Releases: risingwavelabs/risingwave
Releases · risingwavelabs/risingwave
v0.1.12
For installation and running instructions, see Get started.
Main changes
SQL features
- SQL commands:
EXPLAIN
now supports specifying options. Supported options:trace
,verbose
, andtype
. 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 optionsCREATEUSER
andNOCREATEUSER
, 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()
, andsession_user
. #4358
- Adds support for new system information functions:
- The
pg_namespace
catalog now has a new namespace columnnspacl
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 todebezium_json
. #4494
Configuration changes
- The default batch query execution mode was changed from distributed to local. #4789
New Contributors
- @xinchengxx made their first contribution in #4320
- @wanglei4687 made their first contribution in #4477
- @guzzit made their first contribution in #3781
- @KveinAxel made their first contribution in #4675
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 streamingstring_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
torw_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 https://github.com/risingwavelabs/risingwave/pu...
v0.1.11
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
: useeval_row
andunwrap_or(false)
onDatum
, 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
toparse_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
andStateTable
inDynamicFilter
(only writes) by @jon-chuang in #3757 - fix(batch): fix order_by with struct table by @StrikeW in htt...
v0.1.10
For a quick summary on this release, see Release Notes for more information.
What's Changed
- feat: support streaming count/max/min on more types by @neverchanje in #3069
- refactor: using barrier to initialize the source actor by @shanicky in #3067
- fix(e2e): cleanup after extreme null test by @kwannoel in #3079
- test(common): move test_runner to risingwave_test_runner by @xxhZs in #3063
- fix(metrics): add executor throughput and remove actor throughput by @MingjiHan99 in #3045
- feat(batch): index scan & point get by @xxchan in #3014
- fix: cannot create a materialized view with struct column by @cykbls01 in #3078
- fix(ci): fix executor metrics in release mode by @MingjiHan99 in #3087
- feat(storage): use exist_table_id to filter exist key when compaction by @Li0k in #3038
- chore(storage): remove redundant Result on
serialize_pk
by @xxchan in #3088 - feat(risedev): support prometheus + redpanda by @skyzh in #3083
- binder: support string interval by @likzn in #3037
- refactor(expr): introduce ExprError by @TennyZhuang in #3081
- test(bench): add compression benchmark by @MrCroxx in #3090
- feat: alias data type
STRING
toVARCHAR
by @fuyufjh in #3094 - feat: support user authentication in frontend by @yezizp2012 in #3074
- perf(executor): implement dedup pk decoding for BatchQueryExecutor by @kwannoel in #3060
- feat(ci): cache artifacts in build image by @skyzh in #3093
- refactor: remove macros from flush status by @neverchanje in #3098
- feat(meta): add compaction group service/client by @zwang28 in #3061
- feat(storage): add combined SST builder by @zwang28 in #3075
- feat(meta): register/unregister table fragments to compaction group by @zwang28 in #3044
- refactor(relational_iter): dedup
into_stream_inner
andinto_stream
in StateTableRowIter by @wcy-fdu in #3057 - feat(streaming): extend CREATE TABLE syntax to support creating append-only table source by @StrikeW in #3058
- refactor(connector): simplify pulsar reader by @shanicky in #3103
- chore(ci): ci upload failure logs by @huangjw806 in #3099
- feat(storage): implement read pruning by vnode by @xx01cyx in #2882
- feat: support unnest function by @cykbls01 in #3017
- feat(binder): add concat by @kwannoel in #3091
- refactor(common): extend
CheckedAdd
withRhs
andOutput
by @xiangjinwu in #3108 - fix: fix the table descs of value state by @BowenXiao1999 in #3106
- fix(expr): several expressions handle visibility incorrectly by @TennyZhuang in #3096
- fix: no need to expect mem table return Err by @BowenXiao1999 in #3071
- feat(storage): optimize get existing table ids when compact by @Li0k in #3114
- fix(optimizer): fix lost projection pk by @skyzh in #3119
- fix(compaction): fix compaction task do not schedule even if the number of L0 files is very large by @Little-Wallace in #3117
- chore(build): bump toolchain to 2022-06-09 by @skyzh in #3100
- fix(risedev): specify username in playground hints by @BugenZhao in #3123
- fix(pg-wire): fix the simple extended query mode by @ZENOTME in #3104
- feat(connector): add random seed for datagen by @tabVersion in #3124
- chore(risedev): tune etcd configuration. by @zwang28 in #3110
- fix: iter only need the pk prefix reference instead of ownership by @BowenXiao1999 in #3126
- feat: add default super user postgres by @yezizp2012 in #3127
- fix(meta): use CompactionConfigBuilder by @zwang28 in #3128
- fix: create mv support array expression by @cykbls01 in #3113
- refactor(array): introduce ArrayError & unify
ensure!
byanyhow!
by @BugenZhao in #3130 - chore(ci): limit job number of coverage by @skyzh in #3122
- feat: support struct expression by @cykbls01 in #2914
- refactor(streaming): remove
AggStateError
variant and more by @BugenZhao in #3140 - style: introduce lint reasons by @TennyZhuang in #3144
- refactor(stream): remove TopNStateError by @lmatz in #3142
- feat(expr): support
repeat
function by @name1e5s in #3148 - chore: remove all tracing logs relates to pin/unpin by @BowenXiao1999 in #3151
- chore(storage): deprecate in-memory state store in e2e scenarios by @BugenZhao in #3153
- feat(hummock): remove combine group for compaction by @Little-Wallace in #3138
- feat(expr): Implement approx_count_distinct for stream processing by @Graphcalibur in #3121
- fix(streaming): compile error in count distinct by @skyzh in #3163
- test: add some real-world use cases to e2e testing by @neverchanje in #3158
- fix(streaming): Fix error propagation in approx_count_distinct by @Graphcalibur in #3167
- chore: cargo update for frontend/test_runner by @fuyufjh in #3168
- fix: deprecate parse_duration dependency by @nasnoisaac in #3157
- feat(frontend): change the default schema name to public by @TennyZhuang in #3166
- fix(optimizer): fix logical scan pk derive by @st1page in #3171
- refactor(metrics): move some metrics from meta to compactor by @Little-Wallace in #3164
- fix(binder): bind CTE only when schema_name is empty by @TennyZhuang in #3173
- fix(batch scheduler): intermediate stage may have single distribution by @xiangjinwu in #3172
- fix(storage): re-enable compaction filter by @zwang28 in #3141
- feat: retry connect to meta until meta online by @yezizp2012 in #3165
- fix(doc): Add link for batch local execution mode by @liurenjie1024 in #3176
- feat(batch): split plan into fragments for local execution mode by @lmatz in #3032
- feat: support select Row() by @cykbls01 in #3152
- chore(ci): ci add swap file for ec2 instance by @huangjw806 in #3177
- feat(frontend): introduce scheduler error by @lmatz in #3156
- feat(connector): SinkExecutor init + MySQLSink mvp by @nanderstabel in #2969
- fix(ci): remove compile job limit by @skyzh in #3179
- chore: clean up code for legacy frontend by @xxchan in #3181
- chore(ci): fix labeler by @xxchan in #3182
- feat: add state for source manager by @shanicky in #3170
- fix(batch scheduler): has_ta...
v0.1.9
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 thanDataChunkBuilder
ortry_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
- @marvenlee2486 made their first contribution in #2884
- @lokax made their first contribution in #2817
- @ZENOTME made their first contribution in #2961
- @nasnoisaac made their first contribution in #2991
Full Changelog: v0.1.8...v0.1.9
v0.1.8
What's Changed
Click to Expand
- release: v0.1.7 by @TennyZhuang in #2521
- refactor: remove legacy java frontend by @fuyufjh in #2523
- refactor(binder): organize bind_expr arms into groups by @xiangjinwu in #2500
- fix(batch): support incomplete timestamp literal by @likzn in #2478
- refactor(common): use next_visible_row_idx for data chunk iter by @lmatz in #2528
- test: migrate legacy e2e tests by @TennyZhuang in #2536
- fix(ci): fix doc check by @BowenXiao1999 in #2505
- feat: Add query_mode session config by @liurenjie1024 in #2540
- refactor: Remove unused file by @liurenjie1024 in #2543
- docs: update for 0.1.7 release by @skyzh in #2542
- feat(storage): conflict detector in no order by @xxhZs in #2365
- docs: clearify HummockClient's location by @skyzh in #2544
- refactor(stream): remove STREAM_NULL_BY_ROW_COUNT by @TennyZhuang in #2549
- refactor: remove epoch service in meta by @yezizp2012 in #2554
- fix(streaming): avoid sync states when forcing stop actors in recovery by @yezizp2012 in #2497
- refactor(batch): Remove unnecessary executor by @liurenjie1024 in #2548
- refactor: remove catalog v1 service by @BugenZhao in #2556
- refactor(batch): Remove join v1 by @liurenjie1024 in #2559
- refactor(batch): remove frontend v2 in insert executor and fix some ut by @yezizp2012 in #2550
- feat(compaction): make compaction output be partitioned by parallel unit by @soundOfDestiny in #2406
- refactor(batch): Remove fuse and trace v1 by @liurenjie1024 in #2562
- refactor(meta): remove some legacy frontend support in meta, including StreamServiceImpl by @yezizp2012 in #2563
- fix(batch): fix a bug of exchange and project. by @likg227 in #2545
- chore(batch): remove unnecessary compact by @skyzh in #2565
- fix(optimizer): predicate pushdown when there's no filter above join by @xxchan in #2516
- chore: remove
v2
naming related to legacy frontend by @BugenZhao in #2572 - refactor: move fragmenter from meta to frontend by @xxchan in #2263
- feat(storage): suppport disk object store by @wenym1 in #2389
- feat(expr): Implement evaluation for CONCAT_WS expression by @kwannoel in #2470
- refactor(optimizer):
LogicalProject::with_mapping
should returnSelf
by @Enter-tainer in #2566 - fix(frontend): check arguments for agg call by @BugenZhao in #2567
- refactor(batch): Remove executor v1 by @liurenjie1024 in #2575
- refactor(proto): remove TypeName::Symbol and Char by @fuyufjh in #2574
- refactor(meta): remove legacy frontend support in fragmenter by @yezizp2012 in #2560
- refactor: remove function
pg_sleep
by @fuyufjh in #2576 - fix(source): remove epoch in state user key and no flush on idle by @hzxa21 in #2547
- feat(expr): support cast from number to varchar by @xiaoyong-z in #2522
- feat: create table contains nested column by @cykbls01 in #2434
- fix: error returned when creating a source from a non-existent topic by @shanicky in #2496
- refactor(batch): Remove some dead code in scheduler. by @liurenjie1024 in #2586
- refactor: remove test_utils in batch execution by @neverchanje in #2587
- refactor(prost): use src as default build path for prost by @Little-Wallace in #2581
- refactor(stream-scan): remove stream scan after java removed by @BowenXiao1999 in #2590
- feat(frontend): add
LogicalMultijoin
by @jon-chuang in #2526 - chore: add Column for connectors by @shanicky in #2593
- feat(array): use compact encoding for bitmap and bool array by @BugenZhao in #2585
- feat(expr): IN-list support non-literals by @xiangjinwu in #2588
- chore: add RFC template to issue templates by @fuyufjh in #2594
- chore: update design-rfc by @fuyufjh in #2596
- refactor(batch): use wrapper executor to impl time and i32 generate series by @D2Lark in #2524
- chore: ignore generated prost/sim files by @xiangjinwu in #2597
- chore(meta): remove old catalog definition in proto by @yezizp2012 in #2599
- fix(connector): make too big struct a Box by @tabVersion in #2606
- test(frontend): update TPC-H Q16 planner test by @xiangjinwu in #2605
- feat(storage): Add metrics for compaction and object store by @Little-Wallace in #2573
- fix(connector): make kinesis work again by @tabVersion in #2432
- feat(frontend): Bind concat_ws expression by @kwannoel in #2589
- fix(binder): handle ambiguous names in order by by @xiangjinwu in #2604
- test(optimizer): ensure column prune correctly handle reorder by @Enter-tainer in #2603
- feat(expr): Implement IS [NOT] DISTINCT FROM expression by @Graphcalibur in #2582
- chore(streaming): enable actor metrics in release mode by @skyzh in #2612
- chore: switch avro to fork by @skyzh in #2617
- fix(streaming): revert "feat(streaming): split chunks in source executor" by @tabVersion in #2608
- refactor(batch): use generatic type replace generate_series_wrapper_executor by @D2Lark in #2624
- chore(ci): remove unused e2e test by @BowenXiao1999 in #2616
- feat(binder): bind
UPDATE
by @BugenZhao in #2602 - feat(frontend): support alias for window table function by @TennyZhuang in #2633
- feat(expr): add support for abs function by @xiaoyong-z in #2531
- feat: add parallel source connector by @shanicky in #2601
- chore(connector): add some log and fix typo by @shanicky in #2639
- feat(ctl) add args ( epoch , table ) in list-kv by @xxhZs in #2640
- chore: add some logging on pgwire and frontend by @neverchanje in #2642
- fix(docs): use host network mode to start playground by @skyzh in #2652
- refactor(common): impl CheckedAdd for NavieDateTimeWrapper by @D2Lark in #2635
- feat(storage): support sstable store with local object store by @wenym1 in #2558
- refactor(frontend): eliminate
PlanNode
rest panic by @likzn in #2417 - refactor(frontend): ignore stmts START TRANSACTION and ABORT by @likzn in #2607
- chore(e2e): move v2 tests to be the first citizen by @BowenXiao1999 in #2658
- feat(frontend): plan
UPDATE
by @BugenZhao in https://github.com/singularity-data/ris...
v0.1.7
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 toexecutor
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
forArrayIterator
andArrayImplIterator
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
forcoalesce
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...
v0.1.6
What's Changed
Click to Expand
- chore: remove java from coverage by @fuyufjh in #1697
- style(frontend): adjust mod and pub use ordering by @xiangjinwu in #1696
- chore(frontend): hints for pg_catalog by @TennyZhuang in #1700
- test: Add tpch q1 for batch distributed query by @liurenjie1024 in #1701
- chore(legacy): bump proto & grpc version by @BugenZhao in #1704
- chore(doc): add two lines of comments to enforce consistency by @yingjunwu in #1710
- fix(risedev): ulimit on linux by @BugenZhao in #1699
- docs: library -> binary by @skyzh in #1711
- refactor mock meta client by @Little-Wallace in #1694
- feat: support state recovery when meta reboot by @yezizp2012 in #1702
- chore(docs): update new URLs by @CharlieSYH in #1712
- test: Add tpch q5 for batch distributed query by @liurenjie1024 in #1709
- doc: updated developer doc readme by @hengm3467 in #1715
- fix(risedev): kill using C-c by @skyzh in #1719
- doc: flush command in readme.md is optional by @wyhyhyhyh in #1706
- chore(batch): remove unnecessary logs by @skyzh in #1716
- chore(docs): add a logo in readme by @skyzh in #1720
- docs(readme): change
Kafka
toApache Kafka
by @Sunt-ing in #1725 - fix: quick fix for create mv ut timeout by @yezizp2012 in #1728
- ci: only build one docker image by @neverchanje in #1703
- chore(risedev): ask users to modify cluster config by @skyzh in #1733
- community: add discussions and community chat in issue template by @skyzh in #1741
- test: Add tpch q6 for batch distributed query by @liurenjie1024 in #1743
- refactor: replace prettytable-rs with comfy-table by @PsiACE in #1726
- feat(streaming): migrate LookupExecutor to ExecutorV2 by @pleiadesian in #1742
- feat(batch): support hash join non-equi condition in java frontend by @yuhao-su in #1713
- chore(docs): instructions to check-in PRs from forks by @skyzh in #1748
- fix(source): fix previously omitted review by @tabVersion in #1749
- chore(ci): remove setup kafka step by @skyzh in #1752
- test: Add tpch q7 for batch distributed query by @liurenjie1024 in #1750
- doc: add architecture-design doc by @neverchanje in #1698
- feat(cell_based_table): add sentinel column and cell_based muti_get by @wcy-fdu in #1590
- test: remove global rowsort to prevent mistakes by @skyzh in #1755
- feat: disable meta recovery process in CI by @yezizp2012 in #1754
- fix(source): build connector when calling
next
by @tabVersion in #1746 - chore(docs): Tweak some details of dev docs by @Sunt-ing in #1756
- style: enable rustfmt reorder_impl_items by @TennyZhuang in #1758
- feat(session-config): introduce entry-level pure in-memory set configuration by @BowenXiao1999 in #1714
- feat(frontend):
not
expression push down by @Enter-tainer in #1744 - fix(fe-server): do not print unexpected eof as error to log by @BowenXiao1999 in #1760
- feat(risedev): support set disable-recovery by @skyzh in #1765
- fix(risedev): forbid unused parameters in config by @skyzh in #1767
- feat: apply retry strategy when recovery by @yezizp2012 in #1768
- chore(meta): fix retry strategy naming by @yezizp2012 in #1769
- test(streaming): fix order assumption in
extreme_null
by @BugenZhao in #1770 - feat(streaming): migrate TopNExecutor to ExecutorV2 by @pleiadesian in #1737
- feat(streaming): migrate AppendOnlyTopNExecutor to ExecutorV2 by @pleiadesian in #1739
- chore(batch-scheduler): remove old scheduler impl and rename the file by @BowenXiao1999 in #1766
- feat(binder): align type cast-ability with pg by @xiangjinwu in #1759
- chore: bump rust-toolchain to 2022-04-09 by @skyzh in #1776
- chore: cleanup unimplemented by @hawkingrei in #1731
- feat(stream): implement HopWindowExecutor by @TennyZhuang in #1718
- chore: add missing license headers by @TennyZhuang in #1777
- feat(sql): support show sources by @neverchanje in #1775
- fix: Fix distributed query manager bug by @liurenjie1024 in #1778
- ci: add license checker by @TennyZhuang in #1780
- feat: q13 for distributed batch query by @liurenjie1024 in #1782
- ci: refine action names by @TennyZhuang in #1783
- fix(streaming): fix reporting & stopping of rearranged chain by @BugenZhao in #1556
- chore(ci): use bors try for contributors by @skyzh in #1784
- doc(source): doc for data source by @tabVersion in #1781
- chore(pgwire): remove risingwave_common as dep of pgwire by @BowenXiao1999 in #1786
- feat: scheduling splits when creating a materialized view by @shanicky in #1788
- refactor(stream): refine AggExecutor and Executor by @TennyZhuang in #1795
- fix(ci): checkout code before license check by @skyzh in #1798
- chore(cell_based_table): restore some unit tests with cell_based interface by @wcy-fdu in #1792
- refactor(meta): support DAG fragment graph by @skyzh in #1789
- fix: fill source id before creating source in compute node by @hzxa21 in #1806
- chore: Add grouping to issue labels. by @liurenjie1024 in #1809
- fix(streaming): avoid violating the assumption of U+ after U- in hash join & add checker by @BugenZhao in #1811
- feat(stream): Introduce RowsIterV2 by @TennyZhuang in #1813
- feat(stream): migrate ProjectExecutor to ExecutorV2 by @WindowsXp-Beta in #1810
- fix(ss-bench): fix inaccurate throughput calculation by @Sunt-ing in #1815
- feat(meta): split stateful operators into different fragments by @skyzh in #1817
- feat(storage): sync shared buffer based on threshold by @StrikeW in #1671
- refactor(stream): switch to RowRefV2 by @TennyZhuang in #1818
- feat(storage): inject failure in object_store by @xxhZs in #1564
- refactor(stream): remove Executor::clear_cache by @TennyZhuang in #1820
- feat: add sub_fields in field to support create mv conclude struct column by @cykbls01 in #1796
- refactor(stream): refine TopNExecutorBase by @TennyZhuang in #1822
- fix(meta): fix missing source info during `CREATE MATERI...
v0.1.5
Features
- feat(frontend): support window table function (#1396 by @TennyZhuang)
- feat(failover): Recover rebooted compute nodes with notification and snapshot (#1500 by @zbzbw)
- feat(frontend): remove duplicated exprs in agg calls. (#1492 by @likg227)
- feat: use entry size as weight in block and meta cache, export cache capacity config (#1512 by @MrCroxx)
- feat(cell_based_table): add IO interfaces for cell based table (#1312 by @wcy-fdu)
- feat: support ROUND, NOT LIKE and EXTRACT (#1498 by @neverchanje)
- feat(CI): introduce cargo doc check (#1533 by @lmatz)
- feat: Introducing distributed scheduler. (#1448 by @liurenjie1024)
- feat(streaming): rearranged chain executor (#1528 by @BugenZhao)
- feat(expr): migrate expr to separate crate (#1547 by @skyzh)
- feat(streaming): implement v2 executor for merge (#1472 by @BowenXiao1999)
- feat(stream): migrate
MaterializeExecutor
toExecutorV2
(#1539 by @zbzbw) - feat(binder): bind correlated columns (#1497 by @xxchan)
- feat(batch): support non_equi condition in batch hash join in backend (#1305 by @yuhao-su)
- feat(frontend): support TPC-H Q7 Q13 (#1566 by @skyzh)
- feat(streaming): migrate receiver executor to v2 (#1559 by @BowenXiao1999)
- feat(streaming): Make
RemoteInput
async stream based (#1571 by @BowenXiao1999) - feat: Move Cargo.toml to root (#1580 by @liurenjie1024)
- feat: support cast type to the type of itself (#1577 by @neverchanje)
- feat: sync source when recovery and some bug fix (#1578 by @yezizp2012)
- feat(expr): support timestamp/interval ops (#1596 by @TennyZhuang)
- feat(pg-wire): add error handle for cancel request + introduce error type for pgwire crates (#1603 by @BowenXiao1999)
- feat(streaming): migrate agg executors to ExecutorV2 (#1610 by @pleiadesian)
- feat: update downstream actor info when drop mv (#1618 by @yezizp2012)
- feat(frontend): support mv on source (#1623 by @st1page)
- feat(frontend): show command (#1545 by @cykbls01)
- feat(streaming): batch query executor v2 (#1619 by @BugenZhao)
- feat(frontend): add boolean constant folding (#1614 by @Enter-tainer)
- feat: make downstream update after create mv transactional (#1638 by @yezizp2012)
- feat: handle finish actor report for compute node recovery (#1646 by @yezizp2012)
- feat(expr): support interval * int (#1663 by @TennyZhuang)
- feat(sqlparser): support
CREATE MATERIALIZED SOURCE
and related drop commands. (#1679 by @neverchanje) - feat(source): build connector source when meta calls (#1660 by @tabVersion)
- feat(risedev): support kafka and zookeeper (#1690 by @skyzh)
- feat(compaction): use atomic counter to trigger trace info (#1683 by @soundOfDestiny)
Fixes
- fix(frontend): join rewrite column mapping (#1510 by @skyzh)
- fix(doc): broken doc links (#1515 by @lmatz)
- fix(doc): eliminate all the warnings of cargo doc --document-private-items (#1519 by @lmatz)
- fix(ci): re-enable java checks (#1531 by @skyzh)
- fix(binder): skip hidden columns from column aliases (#1537 by @xiangjinwu)
- fix(streaming): use chain v1 for workaround (#1541 by @BugenZhao)
- fix(storage): remove async trait from rocksdb and tikv (#1542 by @lmatz)
- fix(frontend): convert func name to lowercase (#1560 by @skyzh)
- fix(storage): mark orphan SST before vacuum. (#1583 by @zwang28)
- fix(parser): cycle dependency between test runner and parser (#1595 by @skyzh)
- fix(frontend): fix window_start type (#1601 by @TennyZhuang)
- fix(batch): Enable distributed query by default (#1579 by @liurenjie1024)
- fix: Restore distributed ci-3node (#1615 by @liurenjie1024)
- fix: Close session when UnExpectedEof happens. (#1627 by @liurenjie1024)
- fix: Ser/De dummy data chunk should keep cardinality. (#1631 by @liurenjie1024)
- fix(streaming): remove
is_stop_mutation
(#1634 by @BugenZhao) - fix(frontend): allow AnyShard for column indices (#1653 by @skyzh)
- fix: Batch distributed execution should support batch sort merge exchange. (#1672 by @liurenjie1024)
- fix(docs): wrong syntax for markdown links (#1685 by @skyzh)
- fix: fix snapshot_tests and shared buffer seek for reverse iterator (#1684 by @hzxa21)
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 generateas_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
- test: Introducing ci-3node tests. (#1650 by @liurenjie1024)
- test(compaction): print compaction status periodly (#1675 by @soundOfDestiny)
Others
- chore: remove s3 bench (#1514 by @MrCroxx)
- chore(frontend): port more tests (#1518 by @skyzh)
- chore(frontend): remove unstable pg connection test (#1525 by @BowenXiao1999)
- chore(doc): let cargo doc fails on warning due to broken_intra_doc_links (#1524 by @lmatz)
- chore: rename java -> legacy (#1526 by @skyzh)
- chore(typo-fix): fix all typos in current repo (#1522 by @BowenXiao1999)
- chore: remove unused deps, bump deps, remove expr from source (#1549 by @skyzh)
- chore: remove more unused tt in macros (#1573 by @TennyZhuang)
- chore: bump dependencies and fix renaming issues (#1584 by @skyzh)
- chore: bump prost to 0.10, disable rustls in aws-sdk (#1585 by @skyzh)
- chore: remove src/risedev (#1586 by @TennyZhuang)
- chore: update docker related files (#1593 by @KeXiangWang)
- chore: using TableId instead when drop materialized view (#1602 by @yezizp2012)
- chore: remove unused file. (#1607 by @zwang28)
- chore(compaction): add some compaction metrics into grafana (#1538 by @soundOfDestiny)
- chore: fix e2e command in doc. (#1626 by @zwang28)
- chore(object-store): use enum instead of trait objects for
ObjectStore
(#1629 by @BowenXiao1999) - chore(stream): FilterExecutor uses BitmapBuilder (#1622 by @TennyZhuang)
- chore: add tracking issue to NotImplementedError (#1639 by @TennyZhuang)
- chore: compress debug info (#1640 by @skyzh)
- chore(doc): psql not need the db name (#1651 by @BowenXiao1999)
- chore(doc): fix the FLUSH in cluster start up. (#1657 by @BowenXiao1999)
- chore(doc): fix typo in readme (#1659 by @BugenZhao)
- chore: deprecate rocksdb and tikv (#1543 by @skyzh)
- chore: fix some documentation (#1662 by @twocode)
- chore(doc): tweak readme (#1673 by @yingjunwu)
- chore(stream): remove unused async_trait (#1676 by @TennyZhuang)
Uncategorized
- docs: Remove empty docs for s3 (#1504 by @Xuanwo)
- docs: move benchmark tool docs (#1513 by @fuyufjh)
- docs: add mv-on-mv (#1505 by @TennyZhuang)
- docs: add docs for data model and encoding (#1535 by @fuyufjh)
- docs: unify storage overview docs (#1546 by @hzxa21)
- chore: $macro should be ident instead of tt (#1569 by @TennyZhuang)
- hummock: remove some macro in manager (#1567 by @Little-Wallace)
- docs: revise the streaming engine overview (#1574 by @wyhyhyhyh)
- chore: rename rust -> src (#1551 by @skyzh)
- docs: link to user docs (#1594 by @skyzh)
- perf(shared buffer): divide sync task to kr splits to sync shared buf… (#1496 by @soundOfDestiny)
- docs: add getting started guide (#1625 by @skyzh)
- docs: add issue templates and ToCs (#1628 by @skyzh)
- docs: refine src/README.md (#1647 by @TennyZhuang)
- docs: add readme for docker folder (#1649 by @skyzh)
- docs: fix description of types (#1658 by @xiangjinwu)
- ci: disable batch 3 node test (#1664 by @skyzh)
- ci: enable 3-node streaming (#1656 by @skyzh)
- storage: do not fetch all tables during every query. (#1558 by @Little-Wallace)
- minor: allow passing arguments to risedev test (#1691 by @hzxa21)
- ci: add docker build job (#1680 by @neverchanje)
- doc: Minor doc updates (#1688 by @hengm3467)
- release: bump to v0.1.5 (#1678 by @skyzh)
v0.1.4
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
- refactor(get): seek and filter tables by level (#1372 by @Little-Wallace)
- refactor(connector): remove assign_split from SourceReader (#1477 by @tabVersion)
- refactor(compaction): separate select and validate logic in get_compa… (#1160 by @soundOfDestiny)
- refactor(optimizer): remove unused input required (#1434 by @st1page)
Tests
- test(streaming): add unit tests for chain v2 (#1491 by @BugenZhao)
Others
- chore: refine to_rw_result_with (#1470 by @yezizp2012)
- chore: misc refine in cluster manager (#1482 by @yezizp2012)
v0.1.4-alpha
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...