1use std::collections::{HashMap, HashSet, VecDeque};
16use std::future::poll_fn;
17use std::ops::Range;
18use std::sync::{Arc, LazyLock};
19use std::task::{Poll, ready};
20use std::time::{Duration, Instant};
21
22use foyer::{HybridCacheEntry, RangeBoundsExt};
23use futures::future::{join_all, try_join_all};
24use futures::{Future, FutureExt};
25use itertools::Itertools;
26use prometheus::core::{AtomicU64, GenericCounter, GenericCounterVec};
27use prometheus::{
28 Histogram, HistogramVec, IntGauge, Registry, register_histogram_vec_with_registry,
29 register_int_counter_vec_with_registry, register_int_gauge_with_registry,
30};
31use risingwave_common::license::Feature;
32use risingwave_common::monitor::GLOBAL_METRICS_REGISTRY;
33use risingwave_hummock_sdk::compaction_group::hummock_version_ext::SstDeltaInfo;
34use risingwave_hummock_sdk::{HummockSstableObjectId, KeyComparator};
35use thiserror_ext::AsReport;
36use tokio::sync::Semaphore;
37use tokio::task::JoinHandle;
38
39use crate::hummock::local_version::pinned_version::PinnedVersion;
40use crate::hummock::{
41 Block, HummockError, HummockResult, Sstable, SstableBlockIndex, SstableStoreRef, TableHolder,
42};
43use crate::monitor::StoreLocalStatistic;
44use crate::opts::StorageOpts;
45
46pub static GLOBAL_CACHE_REFILL_METRICS: LazyLock<CacheRefillMetrics> =
47 LazyLock::new(|| CacheRefillMetrics::new(&GLOBAL_METRICS_REGISTRY));
48
49pub struct CacheRefillMetrics {
50 pub refill_duration: HistogramVec,
51 pub refill_total: GenericCounterVec<AtomicU64>,
52 pub refill_bytes: GenericCounterVec<AtomicU64>,
53
54 pub data_refill_success_duration: Histogram,
55 pub meta_refill_success_duration: Histogram,
56
57 pub data_refill_filtered_total: GenericCounter<AtomicU64>,
58 pub data_refill_attempts_total: GenericCounter<AtomicU64>,
59 pub data_refill_started_total: GenericCounter<AtomicU64>,
60 pub meta_refill_attempts_total: GenericCounter<AtomicU64>,
61
62 pub data_refill_parent_meta_lookup_hit_total: GenericCounter<AtomicU64>,
63 pub data_refill_parent_meta_lookup_miss_total: GenericCounter<AtomicU64>,
64 pub data_refill_unit_inheritance_hit_total: GenericCounter<AtomicU64>,
65 pub data_refill_unit_inheritance_miss_total: GenericCounter<AtomicU64>,
66
67 pub data_refill_block_unfiltered_total: GenericCounter<AtomicU64>,
68 pub data_refill_block_success_total: GenericCounter<AtomicU64>,
69
70 pub data_refill_ideal_bytes: GenericCounter<AtomicU64>,
71 pub data_refill_success_bytes: GenericCounter<AtomicU64>,
72
73 pub refill_queue_total: IntGauge,
74}
75
76impl CacheRefillMetrics {
77 pub fn new(registry: &Registry) -> Self {
78 let refill_duration = register_histogram_vec_with_registry!(
79 "refill_duration",
80 "refill duration",
81 &["type", "op"],
82 registry,
83 )
84 .unwrap();
85 let refill_total = register_int_counter_vec_with_registry!(
86 "refill_total",
87 "refill total",
88 &["type", "op"],
89 registry,
90 )
91 .unwrap();
92 let refill_bytes = register_int_counter_vec_with_registry!(
93 "refill_bytes",
94 "refill bytes",
95 &["type", "op"],
96 registry,
97 )
98 .unwrap();
99
100 let data_refill_success_duration = refill_duration
101 .get_metric_with_label_values(&["data", "success"])
102 .unwrap();
103 let meta_refill_success_duration = refill_duration
104 .get_metric_with_label_values(&["meta", "success"])
105 .unwrap();
106
107 let data_refill_filtered_total = refill_total
108 .get_metric_with_label_values(&["data", "filtered"])
109 .unwrap();
110 let data_refill_attempts_total = refill_total
111 .get_metric_with_label_values(&["data", "attempts"])
112 .unwrap();
113 let data_refill_started_total = refill_total
114 .get_metric_with_label_values(&["data", "started"])
115 .unwrap();
116 let meta_refill_attempts_total = refill_total
117 .get_metric_with_label_values(&["meta", "attempts"])
118 .unwrap();
119
120 let data_refill_parent_meta_lookup_hit_total = refill_total
121 .get_metric_with_label_values(&["parent_meta", "hit"])
122 .unwrap();
123 let data_refill_parent_meta_lookup_miss_total = refill_total
124 .get_metric_with_label_values(&["parent_meta", "miss"])
125 .unwrap();
126 let data_refill_unit_inheritance_hit_total = refill_total
127 .get_metric_with_label_values(&["unit_inheritance", "hit"])
128 .unwrap();
129 let data_refill_unit_inheritance_miss_total = refill_total
130 .get_metric_with_label_values(&["unit_inheritance", "miss"])
131 .unwrap();
132
133 let data_refill_block_unfiltered_total = refill_total
134 .get_metric_with_label_values(&["block", "unfiltered"])
135 .unwrap();
136 let data_refill_block_success_total = refill_total
137 .get_metric_with_label_values(&["block", "success"])
138 .unwrap();
139
140 let data_refill_ideal_bytes = refill_bytes
141 .get_metric_with_label_values(&["data", "ideal"])
142 .unwrap();
143 let data_refill_success_bytes = refill_bytes
144 .get_metric_with_label_values(&["data", "success"])
145 .unwrap();
146
147 let refill_queue_total = register_int_gauge_with_registry!(
148 "refill_queue_total",
149 "refill queue total",
150 registry,
151 )
152 .unwrap();
153
154 Self {
155 refill_duration,
156 refill_total,
157 refill_bytes,
158
159 data_refill_success_duration,
160 meta_refill_success_duration,
161 data_refill_filtered_total,
162 data_refill_attempts_total,
163 data_refill_started_total,
164 meta_refill_attempts_total,
165
166 data_refill_parent_meta_lookup_hit_total,
167 data_refill_parent_meta_lookup_miss_total,
168 data_refill_unit_inheritance_hit_total,
169 data_refill_unit_inheritance_miss_total,
170
171 data_refill_block_unfiltered_total,
172 data_refill_block_success_total,
173
174 data_refill_ideal_bytes,
175 data_refill_success_bytes,
176
177 refill_queue_total,
178 }
179 }
180}
181
182#[derive(Debug)]
183pub struct CacheRefillConfig {
184 pub timeout: Duration,
186
187 pub data_refill_levels: HashSet<u32>,
189
190 pub concurrency: usize,
192
193 pub unit: usize,
195
196 pub threshold: f64,
200}
201
202impl CacheRefillConfig {
203 pub fn from_storage_opts(options: &StorageOpts) -> Self {
204 let data_refill_levels = match Feature::ElasticDiskCache.check_available() {
205 Ok(_) => options
206 .cache_refill_data_refill_levels
207 .iter()
208 .copied()
209 .collect(),
210 Err(e) => {
211 tracing::warn!(error = %e.as_report(), "ElasticDiskCache is not available.");
212 HashSet::new()
213 }
214 };
215
216 Self {
217 timeout: Duration::from_millis(options.cache_refill_timeout_ms),
218 data_refill_levels,
219 concurrency: options.cache_refill_concurrency,
220 unit: options.cache_refill_unit,
221 threshold: options.cache_refill_threshold,
222 }
223 }
224}
225
226struct Item {
227 handle: JoinHandle<()>,
228 event: CacheRefillerEvent,
229}
230
231pub(crate) type SpawnRefillTask = Arc<
232 dyn Fn(Vec<SstDeltaInfo>, CacheRefillContext, PinnedVersion, PinnedVersion) -> JoinHandle<()>
234 + Send
235 + Sync
236 + 'static,
237>;
238
239pub(crate) struct CacheRefiller {
241 queue: VecDeque<Item>,
243
244 context: CacheRefillContext,
245
246 spawn_refill_task: SpawnRefillTask,
247}
248
249impl CacheRefiller {
250 pub(crate) fn new(
251 config: CacheRefillConfig,
252 sstable_store: SstableStoreRef,
253 spawn_refill_task: SpawnRefillTask,
254 ) -> Self {
255 let config = Arc::new(config);
256 let concurrency = Arc::new(Semaphore::new(config.concurrency));
257 Self {
258 queue: VecDeque::new(),
259 context: CacheRefillContext {
260 config,
261 concurrency,
262 sstable_store,
263 },
264 spawn_refill_task,
265 }
266 }
267
268 pub(crate) fn default_spawn_refill_task() -> SpawnRefillTask {
269 Arc::new(|deltas, context, _, _| {
270 let task = CacheRefillTask { deltas, context };
271 tokio::spawn(task.run())
272 })
273 }
274
275 pub(crate) fn start_cache_refill(
276 &mut self,
277 deltas: Vec<SstDeltaInfo>,
278 pinned_version: PinnedVersion,
279 new_pinned_version: PinnedVersion,
280 ) {
281 let handle = (self.spawn_refill_task)(
282 deltas,
283 self.context.clone(),
284 pinned_version.clone(),
285 new_pinned_version.clone(),
286 );
287 let event = CacheRefillerEvent {
288 pinned_version,
289 new_pinned_version,
290 };
291 let item = Item { handle, event };
292 self.queue.push_back(item);
293 GLOBAL_CACHE_REFILL_METRICS.refill_queue_total.add(1);
294 }
295
296 pub(crate) fn last_new_pinned_version(&self) -> Option<&PinnedVersion> {
297 self.queue.back().map(|item| &item.event.new_pinned_version)
298 }
299}
300
301impl CacheRefiller {
302 pub(crate) fn next_event(&mut self) -> impl Future<Output = CacheRefillerEvent> + '_ {
303 poll_fn(|cx| {
304 if let Some(item) = self.queue.front_mut() {
305 ready!(item.handle.poll_unpin(cx)).unwrap();
306 let item = self.queue.pop_front().unwrap();
307 GLOBAL_CACHE_REFILL_METRICS.refill_queue_total.sub(1);
308 return Poll::Ready(item.event);
309 }
310 Poll::Pending
311 })
312 }
313}
314
315pub struct CacheRefillerEvent {
316 pub pinned_version: PinnedVersion,
317 pub new_pinned_version: PinnedVersion,
318}
319
320#[derive(Clone)]
321pub(crate) struct CacheRefillContext {
322 config: Arc<CacheRefillConfig>,
323 concurrency: Arc<Semaphore>,
324 sstable_store: SstableStoreRef,
325}
326
327struct CacheRefillTask {
328 deltas: Vec<SstDeltaInfo>,
329 context: CacheRefillContext,
330}
331
332impl CacheRefillTask {
333 async fn run(self) {
334 let tasks = self
335 .deltas
336 .iter()
337 .map(|delta| {
338 let context = self.context.clone();
339 async move {
340 let holders = match Self::meta_cache_refill(&context, delta).await {
341 Ok(holders) => holders,
342 Err(e) => {
343 tracing::warn!(error = %e.as_report(), "meta cache refill error");
344 return;
345 }
346 };
347 Self::data_cache_refill(&context, delta, holders).await;
348 }
349 })
350 .collect_vec();
351 let future = join_all(tasks);
352
353 let _ = tokio::time::timeout(self.context.config.timeout, future).await;
354 }
355
356 async fn meta_cache_refill(
357 context: &CacheRefillContext,
358 delta: &SstDeltaInfo,
359 ) -> HummockResult<Vec<TableHolder>> {
360 let tasks = delta
361 .insert_sst_infos
362 .iter()
363 .map(|info| async {
364 let mut stats = StoreLocalStatistic::default();
365 GLOBAL_CACHE_REFILL_METRICS.meta_refill_attempts_total.inc();
366
367 let now = Instant::now();
368 let res = context.sstable_store.sstable(info, &mut stats).await;
369 stats.discard();
370 GLOBAL_CACHE_REFILL_METRICS
371 .meta_refill_success_duration
372 .observe(now.elapsed().as_secs_f64());
373 res
374 })
375 .collect_vec();
376 let holders = try_join_all(tasks).await?;
377 Ok(holders)
378 }
379
380 fn get_units_to_refill_by_inheritance(
382 context: &CacheRefillContext,
383 ssts: &[TableHolder],
384 parent_ssts: impl IntoIterator<Item = HybridCacheEntry<HummockSstableObjectId, Box<Sstable>>>,
385 ) -> HashSet<SstableUnit> {
386 let mut res = HashSet::default();
387
388 let Some(filter) = context.sstable_store.data_recent_filter() else {
389 return res;
390 };
391
392 let units = {
393 let unit = context.config.unit;
394 ssts.iter()
395 .flat_map(|sst| {
396 let units = Unit::units(sst, unit);
397 (0..units).map(|uidx| Unit::new(sst, unit, uidx))
398 })
399 .collect_vec()
400 };
401
402 if cfg!(debug_assertions) {
403 units.iter().tuple_windows().for_each(|(a, b)| {
405 debug_assert_ne!(
406 KeyComparator::compare_encoded_full_key(a.largest_key(), b.smallest_key()),
407 std::cmp::Ordering::Greater
408 )
409 });
410 }
411
412 for psst in parent_ssts {
413 for pblk in 0..psst.block_count() {
414 let pleft = &psst.meta.block_metas[pblk].smallest_key;
415 let pright = if pblk + 1 == psst.block_count() {
416 &psst.meta.largest_key
418 } else {
419 &psst.meta.block_metas[pblk + 1].smallest_key
420 };
421
422 let uleft = units.partition_point(|unit| {
424 KeyComparator::compare_encoded_full_key(unit.largest_key(), pleft)
425 == std::cmp::Ordering::Less
426 });
427 let uright = units.partition_point(|unit| {
429 KeyComparator::compare_encoded_full_key(unit.smallest_key(), pright)
430 != std::cmp::Ordering::Greater
431 });
432
433 for u in units.iter().take(uright).skip(uleft) {
435 let unit = SstableUnit {
436 sst_obj_id: u.sst.id,
437 blks: u.blks.clone(),
438 };
439 if res.contains(&unit) {
440 continue;
441 }
442 if filter.contains(&(psst.id, pblk)) {
443 res.insert(unit);
444 }
445 }
446 }
447 }
448
449 let hit = res.len();
450 let miss = units.len() - res.len();
451 GLOBAL_CACHE_REFILL_METRICS
452 .data_refill_unit_inheritance_hit_total
453 .inc_by(hit as u64);
454 GLOBAL_CACHE_REFILL_METRICS
455 .data_refill_unit_inheritance_miss_total
456 .inc_by(miss as u64);
457
458 res
459 }
460
461 async fn data_cache_refill(
462 context: &CacheRefillContext,
463 delta: &SstDeltaInfo,
464 holders: Vec<TableHolder>,
465 ) {
466 let Some(filter) = context.sstable_store.data_recent_filter() else {
468 return;
469 };
470
471 if delta.insert_sst_infos.is_empty() || delta.delete_sst_object_ids.is_empty() {
473 return;
474 }
475
476 if !context
478 .config
479 .data_refill_levels
480 .contains(&delta.insert_sst_level)
481 || !delta
482 .delete_sst_object_ids
483 .iter()
484 .any(|&id| filter.contains(&(id, usize::MAX)))
485 {
486 GLOBAL_CACHE_REFILL_METRICS.data_refill_filtered_total.inc();
487 return;
488 }
489
490 GLOBAL_CACHE_REFILL_METRICS
491 .data_refill_block_unfiltered_total
492 .inc_by(
493 holders
494 .iter()
495 .map(|sst| sst.block_count() as u64)
496 .sum::<u64>(),
497 );
498
499 if delta.insert_sst_level == 0 {
500 Self::data_file_cache_refill_l0_impl(context, delta, holders).await;
501 } else {
502 Self::data_file_cache_impl(context, delta, holders).await;
503 }
504 }
505
506 async fn data_file_cache_refill_l0_impl(
507 context: &CacheRefillContext,
508 _delta: &SstDeltaInfo,
509 holders: Vec<TableHolder>,
510 ) {
511 let unit = context.config.unit;
512
513 let mut futures = vec![];
514
515 for sst in &holders {
516 for blk_start in (0..sst.block_count()).step_by(unit) {
517 let blk_end = std::cmp::min(sst.block_count(), blk_start + unit);
518 let unit = SstableUnit {
519 sst_obj_id: sst.id,
520 blks: blk_start..blk_end,
521 };
522 futures.push(
523 async move { Self::data_file_cache_refill_unit(context, sst, unit).await },
524 );
525 }
526 }
527 join_all(futures).await;
528 }
529
530 async fn data_file_cache_impl(
531 context: &CacheRefillContext,
532 delta: &SstDeltaInfo,
533 holders: Vec<TableHolder>,
534 ) {
535 let sstable_store = context.sstable_store.clone();
536 let futures = delta.delete_sst_object_ids.iter().map(|sst_obj_id| {
537 let store = &sstable_store;
538 async move {
539 let res = store.sstable_cached(*sst_obj_id).await;
540 match res {
541 Ok(Some(_)) => GLOBAL_CACHE_REFILL_METRICS
542 .data_refill_parent_meta_lookup_hit_total
543 .inc(),
544 Ok(None) => GLOBAL_CACHE_REFILL_METRICS
545 .data_refill_parent_meta_lookup_miss_total
546 .inc(),
547 _ => {}
548 }
549 res
550 }
551 });
552 let parent_ssts = match try_join_all(futures).await {
553 Ok(parent_ssts) => parent_ssts.into_iter().flatten(),
554 Err(e) => {
555 return tracing::error!(error = %e.as_report(), "get old meta from cache error");
556 }
557 };
558 let units = Self::get_units_to_refill_by_inheritance(context, &holders, parent_ssts);
559
560 let ssts: HashMap<HummockSstableObjectId, TableHolder> =
561 holders.into_iter().map(|meta| (meta.id, meta)).collect();
562 let futures = units.into_iter().map(|unit| {
563 let ssts = &ssts;
564 async move {
565 let sst = ssts.get(&unit.sst_obj_id).unwrap();
566 if let Err(e) = Self::data_file_cache_refill_unit(context, sst, unit).await {
567 tracing::error!(error = %e.as_report(), "data file cache unit refill error");
568 }
569 }
570 });
571 join_all(futures).await;
572 }
573
574 async fn data_file_cache_refill_unit(
575 context: &CacheRefillContext,
576 sst: &Sstable,
577 unit: SstableUnit,
578 ) -> HummockResult<()> {
579 let sstable_store = &context.sstable_store;
580 let threshold = context.config.threshold;
581
582 if let Some(filter) = sstable_store.data_recent_filter() {
584 filter.insert((sst.id, usize::MAX));
585 }
586
587 let blocks = unit.blks.size().unwrap();
588
589 let mut tasks = vec![];
590 let mut contexts = Vec::with_capacity(blocks);
591 let mut admits = 0;
592
593 let (range_first, _) = sst.calculate_block_info(unit.blks.start);
594 let (range_last, _) = sst.calculate_block_info(unit.blks.end - 1);
595 let range = range_first.start..range_last.end;
596
597 GLOBAL_CACHE_REFILL_METRICS
598 .data_refill_ideal_bytes
599 .inc_by(range.size().unwrap() as u64);
600
601 for blk in unit.blks {
602 let (range, uncompressed_capacity) = sst.calculate_block_info(blk);
603 let key = SstableBlockIndex {
604 sst_id: sst.id,
605 block_idx: blk as u64,
606 };
607
608 let mut writer = sstable_store.block_cache().storage_writer(key);
609
610 if writer.pick() {
611 admits += 1;
612 }
613
614 contexts.push((writer, range, uncompressed_capacity))
615 }
616
617 if admits as f64 / contexts.len() as f64 >= threshold {
618 let task = async move {
619 GLOBAL_CACHE_REFILL_METRICS.data_refill_attempts_total.inc();
620
621 let permit = context.concurrency.acquire().await.unwrap();
622
623 GLOBAL_CACHE_REFILL_METRICS.data_refill_started_total.inc();
624
625 let timer = GLOBAL_CACHE_REFILL_METRICS
626 .data_refill_success_duration
627 .start_timer();
628
629 let data = sstable_store
630 .store()
631 .read(&sstable_store.get_sst_data_path(sst.id), range.clone())
632 .await?;
633 let mut futures = vec![];
634 for (w, r, uc) in contexts {
635 let offset = r.start - range.start;
636 let len = r.end - r.start;
637 let bytes = data.slice(offset..offset + len);
638 let future = async move {
639 let value = Box::new(Block::decode(bytes, uc)?);
640 if let Some(_entry) = w.force().insert(value) {
642 GLOBAL_CACHE_REFILL_METRICS
643 .data_refill_success_bytes
644 .inc_by(len as u64);
645 GLOBAL_CACHE_REFILL_METRICS
646 .data_refill_block_success_total
647 .inc();
648 }
649 Ok::<_, HummockError>(())
650 };
651 futures.push(future);
652 }
653 try_join_all(futures)
654 .await
655 .map_err(HummockError::file_cache)?;
656
657 drop(permit);
658 drop(timer);
659
660 Ok::<_, HummockError>(())
661 };
662 tasks.push(task);
663 }
664
665 try_join_all(tasks).await?;
666
667 Ok(())
668 }
669}
670
671#[derive(Debug)]
672pub struct SstableBlock {
673 pub sst_obj_id: HummockSstableObjectId,
674 pub blk_idx: usize,
675}
676
677#[derive(Debug, Hash, PartialEq, Eq)]
678pub struct SstableUnit {
679 pub sst_obj_id: HummockSstableObjectId,
680 pub blks: Range<usize>,
681}
682
683impl Ord for SstableUnit {
684 fn cmp(&self, other: &Self) -> std::cmp::Ordering {
685 match self.sst_obj_id.cmp(&other.sst_obj_id) {
686 std::cmp::Ordering::Equal => {}
687 ord => return ord,
688 }
689 match self.blks.start.cmp(&other.blks.start) {
690 std::cmp::Ordering::Equal => {}
691 ord => return ord,
692 }
693 self.blks.end.cmp(&other.blks.end)
694 }
695}
696
697impl PartialOrd for SstableUnit {
698 fn partial_cmp(&self, other: &Self) -> Option<std::cmp::Ordering> {
699 Some(self.cmp(other))
700 }
701}
702
703#[derive(Debug)]
704struct Unit<'a> {
705 sst: &'a Sstable,
706 blks: Range<usize>,
707}
708
709impl<'a> Unit<'a> {
710 fn new(sst: &'a Sstable, unit: usize, uidx: usize) -> Self {
711 let blks = unit * uidx..std::cmp::min(unit * (uidx + 1), sst.block_count());
712 Self { sst, blks }
713 }
714
715 fn smallest_key(&self) -> &Vec<u8> {
716 &self.sst.meta.block_metas[self.blks.start].smallest_key
717 }
718
719 fn largest_key(&self) -> &Vec<u8> {
721 if self.blks.end == self.sst.block_count() {
722 &self.sst.meta.largest_key
723 } else {
724 &self.sst.meta.block_metas[self.blks.end].smallest_key
725 }
726 }
727
728 fn units(sst: &Sstable, unit: usize) -> usize {
729 sst.block_count() / unit + if sst.block_count() % unit == 0 { 0 } else { 1 }
730 }
731}