Skip to content

Releases: risingwavelabs/risingwave

v0.1.12

19 Sep 06:38
Compare
Choose a tag to compare

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

Read more

v0.1.11

29 Jul 09:48
d91bdef
Compare
Choose a tag to compare

What's Changed

  • test(nexmark): rewrite flinksql function to the corresponding pg one by @TennyZhuang in #3654
  • refactor: remove OrderedColumnDesc from proto by @xxchan in #3642
  • feat(meta): do not use watermark as expire time of TTL by @Little-Wallace in #3633
  • fix(lookup): fix the semantics of arrange_order_rules by @BowenXiao1999 in #3655
  • chore(docs): update the binary version to v0.1.10 by @huangjw806 in #3661
  • test(batch): add micro benchmark for NestedLoopJoinExecutor by @wzzzzd in #3652
  • feat(meta): no pause checkpoint with building actor by @xxhZs in #3511
  • feat: expand operator by @likg227 in #3563
  • fix(meta): fix internal_table persisted by @Li0k in #3659
  • feat(frontend): support show config by @yezizp2012 in #3664
  • feat(frontend): StreamDynamicFilter by @jon-chuang in #3515
  • feat(storage): support vnode hint in storage table by @BugenZhao in #3628
  • refactor:introduce per crate error for batch executors by @ZENOTME in #3658
  • fix(docs): fix regress test input file path by @lmatz in #3667
  • test(nexmark): support explain nexmark q15 and q20 by @TennyZhuang in #3660
  • fix(metrics): use iter_in_process_count to replace iter_count_duration by @Li0k in #3678
  • fix(expr, executor): Remove RowExpression: use eval_row and unwrap_or(false) on Datum, not panic on Null/None by @jon-chuang in #3587
  • feat(meta): do not persist data on etcd for pin_snapshot by @Little-Wallace in #3557
  • refactor(streaming): better source executor & split change by @BugenZhao in #3669
  • fix: avoid unnecessary cells in max/min (not-append only) by @BowenXiao1999 in #3630
  • perf(hummock manager): apply version delta from version checkpoint by @soundOfDestiny in #3567
  • chore(ci): use random seed for sqlsmith cron test by @huangjw806 in #3688
  • feat: add overlay string function by @ALeitert in #3671
  • feat(batch): enable parallel table scan by @xxchan in #3670
  • refactor(storage): remove async_trait for MergeIteratorNext by @KivenChen in #3673
  • chore(doc): rename cell-based table to storage table by @wcy-fdu in #3691
  • feat(metrics): add metrics for compact task splits count by @Li0k in #3693
  • feat(frontend): support show all (#3665) by @chenzl25 in #3694
  • chore: fix rustdoc for prost by @xxchan in #3699
  • refactor: consolidate duplicated logic in PlanRoot by @xiangjinwu in #3554
  • feat(expr): support regexp_match by @TennyZhuang in #3702
  • chore(deps): bump openssl-src from 111.20.0+1.1.1o to 111.22.0+1.1.1q by @dependabot in #3701
  • doc: add some comments for keys & rename keys -> key by @xxchan in #3700
  • feat(streaming): allow pause source by @skyzh in #3697
  • feat(meta): allow set parallel degree in config by @skyzh in #3703
  • feat(batch): Implement LookupJoinExecutor by @Graphcalibur in #3614
  • fix(array): ListRef Display by @nanderstabel in #3705
  • feat(meta): add monitoring meta process metrics by @wenym1 in #3706
  • fix: reduce logging in the critical path by @neverchanje in #3704
  • refactor(optimizer): cleanup LogicalAgg::prune_col by @xiangjinwu in #3663
  • fix: correctly implement check_state_consistency by @zwang28 in #3711
  • feat(storage): default block size = 1024 by @skyzh in #3463
  • feat(batch): prune scan partition according to scan_range by @xxchan in #3698
  • test(nexmark): explain q16 q17 by @TennyZhuang in #3715
  • doc: add relational table schema doc + move files by @BowenXiao1999 in #3712
  • fix: fix heartbeat req field and meta client impl by @yezizp2012 in #3716
  • fix(metrics): use current actor id for backpressure by @skyzh in #3721
  • test(streaming): enable streaming e2e test for tpch q4, q18, q20 by @yuhao-su in #3718
  • chore(deps): bump dependencies by @skyzh in #3725
  • feat(executor): Basic in-application-memory DynamicFilterExecutor, pass tpch q11, q22 e2e tests by @jon-chuang in #3681
  • refactor(sqlparser): rename parse_string_agg to parse_string_concat by @richardchien in #3733
  • fix(risedev): Revert Makefile.toml changes by @Graphcalibur in #3732
  • fix: support decimal mul interval by @neverchanje in #3734
  • refactor(storage): remove cell_based serialize/deserialize from serde by @wcy-fdu in #3722
  • fix(sqlsmith): completely cover all exprs by @neverchanje in #3737
  • fix(ci): use header fix action for license check by @skyzh in #3739
  • chore(risedev): update grafana version by @wcy-fdu in #3731
  • test(nexmark): add nexmark q10 q14 e2e test by @TennyZhuang in #3740
  • refactor(streaming): use table catalog in hash join by @yuhao-su in #3707
  • fix(batch): fix batch scan distribution & handle more than one table scans in one stage by @xxchan in #3736
  • feat(optimizer): support two phase topn and limit in batch mode by @chenzl25 in #3719
  • feat: deprecate catalog ref id by @yezizp2012 in #3745
  • refactor(streaming): use table catalog for materialize executor by @wcy-fdu in #3742
  • refactor(meta): improve create mview / scheduler readability by @BugenZhao in #3748
  • feat(metrics): Add Fragment Level Exchange Metrics by @marvenlee2486 in #3696
  • fix(risedev): unexpected rebuilds on Linux by @skyzh in #3761
  • perf(hummmock manager): remove unnecessary hummock version deltas by @soundOfDestiny in #3689
  • fix: sync compaction group correctly by @zwang28 in #3743
  • feat(common): move observer_manager to common service by @xxhZs in #3754
  • refactor: remove vnode_mappings in CompactTask and GroupedSstableBuilder by @hzxa21 in #3764
  • refactor(batch): say goodbye to the state machine in NLJ by @wzzzzd in #3724
  • feat(common): add is_set to BitmapBuilder by @wzzzzd in #3768
  • fix(batch): add first-match optimization for left semi join by @wzzzzd in #3773
  • feat(streaming): use multiple dispatcher for mview creation by @BugenZhao in #3758
  • refactor(stream): refactor state of topN executor to one state table by @StrikeW in #3747
  • chore(storage): remove value meta by @Li0k in #3779
  • feat(executor): Use TableCatalog and StateTable in DynamicFilter (only writes) by @jon-chuang in #3757
  • fix(batch): fix order_by with struct table by @StrikeW in htt...
Read more

v0.1.10

05 Jul 08:48
2df3440
Compare
Choose a tag to compare

For a quick summary on this release, see Release Notes for more information.

What's Changed

Read more

v0.1.9

08 Jun 10:37
68c893e
Compare
Choose a tag to compare

This is a special out-of-schedule release for the new build pipeline.

What's Changed

  • feat(stream): support replace source reader at runtime by @tabVersion in #2923
  • feat(expr): Implementation for bitwise operation by @marvenlee2486 in #2884
  • fix(types): reduce [Struct/List]Value memory usage and fix Decimal data_size by @TennyZhuang in #2970
  • feat(expr): Implementation for bitwise operation (Continue PR #2884) by @marvenlee2486 in #2975
  • chore(ci): speedup unit test by @skyzh in #2974
  • feat(build): drop support for TiKV and RocksDB, and speedup compile by @skyzh in #2982
  • fix(risedev): apply-frontend-test on macOS by @skyzh in #2983
  • feat(build): link openssl statically by @skyzh in #2984
  • feat(grafana): use Python script to generate dashboard by @skyzh in #2979
  • chore(risedev): store kafka and frontend config when compose deploy by @skyzh in #2988
  • refactor(storage): avoid KeyRange type conversion by @zwang28 in #2920
  • feat(expr): Implement approx_count_distinct for batch queries by @Graphcalibur in #2977
  • feat(vnode bitmap): implement vnode-aware overlap in compaction by @soundOfDestiny in #2864
  • chore(test): prevent test compile OOM by @skyzh in #2989
  • feat: add hummock rpc unpin_snapshot_before by @BowenXiao1999 in #2964
  • feat(streaming): use table_id as AppendOnlytopN prefix for keyspace by @Li0k in #2992
  • feat(optimizer): pushdown predicate to LogicalScan by @xxchan in #2987
  • feat: enable exchange operator on frontend to send local execution mode request by @lmatz in #2978
  • chore(grafana): add estimated s3 cost by @skyzh in #3000
  • fix: remove unsafe impl Sync trait for LruCacheShard by @MrCroxx in #2996
  • chore: Ignore commits in the blame view by @xxchan in #2995
  • feat(streaming): record internal_table_ids to TableFragments by @Li0k in #3002
  • chore(ci): migrate docker build pipeline by @huangjw806 in #2990
  • feat: support linking to different database by @cykbls01 in #2751
  • fix(test): unit test of chain executor by @lokax in #2817
  • chore(risedev): allow minio to be used on root disk by @skyzh in #3012
  • feat(meta): record total size of files in version by @Little-Wallace in #2965
  • feat(streaming): source executor use table_id for keyspace prefix by @Li0k in #3010
  • fix(streaming): fix some test with keyspace::table_root by @Li0k in #3018
  • chore(build): bump deps by @skyzh in #3019
  • refactor(kinesis): Correct assume_role_external_id spelling in Kine… by @ryanrussell in #3016
  • feat(risedev): support ipv6 in config by @skyzh in #3011
  • fix(connector): use bound channel for source by @skyzh in #3023
  • feat: support grant/revoke privilege in frontend by @yezizp2012 in #3004
  • feat(storage): support write anytime and spill to disk by @wenym1 in #2919
  • feat(stream): introduce allocator_api in JoinHashMap by @TennyZhuang in #3020
  • refactor(DataChunk): use new rather than DataChunkBuilder or try_from by @xiangjinwu in #3026
  • chore(streaming): add assert check for internal_table_id_set to avoid… by @Li0k in #3025
  • fix: should always unpin epoch for dml query by @BowenXiao1999 in #3034
  • fix(config): parameters are case insensitive in set command by @lmatz in #3033
  • feat(compaction): notify meta when hash mapping changes by @soundOfDestiny in #3035
  • feat(meta): initiate static compaction groups by @zwang28 in #2952
  • perf(executor): decode row datums from pk by @kwannoel in #2957
  • feat(storage): introduce non-proto type for vnode bitmap by @xx01cyx in #3030
  • feat(relational_iter): add state_table_iter with pk_prefix and pk_bounds by @wcy-fdu in #3008
  • feat(pgwire): introduce simple extended query mode by @ZENOTME in #2961
  • feat(expr): implementation for char_length operation by @nasnoisaac in #2991
  • feat(storage): support parallel upload by @skyzh in #3031
  • feat: use unpin_snapshot_before in FE by @BowenXiao1999 in #2993
  • chore: remove scan_with_start_key by @wcy-fdu in #3048
  • chore(docs): bump to 0.1.8 and update CI badge by @skyzh in #3056
  • feat(ci): parallelize e2e test by @skyzh in #3046
  • feat(storage): support concurrent upload in capacity split sst builder by @wenym1 in #3052
  • refactor(session): error when setting unrecognized configuration parameter by @lmatz in #3042
  • release: v0.1.9 by @huangjw806 in #3062
  • fix: the signature unmatch in async trait function by @BowenXiao1999 in #3068
  • fix(connector): remove redundant warning by @tabVersion in #3072
  • chore(ci): migrate release pipeline by @huangjw806 in #3070
  • chore(docs): change risingwave logo in readme by @mikechesterwang in #3076

New Contributors

Full Changelog: v0.1.8...v0.1.9

v0.1.8

03 Jun 05:41
5564b88
Compare
Choose a tag to compare

What's Changed

Click to Expand
Read more

v0.1.7

16 May 02:51
13d35d0
Compare
Choose a tag to compare

What's Changed

Click to Expand
  • feat(frontend/expr): boolean constant folding for (Is, IsNot) x (True, False, Null) by @Enter-tainer in #2265
  • feat(frontend): bind & plan having by @xiangjinwu in #2273
  • docs: re-release v0.1.6 by @skyzh in #2274
  • fix(planner): report unsupported post-agg correlated subquery by @xiangjinwu in #2276
  • e2e(tpch): open some tpch with changing query workaround by @st1page in #2262
  • refactor(relational-table): support serialize pk only by @BowenXiao1999 in #2277
  • feat(planner): support SELECT DISTINCT by @xiangjinwu in #2278
  • chore(frontend): add run-planner-test for risedev by @skyzh in #2282
  • feat(frontend): support distinct within agg call by @xiangjinwu in #2281
  • feat(storage): use binary search to locate SST iterators by @pleiadesian in #2256
  • feat(risedev): differentiate listen addr and advertise addr by @skyzh in #2286
  • refactor(batch): Use futures-async-stream to implement SortMergeJoin executor by @D2Lark in #2216
  • refactor(batch): Use futures-async-stream to implement MergeSortExchange executor by @D2Lark in #2230
  • refactor(stream): reorganize executor builders by @wangrunji0408 in #2289
  • feat(docker): add compactor and single binary into dockerfile by @skyzh in #2294
  • chore(storage): rename reverse to backward by @lmatz in #2298
  • feat(risedev): generate docker-compose.yaml by @skyzh in #2288
  • refactor(stream): rename executor_v2 back to executor by @wangrunji0408 in #2292
  • feat(docker): separate image of each component by @skyzh in #2299
  • chore(relational-table): store zero bytes for sentinel columns by @BowenXiao1999 in #2296
  • refactor(batch): Use futures-async-stream to implement NestedLoopJoin executor by @D2Lark in #2217
  • fix(state-store): fix a dead lock in memory state store by @BowenXiao1999 in #2302
  • refactor(proto): clean up unused methods in risingwave_pb by @TennyZhuang in #2303
  • feat(risedev): support compose minio and redpanda by @skyzh in #2297
  • ci: fix cron invalid workflow by @TennyZhuang in #2307
  • feat(meta): ensure chain index is placed at the same node of upstream by @skyzh in #2270
  • feat(docker): add compactor in compose file by @skyzh in #2306
  • chore(frontend): add test for delta join with projection by @skyzh in #2314
  • chore(batch): remove outdated TODO in MergeSortExchangeExecutor by @lmatz in #2316
  • feat(source): Add nexmark as source connector by @KeXiangWang in #540
  • feat(array): implement TrustedLen for ArrayIterator and ArrayImplIterator by @LittleFall in #2309
  • test: add nexmark e2e by @neverchanje in #2305
  • feat(frontend): add nexmark planner test by @skyzh in #2321
  • test: add aggregation tests for tumble window by @TennyZhuang in #2322
  • refactor(batch): Use futures-async-stream to implement OrderBy executor by @liurenjie1024 in #2327
  • refactor(batch): refine sort agg by @StrikeW in #2313
  • feat(bitmap): store bitmap in meta store by @soundOfDestiny in #2252
  • fix(frontend): fix panic on LogicalHopWindow::prune_col by @Enter-tainer in #2328
  • feat(util): introduce non-memcomparable value encoding for Datum by @WindowsXp-Beta in #2067
  • perf(bitmap): avoid virtualnode bitmap clone by @soundOfDestiny in #2330
  • refactor(meta): add dedicated error enum for hummock meta. by @zwang28 in #2325
  • feat(risedev): support compose prometheus by @skyzh in #2310
  • refactor(storage): better cell based table serialization by @skyzh in #2340
  • e2e(batch): open more tpch batch e2e test by @st1page in #2345
  • feat(storage): vacuum a larger set of ssts by @lmatz in #2315
  • metrics(hummock): add hummock version size metric by @hzxa21 in #2348
  • feat(frontend): order by arbitrary expr by @likg227 in #2329
  • feat(source): support source failover & refactor by @tabVersion in #2257
  • fix(optimizer): logical_hop_window column prune by @Enter-tainer in #2347
  • feat(optimizer): outer join simplify by @st1page in #2349
  • refactor: use primitive array to implement chrono & interval by @xxchan in #2352
  • feat: implement nullif and coalesce function by @cykbls01 in #2308
  • test: add aggregation tests for hop window by @TennyZhuang in #2354
  • feat: Add to_local method to generate local execution lan by @liurenjie1024 in #2335
  • feat(storage): add GroupedSstableBuilder by @zwang28 in #2353
  • feat(streaming): split chunks in source executor by @pleiadesian in #2361
  • fix(dashboard-v2): failed to render because API is changed by @mikechesterwang in #2368
  • perf(storage): make get_key use vnode bitmap filter by @soundOfDestiny in #2341
  • fix(builder): make caller(builder) call get_table_id with new interface by @soundOfDestiny in #2373
  • feat(bitmap): remove old bitmap in sstablemeta by @soundOfDestiny in #2376
  • chore(ci): enable license checker for forks by @skyzh in #2378
  • fix(lru cache): fix a bug when releasing the handle of a stale value by @wenym1 in #2381
  • chore: increase e2e timeout before fine tune hummock compaction by @zwang28 in #2385
  • feat(storage): use the highest bit of sstable id to mark the sstable id generated from remote or local by @wenym1 in #2386
  • feat(compaction): support dynamic leveled-compaction by @Little-Wallace in #2242
  • fix: Frontend doesn't handle left semi join correctly. by @jon-chuang in #2363
  • refactor(binder): use align_types for coalesce by @xiangjinwu in #2382
  • feat(compaction) optimize performance when trigger and apply compaction by @Little-Wallace in #2395
  • test(compaction): re-enable ignored test by @soundOfDestiny in #2380
  • fix(connector): kinesis impl is mismatched to pulsar by @tabVersion in #2390
  • logging(storage): add more error logs in hummock by @hzxa21 in #2351
  • feat(meta): send vnode mapping to compactor on compaction by @xx01cyx in #2388
  • fix(streaming): inappropriate serialization for JoinRow by @yuhao-su in #2398
  • refactor(bitmap): remove limit of bitmaps in SST by @soundOfDestiny in #2399
  • refactor(batch): enable GenericExchangeExecutor2 poll all the sources by @D2Lark in #2372
  • fix: fix failpoint tests and add to CI by @hzxa21 in #23...
Read more

v0.1.6

03 May 06:12
d75b905
Compare
Choose a tag to compare

What's Changed

Click to Expand
Read more

v0.1.5

08 Apr 07:24
d41a605
Compare
Choose a tag to compare

Features

Fixes

Refactors

  • refactor(pgwire): Match on char to avoid utf8 convert (#1506 by @Xuanwo)
  • refactor(storage): use concrete value in value meta instead of bytes (#1501 by @xx01cyx)
  • refactor(stream): remove async_trait from dispatcher (#1489 by @lmatz)
  • refactor: Remove/combine some metrics. (#1534 by @twocode)
  • refactor(storage): set apart value meta and user value in HummockValue (#1552 by @xx01cyx)
  • refactor: extract boolean env var parse (#1553 by @BugenZhao)
  • refactor(expr): simplify gen_binary_expr_atm (#1568 by @TennyZhuang)
  • refactor(batch): return Err when polling finished executor (#1544 by @Enter-tainer)
  • refactor: remove char type (#1555 by @neverchanje)
  • refactor(streaming): clearer logic in merge v2 (#1605 by @BugenZhao)
  • refactor(stream): SimpleExecutor::map_chunk => map_filter_chunk (#1611 by @TennyZhuang)
  • refactor: use enum-as-inner to generate as_xxx functions (#1644 by @BugenZhao)
  • refactor: Break dependencies between risingwave_meta and risingwave_storage (#1608 by @hzxa21)
  • refactor: reduce duplicated code on create source and create table (#1665 by @neverchanje)
  • refactor(expr): simplify type_infer (#1674 by @TennyZhuang)
  • refactor(storage): add storage error type (#1667 by @BugenZhao)
  • refactor: S3FileReader adapts to the new SourceReader trait (#1641 by @pangzhenzhou)
  • refactor: simplify FrontendMetaClient (#1686 by @hzxa21)

Tests

Others

Uncategorized

v0.1.4

01 Apr 03:49
7dd6cdb
Compare
Choose a tag to compare

Features

  • feat(ci): add tar packaging in release workflow (#1449 by @skyzh)
  • feat(meta): Gracefully shutdown actors during compute node failover (#1428 by @zbzbw)
  • feat: replace proto sstable meta with self managed struct (#1447 by @MrCroxx)
  • feat: use arc for sstable meta cache (#1462 by @MrCroxx)
  • feat(frontend): support round function (#1446 by @neverchanje)
  • feat(frontend): support TPC-H Q1 Q5 (#1460 by @skyzh)
  • feat(streaming): introduce async-stream based ChainExecutorV2 (#1469 by @BugenZhao)
  • feat(binder): support table alias (#1480 by @xiangjinwu)
  • feat: flush after write, also fixed some avg problems (#1485 by @neverchanje)
  • feat(storage): support value meta in storage (#1471 by @xx01cyx)
  • feat: improve display format of literals (#1494 by @fuyufjh)

Fixes

  • fix(meta): fix fragmenter upstream actors setup (#1451 by @yezizp2012)
  • fix: fix vacuuming SSTables in aborted epochs (#1454 by @hzxa21)
  • fix(doc): doc under stream crate (#1461 by @lmatz)
  • fix: move profile config from package to workspace (#1483 by @MrCroxx)
  • fix(doc): use the right path for doc links (#1478 by @lmatz)

Refactors

Tests

Others

Uncategorized

v0.1.4-alpha

31 Mar 05:04
Compare
Choose a tag to compare

Features

  • feat: add barrier latency monitor (#553 by @wcy-fdu)
  • feat: Propagate the CreateMview mutation barrier to init executor epoch (#511 by @hzxa21)
  • feat(stream): fetch hash agg state in parallel (#568 by @pleiadesian)
  • feat(bummock): introduce indexing storage (#573 by @twocode)
  • feat(stream): add reset for stream executor (#557 by @yezizp2012)
  • feat: Introducing new subquery decorreclator (#594 by @liurenjie1024)
  • feat: add more metrics for StateStore (#555 by @zehaowei)
  • feat: Introduce join push expression rule. (#603 by @liurenjie1024)
  • feat: Introduce an auto-discovery for S3 Bucket files for Filesystem connector (#608 by @pangzhenzhou)
  • feat: Introducing SimplifyFilterConditionRule (#614 by @liurenjie1024)
  • feat: Support async checkpoint with hummock shared buffer (#602 by @hzxa21)
  • feat(meta): add CompactorManager (#556 by @zwang28)
  • feat: Introducing SimplifyFilterConditionRuleTest (#637 by @liurenjie1024)
  • feat(meta): introduce consistent hash logic (#626 by @xx01cyx)
  • feat(frontend): pull common factors from OR's operands in join (#664 by @lmatz)
  • feat: support shared buffer reset (#629) (#659 by @hzxa21)
  • feat: add scan metrics (#662 by @zehaowei)
  • feat: Introducing JoinConditionTypeCoerceRule (#663 by @liurenjie1024)
  • feat: refine the storage configurations on compute node. (#676 by @twocode)
  • feat: support catalog update (#567 by @HuaHuaY)
  • feat(planner): Introducing RewriteSubQueryRule (#684 by @liurenjie1024)
  • feat(frontend): bind project (#615 by @likg227)
  • feat(meta): support etcd as MetaStore backend (#681 by @TennyZhuang)
  • feat: add offset for source message (#679 by @shanicky)
  • feat(optimizer): column pruning for filter and scan (#693 by @xxchan)
  • feat(risedev): support etcd meta store backend in risedev (#707 by @TennyZhuang)
  • feat(optimizer): Introducing subquery removal rule. (#713 by @liurenjie1024)
  • feat(frontend): LogicalFilter (#685 by @mczhuang)
  • feat(compaction): stat sst upload cnt during compaction (#699 by @soundOfDestiny)
  • feat: support binding functions and unary exprs (#694 by @neverchanje)
  • feat(frontend): add execution context to replace session impl (#714 by @BowenXiao1999)
  • feat(optimizer): implement column pruning for value, project, agg (#710 by @xxchan)
  • feat: asynchronous shared buffer sync (#722 by @BugenZhao)
  • feat: Array parsing support (#604 by @nanderstabel)
  • feat(risedev): load previous components during configure (#750 by @TennyZhuang)
  • feat: New subquery optimizer program. (#752 by @liurenjie1024)
  • feat(storage): support replicate batch (aka remote write) (#718 by @skyzh)
  • feat(compaction): compact idle levels with high priority (#739 by @soundOfDestiny)
  • feat(hummock): vacuum tracked SSTs and metadata. (#725 by @zwang28)
  • feat(optimizer): implement column pruning for topn & join (#733 by @xxchan)
  • feat(planner): integrate with PlanRoot (#726 by @xiangjinwu)
  • feat: report failed actors in barrier manager (#759 by @BugenZhao)
  • feat(ss-bench): support calibrating metric parameter (#740 by @Sunt-ing)
  • feat(ctl): support list Hummock version (#758 by @skyzh)
  • feat(ctl): support list key-value pairs (#782 by @skyzh)
  • feat(optimizer): plan node base (#748 by @st1page)
  • feat: support all-in-one binary (#796 by @skyzh)
  • feat(join): add semi/anti join support (#644 by @BowenXiao1999)
  • feat(compaction): add more metrics into compaction (#771 by @soundOfDestiny)
  • feat(risedev): support all-in-one binary (#799 by @skyzh)
  • feat(compaction): add read/write amount metrics for compaction (#807 by @soundOfDestiny)
  • feat(frontend): use new subquery rewriter in stream planner (#809 by @lmatz)
  • feat: Use version to synchronize catalog (#749 by @HuaHuaY)
  • feat(risedev): warn on no_proxy (#814 by @skyzh)
  • feat(streaming): implement basic logic of lookup executor (#819 by @skyzh)
  • feat(frontend): derive primary key for anti and semi join (#816 by @lmatz)
  • feat(optimizer): Add filter join rule (#808 by @xxchan)
  • feat(streaming): implement lookup row from storage (#822 by @skyzh)
  • feat: add single_value agg function (#824 by @lmatz)
  • feat(frontend): make expr in explain output concise (#802 by @xiangjinwu)
  • feat(catalog): add descriptor for cellbased table (#815 by @st1page)
  • feat: Convert GRPC results to Row (#812 by @cykbls01)
  • feat(planner/optimizer): introduce query context in plan node + id assign for each plan node (#821 by @BowenXiao1999)
  • feat: add notification for catalog-v2 (#850 by @yezizp2012)
  • feat(risectl): move hummock to subcommand (#855 by @skyzh)
  • feat(cmd): add zero-configuration playground to all-in-one binary (#853 by @TennyZhuang)
  • feat(streaming): add unit tests for lookup executor (#851 by @skyzh)
  • feat(risedev): create .bin and link risingwave (#857 by @skyzh)
  • feat(meta): enable heartbeat detection. (#830 by @zwang28)
  • feat: add catalog service v2 proto definition (#867 by @yezizp2012)
  • feat(meta): distinguish and assign responsibilities for different parallel units (simple dispatch and hash dispatch) (#846 by @xx01cyx)
  • feat(storage): support read epoch for in-memory state backend (#874 by @skyzh)
  • feat(planner): plan inner join (#876 by @TennyZhuang)
  • feat(frontend): support BatchInsert (#879 by @skyzh)
  • feat(batch): introduce delete executor in compute node (#883 by @BugenZhao)
  • feat(optimizer): implement BatchValues (#888 by @TennyZhuang)
  • feat(planner): create LogicalAgg (#843 by @likg227)
  • feat(scheduler): exchange node rewrite in serialization (#525 by @BowenXiao1999)
  • feat: transform single_value into a two-phase aggregation (#892 by @lmatz)
  • feat(storage): support hummock in-memory mode (#910 by @skyzh)
  • feat(frontend): create query handler (#907 by @cykbls01)
  • feat(risedev): add risedev p (#916 by @skyzh)
  • feat(binder): bind & plan DELETE (#912 by @BugenZhao)
  • feat(frontend): bind & plan order by (#908 by @xiangjinwu)
  • feat: suppport testing batch plan in plan test runner (#915 by @neverchanje)
  • feat(frontend): support apply test plan (#926 by @skyzh)
  • feat: use inner message (#932 by @shanicky)
  • feat(optimizer): support BatchDelete (#934 by @BugenZhao)
  • feat(frontend): support stream scan plan (#938 by @skyzh)
  • feat(optimzier): col_prune for logical insert (#933 by @st1page)
  • feat(optimizer): turn on HeuristicOptimizer (#942 by @xxchan)
  • feat(handler): get/drop hummock snapshot version in RPC (#936 by @BowenXiao1999)
  • feat(risedev): use hummock in-memory mode by default (#954 by @skyzh)
  • feat(frontend): support HashJoin with non-equal conditions (#949 by @fuyufjh)
  • feat(frontend): add no-op create mv handler (#960 by @skyzh)
  • feat: send notification failed then retry (#925 by @HuaHuaY)
  • feat(meta): Implement create and drop database/schema service v2 (#965 by @zbzbw)
  • feat(streaming): add single value aggregation for streaming (#914 by @lmatz)
  • feat: impl ToStreamProst for stream exchange (#967 by @BowenXiao1999)
  • feat: support DELETE with the Java frontend (#962 by @BugenZhao)
  • feat(meta): alter streaming schedule strategy (#940 by @xx01cyx)
  • feat(frontend): support filter and projection stream serialization (#976 by @skyzh)
  • feat(compaction): metric by frequence and #sst side, compaction doc (#829 by @soundOfDestiny)
  • feat(frontend): support explain create mv (#978 by @skyzh)
  • feat(meta): Implement create/drop MV service v2 (#983 by @zbzbw)
  • feat(hummock): vacuum orphan hummock data (#818 by @zwang28)
  • feat: write telemetry break down. (#987 by @twocode)
  • feat(frontend): get pg_field_descs from boudstatement (#950 by @cykbls01)
  • feat(frontend): support FLUSH (#996 by @TennyZhuang)
  • feat(hummock): support write key conflict detection under debug mode (#968 by @wenym1)
  • feat(risedev): run any dev command (#998 by @skyzh)
  • feat: add local planner test for stream hash join (#1001 by @BowenXiao1999)
  • feat(frontend): insert & delete handler (#1011 by @BugenZhao)
  • feat(storage): store min epoch watermark to hummock version (#1010 by @StrikeW)
  • feat(frontend): add virtual StreamTableScan node (#1024 by @skyzh)
  • feat(frontend): make explained plan be dist (#1004 by @BowenXiao1999)
  • feat: impl batch operators to pb (#986 by @neverchanje)
  • feat(binder): support subqurey in FROM (#992 by @xxchan)
  • feat(optimizer): add FilterProjectRule (#945 by @xxchan)
  • feat: update downstream actor ids when create MoM (#1041 by @yezizp2012)
  • feat(meta): add consistent hash mapping into hash dispatcher (#1030 by @xx01cyx)
  • feat(ci): use nextest (#1048 by @skyzh)
  • feat(frontend): BatchAgg and StreamAgg (#1026 by @likg227)
  • feat(frontend): impl ToBatchProst for BatchSort (#1045 by @lmatz)
  • feat(streaming): use single client for exchange (#1051 by @skyzh)
  • feat(meta): implement create & drop source for catalog v2 (#1043 by @BugenZhao)
  • feat: check ref count for drop source (#1057 by @yezizp2012)
  • feat(frontend): add StreamMaterialize node (#1033 by @skyzh)
  • feat(meta): implement create & drop materialized source for catalog v2 (#1065 by @BugenZhao)
  • feat(streaming): prepare to support multiple dispatchers (#1064 by @skyzh)
  • feat(frontend): bind functions (#734 by @mczhuang)
  • feat(ci): use all-in-one binary (#1067 by @skyzh)
  • feat(streaming): adopt consistent hash dispatch in streaming (#1056 by @xx01cyx)
  • feat(meta): handling duplicated mv creation in create mv service v2 (#1066 by @zbzbw)
  • feat(dashboard): integrate new dashboard ui with risedev (#531 by @mikechesterwang)
  • feat(frontend): Rewrite avg to sum/count. (#1075 by @likg227)
  • feat(risedev): add build dashboard config (#1086 by @skyzh)
  • feat: read break down (#1094 by @twocode)
  • feat(meta): handling duplicated source creation in catalog service v2 (#1101 by @zbzbw)
  • feat(frontend): parallelize test (#1091 by @skyzh)
  • feat(frontend): add stream proto test (#1105 by @skyzh)
  • feat(frontend): support to_protobuf for streaming agg (#1116 by @skyzh)
  • feat(storage): replace MViewTable with CellBasedTable and add relational interfaces (#1046 by @wcy-fdu)
  • fea...
Read more