LCOV - code coverage report
Current view: top level - pageserver/src/bin - pageserver.rs (source / functions) Coverage Total Hit
Test: 07bee600374ccd486c69370d0972d9035964fe68.info Lines: 5.1 % 531 27
Test Date: 2025-02-20 13:11:02 Functions: 8.6 % 35 3

            Line data    Source code
       1              : #![recursion_limit = "300"]
       2              : 
       3              : //! Main entry point for the Page Server executable.
       4              : 
       5              : use std::env;
       6              : use std::env::{var, VarError};
       7              : use std::io::Read;
       8              : use std::str::FromStr;
       9              : use std::sync::Arc;
      10              : use std::time::Duration;
      11              : 
      12              : use anyhow::{anyhow, Context};
      13              : use camino::Utf8Path;
      14              : use clap::{Arg, ArgAction, Command};
      15              : 
      16              : use metrics::launch_timestamp::{set_launch_timestamp_metric, LaunchTimestamp};
      17              : use pageserver::config::PageserverIdentity;
      18              : use pageserver::controller_upcall_client::ControllerUpcallClient;
      19              : use pageserver::disk_usage_eviction_task::{self, launch_disk_usage_global_eviction_task};
      20              : use pageserver::metrics::{STARTUP_DURATION, STARTUP_IS_LOADING};
      21              : use pageserver::task_mgr::{COMPUTE_REQUEST_RUNTIME, WALRECEIVER_RUNTIME};
      22              : use pageserver::tenant::{secondary, TenantSharedResources};
      23              : use pageserver::{CancellableTask, ConsumptionMetricsTasks, HttpEndpointListener};
      24              : use remote_storage::GenericRemoteStorage;
      25              : use tokio::signal::unix::SignalKind;
      26              : use tokio::time::Instant;
      27              : use tokio_util::sync::CancellationToken;
      28              : use tracing::*;
      29              : 
      30              : use metrics::set_build_info_metric;
      31              : use pageserver::{
      32              :     config::PageServerConf,
      33              :     deletion_queue::DeletionQueue,
      34              :     http, page_cache, page_service, task_mgr,
      35              :     task_mgr::{BACKGROUND_RUNTIME, MGMT_REQUEST_RUNTIME},
      36              :     tenant::mgr,
      37              :     virtual_file,
      38              : };
      39              : use postgres_backend::AuthType;
      40              : use utils::crashsafe::syncfs;
      41              : use utils::failpoint_support;
      42              : use utils::logging::TracingErrorLayerEnablement;
      43              : use utils::{
      44              :     auth::{JwtAuth, SwappableJwtAuth},
      45              :     logging, project_build_tag, project_git_version,
      46              :     sentry_init::init_sentry,
      47              :     tcp_listener,
      48              : };
      49              : 
      50              : project_git_version!(GIT_VERSION);
      51              : project_build_tag!(BUILD_TAG);
      52              : 
      53              : #[global_allocator]
      54              : static GLOBAL: tikv_jemallocator::Jemalloc = tikv_jemallocator::Jemalloc;
      55              : 
      56              : /// Configure jemalloc to profile heap allocations by sampling stack traces every 2 MB (1 << 21).
      57              : /// This adds roughly 3% overhead for allocations on average, which is acceptable considering
      58              : /// performance-sensitive code will avoid allocations as far as possible anyway.
      59              : #[allow(non_upper_case_globals)]
      60              : #[export_name = "malloc_conf"]
      61              : pub static malloc_conf: &[u8] = b"prof:true,prof_active:true,lg_prof_sample:21\0";
      62              : 
      63              : const PID_FILE_NAME: &str = "pageserver.pid";
      64              : 
      65              : const FEATURES: &[&str] = &[
      66              :     #[cfg(feature = "testing")]
      67              :     "testing",
      68              : ];
      69              : 
      70            4 : fn version() -> String {
      71            4 :     format!(
      72            4 :         "{GIT_VERSION} failpoints: {}, features: {:?}",
      73            4 :         fail::has_failpoints(),
      74            4 :         FEATURES,
      75            4 :     )
      76            4 : }
      77              : 
      78            0 : fn main() -> anyhow::Result<()> {
      79            0 :     let launch_ts = Box::leak(Box::new(LaunchTimestamp::generate()));
      80            0 : 
      81            0 :     let arg_matches = cli().get_matches();
      82            0 : 
      83            0 :     if arg_matches.get_flag("enabled-features") {
      84            0 :         println!("{{\"features\": {FEATURES:?} }}");
      85            0 :         return Ok(());
      86            0 :     }
      87            0 : 
      88            0 :     let workdir = arg_matches
      89            0 :         .get_one::<String>("workdir")
      90            0 :         .map(Utf8Path::new)
      91            0 :         .unwrap_or_else(|| Utf8Path::new(".neon"));
      92            0 :     let workdir = workdir
      93            0 :         .canonicalize_utf8()
      94            0 :         .with_context(|| format!("Error opening workdir '{workdir}'"))?;
      95              : 
      96            0 :     let cfg_file_path = workdir.join("pageserver.toml");
      97            0 :     let identity_file_path = workdir.join("identity.toml");
      98            0 : 
      99            0 :     // Set CWD to workdir for non-daemon modes
     100            0 :     env::set_current_dir(&workdir)
     101            0 :         .with_context(|| format!("Failed to set application's current dir to '{workdir}'"))?;
     102              : 
     103            0 :     let conf = initialize_config(&identity_file_path, &cfg_file_path, &workdir)?;
     104              : 
     105              :     // Initialize logging.
     106              :     //
     107              :     // It must be initialized before the custom panic hook is installed below.
     108              :     //
     109              :     // Regarding tracing_error enablement: at this time, we only use the
     110              :     // tracing_error crate to debug_assert that log spans contain tenant and timeline ids.
     111              :     // See `debug_assert_current_span_has_tenant_and_timeline_id` in the timeline module
     112            0 :     let tracing_error_layer_enablement = if cfg!(debug_assertions) {
     113            0 :         TracingErrorLayerEnablement::EnableWithRustLogFilter
     114              :     } else {
     115            0 :         TracingErrorLayerEnablement::Disabled
     116              :     };
     117            0 :     logging::init(
     118            0 :         conf.log_format,
     119            0 :         tracing_error_layer_enablement,
     120            0 :         logging::Output::Stdout,
     121            0 :     )?;
     122              : 
     123              :     // mind the order required here: 1. logging, 2. panic_hook, 3. sentry.
     124              :     // disarming this hook on pageserver, because we never tear down tracing.
     125            0 :     logging::replace_panic_hook_with_tracing_panic_hook().forget();
     126            0 : 
     127            0 :     // initialize sentry if SENTRY_DSN is provided
     128            0 :     let _sentry_guard = init_sentry(
     129            0 :         Some(GIT_VERSION.into()),
     130            0 :         &[("node_id", &conf.id.to_string())],
     131            0 :     );
     132            0 : 
     133            0 :     // after setting up logging, log the effective IO engine choice and read path implementations
     134            0 :     info!(?conf.virtual_file_io_engine, "starting with virtual_file IO engine");
     135            0 :     info!(?conf.virtual_file_io_mode, "starting with virtual_file IO mode");
     136            0 :     info!(?conf.wal_receiver_protocol, "starting with WAL receiver protocol");
     137            0 :     info!(?conf.page_service_pipelining, "starting with page service pipelining config");
     138            0 :     info!(?conf.get_vectored_concurrent_io, "starting with get_vectored IO concurrency config");
     139              : 
     140              :     // The tenants directory contains all the pageserver local disk state.
     141              :     // Create if not exists and make sure all the contents are durable before proceeding.
     142              :     // Ensuring durability eliminates a whole bug class where we come up after an unclean shutdown.
     143              :     // After unclea shutdown, we don't know if all the filesystem content we can read via syscalls is actually durable or not.
     144              :     // Examples for that: OOM kill, systemd killing us during shutdown, self abort due to unrecoverable IO error.
     145            0 :     let tenants_path = conf.tenants_path();
     146            0 :     {
     147            0 :         let open = || {
     148            0 :             nix::dir::Dir::open(
     149            0 :                 tenants_path.as_std_path(),
     150            0 :                 nix::fcntl::OFlag::O_DIRECTORY | nix::fcntl::OFlag::O_RDONLY,
     151            0 :                 nix::sys::stat::Mode::empty(),
     152            0 :             )
     153            0 :         };
     154            0 :         let dirfd = match open() {
     155            0 :             Ok(dirfd) => dirfd,
     156            0 :             Err(e) => match e {
     157              :                 nix::errno::Errno::ENOENT => {
     158            0 :                     utils::crashsafe::create_dir_all(&tenants_path).with_context(|| {
     159            0 :                         format!("Failed to create tenants root dir at '{tenants_path}'")
     160            0 :                     })?;
     161            0 :                     open().context("open tenants dir after creating it")?
     162              :                 }
     163            0 :                 e => anyhow::bail!(e),
     164              :             },
     165              :         };
     166              : 
     167            0 :         if conf.no_sync {
     168            0 :             info!("Skipping syncfs on startup");
     169              :         } else {
     170            0 :             let started = Instant::now();
     171            0 :             syncfs(dirfd)?;
     172            0 :             let elapsed = started.elapsed();
     173            0 :             info!(
     174            0 :                 elapsed_ms = elapsed.as_millis(),
     175            0 :                 "made tenant directory contents durable"
     176              :             );
     177              :         }
     178              :     }
     179              : 
     180              :     // Initialize up failpoints support
     181            0 :     let scenario = failpoint_support::init();
     182            0 : 
     183            0 :     // Basic initialization of things that don't change after startup
     184            0 :     tracing::info!("Initializing virtual_file...");
     185              :     virtual_file::init(
     186            0 :         conf.max_file_descriptors,
     187            0 :         conf.virtual_file_io_engine,
     188            0 :         conf.virtual_file_io_mode,
     189            0 :         if conf.no_sync {
     190            0 :             virtual_file::SyncMode::UnsafeNoSync
     191              :         } else {
     192            0 :             virtual_file::SyncMode::Sync
     193              :         },
     194              :     );
     195            0 :     tracing::info!("Initializing page_cache...");
     196            0 :     page_cache::init(conf.page_cache_size);
     197            0 : 
     198            0 :     start_pageserver(launch_ts, conf).context("Failed to start pageserver")?;
     199              : 
     200            0 :     scenario.teardown();
     201            0 :     Ok(())
     202            0 : }
     203              : 
     204            0 : fn initialize_config(
     205            0 :     identity_file_path: &Utf8Path,
     206            0 :     cfg_file_path: &Utf8Path,
     207            0 :     workdir: &Utf8Path,
     208            0 : ) -> anyhow::Result<&'static PageServerConf> {
     209              :     // The deployment orchestrator writes out an indentity file containing the node id
     210              :     // for all pageservers. This file is the source of truth for the node id. In order
     211              :     // to allow for rolling back pageserver releases, the node id is also included in
     212              :     // the pageserver config that the deployment orchestrator writes to disk for the pageserver.
     213              :     // A rolled back version of the pageserver will get the node id from the pageserver.toml
     214              :     // config file.
     215            0 :     let identity = match std::fs::File::open(identity_file_path) {
     216            0 :         Ok(mut f) => {
     217            0 :             let md = f.metadata().context("stat config file")?;
     218            0 :             if !md.is_file() {
     219            0 :                 anyhow::bail!("Pageserver found identity file but it is a dir entry: {identity_file_path}. Aborting start up ...");
     220            0 :             }
     221            0 : 
     222            0 :             let mut s = String::new();
     223            0 :             f.read_to_string(&mut s).context("read identity file")?;
     224            0 :             toml_edit::de::from_str::<PageserverIdentity>(&s)?
     225              :         }
     226            0 :         Err(e) => {
     227            0 :             anyhow::bail!("Pageserver could not read identity file: {identity_file_path}: {e}. Aborting start up ...");
     228              :         }
     229              :     };
     230              : 
     231            0 :     let config_file_contents =
     232            0 :         std::fs::read_to_string(cfg_file_path).context("read config file from filesystem")?;
     233            0 :     let config_toml = serde_path_to_error::deserialize(
     234            0 :         toml_edit::de::Deserializer::from_str(&config_file_contents)
     235            0 :             .context("build toml deserializer")?,
     236              :     )
     237            0 :     .context("deserialize config toml")?;
     238            0 :     let conf = PageServerConf::parse_and_validate(identity.id, config_toml, workdir)
     239            0 :         .context("runtime-validation of config toml")?;
     240              : 
     241            0 :     Ok(Box::leak(Box::new(conf)))
     242            0 : }
     243              : 
     244              : struct WaitForPhaseResult<F: std::future::Future + Unpin> {
     245              :     timeout_remaining: Duration,
     246              :     skipped: Option<F>,
     247              : }
     248              : 
     249              : /// During startup, we apply a timeout to our waits for readiness, to avoid
     250              : /// stalling the whole service if one Tenant experiences some problem.  Each
     251              : /// phase may consume some of the timeout: this function returns the updated
     252              : /// timeout for use in the next call.
     253            0 : async fn wait_for_phase<F>(phase: &str, mut fut: F, timeout: Duration) -> WaitForPhaseResult<F>
     254            0 : where
     255            0 :     F: std::future::Future + Unpin,
     256            0 : {
     257            0 :     let initial_t = Instant::now();
     258            0 :     let skipped = match tokio::time::timeout(timeout, &mut fut).await {
     259            0 :         Ok(_) => None,
     260              :         Err(_) => {
     261            0 :             tracing::info!(
     262            0 :                 timeout_millis = timeout.as_millis(),
     263            0 :                 %phase,
     264            0 :                 "Startup phase timed out, proceeding anyway"
     265              :             );
     266            0 :             Some(fut)
     267              :         }
     268              :     };
     269              : 
     270            0 :     WaitForPhaseResult {
     271            0 :         timeout_remaining: timeout
     272            0 :             .checked_sub(Instant::now().duration_since(initial_t))
     273            0 :             .unwrap_or(Duration::ZERO),
     274            0 :         skipped,
     275            0 :     }
     276            0 : }
     277              : 
     278            0 : fn startup_checkpoint(started_at: Instant, phase: &str, human_phase: &str) {
     279            0 :     let elapsed = started_at.elapsed();
     280            0 :     let secs = elapsed.as_secs_f64();
     281            0 :     STARTUP_DURATION.with_label_values(&[phase]).set(secs);
     282            0 : 
     283            0 :     info!(
     284            0 :         elapsed_ms = elapsed.as_millis(),
     285            0 :         "{human_phase} ({secs:.3}s since start)"
     286              :     )
     287            0 : }
     288              : 
     289            0 : fn start_pageserver(
     290            0 :     launch_ts: &'static LaunchTimestamp,
     291            0 :     conf: &'static PageServerConf,
     292            0 : ) -> anyhow::Result<()> {
     293            0 :     // Monotonic time for later calculating startup duration
     294            0 :     let started_startup_at = Instant::now();
     295            0 : 
     296            0 :     // Print version and launch timestamp to the log,
     297            0 :     // and expose them as prometheus metrics.
     298            0 :     // A changed version string indicates changed software.
     299            0 :     // A changed launch timestamp indicates a pageserver restart.
     300            0 :     info!(
     301            0 :         "version: {} launch_timestamp: {} build_tag: {}",
     302            0 :         version(),
     303            0 :         launch_ts.to_string(),
     304              :         BUILD_TAG,
     305              :     );
     306            0 :     set_build_info_metric(GIT_VERSION, BUILD_TAG);
     307            0 :     set_launch_timestamp_metric(launch_ts);
     308            0 :     #[cfg(target_os = "linux")]
     309            0 :     metrics::register_internal(Box::new(metrics::more_process_metrics::Collector::new())).unwrap();
     310            0 :     metrics::register_internal(Box::new(
     311            0 :         pageserver::metrics::tokio_epoll_uring::Collector::new(),
     312            0 :     ))
     313            0 :     .unwrap();
     314            0 :     pageserver::preinitialize_metrics(conf);
     315            0 : 
     316            0 :     // If any failpoints were set from FAILPOINTS environment variable,
     317            0 :     // print them to the log for debugging purposes
     318            0 :     let failpoints = fail::list();
     319            0 :     if !failpoints.is_empty() {
     320            0 :         info!(
     321            0 :             "started with failpoints: {}",
     322            0 :             failpoints
     323            0 :                 .iter()
     324            0 :                 .map(|(name, actions)| format!("{name}={actions}"))
     325            0 :                 .collect::<Vec<String>>()
     326            0 :                 .join(";")
     327              :         )
     328            0 :     }
     329              : 
     330              :     // Create and lock PID file. This ensures that there cannot be more than one
     331              :     // pageserver process running at the same time.
     332            0 :     let lock_file_path = conf.workdir.join(PID_FILE_NAME);
     333            0 :     info!("Claiming pid file at {lock_file_path:?}...");
     334            0 :     let lock_file =
     335            0 :         utils::pid_file::claim_for_current_process(&lock_file_path).context("claim pid file")?;
     336            0 :     info!("Claimed pid file at {lock_file_path:?}");
     337              : 
     338              :     // Ensure that the lock file is held even if the main thread of the process panics.
     339              :     // We need to release the lock file only when the process exits.
     340            0 :     std::mem::forget(lock_file);
     341            0 : 
     342            0 :     // Bind the HTTP and libpq ports early, so that if they are in use by some other
     343            0 :     // process, we error out early.
     344            0 :     let http_addr = &conf.listen_http_addr;
     345            0 :     info!("Starting pageserver http handler on {http_addr}");
     346            0 :     let http_listener = tcp_listener::bind(http_addr)?;
     347              : 
     348            0 :     let pg_addr = &conf.listen_pg_addr;
     349            0 : 
     350            0 :     info!("Starting pageserver pg protocol handler on {pg_addr}");
     351            0 :     let pageserver_listener = tcp_listener::bind(pg_addr)?;
     352              : 
     353              :     // Launch broker client
     354              :     // The storage_broker::connect call needs to happen inside a tokio runtime thread.
     355            0 :     let broker_client = WALRECEIVER_RUNTIME
     356            0 :         .block_on(async {
     357            0 :             // Note: we do not attempt connecting here (but validate endpoints sanity).
     358            0 :             storage_broker::connect(conf.broker_endpoint.clone(), conf.broker_keepalive_interval)
     359            0 :         })
     360            0 :         .with_context(|| {
     361            0 :             format!(
     362            0 :                 "create broker client for uri={:?} keepalive_interval={:?}",
     363            0 :                 &conf.broker_endpoint, conf.broker_keepalive_interval,
     364            0 :             )
     365            0 :         })?;
     366              : 
     367              :     // Initialize authentication for incoming connections
     368              :     let http_auth;
     369              :     let pg_auth;
     370            0 :     if conf.http_auth_type == AuthType::NeonJWT || conf.pg_auth_type == AuthType::NeonJWT {
     371              :         // unwrap is ok because check is performed when creating config, so path is set and exists
     372            0 :         let key_path = conf.auth_validation_public_key_path.as_ref().unwrap();
     373            0 :         info!("Loading public key(s) for verifying JWT tokens from {key_path:?}");
     374              : 
     375            0 :         let jwt_auth = JwtAuth::from_key_path(key_path)?;
     376            0 :         let auth: Arc<SwappableJwtAuth> = Arc::new(SwappableJwtAuth::new(jwt_auth));
     377              : 
     378            0 :         http_auth = match &conf.http_auth_type {
     379            0 :             AuthType::Trust => None,
     380            0 :             AuthType::NeonJWT => Some(auth.clone()),
     381              :         };
     382            0 :         pg_auth = match &conf.pg_auth_type {
     383            0 :             AuthType::Trust => None,
     384            0 :             AuthType::NeonJWT => Some(auth),
     385              :         };
     386            0 :     } else {
     387            0 :         http_auth = None;
     388            0 :         pg_auth = None;
     389            0 :     }
     390            0 :     info!("Using auth for http API: {:#?}", conf.http_auth_type);
     391            0 :     info!("Using auth for pg connections: {:#?}", conf.pg_auth_type);
     392              : 
     393            0 :     match var("NEON_AUTH_TOKEN") {
     394            0 :         Ok(v) => {
     395            0 :             info!("Loaded JWT token for authentication with Safekeeper");
     396            0 :             pageserver::config::SAFEKEEPER_AUTH_TOKEN
     397            0 :                 .set(Arc::new(v))
     398            0 :                 .map_err(|_| anyhow!("Could not initialize SAFEKEEPER_AUTH_TOKEN"))?;
     399              :         }
     400              :         Err(VarError::NotPresent) => {
     401            0 :             info!("No JWT token for authentication with Safekeeper detected");
     402              :         }
     403            0 :         Err(e) => {
     404            0 :             return Err(e).with_context(|| {
     405            0 :                 "Failed to either load to detect non-present NEON_AUTH_TOKEN environment variable"
     406            0 :             })
     407              :         }
     408              :     };
     409              : 
     410              :     // Top-level cancellation token for the process
     411            0 :     let shutdown_pageserver = tokio_util::sync::CancellationToken::new();
     412              : 
     413              :     // Set up remote storage client
     414            0 :     let remote_storage = BACKGROUND_RUNTIME.block_on(create_remote_storage_client(conf))?;
     415              : 
     416              :     // Set up deletion queue
     417            0 :     let (deletion_queue, deletion_workers) = DeletionQueue::new(
     418            0 :         remote_storage.clone(),
     419            0 :         ControllerUpcallClient::new(conf, &shutdown_pageserver),
     420            0 :         conf,
     421            0 :     );
     422            0 :     deletion_workers.spawn_with(BACKGROUND_RUNTIME.handle());
     423            0 : 
     424            0 :     // Up to this point no significant I/O has been done: this should have been fast.  Record
     425            0 :     // duration prior to starting I/O intensive phase of startup.
     426            0 :     startup_checkpoint(started_startup_at, "initial", "Starting loading tenants");
     427            0 :     STARTUP_IS_LOADING.set(1);
     428            0 : 
     429            0 :     // Startup staging or optimizing:
     430            0 :     //
     431            0 :     // We want to minimize downtime for `page_service` connections, and trying not to overload
     432            0 :     // BACKGROUND_RUNTIME by doing initial compactions and initial logical sizes at the same time.
     433            0 :     //
     434            0 :     // init_done_rx will notify when all initial load operations have completed.
     435            0 :     //
     436            0 :     // background_jobs_can_start (same name used to hold off background jobs from starting at
     437            0 :     // consumer side) will be dropped once we can start the background jobs. Currently it is behind
     438            0 :     // completing all initial logical size calculations (init_logical_size_done_rx) and a timeout
     439            0 :     // (background_task_maximum_delay).
     440            0 :     let (init_remote_done_tx, init_remote_done_rx) = utils::completion::channel();
     441            0 :     let (init_done_tx, init_done_rx) = utils::completion::channel();
     442            0 : 
     443            0 :     let (background_jobs_can_start, background_jobs_barrier) = utils::completion::channel();
     444            0 : 
     445            0 :     let order = pageserver::InitializationOrder {
     446            0 :         initial_tenant_load_remote: Some(init_done_tx),
     447            0 :         initial_tenant_load: Some(init_remote_done_tx),
     448            0 :         background_jobs_can_start: background_jobs_barrier.clone(),
     449            0 :     };
     450            0 : 
     451            0 :     info!(config=?conf.l0_flush, "using l0_flush config");
     452            0 :     let l0_flush_global_state =
     453            0 :         pageserver::l0_flush::L0FlushGlobalState::new(conf.l0_flush.clone());
     454            0 : 
     455            0 :     // Scan the local 'tenants/' directory and start loading the tenants
     456            0 :     let deletion_queue_client = deletion_queue.new_client();
     457            0 :     let background_purges = mgr::BackgroundPurges::default();
     458            0 :     let tenant_manager = BACKGROUND_RUNTIME.block_on(mgr::init_tenant_mgr(
     459            0 :         conf,
     460            0 :         background_purges.clone(),
     461            0 :         TenantSharedResources {
     462            0 :             broker_client: broker_client.clone(),
     463            0 :             remote_storage: remote_storage.clone(),
     464            0 :             deletion_queue_client,
     465            0 :             l0_flush_global_state,
     466            0 :         },
     467            0 :         order,
     468            0 :         shutdown_pageserver.clone(),
     469            0 :     ))?;
     470            0 :     let tenant_manager = Arc::new(tenant_manager);
     471            0 : 
     472            0 :     BACKGROUND_RUNTIME.spawn({
     473            0 :         let shutdown_pageserver = shutdown_pageserver.clone();
     474            0 :         let drive_init = async move {
     475            0 :             // NOTE: unlike many futures in pageserver, this one is cancellation-safe
     476            0 :             let guard = scopeguard::guard_on_success((), |_| {
     477            0 :                 tracing::info!("Cancelled before initial load completed")
     478            0 :             });
     479            0 : 
     480            0 :             let timeout = conf.background_task_maximum_delay;
     481            0 : 
     482            0 :             let init_remote_done = std::pin::pin!(async {
     483            0 :                 init_remote_done_rx.wait().await;
     484            0 :                 startup_checkpoint(
     485            0 :                     started_startup_at,
     486            0 :                     "initial_tenant_load_remote",
     487            0 :                     "Remote part of initial load completed",
     488            0 :                 );
     489            0 :             });
     490              : 
     491              :             let WaitForPhaseResult {
     492            0 :                 timeout_remaining: timeout,
     493            0 :                 skipped: init_remote_skipped,
     494            0 :             } = wait_for_phase("initial_tenant_load_remote", init_remote_done, timeout).await;
     495              : 
     496            0 :             let init_load_done = std::pin::pin!(async {
     497            0 :                 init_done_rx.wait().await;
     498            0 :                 startup_checkpoint(
     499            0 :                     started_startup_at,
     500            0 :                     "initial_tenant_load",
     501            0 :                     "Initial load completed",
     502            0 :                 );
     503            0 :                 STARTUP_IS_LOADING.set(0);
     504            0 :             });
     505              : 
     506              :             let WaitForPhaseResult {
     507            0 :                 timeout_remaining: _timeout,
     508            0 :                 skipped: init_load_skipped,
     509            0 :             } = wait_for_phase("initial_tenant_load", init_load_done, timeout).await;
     510              : 
     511              :             // initial logical sizes can now start, as they were waiting on init_done_rx.
     512              : 
     513            0 :             scopeguard::ScopeGuard::into_inner(guard);
     514            0 : 
     515            0 :             // allow background jobs to start: we either completed prior stages, or they reached timeout
     516            0 :             // and were skipped.  It is important that we do not let them block background jobs indefinitely,
     517            0 :             // because things like consumption metrics for billing are blocked by this barrier.
     518            0 :             drop(background_jobs_can_start);
     519            0 :             startup_checkpoint(
     520            0 :                 started_startup_at,
     521            0 :                 "background_jobs_can_start",
     522            0 :                 "Starting background jobs",
     523            0 :             );
     524            0 : 
     525            0 :             // We are done. If we skipped any phases due to timeout, run them to completion here so that
     526            0 :             // they will eventually update their startup_checkpoint, and so that we do not declare the
     527            0 :             // 'complete' stage until all the other stages are really done.
     528            0 :             let guard = scopeguard::guard_on_success((), |_| {
     529            0 :                 tracing::info!("Cancelled before waiting for skipped phases done")
     530            0 :             });
     531            0 :             if let Some(f) = init_remote_skipped {
     532            0 :                 f.await;
     533            0 :             }
     534            0 :             if let Some(f) = init_load_skipped {
     535            0 :                 f.await;
     536            0 :             }
     537            0 :             scopeguard::ScopeGuard::into_inner(guard);
     538            0 : 
     539            0 :             startup_checkpoint(started_startup_at, "complete", "Startup complete");
     540            0 :         };
     541            0 : 
     542            0 :         async move {
     543            0 :             let mut drive_init = std::pin::pin!(drive_init);
     544            0 :             // just race these tasks
     545            0 :             tokio::select! {
     546            0 :                 _ = shutdown_pageserver.cancelled() => {},
     547            0 :                 _ = &mut drive_init => {},
     548              :             }
     549            0 :         }
     550            0 :     });
     551            0 : 
     552            0 :     let (secondary_controller, secondary_controller_tasks) = secondary::spawn_tasks(
     553            0 :         tenant_manager.clone(),
     554            0 :         remote_storage.clone(),
     555            0 :         background_jobs_barrier.clone(),
     556            0 :         shutdown_pageserver.clone(),
     557            0 :     );
     558            0 : 
     559            0 :     // shared state between the disk-usage backed eviction background task and the http endpoint
     560            0 :     // that allows triggering disk-usage based eviction manually. note that the http endpoint
     561            0 :     // is still accessible even if background task is not configured as long as remote storage has
     562            0 :     // been configured.
     563            0 :     let disk_usage_eviction_state: Arc<disk_usage_eviction_task::State> = Arc::default();
     564            0 : 
     565            0 :     let disk_usage_eviction_task = launch_disk_usage_global_eviction_task(
     566            0 :         conf,
     567            0 :         remote_storage.clone(),
     568            0 :         disk_usage_eviction_state.clone(),
     569            0 :         tenant_manager.clone(),
     570            0 :         background_jobs_barrier.clone(),
     571            0 :     );
     572              : 
     573              :     // Start up the service to handle HTTP mgmt API request. We created the
     574              :     // listener earlier already.
     575            0 :     let http_endpoint_listener = {
     576            0 :         let _rt_guard = MGMT_REQUEST_RUNTIME.enter(); // for hyper
     577            0 :         let cancel = CancellationToken::new();
     578              : 
     579            0 :         let router_state = Arc::new(
     580            0 :             http::routes::State::new(
     581            0 :                 conf,
     582            0 :                 tenant_manager.clone(),
     583            0 :                 http_auth.clone(),
     584            0 :                 remote_storage.clone(),
     585            0 :                 broker_client.clone(),
     586            0 :                 disk_usage_eviction_state,
     587            0 :                 deletion_queue.new_client(),
     588            0 :                 secondary_controller,
     589            0 :             )
     590            0 :             .context("Failed to initialize router state")?,
     591              :         );
     592            0 :         let router = http::make_router(router_state, launch_ts, http_auth.clone())?
     593            0 :             .build()
     594            0 :             .map_err(|err| anyhow!(err))?;
     595            0 :         let service = http_utils::RouterService::new(router).unwrap();
     596            0 :         let server = hyper0::Server::from_tcp(http_listener)?
     597            0 :             .serve(service)
     598            0 :             .with_graceful_shutdown({
     599            0 :                 let cancel = cancel.clone();
     600            0 :                 async move { cancel.clone().cancelled().await }
     601            0 :             });
     602            0 : 
     603            0 :         let task = MGMT_REQUEST_RUNTIME.spawn(task_mgr::exit_on_panic_or_error(
     604            0 :             "http endpoint listener",
     605            0 :             server,
     606            0 :         ));
     607            0 :         HttpEndpointListener(CancellableTask { task, cancel })
     608            0 :     };
     609            0 : 
     610            0 :     let consumption_metrics_tasks = {
     611            0 :         let cancel = shutdown_pageserver.child_token();
     612            0 :         let task = crate::BACKGROUND_RUNTIME.spawn({
     613            0 :             let tenant_manager = tenant_manager.clone();
     614            0 :             let cancel = cancel.clone();
     615            0 :             async move {
     616            0 :                 // first wait until background jobs are cleared to launch.
     617            0 :                 //
     618            0 :                 // this is because we only process active tenants and timelines, and the
     619            0 :                 // Timeline::get_current_logical_size will spawn the logical size calculation,
     620            0 :                 // which will not be rate-limited.
     621            0 :                 tokio::select! {
     622            0 :                     _ = cancel.cancelled() => { return; },
     623            0 :                     _ = background_jobs_barrier.wait() => {}
     624            0 :                 };
     625            0 : 
     626            0 :                 pageserver::consumption_metrics::run(conf, tenant_manager, cancel).await;
     627            0 :             }
     628            0 :         });
     629            0 :         ConsumptionMetricsTasks(CancellableTask { task, cancel })
     630              :     };
     631              : 
     632              :     // Spawn a task to listen for libpq connections. It will spawn further tasks
     633              :     // for each connection. We created the listener earlier already.
     634            0 :     let page_service = page_service::spawn(conf, tenant_manager.clone(), pg_auth, {
     635            0 :         let _entered = COMPUTE_REQUEST_RUNTIME.enter(); // TcpListener::from_std requires it
     636            0 :         pageserver_listener
     637            0 :             .set_nonblocking(true)
     638            0 :             .context("set listener to nonblocking")?;
     639            0 :         tokio::net::TcpListener::from_std(pageserver_listener).context("create tokio listener")?
     640              :     });
     641              : 
     642              :     // All started up! Now just sit and wait for shutdown signal.
     643            0 :     BACKGROUND_RUNTIME.block_on(async move {
     644            0 :         let signal_token = CancellationToken::new();
     645            0 :         let signal_cancel = signal_token.child_token();
     646            0 : 
     647            0 :         // Spawn signal handlers. Runs in a loop since we want to be responsive to multiple signals
     648            0 :         // even after triggering shutdown (e.g. a SIGQUIT after a slow SIGTERM shutdown). See:
     649            0 :         // https://github.com/neondatabase/neon/issues/9740.
     650            0 :         tokio::spawn(async move {
     651            0 :             let mut sigint = tokio::signal::unix::signal(SignalKind::interrupt()).unwrap();
     652            0 :             let mut sigterm = tokio::signal::unix::signal(SignalKind::terminate()).unwrap();
     653            0 :             let mut sigquit = tokio::signal::unix::signal(SignalKind::quit()).unwrap();
     654              : 
     655              :             loop {
     656            0 :                 let signal = tokio::select! {
     657            0 :                     _ = sigquit.recv() => {
     658            0 :                         info!("Got signal SIGQUIT. Terminating in immediate shutdown mode.");
     659            0 :                         std::process::exit(111);
     660              :                     }
     661            0 :                     _ = sigint.recv() => "SIGINT",
     662            0 :                     _ = sigterm.recv() => "SIGTERM",
     663              :                 };
     664              : 
     665            0 :                 if !signal_token.is_cancelled() {
     666            0 :                     info!("Got signal {signal}. Terminating gracefully in fast shutdown mode.");
     667            0 :                     signal_token.cancel();
     668              :                 } else {
     669            0 :                     info!("Got signal {signal}. Already shutting down.");
     670              :                 }
     671              :             }
     672            0 :         });
     673            0 : 
     674            0 :         // Wait for cancellation signal and shut down the pageserver.
     675            0 :         //
     676            0 :         // This cancels the `shutdown_pageserver` cancellation tree. Right now that tree doesn't
     677            0 :         // reach very far, and `task_mgr` is used instead. The plan is to change that over time.
     678            0 :         signal_cancel.cancelled().await;
     679              : 
     680            0 :         shutdown_pageserver.cancel();
     681            0 :         pageserver::shutdown_pageserver(
     682            0 :             http_endpoint_listener,
     683            0 :             page_service,
     684            0 :             consumption_metrics_tasks,
     685            0 :             disk_usage_eviction_task,
     686            0 :             &tenant_manager,
     687            0 :             background_purges,
     688            0 :             deletion_queue.clone(),
     689            0 :             secondary_controller_tasks,
     690            0 :             0,
     691            0 :         )
     692            0 :         .await;
     693            0 :         unreachable!();
     694            0 :     })
     695            0 : }
     696              : 
     697            0 : async fn create_remote_storage_client(
     698            0 :     conf: &'static PageServerConf,
     699            0 : ) -> anyhow::Result<GenericRemoteStorage> {
     700            0 :     let config = if let Some(config) = &conf.remote_storage_config {
     701            0 :         config
     702              :     } else {
     703            0 :         anyhow::bail!("no remote storage configured, this is a deprecated configuration");
     704              :     };
     705              : 
     706              :     // Create the client
     707            0 :     let mut remote_storage = GenericRemoteStorage::from_config(config).await?;
     708              : 
     709              :     // If `test_remote_failures` is non-zero, wrap the client with a
     710              :     // wrapper that simulates failures.
     711            0 :     if conf.test_remote_failures > 0 {
     712            0 :         if !cfg!(feature = "testing") {
     713            0 :             anyhow::bail!("test_remote_failures option is not available because pageserver was compiled without the 'testing' feature");
     714            0 :         }
     715            0 :         info!(
     716            0 :             "Simulating remote failures for first {} attempts of each op",
     717              :             conf.test_remote_failures
     718              :         );
     719            0 :         remote_storage =
     720            0 :             GenericRemoteStorage::unreliable_wrapper(remote_storage, conf.test_remote_failures);
     721            0 :     }
     722              : 
     723            0 :     Ok(remote_storage)
     724            0 : }
     725              : 
     726            4 : fn cli() -> Command {
     727            4 :     Command::new("Neon page server")
     728            4 :         .about("Materializes WAL stream to pages and serves them to the postgres")
     729            4 :         .version(version())
     730            4 :         .arg(
     731            4 :             Arg::new("workdir")
     732            4 :                 .short('D')
     733            4 :                 .long("workdir")
     734            4 :                 .help("Working directory for the pageserver"),
     735            4 :         )
     736            4 :         .arg(
     737            4 :             Arg::new("enabled-features")
     738            4 :                 .long("enabled-features")
     739            4 :                 .action(ArgAction::SetTrue)
     740            4 :                 .help("Show enabled compile time features"),
     741            4 :         )
     742            4 : }
     743              : 
     744              : #[test]
     745            4 : fn verify_cli() {
     746            4 :     cli().debug_assert();
     747            4 : }
        

Generated by: LCOV version 2.1-beta