github risingwavelabs/risingwave v0.1.12

latest releases: v2.0.1, v1.10.2, v2.0.0...
2 years ago

For installation and running instructions, see Get started.

Main changes

SQL features

  • SQL commands:
    • EXPLAIN now supports specifying options. Supported options: trace, verbose, and type. Unlike PostgreSQL, each option should be separated by a comma and wrapped by parentheses as a whole. #4730
    • Adds support for ALTER USER. #4261
    • CREATE/ALTER USER now has new options CREATEUSER and NOCREATEUSER, which specifiy whether or not the user has the privilege to create, alter, or drop other users. #4447
    • Adds support for EXPLAIN CREATE SINK. #4430
  • SQL functions:
    • Adds support for new system information functions: current_schema, current_schema(), and session_user. #4358
  • The pg_namespace catalog now has a new namespace column nspacl for storing access privileges. #4326

Connectors

  • Some connector parameters were renamed. The old parameter names are still functional but may be deprecated in the future. #4503

    • Kafka & Redpanda

      • kafka.brokers -> properties.bootstrap.server
      • kafka.topic -> topic
      • kafka.scan.startup.mode -> scan.starup.mode
      • kafka.time.offset -> scan.startup.timestamp_millis
      • kafka.consumer.group -> consumer.group.id
    • Kinesis

      • kinesis.stream.name -> stream
      • kinesis.stream.region -> aws.region
      • kinesis.endpoint -> endpoint
      • kinesis.credentials.access -> aws.credentials.access_key_id
      • kinesis.credentials.secret -> aws.credentials.secret_access_key
      • kinesis.credentials.session_token -> aws.credentials.session_token
      • kinesis.assumerole.arn -> aws.credentials.role.arn
      • kinesis.assumerole.external_id -> aws.credentials.role.external_id
    • Pulsar

      • pulsar.topic -> topic
      • pulsar.admin.url -> admin.url
      • pulsar.service.url -> service.url
      • pulsar.scan.startup.mode -> scan.startup.mode
      • pulsar.time.offset -> scan.startup.timestamp_millis
  • The row format name, debezium json, for CDC stream sources, has been renamed to debezium_json. #4494

Configuration changes

  • The default batch query execution mode was changed from distributed to local. #4789

New Contributors

Full Changelog: v0.1.11...v0.1.12

What's Changed

What's Changed

  • chore(docs): update the binary version with new tag by @huangjw806 in #4297
  • feat(frontend): support user alter by @cnissnzg in #4261
  • feat(meta): pause concurrent checkpoint by @BugenZhao in #4269
  • build(toolchain): bump to 20220729 by @TennyZhuang in #4292
  • fix: add retry in wait_epoch by @hzxa21 in #4287
  • feat(frontend): Add pg_catalog.pg_class by @Graphcalibur in #4293
  • feat(sqlsmith): ensure panicked queries are reproducible by @kwannoel in #4228
  • fix(binder): Fix ambiguous column name error message by @Graphcalibur in #4282
  • chore(planner test): upgrade serde_yaml to 0.9 & remove yq by @xxchan in #4307
  • fix(frontend): fix display pk of stream table scan by @chenzl25 in #4279
  • refactor(meta): provide SST id to worker id mapping in commit_epoch. by @zwang28 in #4285
  • feat(batch): support delimiter argument in batch string_agg by @richardchien in #4298
  • feat(object store): add list method by @zwang28 in #4257
  • chore(streaming): remove table id in arrange node by @wcy-fdu in #4281
  • fix: refine error prompting by @neverchanje in #4227
  • feat(S3_bench): Add s3_bench by @xxhZs in #4299
  • feat(metrics): add metrics for barrier latency at each stage by @xxhZs in #3965
  • feat(sqlsmith): enable sub-query generation by @marvenlee2486 in #4216
  • fix: Messages should be skipped after parsing failure by @shanicky in #4317
  • feat(stream): support delim argument in streaming string_agg by @richardchien in #4321
  • feat(sqlsmith): print e2e errors by @kwannoel in #4310
  • fix(optimizer): ApplyValues. by @likg227 in #4323
  • feat(frontend): expose Vnode function as __rw_vnode for easy debugging by @richardchien in #4327
  • fix(frontend): only schedule dml to cn which contain table source writer by @yezizp2012 in #4329
  • feat(risedev): support 3 compute nodes in playground by @BugenZhao in #4332
  • fix(compaction): Skip compaction task assignment check for trivial move tasks by @hzxa21 in #4333
  • refactor(batch): refactor hash join by @wzzzzd in #4017
  • fix(risedev): cannot d after adding shared in-memory hummock support by @BugenZhao in #4353
  • refactor(frontend): rename __rw_vnode to rw_vnode by @richardchien in #4342
  • feat:binary format serializer by @ZENOTME in #4284
  • chore: add metric for sink executor by @tabVersion in #4337
  • fix: use correct column indices for chain & batch lookup join by @BugenZhao in #4346
  • refactor(storage): get new SST id in batch by @zwang28 in #4308
  • feat(compaction): optimize iterator and sstable builder for compaction speed by @Little-Wallace in #4034
  • feat(sqlsmith): test stream queries by @kwannoel in #4361
  • feat(frontend): support acl column in pg_namespace by @cnissnzg in #4326
  • feat(planner): Use explain verbose for all planner tests by @jon-chuang in #4359
  • feat(batch): apply row-based encoding for materialize executor and batch mode by @wcy-fdu in #4335
  • fix(batch): Stop polling after data stream returns None by @liurenjie1024 in #4371
  • refactor(streaming): apply row-based encoding for append_only top_n by @wcy-fdu in #4373
  • refactor(batch): unify scan type in batch scan by @wcy-fdu in #4375
  • fix(storage): fix manual_compaction for l0 sub_compaction by @Li0k in #4334
  • fix(common): use smaller upperbound for generators to avoid range overflow by @wzzzzd in #4377
  • feat(meta): support manual compaction for specific sst ids from CN by @soundOfDestiny in #4338
  • feat(storage): provide prefix_iter for prefix_bloom_filter by @Li0k in #4316
  • feat(storage): introduce filter_key_extractor_manager by @Li0k in #4347
  • refactor(frontend): simplify ConditionDisplay by @xxchan in #4382
  • feat(compaction): collect remote io time for every compaction task by @xinchengxx in #4320
  • refactor(batch): remove append_chunk in nested loop join and hash join by @wzzzzd in #4381
  • feat(planner): Bind Natural Join by @jon-chuang in #4349
  • feat(optimizer): support 2-phase streaming agg by @richardchien in #4341
  • fix(parser): parse negative numbers by @kwannoel in #4356
  • fix: add pair number check in startup msg by @yezizp2012 in #4393
  • feat: generator row id using vnode in source executor by @yezizp2012 in #4362
  • chore(developer-docs): add note on compilation bottlenecks by @kwannoel in #4395
  • refactor(lru): use on_release event listener to capture owned key/value when entries evicted or erased by @MrCroxx in #4396
  • feat(optimizer): Implement ProjectJoin rule by @jon-chuang in #4385
  • refactor(meta): eliminate usages of RwError by @HuaHuaY in #4364
  • feat: support current_schema and session_user by @neverchanje in #4358
  • fix: not report error when encounter UnexpectedEof by @ZENOTME in #4378
  • feat(compaction): support sub-level in L0 by @Little-Wallace in #3111
  • feat(planner): general USING/NATURAL column reference disambiguation by @jon-chuang in #4391
  • feat: kafka sink e2e test by @tabVersion in #4402
  • refactor(expression): make building expression from prost consistent in style by @Gun9niR in #4411
  • chore(sqlsmith): use updated binder interface by @kwannoel in #4408
  • feat(sqlsmith): generate explicit type castings by @kwannoel in #4419
  • feat(sqlsmith): Enable gen_agg but workaround distinct agg by @marvenlee2486 in #4421
  • fix(binder): allow Clone for expr::Subquery as part of CTE by @xiangjinwu in #4424
  • fix(frontend): make WITH optional for user create and alter by @yezizp2012 in #4414
  • fix(frontend): fix table option for internal table by @Li0k in #4416
  • fix: use SomeShard as the distribution of batch scan by @xxchan in #4420
  • feat: support explain sink by @tabVersion in #4430
  • chore: update comments for dispatcher by @xxchan in #4413
  • chore(ci): remove repeated ci steps by @huangjw806 in #4423
  • chore(risedev): unify clippy between risedev c and pre-unit-test.sh by @Li0k in #4436
  • fix: fix observer version check and add sync in compute/compactor node by @yezizp2012 in #4439
  • feat(test): make simulation test deterministic! by @wangrunji0408 in #4336
  • feat(cache): introduce tiered cache abstraction by @MrCroxx in #4406
  • chore: support more query statement in extended query mode by @ZENOTME in #4441
  • fix(ci): fix main ci build timeout by @huangjw806 in #4444
  • refactor(common): add rpc client pool by @zwang28 in #4410
  • fix(cache): clean pending request immediately when future cancel by @Little-Wallace in #4422
  • fix: build on non-linux target by @MrCroxx in #4448
  • feat(meta): piggyback extra info in heartbeat RPC. by @zwang28 in #4435
  • fix(planner): Pullup predicates in LogicalScan into BatchLookupJoin by @jon-chuang in #4453
  • feat(meta): add source info and stream source split info in get_clust… by @KeXiangWang in #4277
  • fix(planner): DynamicFilter's LHS should follow upstream distribution by @jon-chuang in #4452
  • feat(meta): meta push initial hummock version into CN by @soundOfDestiny in #4459
  • feat(frontend): add CREATEUSER and NOCREATEUSER option for user create/alter by @cnissnzg in #4447
  • feat(optimizer): support stateless 2-phase agg optimization for append-only min/max by @richardchien in #4433
  • fix(meta): the ddl lock is not really locked by @KeXiangWang in #4461
  • refactor(row-serde): make row-serde directory clearer and update comments by @wcy-fdu in #4443
  • fix(planner): Tumble can accept CTE as input by @jon-chuang in #4450
  • feat(sqlsmith): generate extreme values by @kwannoel in #4345
  • refactor(sink): rename sink properties by @tabVersion in #4465
  • fix(planner): Disallow select * with no tables by @jon-chuang in #4451
  • fix(worker-node-mgr): worker node manager should return error if no workers found by @BowenXiao1999 in #4466
  • fix(test): fix or ignore several unit tests on madsim by @wangrunji0408 in #4460
  • fix(planner): Correctly Alias CTE and columns by @jon-chuang in #4432
  • feat(frontend): push the calculation of inputs of join's condition to its two sides. by @likg227 in #4276
  • fix: ignore epoch check with stop mutation, this might break some scenarios in failover by @yezizp2012 in #4446
  • chore(risedev): avoid using ambiguous "playground" term with risedev d by @BugenZhao in #4475
  • chore(frontend): tweak visibility & remove dead code & fix clippy by @xxchan in #4472
  • fix(frontend): display InputRef index when column name is empty in explain strings by @richardchien in #4445
  • feat(sqllogictest): sync changes from 0.6 by @skyzh in #4478
  • doc: fix markdown toc by @wanglei4687 in #4477
  • feat(storage): track GC watermark SST id. by @zwang28 in #4369
  • fix(risedev): check clippy should report warning by @skyzh in #4479
  • fix(storage): batch qurry with_table_option by @Li0k in #4464
  • fix(optimizer): push Apply down scalar agg. by @likg227 in #4386
  • feat(storage): GC orphan SST in object store. by @zwang28 in #4370
  • feat(test): make deterministic test ready by @wangrunji0408 in #4476
  • chore(grafana): clean up metric by @zwang28 in #4482
  • fix(optimizer): fix wrong project when output indices having dup keys by @st1page in #4481
  • refactor(frontend,meta): refactor index catalog by @chenzl25 in #4340
  • refactor(meta): remove force rewrite of join -> delta by @skyzh in #4480
  • feat(batch): add more e2e tests for batch join executors by @wzzzzd in #4300
  • fix(binder): reject unsupported not null rather than ignoring silently by @xiangjinwu in #4487
  • feat(batch-task): init task status management by @BowenXiao1999 in #4437
  • test(batch): support generating data of more types in test_utils by @wzzzzd in #4490
  • fix(test): fix pg_class e2e test by @zwang28 in #4488
  • feat(fronted): implement __rw_table() to support query on internal table by @cnissnzg in #4412
  • feat(common): introduce async stack trace by @BugenZhao in #4383
  • fix: allow create source with row format debezium_json by @tabVersion in #4494
  • fix(streaming): no extra buffer for remote exchange by @BugenZhao in #4495
  • feat(stream): support cache for group topN by @shmiwy in #4471
  • refactor(meta): split HummockManager impl into several files. by @zwang28 in #4497
  • feat(optimizer): add functional dependency support by @Enter-tainer in #4201
  • chore(ci): use customized profile for pull requests by @BugenZhao in #4502
  • refactor(meta): add StreamClient struct by @HuaHuaY in #4485
  • feat(expr): cast time to interval for cross-type comparison by @xiangjinwu in #4291
  • fix(meta): fix internal_table notification for mv and snapshot by @Li0k in #4467
  • feat(storage): integrate tiered cache system by @MrCroxx in #4463
  • fix(batch): consume dml status and ensure task id always found by @BowenXiao1999 in #4516
  • fix: drop internal tables when drop table/index by @yezizp2012 in #4499
  • fix: set http2 connection windows size to unlimited by @yuhao-su in #4505
  • feat(CI):add extended_query e2e test in CI by @ZENOTME in #4491
  • refactor(encoding): remove cell-based encoding by @wcy-fdu in #4523
  • refactor(test): remove stream proto test case by @ice1000 in #4519
  • fix(meta): fix stop all actors step of recovery by @cnissnzg in #4525
  • feat(sink): add debezium update in KafkaSink by @cnissnzg in #4486
  • feat(common): support serializing struct and list with array index to memcomparable format by @wzzzzd in #4524
  • fix(compactor): fix estimate memory size for compression by @Little-Wallace in #4484
  • feat(storage): Modify the locks on shared buffer and local version by @xxhZs in #4536
  • feat: support show sink by @tabVersion in #4531
  • feat(expr): support assignment casts for temporal types by @xiangjinwu in #4526
  • feat(ci): add sqlsmith e2e to ci by @kwannoel in #4319
  • chore(sqlsmith): use single-thread tokio runtime by @skyzh in #4348
  • fix(planner): handle invalid hop arguments by @kwannoel in #4537
  • refactor(fragmenter): delete unneeded self. in fragmenter by @ice1000 in #4544
  • fix(meta): LSM/SST metrics is stale when there is no alive compactor by @KivenChen in #4449
  • fix(storage): remove timeout when get compaction group id by @zwang28 in #4542
  • feat(stream key): rename logical_pk && move add count for stream agg in to stream by @st1page in #4539
  • fix(meta): fix catalog notification by @Li0k in #4530
  • feat(connector): better names for connector properties by @TennyZhuang in #4503
  • feat(expr): support casting temporal types to string by @xiangjinwu in #4538
  • fix: file cache append index out of range by @MrCroxx in #4552
  • feat(compactor): split code to more files to make code more readable by @Little-Wallace in #4551
  • refactor(meta): merge UserManager, CatalogManager and FragmentManager(Part 1) by @HuaHuaY in #4541
  • chore: remove debug context and allow to check current context with async stack trace by @BugenZhao in #4535
  • fix(frontend): fix lookup join predicate by @chenzl25 in #4563
  • fix(test): fix deterministic test by @wangrunji0408 in #4550
  • refactor: propose the API semantics of abort_task by @BowenXiao1999 in #4560
  • feat(meta): migration by default when recovery enabled in meta by @cnissnzg in #4568
  • fix(expr): reject flag for regexp_match(es) by @xxchan in #4546
  • refactor(storage): refactor row_serde and storage table to match row-based encoding by @wcy-fdu in #4528
  • fix: stack unwind when profiling by @fuyufjh in #4574
  • feat(optimizer): covering index selection by @chenzl25 in #4520
  • feat(sqlsmith): generate ternary and variadic functions by @kwannoel in #4572
  • feat(compactor): separate compactor options for flush and compact by @Little-Wallace in #4570
  • refactor(stream): extract iter_state_table function by @richardchien in #4583
  • feat(common): support all data types in sort_util by @richardchien in #4582
  • refactor(stream): remove SourceError by @guzzit in #3781
  • refactor(stream,agg): add StateTableColumnMapping to convert column indices by @richardchien in #4584
  • fix(common): fix wrong memcomparable encoding for struct/list/interval by @wzzzzd in #4575
  • feat(optimizer): support non-covering index selection by @chenzl25 in #4587
  • feat(batch): abort task when failed by @BowenXiao1999 in #4578
  • refactor(stream): remove useless state_table_to_upstream method by @richardchien in #4596
  • fix: use UpstreamHashShard distribution for table scan by @xxchan in #4534
  • feat(runtime): replace tokio-tracing with minitrace by @skyzh in #4576
  • fix(sink): resolve schema mismatch due to row_id column by @nanderstabel in #4304
  • fix(test): change name in Sink with properties by @nanderstabel in #4604
  • refactor(expr): support string-to-interval casting by @xiangjinwu in #4595
  • chore(runtime): remove jaeger support by @skyzh in #4606
  • refactor(batch): rewrite OrderByExecutor by @wzzzzd in #4500
  • fix(common): justify intervals before hashing by @wzzzzd in #4600
  • refactor(connector): refine code style & use seperate threads for data generation sources by @BugenZhao in #4564
  • fix(ci): make cron e2e script executable by @kwannoel in #4608
  • chore(metrics): add input_buffer_blocking_duration metrics by @KeXiangWang in #4585
  • fix(index): create index name to lowercase by @st1page in #4613
  • feat: decouple vnode mapping and catalog by @yezizp2012 in #4594
  • fix(common): fix memcomparable encoding for list by @wzzzzd in #4599
  • refactor(stream,agg): refactor GenericExtremeState to get rid of hardcoded assumption on column arrangements by @richardchien in #4592
  • fix(dashboard): fix outdated proto & add new operators by @xxchan in #4602
  • feat(optimizer): pk minimization for join and hop window using functional dependency by @Enter-tainer in #4607
  • refactor(state_store): use binary-search for get prune sst by @xinchengxx in #4573
  • fix(ci): add ci-dev profile flags to main-cron config by @kwannoel in #4624
  • feat(stream): infer group topn's state table catalog in frontend. by @shmiwy in #4597
  • fix(parser): fix parsing right angle brackets by @xxchan in #4627
  • fix: bitmap inconsistent encoding by @xxchan in #4603
  • refactor: simplify the task status and stage state by @BowenXiao1999 in #4629
  • fix(handler): handle quoted names in drop user by @xiangjinwu in #4628
  • refactor(streaming): encode row in hash join operator cache by @yuhao-su in #4630
  • feat(storage): introduce filter_key_extractor for sst builder by @Li0k in #4394
  • chore(pgwire):remove unnecessary infer by @ZENOTME in #4632
  • fix(streaming): fix topn cache for recovery by @chenzl25 in #4631
  • feat: async stack trace middleware for compute-node gRPC by @BugenZhao in #4581
  • refactor(meta): refactor compaction task sending and cancellation. by @zwang28 in #4620
  • feat(object_store): implement streaming upload for s3 and in mem object store by @Gun9niR in #4589
  • fix(config): fix datestyle parameter by @xxchan in #4506
  • feat(state_store): use binary-search for get prune sst by @xinchengxx in #4622
  • fix(optimizer): fix logical scan distribution key by @chenzl25 in #4636
  • test(optimizer):add test for distributed plan by @st1page in #4638
  • fix(meta): Stale SST Metrics without Alive Compactors #4380 by @KivenChen in #4571
  • fix(meta): limit compactor's concurrent task number by @zwang28 in #4633
  • refactor: use macro to iterate fields in struct or elements in list by @neverchanje in #4649
  • refactor: use ellipsis to skip details of Struct by @neverchanje in #4648
  • fix(binder): cte name assert use the real name by @st1page in #4655
  • feat(sstable_store): implement streaming upload for sstable store by @Gun9niR in #4644
  • doc: improve comments of index_selection.rs by @fuyufjh in #4653
  • refactor(meta): use oneof for pin_version response by @wenym1 in #4656
  • test(nexmark): add nexmark q17 e2e test by @TennyZhuang in #4660
  • refactor(frontend,meta): don't infer and create state tables for (stateless) local simple agg by @richardchien in #4661
  • feat(planner): Support nested joins by @jon-chuang in #4401
  • feat(frontend): meta push max_committed_epoch to frontend by @Gun9niR in #4651
  • fix(stream,agg): fix bug of cache maintenance of extreme state by @richardchien in #4659
  • refactor(batch): use memcomparable encoding to accelerate top-n executor by @wzzzzd in #4642
  • feat(batch): support lookup join running in distributed mode by @chenzl25 in #4647
  • fix(protobuf): store offset and limit in uint64 in TopNNode and LimitNode by @wzzzzd in #4666
  • refactor: value encoding error by @fuyufjh in #4671
  • feat(storage): introduce streaming_table write and point-get by @wcy-fdu in #4588
  • refactor(storage): remove common stuff in streaming table by @wcy-fdu in #4679
  • refactor(expr): impl Copy for AggKind to get rid of some clone by @richardchien in #4680
  • feat(batch):add metrics for batch exchange executor by @ZENOTME in #4577
  • feat(storage): move sync_uncommitted tasks and ssts from the shared buffer to the local version by @xxhZs in #4492
  • fix: minstant elapsed do not panic on time goes backward by @BugenZhao in #4668
  • fix(binder): is_correlated for intermediate subquery by @xiangjinwu in #4677
  • feat(compaction): limit memory usage for compaction read by @Little-Wallace in #4590
  • feat(test): parallel e2e test under deterministic simulation by @KveinAxel in #4675
  • feat(streaming): vnode bitmap updates for state table by @BugenZhao in #4621
  • test: add tests for list by @neverchanje in #4689
  • refactor: refine error message of type casting failure by @neverchanje in #4690
  • refactor(stream,agg): pass all columns from stream chunk to managed state by @richardchien in #4676
  • feat(risedev): add slt-batch/streaming/all by @xxchan in #4683
  • fix(optimizer): fix some tests for distributed plan by @xxchan in #4686
  • chore(storage): improve metrics for bloom filter by @Li0k in #4664
  • fix(binder): correct the table name and use alias for table function by @richardchien in #4698
  • feat: use risectl to get flamegraph of compute node by @yuhao-su in #4695
  • feat(optimizer): not use 2 phase for stream agg with group key by @st1page in #4684
  • feat(ctl): add sst gc command by @zwang28 in #4674
  • feat(stream): tolerate compute error by default by @xxchan in #4652
  • chore: replace ensure then remove with try_into by @BugenZhao in #4702
  • refactor: replace Epoch in storage with HummockEpoch by @Gun9niR in #4699
  • chore: fix dashboard worker node info by @yezizp2012 in #4711
  • chore(risedev): add a message for saved profiling result by @xxchan in #4712
  • feat(meta): Enable deterministic unit test manager/cluster/tests/test_heartbeat via #[cfg(madsim)] by @jon-chuang in #4697
  • feat(meta): meta push version deltas to CN by @soundOfDestiny in #4473
  • fix(binder): disallow subquery in BoundValues. by @likg227 in #4579
  • refactor(stream): move actor_id into ctx by @xxchan in #4707
  • feat(expr): directly evaluate on row for macro-generated expressions by @BugenZhao in #4667
  • feat(batch): batch dml support index lookup by @chenzl25 in #4701
  • feat(frontend): add support for array_agg in frontend by @richardchien in #4717
  • refactor(encoding): row deserialize only handle value by @wcy-fdu in #4704
  • fix(frontend): reject invalid string_agg calls in frontend by @richardchien in #4724
  • feat(sqlsmith): support generating string_agg calls by @richardchien in #4725
  • test: add test for Date type by @nanderstabel in #4727
  • fix(meta): fix trigger_manual_compaction incorrect table_id by @Li0k in #4714
  • feat: update row-id generator when vnode mapping changed by @yezizp2012 in #4716
  • feat(storage): filter out SST by watermark in GC. by @zwang28 in #4512
  • fix(metrics): fix iterator metrics data report duplication and lost by @MrCroxx in #4723
  • refactor(stream): remove unnecessary Arc<Mutex> in rearranged_chain by @TennyZhuang in #4731
  • feat(binder): resolve primary key constraint and pass it in StreamSourceInfo.pk_column_ids by @xiangjinwu in #4722
  • refactor(stream_key): rename pk_indices in stream plan to stream_key by @st1page in #4733
  • refactor(table): rename pk into stream key by @st1page in #4732
  • fix(opt): dist of batch expand by @st1page in #4718
  • ci(test): add deterministic parallel e2e test by @wangrunji0408 in #4738
  • feat(storage): Upload all data to shared storage as a sstable by @xxhZs in #4442
  • test(batch): add more e2e tests for OrderBy/TopN/Limit by @wzzzzd in #4744
  • chore(deps): bump dependencies by @BugenZhao in #4749
  • feat: set the field names in DataType::Struct by @neverchanje in #4669
  • feat(compaction): support compact several files for overlap-strategy by @Little-Wallace in #4619
  • chore: migrate logging from log to tracing by @wangrunji0408 in #4745
  • fix(storage): fix incorrect lock order by @zwang28 in #4753
  • chore(parser): remove todo for parsing nested negative expressions by @kwannoel in #4758
  • fix(binder): fix panic when index on non composite type by @nanderstabel in #4763
  • feat(stream): new boxed group_top_n executor from proto by @shmiwy in #4682
  • feat(batch): prepare for union operator by @chenzl25 in #4761
  • chore: fix typos & add typo checker to ci by @xxchan in #4767
  • refactor(meta): indicate worker expircy in status code. by @zwang28 in #4739
  • chore: improve some error message display by @xxchan in #4770
  • fix: a potential conflict of task output channel in lookup join by @BowenXiao1999 in #4746
  • chore: remove unnecessary macro for hummock matrics by @MrCroxx in #4772
  • feat(meta): release privileges when dropping catalog by @HuaHuaY in #4742
  • chore(deps): bump pulsar-rs to remove prost 0.10 dep by @BugenZhao in #4771
  • feat(metrics): show compaction result by compactor-node by @Little-Wallace in #4775
  • refactor(storage): remove shared buffer when an epoch is being synced by @wenym1 in #4773
  • fix(risedev): replace shell with bash by @yuhao-su in #4783
  • feat(tracing): print slow request with minitrace by @TennyZhuang in #4778
  • chore(streaming): use separate runtime for actors by @BugenZhao in #4756
  • refactor(storage): relax assumption in sst id tracker by @zwang28 in #4548
  • feat: enforce chain parallelism and fill proper upstream with same vnode range by @yezizp2012 in #4740
  • refactor(batch): Make local mode default by @liurenjie1024 in #4789
  • fix(dashboard): add expand for visualization by @TennyZhuang in #4791
  • fix: cargo run playground by @fuyufjh in #4792
  • test: add nexmark q15 into e2e tests by @fuyufjh in #4793
  • fix(optimizer): fix logical scan clone with predicate by @chenzl25 in #4796
  • feat(ci): randomly pick from multiple frontends in parallel e2e by @BugenZhao in #4795
  • fix(compactor): fix drop mv stuck by @Li0k in #4798
  • chore(source): add more field in nexmark by @KeXiangWang in #4802
  • feat(risedev): add a command to open rust docs by @xxchan in #4794
  • fix(frontend): Change the column name in the table pg_class to be compatible with PostgreSQL by @HuaHuaY in #4809
  • feat(frontend): support casting between arrays by @wzzzzd in #4741
  • feat(plan-test): suggest run-planner-test instead of using panic hook by @xxchan in #4800
  • chore: extract max cache size as const by @fuyufjh in #4812
  • fix(sqlsmith): use distributed execution mode to avoid overflows by @kwannoel in #4806
  • refactor(batch,agg): get rid of two slightly different output methods by @richardchien in #4816
  • fix(meta): fix source notification by @Li0k in #4818
  • chore(risedev): use command line argument for async stack trace by @BugenZhao in #4808
  • feat(metrics): introduce tiered cache metrics by @MrCroxx in #4786
  • fix(local_version): fix deadlock bug by @Little-Wallace in #4810
  • feat(storage): introduce streaming table iter by @wcy-fdu in #4787
  • test: add nexmark q20 by @fuyufjh in #4804
  • fix: make debezium work again by @tabVersion in #4781
  • refactor(frontend): check the validity of ApproxCountDistinct and Count in frontend by @richardchien in #4825
  • feat(optimizer): support index merge optimization by @chenzl25 in #4820
  • feat(metrics): add media type label to object store latency metric by @StrikeW in #4713
  • feat(storage): Initial interfaces for shared buffer redesign by @hzxa21 in #4780
  • refactor(batch,agg): improve creation of agg states by @richardchien in #4824
  • fix(optimizer): fix the bug of selective distinct aggregates. by @likg227 in #4673
  • fix(metrics): fix tiered cache metrics p99 tag by @MrCroxx in #4846
  • fix(binder): depth for has_correlated_input_ref is on Query rather than Select by @xiangjinwu in #4840
  • feat(storage): add sanity check in streaming table and fix range of MemTable by @wcy-fdu in #4832
  • feat(compactor): cancel compact task when no idle compactor by @Little-Wallace in #4830
  • chore(planner, sqlsmith): bump libtest-mimic by @kwannoel in #4837
  • chore: migrate issue template to issue forms by @xxchan in #4859
  • refactor(storage): apply streaming table for all executors and remove origin StateTable and MemTable by @wcy-fdu in #4854
  • chore(ci): introduce ci-release profile for main CI by @BugenZhao in #4863
  • refactor(frontend): refine the doc & impl for batch traits by @xxchan in #4826
  • feat(planner_test): print better debugging message for panics by @kwannoel in #4867
  • feat(batch): add task level metrics delete by @ZENOTME in #4757
  • fix(sqlsmith): disable single value by @kwannoel in #4865
  • refactor(binder): consolidate expr iterators on Select and Values by @xiangjinwu in #4853
  • feat(test): test fault-recovery on madsim by @wangrunji0408 in #4843
  • fix(storage): fix GC watermark id by @zwang28 in #4839
  • test: add e2e test for debezium cdc source by @tabVersion in #4835
  • fix(risedev): provide client-address for compactor by @zwang28 in #4872
  • fix(barrier): Fix bug about barrier collect by @xxhZs in #4813
  • feat(frontend): support primary key of tables by @wzzzzd in #4852
  • feat(batch,bench): add microbench for batch hash agg by @richardchien in #4838
  • chore: rename source ci following new naming by @tabVersion in #4874
  • feat: support heap profiling from risedev by @fuyufjh in #4871
  • refactor(streaming): refactor look up executor to use streaming table by @wcy-fdu in #4879
  • fix: use offsets in ListRef::value_at() by @nanderstabel in #4831
  • feat(compaction): refactor compactor executor to reduce thread context switch by @Little-Wallace in #4750
  • feat(test): support sync point for integration test by @zwang28 in #4855
  • feat(batch,agg): support array_agg for batch mode by @richardchien in #4862
  • feat(batch): monitor task pending and execution time by @wzzzzd in #4799
  • feat(optimizer): improve index range cost by @chenzl25 in #4877
  • fix(compactor): fix version get for trivial_move by @Li0k in #4890
  • feat: add metrics of stream join cached rows & entries by @fuyufjh in #4891
  • chore(expr): cleanup all RwErrors by @BugenZhao in #4873
  • feat(stream,agg): support array_agg for streaming mode by @richardchien in #4895
  • feat(parser): parse explain by @st1page in #4730
  • feat(optimizer): support or condition for scan range by @chenzl25 in #4851
  • fix(sstable): use accurate uncompressed size to avoid grow up vector by @Little-Wallace in #4878
  • chore: print warning message when client address is not specified by @Gun9niR in #4876
  • feat(storage): add current_epoch to support decoupling by @xxhZs in #4760
  • chore: bump madsim to support coarse clock by @BugenZhao in #4901
  • chore(ci): use one session for each file in serial mode e2e tests by @xxchan in #4902
  • fix(opt): fix rewrite_provided_distribution by @st1page in #4904
  • feat(optimizer): simplify expand by @likg227 in #4591
  • fix(source): introduce state_table_id as state store prefix by @tabVersion in #4897
  • feat: Make tpch distributed explicitly by @liurenjie1024 in #4905
  • feat: Storage: Support batch delete in object store by @ALeitert in #4823
  • refactor(frontend): generate meaningful identify for PlanNode by @ZENOTME in #4889
  • refactor: simplify error handling of sink by @neverchanje in #4848
  • refactor: rename DebugExecutor to WrapperExecutor by @fuyufjh in #4899

New Contributors

Full Changelog: v0.1.11...v0.1.12

Don't miss a new risingwave release

NewReleases is sending notifications on new releases.