diff options
35 files changed, 392 insertions, 426 deletions
| diff --git a/src/common/logging/filter.cpp b/src/common/logging/filter.cpp index f055f0e11..42744c994 100644 --- a/src/common/logging/filter.cpp +++ b/src/common/logging/filter.cpp @@ -111,6 +111,7 @@ bool ParseFilterRule(Filter& instance, Iterator begin, Iterator end) {      SUB(Service, NCM)                                                                              \      SUB(Service, NFC)                                                                              \      SUB(Service, NFP)                                                                              \ +    SUB(Service, NGCT)                                                                             \      SUB(Service, NIFM)                                                                             \      SUB(Service, NIM)                                                                              \      SUB(Service, NPNS)                                                                             \ diff --git a/src/common/logging/types.h b/src/common/logging/types.h index 7ad0334fc..ddf9d27ca 100644 --- a/src/common/logging/types.h +++ b/src/common/logging/types.h @@ -81,6 +81,7 @@ enum class Class : u8 {      Service_NCM,       ///< The NCM service      Service_NFC,       ///< The NFC (Near-field communication) service      Service_NFP,       ///< The NFP service +    Service_NGCT,      ///< The NGCT (No Good Content for Terra) service      Service_NIFM,      ///< The NIFM (Network interface) service      Service_NIM,       ///< The NIM service      Service_NPNS,      ///< The NPNS service diff --git a/src/core/CMakeLists.txt b/src/core/CMakeLists.txt index f5cf5c16a..87d47e2e5 100644 --- a/src/core/CMakeLists.txt +++ b/src/core/CMakeLists.txt @@ -452,6 +452,8 @@ add_library(core STATIC      hle/service/nfp/nfp.h      hle/service/nfp/nfp_user.cpp      hle/service/nfp/nfp_user.h +    hle/service/ngct/ngct.cpp +    hle/service/ngct/ngct.h      hle/service/nifm/nifm.cpp      hle/service/nifm/nifm.h      hle/service/nim/nim.cpp diff --git a/src/core/core.cpp b/src/core/core.cpp index 5893a86bf..ba4629993 100644 --- a/src/core/core.cpp +++ b/src/core/core.cpp @@ -507,6 +507,12 @@ const ARM_Interface& System::CurrentArmInterface() const {      return impl->kernel.CurrentPhysicalCore().ArmInterface();  } +std::size_t System::CurrentCoreIndex() const { +    std::size_t core = impl->kernel.GetCurrentHostThreadID(); +    ASSERT(core < Core::Hardware::NUM_CPU_CORES); +    return core; +} +  Kernel::PhysicalCore& System::CurrentPhysicalCore() {      return impl->kernel.CurrentPhysicalCore();  } diff --git a/src/core/core.h b/src/core/core.h index f9116ebb6..715ab88e7 100644 --- a/src/core/core.h +++ b/src/core/core.h @@ -205,6 +205,9 @@ public:      /// Gets an ARM interface to the CPU core that is currently running      [[nodiscard]] const ARM_Interface& CurrentArmInterface() const; +    /// Gets the index of the currently running CPU core +    [[nodiscard]] std::size_t CurrentCoreIndex() const; +      /// Gets the physical core for the CPU core that is currently running      [[nodiscard]] Kernel::PhysicalCore& CurrentPhysicalCore(); diff --git a/src/core/cpu_manager.cpp b/src/core/cpu_manager.cpp index de2e5563e..7e195346b 100644 --- a/src/core/cpu_manager.cpp +++ b/src/core/cpu_manager.cpp @@ -21,25 +21,34 @@ namespace Core {  CpuManager::CpuManager(System& system_) : system{system_} {}  CpuManager::~CpuManager() = default; -void CpuManager::ThreadStart(std::stop_token stop_token, CpuManager& cpu_manager, -                             std::size_t core) { -    cpu_manager.RunThread(stop_token, core); +void CpuManager::ThreadStart(CpuManager& cpu_manager, std::size_t core) { +    cpu_manager.RunThread(core);  }  void CpuManager::Initialize() {      running_mode = true;      if (is_multicore) {          for (std::size_t core = 0; core < Core::Hardware::NUM_CPU_CORES; core++) { -            core_data[core].host_thread = std::jthread(ThreadStart, std::ref(*this), core); +            core_data[core].host_thread = +                std::make_unique<std::thread>(ThreadStart, std::ref(*this), core);          }      } else { -        core_data[0].host_thread = std::jthread(ThreadStart, std::ref(*this), 0); +        core_data[0].host_thread = std::make_unique<std::thread>(ThreadStart, std::ref(*this), 0);      }  }  void CpuManager::Shutdown() {      running_mode = false;      Pause(false); +    if (is_multicore) { +        for (auto& data : core_data) { +            data.host_thread->join(); +            data.host_thread.reset(); +        } +    } else { +        core_data[0].host_thread->join(); +        core_data[0].host_thread.reset(); +    }  }  std::function<void(void*)> CpuManager::GetGuestThreadStartFunc() { @@ -118,18 +127,17 @@ void CpuManager::MultiCoreRunGuestLoop() {              physical_core = &kernel.CurrentPhysicalCore();          }          system.ExitDynarmicProfile(); -        { -            Kernel::KScopedDisableDispatch dd(kernel); -            physical_core->ArmInterface().ClearExclusiveState(); -        } +        physical_core->ArmInterface().ClearExclusiveState(); +        kernel.CurrentScheduler()->RescheduleCurrentCore();      }  }  void CpuManager::MultiCoreRunIdleThread() {      auto& kernel = system.Kernel();      while (true) { -        Kernel::KScopedDisableDispatch dd(kernel); -        kernel.CurrentPhysicalCore().Idle(); +        auto& physical_core = kernel.CurrentPhysicalCore(); +        physical_core.Idle(); +        kernel.CurrentScheduler()->RescheduleCurrentCore();      }  } @@ -137,12 +145,12 @@ void CpuManager::MultiCoreRunSuspendThread() {      auto& kernel = system.Kernel();      kernel.CurrentScheduler()->OnThreadStart();      while (true) { -        auto core = kernel.CurrentPhysicalCoreIndex(); +        auto core = kernel.GetCurrentHostThreadID();          auto& scheduler = *kernel.CurrentScheduler();          Kernel::KThread* current_thread = scheduler.GetCurrentThread();          Common::Fiber::YieldTo(current_thread->GetHostContext(), *core_data[core].host_context);          ASSERT(scheduler.ContextSwitchPending()); -        ASSERT(core == kernel.CurrentPhysicalCoreIndex()); +        ASSERT(core == kernel.GetCurrentHostThreadID());          scheduler.RescheduleCurrentCore();      }  } @@ -309,7 +317,7 @@ void CpuManager::Pause(bool paused) {      }  } -void CpuManager::RunThread(std::stop_token stop_token, std::size_t core) { +void CpuManager::RunThread(std::size_t core) {      /// Initialization      system.RegisterCoreThread(core);      std::string name; @@ -348,8 +356,8 @@ void CpuManager::RunThread(std::stop_token stop_token, std::size_t core) {              sc_sync_first_use = false;          } -        // Emulation was stopped -        if (stop_token.stop_requested()) { +        // Abort if emulation was killed before the session really starts +        if (!system.IsPoweredOn()) {              return;          } diff --git a/src/core/cpu_manager.h b/src/core/cpu_manager.h index 9d92d4af0..140263b09 100644 --- a/src/core/cpu_manager.h +++ b/src/core/cpu_manager.h @@ -78,9 +78,9 @@ private:      void SingleCoreRunSuspendThread();      void SingleCorePause(bool paused); -    static void ThreadStart(std::stop_token stop_token, CpuManager& cpu_manager, std::size_t core); +    static void ThreadStart(CpuManager& cpu_manager, std::size_t core); -    void RunThread(std::stop_token stop_token, std::size_t core); +    void RunThread(std::size_t core);      struct CoreData {          std::shared_ptr<Common::Fiber> host_context; @@ -89,7 +89,7 @@ private:          std::atomic<bool> is_running;          std::atomic<bool> is_paused;          std::atomic<bool> initialized; -        std::jthread host_thread; +        std::unique_ptr<std::thread> host_thread;      };      std::atomic<bool> running_mode{}; diff --git a/src/core/hle/kernel/k_address_arbiter.cpp b/src/core/hle/kernel/k_address_arbiter.cpp index 6771ef621..1b429bc1e 100644 --- a/src/core/hle/kernel/k_address_arbiter.cpp +++ b/src/core/hle/kernel/k_address_arbiter.cpp @@ -28,7 +28,7 @@ bool ReadFromUser(Core::System& system, s32* out, VAddr address) {  bool DecrementIfLessThan(Core::System& system, s32* out, VAddr address, s32 value) {      auto& monitor = system.Monitor(); -    const auto current_core = system.Kernel().CurrentPhysicalCoreIndex(); +    const auto current_core = system.CurrentCoreIndex();      // TODO(bunnei): We should disable interrupts here via KScopedInterruptDisable.      // TODO(bunnei): We should call CanAccessAtomic(..) here. @@ -58,7 +58,7 @@ bool DecrementIfLessThan(Core::System& system, s32* out, VAddr address, s32 valu  bool UpdateIfEqual(Core::System& system, s32* out, VAddr address, s32 value, s32 new_value) {      auto& monitor = system.Monitor(); -    const auto current_core = system.Kernel().CurrentPhysicalCoreIndex(); +    const auto current_core = system.CurrentCoreIndex();      // TODO(bunnei): We should disable interrupts here via KScopedInterruptDisable.      // TODO(bunnei): We should call CanAccessAtomic(..) here. diff --git a/src/core/hle/kernel/k_auto_object.h b/src/core/hle/kernel/k_auto_object.h index 165b76747..e4fcdbc67 100644 --- a/src/core/hle/kernel/k_auto_object.h +++ b/src/core/hle/kernel/k_auto_object.h @@ -170,10 +170,6 @@ public:          }      } -    const std::string& GetName() const { -        return name; -    } -  private:      void RegisterWithKernel();      void UnregisterWithKernel(); diff --git a/src/core/hle/kernel/k_condition_variable.cpp b/src/core/hle/kernel/k_condition_variable.cpp index 4174f35fd..ef14ad1d2 100644 --- a/src/core/hle/kernel/k_condition_variable.cpp +++ b/src/core/hle/kernel/k_condition_variable.cpp @@ -35,7 +35,7 @@ bool WriteToUser(Core::System& system, VAddr address, const u32* p) {  bool UpdateLockAtomic(Core::System& system, u32* out, VAddr address, u32 if_zero,                        u32 new_orr_mask) {      auto& monitor = system.Monitor(); -    const auto current_core = system.Kernel().CurrentPhysicalCoreIndex(); +    const auto current_core = system.CurrentCoreIndex();      // Load the value from the address.      const auto expected = monitor.ExclusiveRead32(current_core, address); diff --git a/src/core/hle/kernel/k_handle_table.cpp b/src/core/hle/kernel/k_handle_table.cpp index d720c2dda..6a420d5b0 100644 --- a/src/core/hle/kernel/k_handle_table.cpp +++ b/src/core/hle/kernel/k_handle_table.cpp @@ -13,7 +13,6 @@ ResultCode KHandleTable::Finalize() {      // Get the table and clear our record of it.      u16 saved_table_size = 0;      { -        KScopedDisableDispatch dd(kernel);          KScopedSpinLock lk(m_lock);          std::swap(m_table_size, saved_table_size); @@ -44,7 +43,6 @@ bool KHandleTable::Remove(Handle handle) {      // Find the object and free the entry.      KAutoObject* obj = nullptr;      { -        KScopedDisableDispatch dd(kernel);          KScopedSpinLock lk(m_lock);          if (this->IsValidHandle(handle)) { @@ -63,7 +61,6 @@ bool KHandleTable::Remove(Handle handle) {  }  ResultCode KHandleTable::Add(Handle* out_handle, KAutoObject* obj, u16 type) { -    KScopedDisableDispatch dd(kernel);      KScopedSpinLock lk(m_lock);      // Never exceed our capacity. @@ -86,7 +83,6 @@ ResultCode KHandleTable::Add(Handle* out_handle, KAutoObject* obj, u16 type) {  }  ResultCode KHandleTable::Reserve(Handle* out_handle) { -    KScopedDisableDispatch dd(kernel);      KScopedSpinLock lk(m_lock);      // Never exceed our capacity. @@ -97,7 +93,6 @@ ResultCode KHandleTable::Reserve(Handle* out_handle) {  }  void KHandleTable::Unreserve(Handle handle) { -    KScopedDisableDispatch dd(kernel);      KScopedSpinLock lk(m_lock);      // Unpack the handle. @@ -116,7 +111,6 @@ void KHandleTable::Unreserve(Handle handle) {  }  void KHandleTable::Register(Handle handle, KAutoObject* obj, u16 type) { -    KScopedDisableDispatch dd(kernel);      KScopedSpinLock lk(m_lock);      // Unpack the handle. diff --git a/src/core/hle/kernel/k_handle_table.h b/src/core/hle/kernel/k_handle_table.h index 75dcec7df..2ff6aa160 100644 --- a/src/core/hle/kernel/k_handle_table.h +++ b/src/core/hle/kernel/k_handle_table.h @@ -69,7 +69,6 @@ public:      template <typename T = KAutoObject>      KScopedAutoObject<T> GetObjectWithoutPseudoHandle(Handle handle) const {          // Lock and look up in table. -        KScopedDisableDispatch dd(kernel);          KScopedSpinLock lk(m_lock);          if constexpr (std::is_same_v<T, KAutoObject>) { @@ -124,7 +123,6 @@ public:          size_t num_opened;          {              // Lock the table. -            KScopedDisableDispatch dd(kernel);              KScopedSpinLock lk(m_lock);              for (num_opened = 0; num_opened < num_handles; num_opened++) {                  // Get the current handle. diff --git a/src/core/hle/kernel/k_process.cpp b/src/core/hle/kernel/k_process.cpp index 3d7e6707e..8ead1a769 100644 --- a/src/core/hle/kernel/k_process.cpp +++ b/src/core/hle/kernel/k_process.cpp @@ -59,7 +59,6 @@ void SetupMainThread(Core::System& system, KProcess& owner_process, u32 priority      thread->GetContext64().cpu_registers[0] = 0;      thread->GetContext32().cpu_registers[1] = thread_handle;      thread->GetContext64().cpu_registers[1] = thread_handle; -    thread->DisableDispatch();      auto& kernel = system.Kernel();      // Threads by default are dormant, wake up the main thread so it runs when the scheduler fires diff --git a/src/core/hle/kernel/k_scheduler.cpp b/src/core/hle/kernel/k_scheduler.cpp index 6ddbae52c..6a7d80d03 100644 --- a/src/core/hle/kernel/k_scheduler.cpp +++ b/src/core/hle/kernel/k_scheduler.cpp @@ -376,18 +376,20 @@ void KScheduler::ClearSchedulerUpdateNeeded(KernelCore& kernel) {  }  void KScheduler::DisableScheduling(KernelCore& kernel) { -    ASSERT(GetCurrentThreadPointer(kernel)->GetDisableDispatchCount() >= 0); -    GetCurrentThreadPointer(kernel)->DisableDispatch(); +    if (auto* scheduler = kernel.CurrentScheduler(); scheduler) { +        ASSERT(scheduler->GetCurrentThread()->GetDisableDispatchCount() >= 0); +        scheduler->GetCurrentThread()->DisableDispatch(); +    }  }  void KScheduler::EnableScheduling(KernelCore& kernel, u64 cores_needing_scheduling) { -    ASSERT(GetCurrentThreadPointer(kernel)->GetDisableDispatchCount() >= 1); - -    if (GetCurrentThreadPointer(kernel)->GetDisableDispatchCount() > 1) { -        GetCurrentThreadPointer(kernel)->EnableDispatch(); -    } else { -        RescheduleCores(kernel, cores_needing_scheduling); +    if (auto* scheduler = kernel.CurrentScheduler(); scheduler) { +        ASSERT(scheduler->GetCurrentThread()->GetDisableDispatchCount() >= 1); +        if (scheduler->GetCurrentThread()->GetDisableDispatchCount() >= 1) { +            scheduler->GetCurrentThread()->EnableDispatch(); +        }      } +    RescheduleCores(kernel, cores_needing_scheduling);  }  u64 KScheduler::UpdateHighestPriorityThreads(KernelCore& kernel) { @@ -615,17 +617,13 @@ KScheduler::KScheduler(Core::System& system_, s32 core_id_) : system{system_}, c      state.highest_priority_thread = nullptr;  } -void KScheduler::Finalize() { +KScheduler::~KScheduler() {      if (idle_thread) {          idle_thread->Close();          idle_thread = nullptr;      }  } -KScheduler::~KScheduler() { -    ASSERT(!idle_thread); -} -  KThread* KScheduler::GetCurrentThread() const {      if (auto result = current_thread.load(); result) {          return result; @@ -644,12 +642,10 @@ void KScheduler::RescheduleCurrentCore() {      if (phys_core.IsInterrupted()) {          phys_core.ClearInterrupt();      } -      guard.Lock();      if (state.needs_scheduling.load()) {          Schedule();      } else { -        GetCurrentThread()->EnableDispatch();          guard.Unlock();      }  } @@ -659,33 +655,26 @@ void KScheduler::OnThreadStart() {  }  void KScheduler::Unload(KThread* thread) { -    ASSERT(thread); -      LOG_TRACE(Kernel, "core {}, unload thread {}", core_id, thread ? thread->GetName() : "nullptr"); -    if (thread->IsCallingSvc()) { -        thread->ClearIsCallingSvc(); -    } - -    auto& physical_core = system.Kernel().PhysicalCore(core_id); -    if (!physical_core.IsInitialized()) { -        return; -    } - -    Core::ARM_Interface& cpu_core = physical_core.ArmInterface(); -    cpu_core.SaveContext(thread->GetContext32()); -    cpu_core.SaveContext(thread->GetContext64()); -    // Save the TPIDR_EL0 system register in case it was modified. -    thread->SetTPIDR_EL0(cpu_core.GetTPIDR_EL0()); -    cpu_core.ClearExclusiveState(); - -    if (!thread->IsTerminationRequested() && thread->GetActiveCore() == core_id) { -        prev_thread = thread; -    } else { -        prev_thread = nullptr; +    if (thread) { +        if (thread->IsCallingSvc()) { +            thread->ClearIsCallingSvc(); +        } +        if (!thread->IsTerminationRequested()) { +            prev_thread = thread; + +            Core::ARM_Interface& cpu_core = system.ArmInterface(core_id); +            cpu_core.SaveContext(thread->GetContext32()); +            cpu_core.SaveContext(thread->GetContext64()); +            // Save the TPIDR_EL0 system register in case it was modified. +            thread->SetTPIDR_EL0(cpu_core.GetTPIDR_EL0()); +            cpu_core.ClearExclusiveState(); +        } else { +            prev_thread = nullptr; +        } +        thread->context_guard.Unlock();      } - -    thread->context_guard.Unlock();  }  void KScheduler::Reload(KThread* thread) { @@ -694,6 +683,11 @@ void KScheduler::Reload(KThread* thread) {      if (thread) {          ASSERT_MSG(thread->GetState() == ThreadState::Runnable, "Thread must be runnable."); +        auto* const thread_owner_process = thread->GetOwnerProcess(); +        if (thread_owner_process != nullptr) { +            system.Kernel().MakeCurrentProcess(thread_owner_process); +        } +          Core::ARM_Interface& cpu_core = system.ArmInterface(core_id);          cpu_core.LoadContext(thread->GetContext32());          cpu_core.LoadContext(thread->GetContext64()); @@ -711,7 +705,7 @@ void KScheduler::SwitchContextStep2() {  }  void KScheduler::ScheduleImpl() { -    KThread* previous_thread = GetCurrentThread(); +    KThread* previous_thread = current_thread.load();      KThread* next_thread = state.highest_priority_thread;      state.needs_scheduling = false; @@ -723,15 +717,10 @@ void KScheduler::ScheduleImpl() {      // If we're not actually switching thread, there's nothing to do.      if (next_thread == current_thread.load()) { -        previous_thread->EnableDispatch();          guard.Unlock();          return;      } -    if (next_thread->GetCurrentCore() != core_id) { -        next_thread->SetCurrentCore(core_id); -    } -      current_thread.store(next_thread);      KProcess* const previous_process = system.Kernel().CurrentProcess(); @@ -742,7 +731,11 @@ void KScheduler::ScheduleImpl() {      Unload(previous_thread);      std::shared_ptr<Common::Fiber>* old_context; -    old_context = &previous_thread->GetHostContext(); +    if (previous_thread != nullptr) { +        old_context = &previous_thread->GetHostContext(); +    } else { +        old_context = &idle_thread->GetHostContext(); +    }      guard.Unlock();      Common::Fiber::YieldTo(*old_context, *switch_fiber); diff --git a/src/core/hle/kernel/k_scheduler.h b/src/core/hle/kernel/k_scheduler.h index 516e0cdba..12cfae919 100644 --- a/src/core/hle/kernel/k_scheduler.h +++ b/src/core/hle/kernel/k_scheduler.h @@ -33,8 +33,6 @@ public:      explicit KScheduler(Core::System& system_, s32 core_id_);      ~KScheduler(); -    void Finalize(); -      /// Reschedules to the next available thread (call after current thread is suspended)      void RescheduleCurrentCore(); diff --git a/src/core/hle/kernel/k_thread.cpp b/src/core/hle/kernel/k_thread.cpp index 0f6808ade..9f1d3156b 100644 --- a/src/core/hle/kernel/k_thread.cpp +++ b/src/core/hle/kernel/k_thread.cpp @@ -14,7 +14,6 @@  #include "common/fiber.h"  #include "common/logging/log.h"  #include "common/scope_exit.h" -#include "common/settings.h"  #include "common/thread_queue_list.h"  #include "core/core.h"  #include "core/cpu_manager.h" @@ -189,7 +188,7 @@ ResultCode KThread::Initialize(KThreadFunction func, uintptr_t arg, VAddr user_s      // Setup the stack parameters.      StackParameters& sp = GetStackParameters();      sp.cur_thread = this; -    sp.disable_count = 0; +    sp.disable_count = 1;      SetInExceptionHandler();      // Set thread ID. @@ -216,10 +215,9 @@ ResultCode KThread::InitializeThread(KThread* thread, KThreadFunction func, uint      // Initialize the thread.      R_TRY(thread->Initialize(func, arg, user_stack_top, prio, core, owner, type)); -    // Initialize emulation parameters. +    // Initialize host context.      thread->host_context =          std::make_shared<Common::Fiber>(std::move(init_func), init_func_parameter); -    thread->is_single_core = !Settings::values.use_multi_core.GetValue();      return ResultSuccess;  } @@ -972,9 +970,6 @@ ResultCode KThread::Run() {          // Set our state and finish.          SetState(ThreadState::Runnable); - -        DisableDispatch(); -          return ResultSuccess;      }  } @@ -1059,16 +1054,4 @@ s32 GetCurrentCoreId(KernelCore& kernel) {      return GetCurrentThread(kernel).GetCurrentCore();  } -KScopedDisableDispatch::~KScopedDisableDispatch() { -    if (GetCurrentThread(kernel).GetDisableDispatchCount() <= 1) { -        auto scheduler = kernel.CurrentScheduler(); - -        if (scheduler) { -            scheduler->RescheduleCurrentCore(); -        } -    } else { -        GetCurrentThread(kernel).EnableDispatch(); -    } -} -  } // namespace Kernel diff --git a/src/core/hle/kernel/k_thread.h b/src/core/hle/kernel/k_thread.h index e4c4c877d..c77f44ad4 100644 --- a/src/core/hle/kernel/k_thread.h +++ b/src/core/hle/kernel/k_thread.h @@ -450,39 +450,16 @@ public:          sleeping_queue = q;      } -    [[nodiscard]] bool IsKernelThread() const { -        return GetActiveCore() == 3; -    } - -    [[nodiscard]] bool IsDispatchTrackingDisabled() const { -        return is_single_core || IsKernelThread(); -    } -      [[nodiscard]] s32 GetDisableDispatchCount() const { -        if (IsDispatchTrackingDisabled()) { -            // TODO(bunnei): Until kernel threads are emulated, we cannot enable/disable dispatch. -            return 1; -        } -          return this->GetStackParameters().disable_count;      }      void DisableDispatch() { -        if (IsDispatchTrackingDisabled()) { -            // TODO(bunnei): Until kernel threads are emulated, we cannot enable/disable dispatch. -            return; -        } -          ASSERT(GetCurrentThread(kernel).GetDisableDispatchCount() >= 0);          this->GetStackParameters().disable_count++;      }      void EnableDispatch() { -        if (IsDispatchTrackingDisabled()) { -            // TODO(bunnei): Until kernel threads are emulated, we cannot enable/disable dispatch. -            return; -        } -          ASSERT(GetCurrentThread(kernel).GetDisableDispatchCount() > 0);          this->GetStackParameters().disable_count--;      } @@ -731,7 +708,6 @@ private:      // For emulation      std::shared_ptr<Common::Fiber> host_context{}; -    bool is_single_core{};      // For debugging      std::vector<KSynchronizationObject*> wait_objects_for_debugging; @@ -776,16 +752,4 @@ public:      }  }; -class KScopedDisableDispatch { -public: -    [[nodiscard]] explicit KScopedDisableDispatch(KernelCore& kernel_) : kernel{kernel_} { -        GetCurrentThread(kernel).DisableDispatch(); -    } - -    ~KScopedDisableDispatch(); - -private: -    KernelCore& kernel; -}; -  } // namespace Kernel diff --git a/src/core/hle/kernel/kernel.cpp b/src/core/hle/kernel/kernel.cpp index 8fdab44e4..bea945301 100644 --- a/src/core/hle/kernel/kernel.cpp +++ b/src/core/hle/kernel/kernel.cpp @@ -85,9 +85,8 @@ struct KernelCore::Impl {      }      void InitializeCores() { -        for (u32 core_id = 0; core_id < Core::Hardware::NUM_CPU_CORES; core_id++) { -            cores[core_id].Initialize(current_process->Is64BitProcess()); -            system.Memory().SetCurrentPageTable(*current_process, core_id); +        for (auto& core : cores) { +            core.Initialize(current_process->Is64BitProcess());          }      } @@ -132,6 +131,15 @@ struct KernelCore::Impl {          next_user_process_id = KProcess::ProcessIDMin;          next_thread_id = 1; +        for (u32 core_id = 0; core_id < Core::Hardware::NUM_CPU_CORES; core_id++) { +            if (suspend_threads[core_id]) { +                suspend_threads[core_id]->Close(); +                suspend_threads[core_id] = nullptr; +            } + +            schedulers[core_id].reset(); +        } +          cores.clear();          global_handle_table->Finalize(); @@ -159,16 +167,6 @@ struct KernelCore::Impl {          CleanupObject(time_shared_mem);          CleanupObject(system_resource_limit); -        for (u32 core_id = 0; core_id < Core::Hardware::NUM_CPU_CORES; core_id++) { -            if (suspend_threads[core_id]) { -                suspend_threads[core_id]->Close(); -                suspend_threads[core_id] = nullptr; -            } - -            schedulers[core_id]->Finalize(); -            schedulers[core_id].reset(); -        } -          // Next host thead ID to use, 0-3 IDs represent core threads, >3 represent others          next_host_thread_id = Core::Hardware::NUM_CPU_CORES; @@ -259,6 +257,14 @@ struct KernelCore::Impl {      void MakeCurrentProcess(KProcess* process) {          current_process = process; +        if (process == nullptr) { +            return; +        } + +        const u32 core_id = GetCurrentHostThreadID(); +        if (core_id < Core::Hardware::NUM_CPU_CORES) { +            system.Memory().SetCurrentPageTable(*process, core_id); +        }      }      static inline thread_local u32 host_thread_id = UINT32_MAX; @@ -821,20 +827,16 @@ const Kernel::PhysicalCore& KernelCore::PhysicalCore(std::size_t id) const {      return impl->cores[id];  } -size_t KernelCore::CurrentPhysicalCoreIndex() const { -    const u32 core_id = impl->GetCurrentHostThreadID(); -    if (core_id >= Core::Hardware::NUM_CPU_CORES) { -        return Core::Hardware::NUM_CPU_CORES - 1; -    } -    return core_id; -} -  Kernel::PhysicalCore& KernelCore::CurrentPhysicalCore() { -    return impl->cores[CurrentPhysicalCoreIndex()]; +    u32 core_id = impl->GetCurrentHostThreadID(); +    ASSERT(core_id < Core::Hardware::NUM_CPU_CORES); +    return impl->cores[core_id];  }  const Kernel::PhysicalCore& KernelCore::CurrentPhysicalCore() const { -    return impl->cores[CurrentPhysicalCoreIndex()]; +    u32 core_id = impl->GetCurrentHostThreadID(); +    ASSERT(core_id < Core::Hardware::NUM_CPU_CORES); +    return impl->cores[core_id];  }  Kernel::KScheduler* KernelCore::CurrentScheduler() { @@ -1027,9 +1029,6 @@ void KernelCore::Suspend(bool in_suspention) {              impl->suspend_threads[core_id]->SetState(state);              impl->suspend_threads[core_id]->SetWaitReasonForDebugging(                  ThreadWaitReasonForDebugging::Suspended); -            if (!should_suspend) { -                impl->suspend_threads[core_id]->DisableDispatch(); -            }          }      }  } @@ -1044,11 +1043,13 @@ void KernelCore::ExceptionalExit() {  }  void KernelCore::EnterSVCProfile() { -    impl->svc_ticks[CurrentPhysicalCoreIndex()] = MicroProfileEnter(MICROPROFILE_TOKEN(Kernel_SVC)); +    std::size_t core = impl->GetCurrentHostThreadID(); +    impl->svc_ticks[core] = MicroProfileEnter(MICROPROFILE_TOKEN(Kernel_SVC));  }  void KernelCore::ExitSVCProfile() { -    MicroProfileLeave(MICROPROFILE_TOKEN(Kernel_SVC), impl->svc_ticks[CurrentPhysicalCoreIndex()]); +    std::size_t core = impl->GetCurrentHostThreadID(); +    MicroProfileLeave(MICROPROFILE_TOKEN(Kernel_SVC), impl->svc_ticks[core]);  }  std::weak_ptr<Kernel::ServiceThread> KernelCore::CreateServiceThread(const std::string& name) { diff --git a/src/core/hle/kernel/kernel.h b/src/core/hle/kernel/kernel.h index 57535433b..3a6db0b1c 100644 --- a/src/core/hle/kernel/kernel.h +++ b/src/core/hle/kernel/kernel.h @@ -146,9 +146,6 @@ public:      /// Gets the an instance of the respective physical CPU core.      const Kernel::PhysicalCore& PhysicalCore(std::size_t id) const; -    /// Gets the current physical core index for the running host thread. -    std::size_t CurrentPhysicalCoreIndex() const; -      /// Gets the sole instance of the Scheduler at the current running core.      Kernel::KScheduler* CurrentScheduler(); diff --git a/src/core/hle/kernel/svc.cpp b/src/core/hle/kernel/svc.cpp index 890c52198..62fb06c45 100644 --- a/src/core/hle/kernel/svc.cpp +++ b/src/core/hle/kernel/svc.cpp @@ -877,7 +877,7 @@ static ResultCode GetInfo(Core::System& system, u64* result, u64 info_id, Handle              const u64 thread_ticks = current_thread->GetCpuTime();              out_ticks = thread_ticks + (core_timing.GetCPUTicks() - prev_ctx_ticks); -        } else if (same_thread && info_sub_id == system.Kernel().CurrentPhysicalCoreIndex()) { +        } else if (same_thread && info_sub_id == system.CurrentCoreIndex()) {              out_ticks = core_timing.GetCPUTicks() - prev_ctx_ticks;          } diff --git a/src/core/hle/service/ngct/ngct.cpp b/src/core/hle/service/ngct/ngct.cpp new file mode 100644 index 000000000..deb3abb28 --- /dev/null +++ b/src/core/hle/service/ngct/ngct.cpp @@ -0,0 +1,46 @@ +// Copyright 2021 yuzu Emulator Project +// Licensed under GPLv2 or any later version +// Refer to the license.txt file included + +#include "common/string_util.h" +#include "core/core.h" +#include "core/hle/ipc_helpers.h" +#include "core/hle/service/ngct/ngct.h" +#include "core/hle/service/service.h" + +namespace Service::NGCT { + +class IService final : public ServiceFramework<IService> { +public: +    explicit IService(Core::System& system_) : ServiceFramework{system_, "ngct:u"} { +        // clang-format off +        static const FunctionInfo functions[] = { +            {0, nullptr, "Match"}, +            {1, &IService::Filter, "Filter"}, +        }; +        // clang-format on + +        RegisterHandlers(functions); +    } + +private: +    void Filter(Kernel::HLERequestContext& ctx) { +        const auto buffer = ctx.ReadBuffer(); +        const auto text = Common::StringFromFixedZeroTerminatedBuffer( +            reinterpret_cast<const char*>(buffer.data()), buffer.size()); + +        LOG_WARNING(Service_NGCT, "(STUBBED) called, text={}", text); + +        // Return the same string since we don't censor anything +        ctx.WriteBuffer(buffer); + +        IPC::ResponseBuilder rb{ctx, 2}; +        rb.Push(ResultSuccess); +    } +}; + +void InstallInterfaces(SM::ServiceManager& service_manager, Core::System& system) { +    std::make_shared<IService>(system)->InstallAsService(system.ServiceManager()); +} + +} // namespace Service::NGCT diff --git a/src/core/hle/service/ngct/ngct.h b/src/core/hle/service/ngct/ngct.h new file mode 100644 index 000000000..1f2a47b78 --- /dev/null +++ b/src/core/hle/service/ngct/ngct.h @@ -0,0 +1,20 @@ +// Copyright 2021 yuzu Emulator Project +// Licensed under GPLv2 or any later version +// Refer to the license.txt file included + +#pragma once + +namespace Core { +class System; +} + +namespace Service::SM { +class ServiceManager; +} + +namespace Service::NGCT { + +/// Registers all NGCT services with the specified service manager. +void InstallInterfaces(SM::ServiceManager& service_manager, Core::System& system); + +} // namespace Service::NGCT diff --git a/src/core/hle/service/nifm/nifm.cpp b/src/core/hle/service/nifm/nifm.cpp index 0a53c0c81..9decb9290 100644 --- a/src/core/hle/service/nifm/nifm.cpp +++ b/src/core/hle/service/nifm/nifm.cpp @@ -277,37 +277,45 @@ private:      void GetCurrentNetworkProfile(Kernel::HLERequestContext& ctx) {          LOG_WARNING(Service_NIFM, "(STUBBED) called"); -        const SfNetworkProfileData network_profile_data{ -            .ip_setting_data{ -                .ip_address_setting{ -                    .is_automatic{true}, -                    .current_address{192, 168, 1, 100}, -                    .subnet_mask{255, 255, 255, 0}, -                    .gateway{192, 168, 1, 1}, -                }, -                .dns_setting{ -                    .is_automatic{true}, -                    .primary_dns{1, 1, 1, 1}, -                    .secondary_dns{1, 0, 0, 1}, +        const auto net_iface = Network::GetSelectedNetworkInterface(); + +        const SfNetworkProfileData network_profile_data = [&net_iface] { +            if (!net_iface) { +                return SfNetworkProfileData{}; +            } + +            return SfNetworkProfileData{ +                .ip_setting_data{ +                    .ip_address_setting{ +                        .is_automatic{true}, +                        .current_address{Network::TranslateIPv4(net_iface->ip_address)}, +                        .subnet_mask{Network::TranslateIPv4(net_iface->subnet_mask)}, +                        .gateway{Network::TranslateIPv4(net_iface->gateway)}, +                    }, +                    .dns_setting{ +                        .is_automatic{true}, +                        .primary_dns{1, 1, 1, 1}, +                        .secondary_dns{1, 0, 0, 1}, +                    }, +                    .proxy_setting{ +                        .enabled{false}, +                        .port{}, +                        .proxy_server{}, +                        .automatic_auth_enabled{}, +                        .user{}, +                        .password{}, +                    }, +                    .mtu{1500},                  }, -                .proxy_setting{ -                    .enabled{false}, -                    .port{}, -                    .proxy_server{}, -                    .automatic_auth_enabled{}, -                    .user{}, -                    .password{}, +                .uuid{0xdeadbeef, 0xdeadbeef}, +                .network_name{"yuzu Network"}, +                .wireless_setting_data{ +                    .ssid_length{12}, +                    .ssid{"yuzu Network"}, +                    .passphrase{"yuzupassword"},                  }, -                .mtu{1500}, -            }, -            .uuid{0xdeadbeef, 0xdeadbeef}, -            .network_name{"yuzu Network"}, -            .wireless_setting_data{ -                .ssid_length{12}, -                .ssid{"yuzu Network"}, -                .passphrase{"yuzupassword"}, -            }, -        }; +            }; +        }();          ctx.WriteBuffer(network_profile_data); @@ -352,38 +360,33 @@ private:          LOG_WARNING(Service_NIFM, "(STUBBED) called");          struct IpConfigInfo { -            IpAddressSetting ip_address_setting; -            DnsSetting dns_setting; +            IpAddressSetting ip_address_setting{}; +            DnsSetting dns_setting{};          };          static_assert(sizeof(IpConfigInfo) == sizeof(IpAddressSetting) + sizeof(DnsSetting),                        "IpConfigInfo has incorrect size."); -        IpConfigInfo ip_config_info{ -            .ip_address_setting{ -                .is_automatic{true}, -                .current_address{0, 0, 0, 0}, -                .subnet_mask{255, 255, 255, 0}, -                .gateway{192, 168, 1, 1}, -            }, -            .dns_setting{ -                .is_automatic{true}, -                .primary_dns{1, 1, 1, 1}, -                .secondary_dns{1, 0, 0, 1}, -            }, -        }; +        const auto net_iface = Network::GetSelectedNetworkInterface(); -        const auto iface = Network::GetSelectedNetworkInterface(); -        if (iface) { -            ip_config_info.ip_address_setting = -                IpAddressSetting{.is_automatic{true}, -                                 .current_address{Network::TranslateIPv4(iface->ip_address)}, -                                 .subnet_mask{Network::TranslateIPv4(iface->subnet_mask)}, -                                 .gateway{Network::TranslateIPv4(iface->gateway)}}; +        const IpConfigInfo ip_config_info = [&net_iface] { +            if (!net_iface) { +                return IpConfigInfo{}; +            } -        } else { -            LOG_ERROR(Service_NIFM, -                      "Couldn't get host network configuration info, using default values"); -        } +            return IpConfigInfo{ +                .ip_address_setting{ +                    .is_automatic{true}, +                    .current_address{Network::TranslateIPv4(net_iface->ip_address)}, +                    .subnet_mask{Network::TranslateIPv4(net_iface->subnet_mask)}, +                    .gateway{Network::TranslateIPv4(net_iface->gateway)}, +                }, +                .dns_setting{ +                    .is_automatic{true}, +                    .primary_dns{1, 1, 1, 1}, +                    .secondary_dns{1, 0, 0, 1}, +                }, +            }; +        }();          IPC::ResponseBuilder rb{ctx, 2 + (sizeof(IpConfigInfo) + 3) / sizeof(u32)};          rb.Push(ResultSuccess); diff --git a/src/core/hle/service/nvflinger/buffer_queue.cpp b/src/core/hle/service/nvflinger/buffer_queue.cpp index b4c3a6099..59ddf6298 100644 --- a/src/core/hle/service/nvflinger/buffer_queue.cpp +++ b/src/core/hle/service/nvflinger/buffer_queue.cpp @@ -9,20 +9,17 @@  #include "core/core.h"  #include "core/hle/kernel/k_writable_event.h"  #include "core/hle/kernel/kernel.h" -#include "core/hle/service/kernel_helpers.h"  #include "core/hle/service/nvflinger/buffer_queue.h"  namespace Service::NVFlinger { -BufferQueue::BufferQueue(Kernel::KernelCore& kernel, u32 id_, u64 layer_id_, -                         KernelHelpers::ServiceContext& service_context_) -    : id(id_), layer_id(layer_id_), service_context{service_context_} { -    buffer_wait_event = service_context.CreateEvent("BufferQueue:WaitEvent"); +BufferQueue::BufferQueue(Kernel::KernelCore& kernel, u32 id_, u64 layer_id_) +    : id(id_), layer_id(layer_id_), buffer_wait_event{kernel} { +    Kernel::KAutoObject::Create(std::addressof(buffer_wait_event)); +    buffer_wait_event.Initialize("BufferQueue:WaitEvent");  } -BufferQueue::~BufferQueue() { -    service_context.CloseEvent(buffer_wait_event); -} +BufferQueue::~BufferQueue() = default;  void BufferQueue::SetPreallocatedBuffer(u32 slot, const IGBPBuffer& igbp_buffer) {      ASSERT(slot < buffer_slots); @@ -44,7 +41,7 @@ void BufferQueue::SetPreallocatedBuffer(u32 slot, const IGBPBuffer& igbp_buffer)          .multi_fence = {},      }; -    buffer_wait_event->GetWritableEvent().Signal(); +    buffer_wait_event.GetWritableEvent().Signal();  }  std::optional<std::pair<u32, Service::Nvidia::MultiFence*>> BufferQueue::DequeueBuffer(u32 width, @@ -122,7 +119,7 @@ void BufferQueue::CancelBuffer(u32 slot, const Service::Nvidia::MultiFence& mult      }      free_buffers_condition.notify_one(); -    buffer_wait_event->GetWritableEvent().Signal(); +    buffer_wait_event.GetWritableEvent().Signal();  }  std::optional<std::reference_wrapper<const BufferQueue::Buffer>> BufferQueue::AcquireBuffer() { @@ -157,7 +154,7 @@ void BufferQueue::ReleaseBuffer(u32 slot) {      }      free_buffers_condition.notify_one(); -    buffer_wait_event->GetWritableEvent().Signal(); +    buffer_wait_event.GetWritableEvent().Signal();  }  void BufferQueue::Connect() { @@ -172,7 +169,7 @@ void BufferQueue::Disconnect() {          std::unique_lock lock{queue_sequence_mutex};          queue_sequence.clear();      } -    buffer_wait_event->GetWritableEvent().Signal(); +    buffer_wait_event.GetWritableEvent().Signal();      is_connect = false;      free_buffers_condition.notify_one();  } @@ -192,11 +189,11 @@ u32 BufferQueue::Query(QueryType type) {  }  Kernel::KWritableEvent& BufferQueue::GetWritableBufferWaitEvent() { -    return buffer_wait_event->GetWritableEvent(); +    return buffer_wait_event.GetWritableEvent();  }  Kernel::KReadableEvent& BufferQueue::GetBufferWaitEvent() { -    return buffer_wait_event->GetReadableEvent(); +    return buffer_wait_event.GetReadableEvent();  }  } // namespace Service::NVFlinger diff --git a/src/core/hle/service/nvflinger/buffer_queue.h b/src/core/hle/service/nvflinger/buffer_queue.h index 759247eb0..61e337ac5 100644 --- a/src/core/hle/service/nvflinger/buffer_queue.h +++ b/src/core/hle/service/nvflinger/buffer_queue.h @@ -24,10 +24,6 @@ class KReadableEvent;  class KWritableEvent;  } // namespace Kernel -namespace Service::KernelHelpers { -class ServiceContext; -} // namespace Service::KernelHelpers -  namespace Service::NVFlinger {  constexpr u32 buffer_slots = 0x40; @@ -58,8 +54,7 @@ public:          NativeWindowFormat = 2,      }; -    explicit BufferQueue(Kernel::KernelCore& kernel, u32 id_, u64 layer_id_, -                         KernelHelpers::ServiceContext& service_context_); +    explicit BufferQueue(Kernel::KernelCore& kernel, u32 id_, u64 layer_id_);      ~BufferQueue();      enum class BufferTransformFlags : u32 { @@ -135,14 +130,12 @@ private:      std::list<u32> free_buffers;      std::array<Buffer, buffer_slots> buffers;      std::list<u32> queue_sequence; -    Kernel::KEvent* buffer_wait_event{}; +    Kernel::KEvent buffer_wait_event;      std::mutex free_buffers_mutex;      std::condition_variable free_buffers_condition;      std::mutex queue_sequence_mutex; - -    KernelHelpers::ServiceContext& service_context;  };  } // namespace Service::NVFlinger diff --git a/src/core/hle/service/nvflinger/nvflinger.cpp b/src/core/hle/service/nvflinger/nvflinger.cpp index 00bff8caf..941748970 100644 --- a/src/core/hle/service/nvflinger/nvflinger.cpp +++ b/src/core/hle/service/nvflinger/nvflinger.cpp @@ -61,13 +61,12 @@ void NVFlinger::SplitVSync() {      }  } -NVFlinger::NVFlinger(Core::System& system_) -    : system(system_), service_context(system_, "nvflinger") { -    displays.emplace_back(0, "Default", service_context, system); -    displays.emplace_back(1, "External", service_context, system); -    displays.emplace_back(2, "Edid", service_context, system); -    displays.emplace_back(3, "Internal", service_context, system); -    displays.emplace_back(4, "Null", service_context, system); +NVFlinger::NVFlinger(Core::System& system_) : system(system_) { +    displays.emplace_back(0, "Default", system); +    displays.emplace_back(1, "External", system); +    displays.emplace_back(2, "Edid", system); +    displays.emplace_back(3, "Internal", system); +    displays.emplace_back(4, "Null", system);      guard = std::make_shared<std::mutex>();      // Schedule the screen composition events @@ -147,7 +146,7 @@ std::optional<u64> NVFlinger::CreateLayer(u64 display_id) {  void NVFlinger::CreateLayerAtId(VI::Display& display, u64 layer_id) {      const u32 buffer_queue_id = next_buffer_queue_id++;      buffer_queues.emplace_back( -        std::make_unique<BufferQueue>(system.Kernel(), buffer_queue_id, layer_id, service_context)); +        std::make_unique<BufferQueue>(system.Kernel(), buffer_queue_id, layer_id));      display.CreateLayer(layer_id, *buffer_queues.back());  } diff --git a/src/core/hle/service/nvflinger/nvflinger.h b/src/core/hle/service/nvflinger/nvflinger.h index 6d84cafb4..d80fd07ef 100644 --- a/src/core/hle/service/nvflinger/nvflinger.h +++ b/src/core/hle/service/nvflinger/nvflinger.h @@ -15,7 +15,6 @@  #include <vector>  #include "common/common_types.h" -#include "core/hle/service/kernel_helpers.h"  namespace Common {  class Event; @@ -136,8 +135,6 @@ private:      std::unique_ptr<std::thread> vsync_thread;      std::unique_ptr<Common::Event> wait_event;      std::atomic<bool> is_running{}; - -    KernelHelpers::ServiceContext service_context;  };  } // namespace Service::NVFlinger diff --git a/src/core/hle/service/service.cpp b/src/core/hle/service/service.cpp index b3e50433b..065133166 100644 --- a/src/core/hle/service/service.cpp +++ b/src/core/hle/service/service.cpp @@ -46,6 +46,7 @@  #include "core/hle/service/ncm/ncm.h"  #include "core/hle/service/nfc/nfc.h"  #include "core/hle/service/nfp/nfp.h" +#include "core/hle/service/ngct/ngct.h"  #include "core/hle/service/nifm/nifm.h"  #include "core/hle/service/nim/nim.h"  #include "core/hle/service/npns/npns.h" @@ -271,6 +272,7 @@ Services::Services(std::shared_ptr<SM::ServiceManager>& sm, Core::System& system      NCM::InstallInterfaces(*sm, system);      NFC::InstallInterfaces(*sm, system);      NFP::InstallInterfaces(*sm, system); +    NGCT::InstallInterfaces(*sm, system);      NIFM::InstallInterfaces(*sm, system);      NIM::InstallInterfaces(*sm, system);      NPNS::InstallInterfaces(*sm, system); diff --git a/src/core/hle/service/vi/display/vi_display.cpp b/src/core/hle/service/vi/display/vi_display.cpp index b7705c02a..0dd342dbf 100644 --- a/src/core/hle/service/vi/display/vi_display.cpp +++ b/src/core/hle/service/vi/display/vi_display.cpp @@ -12,21 +12,18 @@  #include "core/hle/kernel/k_event.h"  #include "core/hle/kernel/k_readable_event.h"  #include "core/hle/kernel/k_writable_event.h" -#include "core/hle/service/kernel_helpers.h"  #include "core/hle/service/vi/display/vi_display.h"  #include "core/hle/service/vi/layer/vi_layer.h"  namespace Service::VI { -Display::Display(u64 id, std::string name_, KernelHelpers::ServiceContext& service_context_, -                 Core::System& system_) -    : display_id{id}, name{std::move(name_)}, service_context{service_context_} { -    vsync_event = service_context.CreateEvent(fmt::format("Display VSync Event {}", id)); +Display::Display(u64 id, std::string name_, Core::System& system) +    : display_id{id}, name{std::move(name_)}, vsync_event{system.Kernel()} { +    Kernel::KAutoObject::Create(std::addressof(vsync_event)); +    vsync_event.Initialize(fmt::format("Display VSync Event {}", id));  } -Display::~Display() { -    service_context.CloseEvent(vsync_event); -} +Display::~Display() = default;  Layer& Display::GetLayer(std::size_t index) {      return *layers.at(index); @@ -37,11 +34,11 @@ const Layer& Display::GetLayer(std::size_t index) const {  }  Kernel::KReadableEvent& Display::GetVSyncEvent() { -    return vsync_event->GetReadableEvent(); +    return vsync_event.GetReadableEvent();  }  void Display::SignalVSyncEvent() { -    vsync_event->GetWritableEvent().Signal(); +    vsync_event.GetWritableEvent().Signal();  }  void Display::CreateLayer(u64 layer_id, NVFlinger::BufferQueue& buffer_queue) { diff --git a/src/core/hle/service/vi/display/vi_display.h b/src/core/hle/service/vi/display/vi_display.h index 0979fc421..166f2a4cc 100644 --- a/src/core/hle/service/vi/display/vi_display.h +++ b/src/core/hle/service/vi/display/vi_display.h @@ -18,9 +18,6 @@ class KEvent;  namespace Service::NVFlinger {  class BufferQueue;  } -namespace Service::KernelHelpers { -class ServiceContext; -} // namespace Service::KernelHelpers  namespace Service::VI { @@ -34,13 +31,10 @@ class Display {  public:      /// Constructs a display with a given unique ID and name.      /// -    /// @param id The unique ID for this display. -    /// @param service_context_ The ServiceContext for the owning service. +    /// @param id   The unique ID for this display.      /// @param name_ The name for this display. -    /// @param system_ The global system instance.      /// -    Display(u64 id, std::string name_, KernelHelpers::ServiceContext& service_context_, -            Core::System& system_); +    Display(u64 id, std::string name_, Core::System& system);      ~Display();      /// Gets the unique ID assigned to this display. @@ -104,10 +98,9 @@ public:  private:      u64 display_id;      std::string name; -    KernelHelpers::ServiceContext& service_context;      std::vector<std::shared_ptr<Layer>> layers; -    Kernel::KEvent* vsync_event{}; +    Kernel::KEvent vsync_event;  };  } // namespace Service::VI diff --git a/src/core/network/network_interface.cpp b/src/core/network/network_interface.cpp index cecc9aa11..6811f21b1 100644 --- a/src/core/network/network_interface.cpp +++ b/src/core/network/network_interface.cpp @@ -37,73 +37,73 @@ std::vector<NetworkInterface> GetAvailableNetworkInterfaces() {              AF_INET, GAA_FLAG_SKIP_MULTICAST | GAA_FLAG_SKIP_DNS_SERVER | GAA_FLAG_INCLUDE_GATEWAYS,              nullptr, adapter_addresses.data(), &buf_size); -        if (ret == ERROR_BUFFER_OVERFLOW) { -            adapter_addresses.resize((buf_size / sizeof(IP_ADAPTER_ADDRESSES)) + 1); -        } else { +        if (ret != ERROR_BUFFER_OVERFLOW) {              break;          } + +        adapter_addresses.resize((buf_size / sizeof(IP_ADAPTER_ADDRESSES)) + 1);      } -    if (ret == NO_ERROR) { -        std::vector<NetworkInterface> result; +    if (ret != NO_ERROR) { +        LOG_ERROR(Network, "Failed to get network interfaces with GetAdaptersAddresses"); +        return {}; +    } -        for (auto current_address = adapter_addresses.data(); current_address != nullptr; -             current_address = current_address->Next) { -            if (current_address->FirstUnicastAddress == nullptr || -                current_address->FirstUnicastAddress->Address.lpSockaddr == nullptr) { -                continue; -            } +    std::vector<NetworkInterface> result; -            if (current_address->OperStatus != IfOperStatusUp) { -                continue; -            } +    for (auto current_address = adapter_addresses.data(); current_address != nullptr; +         current_address = current_address->Next) { +        if (current_address->FirstUnicastAddress == nullptr || +            current_address->FirstUnicastAddress->Address.lpSockaddr == nullptr) { +            continue; +        } -            const auto ip_addr = Common::BitCast<struct sockaddr_in>( -                                     *current_address->FirstUnicastAddress->Address.lpSockaddr) -                                     .sin_addr; +        if (current_address->OperStatus != IfOperStatusUp) { +            continue; +        } -            ULONG mask = 0; -            if (ConvertLengthToIpv4Mask(current_address->FirstUnicastAddress->OnLinkPrefixLength, -                                        &mask) != NO_ERROR) { -                LOG_ERROR(Network, "Failed to convert IPv4 prefix length to subnet mask"); -                continue; -            } +        const auto ip_addr = Common::BitCast<struct sockaddr_in>( +                                 *current_address->FirstUnicastAddress->Address.lpSockaddr) +                                 .sin_addr; -            struct in_addr gateway = {.S_un{.S_addr{0}}}; -            if (current_address->FirstGatewayAddress != nullptr && -                current_address->FirstGatewayAddress->Address.lpSockaddr != nullptr) { -                gateway = Common::BitCast<struct sockaddr_in>( -                              *current_address->FirstGatewayAddress->Address.lpSockaddr) -                              .sin_addr; -            } +        ULONG mask = 0; +        if (ConvertLengthToIpv4Mask(current_address->FirstUnicastAddress->OnLinkPrefixLength, +                                    &mask) != NO_ERROR) { +            LOG_ERROR(Network, "Failed to convert IPv4 prefix length to subnet mask"); +            continue; +        } -            result.push_back(NetworkInterface{ -                .name{Common::UTF16ToUTF8(std::wstring{current_address->FriendlyName})}, -                .ip_address{ip_addr}, -                .subnet_mask = in_addr{.S_un{.S_addr{mask}}}, -                .gateway = gateway}); +        struct in_addr gateway = {.S_un{.S_addr{0}}}; +        if (current_address->FirstGatewayAddress != nullptr && +            current_address->FirstGatewayAddress->Address.lpSockaddr != nullptr) { +            gateway = Common::BitCast<struct sockaddr_in>( +                          *current_address->FirstGatewayAddress->Address.lpSockaddr) +                          .sin_addr;          } -        return result; -    } else { -        LOG_ERROR(Network, "Failed to get network interfaces with GetAdaptersAddresses"); -        return {}; +        result.emplace_back(NetworkInterface{ +            .name{Common::UTF16ToUTF8(std::wstring{current_address->FriendlyName})}, +            .ip_address{ip_addr}, +            .subnet_mask = in_addr{.S_un{.S_addr{mask}}}, +            .gateway = gateway});      } + +    return result;  }  #else  std::vector<NetworkInterface> GetAvailableNetworkInterfaces() { -    std::vector<NetworkInterface> result; -      struct ifaddrs* ifaddr = nullptr;      if (getifaddrs(&ifaddr) != 0) {          LOG_ERROR(Network, "Failed to get network interfaces with getifaddrs: {}",                    std::strerror(errno)); -        return result; +        return {};      } +    std::vector<NetworkInterface> result; +      for (auto ifa = ifaddr; ifa != nullptr; ifa = ifa->ifa_next) {          if (ifa->ifa_addr == nullptr || ifa->ifa_netmask == nullptr) {              continue; @@ -117,55 +117,62 @@ std::vector<NetworkInterface> GetAvailableNetworkInterfaces() {              continue;          } -        std::uint32_t gateway{0}; +        u32 gateway{}; +          std::ifstream file{"/proc/net/route"}; -        if (file.is_open()) { +        if (!file.is_open()) { +            LOG_ERROR(Network, "Failed to open \"/proc/net/route\""); -            // ignore header -            file.ignore(std::numeric_limits<std::streamsize>::max(), '\n'); +            result.emplace_back(NetworkInterface{ +                .name{ifa->ifa_name}, +                .ip_address{Common::BitCast<struct sockaddr_in>(*ifa->ifa_addr).sin_addr}, +                .subnet_mask{Common::BitCast<struct sockaddr_in>(*ifa->ifa_netmask).sin_addr}, +                .gateway{in_addr{.s_addr = gateway}}}); +            continue; +        } -            bool gateway_found = false; +        // ignore header +        file.ignore(std::numeric_limits<std::streamsize>::max(), '\n'); -            for (std::string line; std::getline(file, line);) { -                std::istringstream iss{line}; +        bool gateway_found = false; -                std::string iface_name{}; -                iss >> iface_name; -                if (iface_name != ifa->ifa_name) { -                    continue; -                } +        for (std::string line; std::getline(file, line);) { +            std::istringstream iss{line}; -                iss >> std::hex; +            std::string iface_name; +            iss >> iface_name; +            if (iface_name != ifa->ifa_name) { +                continue; +            } -                std::uint32_t dest{0}; -                iss >> dest; -                if (dest != 0) { -                    // not the default route -                    continue; -                } +            iss >> std::hex; -                iss >> gateway; +            u32 dest{}; +            iss >> dest; +            if (dest != 0) { +                // not the default route +                continue; +            } -                std::uint16_t flags{0}; -                iss >> flags; +            iss >> gateway; -                // flag RTF_GATEWAY (defined in <linux/route.h>) -                if ((flags & 0x2) == 0) { -                    continue; -                } +            u16 flags{}; +            iss >> flags; -                gateway_found = true; -                break; +            // flag RTF_GATEWAY (defined in <linux/route.h>) +            if ((flags & 0x2) == 0) { +                continue;              } -            if (!gateway_found) { -                gateway = 0; -            } -        } else { -            LOG_ERROR(Network, "Failed to open \"/proc/net/route\""); +            gateway_found = true; +            break;          } -        result.push_back(NetworkInterface{ +        if (!gateway_found) { +            gateway = 0; +        } + +        result.emplace_back(NetworkInterface{              .name{ifa->ifa_name},              .ip_address{Common::BitCast<struct sockaddr_in>(*ifa->ifa_addr).sin_addr},              .subnet_mask{Common::BitCast<struct sockaddr_in>(*ifa->ifa_netmask).sin_addr}, @@ -180,11 +187,11 @@ std::vector<NetworkInterface> GetAvailableNetworkInterfaces() {  #endif  std::optional<NetworkInterface> GetSelectedNetworkInterface() { -    const std::string& selected_network_interface = Settings::values.network_interface.GetValue(); +    const auto& selected_network_interface = Settings::values.network_interface.GetValue();      const auto network_interfaces = Network::GetAvailableNetworkInterfaces();      if (network_interfaces.size() == 0) {          LOG_ERROR(Network, "GetAvailableNetworkInterfaces returned no interfaces"); -        return {}; +        return std::nullopt;      }      const auto res = @@ -192,12 +199,12 @@ std::optional<NetworkInterface> GetSelectedNetworkInterface() {              return iface.name == selected_network_interface;          }); -    if (res != network_interfaces.end()) { -        return *res; -    } else { +    if (res == network_interfaces.end()) {          LOG_ERROR(Network, "Couldn't find selected interface \"{}\"", selected_network_interface); -        return {}; +        return std::nullopt;      } + +    return *res;  }  } // namespace Network diff --git a/src/video_core/command_classes/codecs/vp9.cpp b/src/video_core/command_classes/codecs/vp9.cpp index 70030066a..d7e749485 100644 --- a/src/video_core/command_classes/codecs/vp9.cpp +++ b/src/video_core/command_classes/codecs/vp9.cpp @@ -742,6 +742,7 @@ VpxBitStreamWriter VP9::ComposeUncompressedHeader() {      uncomp_writer.WriteDeltaQ(current_frame_info.uv_dc_delta_q);      uncomp_writer.WriteDeltaQ(current_frame_info.uv_ac_delta_q); +    ASSERT(!current_frame_info.segment_enabled);      uncomp_writer.WriteBit(false); // Segmentation enabled (TODO).      const s32 min_tile_cols_log2 = CalcMinLog2TileCols(current_frame_info.frame_size.width); diff --git a/src/video_core/command_classes/codecs/vp9_types.h b/src/video_core/command_classes/codecs/vp9_types.h index 87eafdb03..3b1ed4b3a 100644 --- a/src/video_core/command_classes/codecs/vp9_types.h +++ b/src/video_core/command_classes/codecs/vp9_types.h @@ -22,7 +22,7 @@ struct Vp9FrameDimensions {  };  static_assert(sizeof(Vp9FrameDimensions) == 0x8, "Vp9 Vp9FrameDimensions is an invalid size"); -enum FrameFlags : u32 { +enum class FrameFlags : u32 {      IsKeyFrame = 1 << 0,      LastFrameIsKeyFrame = 1 << 1,      FrameSizeChanged = 1 << 2, @@ -30,6 +30,7 @@ enum FrameFlags : u32 {      LastShowFrame = 1 << 4,      IntraOnly = 1 << 5,  }; +DECLARE_ENUM_FLAG_OPERATORS(FrameFlags)  enum class TxSize {      Tx4x4 = 0,   // 4x4 transform @@ -92,44 +93,34 @@ struct Vp9EntropyProbs {  static_assert(sizeof(Vp9EntropyProbs) == 0x7B4, "Vp9EntropyProbs is an invalid size");  struct Vp9PictureInfo { -    bool is_key_frame; -    bool intra_only; -    bool last_frame_was_key; -    bool frame_size_changed; -    bool error_resilient_mode; -    bool last_frame_shown; -    bool show_frame; +    u32 bitstream_size; +    std::array<u64, 4> frame_offsets;      std::array<s8, 4> ref_frame_sign_bias;      s32 base_q_index;      s32 y_dc_delta_q;      s32 uv_dc_delta_q;      s32 uv_ac_delta_q; -    bool lossless;      s32 transform_mode; -    bool allow_high_precision_mv;      s32 interp_filter;      s32 reference_mode; -    s8 comp_fixed_ref; -    std::array<s8, 2> comp_var_ref;      s32 log2_tile_cols;      s32 log2_tile_rows; -    bool segment_enabled; -    bool segment_map_update; -    bool segment_map_temporal_update; -    s32 segment_abs_delta; -    std::array<u32, 8> segment_feature_enable; -    std::array<std::array<s16, 4>, 8> segment_feature_data; -    bool mode_ref_delta_enabled; -    bool use_prev_in_find_mv_refs;      std::array<s8, 4> ref_deltas;      std::array<s8, 2> mode_deltas;      Vp9EntropyProbs entropy;      Vp9FrameDimensions frame_size;      u8 first_level;      u8 sharpness_level; -    u32 bitstream_size; -    std::array<u64, 4> frame_offsets; -    std::array<bool, 4> refresh_frame; +    bool is_key_frame; +    bool intra_only; +    bool last_frame_was_key; +    bool error_resilient_mode; +    bool last_frame_shown; +    bool show_frame; +    bool lossless; +    bool allow_high_precision_mv; +    bool segment_enabled; +    bool mode_ref_delta_enabled;  };  struct Vp9FrameContainer { @@ -145,7 +136,7 @@ struct PictureInfo {      Vp9FrameDimensions golden_frame_size;  ///< 0x50      Vp9FrameDimensions alt_frame_size;     ///< 0x58      Vp9FrameDimensions current_frame_size; ///< 0x60 -    u32 vp9_flags;                         ///< 0x68 +    FrameFlags vp9_flags;                  ///< 0x68      std::array<s8, 4> ref_frame_sign_bias; ///< 0x6C      u8 first_level;                        ///< 0x70      u8 sharpness_level;                    ///< 0x71 @@ -158,60 +149,43 @@ struct PictureInfo {      u8 allow_high_precision_mv;            ///< 0x78      u8 interp_filter;                      ///< 0x79      u8 reference_mode;                     ///< 0x7A -    s8 comp_fixed_ref;                     ///< 0x7B -    std::array<s8, 2> comp_var_ref;        ///< 0x7C +    INSERT_PADDING_BYTES_NOINIT(3);        ///< 0x7B      u8 log2_tile_cols;                     ///< 0x7E      u8 log2_tile_rows;                     ///< 0x7F      Segmentation segmentation;             ///< 0x80      LoopFilter loop_filter;                ///< 0xE4 -    INSERT_PADDING_BYTES_NOINIT(5);        ///< 0xEB -    u32 surface_params;                    ///< 0xF0 -    INSERT_PADDING_WORDS_NOINIT(3);        ///< 0xF4 +    INSERT_PADDING_BYTES_NOINIT(21);       ///< 0xEB      [[nodiscard]] Vp9PictureInfo Convert() const {          return { -            .is_key_frame = (vp9_flags & FrameFlags::IsKeyFrame) != 0, -            .intra_only = (vp9_flags & FrameFlags::IntraOnly) != 0, -            .last_frame_was_key = (vp9_flags & FrameFlags::LastFrameIsKeyFrame) != 0, -            .frame_size_changed = (vp9_flags & FrameFlags::FrameSizeChanged) != 0, -            .error_resilient_mode = (vp9_flags & FrameFlags::ErrorResilientMode) != 0, -            .last_frame_shown = (vp9_flags & FrameFlags::LastShowFrame) != 0, -            .show_frame = true, +            .bitstream_size = bitstream_size, +            .frame_offsets{},              .ref_frame_sign_bias = ref_frame_sign_bias,              .base_q_index = base_q_index,              .y_dc_delta_q = y_dc_delta_q,              .uv_dc_delta_q = uv_dc_delta_q,              .uv_ac_delta_q = uv_ac_delta_q, -            .lossless = lossless != 0,              .transform_mode = tx_mode, -            .allow_high_precision_mv = allow_high_precision_mv != 0,              .interp_filter = interp_filter,              .reference_mode = reference_mode, -            .comp_fixed_ref = comp_fixed_ref, -            .comp_var_ref = comp_var_ref,              .log2_tile_cols = log2_tile_cols,              .log2_tile_rows = log2_tile_rows, -            .segment_enabled = segmentation.enabled != 0, -            .segment_map_update = segmentation.update_map != 0, -            .segment_map_temporal_update = segmentation.temporal_update != 0, -            .segment_abs_delta = segmentation.abs_delta, -            .segment_feature_enable = segmentation.feature_mask, -            .segment_feature_data = segmentation.feature_data, -            .mode_ref_delta_enabled = loop_filter.mode_ref_delta_enabled != 0, -            .use_prev_in_find_mv_refs = !(vp9_flags == (FrameFlags::ErrorResilientMode)) && -                                        !(vp9_flags == (FrameFlags::FrameSizeChanged)) && -                                        !(vp9_flags == (FrameFlags::IntraOnly)) && -                                        (vp9_flags == (FrameFlags::LastShowFrame)) && -                                        !(vp9_flags == (FrameFlags::LastFrameIsKeyFrame)),              .ref_deltas = loop_filter.ref_deltas,              .mode_deltas = loop_filter.mode_deltas,              .entropy{},              .frame_size = current_frame_size,              .first_level = first_level,              .sharpness_level = sharpness_level, -            .bitstream_size = bitstream_size, -            .frame_offsets{}, -            .refresh_frame{}, +            .is_key_frame = True(vp9_flags & FrameFlags::IsKeyFrame), +            .intra_only = True(vp9_flags & FrameFlags::IntraOnly), +            .last_frame_was_key = True(vp9_flags & FrameFlags::LastFrameIsKeyFrame), +            .error_resilient_mode = True(vp9_flags & FrameFlags::ErrorResilientMode), +            .last_frame_shown = True(vp9_flags & FrameFlags::LastShowFrame), +            .show_frame = true, +            .lossless = lossless != 0, +            .allow_high_precision_mv = allow_high_precision_mv != 0, +            .segment_enabled = segmentation.enabled != 0, +            .mode_ref_delta_enabled = loop_filter.mode_ref_delta_enabled != 0,          };      }  }; @@ -316,7 +290,6 @@ ASSERT_POSITION(last_frame_size, 0x48);  ASSERT_POSITION(first_level, 0x70);  ASSERT_POSITION(segmentation, 0x80);  ASSERT_POSITION(loop_filter, 0xE4); -ASSERT_POSITION(surface_params, 0xF0);  #undef ASSERT_POSITION  #define ASSERT_POSITION(field_name, position)                                                      \ diff --git a/src/video_core/renderer_vulkan/vk_blit_screen.cpp b/src/video_core/renderer_vulkan/vk_blit_screen.cpp index 5c43b8acf..cb0580182 100644 --- a/src/video_core/renderer_vulkan/vk_blit_screen.cpp +++ b/src/video_core/renderer_vulkan/vk_blit_screen.cpp @@ -159,11 +159,13 @@ VkSemaphore VKBlitScreen::Draw(const Tegra::FramebufferConfig& framebuffer,          const VAddr framebuffer_addr = framebuffer.address + framebuffer.offset;          const u8* const host_ptr = cpu_memory.GetPointer(framebuffer_addr); -        const size_t size_bytes = GetSizeInBytes(framebuffer);          // TODO(Rodrigo): Read this from HLE          constexpr u32 block_height_log2 = 4;          const u32 bytes_per_pixel = GetBytesPerPixel(framebuffer); +        const u64 size_bytes{Tegra::Texture::CalculateSize(true, bytes_per_pixel, +                                                           framebuffer.stride, framebuffer.height, +                                                           1, block_height_log2, 0)};          Tegra::Texture::UnswizzleTexture(              mapped_span.subspan(image_offset, size_bytes), std::span(host_ptr, size_bytes),              bytes_per_pixel, framebuffer.width, framebuffer.height, 1, block_height_log2, 0); diff --git a/src/video_core/textures/decoders.cpp b/src/video_core/textures/decoders.cpp index c010b9353..24e943e4c 100644 --- a/src/video_core/textures/decoders.cpp +++ b/src/video_core/textures/decoders.cpp @@ -63,14 +63,6 @@ void SwizzleImpl(std::span<u8> output, std::span<const u8> input, u32 width, u32                  const u32 unswizzled_offset =                      slice * pitch * height + line * pitch + column * BYTES_PER_PIXEL; -                if (const auto offset = (TO_LINEAR ? unswizzled_offset : swizzled_offset); -                    offset >= input.size()) { -                    // TODO(Rodrigo): This is an out of bounds access that should never happen. To -                    // avoid crashing the emulator, break. -                    ASSERT_MSG(false, "offset {} exceeds input size {}!", offset, input.size()); -                    break; -                } -                  u8* const dst = &output[TO_LINEAR ? swizzled_offset : unswizzled_offset];                  const u8* const src = &input[TO_LINEAR ? unswizzled_offset : swizzled_offset]; | 
