1
//! The onion service publisher reactor.
2
//!
3
//! Generates and publishes hidden service descriptors in response to various events.
4
//!
5
//! [`Reactor::run`] is the entry-point of the reactor. It starts the reactor,
6
//! and runs until [`Reactor::run_once`] returns [`ShutdownStatus::Terminate`]
7
//! or a fatal error occurs. `ShutdownStatus::Terminate` is returned if
8
//! any of the channels the reactor is receiving events from is closed
9
//! (i.e. when the senders are dropped).
10
//!
11
//! ## Publisher status
12
//!
13
//! The publisher has an internal [`PublishStatus`], distinct from its [`State`],
14
//! which is used for onion service status reporting.
15
//!
16
//! The main loop of the reactor reads the current `PublishStatus` from `publish_status_rx`,
17
//! and responds by generating and publishing a new descriptor if needed.
18
//!
19
//! See [`PublishStatus`] and [`Reactor::publish_status_rx`] for more details.
20
//!
21
//! ## When do we publish?
22
//!
23
//! We generate and publish a new descriptor if
24
//!   * the introduction points have changed
25
//!   * the onion service configuration has changed in a meaningful way (for example,
26
//!     if the `restricted_discovery` configuration or its [`Anonymity`](crate::Anonymity)
27
//!     has changed. See [`OnionServiceConfigPublisherView`]).
28
//!   * there is a new consensus
29
//!   * it is time to republish the descriptor (after we upload a descriptor,
30
//!     we schedule it for republishing at a random time between 60 minutes and 120 minutes
31
//!     in the future)
32
//!
33
//! ## Onion service status
34
//!
35
//! With respect to [`OnionServiceStatus`] reporting,
36
//! the following state transitions are possible:
37
//!
38
//!
39
//! ```ignore
40
//!
41
//!                 update_publish_status(UploadScheduled|AwaitingIpts|RateLimited)
42
//!                +---------------------------------------+
43
//!                |                                       |
44
//!                |                                       v
45
//!                |                               +---------------+
46
//!                |                               | Bootstrapping |
47
//!                |                               +---------------+
48
//!                |                                       |
49
//!                |                                       |           uploaded to at least
50
//!                |  not enough HsDir uploads succeeded   |        some HsDirs from each ring
51
//!                |         +-----------------------------+-----------------------+
52
//!                |         |                             |                       |
53
//!                |         |              all HsDir uploads succeeded            |
54
//!                |         |                             |                       |
55
//!                |         v                             v                       v
56
//!                |  +---------------------+         +---------+        +---------------------+
57
//!                |  | DegradedUnreachable |         | Running |        |  DegradedReachable  |
58
//! +----------+   |  +---------------------+         +---------+        +---------------------+
59
//! | Shutdown |-- |         |                           |                        |
60
//! +----------+   |         |                           |                        |
61
//!                |         |                           |                        |
62
//!                |         |                           |                        |
63
//!                |         +---------------------------+------------------------+
64
//!                |                                     |   invalid authorized_clients
65
//!                |                                     |      after handling config change
66
//!                |                                     |
67
//!                |                                     v
68
//!                |     run_once() returns an error +--------+
69
//!                +-------------------------------->| Broken |
70
//!                                                  +--------+
71
//! ```
72
//!
73
//! We can also transition from `Broken`, `DegradedReachable`, or `DegradedUnreachable`
74
//! back to `Bootstrapping` (those transitions were omitted for brevity).
75

            
76
use tor_config::file_watcher::{
77
    self, Event as FileEvent, FileEventReceiver, FileEventSender, FileWatcher, FileWatcherBuilder,
78
};
79
use tor_config_path::{CfgPath, CfgPathResolver};
80
use tor_dirclient::SourceInfo;
81
use tor_netdir::{DirEvent, NetDir};
82

            
83
use crate::config::restricted_discovery::{
84
    DirectoryKeyProviderList, RestrictedDiscoveryConfig, RestrictedDiscoveryKeys,
85
};
86
use crate::config::OnionServiceConfigPublisherView;
87
use crate::status::{DescUploadRetryError, Problem};
88

            
89
use super::*;
90

            
91
// TODO-CLIENT-AUTH: perhaps we should add a separate CONFIG_CHANGE_REPUBLISH_DEBOUNCE_INTERVAL
92
// for rate-limiting the publish jobs triggered by a change in the config?
93
//
94
// Currently the descriptor publish tasks triggered by changes in the config
95
// are rate-limited via the usual rate limiting mechanism
96
// (which rate-limits the uploads for 1m).
97
//
98
// I think this is OK for now, but we might need to rethink this if it becomes problematic
99
// (for example, we might want an even longer rate-limit, or to reset any existing rate-limits
100
// each time the config is modified).
101

            
102
/// The upload rate-limiting threshold.
103
///
104
/// Before initiating an upload, the reactor checks if the last upload was at least
105
/// `UPLOAD_RATE_LIM_THRESHOLD` seconds ago. If so, it uploads the descriptor to all HsDirs that
106
/// need it. If not, it schedules the upload to happen `UPLOAD_RATE_LIM_THRESHOLD` seconds from the
107
/// current time.
108
//
109
// TODO: We may someday need to tune this value; it was chosen more or less arbitrarily.
110
const UPLOAD_RATE_LIM_THRESHOLD: Duration = Duration::from_secs(60);
111

            
112
/// The maximum number of concurrent upload tasks per time period.
113
//
114
// TODO: this value was arbitrarily chosen and may not be optimal.  For now, it
115
// will have no effect, since the current number of replicas is far less than
116
// this value.
117
//
118
// The uploads for all TPs happen in parallel.  As a result, the actual limit for the maximum
119
// number of concurrent upload tasks is multiplied by a number which depends on the TP parameters
120
// (currently 2, which means the concurrency limit will, in fact, be 32).
121
//
122
// We should try to decouple this value from the TP parameters.
123
const MAX_CONCURRENT_UPLOADS: usize = 16;
124

            
125
/// The maximum time allowed for uploading a descriptor to a single HSDir,
126
/// across all attempts.
127
pub(crate) const OVERALL_UPLOAD_TIMEOUT: Duration = Duration::from_secs(5 * 60);
128

            
129
/// A reactor for the HsDir [`Publisher`]
130
///
131
/// The entrypoint is [`Reactor::run`].
132
#[must_use = "If you don't call run() on the reactor, it won't publish any descriptors."]
133
pub(super) struct Reactor<R: Runtime, M: Mockable> {
134
    /// The immutable, shared inner state.
135
    imm: Arc<Immutable<R, M>>,
136
    /// A source for new network directories that we use to determine
137
    /// our HsDirs.
138
    dir_provider: Arc<dyn NetDirProvider>,
139
    /// The mutable inner state,
140
    inner: Arc<Mutex<Inner>>,
141
    /// A channel for receiving IPT change notifications.
142
    ipt_watcher: IptsPublisherView,
143
    /// A channel for receiving onion service config change notifications.
144
    config_rx: watch::Receiver<Arc<OnionServiceConfig>>,
145
    /// A channel for receiving restricted discovery key_dirs change notifications.
146
    key_dirs_rx: FileEventReceiver,
147
    /// A channel for sending restricted discovery key_dirs change notifications.
148
    ///
149
    /// A copy of this sender is handed out to every `FileWatcher` created.
150
    key_dirs_tx: FileEventSender,
151
    /// A channel for receiving updates regarding our [`PublishStatus`].
152
    ///
153
    /// The main loop of the reactor watches for updates on this channel.
154
    ///
155
    /// When the [`PublishStatus`] changes to [`UploadScheduled`](PublishStatus::UploadScheduled),
156
    /// we can start publishing descriptors.
157
    ///
158
    /// If the [`PublishStatus`] is [`AwaitingIpts`](PublishStatus::AwaitingIpts), publishing is
159
    /// paused until we receive a notification on `ipt_watcher` telling us the IPT manager has
160
    /// established some introduction points.
161
    publish_status_rx: watch::Receiver<PublishStatus>,
162
    /// A sender for updating our [`PublishStatus`].
163
    ///
164
    /// When our [`PublishStatus`] changes to [`UploadScheduled`](PublishStatus::UploadScheduled),
165
    /// we can start publishing descriptors.
166
    publish_status_tx: watch::Sender<PublishStatus>,
167
    /// A channel for sending upload completion notifications.
168
    ///
169
    /// This channel is polled in the main loop of the reactor.
170
    upload_task_complete_rx: mpsc::Receiver<TimePeriodUploadResult>,
171
    /// A channel for receiving upload completion notifications.
172
    ///
173
    /// A copy of this sender is handed to each upload task.
174
    upload_task_complete_tx: mpsc::Sender<TimePeriodUploadResult>,
175
    /// A sender for notifying any pending upload tasks that the reactor is shutting down.
176
    ///
177
    /// Receivers can use this channel to find out when reactor is dropped.
178
    ///
179
    /// This is currently only used in [`upload_for_time_period`](Reactor::upload_for_time_period).
180
    /// Any future background tasks can also use this channel to detect if the reactor is dropped.
181
    ///
182
    /// Closing this channel will cause any pending upload tasks to be dropped.
183
    shutdown_tx: broadcast::Sender<Void>,
184
    /// Path resolver for configuration files.
185
    path_resolver: Arc<CfgPathResolver>,
186
    /// Queue on which we receive messages from the [`PowManager`] telling us that a seed has
187
    /// rotated and thus we need to republish the descriptor for a particular time period.
188
    update_from_pow_manager_rx: mpsc::Receiver<TimePeriod>,
189
}
190

            
191
/// The immutable, shared state of the descriptor publisher reactor.
192
#[derive(Clone)]
193
struct Immutable<R: Runtime, M: Mockable> {
194
    /// The runtime.
195
    runtime: R,
196
    /// Mockable state.
197
    ///
198
    /// This is used for launching circuits and for obtaining random number generators.
199
    mockable: M,
200
    /// The service for which we're publishing descriptors.
201
    nickname: HsNickname,
202
    /// The key manager,
203
    keymgr: Arc<KeyMgr>,
204
    /// A sender for updating the status of the onion service.
205
    status_tx: PublisherStatusSender,
206
    /// Proof-of-work state.
207
    pow_manager: Arc<PowManager<R>>,
208
}
209

            
210
impl<R: Runtime, M: Mockable> Immutable<R, M> {
211
    /// Create an [`AesOpeKey`] for generating revision counters for the descriptors associated
212
    /// with the specified [`TimePeriod`].
213
    ///
214
    /// If the onion service is not running in offline mode, the key of the returned `AesOpeKey` is
215
    /// the private part of the blinded identity key. Otherwise, the key is the private part of the
216
    /// descriptor signing key.
217
    ///
218
    /// Returns an error if the service is running in offline mode and the descriptor signing
219
    /// keypair of the specified `period` is not available.
220
    //
221
    // TODO (#1194): we don't support "offline" mode (yet), so this always returns an AesOpeKey
222
    // built from the blinded id key
223
    fn create_ope_key(&self, period: TimePeriod) -> Result<AesOpeKey, FatalError> {
224
        let ope_key = match read_blind_id_keypair(&self.keymgr, &self.nickname, period)? {
225
            Some(key) => {
226
                let key: ed25519::ExpandedKeypair = key.into();
227
                key.to_secret_key_bytes()[0..32]
228
                    .try_into()
229
                    .expect("Wrong length on slice")
230
            }
231
            None => {
232
                // TODO (#1194): we don't support externally provisioned keys (yet), so this branch
233
                // is unreachable (for now).
234
                let desc_sign_key_spec =
235
                    DescSigningKeypairSpecifier::new(self.nickname.clone(), period);
236
                let key: ed25519::Keypair = self
237
                    .keymgr
238
                    .get::<HsDescSigningKeypair>(&desc_sign_key_spec)?
239
                    // TODO (#1194): internal! is not the right type for this error (we need an
240
                    // error type for the case where a hidden service running in offline mode has
241
                    // run out of its pre-previsioned keys).
242
                    //
243
                    // This will be addressed when we add support for offline hs_id mode
244
                    .ok_or_else(|| internal!("identity keys are offline, but descriptor signing key is unavailable?!"))?
245
                    .into();
246
                key.to_bytes()
247
            }
248
        };
249

            
250
        Ok(AesOpeKey::from_secret(&ope_key))
251
    }
252

            
253
    /// Generate a revision counter for a descriptor associated with the specified
254
    /// [`TimePeriod`].
255
    ///
256
    /// Returns a revision counter generated according to the [encrypted time in period] scheme.
257
    ///
258
    /// [encrypted time in period]: https://spec.torproject.org/rend-spec/revision-counter-mgt.html#encrypted-time
259
    fn generate_revision_counter(
260
        &self,
261
        params: &HsDirParams,
262
        now: SystemTime,
263
    ) -> Result<RevisionCounter, FatalError> {
264
        // TODO: in the future, we might want to compute ope_key once per time period (as oppposed
265
        // to each time we generate a new descriptor), for performance reasons.
266
        let ope_key = self.create_ope_key(params.time_period())?;
267

            
268
        // TODO: perhaps this should be moved to a new HsDirParams::offset_within_sr() function
269
        let srv_start = params.start_of_shard_rand_period();
270
        let offset = params.offset_within_srv_period(now).ok_or_else(|| {
271
            internal!(
272
                "current wallclock time not within SRV range?! (now={:?}, SRV_start={:?})",
273
                now,
274
                srv_start
275
            )
276
        })?;
277
        let rev = ope_key.encrypt(offset);
278

            
279
        Ok(RevisionCounter::from(rev))
280
    }
281
}
282

            
283
/// Mockable state for the descriptor publisher reactor.
284
///
285
/// This enables us to mock parts of the [`Reactor`] for testing purposes.
286
#[async_trait]
287
pub(crate) trait Mockable: Clone + Send + Sync + Sized + 'static {
288
    /// The type of random number generator.
289
    type Rng: rand::Rng + rand::CryptoRng;
290

            
291
    /// The type of client circuit.
292
    type ClientCirc: MockableClientCirc;
293

            
294
    /// Return a random number generator.
295
    fn thread_rng(&self) -> Self::Rng;
296

            
297
    /// Create a circuit of the specified `kind` to `target`.
298
    async fn get_or_launch_specific<T>(
299
        &self,
300
        netdir: &NetDir,
301
        kind: HsCircKind,
302
        target: T,
303
    ) -> Result<Arc<Self::ClientCirc>, tor_circmgr::Error>
304
    where
305
        T: CircTarget + Send + Sync;
306

            
307
    /// Return an estimate-based value for how long we should allow a single
308
    /// directory upload operation to complete.
309
    ///
310
    /// Includes circuit construction, stream opening, upload, and waiting for a
311
    /// response.
312
    fn estimate_upload_timeout(&self) -> Duration;
313
}
314

            
315
/// Mockable client circuit
316
#[async_trait]
317
pub(crate) trait MockableClientCirc: Send + Sync {
318
    /// The data stream type.
319
    type DataStream: AsyncRead + AsyncWrite + Send + Unpin;
320

            
321
    /// Start a new stream to the last relay in the circuit, using
322
    /// a BEGIN_DIR cell.
323
    async fn begin_dir_stream(self: Arc<Self>) -> Result<Self::DataStream, tor_proto::Error>;
324

            
325
    /// Try to get a SourceInfo for this circuit, for using it in a directory request.
326
    fn source_info(&self) -> tor_proto::Result<Option<SourceInfo>>;
327
}
328

            
329
#[async_trait]
330
impl MockableClientCirc for ClientCirc {
331
    type DataStream = tor_proto::stream::DataStream;
332

            
333
    async fn begin_dir_stream(self: Arc<Self>) -> Result<Self::DataStream, tor_proto::Error> {
334
        ClientCirc::begin_dir_stream(self).await
335
    }
336

            
337
    fn source_info(&self) -> tor_proto::Result<Option<SourceInfo>> {
338
        SourceInfo::from_circuit(self)
339
    }
340
}
341

            
342
/// The real version of the mockable state of the reactor.
343
#[derive(Clone, From, Into)]
344
pub(crate) struct Real<R: Runtime>(Arc<HsCircPool<R>>);
345

            
346
#[async_trait]
347
impl<R: Runtime> Mockable for Real<R> {
348
    type Rng = rand::rngs::ThreadRng;
349
    type ClientCirc = ClientCirc;
350

            
351
    fn thread_rng(&self) -> Self::Rng {
352
        rand::rng()
353
    }
354

            
355
    async fn get_or_launch_specific<T>(
356
        &self,
357
        netdir: &NetDir,
358
        kind: HsCircKind,
359
        target: T,
360
    ) -> Result<Arc<ClientCirc>, tor_circmgr::Error>
361
    where
362
        T: CircTarget + Send + Sync,
363
    {
364
        self.0.get_or_launch_specific(netdir, kind, target).await
365
    }
366

            
367
    fn estimate_upload_timeout(&self) -> Duration {
368
        use tor_circmgr::timeouts::Action;
369
        let est_build = self.0.estimate_timeout(&Action::BuildCircuit { length: 4 });
370
        let est_roundtrip = self.0.estimate_timeout(&Action::RoundTrip { length: 4 });
371
        // We assume that in the worst case we'll have to wait for an entire
372
        // circuit construction and two round-trips to the hsdir.
373
        let est_total = est_build + est_roundtrip * 2;
374
        // We always allow _at least_ this much time, in case our estimate is
375
        // ridiculously low.
376
        let min_timeout = Duration::from_secs(30);
377
        max(est_total, min_timeout)
378
    }
379
}
380

            
381
/// The mutable state of a [`Reactor`].
382
struct Inner {
383
    /// The onion service config.
384
    config: Arc<OnionServiceConfigPublisherView>,
385
    /// Watcher for key_dirs.
386
    ///
387
    /// Set to `None` if the reactor is not running, or if `watch_configuration` is false.
388
    ///
389
    /// The watcher is recreated whenever the `restricted_discovery.key_dirs` change.
390
    file_watcher: Option<FileWatcher>,
391
    /// The relevant time periods.
392
    ///
393
    /// This includes the current time period, as well as any other time periods we need to be
394
    /// publishing descriptors for.
395
    ///
396
    /// This is empty until we fetch our first netdir in [`Reactor::run`].
397
    time_periods: Vec<TimePeriodContext>,
398
    /// Our most up to date netdir.
399
    ///
400
    /// This is initialized in [`Reactor::run`].
401
    netdir: Option<Arc<NetDir>>,
402
    /// The timestamp of our last upload.
403
    ///
404
    /// This is the time when the last update was _initiated_ (rather than completed), to prevent
405
    /// the publisher from spawning multiple upload tasks at once in response to multiple external
406
    /// events happening in quick succession, such as the IPT manager sending multiple IPT change
407
    /// notifications in a short time frame (#1142), or an IPT change notification that's
408
    /// immediately followed by a consensus change. Starting two upload tasks at once is not only
409
    /// inefficient, but it also causes the publisher to generate two different descriptors with
410
    /// the same revision counter (the revision counter is derived from the current timestamp),
411
    /// which ultimately causes the slower upload task to fail (see #1142).
412
    ///
413
    /// Note: This is only used for deciding when to reschedule a rate-limited upload. It is _not_
414
    /// used for retrying failed uploads (these are handled internally by
415
    /// [`Reactor::upload_descriptor_with_retries`]).
416
    last_uploaded: Option<Instant>,
417
    /// A max-heap containing the time periods for which we need to reupload the descriptor.
418
    // TODO: we are currently reuploading more than nececessary.
419
    // Ideally, this shouldn't contain contain duplicate TimePeriods,
420
    // because we only need to retain the latest reupload time for each time period.
421
    //
422
    // Currently, if, for some reason, we upload the descriptor multiple times for the same TP,
423
    // we will end up with multiple ReuploadTimer entries for that TP,
424
    // each of which will (eventually) result in a reupload.
425
    //
426
    // TODO: maybe this should just be a HashMap<TimePeriod, Instant>
427
    //
428
    // See https://gitlab.torproject.org/tpo/core/arti/-/merge_requests/1971#note_2994950
429
    reupload_timers: BinaryHeap<ReuploadTimer>,
430
    /// The restricted discovery authorized clients.
431
    ///
432
    /// `None`, unless the service is running in restricted discovery mode.
433
    authorized_clients: Option<Arc<RestrictedDiscoveryKeys>>,
434
}
435

            
436
/// The part of the reactor state that changes with every time period.
437
struct TimePeriodContext {
438
    /// The HsDir params.
439
    params: HsDirParams,
440
    /// The HsDirs to use in this time period.
441
    ///
442
    // We keep a list of `RelayIds` because we can't store a `Relay<'_>` inside the reactor
443
    // (the lifetime of a relay is tied to the lifetime of its corresponding `NetDir`. To
444
    // store `Relay<'_>`s in the reactor, we'd need a way of atomically swapping out both the
445
    // `NetDir` and the cached relays, and to convince Rust what we're doing is sound)
446
    hs_dirs: Vec<(RelayIds, DescriptorStatus)>,
447
    /// The revision counter of the last successful upload, if any.
448
    last_successful: Option<RevisionCounter>,
449
    /// The outcome of the last upload, if any.
450
    upload_results: Vec<HsDirUploadStatus>,
451
}
452

            
453
impl TimePeriodContext {
454
    /// Create a new `TimePeriodContext`.
455
    ///
456
    /// Any of the specified `old_hsdirs` also present in the new list of HsDirs
457
    /// (returned by `NetDir::hs_dirs_upload`) will have their `DescriptorStatus` preserved.
458
    fn new<'r>(
459
        params: HsDirParams,
460
        blind_id: HsBlindId,
461
        netdir: &Arc<NetDir>,
462
        old_hsdirs: impl Iterator<Item = &'r (RelayIds, DescriptorStatus)>,
463
        old_upload_results: Vec<HsDirUploadStatus>,
464
    ) -> Result<Self, FatalError> {
465
        let period = params.time_period();
466
        let hs_dirs = Self::compute_hsdirs(period, blind_id, netdir, old_hsdirs)?;
467
        let upload_results = old_upload_results
468
            .into_iter()
469
            .filter(|res|
470
                // Check if the HsDir of this result still exists
471
                hs_dirs
472
                    .iter()
473
                    .any(|(relay_ids, _status)| relay_ids == &res.relay_ids))
474
            .collect();
475

            
476
        Ok(Self {
477
            params,
478
            hs_dirs,
479
            last_successful: None,
480
            upload_results,
481
        })
482
    }
483

            
484
    /// Recompute the HsDirs for this time period.
485
    fn compute_hsdirs<'r>(
486
        period: TimePeriod,
487
        blind_id: HsBlindId,
488
        netdir: &Arc<NetDir>,
489
        mut old_hsdirs: impl Iterator<Item = &'r (RelayIds, DescriptorStatus)>,
490
    ) -> Result<Vec<(RelayIds, DescriptorStatus)>, FatalError> {
491
        let hs_dirs = netdir.hs_dirs_upload(blind_id, period)?;
492

            
493
        Ok(hs_dirs
494
            .map(|hs_dir| {
495
                let mut builder = RelayIds::builder();
496
                if let Some(ed_id) = hs_dir.ed_identity() {
497
                    builder.ed_identity(*ed_id);
498
                }
499

            
500
                if let Some(rsa_id) = hs_dir.rsa_identity() {
501
                    builder.rsa_identity(*rsa_id);
502
                }
503

            
504
                let relay_id = builder.build().unwrap_or_else(|_| RelayIds::empty());
505

            
506
                // Have we uploaded the descriptor to thiw relay before? If so, we don't need to
507
                // reupload it unless it was already dirty and due for a reupload.
508
                let status = match old_hsdirs.find(|(id, _)| *id == relay_id) {
509
                    Some((_, status)) => *status,
510
                    None => DescriptorStatus::Dirty,
511
                };
512

            
513
                (relay_id, status)
514
            })
515
            .collect::<Vec<_>>())
516
    }
517

            
518
    /// Mark the descriptor dirty for all HSDirs of this time period.
519
    fn mark_all_dirty(&mut self) {
520
        self.hs_dirs
521
            .iter_mut()
522
            .for_each(|(_relay_id, status)| *status = DescriptorStatus::Dirty);
523
    }
524

            
525
    /// Update the upload result for this time period.
526
    fn set_upload_results(&mut self, upload_results: Vec<HsDirUploadStatus>) {
527
        self.upload_results = upload_results;
528
    }
529
}
530

            
531
/// An error that occurs while trying to upload a descriptor.
532
#[derive(Clone, Debug, thiserror::Error)]
533
#[non_exhaustive]
534
pub enum UploadError {
535
    /// An error that has occurred after we have contacted a directory cache and made a circuit to it.
536
    #[error("descriptor upload request failed: {}", _0.error)]
537
    Request(#[from] RequestFailedError),
538

            
539
    /// Failed to establish circuit to hidden service directory
540
    #[error("could not build circuit to HsDir")]
541
    Circuit(#[from] tor_circmgr::Error),
542

            
543
    /// Failed to establish stream to hidden service directory
544
    #[error("failed to establish directory stream to HsDir")]
545
    Stream(#[source] tor_proto::Error),
546

            
547
    /// An internal error.
548
    #[error("Internal error")]
549
    Bug(#[from] tor_error::Bug),
550
}
551
define_asref_dyn_std_error!(UploadError);
552

            
553
impl UploadError {
554
    /// Return true if this error is one that we should report as a suspicious event,
555
    /// along with the dirserver, and description of the relevant document.
556
    pub(crate) fn should_report_as_suspicious(&self) -> bool {
557
        match self {
558
            UploadError::Request(e) => e.error.should_report_as_suspicious_if_anon(),
559
            UploadError::Circuit(_) => false, // TODO prop360
560
            UploadError::Stream(_) => false,  // TODO prop360
561
            UploadError::Bug(_) => false,
562
        }
563
    }
564
}
565

            
566
impl<R: Runtime, M: Mockable> Reactor<R, M> {
567
    /// Create a new `Reactor`.
568
    #[allow(clippy::too_many_arguments)]
569
    pub(super) fn new(
570
        runtime: R,
571
        nickname: HsNickname,
572
        dir_provider: Arc<dyn NetDirProvider>,
573
        mockable: M,
574
        config: &OnionServiceConfig,
575
        ipt_watcher: IptsPublisherView,
576
        config_rx: watch::Receiver<Arc<OnionServiceConfig>>,
577
        status_tx: PublisherStatusSender,
578
        keymgr: Arc<KeyMgr>,
579
        path_resolver: Arc<CfgPathResolver>,
580
        pow_manager: Arc<PowManager<R>>,
581
        update_from_pow_manager_rx: mpsc::Receiver<TimePeriod>,
582
    ) -> Self {
583
        /// The maximum size of the upload completion notifier channel.
584
        ///
585
        /// The channel we use this for is a futures::mpsc channel, which has a capacity of
586
        /// `UPLOAD_CHAN_BUF_SIZE + num-senders`. We don't need the buffer size to be non-zero, as
587
        /// each sender will send exactly one message.
588
        const UPLOAD_CHAN_BUF_SIZE: usize = 0;
589

            
590
        // Internally-generated instructions, no need for mq.
591
        let (upload_task_complete_tx, upload_task_complete_rx) =
592
            mpsc_channel_no_memquota(UPLOAD_CHAN_BUF_SIZE);
593

            
594
        let (publish_status_tx, publish_status_rx) = watch::channel();
595
        // Setting the buffer size to zero here is OK,
596
        // since we never actually send anything on this channel.
597
        let (shutdown_tx, _shutdown_rx) = broadcast::channel(0);
598

            
599
        let authorized_clients =
600
            Self::read_authorized_clients(&config.restricted_discovery, &path_resolver);
601

            
602
        // Create a channel for watching for changes in the configured
603
        // restricted_discovery.key_dirs.
604
        let (key_dirs_tx, key_dirs_rx) = file_watcher::channel();
605

            
606
        let imm = Immutable {
607
            runtime,
608
            mockable,
609
            nickname,
610
            keymgr,
611
            status_tx,
612
            pow_manager,
613
        };
614

            
615
        let inner = Inner {
616
            time_periods: vec![],
617
            config: Arc::new(config.into()),
618
            file_watcher: None,
619
            netdir: None,
620
            last_uploaded: None,
621
            reupload_timers: Default::default(),
622
            authorized_clients,
623
        };
624

            
625
        Self {
626
            imm: Arc::new(imm),
627
            inner: Arc::new(Mutex::new(inner)),
628
            dir_provider,
629
            ipt_watcher,
630
            config_rx,
631
            key_dirs_rx,
632
            key_dirs_tx,
633
            publish_status_rx,
634
            publish_status_tx,
635
            upload_task_complete_rx,
636
            upload_task_complete_tx,
637
            shutdown_tx,
638
            path_resolver,
639
            update_from_pow_manager_rx,
640
        }
641
    }
642

            
643
    /// Start the reactor.
644
    ///
645
    /// Under normal circumstances, this function runs indefinitely.
646
    ///
647
    /// Note: this also spawns the "reminder task" that we use to reschedule uploads whenever an
648
    /// upload fails or is rate-limited.
649
    pub(super) async fn run(mut self) -> Result<(), FatalError> {
650
        debug!(nickname=%self.imm.nickname, "starting descriptor publisher reactor");
651

            
652
        {
653
            let netdir = self
654
                .dir_provider
655
                .wait_for_netdir(Timeliness::Timely)
656
                .await?;
657
            let time_periods = self.compute_time_periods(&netdir, &[])?;
658

            
659
            let mut inner = self.inner.lock().expect("poisoned lock");
660

            
661
            inner.netdir = Some(netdir);
662
            inner.time_periods = time_periods;
663
        }
664

            
665
        // Create the initial key_dirs watcher.
666
        self.update_file_watcher();
667

            
668
        loop {
669
            match self.run_once().await {
670
                Ok(ShutdownStatus::Continue) => continue,
671
                Ok(ShutdownStatus::Terminate) => {
672
                    debug!(nickname=%self.imm.nickname, "descriptor publisher is shutting down!");
673

            
674
                    self.imm.status_tx.send_shutdown();
675
                    return Ok(());
676
                }
677
                Err(e) => {
678
                    error_report!(
679
                        e,
680
                        "HS service {}: descriptor publisher crashed!",
681
                        self.imm.nickname
682
                    );
683

            
684
                    self.imm.status_tx.send_broken(e.clone());
685

            
686
                    return Err(e);
687
                }
688
            }
689
        }
690
    }
691

            
692
    /// Run one iteration of the reactor loop.
693
    #[allow(clippy::cognitive_complexity)] // TODO: Refactor
694
    async fn run_once(&mut self) -> Result<ShutdownStatus, FatalError> {
695
        let mut netdir_events = self.dir_provider.events();
696

            
697
        // Note: TrackingNow tracks the values it is compared with.
698
        // This is equivalent to sleeping for (until - now) units of time,
699
        let upload_rate_lim: TrackingNow = TrackingNow::now(&self.imm.runtime);
700
        if let PublishStatus::RateLimited(until) = self.status() {
701
            if upload_rate_lim > until {
702
                // We are no longer rate-limited
703
                self.expire_rate_limit().await?;
704
            }
705
        }
706

            
707
        let reupload_tracking = TrackingNow::now(&self.imm.runtime);
708
        let mut reupload_periods = vec![];
709
        {
710
            let mut inner = self.inner.lock().expect("poisoned lock");
711
            let inner = &mut *inner;
712
            while let Some(reupload) = inner.reupload_timers.peek().copied() {
713
                // First, extract all the timeouts that already elapsed.
714
                if reupload.when <= reupload_tracking {
715
                    inner.reupload_timers.pop();
716
                    reupload_periods.push(reupload.period);
717
                } else {
718
                    // We are not ready to schedule any more reuploads.
719
                    //
720
                    // How much we need to sleep is implicitly
721
                    // tracked in reupload_tracking (through
722
                    // the TrackingNow implementation)
723
                    break;
724
                }
725
            }
726
        }
727

            
728
        // Check if it's time to schedule any reuploads.
729
        for period in reupload_periods {
730
            if self.mark_dirty(&period) {
731
                debug!(
732
                    time_period=?period,
733
                    "descriptor reupload timer elapsed; scheduling reupload",
734
                );
735
                self.update_publish_status_unless_rate_lim(PublishStatus::UploadScheduled)
736
                    .await?;
737
            }
738
        }
739

            
740
        select_biased! {
741
            res = self.upload_task_complete_rx.next().fuse() => {
742
                let Some(upload_res) = res else {
743
                    return Ok(ShutdownStatus::Terminate);
744
                };
745

            
746
                self.handle_upload_results(upload_res);
747
                self.upload_result_to_svc_status()?;
748
            },
749
            () = upload_rate_lim.wait_for_earliest(&self.imm.runtime).fuse() => {
750
                self.expire_rate_limit().await?;
751
            },
752
            () = reupload_tracking.wait_for_earliest(&self.imm.runtime).fuse() => {
753
                // Run another iteration, executing run_once again. This time, we will remove the
754
                // expired reupload from self.reupload_timers, mark the descriptor dirty for all
755
                // relevant HsDirs, and schedule the upload by setting our status to
756
                // UploadScheduled.
757
                return Ok(ShutdownStatus::Continue);
758
            },
759
            netdir_event = netdir_events.next().fuse() => {
760
                let Some(netdir_event) = netdir_event else {
761
                    debug!("netdir event stream ended");
762
                    return Ok(ShutdownStatus::Terminate);
763
                };
764

            
765
                if !matches!(netdir_event, DirEvent::NewConsensus) {
766
                    return Ok(ShutdownStatus::Continue);
767
                };
768

            
769
                // The consensus changed. Grab a new NetDir.
770
                let netdir = match self.dir_provider.netdir(Timeliness::Timely) {
771
                    Ok(y) => y,
772
                    Err(e) => {
773
                        error_report!(e, "HS service {}: netdir unavailable. Retrying...", self.imm.nickname);
774
                        // Hopefully a netdir will appear in the future.
775
                        // in the meantime, suspend operations.
776
                        //
777
                        // TODO (#1218): there is a bug here: we stop reading on our inputs
778
                        // including eg publish_status_rx, but it is our job to log some of
779
                        // these things.  While we are waiting for a netdir, all those messages
780
                        // are "stuck"; they'll appear later, with misleading timestamps.
781
                        //
782
                        // Probably this should be fixed by moving the logging
783
                        // out of the reactor, where it won't be blocked.
784
                        self.dir_provider.wait_for_netdir(Timeliness::Timely)
785
                            .await?
786
                    }
787
                };
788
                let relevant_periods = netdir.hs_all_time_periods();
789
                self.handle_consensus_change(netdir).await?;
790
                expire_publisher_keys(
791
                    &self.imm.keymgr,
792
                    &self.imm.nickname,
793
                    &relevant_periods,
794
                ).unwrap_or_else(|e| {
795
                    error_report!(e, "failed to remove expired keys");
796
                });
797
            }
798
            update = self.ipt_watcher.await_update().fuse() => {
799
                if self.handle_ipt_change(update).await? == ShutdownStatus::Terminate {
800
                    return Ok(ShutdownStatus::Terminate);
801
                }
802
            },
803
            config = self.config_rx.next().fuse() => {
804
                let Some(config) = config else {
805
                    return Ok(ShutdownStatus::Terminate);
806
                };
807

            
808
                self.handle_svc_config_change(&config).await?;
809
            },
810
            res = self.key_dirs_rx.next().fuse() => {
811
                let Some(event) = res else {
812
                    return Ok(ShutdownStatus::Terminate);
813
                };
814

            
815
                while let Some(_ignore) = self.key_dirs_rx.try_recv() {
816
                    // Discard other events, so that we only reload once.
817
                }
818

            
819
                self.handle_key_dirs_change(event).await?;
820
            }
821
            should_upload = self.publish_status_rx.next().fuse() => {
822
                let Some(should_upload) = should_upload else {
823
                    return Ok(ShutdownStatus::Terminate);
824
                };
825

            
826
                // Our PublishStatus changed -- are we ready to publish?
827
                if should_upload == PublishStatus::UploadScheduled {
828
                    self.update_publish_status_unless_waiting(PublishStatus::Idle).await?;
829
                    self.upload_all().await?;
830
                }
831
            }
832
            update_tp_pow_seed = self.update_from_pow_manager_rx.next().fuse() => {
833
                debug!("Update PoW seed for TP!");
834
                let Some(time_period) = update_tp_pow_seed else {
835
                    return Ok(ShutdownStatus::Terminate);
836
                };
837
                self.mark_dirty(&time_period);
838
                self.upload_all().await?;
839
            }
840
        }
841

            
842
        Ok(ShutdownStatus::Continue)
843
    }
844

            
845
    /// Returns the current status of the publisher
846
    fn status(&self) -> PublishStatus {
847
        *self.publish_status_rx.borrow()
848
    }
849

            
850
    /// Handle a batch of upload outcomes,
851
    /// possibly updating the status of the descriptor for the corresponding HSDirs.
852
    fn handle_upload_results(&self, results: TimePeriodUploadResult) {
853
        let mut inner = self.inner.lock().expect("poisoned lock");
854
        let inner = &mut *inner;
855

            
856
        // Check which time period these uploads pertain to.
857
        let period = inner
858
            .time_periods
859
            .iter_mut()
860
            .find(|ctx| ctx.params.time_period() == results.time_period);
861

            
862
        let Some(period) = period else {
863
            // The uploads were for a time period that is no longer relevant, so we
864
            // can ignore the result.
865
            return;
866
        };
867

            
868
        // We will need to reupload this descriptor at at some point, so we pick
869
        // a random time between 60 minutes and 120 minutes in the future.
870
        //
871
        // See https://spec.torproject.org/rend-spec/deriving-keys.html#WHEN-HSDESC
872
        let mut rng = self.imm.mockable.thread_rng();
873
        // TODO SPEC: Control republish period using a consensus parameter?
874
        let minutes = rng.gen_range_checked(60..=120).expect("low > high?!");
875
        let duration = Duration::from_secs(minutes * 60);
876
        let reupload_when = self.imm.runtime.now() + duration;
877
        let time_period = period.params.time_period();
878

            
879
        info!(
880
            time_period=?time_period,
881
            "reuploading descriptor in {}",
882
            humantime::format_duration(duration),
883
        );
884

            
885
        inner.reupload_timers.push(ReuploadTimer {
886
            period: time_period,
887
            when: reupload_when,
888
        });
889

            
890
        let mut upload_results = vec![];
891
        for upload_res in results.hsdir_result {
892
            let relay = period
893
                .hs_dirs
894
                .iter_mut()
895
                .find(|(relay_ids, _status)| relay_ids == &upload_res.relay_ids);
896

            
897
            let Some((_relay, status)): Option<&mut (RelayIds, _)> = relay else {
898
                // This HSDir went away, so the result doesn't matter.
899
                // Continue processing the rest of the results
900
                continue;
901
            };
902

            
903
            if upload_res.upload_res.is_ok() {
904
                let update_last_successful = match period.last_successful {
905
                    None => true,
906
                    Some(counter) => counter <= upload_res.revision_counter,
907
                };
908

            
909
                if update_last_successful {
910
                    period.last_successful = Some(upload_res.revision_counter);
911
                    // TODO (#1098): Is it possible that this won't update the statuses promptly
912
                    // enough. For example, it's possible for the reactor to see a Dirty descriptor
913
                    // and start an upload task for a descriptor has already been uploaded (or is
914
                    // being uploaded) in another task, but whose upload results have not yet been
915
                    // processed.
916
                    //
917
                    // This is probably made worse by the fact that the statuses are updated in
918
                    // batches (grouped by time period), rather than one by one as the upload tasks
919
                    // complete (updating the status involves locking the inner mutex, and I wanted
920
                    // to minimize the locking/unlocking overheads). I'm not sure handling the
921
                    // updates in batches was the correct decision here.
922
                    *status = DescriptorStatus::Clean;
923
                }
924
            }
925

            
926
            upload_results.push(upload_res);
927
        }
928

            
929
        period.set_upload_results(upload_results);
930
    }
931

            
932
    /// Maybe update our list of HsDirs.
933
    async fn handle_consensus_change(&mut self, netdir: Arc<NetDir>) -> Result<(), FatalError> {
934
        trace!("the consensus has changed; recomputing HSDirs");
935

            
936
        let _old: Option<Arc<NetDir>> = self.replace_netdir(netdir);
937

            
938
        self.recompute_hs_dirs()?;
939
        self.update_publish_status_unless_waiting(PublishStatus::UploadScheduled)
940
            .await?;
941

            
942
        // If the time period has changed, some of our upload results may now be irrelevant,
943
        // so we might need to update our status (for example, if our uploads are
944
        // for a no-longer-relevant time period, it means we might be able to update
945
        // out status from "degraded" to "running")
946
        self.upload_result_to_svc_status()?;
947

            
948
        Ok(())
949
    }
950

            
951
    /// Recompute the HsDirs for all relevant time periods.
952
    fn recompute_hs_dirs(&self) -> Result<(), FatalError> {
953
        let mut inner = self.inner.lock().expect("poisoned lock");
954
        let inner = &mut *inner;
955

            
956
        let netdir = Arc::clone(
957
            inner
958
                .netdir
959
                .as_ref()
960
                .ok_or_else(|| internal!("started upload task without a netdir"))?,
961
        );
962

            
963
        // Update our list of relevant time periods.
964
        let new_time_periods = self.compute_time_periods(&netdir, &inner.time_periods)?;
965
        inner.time_periods = new_time_periods;
966

            
967
        Ok(())
968
    }
969

            
970
    /// Compute the [`TimePeriodContext`]s for the time periods from the specified [`NetDir`].
971
    ///
972
    /// The specified `time_periods` are used to preserve the `DescriptorStatus` of the
973
    /// HsDirs where possible.
974
    fn compute_time_periods(
975
        &self,
976
        netdir: &Arc<NetDir>,
977
        time_periods: &[TimePeriodContext],
978
    ) -> Result<Vec<TimePeriodContext>, FatalError> {
979
        netdir
980
            .hs_all_time_periods()
981
            .iter()
982
            .map(|params| {
983
                let period = params.time_period();
984
                let blind_id_kp =
985
                    read_blind_id_keypair(&self.imm.keymgr, &self.imm.nickname, period)?
986
                        // Note: for now, read_blind_id_keypair cannot return Ok(None).
987
                        // It's supposed to return Ok(None) if we're in offline hsid mode,
988
                        // but that might change when we do #1194
989
                        .ok_or_else(|| internal!("offline hsid mode not supported"))?;
990

            
991
                let blind_id: HsBlindIdKey = (&blind_id_kp).into();
992

            
993
                // If our previous `TimePeriodContext`s also had an entry for `period`, we need to
994
                // preserve the `DescriptorStatus` of its HsDirs. This helps prevent unnecessarily
995
                // publishing the descriptor to the HsDirs that already have it (the ones that are
996
                // marked with DescriptorStatus::Clean).
997
                //
998
                // In other words, we only want to publish to those HsDirs that
999
                //   * are part of a new time period (which we have never published the descriptor
                //   for), or
                //   * have just been added to the ring of a time period we already knew about
                if let Some(ctx) = time_periods
                    .iter()
                    .find(|ctx| ctx.params.time_period() == period)
                {
                    TimePeriodContext::new(
                        params.clone(),
                        blind_id.into(),
                        netdir,
                        ctx.hs_dirs.iter(),
                        ctx.upload_results.clone(),
                    )
                } else {
                    // Passing an empty iterator here means all HsDirs in this TimePeriodContext
                    // will be marked as dirty, meaning we will need to upload our descriptor to them.
                    TimePeriodContext::new(
                        params.clone(),
                        blind_id.into(),
                        netdir,
                        iter::empty(),
                        vec![],
                    )
                }
            })
            .collect::<Result<Vec<TimePeriodContext>, FatalError>>()
    }
    /// Replace the old netdir with the new, returning the old.
    fn replace_netdir(&self, new_netdir: Arc<NetDir>) -> Option<Arc<NetDir>> {
        self.inner
            .lock()
            .expect("poisoned lock")
            .netdir
            .replace(new_netdir)
    }
    /// Replace our view of the service config with `new_config` if `new_config` contains changes
    /// that would cause us to generate a new descriptor.
    fn replace_config_if_changed(&self, new_config: Arc<OnionServiceConfigPublisherView>) -> bool {
        let mut inner = self.inner.lock().expect("poisoned lock");
        let old_config = &mut inner.config;
        // The fields we're interested in haven't changed, so there's no need to update
        // `inner.config`.
        if *old_config == new_config {
            return false;
        }
        let log_change = match (
            old_config.restricted_discovery.enabled,
            new_config.restricted_discovery.enabled,
        ) {
            (true, false) => Some("Disabling restricted discovery mode"),
            (false, true) => Some("Enabling restricted discovery mode"),
            _ => None,
        };
        if let Some(msg) = log_change {
            info!(nickname=%self.imm.nickname, "{}", msg);
        }
        let _old: Arc<OnionServiceConfigPublisherView> = std::mem::replace(old_config, new_config);
        true
    }
    /// Recreate the FileWatcher for watching the restricted discovery key_dirs.
    fn update_file_watcher(&self) {
        let mut inner = self.inner.lock().expect("poisoned lock");
        if inner.config.restricted_discovery.watch_configuration() {
            debug!("The restricted_discovery.key_dirs have changed, updating file watcher");
            let mut watcher = FileWatcher::builder(self.imm.runtime.clone());
            let dirs = inner.config.restricted_discovery.key_dirs().clone();
            watch_dirs(&mut watcher, &dirs, &self.path_resolver);
            let watcher = watcher
                .start_watching(self.key_dirs_tx.clone())
                .map_err(|e| {
                    // TODO: update the publish status (see also the module-level TODO about this).
                    error_report!(e, "Cannot set file watcher");
                })
                .ok();
            inner.file_watcher = watcher;
        } else {
            if inner.file_watcher.is_some() {
                debug!("removing key_dirs watcher");
            }
            inner.file_watcher = None;
        }
    }
    /// Read the intro points from `ipt_watcher`, and decide whether we're ready to start
    /// uploading.
    fn note_ipt_change(&self) -> PublishStatus {
        let mut ipts = self.ipt_watcher.borrow_for_publish();
        match ipts.ipts.as_mut() {
            Some(_ipts) => PublishStatus::UploadScheduled,
            None => PublishStatus::AwaitingIpts,
        }
    }
    /// Update our list of introduction points.
    async fn handle_ipt_change(
        &mut self,
        update: Option<Result<(), crate::FatalError>>,
    ) -> Result<ShutdownStatus, FatalError> {
        trace!(nickname=%self.imm.nickname, "received IPT change notification from IPT manager");
        match update {
            Some(Ok(())) => {
                let should_upload = self.note_ipt_change();
                debug!(nickname=%self.imm.nickname, "the introduction points have changed");
                self.mark_all_dirty();
                self.update_publish_status_unless_rate_lim(should_upload)
                    .await?;
                Ok(ShutdownStatus::Continue)
            }
            Some(Err(e)) => Err(e),
            None => {
                debug!(nickname=%self.imm.nickname, "received shut down signal from IPT manager");
                Ok(ShutdownStatus::Terminate)
            }
        }
    }
    /// Update the `PublishStatus` of the reactor with `new_state`,
    /// unless the current state is `AwaitingIpts`.
    async fn update_publish_status_unless_waiting(
        &mut self,
        new_state: PublishStatus,
    ) -> Result<(), FatalError> {
        // Only update the state if we're not waiting for intro points.
        if self.status() != PublishStatus::AwaitingIpts {
            self.update_publish_status(new_state).await?;
        }
        Ok(())
    }
    /// Update the `PublishStatus` of the reactor with `new_state`,
    /// unless the current state is `RateLimited`.
    async fn update_publish_status_unless_rate_lim(
        &mut self,
        new_state: PublishStatus,
    ) -> Result<(), FatalError> {
        // We can't exit this state until the rate-limit expires.
        if !matches!(self.status(), PublishStatus::RateLimited(_)) {
            self.update_publish_status(new_state).await?;
        }
        Ok(())
    }
    /// Unconditionally update the `PublishStatus` of the reactor with `new_state`.
    async fn update_publish_status(&mut self, new_state: PublishStatus) -> Result<(), Bug> {
        let onion_status = match new_state {
            PublishStatus::Idle => None,
            PublishStatus::UploadScheduled
            | PublishStatus::AwaitingIpts
            | PublishStatus::RateLimited(_) => Some(State::Bootstrapping),
        };
        if let Some(onion_status) = onion_status {
            self.imm.status_tx.send(onion_status, None);
        }
        trace!(
            "publisher reactor status change: {:?} -> {:?}",
            self.status(),
            new_state
        );
        self.publish_status_tx.send(new_state).await.map_err(
            |_: postage::sink::SendError<_>| internal!("failed to send upload notification?!"),
        )?;
        Ok(())
    }
    /// Update the onion svc status based on the results of the last descriptor uploads.
    fn upload_result_to_svc_status(&self) -> Result<(), FatalError> {
        let inner = self.inner.lock().expect("poisoned lock");
        let netdir = inner
            .netdir
            .as_ref()
            .ok_or_else(|| internal!("handling upload results without netdir?!"))?;
        let (state, err) = upload_result_state(netdir, &inner.time_periods);
        self.imm.status_tx.send(state, err);
        Ok(())
    }
    /// Update the descriptors based on the config change.
    async fn handle_svc_config_change(
        &mut self,
        config: &OnionServiceConfig,
    ) -> Result<(), FatalError> {
        let new_config = Arc::new(config.into());
        if self.replace_config_if_changed(Arc::clone(&new_config)) {
            self.update_file_watcher();
            self.update_authorized_clients_if_changed().await?;
            info!(nickname=%self.imm.nickname, "Config has changed, generating a new descriptor");
            self.mark_all_dirty();
            // Schedule an upload, unless we're still waiting for IPTs.
            self.update_publish_status_unless_waiting(PublishStatus::UploadScheduled)
                .await?;
        }
        Ok(())
    }
    /// Update the descriptors based on a restricted discovery key_dirs change.
    ///
    /// If the authorized clients from the [`RestrictedDiscoveryConfig`] have changed,
    /// this marks the descriptor as dirty for all time periods,
    /// and schedules a reupload.
    async fn handle_key_dirs_change(&mut self, event: FileEvent) -> Result<(), FatalError> {
        debug!("The configured key_dirs have changed");
        match event {
            FileEvent::Rescan | FileEvent::FileChanged => {
                // These events are handled in the same way, by re-reading the keys from disk
                // and republishing the descriptor if necessary
            }
            _ => return Err(internal!("file watcher event {event:?}").into()),
        };
        // Update the file watcher, in case the change was triggered by a key_dir move.
        self.update_file_watcher();
        if self.update_authorized_clients_if_changed().await? {
            self.mark_all_dirty();
            // Schedule an upload, unless we're still waiting for IPTs.
            self.update_publish_status_unless_waiting(PublishStatus::UploadScheduled)
                .await?;
        }
        Ok(())
    }
    /// Recreate the authorized_clients based on the current config.
    ///
    /// Returns `true` if the authorized clients have changed.
    async fn update_authorized_clients_if_changed(&mut self) -> Result<bool, FatalError> {
        let mut inner = self.inner.lock().expect("poisoned lock");
        let authorized_clients =
            Self::read_authorized_clients(&inner.config.restricted_discovery, &self.path_resolver);
        let clients = &mut inner.authorized_clients;
        let changed = clients.as_ref() != authorized_clients.as_ref();
        if changed {
            info!("The restricted discovery mode authorized clients have changed");
            *clients = authorized_clients;
        }
        Ok(changed)
    }
    /// Read the authorized `RestrictedDiscoveryKeys` from `config`.
    fn read_authorized_clients(
        config: &RestrictedDiscoveryConfig,
        path_resolver: &CfgPathResolver,
    ) -> Option<Arc<RestrictedDiscoveryKeys>> {
        let authorized_clients = config.read_keys(path_resolver);
        if matches!(authorized_clients.as_ref(), Some(c) if c.is_empty()) {
            warn!(
                "Running in restricted discovery mode, but we have no authorized clients. Service will be unreachable"
            );
        }
        authorized_clients.map(Arc::new)
    }
    /// Mark the descriptor dirty for all time periods.
    fn mark_all_dirty(&self) {
        trace!("marking the descriptor dirty for all time periods");
        self.inner
            .lock()
            .expect("poisoned lock")
            .time_periods
            .iter_mut()
            .for_each(|tp| tp.mark_all_dirty());
    }
    /// Mark the descriptor dirty for the specified time period.
    ///
    /// Returns `true` if the specified period is still relevant, and `false` otherwise.
    fn mark_dirty(&self, period: &TimePeriod) -> bool {
        let mut inner = self.inner.lock().expect("poisoned lock");
        let period_ctx = inner
            .time_periods
            .iter_mut()
            .find(|tp| tp.params.time_period() == *period);
        match period_ctx {
            Some(ctx) => {
                trace!(time_period=?period, "marking the descriptor dirty");
                ctx.mark_all_dirty();
                true
            }
            None => false,
        }
    }
    /// Try to upload our descriptor to the HsDirs that need it.
    ///
    /// If we've recently uploaded some descriptors, we return immediately and schedule the upload
    /// to happen after [`UPLOAD_RATE_LIM_THRESHOLD`].
    ///
    /// Failed uploads are retried
    /// (see [`upload_descriptor_with_retries`](Reactor::upload_descriptor_with_retries)).
    ///
    /// If restricted discovery mode is enabled and there are no authorized clients,
    /// we abort the upload and set our status to [`State::Broken`].
    //
    // Note: a broken restricted discovery config won't prevent future uploads from being scheduled
    // (for example if the IPTs change),
    // which can can cause the publisher's status to oscillate between `Bootstrapping` and `Broken`.
    // TODO: we might wish to refactor the publisher to be more sophisticated about this.
    //
    /// For each current time period, we spawn a task that uploads the descriptor to
    /// all the HsDirs on the HsDir ring of that time period.
    /// Each task shuts down on completion, or when the reactor is dropped.
    ///
    /// Each task reports its upload results (`TimePeriodUploadResult`)
    /// via the `upload_task_complete_tx` channel.
    /// The results are received and processed in the main loop of the reactor.
    ///
    /// Returns an error if it fails to spawn a task, or if an internal error occurs.
    #[allow(clippy::cognitive_complexity)] // TODO #2010: Refactor
    async fn upload_all(&mut self) -> Result<(), FatalError> {
        trace!("starting descriptor upload task...");
        // Abort the upload entirely if we have an empty list of authorized clients
        let authorized_clients = match self.authorized_clients() {
            Ok(authorized_clients) => authorized_clients,
            Err(e) => {
                error_report!(e, "aborting upload");
                self.imm.status_tx.send_broken(e.clone());
                // Returning an error would shut down the reactor, so we have to return Ok here.
                return Ok(());
            }
        };
        let last_uploaded = self.inner.lock().expect("poisoned lock").last_uploaded;
        let now = self.imm.runtime.now();
        // Check if we should rate-limit this upload.
        if let Some(ts) = last_uploaded {
            let duration_since_upload = now.duration_since(ts);
            if duration_since_upload < UPLOAD_RATE_LIM_THRESHOLD {
                return Ok(self.start_rate_limit(UPLOAD_RATE_LIM_THRESHOLD).await?);
            }
        }
        let mut inner = self.inner.lock().expect("poisoned lock");
        let inner = &mut *inner;
        let _ = inner.last_uploaded.insert(now);
        for period_ctx in inner.time_periods.iter_mut() {
            let upload_task_complete_tx = self.upload_task_complete_tx.clone();
            // Figure out which HsDirs we need to upload the descriptor to (some of them might already
            // have our latest descriptor, so we filter them out).
            let hs_dirs = period_ctx
                .hs_dirs
                .iter()
                .filter_map(|(relay_id, status)| {
                    if *status == DescriptorStatus::Dirty {
                        Some(relay_id.clone())
                    } else {
                        None
                    }
                })
                .collect::<Vec<_>>();
            if hs_dirs.is_empty() {
                trace!("the descriptor is clean for all HSDirs. Nothing to do");
                return Ok(());
            }
            let time_period = period_ctx.params.time_period();
            // This scope exists because rng is not Send, so it needs to fall out of scope before we
            // await anything.
            let netdir = Arc::clone(
                inner
                    .netdir
                    .as_ref()
                    .ok_or_else(|| internal!("started upload task without a netdir"))?,
            );
            let imm = Arc::clone(&self.imm);
            let ipt_upload_view = self.ipt_watcher.upload_view();
            let config = Arc::clone(&inner.config);
            let authorized_clients = authorized_clients.clone();
            trace!(nickname=%self.imm.nickname, time_period=?time_period,
                "spawning upload task"
            );
            let params = period_ctx.params.clone();
            let shutdown_rx = self.shutdown_tx.subscribe();
            // Spawn a task to upload the descriptor to all HsDirs of this time period.
            //
            // This task will shut down when the reactor is dropped (i.e. when shutdown_rx is
            // dropped).
            let _handle: () = self
                .imm
                .runtime
                .spawn(async move {
                    if let Err(e) = Self::upload_for_time_period(
                        hs_dirs,
                        &netdir,
                        config,
                        params,
                        Arc::clone(&imm),
                        ipt_upload_view.clone(),
                        authorized_clients.clone(),
                        upload_task_complete_tx,
                        shutdown_rx,
                    )
                    .await
                    {
                        error_report!(
                            e,
                            "descriptor upload failed for HS service {} and time period {:?}",
                            imm.nickname,
                            time_period
                        );
                    }
                })
                .map_err(|e| FatalError::from_spawn("upload_for_time_period task", e))?;
        }
        Ok(())
    }
    /// Upload the descriptor for the time period specified in `params`.
    ///
    /// Failed uploads are retried
    /// (see [`upload_descriptor_with_retries`](Reactor::upload_descriptor_with_retries)).
    #[allow(clippy::too_many_arguments)] // TODO: refactor
    #[allow(clippy::cognitive_complexity)] // TODO: Refactor
    async fn upload_for_time_period(
        hs_dirs: Vec<RelayIds>,
        netdir: &Arc<NetDir>,
        config: Arc<OnionServiceConfigPublisherView>,
        params: HsDirParams,
        imm: Arc<Immutable<R, M>>,
        ipt_upload_view: IptsPublisherUploadView,
        authorized_clients: Option<Arc<RestrictedDiscoveryKeys>>,
        mut upload_task_complete_tx: mpsc::Sender<TimePeriodUploadResult>,
        shutdown_rx: broadcast::Receiver<Void>,
    ) -> Result<(), FatalError> {
        let time_period = params.time_period();
        trace!(time_period=?time_period, "uploading descriptor to all HSDirs for this time period");
        let hsdir_count = hs_dirs.len();
        /// An error returned from an upload future.
        //
        // Exhaustive, because this is a private type.
        #[derive(Clone, Debug, thiserror::Error)]
        enum PublishError {
            /// The upload was aborted because there are no IPTs.
            ///
            /// This happens because of an inevitable TOCTOU race, where after being notified by
            /// the IPT manager that the IPTs have changed (via `self.ipt_watcher.await_update`),
            /// we find out there actually are no IPTs, so we can't build the descriptor.
            ///
            /// This is a special kind of error that interrupts the current upload task, and is
            /// logged at `debug!` level rather than `warn!` or `error!`.
            ///
            /// Ideally, this shouldn't happen very often (if at all).
            #[error("No IPTs")]
            NoIpts,
            /// The reactor has shut down
            #[error("The reactor has shut down")]
            Shutdown,
            /// An fatal error.
            #[error("{0}")]
            Fatal(#[from] FatalError),
        }
        let max_hsdesc_len: usize = netdir
            .params()
            .hsdir_max_desc_size
            .try_into()
            .expect("Unable to convert positive int32 to usize!?");
        let upload_results = futures::stream::iter(hs_dirs)
            .map(|relay_ids| {
                let netdir = netdir.clone();
                let config = Arc::clone(&config);
                let imm = Arc::clone(&imm);
                let ipt_upload_view = ipt_upload_view.clone();
                let authorized_clients = authorized_clients.clone();
                let params = params.clone();
                let mut shutdown_rx = shutdown_rx.clone();
                let ed_id = relay_ids
                    .rsa_identity()
                    .map(|id| id.to_string())
                    .unwrap_or_else(|| "unknown".into());
                let rsa_id = relay_ids
                    .rsa_identity()
                    .map(|id| id.to_string())
                    .unwrap_or_else(|| "unknown".into());
                async move {
                    let run_upload = |desc| async {
                        let Some(hsdir) = netdir.by_ids(&relay_ids) else {
                            // This should never happen (all of our relay_ids are from the stored
                            // netdir).
                            let err =
                                "tried to upload descriptor to relay not found in consensus?!";
                            warn!(
                                nickname=%imm.nickname, hsdir_id=%ed_id, hsdir_rsa_id=%rsa_id,
                                "{err}"
                            );
                            return Err(internal!("{err}").into());
                        };
                        Self::upload_descriptor_with_retries(
                            desc,
                            &netdir,
                            &hsdir,
                            &ed_id,
                            &rsa_id,
                            Arc::clone(&imm),
                        )
                        .await
                    };
                    // How long until we're supposed to time out?
                    let worst_case_end = imm.runtime.now() + OVERALL_UPLOAD_TIMEOUT;
                    // We generate a new descriptor before _each_ HsDir upload. This means each
                    // HsDir could, in theory, receive a different descriptor (not just in terms of
                    // revision-counters, but also with a different set of IPTs). It may seem like
                    // this could lead to some HsDirs being left with an outdated descriptor, but
                    // that's not the case: after the upload completes, the publisher will be
                    // notified by the ipt_watcher of the IPT change event (if there was one to
                    // begin with), which will trigger another upload job.
                    let hsdesc = {
                        // This scope is needed because the ipt_set MutexGuard is not Send, so it
                        // needs to fall out of scope before the await point below
                        let mut ipt_set = ipt_upload_view.borrow_for_publish();
                        // If there are no IPTs, we abort the upload. At this point, we might have
                        // uploaded the descriptor to some, but not all, HSDirs from the specified
                        // time period.
                        //
                        // Returning an error here means the upload completion task is never
                        // notified of the outcome of any of these uploads (which means the
                        // descriptor is not marked clean). This is OK, because if we suddenly find
                        // out we have no IPTs, it means our built `hsdesc` has an outdated set of
                        // IPTs, so we need to go back to the main loop to wait for IPT changes,
                        // and generate a fresh descriptor anyway.
                        //
                        // Ideally, this shouldn't happen very often (if at all).
                        let Some(ipts) = ipt_set.ipts.as_mut() else {
                            return Err(PublishError::NoIpts);
                        };
                        let hsdesc = {
                            trace!(
                                nickname=%imm.nickname, time_period=?time_period,
                                "building descriptor"
                            );
                            let mut rng = imm.mockable.thread_rng();
                            let mut key_rng = tor_llcrypto::rng::CautiousRng;
                            // We're about to generate a new version of the descriptor,
                            // so let's generate a new revision counter.
                            let now = imm.runtime.wallclock();
                            let revision_counter = imm.generate_revision_counter(&params, now)?;
                            build_sign(
                                &imm.keymgr,
                                &imm.pow_manager,
                                &config,
                                authorized_clients.as_deref(),
                                ipts,
                                time_period,
                                revision_counter,
                                &mut rng,
                                &mut key_rng,
                                imm.runtime.wallclock(),
                                max_hsdesc_len,
                            )?
                        };
                        if let Err(e) =
                            ipt_set.note_publication_attempt(&imm.runtime, worst_case_end)
                        {
                            let wait = e.log_retry_max(&imm.nickname)?;
                            // TODO (#1226): retry instead of this
                            return Err(FatalError::Bug(internal!(
                                "ought to retry after {wait:?}, crashing instead"
                            ))
                            .into());
                        }
                        hsdesc
                    };
                    let VersionedDescriptor {
                        desc,
                        revision_counter,
                    } = hsdesc;
                    trace!(
                        nickname=%imm.nickname, time_period=?time_period,
                        revision_counter=?revision_counter,
                        "generated new descriptor for time period",
                    );
                    // (Actually launch the upload attempt. No timeout is needed
                    // here, since the backoff::Runner code will handle that for us.)
                    let upload_res: UploadResult = select_biased! {
                        shutdown = shutdown_rx.next().fuse() => {
                            // This will always be None, since Void is uninhabited.
                            let _: Option<Void> = shutdown;
                            // It looks like the reactor has shut down,
                            // so there is no point in uploading the descriptor anymore.
                            //
                            // Let's shut down the upload task too.
                            trace!(
                                nickname=%imm.nickname, time_period=?time_period,
                                "upload task received shutdown signal"
                            );
                            return Err(PublishError::Shutdown);
                        },
                        res = run_upload(desc.clone()).fuse() => res,
                    };
                    // Note: UploadResult::Failure is only returned when
                    // upload_descriptor_with_retries fails, i.e. if all our retry
                    // attempts have failed
                    Ok(HsDirUploadStatus {
                        relay_ids,
                        upload_res,
                        revision_counter,
                    })
                }
            })
            // This fails to compile unless the stream is boxed. See https://github.com/rust-lang/rust/issues/104382
            .boxed()
            .buffer_unordered(MAX_CONCURRENT_UPLOADS)
            .try_collect::<Vec<_>>()
            .await;
        let upload_results = match upload_results {
            Ok(v) => v,
            Err(PublishError::Fatal(e)) => return Err(e),
            Err(PublishError::NoIpts) => {
                debug!(
                    nickname=%imm.nickname, time_period=?time_period,
                     "no introduction points; skipping upload"
                );
                return Ok(());
            }
            Err(PublishError::Shutdown) => {
                debug!(
                    nickname=%imm.nickname, time_period=?time_period,
                     "the reactor has shut down; aborting upload"
                );
                return Ok(());
            }
        };
        let (succeeded, _failed): (Vec<_>, Vec<_>) = upload_results
            .iter()
            .partition(|res| res.upload_res.is_ok());
        debug!(
            nickname=%imm.nickname, time_period=?time_period,
            "descriptor uploaded successfully to {}/{} HSDirs",
            succeeded.len(), hsdir_count
        );
        if upload_task_complete_tx
            .send(TimePeriodUploadResult {
                time_period,
                hsdir_result: upload_results,
            })
            .await
            .is_err()
        {
            return Err(internal!(
                "failed to notify reactor of upload completion (reactor shut down)"
            )
            .into());
        }
        Ok(())
    }
    /// Upload a descriptor to the specified HSDir.
    ///
    /// If an upload fails, this returns an `Err`. This function does not handle retries. It is up
    /// to the caller to retry on failure.
    ///
    /// This function does not handle timeouts.
    async fn upload_descriptor(
        hsdesc: String,
        netdir: &Arc<NetDir>,
        hsdir: &Relay<'_>,
        imm: Arc<Immutable<R, M>>,
    ) -> Result<(), UploadError> {
        let request = HsDescUploadRequest::new(hsdesc);
        trace!(nickname=%imm.nickname, hsdir_id=%hsdir.id(), hsdir_rsa_id=%hsdir.rsa_id(),
            "starting descriptor upload",
        );
        let circuit = imm
            .mockable
            .get_or_launch_specific(
                netdir,
                HsCircKind::SvcHsDir,
                OwnedCircTarget::from_circ_target(hsdir),
            )
            .await?;
        let source: Option<SourceInfo> = circuit
            .source_info()
            .map_err(into_internal!("Couldn't get SourceInfo for circuit"))?;
        let mut stream = circuit
            .begin_dir_stream()
            .await
            .map_err(UploadError::Stream)?;
        let _response: String = send_request(&imm.runtime, &request, &mut stream, source)
            .await
            .map_err(|dir_error| -> UploadError {
                match dir_error {
                    DirClientError::RequestFailed(e) => e.into(),
                    DirClientError::CircMgr(e) => into_internal!(
                        "tor-dirclient complains about circmgr going wrong but we gave it a stream"
                    )(e)
                    .into(),
                    e => into_internal!("unexpected error")(e).into(),
                }
            })?
            .into_output_string()?; // This returns an error if we received an error response
        Ok(())
    }
    /// Upload a descriptor to the specified HSDir, retrying if appropriate.
    ///
    /// Any failed uploads are retried according to a [`PublisherBackoffSchedule`].
    /// Each failed upload is retried until it succeeds, or until the overall timeout specified
    /// by [`BackoffSchedule::overall_timeout`] elapses. Individual attempts are timed out
    /// according to the [`BackoffSchedule::single_attempt_timeout`].
    /// This function gives up after the overall timeout elapses,
    /// declaring the upload a failure, and never retrying it again.
    ///
    /// See also [`BackoffSchedule`].
    async fn upload_descriptor_with_retries(
        hsdesc: String,
        netdir: &Arc<NetDir>,
        hsdir: &Relay<'_>,
        ed_id: &str,
        rsa_id: &str,
        imm: Arc<Immutable<R, M>>,
    ) -> UploadResult {
        /// The base delay to use for the backoff schedule.
        const BASE_DELAY_MSEC: u32 = 1000;
        let schedule = PublisherBackoffSchedule {
            retry_delay: RetryDelay::from_msec(BASE_DELAY_MSEC),
            mockable: imm.mockable.clone(),
        };
        let runner = Runner::new(
            "upload a hidden service descriptor".into(),
            schedule.clone(),
            imm.runtime.clone(),
        );
        let fallible_op = || async {
            let r = Self::upload_descriptor(hsdesc.clone(), netdir, hsdir, Arc::clone(&imm)).await;
            if let Err(e) = &r {
                if e.should_report_as_suspicious() {
                    // Note that not every protocol violation is suspicious:
                    // we only warn on the protocol violations that look like attempts
                    // to do a traffic tagging attack via hsdir inflation.
                    // (See proposal 360.)
                    warn_report!(
                        &e.clone(),
                        "Suspicious error while uploading descriptor to {}/{}",
                        ed_id,
                        rsa_id
                    );
                }
            }
            r
        };
        let outcome: Result<(), BackoffError<UploadError>> = runner.run(fallible_op).await;
        match outcome {
            Ok(()) => {
                debug!(
                    nickname=%imm.nickname, hsdir_id=%ed_id, hsdir_rsa_id=%rsa_id,
                    "successfully uploaded descriptor to HSDir",
                );
                Ok(())
            }
            Err(e) => {
                warn_report!(
                    e,
                    "failed to upload descriptor for service {} (hsdir_id={}, hsdir_rsa_id={})",
                    imm.nickname,
                    ed_id,
                    rsa_id
                );
                Err(e.into())
            }
        }
    }
    /// Stop publishing descriptors until the specified delay elapses.
    async fn start_rate_limit(&mut self, delay: Duration) -> Result<(), Bug> {
        if !matches!(self.status(), PublishStatus::RateLimited(_)) {
            debug!(
                "We are rate-limited for {}; pausing descriptor publication",
                humantime::format_duration(delay)
            );
            let until = self.imm.runtime.now() + delay;
            self.update_publish_status(PublishStatus::RateLimited(until))
                .await?;
        }
        Ok(())
    }
    /// Handle the upload rate-limit being lifted.
    async fn expire_rate_limit(&mut self) -> Result<(), Bug> {
        debug!("We are no longer rate-limited; resuming descriptor publication");
        self.update_publish_status(PublishStatus::UploadScheduled)
            .await?;
        Ok(())
    }
    /// Return the authorized clients, if restricted mode is enabled.
    ///
    /// Returns `Ok(None)` if restricted discovery mode is disabled.
    ///
    /// Returns an error if restricted discovery mode is enabled, but the client list is empty.
    #[cfg_attr(
        not(feature = "restricted-discovery"),
        allow(clippy::unnecessary_wraps)
    )]
    fn authorized_clients(&self) -> Result<Option<Arc<RestrictedDiscoveryKeys>>, FatalError> {
        cfg_if::cfg_if! {
            if #[cfg(feature = "restricted-discovery")] {
                let authorized_clients = self
                    .inner
                    .lock()
                    .expect("poisoned lock")
                    .authorized_clients
                    .clone();
                if authorized_clients.as_ref().as_ref().map(|v| v.is_empty()).unwrap_or_default() {
                    return Err(FatalError::RestrictedDiscoveryNoClients);
                }
                Ok(authorized_clients)
            } else {
                Ok(None)
            }
        }
    }
}
/// Try to expand a path, logging a warning on failure.
fn maybe_expand_path(p: &CfgPath, r: &CfgPathResolver) -> Option<PathBuf> {
    // map_err returns unit for clarity
    #[allow(clippy::unused_unit, clippy::semicolon_if_nothing_returned)]
    p.path(r)
        .map_err(|e| {
            tor_error::warn_report!(e, "invalid path");
            ()
        })
        .ok()
}
/// Add `path` to the specified `watcher`.
macro_rules! watch_path {
    ($watcher:expr, $path:expr, $watch_fn:ident, $($watch_fn_args:expr,)*) => {{
        if let Err(e) = $watcher.$watch_fn(&$path, $($watch_fn_args)*) {
            warn_report!(e, "failed to watch path {:?}", $path);
        } else {
            debug!("watching path {:?}", $path);
        }
    }}
}
/// Add the specified directories to the watcher.
#[allow(clippy::cognitive_complexity)]
fn watch_dirs<R: Runtime>(
    watcher: &mut FileWatcherBuilder<R>,
    dirs: &DirectoryKeyProviderList,
    path_resolver: &CfgPathResolver,
) {
    for path in dirs {
        let path = path.path();
        let Some(path) = maybe_expand_path(path, path_resolver) else {
            warn!("failed to expand key_dir path {:?}", path);
            continue;
        };
        // If the path doesn't exist, the notify watcher will return an error if we attempt to watch it,
        // so we skip over paths that don't exist at this time
        // (this obviously suffers from a TOCTOU race, but most of the time,
        // it is good enough at preventing the watcher from failing to watch.
        // If the race *does* happen it is not disastrous, i.e. the reactor won't crash,
        // but it will fail to set the watcher).
        if matches!(path.try_exists(), Ok(true)) {
            watch_path!(watcher, &path, watch_dir, "auth",);
        }
        // FileWatcher::watch_path causes the parent dir of the path to be watched.
        if matches!(path.parent().map(|p| p.try_exists()), Some(Ok(true))) {
            watch_path!(watcher, &path, watch_path,);
        }
    }
}
/// Try to read the blinded identity key for a given `TimePeriod`.
///
/// Returns `None` if the service is running in "offline" mode.
///
// TODO (#1194): we don't currently have support for "offline" mode so this can never return
// `Ok(None)`.
pub(super) fn read_blind_id_keypair(
    keymgr: &Arc<KeyMgr>,
    nickname: &HsNickname,
    period: TimePeriod,
) -> Result<Option<HsBlindIdKeypair>, FatalError> {
    let svc_key_spec = HsIdKeypairSpecifier::new(nickname.clone());
    let hsid_kp = keymgr
        .get::<HsIdKeypair>(&svc_key_spec)?
        .ok_or_else(|| FatalError::MissingHsIdKeypair(nickname.clone()))?;
    let blind_id_key_spec = BlindIdKeypairSpecifier::new(nickname.clone(), period);
    // TODO: make the keystore selector configurable
    let keystore_selector = Default::default();
    match keymgr.get::<HsBlindIdKeypair>(&blind_id_key_spec)? {
        Some(kp) => Ok(Some(kp)),
        None => {
            let (_hs_blind_id_key, hs_blind_id_kp, _subcredential) = hsid_kp
                .compute_blinded_key(period)
                .map_err(|_| internal!("failed to compute blinded key"))?;
            // Note: we can't use KeyMgr::generate because this key is derived from the HsId
            // (KeyMgr::generate uses the tor_keymgr::Keygen trait under the hood,
            // which assumes keys are randomly generated, rather than derived from existing keys).
            keymgr.insert(hs_blind_id_kp, &blind_id_key_spec, keystore_selector, true)?;
            let arti_path = |spec: &dyn KeySpecifier| {
                spec.arti_path()
                    .map_err(into_internal!("invalid key specifier?!"))
            };
            Ok(Some(
                keymgr.get::<HsBlindIdKeypair>(&blind_id_key_spec)?.ok_or(
                    FatalError::KeystoreRace {
                        action: "read",
                        path: arti_path(&blind_id_key_spec)?,
                    },
                )?,
            ))
        }
    }
}
/// Determine the [`State`] of the publisher based on the upload results
/// from the current `time_periods`.
16
fn upload_result_state(
16
    netdir: &NetDir,
16
    time_periods: &[TimePeriodContext],
16
) -> (State, Option<Problem>) {
16
    let current_period = netdir.hs_time_period();
16
    let current_period_res = time_periods
16
        .iter()
24
        .find(|ctx| ctx.params.time_period() == current_period);
16

            
16
    let succeeded_current_tp = current_period_res
16
        .iter()
24
        .flat_map(|res| &res.upload_results)
132
        .filter(|res| res.upload_res.is_ok())
16
        .collect_vec();
16

            
16
    let secondary_tp_res = time_periods
16
        .iter()
36
        .filter(|ctx| ctx.params.time_period() != current_period)
16
        .collect_vec();
16

            
16
    let succeeded_secondary_tp = secondary_tp_res
16
        .iter()
22
        .flat_map(|res| &res.upload_results)
108
        .filter(|res| res.upload_res.is_ok())
16
        .collect_vec();
16

            
16
    // All of the failed uploads (for all TPs)
16
    let failed = time_periods
16
        .iter()
36
        .flat_map(|res| &res.upload_results)
232
        .filter(|res| res.upload_res.is_err())
16
        .collect_vec();
16
    let problems: Vec<DescUploadRetryError> = failed
16
        .iter()
108
        .flat_map(|e| e.upload_res.as_ref().map_err(|e| e.clone()).err())
16
        .collect();
16
    let err = match problems.as_slice() {
16
        [_, ..] => Some(problems.into()),
8
        [] => None,
    };
16
    if time_periods.len() < 2 {
        // We need at least TP contexts (one for the primary TP,
        // and another for the secondary one).
        //
        // If either is missing, we are unreachable for some or all clients.
4
        return (State::DegradedUnreachable, err);
12
    }
12
    let state = match (
12
        succeeded_current_tp.as_slice(),
12
        succeeded_secondary_tp.as_slice(),
12
    ) {
12
        (&[], &[..]) | (&[..], &[]) if failed.is_empty() => {
            // We don't have any upload results for one or both TPs.
            // We are still bootstrapping.
6
            State::Bootstrapping
        }
4
        (&[_, ..], &[_, ..]) if failed.is_empty() => {
2
            // We have uploaded the descriptor to one or more HsDirs from both
2
            // HsDir rings (primary and secondary), and none of the uploads failed.
2
            // We are fully reachable.
2
            State::Running
        }
        (&[_, ..], &[_, ..]) => {
            // We have uploaded the descriptor to one or more HsDirs from both
            // HsDir rings (primary and secondary), but some of the uploads failed.
            // We are reachable, but we failed to upload the descriptor to all the HsDirs
            // that were supposed to have it.
2
            State::DegradedReachable
        }
        (&[..], &[]) | (&[], &[..]) => {
            // We have either
            //   * uploaded the descriptor to some of the HsDirs from one of the rings,
            //   but haven't managed to upload it to any of the HsDirs on the other ring, or
            //   * all of the uploads failed
            //
            // Either way, we are definitely not reachable by all clients.
2
            State::DegradedUnreachable
        }
    };
12
    (state, err)
16
}
/// Whether the reactor should initiate an upload.
#[derive(Copy, Clone, Debug, Default, PartialEq)]
enum PublishStatus {
    /// We need to call upload_all.
    UploadScheduled,
    /// We are rate-limited until the specified [`Instant`].
    ///
    /// We have tried to schedule multiple uploads in a short time span,
    /// and we are rate-limited. We are waiting for a signal from the schedule_upload_tx
    /// channel to unblock us.
    RateLimited(Instant),
    /// We are idle and waiting for external events.
    ///
    /// We have enough information to build the descriptor, but since we have already called
    /// upload_all to upload it to all relevant HSDirs, there is nothing for us to do right nbow.
    Idle,
    /// We are waiting for the IPT manager to establish some introduction points.
    ///
    /// No descriptors will be published until the `PublishStatus` of the reactor is changed to
    /// `UploadScheduled`.
    #[default]
    AwaitingIpts,
}
/// The backoff schedule for the task that publishes descriptors.
#[derive(Clone, Debug)]
struct PublisherBackoffSchedule<M: Mockable> {
    /// The delays
    retry_delay: RetryDelay,
    /// The mockable reactor state, needed for obtaining an rng.
    mockable: M,
}
impl<M: Mockable> BackoffSchedule for PublisherBackoffSchedule<M> {
    fn max_retries(&self) -> Option<usize> {
        None
    }
    fn overall_timeout(&self) -> Option<Duration> {
        Some(OVERALL_UPLOAD_TIMEOUT)
    }
    fn single_attempt_timeout(&self) -> Option<Duration> {
        Some(self.mockable.estimate_upload_timeout())
    }
    fn next_delay<E: RetriableError>(&mut self, _error: &E) -> Option<Duration> {
        Some(self.retry_delay.next_delay(&mut self.mockable.thread_rng()))
    }
}
impl RetriableError for UploadError {
    fn should_retry(&self) -> bool {
        match self {
            UploadError::Request(_) | UploadError::Circuit(_) | UploadError::Stream(_) => true,
            UploadError::Bug(_) => false,
        }
    }
}
/// The outcome of uploading a descriptor to the HSDirs from a particular time period.
#[derive(Debug, Clone)]
struct TimePeriodUploadResult {
    /// The time period.
    time_period: TimePeriod,
    /// The upload results.
    hsdir_result: Vec<HsDirUploadStatus>,
}
/// The outcome of uploading a descriptor to a particular HsDir.
#[derive(Clone, Debug)]
struct HsDirUploadStatus {
    /// The identity of the HsDir we attempted to upload the descriptor to.
    relay_ids: RelayIds,
    /// The outcome of this attempt.
    upload_res: UploadResult,
    /// The revision counter of the descriptor we tried to upload.
    revision_counter: RevisionCounter,
}
/// The outcome of uploading a descriptor.
type UploadResult = Result<(), DescUploadRetryError>;
impl From<BackoffError<UploadError>> for DescUploadRetryError {
    fn from(e: BackoffError<UploadError>) -> Self {
        use BackoffError as BE;
        use DescUploadRetryError as DURE;
        match e {
            BE::FatalError(e) => DURE::FatalError(e),
            BE::MaxRetryCountExceeded(e) => DURE::MaxRetryCountExceeded(e),
            BE::Timeout(e) => DURE::Timeout(e),
            BE::ExplicitStop(_) => {
                DURE::Bug(internal!("explicit stop in publisher backoff schedule?!"))
            }
        }
    }
}
// NOTE: the rest of the publisher tests live in publish.rs
#[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 tor_netdir::testnet;
    /// Create a `TimePeriodContext` from the specified upload results.
    fn create_time_period_ctx(
        params: &HsDirParams,
        upload_results: Vec<HsDirUploadStatus>,
    ) -> TimePeriodContext {
        TimePeriodContext {
            params: params.clone(),
            hs_dirs: vec![],
            last_successful: None,
            upload_results,
        }
    }
    /// Create a single `HsDirUploadStatus`
    fn create_upload_status(upload_res: UploadResult) -> HsDirUploadStatus {
        HsDirUploadStatus {
            relay_ids: RelayIds::empty(),
            upload_res,
            revision_counter: RevisionCounter::from(13),
        }
    }
    /// Create a bunch of results, all with the specified `upload_res`.
    fn create_upload_results(upload_res: UploadResult) -> Vec<HsDirUploadStatus> {
        std::iter::repeat_with(|| create_upload_status(upload_res.clone()))
            .take(10)
            .collect()
    }
    fn construct_netdir() -> NetDir {
        const SRV1: [u8; 32] = *b"The door refused to open.       ";
        const SRV2: [u8; 32] = *b"It said, 'Five cents, please.'  ";
        let dir = testnet::construct_custom_netdir(|_, _, bld| {
            bld.shared_rand_prev(7, SRV1.into(), None)
                .shared_rand_prev(7, SRV2.into(), None);
        })
        .unwrap();
        dir.unwrap_if_sufficient().unwrap()
    }
    #[test]
    fn upload_result_status_bootstrapping() {
        let netdir = construct_netdir();
        let all_params = netdir.hs_all_time_periods();
        let current_period = netdir.hs_time_period();
        let primary_params = all_params
            .iter()
            .find(|param| param.time_period() == current_period)
            .unwrap();
        let results = [
            (vec![], vec![]),
            (vec![], create_upload_results(Ok(()))),
            (create_upload_results(Ok(())), vec![]),
        ];
        for (primary_result, secondary_result) in results {
            let primary_ctx = create_time_period_ctx(primary_params, primary_result);
            let secondary_params = all_params
                .iter()
                .find(|param| param.time_period() != current_period)
                .unwrap();
            let secondary_ctx = create_time_period_ctx(secondary_params, secondary_result.clone());
            let (status, err) = upload_result_state(&netdir, &[primary_ctx, secondary_ctx]);
            assert_eq!(status, State::Bootstrapping);
            assert!(err.is_none());
        }
    }
    #[test]
    fn upload_result_status_running() {
        let netdir = construct_netdir();
        let all_params = netdir.hs_all_time_periods();
        let current_period = netdir.hs_time_period();
        let primary_params = all_params
            .iter()
            .find(|param| param.time_period() == current_period)
            .unwrap();
        let secondary_result = create_upload_results(Ok(()));
        let secondary_params = all_params
            .iter()
            .find(|param| param.time_period() != current_period)
            .unwrap();
        let secondary_ctx = create_time_period_ctx(secondary_params, secondary_result.clone());
        let primary_result = create_upload_results(Ok(()));
        let primary_ctx = create_time_period_ctx(primary_params, primary_result);
        let (status, err) = upload_result_state(&netdir, &[primary_ctx, secondary_ctx]);
        assert_eq!(status, State::Running);
        assert!(err.is_none());
    }
    #[test]
    fn upload_result_status_reachable() {
        let netdir = construct_netdir();
        let all_params = netdir.hs_all_time_periods();
        let current_period = netdir.hs_time_period();
        let primary_params = all_params
            .iter()
            .find(|param| param.time_period() == current_period)
            .unwrap();
        let primary_result = create_upload_results(Ok(()));
        let primary_ctx = create_time_period_ctx(primary_params, primary_result.clone());
        let failed_res = create_upload_results(Err(DescUploadRetryError::Bug(internal!("test"))));
        let secondary_result = create_upload_results(Ok(()))
            .into_iter()
            .chain(failed_res.iter().cloned())
            .collect();
        let secondary_params = all_params
            .iter()
            .find(|param| param.time_period() != current_period)
            .unwrap();
        let secondary_ctx = create_time_period_ctx(secondary_params, secondary_result);
        let (status, err) = upload_result_state(&netdir, &[primary_ctx, secondary_ctx]);
        // Degraded but reachable (because some of the secondary HsDir uploads failed).
        assert_eq!(status, State::DegradedReachable);
        assert!(matches!(err, Some(Problem::DescriptorUpload(_))));
    }
    #[test]
    fn upload_result_status_unreachable() {
        let netdir = construct_netdir();
        let all_params = netdir.hs_all_time_periods();
        let current_period = netdir.hs_time_period();
        let primary_params = all_params
            .iter()
            .find(|param| param.time_period() == current_period)
            .unwrap();
        let mut primary_result =
            create_upload_results(Err(DescUploadRetryError::Bug(internal!("test"))));
        let primary_ctx = create_time_period_ctx(primary_params, primary_result.clone());
        // No secondary TP (we are unreachable).
        let (status, err) = upload_result_state(&netdir, &[primary_ctx]);
        assert_eq!(status, State::DegradedUnreachable);
        assert!(matches!(err, Some(Problem::DescriptorUpload(_))));
        // Add a successful result
        primary_result.push(create_upload_status(Ok(())));
        let primary_ctx = create_time_period_ctx(primary_params, primary_result.clone());
        let (status, err) = upload_result_state(&netdir, &[primary_ctx]);
        // Still degraded, and unreachable (because we don't have a TimePeriodContext
        // for the secondary TP)
        assert_eq!(status, State::DegradedUnreachable);
        assert!(matches!(err, Some(Problem::DescriptorUpload(_))));
        // If we add another time period where none of the uploads were successful,
        // we're *still* unreachable
        let secondary_result =
            create_upload_results(Err(DescUploadRetryError::Bug(internal!("test"))));
        let secondary_params = all_params
            .iter()
            .find(|param| param.time_period() != current_period)
            .unwrap();
        let secondary_ctx = create_time_period_ctx(secondary_params, secondary_result.clone());
        let primary_ctx = create_time_period_ctx(primary_params, primary_result.clone());
        let (status, err) = upload_result_state(&netdir, &[primary_ctx, secondary_ctx]);
        assert_eq!(status, State::DegradedUnreachable);
        assert!(matches!(err, Some(Problem::DescriptorUpload(_))));
    }
}