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_netdir::{DirEvent, NetDir};
81

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

            
88
use super::*;
89

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

            
325
#[async_trait]
326
impl MockableClientCirc for ClientCirc {
327
    type DataStream = tor_proto::stream::DataStream;
328

            
329
    async fn begin_dir_stream(self: Arc<Self>) -> Result<Self::DataStream, tor_proto::Error> {
330
        ClientCirc::begin_dir_stream(self).await
331
    }
332
}
333

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

            
338
#[async_trait]
339
impl<R: Runtime> Mockable for Real<R> {
340
    type Rng = rand::rngs::ThreadRng;
341
    type ClientCirc = ClientCirc;
342

            
343
    fn thread_rng(&self) -> Self::Rng {
344
        rand::rng()
345
    }
346

            
347
    async fn get_or_launch_specific<T>(
348
        &self,
349
        netdir: &NetDir,
350
        kind: HsCircKind,
351
        target: T,
352
    ) -> Result<Arc<ClientCirc>, tor_circmgr::Error>
353
    where
354
        T: CircTarget + Send + Sync,
355
    {
356
        self.0.get_or_launch_specific(netdir, kind, target).await
357
    }
358

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

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

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

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

            
468
        Ok(Self {
469
            params,
470
            hs_dirs,
471
            last_successful: None,
472
            upload_results,
473
        })
474
    }
475

            
476
    /// Recompute the HsDirs for this time period.
477
    fn compute_hsdirs<'r>(
478
        period: TimePeriod,
479
        blind_id: HsBlindId,
480
        netdir: &Arc<NetDir>,
481
        mut old_hsdirs: impl Iterator<Item = &'r (RelayIds, DescriptorStatus)>,
482
    ) -> Result<Vec<(RelayIds, DescriptorStatus)>, FatalError> {
483
        let hs_dirs = netdir.hs_dirs_upload(blind_id, period)?;
484

            
485
        Ok(hs_dirs
486
            .map(|hs_dir| {
487
                let mut builder = RelayIds::builder();
488
                if let Some(ed_id) = hs_dir.ed_identity() {
489
                    builder.ed_identity(*ed_id);
490
                }
491

            
492
                if let Some(rsa_id) = hs_dir.rsa_identity() {
493
                    builder.rsa_identity(*rsa_id);
494
                }
495

            
496
                let relay_id = builder.build().unwrap_or_else(|_| RelayIds::empty());
497

            
498
                // Have we uploaded the descriptor to thiw relay before? If so, we don't need to
499
                // reupload it unless it was already dirty and due for a reupload.
500
                let status = match old_hsdirs.find(|(id, _)| *id == relay_id) {
501
                    Some((_, status)) => *status,
502
                    None => DescriptorStatus::Dirty,
503
                };
504

            
505
                (relay_id, status)
506
            })
507
            .collect::<Vec<_>>())
508
    }
509

            
510
    /// Mark the descriptor dirty for all HSDirs of this time period.
511
    fn mark_all_dirty(&mut self) {
512
        self.hs_dirs
513
            .iter_mut()
514
            .for_each(|(_relay_id, status)| *status = DescriptorStatus::Dirty);
515
    }
516

            
517
    /// Update the upload result for this time period.
518
    fn set_upload_results(&mut self, upload_results: Vec<HsDirUploadStatus>) {
519
        self.upload_results = upload_results;
520
    }
521
}
522

            
523
/// An error that occurs while trying to upload a descriptor.
524
#[derive(Clone, Debug, thiserror::Error)]
525
#[non_exhaustive]
526
pub enum UploadError {
527
    /// An error that has occurred after we have contacted a directory cache and made a circuit to it.
528
    #[error("descriptor upload request failed: {}", _0.error)]
529
    Request(#[from] RequestFailedError),
530

            
531
    /// Failed to establish circuit to hidden service directory
532
    #[error("could not build circuit to HsDir")]
533
    Circuit(#[from] tor_circmgr::Error),
534

            
535
    /// Failed to establish stream to hidden service directory
536
    #[error("failed to establish directory stream to HsDir")]
537
    Stream(#[source] tor_proto::Error),
538

            
539
    /// An internal error.
540
    #[error("Internal error")]
541
    Bug(#[from] tor_error::Bug),
542
}
543
define_asref_dyn_std_error!(UploadError);
544

            
545
impl<R: Runtime, M: Mockable> Reactor<R, M> {
546
    /// Create a new `Reactor`.
547
    #[allow(clippy::too_many_arguments)]
548
    pub(super) fn new(
549
        runtime: R,
550
        nickname: HsNickname,
551
        dir_provider: Arc<dyn NetDirProvider>,
552
        mockable: M,
553
        config: &OnionServiceConfig,
554
        ipt_watcher: IptsPublisherView,
555
        config_rx: watch::Receiver<Arc<OnionServiceConfig>>,
556
        status_tx: PublisherStatusSender,
557
        keymgr: Arc<KeyMgr>,
558
        path_resolver: Arc<CfgPathResolver>,
559
        pow_manager: Arc<PowManager<R>>,
560
        update_from_pow_manager_rx: mpsc::Receiver<TimePeriod>,
561
    ) -> Self {
562
        /// The maximum size of the upload completion notifier channel.
563
        ///
564
        /// The channel we use this for is a futures::mpsc channel, which has a capacity of
565
        /// `UPLOAD_CHAN_BUF_SIZE + num-senders`. We don't need the buffer size to be non-zero, as
566
        /// each sender will send exactly one message.
567
        const UPLOAD_CHAN_BUF_SIZE: usize = 0;
568

            
569
        // Internally-generated instructions, no need for mq.
570
        let (upload_task_complete_tx, upload_task_complete_rx) =
571
            mpsc_channel_no_memquota(UPLOAD_CHAN_BUF_SIZE);
572

            
573
        let (publish_status_tx, publish_status_rx) = watch::channel();
574
        // Setting the buffer size to zero here is OK,
575
        // since we never actually send anything on this channel.
576
        let (shutdown_tx, _shutdown_rx) = broadcast::channel(0);
577

            
578
        let authorized_clients =
579
            Self::read_authorized_clients(&config.restricted_discovery, &path_resolver);
580

            
581
        // Create a channel for watching for changes in the configured
582
        // restricted_discovery.key_dirs.
583
        let (key_dirs_tx, key_dirs_rx) = file_watcher::channel();
584

            
585
        let imm = Immutable {
586
            runtime,
587
            mockable,
588
            nickname,
589
            keymgr,
590
            status_tx,
591
            pow_manager,
592
        };
593

            
594
        let inner = Inner {
595
            time_periods: vec![],
596
            config: Arc::new(config.into()),
597
            file_watcher: None,
598
            netdir: None,
599
            last_uploaded: None,
600
            reupload_timers: Default::default(),
601
            authorized_clients,
602
        };
603

            
604
        Self {
605
            imm: Arc::new(imm),
606
            inner: Arc::new(Mutex::new(inner)),
607
            dir_provider,
608
            ipt_watcher,
609
            config_rx,
610
            key_dirs_rx,
611
            key_dirs_tx,
612
            publish_status_rx,
613
            publish_status_tx,
614
            upload_task_complete_rx,
615
            upload_task_complete_tx,
616
            shutdown_tx,
617
            path_resolver,
618
            update_from_pow_manager_rx,
619
        }
620
    }
621

            
622
    /// Start the reactor.
623
    ///
624
    /// Under normal circumstances, this function runs indefinitely.
625
    ///
626
    /// Note: this also spawns the "reminder task" that we use to reschedule uploads whenever an
627
    /// upload fails or is rate-limited.
628
    pub(super) async fn run(mut self) -> Result<(), FatalError> {
629
        debug!(nickname=%self.imm.nickname, "starting descriptor publisher reactor");
630

            
631
        {
632
            let netdir = self
633
                .dir_provider
634
                .wait_for_netdir(Timeliness::Timely)
635
                .await?;
636
            let time_periods = self.compute_time_periods(&netdir, &[])?;
637

            
638
            let mut inner = self.inner.lock().expect("poisoned lock");
639

            
640
            inner.netdir = Some(netdir);
641
            inner.time_periods = time_periods;
642
        }
643

            
644
        // Create the initial key_dirs watcher.
645
        self.update_file_watcher();
646

            
647
        loop {
648
            match self.run_once().await {
649
                Ok(ShutdownStatus::Continue) => continue,
650
                Ok(ShutdownStatus::Terminate) => {
651
                    debug!(nickname=%self.imm.nickname, "descriptor publisher is shutting down!");
652

            
653
                    self.imm.status_tx.send_shutdown();
654
                    return Ok(());
655
                }
656
                Err(e) => {
657
                    error_report!(
658
                        e,
659
                        "HS service {}: descriptor publisher crashed!",
660
                        self.imm.nickname
661
                    );
662

            
663
                    self.imm.status_tx.send_broken(e.clone());
664

            
665
                    return Err(e);
666
                }
667
            }
668
        }
669
    }
670

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

            
676
        // Note: TrackingNow tracks the values it is compared with.
677
        // This is equivalent to sleeping for (until - now) units of time,
678
        let upload_rate_lim: TrackingNow = TrackingNow::now(&self.imm.runtime);
679
        if let PublishStatus::RateLimited(until) = self.status() {
680
            if upload_rate_lim > until {
681
                // We are no longer rate-limited
682
                self.expire_rate_limit().await?;
683
            }
684
        }
685

            
686
        let reupload_tracking = TrackingNow::now(&self.imm.runtime);
687
        let mut reupload_periods = vec![];
688
        {
689
            let mut inner = self.inner.lock().expect("poisoned lock");
690
            let inner = &mut *inner;
691
            while let Some(reupload) = inner.reupload_timers.peek().copied() {
692
                // First, extract all the timeouts that already elapsed.
693
                if reupload.when <= reupload_tracking {
694
                    inner.reupload_timers.pop();
695
                    reupload_periods.push(reupload.period);
696
                } else {
697
                    // We are not ready to schedule any more reuploads.
698
                    //
699
                    // How much we need to sleep is implicitly
700
                    // tracked in reupload_tracking (through
701
                    // the TrackingNow implementation)
702
                    break;
703
                }
704
            }
705
        }
706

            
707
        // Check if it's time to schedule any reuploads.
708
        for period in reupload_periods {
709
            if self.mark_dirty(&period) {
710
                debug!(
711
                    time_period=?period,
712
                    "descriptor reupload timer elapsed; scheduling reupload",
713
                );
714
                self.update_publish_status_unless_rate_lim(PublishStatus::UploadScheduled)
715
                    .await?;
716
            }
717
        }
718

            
719
        select_biased! {
720
            res = self.upload_task_complete_rx.next().fuse() => {
721
                let Some(upload_res) = res else {
722
                    return Ok(ShutdownStatus::Terminate);
723
                };
724

            
725
                self.handle_upload_results(upload_res);
726
                self.upload_result_to_svc_status()?;
727
            },
728
            () = upload_rate_lim.wait_for_earliest(&self.imm.runtime).fuse() => {
729
                self.expire_rate_limit().await?;
730
            },
731
            () = reupload_tracking.wait_for_earliest(&self.imm.runtime).fuse() => {
732
                // Run another iteration, executing run_once again. This time, we will remove the
733
                // expired reupload from self.reupload_timers, mark the descriptor dirty for all
734
                // relevant HsDirs, and schedule the upload by setting our status to
735
                // UploadScheduled.
736
                return Ok(ShutdownStatus::Continue);
737
            },
738
            netdir_event = netdir_events.next().fuse() => {
739
                let Some(netdir_event) = netdir_event else {
740
                    debug!("netdir event stream ended");
741
                    return Ok(ShutdownStatus::Terminate);
742
                };
743

            
744
                if !matches!(netdir_event, DirEvent::NewConsensus) {
745
                    return Ok(ShutdownStatus::Continue);
746
                };
747

            
748
                // The consensus changed. Grab a new NetDir.
749
                let netdir = match self.dir_provider.netdir(Timeliness::Timely) {
750
                    Ok(y) => y,
751
                    Err(e) => {
752
                        error_report!(e, "HS service {}: netdir unavailable. Retrying...", self.imm.nickname);
753
                        // Hopefully a netdir will appear in the future.
754
                        // in the meantime, suspend operations.
755
                        //
756
                        // TODO (#1218): there is a bug here: we stop reading on our inputs
757
                        // including eg publish_status_rx, but it is our job to log some of
758
                        // these things.  While we are waiting for a netdir, all those messages
759
                        // are "stuck"; they'll appear later, with misleading timestamps.
760
                        //
761
                        // Probably this should be fixed by moving the logging
762
                        // out of the reactor, where it won't be blocked.
763
                        self.dir_provider.wait_for_netdir(Timeliness::Timely)
764
                            .await?
765
                    }
766
                };
767
                let relevant_periods = netdir.hs_all_time_periods();
768
                self.handle_consensus_change(netdir).await?;
769
                expire_publisher_keys(
770
                    &self.imm.keymgr,
771
                    &self.imm.nickname,
772
                    &relevant_periods,
773
                ).unwrap_or_else(|e| {
774
                    error_report!(e, "failed to remove expired keys");
775
                });
776
            }
777
            update = self.ipt_watcher.await_update().fuse() => {
778
                if self.handle_ipt_change(update).await? == ShutdownStatus::Terminate {
779
                    return Ok(ShutdownStatus::Terminate);
780
                }
781
            },
782
            config = self.config_rx.next().fuse() => {
783
                let Some(config) = config else {
784
                    return Ok(ShutdownStatus::Terminate);
785
                };
786

            
787
                self.handle_svc_config_change(&config).await?;
788
            },
789
            res = self.key_dirs_rx.next().fuse() => {
790
                let Some(event) = res else {
791
                    return Ok(ShutdownStatus::Terminate);
792
                };
793

            
794
                while let Some(_ignore) = self.key_dirs_rx.try_recv() {
795
                    // Discard other events, so that we only reload once.
796
                }
797

            
798
                self.handle_key_dirs_change(event).await?;
799
            }
800
            should_upload = self.publish_status_rx.next().fuse() => {
801
                let Some(should_upload) = should_upload else {
802
                    return Ok(ShutdownStatus::Terminate);
803
                };
804

            
805
                // Our PublishStatus changed -- are we ready to publish?
806
                if should_upload == PublishStatus::UploadScheduled {
807
                    self.update_publish_status_unless_waiting(PublishStatus::Idle).await?;
808
                    self.upload_all().await?;
809
                }
810
            }
811
            update_tp_pow_seed = self.update_from_pow_manager_rx.next().fuse() => {
812
                debug!("Update PoW seed for TP!");
813
                let Some(time_period) = update_tp_pow_seed else {
814
                    return Ok(ShutdownStatus::Terminate);
815
                };
816
                self.mark_dirty(&time_period);
817
                self.upload_all().await?;
818
            }
819
        }
820

            
821
        Ok(ShutdownStatus::Continue)
822
    }
823

            
824
    /// Returns the current status of the publisher
825
    fn status(&self) -> PublishStatus {
826
        *self.publish_status_rx.borrow()
827
    }
828

            
829
    /// Handle a batch of upload outcomes,
830
    /// possibly updating the status of the descriptor for the corresponding HSDirs.
831
    fn handle_upload_results(&self, results: TimePeriodUploadResult) {
832
        let mut inner = self.inner.lock().expect("poisoned lock");
833
        let inner = &mut *inner;
834

            
835
        // Check which time period these uploads pertain to.
836
        let period = inner
837
            .time_periods
838
            .iter_mut()
839
            .find(|ctx| ctx.params.time_period() == results.time_period);
840

            
841
        let Some(period) = period else {
842
            // The uploads were for a time period that is no longer relevant, so we
843
            // can ignore the result.
844
            return;
845
        };
846

            
847
        // We will need to reupload this descriptor at at some point, so we pick
848
        // a random time between 60 minutes and 120 minutes in the future.
849
        //
850
        // See https://spec.torproject.org/rend-spec/deriving-keys.html#WHEN-HSDESC
851
        let mut rng = self.imm.mockable.thread_rng();
852
        // TODO SPEC: Control republish period using a consensus parameter?
853
        let minutes = rng.gen_range_checked(60..=120).expect("low > high?!");
854
        let duration = Duration::from_secs(minutes * 60);
855
        let reupload_when = self.imm.runtime.now() + duration;
856
        let time_period = period.params.time_period();
857

            
858
        info!(
859
            time_period=?time_period,
860
            "reuploading descriptor in {}",
861
            humantime::format_duration(duration),
862
        );
863

            
864
        inner.reupload_timers.push(ReuploadTimer {
865
            period: time_period,
866
            when: reupload_when,
867
        });
868

            
869
        let mut upload_results = vec![];
870
        for upload_res in results.hsdir_result {
871
            let relay = period
872
                .hs_dirs
873
                .iter_mut()
874
                .find(|(relay_ids, _status)| relay_ids == &upload_res.relay_ids);
875

            
876
            let Some((_relay, status)): Option<&mut (RelayIds, _)> = relay else {
877
                // This HSDir went away, so the result doesn't matter.
878
                // Continue processing the rest of the results
879
                continue;
880
            };
881

            
882
            if upload_res.upload_res.is_ok() {
883
                let update_last_successful = match period.last_successful {
884
                    None => true,
885
                    Some(counter) => counter <= upload_res.revision_counter,
886
                };
887

            
888
                if update_last_successful {
889
                    period.last_successful = Some(upload_res.revision_counter);
890
                    // TODO (#1098): Is it possible that this won't update the statuses promptly
891
                    // enough. For example, it's possible for the reactor to see a Dirty descriptor
892
                    // and start an upload task for a descriptor has already been uploaded (or is
893
                    // being uploaded) in another task, but whose upload results have not yet been
894
                    // processed.
895
                    //
896
                    // This is probably made worse by the fact that the statuses are updated in
897
                    // batches (grouped by time period), rather than one by one as the upload tasks
898
                    // complete (updating the status involves locking the inner mutex, and I wanted
899
                    // to minimize the locking/unlocking overheads). I'm not sure handling the
900
                    // updates in batches was the correct decision here.
901
                    *status = DescriptorStatus::Clean;
902
                }
903
            }
904

            
905
            upload_results.push(upload_res);
906
        }
907

            
908
        period.set_upload_results(upload_results);
909
    }
910

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

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

            
917
        self.recompute_hs_dirs()?;
918
        self.update_publish_status_unless_waiting(PublishStatus::UploadScheduled)
919
            .await?;
920

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

            
927
        Ok(())
928
    }
929

            
930
    /// Recompute the HsDirs for all relevant time periods.
931
    fn recompute_hs_dirs(&self) -> Result<(), FatalError> {
932
        let mut inner = self.inner.lock().expect("poisoned lock");
933
        let inner = &mut *inner;
934

            
935
        let netdir = Arc::clone(
936
            inner
937
                .netdir
938
                .as_ref()
939
                .ok_or_else(|| internal!("started upload task without a netdir"))?,
940
        );
941

            
942
        // Update our list of relevant time periods.
943
        let new_time_periods = self.compute_time_periods(&netdir, &inner.time_periods)?;
944
        inner.time_periods = new_time_periods;
945

            
946
        Ok(())
947
    }
948

            
949
    /// Compute the [`TimePeriodContext`]s for the time periods from the specified [`NetDir`].
950
    ///
951
    /// The specified `time_periods` are used to preserve the `DescriptorStatus` of the
952
    /// HsDirs where possible.
953
    fn compute_time_periods(
954
        &self,
955
        netdir: &Arc<NetDir>,
956
        time_periods: &[TimePeriodContext],
957
    ) -> Result<Vec<TimePeriodContext>, FatalError> {
958
        netdir
959
            .hs_all_time_periods()
960
            .iter()
961
            .map(|params| {
962
                let period = params.time_period();
963
                let blind_id_kp =
964
                    read_blind_id_keypair(&self.imm.keymgr, &self.imm.nickname, period)?
965
                        // Note: for now, read_blind_id_keypair cannot return Ok(None).
966
                        // It's supposed to return Ok(None) if we're in offline hsid mode,
967
                        // but that might change when we do #1194
968
                        .ok_or_else(|| internal!("offline hsid mode not supported"))?;
969

            
970
                let blind_id: HsBlindIdKey = (&blind_id_kp).into();
971

            
972
                // If our previous `TimePeriodContext`s also had an entry for `period`, we need to
973
                // preserve the `DescriptorStatus` of its HsDirs. This helps prevent unnecessarily
974
                // publishing the descriptor to the HsDirs that already have it (the ones that are
975
                // marked with DescriptorStatus::Clean).
976
                //
977
                // In other words, we only want to publish to those HsDirs that
978
                //   * are part of a new time period (which we have never published the descriptor
979
                //   for), or
980
                //   * have just been added to the ring of a time period we already knew about
981
                if let Some(ctx) = time_periods
982
                    .iter()
983
                    .find(|ctx| ctx.params.time_period() == period)
984
                {
985
                    TimePeriodContext::new(
986
                        params.clone(),
987
                        blind_id.into(),
988
                        netdir,
989
                        ctx.hs_dirs.iter(),
990
                        ctx.upload_results.clone(),
991
                    )
992
                } else {
993
                    // Passing an empty iterator here means all HsDirs in this TimePeriodContext
994
                    // will be marked as dirty, meaning we will need to upload our descriptor to them.
995
                    TimePeriodContext::new(
996
                        params.clone(),
997
                        blind_id.into(),
998
                        netdir,
999
                        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 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(),
                            )?
                        };
                        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 mut stream = circuit
            .begin_dir_stream()
            .await
            .map_err(UploadError::Stream)?;
        let _response: String = send_request(&imm.runtime, &request, &mut stream, None)
            .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 =
            || Self::upload_descriptor(hsdesc.clone(), netdir, hsdir, Arc::clone(&imm));
        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(_))));
    }
}