1
#![cfg_attr(docsrs, feature(doc_auto_cfg, doc_cfg))]
2
#![doc = include_str!("../README.md")]
3
// @@ begin lint list maintained by maint/add_warning @@
4
#![allow(renamed_and_removed_lints)] // @@REMOVE_WHEN(ci_arti_stable)
5
#![allow(unknown_lints)] // @@REMOVE_WHEN(ci_arti_nightly)
6
#![warn(missing_docs)]
7
#![warn(noop_method_call)]
8
#![warn(unreachable_pub)]
9
#![warn(clippy::all)]
10
#![deny(clippy::await_holding_lock)]
11
#![deny(clippy::cargo_common_metadata)]
12
#![deny(clippy::cast_lossless)]
13
#![deny(clippy::checked_conversions)]
14
#![warn(clippy::cognitive_complexity)]
15
#![deny(clippy::debug_assert_with_mut_call)]
16
#![deny(clippy::exhaustive_enums)]
17
#![deny(clippy::exhaustive_structs)]
18
#![deny(clippy::expl_impl_clone_on_copy)]
19
#![deny(clippy::fallible_impl_from)]
20
#![deny(clippy::implicit_clone)]
21
#![deny(clippy::large_stack_arrays)]
22
#![warn(clippy::manual_ok_or)]
23
#![deny(clippy::missing_docs_in_private_items)]
24
#![warn(clippy::needless_borrow)]
25
#![warn(clippy::needless_pass_by_value)]
26
#![warn(clippy::option_option)]
27
#![deny(clippy::print_stderr)]
28
#![deny(clippy::print_stdout)]
29
#![warn(clippy::rc_buffer)]
30
#![deny(clippy::ref_option_ref)]
31
#![warn(clippy::semicolon_if_nothing_returned)]
32
#![warn(clippy::trait_duplication_in_bounds)]
33
#![deny(clippy::unchecked_duration_subtraction)]
34
#![deny(clippy::unnecessary_wraps)]
35
#![warn(clippy::unseparated_literal_suffix)]
36
#![deny(clippy::unwrap_used)]
37
#![deny(clippy::mod_module_files)]
38
#![allow(clippy::let_unit_value)] // This can reasonably be done for explicitness
39
#![allow(clippy::uninlined_format_args)]
40
#![allow(clippy::significant_drop_in_scrutinee)] // arti/-/merge_requests/588/#note_2812945
41
#![allow(clippy::result_large_err)] // temporary workaround for arti#587
42
#![allow(clippy::needless_raw_string_hashes)] // complained-about code is fine, often best
43
#![allow(clippy::needless_lifetimes)] // See arti#1765
44
//! <!-- @@ end lint list maintained by maint/add_warning @@ -->
45

            
46
// This clippy lint produces a false positive on `use strum`, below.
47
// Attempting to apply the lint to just the use statement fails to suppress
48
// this lint and instead produces another lint about a useless clippy attribute.
49
#![allow(clippy::single_component_path_imports)]
50

            
51
pub mod authority;
52
mod bootstrap;
53
pub mod config;
54
mod docid;
55
mod docmeta;
56
mod err;
57
mod event;
58
mod retry;
59
mod shared_ref;
60
mod state;
61
mod storage;
62

            
63
#[cfg(feature = "bridge-client")]
64
pub mod bridgedesc;
65
#[cfg(feature = "dirfilter")]
66
pub mod filter;
67

            
68
use crate::docid::{CacheUsage, ClientRequest, DocQuery};
69
use crate::err::BootstrapAction;
70
#[cfg(not(feature = "experimental-api"))]
71
use crate::shared_ref::SharedMutArc;
72
#[cfg(feature = "experimental-api")]
73
pub use crate::shared_ref::SharedMutArc;
74
use crate::storage::{DynStore, Store};
75
use bootstrap::AttemptId;
76
use event::DirProgress;
77
use postage::watch;
78
pub use retry::{DownloadSchedule, DownloadScheduleBuilder};
79
use scopeguard::ScopeGuard;
80
use tor_circmgr::CircMgr;
81
use tor_dirclient::SourceInfo;
82
use tor_error::{info_report, into_internal, warn_report};
83
use tor_netdir::params::NetParameters;
84
use tor_netdir::{DirEvent, MdReceiver, NetDir, NetDirProvider};
85

            
86
use async_trait::async_trait;
87
use futures::{stream::BoxStream, task::SpawnExt};
88
use oneshot_fused_workaround as oneshot;
89
use tor_netdoc::doc::netstatus::ProtoStatuses;
90
use tor_rtcompat::scheduler::{TaskHandle, TaskSchedule};
91
use tor_rtcompat::Runtime;
92
use tracing::{debug, info, trace, warn};
93

            
94
use std::marker::PhantomData;
95
use std::sync::atomic::{AtomicBool, Ordering};
96
use std::sync::{Arc, Mutex};
97
use std::time::Duration;
98
use std::{collections::HashMap, sync::Weak};
99
use std::{fmt::Debug, time::SystemTime};
100

            
101
use crate::state::{DirState, NetDirChange};
102
pub use authority::{Authority, AuthorityBuilder};
103
pub use config::{
104
    DirMgrConfig, DirTolerance, DirToleranceBuilder, DownloadScheduleConfig,
105
    DownloadScheduleConfigBuilder, NetworkConfig, NetworkConfigBuilder,
106
};
107
pub use docid::DocId;
108
pub use err::Error;
109
pub use event::{DirBlockage, DirBootstrapEvents, DirBootstrapStatus};
110
pub use storage::DocumentText;
111
pub use tor_guardmgr::fallback::{FallbackDir, FallbackDirBuilder};
112
pub use tor_netdir::Timeliness;
113

            
114
/// Re-export of `strum` crate for use by an internal macro
115
use strum;
116

            
117
/// A Result as returned by this crate.
118
pub type Result<T> = std::result::Result<T, Error>;
119

            
120
/// Storage manager used by [`DirMgr`] and
121
/// [`BridgeDescMgr`](bridgedesc::BridgeDescMgr)
122
///
123
/// Internally, this wraps up a sqlite database.
124
///
125
/// This is a handle, which is cheap to clone; clones share state.
126
#[derive(Clone)]
127
pub struct DirMgrStore<R: Runtime> {
128
    /// The actual store
129
    pub(crate) store: Arc<Mutex<crate::DynStore>>,
130

            
131
    /// Be parameterized by Runtime even though we don't use it right now
132
    pub(crate) runtime: PhantomData<R>,
133
}
134

            
135
impl<R: Runtime> DirMgrStore<R> {
136
    /// Open the storage, according to the specified configuration
137
22
    pub fn new(config: &DirMgrConfig, runtime: R, offline: bool) -> Result<Self> {
138
22
        let store = Arc::new(Mutex::new(config.open_store(offline)?));
139
22
        drop(runtime);
140
22
        let runtime = PhantomData;
141
22
        Ok(DirMgrStore { store, runtime })
142
22
    }
143
}
144

            
145
/// Trait for DirMgr implementations
146
#[async_trait]
147
pub trait DirProvider: NetDirProvider {
148
    /// Try to change our configuration to `new_config`.
149
    ///
150
    /// Actual behavior will depend on the value of `how`.
151
    fn reconfigure(
152
        &self,
153
        new_config: &DirMgrConfig,
154
        how: tor_config::Reconfigure,
155
    ) -> std::result::Result<(), tor_config::ReconfigureError>;
156

            
157
    /// Bootstrap a `DirProvider` that hasn't been bootstrapped yet.
158
    async fn bootstrap(&self) -> Result<()>;
159

            
160
    /// Return a stream of [`DirBootstrapStatus`] events to tell us about changes
161
    /// in the latest directory's bootstrap status.
162
    ///
163
    /// Note that this stream can be lossy: the caller will not necessarily
164
    /// observe every event on the stream
165
    fn bootstrap_events(&self) -> BoxStream<'static, DirBootstrapStatus>;
166

            
167
    /// Return a [`TaskHandle`] that can be used to manage the download process.
168
    fn download_task_handle(&self) -> Option<TaskHandle> {
169
        None
170
    }
171
}
172

            
173
// NOTE(eta): We can't implement this for Arc<DirMgr<R>> due to trait coherence rules, so instead
174
//            there's a blanket impl for Arc<T> in tor-netdir.
175
impl<R: Runtime> NetDirProvider for DirMgr<R> {
176
52
    fn netdir(&self, timeliness: Timeliness) -> tor_netdir::Result<Arc<NetDir>> {
177
        use tor_netdir::Error as NetDirError;
178
52
        let netdir = self.netdir.get().ok_or(NetDirError::NoInfo)?;
179
        let lifetime = match timeliness {
180
            Timeliness::Strict => netdir.lifetime().clone(),
181
            Timeliness::Timely => self
182
                .config
183
                .get()
184
                .tolerance
185
                .extend_lifetime(netdir.lifetime()),
186
            Timeliness::Unchecked => return Ok(netdir),
187
        };
188
        let now = SystemTime::now();
189
        if lifetime.valid_after() > now {
190
            Err(NetDirError::DirNotYetValid)
191
        } else if lifetime.valid_until() < now {
192
            Err(NetDirError::DirExpired)
193
        } else {
194
            Ok(netdir)
195
        }
196
52
    }
197

            
198
72
    fn events(&self) -> BoxStream<'static, DirEvent> {
199
72
        Box::pin(self.events.subscribe())
200
72
    }
201

            
202
12
    fn params(&self) -> Arc<dyn AsRef<tor_netdir::params::NetParameters>> {
203
12
        if let Some(netdir) = self.netdir.get() {
204
            // We have a directory, so we'd like to give it out for its
205
            // parameters.
206
            //
207
            // We do this even if the directory is expired, since parameters
208
            // don't really expire on any plausible timescale.
209
            netdir
210
        } else {
211
            // We have no directory, so we'll give out the default parameters as
212
            // modified by the provided override_net_params configuration.
213
            //
214
12
            self.default_parameters
215
12
                .lock()
216
12
                .expect("Poisoned lock")
217
12
                .clone()
218
        }
219
        // TODO(nickm): If we felt extremely clever, we could add a third case
220
        // where, if we have a pending directory with a validated consensus, we
221
        // give out that consensus's network parameters even if we _don't_ yet
222
        // have a full directory.  That's significant refactoring, though, for
223
        // an unclear amount of benefit.
224
12
    }
225

            
226
8
    fn protocol_statuses(&self) -> Option<(SystemTime, Arc<ProtoStatuses>)> {
227
8
        self.protocols.lock().expect("Poisoned lock").clone()
228
8
    }
229
}
230

            
231
#[async_trait]
232
impl<R: Runtime> DirProvider for Arc<DirMgr<R>> {
233
4
    fn reconfigure(
234
4
        &self,
235
4
        new_config: &DirMgrConfig,
236
4
        how: tor_config::Reconfigure,
237
4
    ) -> std::result::Result<(), tor_config::ReconfigureError> {
238
4
        DirMgr::reconfigure(self, new_config, how)
239
4
    }
240

            
241
    async fn bootstrap(&self) -> Result<()> {
242
        DirMgr::bootstrap(self).await
243
    }
244

            
245
8
    fn bootstrap_events(&self) -> BoxStream<'static, DirBootstrapStatus> {
246
8
        Box::pin(DirMgr::bootstrap_events(self))
247
8
    }
248

            
249
8
    fn download_task_handle(&self) -> Option<TaskHandle> {
250
8
        Some(self.task_handle.clone())
251
8
    }
252
}
253

            
254
/// A directory manager to download, fetch, and cache a Tor directory.
255
///
256
/// A DirMgr can operate in three modes:
257
///   * In **offline** mode, it only reads from the cache, and can
258
///     only read once.
259
///   * In **read-only** mode, it reads from the cache, but checks
260
///     whether it can acquire an associated lock file.  If it can, then
261
///     it enters read-write mode.  If not, it checks the cache
262
///     periodically for new information.
263
///   * In **read-write** mode, it knows that no other process will be
264
///     writing to the cache, and it takes responsibility for fetching
265
///     data from the network and updating the directory with new
266
///     directory information.
267
pub struct DirMgr<R: Runtime> {
268
    /// Configuration information: where to find directories, how to
269
    /// validate them, and so on.
270
    config: tor_config::MutCfg<DirMgrConfig>,
271
    /// Handle to our sqlite cache.
272
    // TODO(nickm): I'd like to use an rwlock, but that's not feasible, since
273
    // rusqlite::Connection isn't Sync.
274
    // TODO is needed?
275
    store: Arc<Mutex<DynStore>>,
276
    /// Our latest sufficiently bootstrapped directory, if we have one.
277
    ///
278
    /// We use the RwLock so that we can give this out to a bunch of other
279
    /// users, and replace it once a new directory is bootstrapped.
280
    // TODO(eta): Eurgh! This is so many Arcs! (especially considering this
281
    //            gets wrapped in an Arc)
282
    netdir: Arc<SharedMutArc<NetDir>>,
283

            
284
    /// Our latest set of recommended protocols.
285
    protocols: Mutex<Option<(SystemTime, Arc<ProtoStatuses>)>>,
286

            
287
    /// A set of network parameters to hand out when we have no directory.
288
    default_parameters: Mutex<Arc<NetParameters>>,
289

            
290
    /// A publisher handle that we notify whenever the consensus changes.
291
    events: event::FlagPublisher<DirEvent>,
292

            
293
    /// A publisher handle that we notify whenever our bootstrapping status
294
    /// changes.
295
    send_status: Mutex<watch::Sender<event::DirBootstrapStatus>>,
296

            
297
    /// A receiver handle that gets notified whenever our bootstrapping status
298
    /// changes.
299
    ///
300
    /// We don't need to keep this drained, since `postage::watch` already knows
301
    /// to discard unread events.
302
    receive_status: DirBootstrapEvents,
303

            
304
    /// A circuit manager, if this DirMgr supports downloading.
305
    circmgr: Option<Arc<CircMgr<R>>>,
306

            
307
    /// Our asynchronous runtime.
308
    runtime: R,
309

            
310
    /// Whether or not we're operating in offline mode.
311
    offline: bool,
312

            
313
    /// If we're not in offline mode, stores whether or not the `DirMgr` has attempted
314
    /// to bootstrap yet or not.
315
    ///
316
    /// This exists in order to prevent starting two concurrent bootstrap tasks.
317
    ///
318
    /// (In offline mode, this does nothing.)
319
    bootstrap_started: AtomicBool,
320

            
321
    /// A filter that gets applied to directory objects before we use them.
322
    #[cfg(feature = "dirfilter")]
323
    filter: crate::filter::FilterConfig,
324

            
325
    /// A task schedule that can be used if we're bootstrapping.  If this is
326
    /// None, then there's currently a scheduled task in progress.
327
    task_schedule: Mutex<Option<TaskSchedule<R>>>,
328

            
329
    /// A task handle that we return to anybody who needs to manage our download process.
330
    task_handle: TaskHandle,
331
}
332

            
333
/// The possible origins of a document.
334
///
335
/// Used (for example) to report where we got a document from if it fails to
336
/// parse.
337
#[derive(Debug, Clone)]
338
#[non_exhaustive]
339
pub enum DocSource {
340
    /// We loaded the document from our cache.
341
    LocalCache,
342
    /// We fetched the document from a server.
343
    DirServer {
344
        /// Information about the server we fetched the document from.
345
        source: Option<SourceInfo>,
346
    },
347
}
348

            
349
impl std::fmt::Display for DocSource {
350
2
    fn fmt(&self, f: &mut std::fmt::Formatter<'_>) -> std::fmt::Result {
351
2
        match self {
352
            DocSource::LocalCache => write!(f, "local cache"),
353
2
            DocSource::DirServer { source: None } => write!(f, "directory server"),
354
            DocSource::DirServer { source: Some(info) } => write!(f, "directory server {}", info),
355
        }
356
2
    }
357
}
358

            
359
impl<R: Runtime> DirMgr<R> {
360
    /// Try to load the directory from disk, without launching any
361
    /// kind of update process.
362
    ///
363
    /// This function runs in **offline** mode: it will give an error
364
    /// if the result is not up-to-date, or not fully downloaded.
365
    ///
366
    /// In general, you shouldn't use this function in a long-running
367
    /// program; it's only suitable for command-line or batch tools.
368
    // TODO: I wish this function didn't have to be async or take a runtime.
369
    pub async fn load_once(runtime: R, config: DirMgrConfig) -> Result<Arc<NetDir>> {
370
        let store = DirMgrStore::new(&config, runtime.clone(), true)?;
371
        let dirmgr = Arc::new(Self::from_config(config, runtime, store, None, true)?);
372

            
373
        // TODO: add some way to return a directory that isn't up-to-date
374
        let attempt = AttemptId::next();
375
        trace!(%attempt, "Trying to load a full directory from cache");
376
        let outcome = dirmgr.load_directory(attempt).await;
377
        trace!(%attempt, "Load result: {outcome:?}");
378
        let _success = outcome?;
379

            
380
        dirmgr
381
            .netdir(Timeliness::Timely)
382
            .map_err(|_| Error::DirectoryNotPresent)
383
    }
384

            
385
    /// Return a current netdir, either loading it or bootstrapping it
386
    /// as needed.
387
    ///
388
    /// Like load_once, but will try to bootstrap (or wait for another
389
    /// process to bootstrap) if we don't have an up-to-date
390
    /// bootstrapped directory.
391
    ///
392
    /// In general, you shouldn't use this function in a long-running
393
    /// program; it's only suitable for command-line or batch tools.
394
    pub async fn load_or_bootstrap_once(
395
        config: DirMgrConfig,
396
        runtime: R,
397
        store: DirMgrStore<R>,
398
        circmgr: Arc<CircMgr<R>>,
399
    ) -> Result<Arc<NetDir>> {
400
        let dirmgr = DirMgr::bootstrap_from_config(config, runtime, store, circmgr).await?;
401
        dirmgr
402
            .timely_netdir()
403
            .map_err(|_| Error::DirectoryNotPresent)
404
    }
405

            
406
    /// Create a new `DirMgr` in online mode, but don't bootstrap it yet.
407
    ///
408
    /// The `DirMgr` can be bootstrapped later with `bootstrap`.
409
8
    pub fn create_unbootstrapped(
410
8
        config: DirMgrConfig,
411
8
        runtime: R,
412
8
        store: DirMgrStore<R>,
413
8
        circmgr: Arc<CircMgr<R>>,
414
8
    ) -> Result<Arc<Self>> {
415
8
        Ok(Arc::new(DirMgr::from_config(
416
8
            config,
417
8
            runtime,
418
8
            store,
419
8
            Some(circmgr),
420
8
            false,
421
8
        )?))
422
8
    }
423

            
424
    /// Bootstrap a `DirMgr` created in online mode that hasn't been bootstrapped yet.
425
    ///
426
    /// This function will not return until the directory is bootstrapped enough to build circuits.
427
    /// It will also launch a background task that fetches any missing information, and that
428
    /// replaces the directory when a new one is available.
429
    ///
430
    /// This function is intended to be used together with `create_unbootstrapped`. There is no
431
    /// need to call this function otherwise.
432
    ///
433
    /// If bootstrapping has already successfully taken place, returns early with success.
434
    ///
435
    /// # Errors
436
    ///
437
    /// Returns an error if bootstrapping fails. If the error is [`Error::CantAdvanceState`],
438
    /// it may be possible to successfully bootstrap later on by calling this function again.
439
    ///
440
    /// # Panics
441
    ///
442
    /// Panics if the `DirMgr` passed to this function was not created in online mode, such as
443
    /// via `load_once`.
444
    pub async fn bootstrap(self: &Arc<Self>) -> Result<()> {
445
        if self.offline {
446
            return Err(Error::OfflineMode);
447
        }
448

            
449
        // The semantics of this are "attempt to replace a 'false' value with 'true'.
450
        // If the value in bootstrap_started was not 'false' when the attempt was made, returns
451
        // `Err`; this means another bootstrap attempt is in progress or has completed, so we
452
        // return early.
453

            
454
        // NOTE(eta): could potentially weaken the `Ordering` here in future
455
        if self
456
            .bootstrap_started
457
            .compare_exchange(false, true, Ordering::SeqCst, Ordering::SeqCst)
458
            .is_err()
459
        {
460
            debug!("Attempted to bootstrap twice; ignoring.");
461
            return Ok(());
462
        }
463

            
464
        // Use a RAII guard to reset `bootstrap_started` to `false` if we return early without
465
        // completing bootstrap.
466
        let reset_bootstrap_started = scopeguard::guard(&self.bootstrap_started, |v| {
467
            v.store(false, Ordering::SeqCst);
468
        });
469

            
470
        let schedule = {
471
            let sched = self.task_schedule.lock().expect("poisoned lock").take();
472
            match sched {
473
                Some(sched) => sched,
474
                None => {
475
                    debug!("Attempted to bootstrap twice; ignoring.");
476
                    return Ok(());
477
                }
478
            }
479
        };
480

            
481
        // Try to load from the cache.
482
        let attempt_id = AttemptId::next();
483
        trace!(attempt=%attempt_id, "Starting to bootstrap directory");
484
        let have_directory = self.load_directory(attempt_id).await?;
485

            
486
        let (mut sender, receiver) = if have_directory {
487
            info!("Loaded a good directory from cache.");
488
            (None, None)
489
        } else {
490
            info!("Didn't get usable directory from cache.");
491
            let (sender, receiver) = oneshot::channel();
492
            (Some(sender), Some(receiver))
493
        };
494

            
495
        // Whether we loaded or not, we now start downloading.
496
        let dirmgr_weak = Arc::downgrade(self);
497
        self.runtime
498
            .spawn(async move {
499
                // Use an RAII guard to make sure that when this task exits, the
500
                // TaskSchedule object is put back.
501
                //
502
                // TODO(nick): Putting the schedule back isn't actually useful
503
                // if the task exits _after_ we've bootstrapped for the first
504
                // time, because of how bootstrap_started works.
505
                let mut schedule = scopeguard::guard(schedule, |schedule| {
506
                    if let Some(dm) = Weak::upgrade(&dirmgr_weak) {
507
                        *dm.task_schedule.lock().expect("poisoned lock") = Some(schedule);
508
                    }
509
                });
510

            
511
                // Don't warn when these are Error::ManagerDropped: that
512
                // means that the DirMgr has been shut down.
513
                if let Err(e) =
514
                    Self::reload_until_owner(&dirmgr_weak, &mut schedule, attempt_id, &mut sender)
515
                        .await
516
                {
517
                    match e {
518
                        Error::ManagerDropped => {}
519
                        _ => warn_report!(e, "Unrecovered error while waiting for bootstrap",),
520
                    }
521
                } else if let Err(e) =
522
                    Self::download_forever(dirmgr_weak.clone(), &mut schedule, attempt_id, sender)
523
                        .await
524
                {
525
                    match e {
526
                        Error::ManagerDropped => {}
527
                        _ => warn_report!(e, "Unrecovered error while downloading"),
528
                    }
529
                }
530
            })
531
            .map_err(|e| Error::from_spawn("directory updater task", e))?;
532

            
533
        if let Some(receiver) = receiver {
534
            match receiver.await {
535
                Ok(()) => {
536
                    info!("We have enough information to build circuits.");
537
                    // Disarm the RAII guard, since we succeeded.  Now bootstrap_started will remain true.
538
                    let _ = ScopeGuard::into_inner(reset_bootstrap_started);
539
                }
540
                Err(_) => {
541
                    warn!("Bootstrapping task exited before finishing.");
542
                    return Err(Error::CantAdvanceState);
543
                }
544
            }
545
        }
546
        Ok(())
547
    }
548

            
549
    /// Returns `true` if a bootstrap attempt is in progress, or successfully completed.
550
    pub fn bootstrap_started(&self) -> bool {
551
        self.bootstrap_started.load(Ordering::SeqCst)
552
    }
553

            
554
    /// Return a new directory manager from a given configuration,
555
    /// bootstrapping from the network as necessary.
556
    pub async fn bootstrap_from_config(
557
        config: DirMgrConfig,
558
        runtime: R,
559
        store: DirMgrStore<R>,
560
        circmgr: Arc<CircMgr<R>>,
561
    ) -> Result<Arc<Self>> {
562
        let dirmgr = Self::create_unbootstrapped(config, runtime, store, circmgr)?;
563

            
564
        dirmgr.bootstrap().await?;
565

            
566
        Ok(dirmgr)
567
    }
568

            
569
    /// Try forever to either lock the storage (and thereby become the
570
    /// owner), or to reload the database.
571
    ///
572
    /// If we have begin to have a bootstrapped directory, send a
573
    /// message using `on_complete`.
574
    ///
575
    /// If we eventually become the owner, return Ok().
576
    async fn reload_until_owner(
577
        weak: &Weak<Self>,
578
        schedule: &mut TaskSchedule<R>,
579
        attempt_id: AttemptId,
580
        on_complete: &mut Option<oneshot::Sender<()>>,
581
    ) -> Result<()> {
582
        let mut logged = false;
583
        let mut bootstrapped;
584
        {
585
            let dirmgr = upgrade_weak_ref(weak)?;
586
            bootstrapped = dirmgr.netdir.get().is_some();
587
        }
588

            
589
        loop {
590
            {
591
                let dirmgr = upgrade_weak_ref(weak)?;
592
                trace!("Trying to take ownership of the directory cache lock");
593
                if dirmgr.try_upgrade_to_readwrite()? {
594
                    // We now own the lock!  (Maybe we owned it before; the
595
                    // upgrade_to_readwrite() function is idempotent.)  We can
596
                    // do our own bootstrapping.
597
                    if logged {
598
                        info!("The previous owning process has given up the lock. We are now in charge of managing the directory.");
599
                    }
600
                    return Ok(());
601
                }
602
            }
603

            
604
            if !logged {
605
                logged = true;
606
                if bootstrapped {
607
                    info!("Another process is managing the directory. We'll use its cache.");
608
                } else {
609
                    info!("Another process is bootstrapping the directory. Waiting till it finishes or exits.");
610
                }
611
            }
612

            
613
            // We don't own the lock.  Somebody else owns the cache.  They
614
            // should be updating it.  Wait a bit, then try again.
615
            let pause = if bootstrapped {
616
                std::time::Duration::new(120, 0)
617
            } else {
618
                std::time::Duration::new(5, 0)
619
            };
620
            schedule.sleep(pause).await?;
621
            // TODO: instead of loading the whole thing we should have a
622
            // database entry that says when the last update was, or use
623
            // our state functions.
624
            {
625
                let dirmgr = upgrade_weak_ref(weak)?;
626
                trace!("Trying to load from the directory cache");
627
                if dirmgr.load_directory(attempt_id).await? {
628
                    // Successfully loaded a bootstrapped directory.
629
                    if let Some(send_done) = on_complete.take() {
630
                        let _ = send_done.send(());
631
                    }
632
                    if !bootstrapped {
633
                        info!("The directory is now bootstrapped.");
634
                    }
635
                    bootstrapped = true;
636
                }
637
            }
638
        }
639
    }
640

            
641
    /// Try to fetch our directory info and keep it updated, indefinitely.
642
    ///
643
    /// If we have begin to have a bootstrapped directory, send a
644
    /// message using `on_complete`.
645
    async fn download_forever(
646
        weak: Weak<Self>,
647
        schedule: &mut TaskSchedule<R>,
648
        mut attempt_id: AttemptId,
649
        mut on_complete: Option<oneshot::Sender<()>>,
650
    ) -> Result<()> {
651
        let mut state: Box<dyn DirState> = {
652
            let dirmgr = upgrade_weak_ref(&weak)?;
653
            Box::new(state::GetConsensusState::new(
654
                dirmgr.runtime.clone(),
655
                dirmgr.config.get(),
656
                CacheUsage::CacheOkay,
657
                Some(dirmgr.netdir.clone()),
658
                #[cfg(feature = "dirfilter")]
659
                dirmgr
660
                    .filter
661
                    .clone()
662
                    .unwrap_or_else(|| Arc::new(crate::filter::NilFilter)),
663
            ))
664
        };
665

            
666
        trace!("Entering download loop.");
667

            
668
        loop {
669
            let mut usable = false;
670

            
671
            let retry_config = {
672
                let dirmgr = upgrade_weak_ref(&weak)?;
673
                // TODO(nickm): instead of getting this every time we loop, it
674
                // might be a good idea to refresh it with each attempt, at
675
                // least at the point of checking the number of attempts.
676
                dirmgr.config.get().schedule.retry_bootstrap
677
            };
678
            let mut retry_delay = retry_config.schedule();
679

            
680
            'retry_attempt: for try_num in retry_config.attempts() {
681
                trace!(attempt=%attempt_id, ?try_num, "Trying to download a directory.");
682
                let outcome = bootstrap::download(
683
                    Weak::clone(&weak),
684
                    &mut state,
685
                    schedule,
686
                    attempt_id,
687
                    &mut on_complete,
688
                )
689
                .await;
690
                trace!(attempt=%attempt_id, ?try_num, ?outcome, "Download is over.");
691

            
692
                if let Err(err) = outcome {
693
                    if state.is_ready(Readiness::Usable) {
694
                        usable = true;
695
                        info_report!(err, "Unable to completely download a directory. (Nevertheless, the directory is usable, so we'll pause for now)");
696
                        break 'retry_attempt;
697
                    }
698

            
699
                    match err.bootstrap_action() {
700
                        BootstrapAction::Nonfatal => {
701
                            return Err(into_internal!(
702
                                "Nonfatal error should not have propagated here"
703
                            )(err)
704
                            .into());
705
                        }
706
                        BootstrapAction::Reset => {}
707
                        BootstrapAction::Fatal => return Err(err),
708
                    }
709

            
710
                    let delay = retry_delay.next_delay(&mut rand::rng());
711
                    warn_report!(
712
                        err,
713
                        "Unable to download a usable directory. (We will restart in {})",
714
                        humantime::format_duration(delay),
715
                    );
716
                    {
717
                        let dirmgr = upgrade_weak_ref(&weak)?;
718
                        dirmgr.note_reset(attempt_id);
719
                    }
720
                    schedule.sleep(delay).await?;
721
                    state = state.reset();
722
                } else {
723
                    info!(attempt=%attempt_id, "Directory is complete.");
724
                    usable = true;
725
                    break 'retry_attempt;
726
                }
727
            }
728

            
729
            if !usable {
730
                // we ran out of attempts.
731
                warn!(
732
                    "We failed {} times to bootstrap a directory. We're going to give up.",
733
                    retry_config.n_attempts()
734
                );
735
                return Err(Error::CantAdvanceState);
736
            } else {
737
                // Report success, if appropriate.
738
                if let Some(send_done) = on_complete.take() {
739
                    let _ = send_done.send(());
740
                }
741
            }
742

            
743
            let reset_at = state.reset_time();
744
            match reset_at {
745
                Some(t) => {
746
                    trace!("Sleeping until {}", time::OffsetDateTime::from(t));
747
                    schedule.sleep_until_wallclock(t).await?;
748
                }
749
                None => return Ok(()),
750
            }
751
            attempt_id = bootstrap::AttemptId::next();
752
            trace!(attempt=%attempt_id, "Beginning new attempt to bootstrap directory");
753
            state = state.reset();
754
        }
755
    }
756

            
757
    /// Get a reference to the circuit manager, if we have one.
758
2
    fn circmgr(&self) -> Result<Arc<CircMgr<R>>> {
759
2
        self.circmgr.clone().ok_or(Error::NoDownloadSupport)
760
2
    }
761

            
762
    /// Try to change our configuration to `new_config`.
763
    ///
764
    /// Actual behavior will depend on the value of `how`.
765
4
    pub fn reconfigure(
766
4
        &self,
767
4
        new_config: &DirMgrConfig,
768
4
        how: tor_config::Reconfigure,
769
4
    ) -> std::result::Result<(), tor_config::ReconfigureError> {
770
4
        let config = self.config.get();
771
4
        // We don't support changing these: doing so basically would require us
772
4
        // to abort all our in-progress downloads, since they might be based on
773
4
        // no-longer-viable information.
774
4
        // NOTE: keep this in sync with the behaviour of `DirMgrConfig::update_from_config`
775
4
        if new_config.cache_dir != config.cache_dir {
776
            how.cannot_change("storage.cache_dir")?;
777
4
        }
778
4
        if new_config.cache_trust != config.cache_trust {
779
            how.cannot_change("storage.permissions")?;
780
4
        }
781
4
        if new_config.authorities() != config.authorities() {
782
            how.cannot_change("network.authorities")?;
783
4
        }
784

            
785
4
        if how == tor_config::Reconfigure::CheckAllOrNothing {
786
2
            return Ok(());
787
2
        }
788
2

            
789
2
        let params_changed = new_config.override_net_params != config.override_net_params;
790
2

            
791
2
        self.config
792
2
            .map_and_replace(|cfg| cfg.update_from_config(new_config));
793
2

            
794
2
        if params_changed {
795
            let _ignore_err = self.netdir.mutate(|netdir| {
796
                netdir.replace_overridden_parameters(&new_config.override_net_params);
797
                Ok(())
798
            });
799
            {
800
                let mut params = self.default_parameters.lock().expect("lock failed");
801
                *params = Arc::new(NetParameters::from_map(&new_config.override_net_params));
802
            }
803

            
804
            // (It's okay to ignore the error, since it just means that there
805
            // was no current netdir.)
806
            self.events.publish(DirEvent::NewConsensus);
807
2
        }
808

            
809
2
        Ok(())
810
4
    }
811

            
812
    /// Return a stream of [`DirBootstrapStatus`] events to tell us about changes
813
    /// in the latest directory's bootstrap status.
814
    ///
815
    /// Note that this stream can be lossy: the caller will not necessarily
816
    /// observe every event on the stream
817
8
    pub fn bootstrap_events(&self) -> event::DirBootstrapEvents {
818
8
        self.receive_status.clone()
819
8
    }
820

            
821
    /// Replace the latest status with `progress` and broadcast to anybody
822
    /// watching via a [`DirBootstrapEvents`] stream.
823
30
    fn update_progress(&self, attempt_id: AttemptId, progress: DirProgress) {
824
30
        // TODO(nickm): can I kill off this lock by having something else own the sender?
825
30
        let mut sender = self.send_status.lock().expect("poisoned lock");
826
30
        let mut status = sender.borrow_mut();
827
30

            
828
30
        status.update_progress(attempt_id, progress);
829
30
    }
830

            
831
    /// Update our status tracker to note that some number of errors has
832
    /// occurred.
833
    fn note_errors(&self, attempt_id: AttemptId, n_errors: usize) {
834
        if n_errors == 0 {
835
            return;
836
        }
837
        let mut sender = self.send_status.lock().expect("poisoned lock");
838
        let mut status = sender.borrow_mut();
839

            
840
        status.note_errors(attempt_id, n_errors);
841
    }
842

            
843
    /// Update our status tracker to note that we've needed to reset our download attempt.
844
    fn note_reset(&self, attempt_id: AttemptId) {
845
        let mut sender = self.send_status.lock().expect("poisoned lock");
846
        let mut status = sender.borrow_mut();
847

            
848
        status.note_reset(attempt_id);
849
    }
850

            
851
    /// Try to make this a directory manager with read-write access to its
852
    /// storage.
853
    ///
854
    /// Return true if we got the lock, or if we already had it.
855
    ///
856
    /// Return false if another process has the lock
857
    fn try_upgrade_to_readwrite(&self) -> Result<bool> {
858
        self.store
859
            .lock()
860
            .expect("Directory storage lock poisoned")
861
            .upgrade_to_readwrite()
862
    }
863

            
864
    /// Return a reference to the store, if it is currently read-write.
865
    #[cfg(test)]
866
4
    fn store_if_rw(&self) -> Option<&Mutex<DynStore>> {
867
4
        let rw = !self
868
4
            .store
869
4
            .lock()
870
4
            .expect("Directory storage lock poisoned")
871
4
            .is_readonly();
872
4
        // A race-condition is possible here, but I believe it's harmless.
873
4
        if rw {
874
4
            Some(&self.store)
875
        } else {
876
            None
877
        }
878
4
    }
879

            
880
    /// Construct a DirMgr from a DirMgrConfig.
881
    ///
882
    /// If `offline` is set, opens the SQLite store read-only and sets the offline flag in the
883
    /// returned manager.
884
    #[allow(clippy::unnecessary_wraps)] // API compat and future-proofing
885
22
    fn from_config(
886
22
        config: DirMgrConfig,
887
22
        runtime: R,
888
22
        store: DirMgrStore<R>,
889
22
        circmgr: Option<Arc<CircMgr<R>>>,
890
22
        offline: bool,
891
22
    ) -> Result<Self> {
892
22
        let netdir = Arc::new(SharedMutArc::new());
893
22
        let events = event::FlagPublisher::new();
894
22
        let default_parameters = NetParameters::from_map(&config.override_net_params);
895
22
        let default_parameters = Mutex::new(Arc::new(default_parameters));
896
22

            
897
22
        let (send_status, receive_status) = postage::watch::channel();
898
22
        let send_status = Mutex::new(send_status);
899
22
        let receive_status = DirBootstrapEvents {
900
22
            inner: receive_status,
901
22
        };
902
22
        #[cfg(feature = "dirfilter")]
903
22
        let filter = config.extensions.filter.clone();
904
22

            
905
22
        // We create these early so the client code can access task_handle before bootstrap() returns.
906
22
        let (task_schedule, task_handle) = TaskSchedule::new(runtime.clone());
907
22
        let task_schedule = Mutex::new(Some(task_schedule));
908

            
909
        // We load the cached protocol recommendations unconditionally: the caller needs them even
910
        // if it does not try to load the reset of the cache.
911
22
        let protocols = {
912
22
            let store = store.store.lock().expect("lock poisoned");
913
22
            store
914
22
                .cached_protocol_recommendations()?
915
22
                .map(|(t, p)| (t, Arc::new(p)))
916
22
        };
917
22

            
918
22
        Ok(DirMgr {
919
22
            config: config.into(),
920
22
            store: store.store,
921
22
            netdir,
922
22
            protocols: Mutex::new(protocols),
923
22
            default_parameters,
924
22
            events,
925
22
            send_status,
926
22
            receive_status,
927
22
            circmgr,
928
22
            runtime,
929
22
            offline,
930
22
            bootstrap_started: AtomicBool::new(false),
931
22
            #[cfg(feature = "dirfilter")]
932
22
            filter,
933
22
            task_schedule,
934
22
            task_handle,
935
22
        })
936
22
    }
937

            
938
    /// Load the latest non-pending non-expired directory from the
939
    /// cache, if it is newer than the one we have.
940
    ///
941
    /// Return false if there is no such consensus.
942
    async fn load_directory(self: &Arc<Self>, attempt_id: AttemptId) -> Result<bool> {
943
        let state = state::GetConsensusState::new(
944
            self.runtime.clone(),
945
            self.config.get(),
946
            CacheUsage::CacheOnly,
947
            None,
948
            #[cfg(feature = "dirfilter")]
949
            self.filter
950
                .clone()
951
                .unwrap_or_else(|| Arc::new(crate::filter::NilFilter)),
952
        );
953
        let _ = bootstrap::load(Arc::clone(self), Box::new(state), attempt_id).await?;
954

            
955
        Ok(self.netdir.get().is_some())
956
    }
957

            
958
    /// Return a new asynchronous stream that will receive notification
959
    /// whenever the consensus has changed.
960
    ///
961
    /// Multiple events may be batched up into a single item: each time
962
    /// this stream yields an event, all you can assume is that the event has
963
    /// occurred at least once.
964
    pub fn events(&self) -> impl futures::Stream<Item = DirEvent> {
965
        self.events.subscribe()
966
    }
967

            
968
    /// Try to load the text of a single document described by `doc` from
969
    /// storage.
970
6
    pub fn text(&self, doc: &DocId) -> Result<Option<DocumentText>> {
971
        use itertools::Itertools;
972
6
        let mut result = HashMap::new();
973
6
        let query: DocQuery = (*doc).into();
974
6
        let store = self.store.lock().expect("store lock poisoned");
975
6
        query.load_from_store_into(&mut result, &**store)?;
976
6
        let item = result.into_iter().at_most_one().map_err(|_| {
977
            Error::CacheCorruption("Found more than one entry in storage for given docid")
978
6
        })?;
979
6
        if let Some((docid, doctext)) = item {
980
4
            if &docid != doc {
981
                return Err(Error::CacheCorruption(
982
                    "Item from storage had incorrect docid.",
983
                ));
984
4
            }
985
4
            Ok(Some(doctext))
986
        } else {
987
2
            Ok(None)
988
        }
989
6
    }
990

            
991
    /// Load the text for a collection of documents.
992
    ///
993
    /// If many of the documents have the same type, this can be more
994
    /// efficient than calling [`text`](Self::text).
995
2
    pub fn texts<T>(&self, docs: T) -> Result<HashMap<DocId, DocumentText>>
996
2
    where
997
2
        T: IntoIterator<Item = DocId>,
998
2
    {
999
2
        let partitioned = docid::partition_by_type(docs);
2
        let mut result = HashMap::new();
2
        let store = self.store.lock().expect("store lock poisoned");
6
        for (_, query) in partitioned.into_iter() {
6
            query.load_from_store_into(&mut result, &**store)?;
        }
2
        Ok(result)
2
    }
    /// Given a request we sent and the response we got from a
    /// directory server, see whether we should expand that response
    /// into "something larger".
    ///
    /// Currently, this handles expanding consensus diffs, and nothing
    /// else.  We do it at this stage of our downloading operation
    /// because it requires access to the store.
12
    fn expand_response_text(&self, req: &ClientRequest, text: String) -> Result<String> {
12
        if let ClientRequest::Consensus(req) = req {
8
            if tor_consdiff::looks_like_diff(&text) {
4
                if let Some(old_d) = req.old_consensus_digests().next() {
4
                    let db_val = {
4
                        let s = self.store.lock().expect("Directory storage lock poisoned");
4
                        s.consensus_by_sha3_digest_of_signed_part(old_d)?
                    };
4
                    if let Some((old_consensus, meta)) = db_val {
4
                        info!("Applying a consensus diff");
4
                        let new_consensus = tor_consdiff::apply_diff(
4
                            old_consensus.as_str()?,
4
                            &text,
4
                            Some(*meta.sha3_256_of_signed()),
                        )?;
4
                        new_consensus.check_digest()?;
2
                        return Ok(new_consensus.to_string());
                    }
                }
                return Err(Error::Unwanted(
                    "Received a consensus diff we did not ask for",
                ));
4
            }
4
        }
8
        Ok(text)
12
    }
    /// If `state` has netdir changes to apply, apply them to our netdir.
    #[allow(clippy::cognitive_complexity)]
16
    fn apply_netdir_changes(
16
        self: &Arc<Self>,
16
        state: &mut Box<dyn DirState>,
16
        store: &mut dyn Store,
16
    ) -> Result<()> {
16
        if let Some(change) = state.get_netdir_change() {
            match change {
                NetDirChange::AttemptReplace {
                    netdir,
                    consensus_meta,
                } => {
                    // Check the new netdir is sufficient, if we have a circmgr.
                    // (Unwraps are fine because the `Option` is `Some` until we take it.)
                    if let Some(ref cm) = self.circmgr {
                        if !cm
                            .netdir_is_sufficient(netdir.as_ref().expect("AttemptReplace had None"))
                        {
                            debug!("Got a new NetDir, but it doesn't have enough guards yet.");
                            return Ok(());
                        }
                    }
                    let is_stale = {
                        // Done inside a block to not hold a long-lived copy of the NetDir.
                        self.netdir
                            .get()
                            .map(|x| {
                                x.lifetime().valid_after()
                                    > netdir
                                        .as_ref()
                                        .expect("AttemptReplace had None")
                                        .lifetime()
                                        .valid_after()
                            })
                            .unwrap_or(false)
                    };
                    if is_stale {
                        warn!("Got a new NetDir, but it's older than the one we currently have!");
                        return Err(Error::NetDirOlder);
                    }
                    let cfg = self.config.get();
                    let mut netdir = netdir.take().expect("AttemptReplace had None");
                    netdir.replace_overridden_parameters(&cfg.override_net_params);
                    self.netdir.replace(netdir);
                    self.events.publish(DirEvent::NewConsensus);
                    self.events.publish(DirEvent::NewDescriptors);
                    info!("Marked consensus usable.");
                    if !store.is_readonly() {
                        store.mark_consensus_usable(consensus_meta)?;
                        // Now that a consensus is usable, older consensuses may
                        // need to expire.
                        store.expire_all(&crate::storage::EXPIRATION_DEFAULTS)?;
                    }
                    Ok(())
                }
                NetDirChange::AddMicrodescs(mds) => {
                    self.netdir.mutate(|netdir| {
                        for md in mds.drain(..) {
                            netdir.add_microdesc(md);
                        }
                        Ok(())
                    })?;
                    self.events.publish(DirEvent::NewDescriptors);
                    Ok(())
                }
                NetDirChange::SetRequiredProtocol { timestamp, protos } => {
                    if !store.is_readonly() {
                        store.update_protocol_recommendations(timestamp, protos.as_ref())?;
                    }
                    let mut pr = self.protocols.lock().expect("Poisoned lock");
                    *pr = Some((timestamp, protos));
                    self.events.publish(DirEvent::NewProtocolRecommendation);
                    Ok(())
                }
            }
        } else {
16
            Ok(())
        }
16
    }
}
/// A degree of readiness for a given directory state object.
#[derive(Debug, Copy, Clone)]
enum Readiness {
    /// There is no more information to download.
    Complete,
    /// There is more information to download, but we don't need to
    Usable,
}
/// Try to upgrade a weak reference to a DirMgr, and give an error on
/// failure.
24
fn upgrade_weak_ref<T>(weak: &Weak<T>) -> Result<Arc<T>> {
24
    Weak::upgrade(weak).ok_or(Error::ManagerDropped)
24
}
/// Given a time `now`, and an amount of tolerated clock skew `tolerance`,
/// return the age of the oldest consensus that we should request at that time.
8
pub(crate) fn default_consensus_cutoff(
8
    now: SystemTime,
8
    tolerance: &DirTolerance,
8
) -> Result<SystemTime> {
    /// We _always_ allow at least this much age in our consensuses, to account
    /// for the fact that consensuses have some lifetime.
    const MIN_AGE_TO_ALLOW: Duration = Duration::from_secs(3 * 3600);
8
    let allow_skew = std::cmp::max(MIN_AGE_TO_ALLOW, tolerance.post_valid_tolerance);
8
    let cutoff = time::OffsetDateTime::from(now - allow_skew);
8
    // We now round cutoff to the next hour, so that we aren't leaking our exact
8
    // time to the directory cache.
8
    //
8
    // With the time crate, it's easier to calculate the "next hour" by rounding
8
    // _down_ then adding an hour; rounding up would sometimes require changing
8
    // the date too.
8
    let (h, _m, _s) = cutoff.to_hms();
8
    let cutoff = cutoff.replace_time(
8
        time::Time::from_hms(h, 0, 0)
8
            .map_err(tor_error::into_internal!("Failed clock calculation"))?,
    );
8
    let cutoff = cutoff + Duration::from_secs(3600);
8

            
8
    Ok(cutoff.into())
8
}
/// Return a list of the protocols [supported](tor_protover::doc_supported) by this crate
/// when running as a client.
177
pub fn supported_client_protocols() -> tor_protover::Protocols {
    use tor_protover::named::*;
    // WARNING: REMOVING ELEMENTS FROM THIS LIST CAN BE DANGEROUS!
    // SEE [`tor_protover::doc_changing`]
177
    [
177
        //
177
        DIRCACHE_CONSDIFF,
177
    ]
177
    .into_iter()
177
    .collect()
177
}
#[cfg(test)]
mod test {
    // @@ begin test lint list maintained by maint/add_warning @@
    #![allow(clippy::bool_assert_comparison)]
    #![allow(clippy::clone_on_copy)]
    #![allow(clippy::dbg_macro)]
    #![allow(clippy::mixed_attributes_style)]
    #![allow(clippy::print_stderr)]
    #![allow(clippy::print_stdout)]
    #![allow(clippy::single_char_pattern)]
    #![allow(clippy::unwrap_used)]
    #![allow(clippy::unchecked_duration_subtraction)]
    #![allow(clippy::useless_vec)]
    #![allow(clippy::needless_pass_by_value)]
    //! <!-- @@ end test lint list maintained by maint/add_warning @@ -->
    use super::*;
    use crate::docmeta::{AuthCertMeta, ConsensusMeta};
    use std::time::Duration;
    use tempfile::TempDir;
    use tor_basic_utils::test_rng::testing_rng;
    use tor_netdoc::doc::netstatus::ConsensusFlavor;
    use tor_netdoc::doc::{authcert::AuthCertKeyIds, netstatus::Lifetime};
    use tor_rtcompat::SleepProvider;
    #[test]
    fn protocols() {
        let pr = supported_client_protocols();
        let expected = "DirCache=2".parse().unwrap();
        assert_eq!(pr, expected);
    }
    pub(crate) fn new_mgr<R: Runtime>(runtime: R) -> (TempDir, DirMgr<R>) {
        let dir = TempDir::new().unwrap();
        let config = DirMgrConfig {
            cache_dir: dir.path().into(),
            ..Default::default()
        };
        let store = DirMgrStore::new(&config, runtime.clone(), false).unwrap();
        let dirmgr = DirMgr::from_config(config, runtime, store, None, false).unwrap();
        (dir, dirmgr)
    }
    #[test]
    fn failing_accessors() {
        tor_rtcompat::test_with_one_runtime!(|rt| async {
            let (_tempdir, mgr) = new_mgr(rt);
            assert!(mgr.circmgr().is_err());
            assert!(mgr.netdir(Timeliness::Unchecked).is_err());
        });
    }
    #[test]
    fn load_and_store_internals() {
        tor_rtcompat::test_with_one_runtime!(|rt| async {
            let now = rt.wallclock();
            let tomorrow = now + Duration::from_secs(86400);
            let later = tomorrow + Duration::from_secs(86400);
            let (_tempdir, mgr) = new_mgr(rt);
            // Seed the storage with a bunch of junk.
            let d1 = [5_u8; 32];
            let d2 = [7; 32];
            let d3 = [42; 32];
            let d4 = [99; 20];
            let d5 = [12; 20];
            let certid1 = AuthCertKeyIds {
                id_fingerprint: d4.into(),
                sk_fingerprint: d5.into(),
            };
            let certid2 = AuthCertKeyIds {
                id_fingerprint: d5.into(),
                sk_fingerprint: d4.into(),
            };
            {
                let mut store = mgr.store.lock().unwrap();
                store
                    .store_microdescs(
                        &[
                            ("Fake micro 1", &d1),
                            ("Fake micro 2", &d2),
                            ("Fake micro 3", &d3),
                        ],
                        now,
                    )
                    .unwrap();
                #[cfg(feature = "routerdesc")]
                store
                    .store_routerdescs(&[("Fake rd1", now, &d4), ("Fake rd2", now, &d5)])
                    .unwrap();
                store
                    .store_authcerts(&[
                        (
                            AuthCertMeta::new(certid1, now, tomorrow),
                            "Fake certificate one",
                        ),
                        (
                            AuthCertMeta::new(certid2, now, tomorrow),
                            "Fake certificate two",
                        ),
                    ])
                    .unwrap();
                let cmeta = ConsensusMeta::new(
                    Lifetime::new(now, tomorrow, later).unwrap(),
                    [102; 32],
                    [103; 32],
                );
                store
                    .store_consensus(&cmeta, ConsensusFlavor::Microdesc, false, "Fake consensus!")
                    .unwrap();
            }
            // Try to get it with text().
            let t1 = mgr.text(&DocId::Microdesc(d1)).unwrap().unwrap();
            assert_eq!(t1.as_str(), Ok("Fake micro 1"));
            let t2 = mgr
                .text(&DocId::LatestConsensus {
                    flavor: ConsensusFlavor::Microdesc,
                    cache_usage: CacheUsage::CacheOkay,
                })
                .unwrap()
                .unwrap();
            assert_eq!(t2.as_str(), Ok("Fake consensus!"));
            let t3 = mgr.text(&DocId::Microdesc([255; 32])).unwrap();
            assert!(t3.is_none());
            // Now try texts()
            let d_bogus = DocId::Microdesc([255; 32]);
            let res = mgr
                .texts(vec![
                    DocId::Microdesc(d2),
                    DocId::Microdesc(d3),
                    d_bogus,
                    DocId::AuthCert(certid2),
                    #[cfg(feature = "routerdesc")]
                    DocId::RouterDesc(d5),
                ])
                .unwrap();
            assert_eq!(
                res.get(&DocId::Microdesc(d2)).unwrap().as_str(),
                Ok("Fake micro 2")
            );
            assert_eq!(
                res.get(&DocId::Microdesc(d3)).unwrap().as_str(),
                Ok("Fake micro 3")
            );
            assert!(!res.contains_key(&d_bogus));
            assert_eq!(
                res.get(&DocId::AuthCert(certid2)).unwrap().as_str(),
                Ok("Fake certificate two")
            );
            #[cfg(feature = "routerdesc")]
            assert_eq!(
                res.get(&DocId::RouterDesc(d5)).unwrap().as_str(),
                Ok("Fake rd2")
            );
        });
    }
    #[test]
    fn make_consensus_request() {
        tor_rtcompat::test_with_one_runtime!(|rt| async {
            let now = rt.wallclock();
            let tomorrow = now + Duration::from_secs(86400);
            let later = tomorrow + Duration::from_secs(86400);
            let (_tempdir, mgr) = new_mgr(rt);
            let config = DirMgrConfig::default();
            // Try with an empty store.
            let req = {
                let store = mgr.store.lock().unwrap();
                bootstrap::make_consensus_request(
                    now,
                    ConsensusFlavor::Microdesc,
                    &**store,
                    &config,
                )
                .unwrap()
            };
            let tolerance = DirTolerance::default().post_valid_tolerance;
            match req {
                ClientRequest::Consensus(r) => {
                    assert_eq!(r.old_consensus_digests().count(), 0);
                    let date = r.last_consensus_date().unwrap();
                    assert!(date >= now - tolerance);
                    assert!(date <= now - tolerance + Duration::from_secs(3600));
                }
                _ => panic!("Wrong request type"),
            }
            // Add a fake consensus record.
            let d_prev = [42; 32];
            {
                let mut store = mgr.store.lock().unwrap();
                let cmeta = ConsensusMeta::new(
                    Lifetime::new(now, tomorrow, later).unwrap(),
                    d_prev,
                    [103; 32],
                );
                store
                    .store_consensus(&cmeta, ConsensusFlavor::Microdesc, false, "Fake consensus!")
                    .unwrap();
            }
            // Now try again.
            let req = {
                let store = mgr.store.lock().unwrap();
                bootstrap::make_consensus_request(
                    now,
                    ConsensusFlavor::Microdesc,
                    &**store,
                    &config,
                )
                .unwrap()
            };
            match req {
                ClientRequest::Consensus(r) => {
                    let ds: Vec<_> = r.old_consensus_digests().collect();
                    assert_eq!(ds.len(), 1);
                    assert_eq!(ds[0], &d_prev);
                    assert_eq!(r.last_consensus_date(), Some(now));
                }
                _ => panic!("Wrong request type"),
            }
        });
    }
    #[test]
    fn make_other_requests() {
        tor_rtcompat::test_with_one_runtime!(|rt| async {
            use rand::Rng;
            let (_tempdir, mgr) = new_mgr(rt);
            let certid1 = AuthCertKeyIds {
                id_fingerprint: [99; 20].into(),
                sk_fingerprint: [100; 20].into(),
            };
            let mut rng = testing_rng();
            #[cfg(feature = "routerdesc")]
            let rd_ids: Vec<DocId> = (0..1000).map(|_| DocId::RouterDesc(rng.random())).collect();
            let md_ids: Vec<DocId> = (0..1000).map(|_| DocId::Microdesc(rng.random())).collect();
            let config = DirMgrConfig::default();
            // Try an authcert.
            let query = DocId::AuthCert(certid1);
            let store = mgr.store.lock().unwrap();
            let reqs =
                bootstrap::make_requests_for_documents(&mgr.runtime, &[query], &**store, &config)
                    .unwrap();
            assert_eq!(reqs.len(), 1);
            let req = &reqs[0];
            if let ClientRequest::AuthCert(r) = req {
                assert_eq!(r.keys().next(), Some(&certid1));
            } else {
                panic!();
            }
            // Try a bunch of mds.
            let reqs =
                bootstrap::make_requests_for_documents(&mgr.runtime, &md_ids, &**store, &config)
                    .unwrap();
            assert_eq!(reqs.len(), 2);
            assert!(matches!(reqs[0], ClientRequest::Microdescs(_)));
            // Try a bunch of rds.
            #[cfg(feature = "routerdesc")]
            {
                let reqs = bootstrap::make_requests_for_documents(
                    &mgr.runtime,
                    &rd_ids,
                    &**store,
                    &config,
                )
                .unwrap();
                assert_eq!(reqs.len(), 2);
                assert!(matches!(reqs[0], ClientRequest::RouterDescs(_)));
            }
        });
    }
    #[test]
    fn expand_response() {
        tor_rtcompat::test_with_one_runtime!(|rt| async {
            let now = rt.wallclock();
            let day = Duration::from_secs(86400);
            let config = DirMgrConfig::default();
            let (_tempdir, mgr) = new_mgr(rt);
            // Try a simple request: nothing should happen.
            let q = DocId::Microdesc([99; 32]);
            let r = {
                let store = mgr.store.lock().unwrap();
                bootstrap::make_requests_for_documents(&mgr.runtime, &[q], &**store, &config)
                    .unwrap()
            };
            let expanded = mgr.expand_response_text(&r[0], "ABC".to_string());
            assert_eq!(&expanded.unwrap(), "ABC");
            // Try a consensus response that doesn't look like a diff in
            // response to a query that doesn't ask for one.
            let latest_id = DocId::LatestConsensus {
                flavor: ConsensusFlavor::Microdesc,
                cache_usage: CacheUsage::CacheOkay,
            };
            let r = {
                let store = mgr.store.lock().unwrap();
                bootstrap::make_requests_for_documents(
                    &mgr.runtime,
                    &[latest_id],
                    &**store,
                    &config,
                )
                .unwrap()
            };
            let expanded = mgr.expand_response_text(&r[0], "DEF".to_string());
            assert_eq!(&expanded.unwrap(), "DEF");
            // Now stick some metadata and a string into the storage so that
            // we can ask for a diff.
            {
                let mut store = mgr.store.lock().unwrap();
                let d_in = [0x99; 32]; // This one, we can fake.
                let cmeta = ConsensusMeta::new(
                    Lifetime::new(now, now + day, now + 2 * day).unwrap(),
                    d_in,
                    d_in,
                );
                store
                    .store_consensus(
                        &cmeta,
                        ConsensusFlavor::Microdesc,
                        false,
                        "line 1\nline2\nline 3\n",
                    )
                    .unwrap();
            }
            // Try expanding something that isn't a consensus, even if we'd like
            // one.
            let r = {
                let store = mgr.store.lock().unwrap();
                bootstrap::make_requests_for_documents(
                    &mgr.runtime,
                    &[latest_id],
                    &**store,
                    &config,
                )
                .unwrap()
            };
            let expanded = mgr.expand_response_text(&r[0], "hello".to_string());
            assert_eq!(&expanded.unwrap(), "hello");
            // Finally, try "expanding" a diff (by applying it and checking the digest.
            let diff = "network-status-diff-version 1
hash 9999999999999999999999999999999999999999999999999999999999999999 8382374ca766873eb0d2530643191c6eaa2c5e04afa554cbac349b5d0592d300
2c
replacement line
.
".to_string();
            let expanded = mgr.expand_response_text(&r[0], diff);
            assert_eq!(expanded.unwrap(), "line 1\nreplacement line\nline 3\n");
            // If the digest is wrong, that should get rejected.
            let diff = "network-status-diff-version 1
hash 9999999999999999999999999999999999999999999999999999999999999999 9999999999999999999999999999999999999999999999999999999999999999
2c
replacement line
.
".to_string();
            let expanded = mgr.expand_response_text(&r[0], diff);
            assert!(expanded.is_err());
        });
    }
}