diff options
| -rw-r--r-- | src/core/file_sys/partition_filesystem.cpp | 2 | ||||
| -rw-r--r-- | src/core/file_sys/vfs_offset.cpp | 6 | ||||
| -rw-r--r-- | src/core/file_sys/vfs_offset.h | 2 | ||||
| -rw-r--r-- | src/core/hle/kernel/address_arbiter.cpp | 4 | ||||
| -rw-r--r-- | src/core/hle/kernel/hle_ipc.cpp | 4 | ||||
| -rw-r--r-- | src/core/hle/kernel/mutex.cpp | 6 | ||||
| -rw-r--r-- | src/core/hle/kernel/scheduler.cpp | 16 | ||||
| -rw-r--r-- | src/core/hle/kernel/server_session.cpp | 4 | ||||
| -rw-r--r-- | src/core/hle/kernel/svc.cpp | 20 | ||||
| -rw-r--r-- | src/core/hle/kernel/thread.cpp | 47 | ||||
| -rw-r--r-- | src/core/hle/kernel/thread.h | 28 | ||||
| -rw-r--r-- | src/core/hle/kernel/wait_object.cpp | 12 | ||||
| -rw-r--r-- | src/core/hle/service/audio/audout_u.cpp | 3 | ||||
| -rw-r--r-- | src/core/hle/service/audio/audren_u.cpp | 6 | ||||
| -rw-r--r-- | src/core/hle/service/ns/pl_u.cpp | 6 | ||||
| -rw-r--r-- | src/core/loader/nca.cpp | 3 | ||||
| -rw-r--r-- | src/core/loader/nro.cpp | 3 | ||||
| -rw-r--r-- | src/core/loader/nso.cpp | 23 | ||||
| -rw-r--r-- | src/video_core/engines/maxwell_3d.cpp | 2 | ||||
| -rw-r--r-- | src/video_core/renderer_opengl/gl_shader_decompiler.cpp | 14 | ||||
| -rw-r--r-- | src/yuzu/debugger/wait_tree.cpp | 44 | 
21 files changed, 123 insertions, 132 deletions
| diff --git a/src/core/file_sys/partition_filesystem.cpp b/src/core/file_sys/partition_filesystem.cpp index d4097a510..7ccca1089 100644 --- a/src/core/file_sys/partition_filesystem.cpp +++ b/src/core/file_sys/partition_filesystem.cpp @@ -76,7 +76,7 @@ std::vector<std::shared_ptr<VfsFile>> PartitionFilesystem::GetFiles() const {  }  std::vector<std::shared_ptr<VfsDirectory>> PartitionFilesystem::GetSubdirectories() const { -    return {}; +    return pfs_dirs;  }  std::string PartitionFilesystem::GetName() const { diff --git a/src/core/file_sys/vfs_offset.cpp b/src/core/file_sys/vfs_offset.cpp index 288499cb5..31fdd9aa1 100644 --- a/src/core/file_sys/vfs_offset.cpp +++ b/src/core/file_sys/vfs_offset.cpp @@ -2,13 +2,15 @@  // Licensed under GPLv2 or any later version  // Refer to the license.txt file included. +#include <utility> +  #include "core/file_sys/vfs_offset.h"  namespace FileSys {  OffsetVfsFile::OffsetVfsFile(std::shared_ptr<VfsFile> file_, size_t size_, size_t offset_, -                             const std::string& name_) -    : file(file_), offset(offset_), size(size_), name(name_) {} +                             std::string name_) +    : file(std::move(file_)), offset(offset_), size(size_), name(std::move(name_)) {}  std::string OffsetVfsFile::GetName() const {      return name.empty() ? file->GetName() : name; diff --git a/src/core/file_sys/vfs_offset.h b/src/core/file_sys/vfs_offset.h index adc615b38..2e16e47eb 100644 --- a/src/core/file_sys/vfs_offset.h +++ b/src/core/file_sys/vfs_offset.h @@ -14,7 +14,7 @@ namespace FileSys {  // the size of this wrapper.  struct OffsetVfsFile : public VfsFile {      OffsetVfsFile(std::shared_ptr<VfsFile> file, size_t size, size_t offset = 0, -                  const std::string& new_name = ""); +                  std::string new_name = "");      std::string GetName() const override;      size_t GetSize() const override; diff --git a/src/core/hle/kernel/address_arbiter.cpp b/src/core/hle/kernel/address_arbiter.cpp index dcc68aabf..233fdab25 100644 --- a/src/core/hle/kernel/address_arbiter.cpp +++ b/src/core/hle/kernel/address_arbiter.cpp @@ -20,7 +20,7 @@ namespace AddressArbiter {  static ResultCode WaitForAddress(VAddr address, s64 timeout) {      SharedPtr<Thread> current_thread = GetCurrentThread();      current_thread->arb_wait_address = address; -    current_thread->status = THREADSTATUS_WAIT_ARB; +    current_thread->status = ThreadStatus::WaitArb;      current_thread->wakeup_callback = nullptr;      current_thread->WakeAfterDelay(timeout); @@ -65,7 +65,7 @@ static void WakeThreads(std::vector<SharedPtr<Thread>>& waiting_threads, s32 num      // Signal the waiting threads.      for (size_t i = 0; i < last; i++) { -        ASSERT(waiting_threads[i]->status == THREADSTATUS_WAIT_ARB); +        ASSERT(waiting_threads[i]->status == ThreadStatus::WaitArb);          waiting_threads[i]->SetWaitSynchronizationResult(RESULT_SUCCESS);          waiting_threads[i]->arb_wait_address = 0;          waiting_threads[i]->ResumeFromWait(); diff --git a/src/core/hle/kernel/hle_ipc.cpp b/src/core/hle/kernel/hle_ipc.cpp index 8f40bdd5a..f24392520 100644 --- a/src/core/hle/kernel/hle_ipc.cpp +++ b/src/core/hle/kernel/hle_ipc.cpp @@ -38,7 +38,7 @@ SharedPtr<Event> HLERequestContext::SleepClientThread(SharedPtr<Thread> thread,      thread->wakeup_callback =          [context = *this, callback](ThreadWakeupReason reason, SharedPtr<Thread> thread,                                      SharedPtr<WaitObject> object, size_t index) mutable -> bool { -        ASSERT(thread->status == THREADSTATUS_WAIT_HLE_EVENT); +        ASSERT(thread->status == ThreadStatus::WaitHLEEvent);          callback(thread, context, reason);          context.WriteToOutgoingCommandBuffer(*thread);          return true; @@ -50,7 +50,7 @@ SharedPtr<Event> HLERequestContext::SleepClientThread(SharedPtr<Thread> thread,      }      event->Clear(); -    thread->status = THREADSTATUS_WAIT_HLE_EVENT; +    thread->status = ThreadStatus::WaitHLEEvent;      thread->wait_objects = {event};      event->AddWaitingThread(thread); diff --git a/src/core/hle/kernel/mutex.cpp b/src/core/hle/kernel/mutex.cpp index 65560226d..3f1de3258 100644 --- a/src/core/hle/kernel/mutex.cpp +++ b/src/core/hle/kernel/mutex.cpp @@ -28,7 +28,7 @@ static std::pair<SharedPtr<Thread>, u32> GetHighestPriorityMutexWaitingThread(          if (thread->mutex_wait_address != mutex_addr)              continue; -        ASSERT(thread->status == THREADSTATUS_WAIT_MUTEX); +        ASSERT(thread->status == ThreadStatus::WaitMutex);          ++num_waiters;          if (highest_priority_thread == nullptr || @@ -83,7 +83,7 @@ ResultCode Mutex::TryAcquire(VAddr address, Handle holding_thread_handle,      GetCurrentThread()->mutex_wait_address = address;      GetCurrentThread()->wait_handle = requesting_thread_handle; -    GetCurrentThread()->status = THREADSTATUS_WAIT_MUTEX; +    GetCurrentThread()->status = ThreadStatus::WaitMutex;      GetCurrentThread()->wakeup_callback = nullptr;      // Update the lock holder thread's priority to prevent priority inversion. @@ -121,7 +121,7 @@ ResultCode Mutex::Release(VAddr address) {      // Grant the mutex to the next waiting thread and resume it.      Memory::Write32(address, mutex_value); -    ASSERT(thread->status == THREADSTATUS_WAIT_MUTEX); +    ASSERT(thread->status == ThreadStatus::WaitMutex);      thread->ResumeFromWait();      thread->lock_owner = nullptr; diff --git a/src/core/hle/kernel/scheduler.cpp b/src/core/hle/kernel/scheduler.cpp index 1f4abfbe8..f7e25cbf5 100644 --- a/src/core/hle/kernel/scheduler.cpp +++ b/src/core/hle/kernel/scheduler.cpp @@ -34,7 +34,7 @@ Thread* Scheduler::PopNextReadyThread() {      Thread* next = nullptr;      Thread* thread = GetCurrentThread(); -    if (thread && thread->status == THREADSTATUS_RUNNING) { +    if (thread && thread->status == ThreadStatus::Running) {          // We have to do better than the current thread.          // This call returns null when that's not possible.          next = ready_queue.pop_first_better(thread->current_priority); @@ -57,17 +57,17 @@ void Scheduler::SwitchContext(Thread* new_thread) {          previous_thread->last_running_ticks = CoreTiming::GetTicks();          cpu_core->SaveContext(previous_thread->context); -        if (previous_thread->status == THREADSTATUS_RUNNING) { +        if (previous_thread->status == ThreadStatus::Running) {              // This is only the case when a reschedule is triggered without the current thread              // yielding execution (i.e. an event triggered, system core time-sliced, etc)              ready_queue.push_front(previous_thread->current_priority, previous_thread); -            previous_thread->status = THREADSTATUS_READY; +            previous_thread->status = ThreadStatus::Ready;          }      }      // Load context of new thread      if (new_thread) { -        ASSERT_MSG(new_thread->status == THREADSTATUS_READY, +        ASSERT_MSG(new_thread->status == ThreadStatus::Ready,                     "Thread must be ready to become running.");          // Cancel any outstanding wakeup events for this thread @@ -78,7 +78,7 @@ void Scheduler::SwitchContext(Thread* new_thread) {          current_thread = new_thread;          ready_queue.remove(new_thread->current_priority, new_thread); -        new_thread->status = THREADSTATUS_RUNNING; +        new_thread->status = ThreadStatus::Running;          if (previous_process != current_thread->owner_process) {              Core::CurrentProcess() = current_thread->owner_process; @@ -129,14 +129,14 @@ void Scheduler::RemoveThread(Thread* thread) {  void Scheduler::ScheduleThread(Thread* thread, u32 priority) {      std::lock_guard<std::mutex> lock(scheduler_mutex); -    ASSERT(thread->status == THREADSTATUS_READY); +    ASSERT(thread->status == ThreadStatus::Ready);      ready_queue.push_back(priority, thread);  }  void Scheduler::UnscheduleThread(Thread* thread, u32 priority) {      std::lock_guard<std::mutex> lock(scheduler_mutex); -    ASSERT(thread->status == THREADSTATUS_READY); +    ASSERT(thread->status == ThreadStatus::Ready);      ready_queue.remove(priority, thread);  } @@ -144,7 +144,7 @@ void Scheduler::SetThreadPriority(Thread* thread, u32 priority) {      std::lock_guard<std::mutex> lock(scheduler_mutex);      // If thread was ready, adjust queues -    if (thread->status == THREADSTATUS_READY) +    if (thread->status == ThreadStatus::Ready)          ready_queue.move(thread, thread->current_priority, priority);      else          ready_queue.prepare(priority); diff --git a/src/core/hle/kernel/server_session.cpp b/src/core/hle/kernel/server_session.cpp index 19d17af4f..29b163528 100644 --- a/src/core/hle/kernel/server_session.cpp +++ b/src/core/hle/kernel/server_session.cpp @@ -110,10 +110,10 @@ ResultCode ServerSession::HandleSyncRequest(SharedPtr<Thread> thread) {          result = hle_handler->HandleSyncRequest(context);      } -    if (thread->status == THREADSTATUS_RUNNING) { +    if (thread->status == ThreadStatus::Running) {          // Put the thread to sleep until the server replies, it will be awoken in          // svcReplyAndReceive for LLE servers. -        thread->status = THREADSTATUS_WAIT_IPC; +        thread->status = ThreadStatus::WaitIPC;          if (hle_handler != nullptr) {              // For HLE services, we put the request threads to sleep for a short duration to diff --git a/src/core/hle/kernel/svc.cpp b/src/core/hle/kernel/svc.cpp index c6b0bb442..6b2995fe2 100644 --- a/src/core/hle/kernel/svc.cpp +++ b/src/core/hle/kernel/svc.cpp @@ -133,7 +133,7 @@ static ResultCode GetProcessId(u32* process_id, Handle process_handle) {  /// Default thread wakeup callback for WaitSynchronization  static bool DefaultThreadWakeupCallback(ThreadWakeupReason reason, SharedPtr<Thread> thread,                                          SharedPtr<WaitObject> object, size_t index) { -    ASSERT(thread->status == THREADSTATUS_WAIT_SYNCH_ANY); +    ASSERT(thread->status == ThreadStatus::WaitSynchAny);      if (reason == ThreadWakeupReason::Timeout) {          thread->SetWaitSynchronizationResult(RESULT_TIMEOUT); @@ -197,7 +197,7 @@ static ResultCode WaitSynchronization(Handle* index, VAddr handles_address, u64          object->AddWaitingThread(thread);      thread->wait_objects = std::move(objects); -    thread->status = THREADSTATUS_WAIT_SYNCH_ANY; +    thread->status = ThreadStatus::WaitSynchAny;      // Create an event to wake the thread up after the specified nanosecond delay has passed      thread->WakeAfterDelay(nano_seconds); @@ -217,7 +217,7 @@ static ResultCode CancelSynchronization(Handle thread_handle) {          return ERR_INVALID_HANDLE;      } -    ASSERT(thread->status == THREADSTATUS_WAIT_SYNCH_ANY); +    ASSERT(thread->status == ThreadStatus::WaitSynchAny);      thread->SetWaitSynchronizationResult(          ResultCode(ErrorModule::Kernel, ErrCodes::SynchronizationCanceled));      thread->ResumeFromWait(); @@ -468,8 +468,8 @@ static void ExitProcess() {                  continue;              // TODO(Subv): When are the other running/ready threads terminated? -            ASSERT_MSG(thread->status == THREADSTATUS_WAIT_SYNCH_ANY || -                           thread->status == THREADSTATUS_WAIT_SYNCH_ALL, +            ASSERT_MSG(thread->status == ThreadStatus::WaitSynchAny || +                           thread->status == ThreadStatus::WaitSynchAll,                         "Exiting processes with non-waiting threads is currently unimplemented");              thread->Stop(); @@ -545,7 +545,7 @@ static ResultCode StartThread(Handle thread_handle) {          return ERR_INVALID_HANDLE;      } -    ASSERT(thread->status == THREADSTATUS_DORMANT); +    ASSERT(thread->status == ThreadStatus::Dormant);      thread->ResumeFromWait();      Core::System::GetInstance().CpuCore(thread->processor_id).PrepareReschedule(); @@ -596,7 +596,7 @@ static ResultCode WaitProcessWideKeyAtomic(VAddr mutex_addr, VAddr condition_var      current_thread->condvar_wait_address = condition_variable_addr;      current_thread->mutex_wait_address = mutex_addr;      current_thread->wait_handle = thread_handle; -    current_thread->status = THREADSTATUS_WAIT_MUTEX; +    current_thread->status = ThreadStatus::WaitMutex;      current_thread->wakeup_callback = nullptr;      current_thread->WakeAfterDelay(nano_seconds); @@ -656,7 +656,7 @@ static ResultCode SignalProcessWideKey(VAddr condition_variable_addr, s32 target          if (mutex_val == 0) {              // We were able to acquire the mutex, resume this thread.              Memory::Write32(thread->mutex_wait_address, thread->wait_handle); -            ASSERT(thread->status == THREADSTATUS_WAIT_MUTEX); +            ASSERT(thread->status == ThreadStatus::WaitMutex);              thread->ResumeFromWait();              auto lock_owner = thread->lock_owner; @@ -672,8 +672,8 @@ static ResultCode SignalProcessWideKey(VAddr condition_variable_addr, s32 target              Handle owner_handle = static_cast<Handle>(mutex_val & Mutex::MutexOwnerMask);              auto owner = g_handle_table.Get<Thread>(owner_handle);              ASSERT(owner); -            ASSERT(thread->status != THREADSTATUS_RUNNING); -            thread->status = THREADSTATUS_WAIT_MUTEX; +            ASSERT(thread->status != ThreadStatus::Running); +            thread->status = ThreadStatus::WaitMutex;              thread->wakeup_callback = nullptr;              // Signal that the mutex now has a waiting thread. diff --git a/src/core/hle/kernel/thread.cpp b/src/core/hle/kernel/thread.cpp index e7fd6c842..53f2e861e 100644 --- a/src/core/hle/kernel/thread.cpp +++ b/src/core/hle/kernel/thread.cpp @@ -30,7 +30,7 @@ namespace Kernel {  static CoreTiming::EventType* ThreadWakeupEventType = nullptr;  bool Thread::ShouldWait(Thread* thread) const { -    return status != THREADSTATUS_DEAD; +    return status != ThreadStatus::Dead;  }  void Thread::Acquire(Thread* thread) { @@ -63,11 +63,11 @@ void Thread::Stop() {      // Clean up thread from ready queue      // This is only needed when the thread is termintated forcefully (SVC TerminateProcess) -    if (status == THREADSTATUS_READY) { +    if (status == ThreadStatus::Ready) {          scheduler->UnscheduleThread(this, current_priority);      } -    status = THREADSTATUS_DEAD; +    status = ThreadStatus::Dead;      WakeupAllWaitingThreads(); @@ -86,7 +86,7 @@ void Thread::Stop() {  void WaitCurrentThread_Sleep() {      Thread* thread = GetCurrentThread(); -    thread->status = THREADSTATUS_WAIT_SLEEP; +    thread->status = ThreadStatus::WaitSleep;  }  void ExitCurrentThread() { @@ -110,10 +110,9 @@ static void ThreadWakeupCallback(u64 thread_handle, int cycles_late) {      bool resume = true; -    if (thread->status == THREADSTATUS_WAIT_SYNCH_ANY || -        thread->status == THREADSTATUS_WAIT_SYNCH_ALL || -        thread->status == THREADSTATUS_WAIT_HLE_EVENT) { - +    if (thread->status == ThreadStatus::WaitSynchAny || +        thread->status == ThreadStatus::WaitSynchAll || +        thread->status == ThreadStatus::WaitHLEEvent) {          // Remove the thread from each of its waiting objects' waitlists          for (auto& object : thread->wait_objects)              object->RemoveWaitingThread(thread.get()); @@ -126,7 +125,7 @@ static void ThreadWakeupCallback(u64 thread_handle, int cycles_late) {      if (thread->mutex_wait_address != 0 || thread->condvar_wait_address != 0 ||          thread->wait_handle) { -        ASSERT(thread->status == THREADSTATUS_WAIT_MUTEX); +        ASSERT(thread->status == ThreadStatus::WaitMutex);          thread->mutex_wait_address = 0;          thread->condvar_wait_address = 0;          thread->wait_handle = 0; @@ -141,7 +140,7 @@ static void ThreadWakeupCallback(u64 thread_handle, int cycles_late) {      }      if (thread->arb_wait_address != 0) { -        ASSERT(thread->status == THREADSTATUS_WAIT_ARB); +        ASSERT(thread->status == ThreadStatus::WaitArb);          thread->arb_wait_address = 0;      } @@ -178,28 +177,28 @@ void Thread::ResumeFromWait() {      ASSERT_MSG(wait_objects.empty(), "Thread is waking up while waiting for objects");      switch (status) { -    case THREADSTATUS_WAIT_SYNCH_ALL: -    case THREADSTATUS_WAIT_SYNCH_ANY: -    case THREADSTATUS_WAIT_HLE_EVENT: -    case THREADSTATUS_WAIT_SLEEP: -    case THREADSTATUS_WAIT_IPC: -    case THREADSTATUS_WAIT_MUTEX: -    case THREADSTATUS_WAIT_ARB: +    case ThreadStatus::WaitSynchAll: +    case ThreadStatus::WaitSynchAny: +    case ThreadStatus::WaitHLEEvent: +    case ThreadStatus::WaitSleep: +    case ThreadStatus::WaitIPC: +    case ThreadStatus::WaitMutex: +    case ThreadStatus::WaitArb:          break; -    case THREADSTATUS_READY: +    case ThreadStatus::Ready:          // The thread's wakeup callback must have already been cleared when the thread was first          // awoken.          ASSERT(wakeup_callback == nullptr);          // If the thread is waiting on multiple wait objects, it might be awoken more than once          // before actually resuming. We can ignore subsequent wakeups if the thread status has -        // already been set to THREADSTATUS_READY. +        // already been set to ThreadStatus::Ready.          return; -    case THREADSTATUS_RUNNING: +    case ThreadStatus::Running:          DEBUG_ASSERT_MSG(false, "Thread with object id {} has already resumed.", GetObjectId());          return; -    case THREADSTATUS_DEAD: +    case ThreadStatus::Dead:          // This should never happen, as threads must complete before being stopped.          DEBUG_ASSERT_MSG(false, "Thread with object id {} cannot be resumed because it's DEAD.",                           GetObjectId()); @@ -208,7 +207,7 @@ void Thread::ResumeFromWait() {      wakeup_callback = nullptr; -    status = THREADSTATUS_READY; +    status = ThreadStatus::Ready;      boost::optional<s32> new_processor_id = GetNextProcessorId(affinity_mask);      if (!new_processor_id) { @@ -310,7 +309,7 @@ ResultVal<SharedPtr<Thread>> Thread::Create(std::string name, VAddr entry_point,      SharedPtr<Thread> thread(new Thread);      thread->thread_id = NewThreadId(); -    thread->status = THREADSTATUS_DORMANT; +    thread->status = ThreadStatus::Dormant;      thread->entry_point = entry_point;      thread->stack_top = stack_top;      thread->nominal_priority = thread->current_priority = priority; @@ -471,7 +470,7 @@ void Thread::ChangeCore(u32 core, u64 mask) {      ideal_core = core;      affinity_mask = mask; -    if (status != THREADSTATUS_READY) { +    if (status != ThreadStatus::Ready) {          return;      } diff --git a/src/core/hle/kernel/thread.h b/src/core/hle/kernel/thread.h index f1e759802..47881ec20 100644 --- a/src/core/hle/kernel/thread.h +++ b/src/core/hle/kernel/thread.h @@ -36,18 +36,18 @@ enum ThreadProcessorId : s32 {                                       (1 << THREADPROCESSORID_2) | (1 << THREADPROCESSORID_3)  }; -enum ThreadStatus { -    THREADSTATUS_RUNNING,        ///< Currently running -    THREADSTATUS_READY,          ///< Ready to run -    THREADSTATUS_WAIT_HLE_EVENT, ///< Waiting for hle event to finish -    THREADSTATUS_WAIT_SLEEP,     ///< Waiting due to a SleepThread SVC -    THREADSTATUS_WAIT_IPC,       ///< Waiting for the reply from an IPC request -    THREADSTATUS_WAIT_SYNCH_ANY, ///< Waiting due to WaitSynch1 or WaitSynchN with wait_all = false -    THREADSTATUS_WAIT_SYNCH_ALL, ///< Waiting due to WaitSynchronizationN with wait_all = true -    THREADSTATUS_WAIT_MUTEX,     ///< Waiting due to an ArbitrateLock/WaitProcessWideKey svc -    THREADSTATUS_WAIT_ARB,       ///< Waiting due to a SignalToAddress/WaitForAddress svc -    THREADSTATUS_DORMANT,        ///< Created but not yet made ready -    THREADSTATUS_DEAD            ///< Run to completion, or forcefully terminated +enum class ThreadStatus { +    Running,      ///< Currently running +    Ready,        ///< Ready to run +    WaitHLEEvent, ///< Waiting for hle event to finish +    WaitSleep,    ///< Waiting due to a SleepThread SVC +    WaitIPC,      ///< Waiting for the reply from an IPC request +    WaitSynchAny, ///< Waiting due to WaitSynch1 or WaitSynchN with wait_all = false +    WaitSynchAll, ///< Waiting due to WaitSynchronizationN with wait_all = true +    WaitMutex,    ///< Waiting due to an ArbitrateLock/WaitProcessWideKey svc +    WaitArb,      ///< Waiting due to a SignalToAddress/WaitForAddress svc +    Dormant,      ///< Created but not yet made ready +    Dead          ///< Run to completion, or forcefully terminated  };  enum class ThreadWakeupReason { @@ -194,14 +194,14 @@ public:       * with wait_all = true.       */      bool IsSleepingOnWaitAll() const { -        return status == THREADSTATUS_WAIT_SYNCH_ALL; +        return status == ThreadStatus::WaitSynchAll;      }      ARM_Interface::ThreadContext context;      u32 thread_id; -    u32 status; +    ThreadStatus status;      VAddr entry_point;      VAddr stack_top; diff --git a/src/core/hle/kernel/wait_object.cpp b/src/core/hle/kernel/wait_object.cpp index b08ac72c1..eb3c92e66 100644 --- a/src/core/hle/kernel/wait_object.cpp +++ b/src/core/hle/kernel/wait_object.cpp @@ -38,9 +38,9 @@ SharedPtr<Thread> WaitObject::GetHighestPriorityReadyThread() {      for (const auto& thread : waiting_threads) {          // The list of waiting threads must not contain threads that are not waiting to be awakened. -        ASSERT_MSG(thread->status == THREADSTATUS_WAIT_SYNCH_ANY || -                       thread->status == THREADSTATUS_WAIT_SYNCH_ALL || -                       thread->status == THREADSTATUS_WAIT_HLE_EVENT, +        ASSERT_MSG(thread->status == ThreadStatus::WaitSynchAny || +                       thread->status == ThreadStatus::WaitSynchAll || +                       thread->status == ThreadStatus::WaitHLEEvent,                     "Inconsistent thread statuses in waiting_threads");          if (thread->current_priority >= candidate_priority) @@ -49,10 +49,10 @@ SharedPtr<Thread> WaitObject::GetHighestPriorityReadyThread() {          if (ShouldWait(thread.get()))              continue; -        // A thread is ready to run if it's either in THREADSTATUS_WAIT_SYNCH_ANY or -        // in THREADSTATUS_WAIT_SYNCH_ALL and the rest of the objects it is waiting on are ready. +        // A thread is ready to run if it's either in ThreadStatus::WaitSynchAny or +        // in ThreadStatus::WaitSynchAll and the rest of the objects it is waiting on are ready.          bool ready_to_run = true; -        if (thread->status == THREADSTATUS_WAIT_SYNCH_ALL) { +        if (thread->status == ThreadStatus::WaitSynchAll) {              ready_to_run = std::none_of(thread->wait_objects.begin(), thread->wait_objects.end(),                                          [&thread](const SharedPtr<WaitObject>& object) {                                              return object->ShouldWait(thread.get()); diff --git a/src/core/hle/service/audio/audout_u.cpp b/src/core/hle/service/audio/audout_u.cpp index 4217ea4fb..154bc12da 100644 --- a/src/core/hle/service/audio/audout_u.cpp +++ b/src/core/hle/service/audio/audout_u.cpp @@ -2,6 +2,7 @@  // Licensed under GPLv2 or any later version  // Refer to the license.txt file included. +#include <array>  #include <vector>  #include "common/logging/log.h"  #include "core/core_timing.h" @@ -167,7 +168,7 @@ void AudOutU::ListAudioOutsImpl(Kernel::HLERequestContext& ctx) {      LOG_WARNING(Service_Audio, "(STUBBED) called");      IPC::RequestParser rp{ctx}; -    const std::string audio_interface = "AudioInterface"; +    constexpr std::array<char, 15> audio_interface{{"AudioInterface"}};      ctx.WriteBuffer(audio_interface);      IPC::ResponseBuilder rb = rp.MakeBuilder(3, 0, 0); diff --git a/src/core/hle/service/audio/audren_u.cpp b/src/core/hle/service/audio/audren_u.cpp index 6903f52d6..e623f4f8e 100644 --- a/src/core/hle/service/audio/audren_u.cpp +++ b/src/core/hle/service/audio/audren_u.cpp @@ -2,6 +2,8 @@  // Licensed under GPLv2 or any later version  // Refer to the license.txt file included. +#include <array> +  #include "common/alignment.h"  #include "common/logging/log.h"  #include "core/core_timing.h" @@ -298,7 +300,7 @@ private:          LOG_WARNING(Service_Audio, "(STUBBED) called");          IPC::RequestParser rp{ctx}; -        const std::string audio_interface = "AudioInterface"; +        constexpr std::array<char, 15> audio_interface{{"AudioInterface"}};          ctx.WriteBuffer(audio_interface);          IPC::ResponseBuilder rb = rp.MakeBuilder(3, 0, 0); @@ -323,7 +325,7 @@ private:          LOG_WARNING(Service_Audio, "(STUBBED) called");          IPC::RequestParser rp{ctx}; -        const std::string audio_interface = "AudioDevice"; +        constexpr std::array<char, 12> audio_interface{{"AudioDevice"}};          ctx.WriteBuffer(audio_interface);          IPC::ResponseBuilder rb = rp.MakeBuilder(3, 0, 0); diff --git a/src/core/hle/service/ns/pl_u.cpp b/src/core/hle/service/ns/pl_u.cpp index d4e0f615a..691b1d106 100644 --- a/src/core/hle/service/ns/pl_u.cpp +++ b/src/core/hle/service/ns/pl_u.cpp @@ -132,9 +132,9 @@ void PL_U::GetSharedFontInOrderOfPriority(Kernel::HLERequestContext& ctx) {          font_sizes.push_back(SHARED_FONT_REGIONS[i].size);      } -    ctx.WriteBuffer(font_codes.data(), font_codes.size() * sizeof(u32), 0); -    ctx.WriteBuffer(font_offsets.data(), font_offsets.size() * sizeof(u32), 1); -    ctx.WriteBuffer(font_sizes.data(), font_sizes.size() * sizeof(u32), 2); +    ctx.WriteBuffer(font_codes, 0); +    ctx.WriteBuffer(font_offsets, 1); +    ctx.WriteBuffer(font_sizes, 2);      rb.Push(RESULT_SUCCESS);      rb.Push<u8>(static_cast<u8>(LoadState::Done)); // Fonts Loaded diff --git a/src/core/loader/nca.cpp b/src/core/loader/nca.cpp index e73b253b2..c80df23be 100644 --- a/src/core/loader/nca.cpp +++ b/src/core/loader/nca.cpp @@ -2,6 +2,7 @@  // Licensed under GPLv2 or any later version  // Refer to the license.txt file included. +#include <utility>  #include <vector>  #include "common/file_util.h" @@ -21,7 +22,7 @@  namespace Loader { -AppLoader_NCA::AppLoader_NCA(FileSys::VirtualFile file) : AppLoader(file) {} +AppLoader_NCA::AppLoader_NCA(FileSys::VirtualFile file) : AppLoader(std::move(file)) {}  FileType AppLoader_NCA::IdentifyType(const FileSys::VirtualFile& file) {      // TODO(DarkLordZach): Assuming everything is decrypted. Add crypto support. diff --git a/src/core/loader/nro.cpp b/src/core/loader/nro.cpp index 465b827bb..c020399f2 100644 --- a/src/core/loader/nro.cpp +++ b/src/core/loader/nro.cpp @@ -2,6 +2,7 @@  // Licensed under GPLv2 or any later version  // Refer to the license.txt file included. +#include <utility>  #include <vector>  #include "common/common_funcs.h" @@ -48,7 +49,7 @@ struct ModHeader {  };  static_assert(sizeof(ModHeader) == 0x1c, "ModHeader has incorrect size."); -AppLoader_NRO::AppLoader_NRO(FileSys::VirtualFile file) : AppLoader(file) {} +AppLoader_NRO::AppLoader_NRO(FileSys::VirtualFile file) : AppLoader(std::move(file)) {}  FileType AppLoader_NRO::IdentifyType(const FileSys::VirtualFile& file) {      // Read NSO header diff --git a/src/core/loader/nso.cpp b/src/core/loader/nso.cpp index c66561bf4..06b1b33f4 100644 --- a/src/core/loader/nso.cpp +++ b/src/core/loader/nso.cpp @@ -69,29 +69,18 @@ FileType AppLoader_NSO::IdentifyType(const FileSys::VirtualFile& file) {  static std::vector<u8> DecompressSegment(const std::vector<u8>& compressed_data,                                           const NsoSegmentHeader& header) {      std::vector<u8> uncompressed_data(header.size); -    const int bytes_uncompressed = LZ4_decompress_safe( -        reinterpret_cast<const char*>(compressed_data.data()), -        reinterpret_cast<char*>(uncompressed_data.data()), compressed_data.size(), header.size); +    const int bytes_uncompressed = +        LZ4_decompress_safe(reinterpret_cast<const char*>(compressed_data.data()), +                            reinterpret_cast<char*>(uncompressed_data.data()), +                            static_cast<int>(compressed_data.size()), header.size); -    ASSERT_MSG(bytes_uncompressed == header.size && bytes_uncompressed == uncompressed_data.size(), +    ASSERT_MSG(bytes_uncompressed == static_cast<int>(header.size) && +                   bytes_uncompressed == static_cast<int>(uncompressed_data.size()),                 "{} != {} != {}", bytes_uncompressed, header.size, uncompressed_data.size());      return uncompressed_data;  } -static std::vector<u8> ReadSegment(FileUtil::IOFile& file, const NsoSegmentHeader& header, -                                   size_t compressed_size) { -    std::vector<u8> compressed_data(compressed_size); - -    file.Seek(header.offset, SEEK_SET); -    if (compressed_size != file.ReadBytes(compressed_data.data(), compressed_size)) { -        LOG_CRITICAL(Loader, "Failed to read {} NSO LZ4 compressed bytes", compressed_size); -        return {}; -    } - -    return DecompressSegment(compressed_data, header); -} -  static constexpr u32 PageAlignSize(u32 size) {      return (size + Memory::PAGE_MASK) & ~Memory::PAGE_MASK;  } diff --git a/src/video_core/engines/maxwell_3d.cpp b/src/video_core/engines/maxwell_3d.cpp index dfbf80abd..d7328ff39 100644 --- a/src/video_core/engines/maxwell_3d.cpp +++ b/src/video_core/engines/maxwell_3d.cpp @@ -317,8 +317,6 @@ std::vector<Texture::FullTextureInfo> Maxwell3D::GetStageTextures(Regs::ShaderSt      auto& tex_info_buffer = fragment_shader.const_buffers[regs.tex_cb_index];      ASSERT(tex_info_buffer.enabled && tex_info_buffer.address != 0); -    GPUVAddr tic_base_address = regs.tic.TICAddress(); -      GPUVAddr tex_info_buffer_end = tex_info_buffer.address + tex_info_buffer.size;      // Offset into the texture constbuffer where the texture info begins. diff --git a/src/video_core/renderer_opengl/gl_shader_decompiler.cpp b/src/video_core/renderer_opengl/gl_shader_decompiler.cpp index 5fae95788..a1ac18a71 100644 --- a/src/video_core/renderer_opengl/gl_shader_decompiler.cpp +++ b/src/video_core/renderer_opengl/gl_shader_decompiler.cpp @@ -216,7 +216,7 @@ public:      }      /// Returns a GLSL string representing the current state of the register -    const std::string GetActiveString() { +    std::string GetActiveString() {          declr_type.insert(active_type);          return GetPrefixString(active_type) + std::to_string(index) + '_' + suffix;      } @@ -518,7 +518,7 @@ public:  private:      /// Build GLSL conversion function, e.g. floatBitsToInt, intBitsToFloat, etc. -    const std::string GetGLSLConversionFunc(GLSLRegister::Type src, GLSLRegister::Type dest) const { +    std::string GetGLSLConversionFunc(GLSLRegister::Type src, GLSLRegister::Type dest) const {          const std::string src_type = GLSLRegister::GetTypeString(src);          std::string dest_type = GLSLRegister::GetTypeString(dest);          dest_type[0] = toupper(dest_type[0]); @@ -1405,7 +1405,7 @@ private:                  // TEXS has two destination registers. RG goes into gpr0+0 and gpr0+1, and BA                  // goes into gpr28+0 and gpr28+1 -                size_t offset{}; +                size_t texs_offset{};                  for (const auto& dest : {instr.gpr0.Value(), instr.gpr28.Value()}) {                      for (unsigned elem = 0; elem < 2; ++elem) { @@ -1413,7 +1413,8 @@ private:                              // Skip disabled components                              continue;                          } -                        regs.SetRegisterToFloat(dest, elem + offset, texture, 1, 4, false, elem); +                        regs.SetRegisterToFloat(dest, elem + texs_offset, texture, 1, 4, false, +                                                elem);                      }                      if (!instr.texs.HasTwoDestinations()) { @@ -1421,7 +1422,7 @@ private:                          break;                      } -                    offset += 2; +                    texs_offset += 2;                  }                  --shader.scope;                  shader.AddLine("}"); @@ -1463,7 +1464,6 @@ private:                  op_b = "abs(" + op_b + ')';              } -            using Tegra::Shader::Pred;              // We can't use the constant predicate as destination.              ASSERT(instr.fsetp.pred3 != static_cast<u64>(Pred::UnusedIndex)); @@ -1500,7 +1500,6 @@ private:                  }              } -            using Tegra::Shader::Pred;              // We can't use the constant predicate as destination.              ASSERT(instr.isetp.pred3 != static_cast<u64>(Pred::UnusedIndex)); @@ -1528,7 +1527,6 @@ private:              std::string op_b =                  GetPredicateCondition(instr.psetp.pred29, instr.psetp.neg_pred29 != 0); -            using Tegra::Shader::Pred;              // We can't use the constant predicate as destination.              ASSERT(instr.psetp.pred3 != static_cast<u64>(Pred::UnusedIndex)); diff --git a/src/yuzu/debugger/wait_tree.cpp b/src/yuzu/debugger/wait_tree.cpp index 7101b381e..8f24586ce 100644 --- a/src/yuzu/debugger/wait_tree.cpp +++ b/src/yuzu/debugger/wait_tree.cpp @@ -194,32 +194,32 @@ QString WaitTreeThread::GetText() const {      const auto& thread = static_cast<const Kernel::Thread&>(object);      QString status;      switch (thread.status) { -    case THREADSTATUS_RUNNING: +    case ThreadStatus::Running:          status = tr("running");          break; -    case THREADSTATUS_READY: +    case ThreadStatus::Ready:          status = tr("ready");          break; -    case THREADSTATUS_WAIT_HLE_EVENT: +    case ThreadStatus::WaitHLEEvent:          status = tr("waiting for HLE return");          break; -    case THREADSTATUS_WAIT_SLEEP: +    case ThreadStatus::WaitSleep:          status = tr("sleeping");          break; -    case THREADSTATUS_WAIT_SYNCH_ALL: -    case THREADSTATUS_WAIT_SYNCH_ANY: +    case ThreadStatus::WaitSynchAll: +    case ThreadStatus::WaitSynchAny:          status = tr("waiting for objects");          break; -    case THREADSTATUS_WAIT_MUTEX: +    case ThreadStatus::WaitMutex:          status = tr("waiting for mutex");          break; -    case THREADSTATUS_WAIT_ARB: +    case ThreadStatus::WaitArb:          status = tr("waiting for address arbiter");          break; -    case THREADSTATUS_DORMANT: +    case ThreadStatus::Dormant:          status = tr("dormant");          break; -    case THREADSTATUS_DEAD: +    case ThreadStatus::Dead:          status = tr("dead");          break;      } @@ -232,22 +232,22 @@ QString WaitTreeThread::GetText() const {  QColor WaitTreeThread::GetColor() const {      const auto& thread = static_cast<const Kernel::Thread&>(object);      switch (thread.status) { -    case THREADSTATUS_RUNNING: +    case ThreadStatus::Running:          return QColor(Qt::GlobalColor::darkGreen); -    case THREADSTATUS_READY: +    case ThreadStatus::Ready:          return QColor(Qt::GlobalColor::darkBlue); -    case THREADSTATUS_WAIT_HLE_EVENT: +    case ThreadStatus::WaitHLEEvent:          return QColor(Qt::GlobalColor::darkRed); -    case THREADSTATUS_WAIT_SLEEP: +    case ThreadStatus::WaitSleep:          return QColor(Qt::GlobalColor::darkYellow); -    case THREADSTATUS_WAIT_SYNCH_ALL: -    case THREADSTATUS_WAIT_SYNCH_ANY: -    case THREADSTATUS_WAIT_MUTEX: -    case THREADSTATUS_WAIT_ARB: +    case ThreadStatus::WaitSynchAll: +    case ThreadStatus::WaitSynchAny: +    case ThreadStatus::WaitMutex: +    case ThreadStatus::WaitArb:          return QColor(Qt::GlobalColor::red); -    case THREADSTATUS_DORMANT: +    case ThreadStatus::Dormant:          return QColor(Qt::GlobalColor::darkCyan); -    case THREADSTATUS_DEAD: +    case ThreadStatus::Dead:          return QColor(Qt::GlobalColor::gray);      default:          return WaitTreeItem::GetColor(); @@ -291,8 +291,8 @@ std::vector<std::unique_ptr<WaitTreeItem>> WaitTreeThread::GetChildren() const {      else          list.push_back(std::make_unique<WaitTreeText>(tr("not waiting for mutex"))); -    if (thread.status == THREADSTATUS_WAIT_SYNCH_ANY || -        thread.status == THREADSTATUS_WAIT_SYNCH_ALL) { +    if (thread.status == ThreadStatus::WaitSynchAny || +        thread.status == ThreadStatus::WaitSynchAll) {          list.push_back(std::make_unique<WaitTreeObjectList>(thread.wait_objects,                                                              thread.IsSleepingOnWaitAll()));      } | 
