PhysicsSystem.cpp 116 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715
  1. // Jolt Physics Library (https://github.com/jrouwe/JoltPhysics)
  2. // SPDX-FileCopyrightText: 2021 Jorrit Rouwe
  3. // SPDX-License-Identifier: MIT
  4. #include <Jolt/Jolt.h>
  5. #include <Jolt/Physics/PhysicsSystem.h>
  6. #include <Jolt/Physics/PhysicsSettings.h>
  7. #include <Jolt/Physics/PhysicsUpdateContext.h>
  8. #include <Jolt/Physics/PhysicsStepListener.h>
  9. #include <Jolt/Physics/Collision/BroadPhase/BroadPhaseBruteForce.h>
  10. #include <Jolt/Physics/Collision/BroadPhase/BroadPhaseQuadTree.h>
  11. #include <Jolt/Physics/Collision/CollisionDispatch.h>
  12. #include <Jolt/Physics/Collision/AABoxCast.h>
  13. #include <Jolt/Physics/Collision/ShapeCast.h>
  14. #include <Jolt/Physics/Collision/CollideShape.h>
  15. #include <Jolt/Physics/Collision/CollisionCollectorImpl.h>
  16. #include <Jolt/Physics/Collision/CastResult.h>
  17. #include <Jolt/Physics/Collision/CollideConvexVsTriangles.h>
  18. #include <Jolt/Physics/Collision/ManifoldBetweenTwoFaces.h>
  19. #include <Jolt/Physics/Collision/Shape/ConvexShape.h>
  20. #include <Jolt/Physics/Collision/InternalEdgeRemovingCollector.h>
  21. #include <Jolt/Physics/Constraints/CalculateSolverSteps.h>
  22. #include <Jolt/Physics/Constraints/ConstraintPart/AxisConstraintPart.h>
  23. #include <Jolt/Physics/DeterminismLog.h>
  24. #include <Jolt/Physics/SoftBody/SoftBodyMotionProperties.h>
  25. #include <Jolt/Physics/SoftBody/SoftBodyShape.h>
  26. #include <Jolt/Geometry/RayAABox.h>
  27. #include <Jolt/Geometry/ClosestPoint.h>
  28. #include <Jolt/Core/JobSystem.h>
  29. #include <Jolt/Core/TempAllocator.h>
  30. #include <Jolt/Core/QuickSort.h>
  31. #include <Jolt/Core/ScopeExit.h>
  32. #ifdef JPH_DEBUG_RENDERER
  33. #include <Jolt/Renderer/DebugRenderer.h>
  34. #endif // JPH_DEBUG_RENDERER
  35. JPH_NAMESPACE_BEGIN
  36. #ifdef JPH_DEBUG_RENDERER
  37. bool PhysicsSystem::sDrawMotionQualityLinearCast = false;
  38. #endif // JPH_DEBUG_RENDERER
  39. //#define BROAD_PHASE BroadPhaseBruteForce
  40. #define BROAD_PHASE BroadPhaseQuadTree
  41. static const Color cColorUpdateBroadPhaseFinalize = Color::sGetDistinctColor(1);
  42. static const Color cColorUpdateBroadPhasePrepare = Color::sGetDistinctColor(2);
  43. static const Color cColorFindCollisions = Color::sGetDistinctColor(3);
  44. static const Color cColorApplyGravity = Color::sGetDistinctColor(4);
  45. static const Color cColorSetupVelocityConstraints = Color::sGetDistinctColor(5);
  46. static const Color cColorBuildIslandsFromConstraints = Color::sGetDistinctColor(6);
  47. static const Color cColorDetermineActiveConstraints = Color::sGetDistinctColor(7);
  48. static const Color cColorFinalizeIslands = Color::sGetDistinctColor(8);
  49. static const Color cColorContactRemovedCallbacks = Color::sGetDistinctColor(9);
  50. static const Color cColorBodySetIslandIndex = Color::sGetDistinctColor(10);
  51. static const Color cColorStartNextStep = Color::sGetDistinctColor(11);
  52. static const Color cColorSolveVelocityConstraints = Color::sGetDistinctColor(12);
  53. static const Color cColorPreIntegrateVelocity = Color::sGetDistinctColor(13);
  54. static const Color cColorIntegrateVelocity = Color::sGetDistinctColor(14);
  55. static const Color cColorPostIntegrateVelocity = Color::sGetDistinctColor(15);
  56. static const Color cColorResolveCCDContacts = Color::sGetDistinctColor(16);
  57. static const Color cColorSolvePositionConstraints = Color::sGetDistinctColor(17);
  58. static const Color cColorFindCCDContacts = Color::sGetDistinctColor(18);
  59. static const Color cColorStepListeners = Color::sGetDistinctColor(19);
  60. static const Color cColorSoftBodyPrepare = Color::sGetDistinctColor(20);
  61. static const Color cColorSoftBodyCollide = Color::sGetDistinctColor(21);
  62. static const Color cColorSoftBodySimulate = Color::sGetDistinctColor(22);
  63. static const Color cColorSoftBodyFinalize = Color::sGetDistinctColor(23);
  64. PhysicsSystem::~PhysicsSystem()
  65. {
  66. // Remove broadphase
  67. delete mBroadPhase;
  68. }
  69. void PhysicsSystem::Init(uint inMaxBodies, uint inNumBodyMutexes, uint inMaxBodyPairs, uint inMaxContactConstraints, const BroadPhaseLayerInterface &inBroadPhaseLayerInterface, const ObjectVsBroadPhaseLayerFilter &inObjectVsBroadPhaseLayerFilter, const ObjectLayerPairFilter &inObjectLayerPairFilter)
  70. {
  71. JPH_ASSERT(inMaxBodies <= BodyID::cMaxBodyIndex, "Cannot support this many bodies");
  72. mObjectVsBroadPhaseLayerFilter = &inObjectVsBroadPhaseLayerFilter;
  73. mObjectLayerPairFilter = &inObjectLayerPairFilter;
  74. // Initialize body manager
  75. mBodyManager.Init(inMaxBodies, inNumBodyMutexes, inBroadPhaseLayerInterface);
  76. // Create broadphase
  77. mBroadPhase = new BROAD_PHASE();
  78. mBroadPhase->Init(&mBodyManager, inBroadPhaseLayerInterface);
  79. // Init contact constraint manager
  80. mContactManager.Init(inMaxBodyPairs, inMaxContactConstraints);
  81. // Init islands builder
  82. mIslandBuilder.Init(inMaxBodies);
  83. // Initialize body interface
  84. mBodyInterfaceLocking.Init(mBodyLockInterfaceLocking, mBodyManager, *mBroadPhase);
  85. mBodyInterfaceNoLock.Init(mBodyLockInterfaceNoLock, mBodyManager, *mBroadPhase);
  86. // Initialize narrow phase query
  87. mNarrowPhaseQueryLocking.Init(mBodyLockInterfaceLocking, *mBroadPhase);
  88. mNarrowPhaseQueryNoLock.Init(mBodyLockInterfaceNoLock, *mBroadPhase);
  89. }
  90. void PhysicsSystem::OptimizeBroadPhase()
  91. {
  92. mBroadPhase->Optimize();
  93. }
  94. void PhysicsSystem::AddStepListener(PhysicsStepListener *inListener)
  95. {
  96. lock_guard lock(mStepListenersMutex);
  97. JPH_ASSERT(std::find(mStepListeners.begin(), mStepListeners.end(), inListener) == mStepListeners.end());
  98. mStepListeners.push_back(inListener);
  99. }
  100. void PhysicsSystem::RemoveStepListener(PhysicsStepListener *inListener)
  101. {
  102. lock_guard lock(mStepListenersMutex);
  103. StepListeners::iterator i = std::find(mStepListeners.begin(), mStepListeners.end(), inListener);
  104. JPH_ASSERT(i != mStepListeners.end());
  105. *i = mStepListeners.back();
  106. mStepListeners.pop_back();
  107. }
  108. EPhysicsUpdateError PhysicsSystem::Update(float inDeltaTime, int inCollisionSteps, TempAllocator *inTempAllocator, JobSystem *inJobSystem)
  109. {
  110. JPH_PROFILE_FUNCTION();
  111. JPH_DET_LOG("PhysicsSystem::Update: dt: " << inDeltaTime << " steps: " << inCollisionSteps);
  112. JPH_ASSERT(inCollisionSteps > 0);
  113. JPH_ASSERT(inDeltaTime >= 0.0f);
  114. // Sync point for the broadphase. This will allow it to do clean up operations without having any mutexes locked yet.
  115. mBroadPhase->FrameSync();
  116. // If there are no active bodies or there's no time delta
  117. uint32 num_active_rigid_bodies = mBodyManager.GetNumActiveBodies(EBodyType::RigidBody);
  118. uint32 num_active_soft_bodies = mBodyManager.GetNumActiveBodies(EBodyType::SoftBody);
  119. if ((num_active_rigid_bodies == 0 && num_active_soft_bodies == 0) || inDeltaTime <= 0.0f)
  120. {
  121. mBodyManager.LockAllBodies();
  122. // Update broadphase
  123. mBroadPhase->LockModifications();
  124. BroadPhase::UpdateState update_state = mBroadPhase->UpdatePrepare();
  125. mBroadPhase->UpdateFinalize(update_state);
  126. mBroadPhase->UnlockModifications();
  127. // Call contact removal callbacks from contacts that existed in the previous update
  128. mContactManager.FinalizeContactCacheAndCallContactPointRemovedCallbacks(0, 0);
  129. mBodyManager.UnlockAllBodies();
  130. return EPhysicsUpdateError::None;
  131. }
  132. // Calculate ratio between current and previous frame delta time to scale initial constraint forces
  133. float step_delta_time = inDeltaTime / inCollisionSteps;
  134. float warm_start_impulse_ratio = mPhysicsSettings.mConstraintWarmStart && mPreviousStepDeltaTime > 0.0f? step_delta_time / mPreviousStepDeltaTime : 0.0f;
  135. mPreviousStepDeltaTime = step_delta_time;
  136. // Create the context used for passing information between jobs
  137. PhysicsUpdateContext context(*inTempAllocator);
  138. context.mPhysicsSystem = this;
  139. context.mJobSystem = inJobSystem;
  140. context.mBarrier = inJobSystem->CreateBarrier();
  141. context.mIslandBuilder = &mIslandBuilder;
  142. context.mStepDeltaTime = step_delta_time;
  143. context.mWarmStartImpulseRatio = warm_start_impulse_ratio;
  144. context.mSteps.resize(inCollisionSteps);
  145. // Allocate space for body pairs
  146. JPH_ASSERT(context.mBodyPairs == nullptr);
  147. context.mBodyPairs = static_cast<BodyPair *>(inTempAllocator->Allocate(sizeof(BodyPair) * mPhysicsSettings.mMaxInFlightBodyPairs));
  148. // Lock all bodies for write so that we can freely touch them
  149. mStepListenersMutex.lock();
  150. mBodyManager.LockAllBodies();
  151. mBroadPhase->LockModifications();
  152. // Get max number of concurrent jobs
  153. int max_concurrency = context.GetMaxConcurrency();
  154. // Calculate how many step listener jobs we spawn
  155. int num_step_listener_jobs = mStepListeners.empty()? 0 : max(1, min((int)mStepListeners.size() / mPhysicsSettings.mStepListenersBatchSize / mPhysicsSettings.mStepListenerBatchesPerJob, max_concurrency));
  156. // Number of gravity jobs depends on the amount of active bodies.
  157. // Launch max 1 job per batch of active bodies
  158. // Leave 1 thread for update broadphase prepare and 1 for determine active constraints
  159. int num_apply_gravity_jobs = max(1, min(((int)num_active_rigid_bodies + cApplyGravityBatchSize - 1) / cApplyGravityBatchSize, max_concurrency - 2));
  160. // Number of determine active constraints jobs to run depends on number of constraints.
  161. // Leave 1 thread for update broadphase prepare and 1 for apply gravity
  162. int num_determine_active_constraints_jobs = max(1, min(((int)mConstraintManager.GetNumConstraints() + cDetermineActiveConstraintsBatchSize - 1) / cDetermineActiveConstraintsBatchSize, max_concurrency - 2));
  163. // Number of setup velocity constraints jobs to run depends on number of constraints.
  164. int num_setup_velocity_constraints_jobs = max(1, min(((int)mConstraintManager.GetNumConstraints() + cSetupVelocityConstraintsBatchSize - 1) / cSetupVelocityConstraintsBatchSize, max_concurrency));
  165. // Number of find collisions jobs to run depends on number of active bodies.
  166. // Note that when we have more than 1 thread, we always spawn at least 2 find collisions jobs so that the first job can wait for build islands from constraints
  167. // (which may activate additional bodies that need to be processed) while the second job can start processing collision work.
  168. int num_find_collisions_jobs = max(max_concurrency == 1? 1 : 2, min(((int)num_active_rigid_bodies + cActiveBodiesBatchSize - 1) / cActiveBodiesBatchSize, max_concurrency));
  169. // Number of integrate velocity jobs depends on number of active bodies.
  170. int num_integrate_velocity_jobs = max(1, min(((int)num_active_rigid_bodies + cIntegrateVelocityBatchSize - 1) / cIntegrateVelocityBatchSize, max_concurrency));
  171. {
  172. JPH_PROFILE("Build Jobs");
  173. // Iterate over collision steps
  174. for (int step_idx = 0; step_idx < inCollisionSteps; ++step_idx)
  175. {
  176. bool is_first_step = step_idx == 0;
  177. bool is_last_step = step_idx == inCollisionSteps - 1;
  178. PhysicsUpdateContext::Step &step = context.mSteps[step_idx];
  179. step.mContext = &context;
  180. step.mIsFirst = is_first_step;
  181. step.mIsLast = is_last_step;
  182. // Create job to do broadphase finalization
  183. // This job must finish before integrating velocities. Until then the positions will not be updated neither will bodies be added / removed.
  184. step.mUpdateBroadphaseFinalize = inJobSystem->CreateJob("UpdateBroadPhaseFinalize", cColorUpdateBroadPhaseFinalize, [&context, &step]()
  185. {
  186. // Validate that all find collision jobs have stopped
  187. JPH_ASSERT(step.mActiveFindCollisionJobs == 0);
  188. // Finalize the broadphase update
  189. context.mPhysicsSystem->mBroadPhase->UpdateFinalize(step.mBroadPhaseUpdateState);
  190. // Signal that it is done
  191. step.mPreIntegrateVelocity.RemoveDependency();
  192. }, num_find_collisions_jobs + 2); // depends on: find collisions, broadphase prepare update, finish building jobs
  193. // The immediate jobs below are only immediate for the first step, the all finished job will kick them for the next step
  194. int previous_step_dependency_count = is_first_step? 0 : 1;
  195. // Start job immediately: Start the prepare broadphase
  196. // Must be done under body lock protection since the order is body locks then broadphase mutex
  197. // If this is turned around the RemoveBody call will hang since it locks in that order
  198. step.mBroadPhasePrepare = inJobSystem->CreateJob("UpdateBroadPhasePrepare", cColorUpdateBroadPhasePrepare, [&context, &step]()
  199. {
  200. // Prepare the broadphase update
  201. step.mBroadPhaseUpdateState = context.mPhysicsSystem->mBroadPhase->UpdatePrepare();
  202. // Now the finalize can run (if other dependencies are met too)
  203. step.mUpdateBroadphaseFinalize.RemoveDependency();
  204. }, previous_step_dependency_count);
  205. // This job will find all collisions
  206. step.mBodyPairQueues.resize(max_concurrency);
  207. step.mMaxBodyPairsPerQueue = mPhysicsSettings.mMaxInFlightBodyPairs / max_concurrency;
  208. step.mActiveFindCollisionJobs = ~PhysicsUpdateContext::JobMask(0) >> (sizeof(PhysicsUpdateContext::JobMask) * 8 - num_find_collisions_jobs);
  209. step.mFindCollisions.resize(num_find_collisions_jobs);
  210. for (int i = 0; i < num_find_collisions_jobs; ++i)
  211. {
  212. // Build islands from constraints may activate additional bodies, so the first job will wait for this to finish in order to not miss any active bodies
  213. int num_dep_build_islands_from_constraints = i == 0? 1 : 0;
  214. step.mFindCollisions[i] = inJobSystem->CreateJob("FindCollisions", cColorFindCollisions, [&step, i]()
  215. {
  216. step.mContext->mPhysicsSystem->JobFindCollisions(&step, i);
  217. }, num_apply_gravity_jobs + num_determine_active_constraints_jobs + 1 + num_dep_build_islands_from_constraints); // depends on: apply gravity, determine active constraints, finish building jobs, build islands from constraints
  218. }
  219. if (is_first_step)
  220. {
  221. #ifdef JPH_ENABLE_ASSERTS
  222. // Don't allow write operations to the active bodies list
  223. mBodyManager.SetActiveBodiesLocked(true);
  224. #endif
  225. // Store the number of active bodies at the start of the step
  226. step.mNumActiveBodiesAtStepStart = mBodyManager.GetNumActiveBodies(EBodyType::RigidBody);
  227. // Lock all constraints
  228. mConstraintManager.LockAllConstraints();
  229. // Allocate memory for storing the active constraints
  230. JPH_ASSERT(context.mActiveConstraints == nullptr);
  231. context.mActiveConstraints = static_cast<Constraint **>(inTempAllocator->Allocate(mConstraintManager.GetNumConstraints() * sizeof(Constraint *)));
  232. // Prepare contact buffer
  233. mContactManager.PrepareConstraintBuffer(&context);
  234. // Setup island builder
  235. mIslandBuilder.PrepareContactConstraints(mContactManager.GetMaxConstraints(), context.mTempAllocator);
  236. }
  237. // This job applies gravity to all active bodies
  238. step.mApplyGravity.resize(num_apply_gravity_jobs);
  239. for (int i = 0; i < num_apply_gravity_jobs; ++i)
  240. step.mApplyGravity[i] = inJobSystem->CreateJob("ApplyGravity", cColorApplyGravity, [&context, &step]()
  241. {
  242. context.mPhysicsSystem->JobApplyGravity(&context, &step);
  243. JobHandle::sRemoveDependencies(step.mFindCollisions);
  244. }, num_step_listener_jobs > 0? num_step_listener_jobs : previous_step_dependency_count); // depends on: step listeners (or previous step if no step listeners)
  245. // This job will setup velocity constraints for non-collision constraints
  246. step.mSetupVelocityConstraints.resize(num_setup_velocity_constraints_jobs);
  247. for (int i = 0; i < num_setup_velocity_constraints_jobs; ++i)
  248. step.mSetupVelocityConstraints[i] = inJobSystem->CreateJob("SetupVelocityConstraints", cColorSetupVelocityConstraints, [&context, &step]()
  249. {
  250. context.mPhysicsSystem->JobSetupVelocityConstraints(context.mStepDeltaTime, &step);
  251. JobHandle::sRemoveDependencies(step.mSolveVelocityConstraints);
  252. }, num_determine_active_constraints_jobs + 1); // depends on: determine active constraints, finish building jobs
  253. // This job will build islands from constraints
  254. step.mBuildIslandsFromConstraints = inJobSystem->CreateJob("BuildIslandsFromConstraints", cColorBuildIslandsFromConstraints, [&context, &step]()
  255. {
  256. context.mPhysicsSystem->JobBuildIslandsFromConstraints(&context, &step);
  257. step.mFindCollisions[0].RemoveDependency(); // The first collisions job cannot start running until we've finished building islands and activated all bodies
  258. step.mFinalizeIslands.RemoveDependency();
  259. }, num_determine_active_constraints_jobs + 1); // depends on: determine active constraints, finish building jobs
  260. // This job determines active constraints
  261. step.mDetermineActiveConstraints.resize(num_determine_active_constraints_jobs);
  262. for (int i = 0; i < num_determine_active_constraints_jobs; ++i)
  263. step.mDetermineActiveConstraints[i] = inJobSystem->CreateJob("DetermineActiveConstraints", cColorDetermineActiveConstraints, [&context, &step]()
  264. {
  265. context.mPhysicsSystem->JobDetermineActiveConstraints(&step);
  266. step.mBuildIslandsFromConstraints.RemoveDependency();
  267. // Kick these jobs last as they will use up all CPU cores leaving no space for the previous job, we prefer setup velocity constraints to finish first so we kick it first
  268. JobHandle::sRemoveDependencies(step.mSetupVelocityConstraints);
  269. JobHandle::sRemoveDependencies(step.mFindCollisions);
  270. }, num_step_listener_jobs > 0? num_step_listener_jobs : previous_step_dependency_count); // depends on: step listeners (or previous step if no step listeners)
  271. // This job calls the step listeners
  272. step.mStepListeners.resize(num_step_listener_jobs);
  273. for (int i = 0; i < num_step_listener_jobs; ++i)
  274. step.mStepListeners[i] = inJobSystem->CreateJob("StepListeners", cColorStepListeners, [&context, &step]()
  275. {
  276. // Call the step listeners
  277. context.mPhysicsSystem->JobStepListeners(&step);
  278. // Kick apply gravity and determine active constraint jobs
  279. JobHandle::sRemoveDependencies(step.mApplyGravity);
  280. JobHandle::sRemoveDependencies(step.mDetermineActiveConstraints);
  281. }, previous_step_dependency_count);
  282. // Unblock the previous step
  283. if (!is_first_step)
  284. context.mSteps[step_idx - 1].mStartNextStep.RemoveDependency();
  285. // This job will finalize the simulation islands
  286. step.mFinalizeIslands = inJobSystem->CreateJob("FinalizeIslands", cColorFinalizeIslands, [&context, &step]()
  287. {
  288. // Validate that all find collision jobs have stopped
  289. JPH_ASSERT(step.mActiveFindCollisionJobs == 0);
  290. context.mPhysicsSystem->JobFinalizeIslands(&context);
  291. JobHandle::sRemoveDependencies(step.mSolveVelocityConstraints);
  292. step.mBodySetIslandIndex.RemoveDependency();
  293. }, num_find_collisions_jobs + 2); // depends on: find collisions, build islands from constraints, finish building jobs
  294. // Unblock previous job
  295. // Note: technically we could release find collisions here but we don't want to because that could make them run before 'setup velocity constraints' which means that job won't have a thread left
  296. step.mBuildIslandsFromConstraints.RemoveDependency();
  297. // This job will call the contact removed callbacks
  298. step.mContactRemovedCallbacks = inJobSystem->CreateJob("ContactRemovedCallbacks", cColorContactRemovedCallbacks, [&context, &step]()
  299. {
  300. context.mPhysicsSystem->JobContactRemovedCallbacks(&step);
  301. if (step.mStartNextStep.IsValid())
  302. step.mStartNextStep.RemoveDependency();
  303. }, 1); // depends on the find ccd contacts
  304. // This job will set the island index on each body (only used for debug drawing purposes)
  305. // It will also delete any bodies that have been destroyed in the last frame
  306. step.mBodySetIslandIndex = inJobSystem->CreateJob("BodySetIslandIndex", cColorBodySetIslandIndex, [&context, &step]()
  307. {
  308. context.mPhysicsSystem->JobBodySetIslandIndex();
  309. JobHandle::sRemoveDependencies(step.mSolvePositionConstraints);
  310. }, 2); // depends on: finalize islands, finish building jobs
  311. // Job to start the next collision step
  312. if (!is_last_step)
  313. {
  314. PhysicsUpdateContext::Step *next_step = &context.mSteps[step_idx + 1];
  315. step.mStartNextStep = inJobSystem->CreateJob("StartNextStep", cColorStartNextStep, [this, next_step]()
  316. {
  317. #ifdef JPH_DEBUG
  318. // Validate that the cached bounds are correct
  319. mBodyManager.ValidateActiveBodyBounds();
  320. #endif // JPH_DEBUG
  321. // Store the number of active bodies at the start of the step
  322. next_step->mNumActiveBodiesAtStepStart = mBodyManager.GetNumActiveBodies(EBodyType::RigidBody);
  323. // Clear the large island splitter
  324. TempAllocator *temp_allocator = next_step->mContext->mTempAllocator;
  325. mLargeIslandSplitter.Reset(temp_allocator);
  326. // Clear the island builder
  327. mIslandBuilder.ResetIslands(temp_allocator);
  328. // Setup island builder
  329. mIslandBuilder.PrepareContactConstraints(mContactManager.GetMaxConstraints(), temp_allocator);
  330. // Restart the contact manager
  331. mContactManager.RecycleConstraintBuffer();
  332. // Kick the jobs of the next step (in the same order as the first step)
  333. next_step->mBroadPhasePrepare.RemoveDependency();
  334. if (next_step->mStepListeners.empty())
  335. {
  336. // Kick the gravity and active constraints jobs immediately
  337. JobHandle::sRemoveDependencies(next_step->mApplyGravity);
  338. JobHandle::sRemoveDependencies(next_step->mDetermineActiveConstraints);
  339. }
  340. else
  341. {
  342. // Kick the step listeners job first
  343. JobHandle::sRemoveDependencies(next_step->mStepListeners);
  344. }
  345. }, 3); // depends on: update soft bodies, contact removed callbacks, finish building the previous step
  346. }
  347. // This job will solve the velocity constraints
  348. step.mSolveVelocityConstraints.resize(max_concurrency);
  349. for (int i = 0; i < max_concurrency; ++i)
  350. step.mSolveVelocityConstraints[i] = inJobSystem->CreateJob("SolveVelocityConstraints", cColorSolveVelocityConstraints, [&context, &step]()
  351. {
  352. context.mPhysicsSystem->JobSolveVelocityConstraints(&context, &step);
  353. step.mPreIntegrateVelocity.RemoveDependency();
  354. }, num_setup_velocity_constraints_jobs + 2); // depends on: finalize islands, setup velocity constraints, finish building jobs.
  355. // We prefer setup velocity constraints to finish first so we kick it first
  356. JobHandle::sRemoveDependencies(step.mSetupVelocityConstraints);
  357. JobHandle::sRemoveDependencies(step.mFindCollisions);
  358. // Finalize islands is a dependency on find collisions so it can go last
  359. step.mFinalizeIslands.RemoveDependency();
  360. // This job will prepare the position update of all active bodies
  361. step.mPreIntegrateVelocity = inJobSystem->CreateJob("PreIntegrateVelocity", cColorPreIntegrateVelocity, [&context, &step]()
  362. {
  363. context.mPhysicsSystem->JobPreIntegrateVelocity(&context, &step);
  364. JobHandle::sRemoveDependencies(step.mIntegrateVelocity);
  365. }, 2 + max_concurrency); // depends on: broadphase update finalize, solve velocity constraints, finish building jobs.
  366. // Unblock previous jobs
  367. step.mUpdateBroadphaseFinalize.RemoveDependency();
  368. JobHandle::sRemoveDependencies(step.mSolveVelocityConstraints);
  369. // This job will update the positions of all active bodies
  370. step.mIntegrateVelocity.resize(num_integrate_velocity_jobs);
  371. for (int i = 0; i < num_integrate_velocity_jobs; ++i)
  372. step.mIntegrateVelocity[i] = inJobSystem->CreateJob("IntegrateVelocity", cColorIntegrateVelocity, [&context, &step]()
  373. {
  374. context.mPhysicsSystem->JobIntegrateVelocity(&context, &step);
  375. step.mPostIntegrateVelocity.RemoveDependency();
  376. }, 2); // depends on: pre integrate velocity, finish building jobs.
  377. // Unblock previous job
  378. step.mPreIntegrateVelocity.RemoveDependency();
  379. // This job will finish the position update of all active bodies
  380. step.mPostIntegrateVelocity = inJobSystem->CreateJob("PostIntegrateVelocity", cColorPostIntegrateVelocity, [&context, &step]()
  381. {
  382. context.mPhysicsSystem->JobPostIntegrateVelocity(&context, &step);
  383. step.mResolveCCDContacts.RemoveDependency();
  384. }, num_integrate_velocity_jobs + 1); // depends on: integrate velocity, finish building jobs
  385. // Unblock previous jobs
  386. JobHandle::sRemoveDependencies(step.mIntegrateVelocity);
  387. // This job will update the positions and velocities for all bodies that need continuous collision detection
  388. step.mResolveCCDContacts = inJobSystem->CreateJob("ResolveCCDContacts", cColorResolveCCDContacts, [&context, &step]()
  389. {
  390. context.mPhysicsSystem->JobResolveCCDContacts(&context, &step);
  391. JobHandle::sRemoveDependencies(step.mSolvePositionConstraints);
  392. }, 2); // depends on: integrate velocities, detect ccd contacts (added dynamically), finish building jobs.
  393. // Unblock previous job
  394. step.mPostIntegrateVelocity.RemoveDependency();
  395. // Fixes up drift in positions and updates the broadphase with new body positions
  396. step.mSolvePositionConstraints.resize(max_concurrency);
  397. for (int i = 0; i < max_concurrency; ++i)
  398. step.mSolvePositionConstraints[i] = inJobSystem->CreateJob("SolvePositionConstraints", cColorSolvePositionConstraints, [&context, &step]()
  399. {
  400. context.mPhysicsSystem->JobSolvePositionConstraints(&context, &step);
  401. // Kick the next step
  402. if (step.mSoftBodyPrepare.IsValid())
  403. step.mSoftBodyPrepare.RemoveDependency();
  404. }, 3); // depends on: resolve ccd contacts, body set island index, finish building jobs.
  405. // Unblock previous jobs.
  406. step.mResolveCCDContacts.RemoveDependency();
  407. step.mBodySetIslandIndex.RemoveDependency();
  408. // The soft body prepare job will create other jobs if needed
  409. step.mSoftBodyPrepare = inJobSystem->CreateJob("SoftBodyPrepare", cColorSoftBodyPrepare, [&context, &step]()
  410. {
  411. context.mPhysicsSystem->JobSoftBodyPrepare(&context, &step);
  412. }, max_concurrency); // depends on: solve position constraints.
  413. // Unblock previous jobs
  414. JobHandle::sRemoveDependencies(step.mSolvePositionConstraints);
  415. }
  416. }
  417. // Build the list of jobs to wait for
  418. JobSystem::Barrier *barrier = context.mBarrier;
  419. {
  420. JPH_PROFILE("Build job barrier");
  421. StaticArray<JobHandle, cMaxPhysicsJobs> handles;
  422. for (const PhysicsUpdateContext::Step &step : context.mSteps)
  423. {
  424. if (step.mBroadPhasePrepare.IsValid())
  425. handles.push_back(step.mBroadPhasePrepare);
  426. for (const JobHandle &h : step.mStepListeners)
  427. handles.push_back(h);
  428. for (const JobHandle &h : step.mDetermineActiveConstraints)
  429. handles.push_back(h);
  430. for (const JobHandle &h : step.mApplyGravity)
  431. handles.push_back(h);
  432. for (const JobHandle &h : step.mFindCollisions)
  433. handles.push_back(h);
  434. if (step.mUpdateBroadphaseFinalize.IsValid())
  435. handles.push_back(step.mUpdateBroadphaseFinalize);
  436. for (const JobHandle &h : step.mSetupVelocityConstraints)
  437. handles.push_back(h);
  438. handles.push_back(step.mBuildIslandsFromConstraints);
  439. handles.push_back(step.mFinalizeIslands);
  440. handles.push_back(step.mBodySetIslandIndex);
  441. for (const JobHandle &h : step.mSolveVelocityConstraints)
  442. handles.push_back(h);
  443. handles.push_back(step.mPreIntegrateVelocity);
  444. for (const JobHandle &h : step.mIntegrateVelocity)
  445. handles.push_back(h);
  446. handles.push_back(step.mPostIntegrateVelocity);
  447. handles.push_back(step.mResolveCCDContacts);
  448. for (const JobHandle &h : step.mSolvePositionConstraints)
  449. handles.push_back(h);
  450. handles.push_back(step.mContactRemovedCallbacks);
  451. if (step.mSoftBodyPrepare.IsValid())
  452. handles.push_back(step.mSoftBodyPrepare);
  453. if (step.mStartNextStep.IsValid())
  454. handles.push_back(step.mStartNextStep);
  455. }
  456. barrier->AddJobs(handles.data(), handles.size());
  457. }
  458. // Wait until all jobs finish
  459. // Note we don't just wait for the last job. If we would and another job
  460. // would be scheduled in between there is the possibility of a deadlock.
  461. // The other job could try to e.g. add/remove a body which would try to
  462. // lock a body mutex while this thread has already locked the mutex
  463. inJobSystem->WaitForJobs(barrier);
  464. // We're done with the barrier for this update
  465. inJobSystem->DestroyBarrier(barrier);
  466. #ifdef JPH_DEBUG
  467. // Validate that the cached bounds are correct
  468. mBodyManager.ValidateActiveBodyBounds();
  469. #endif // JPH_DEBUG
  470. // Clear the large island splitter
  471. mLargeIslandSplitter.Reset(inTempAllocator);
  472. // Clear the island builder
  473. mIslandBuilder.ResetIslands(inTempAllocator);
  474. // Clear the contact manager
  475. mContactManager.FinishConstraintBuffer();
  476. // Free active constraints
  477. inTempAllocator->Free(context.mActiveConstraints, mConstraintManager.GetNumConstraints() * sizeof(Constraint *));
  478. context.mActiveConstraints = nullptr;
  479. // Free body pairs
  480. inTempAllocator->Free(context.mBodyPairs, sizeof(BodyPair) * mPhysicsSettings.mMaxInFlightBodyPairs);
  481. context.mBodyPairs = nullptr;
  482. // Unlock the broadphase
  483. mBroadPhase->UnlockModifications();
  484. // Unlock all constraints
  485. mConstraintManager.UnlockAllConstraints();
  486. #ifdef JPH_ENABLE_ASSERTS
  487. // Allow write operations to the active bodies list
  488. mBodyManager.SetActiveBodiesLocked(false);
  489. #endif
  490. // Unlock all bodies
  491. mBodyManager.UnlockAllBodies();
  492. // Unlock step listeners
  493. mStepListenersMutex.unlock();
  494. // Return any errors
  495. EPhysicsUpdateError errors = static_cast<EPhysicsUpdateError>(context.mErrors.load(memory_order_acquire));
  496. JPH_ASSERT(errors == EPhysicsUpdateError::None, "An error occurred during the physics update, see EPhysicsUpdateError for more information");
  497. return errors;
  498. }
  499. void PhysicsSystem::JobStepListeners(PhysicsUpdateContext::Step *ioStep)
  500. {
  501. #ifdef JPH_ENABLE_ASSERTS
  502. // Read positions (broadphase updates concurrently so we can't write), read/write velocities
  503. BodyAccess::Grant grant(BodyAccess::EAccess::ReadWrite, BodyAccess::EAccess::Read);
  504. // Can activate bodies only (we cache the amount of active bodies at the beginning of the step in mNumActiveBodiesAtStepStart so we cannot deactivate here)
  505. BodyManager::GrantActiveBodiesAccess grant_active(true, false);
  506. #endif
  507. PhysicsStepListenerContext context;
  508. context.mDeltaTime = ioStep->mContext->mStepDeltaTime;
  509. context.mIsFirstStep = ioStep->mIsFirst;
  510. context.mIsLastStep = ioStep->mIsLast;
  511. context.mPhysicsSystem = this;
  512. uint32 batch_size = mPhysicsSettings.mStepListenersBatchSize;
  513. for (;;)
  514. {
  515. // Get the start of a new batch
  516. uint32 batch = ioStep->mStepListenerReadIdx.fetch_add(batch_size);
  517. if (batch >= mStepListeners.size())
  518. break;
  519. // Call the listeners
  520. for (uint32 i = batch, i_end = min((uint32)mStepListeners.size(), batch + batch_size); i < i_end; ++i)
  521. mStepListeners[i]->OnStep(context);
  522. }
  523. }
  524. void PhysicsSystem::JobDetermineActiveConstraints(PhysicsUpdateContext::Step *ioStep) const
  525. {
  526. #ifdef JPH_ENABLE_ASSERTS
  527. // No body access
  528. BodyAccess::Grant grant(BodyAccess::EAccess::None, BodyAccess::EAccess::None);
  529. #endif
  530. uint32 num_constraints = mConstraintManager.GetNumConstraints();
  531. uint32 num_active_constraints;
  532. Constraint **active_constraints = (Constraint **)JPH_STACK_ALLOC(cDetermineActiveConstraintsBatchSize * sizeof(Constraint *));
  533. for (;;)
  534. {
  535. // Atomically fetch a batch of constraints
  536. uint32 constraint_idx = ioStep->mDetermineActiveConstraintReadIdx.fetch_add(cDetermineActiveConstraintsBatchSize);
  537. if (constraint_idx >= num_constraints)
  538. break;
  539. // Calculate the end of the batch
  540. uint32 constraint_idx_end = min(num_constraints, constraint_idx + cDetermineActiveConstraintsBatchSize);
  541. // Store the active constraints at the start of the step (bodies get activated during the step which in turn may activate constraints leading to an inconsistent shapshot)
  542. mConstraintManager.GetActiveConstraints(constraint_idx, constraint_idx_end, active_constraints, num_active_constraints);
  543. // Copy the block of active constraints to the global list of active constraints
  544. if (num_active_constraints > 0)
  545. {
  546. uint32 active_constraint_idx = ioStep->mNumActiveConstraints.fetch_add(num_active_constraints);
  547. memcpy(ioStep->mContext->mActiveConstraints + active_constraint_idx, active_constraints, num_active_constraints * sizeof(Constraint *));
  548. }
  549. }
  550. }
  551. void PhysicsSystem::JobApplyGravity(const PhysicsUpdateContext *ioContext, PhysicsUpdateContext::Step *ioStep)
  552. {
  553. #ifdef JPH_ENABLE_ASSERTS
  554. // We update velocities and need the rotation to do so
  555. BodyAccess::Grant grant(BodyAccess::EAccess::ReadWrite, BodyAccess::EAccess::Read);
  556. #endif
  557. // Get list of active bodies that we had at the start of the physics update.
  558. // Any body that is activated as part of the simulation step does not receive gravity this frame.
  559. // Note that bodies may be activated during this job but not deactivated, this means that only elements
  560. // will be added to the array. Since the array is made to not reallocate, this is a safe operation.
  561. const BodyID *active_bodies = mBodyManager.GetActiveBodiesUnsafe(EBodyType::RigidBody);
  562. uint32 num_active_bodies_at_step_start = ioStep->mNumActiveBodiesAtStepStart;
  563. // Fetch delta time once outside the loop
  564. float delta_time = ioContext->mStepDeltaTime;
  565. // Update velocities from forces
  566. for (;;)
  567. {
  568. // Atomically fetch a batch of bodies
  569. uint32 active_body_idx = ioStep->mApplyGravityReadIdx.fetch_add(cApplyGravityBatchSize);
  570. if (active_body_idx >= num_active_bodies_at_step_start)
  571. break;
  572. // Calculate the end of the batch
  573. uint32 active_body_idx_end = min(num_active_bodies_at_step_start, active_body_idx + cApplyGravityBatchSize);
  574. // Process the batch
  575. while (active_body_idx < active_body_idx_end)
  576. {
  577. Body &body = mBodyManager.GetBody(active_bodies[active_body_idx]);
  578. if (body.IsDynamic())
  579. {
  580. MotionProperties *mp = body.GetMotionProperties();
  581. Quat rotation = body.GetRotation();
  582. if (body.GetApplyGyroscopicForce())
  583. mp->ApplyGyroscopicForceInternal(rotation, delta_time);
  584. mp->ApplyForceTorqueAndDragInternal(rotation, mGravity, delta_time);
  585. }
  586. active_body_idx++;
  587. }
  588. }
  589. }
  590. void PhysicsSystem::JobSetupVelocityConstraints(float inDeltaTime, PhysicsUpdateContext::Step *ioStep) const
  591. {
  592. #ifdef JPH_ENABLE_ASSERTS
  593. // We only read positions
  594. BodyAccess::Grant grant(BodyAccess::EAccess::None, BodyAccess::EAccess::Read);
  595. #endif
  596. uint32 num_constraints = ioStep->mNumActiveConstraints;
  597. for (;;)
  598. {
  599. // Atomically fetch a batch of constraints
  600. uint32 constraint_idx = ioStep->mSetupVelocityConstraintsReadIdx.fetch_add(cSetupVelocityConstraintsBatchSize);
  601. if (constraint_idx >= num_constraints)
  602. break;
  603. ConstraintManager::sSetupVelocityConstraints(ioStep->mContext->mActiveConstraints + constraint_idx, min<uint32>(cSetupVelocityConstraintsBatchSize, num_constraints - constraint_idx), inDeltaTime);
  604. }
  605. }
  606. void PhysicsSystem::JobBuildIslandsFromConstraints(PhysicsUpdateContext *ioContext, PhysicsUpdateContext::Step *ioStep)
  607. {
  608. #ifdef JPH_ENABLE_ASSERTS
  609. // We read constraints and positions
  610. BodyAccess::Grant grant(BodyAccess::EAccess::None, BodyAccess::EAccess::Read);
  611. // Can only activate bodies
  612. BodyManager::GrantActiveBodiesAccess grant_active(true, false);
  613. #endif
  614. // Prepare the island builder
  615. mIslandBuilder.PrepareNonContactConstraints(ioStep->mNumActiveConstraints, ioContext->mTempAllocator);
  616. // Build the islands
  617. ConstraintManager::sBuildIslands(ioStep->mContext->mActiveConstraints, ioStep->mNumActiveConstraints, mIslandBuilder, mBodyManager);
  618. }
  619. void PhysicsSystem::TrySpawnJobFindCollisions(PhysicsUpdateContext::Step *ioStep) const
  620. {
  621. // Get how many jobs we can spawn and check if we can spawn more
  622. uint max_jobs = ioStep->mBodyPairQueues.size();
  623. if (CountBits(ioStep->mActiveFindCollisionJobs) >= max_jobs)
  624. return;
  625. // Count how many body pairs we have waiting
  626. uint32 num_body_pairs = 0;
  627. for (const PhysicsUpdateContext::BodyPairQueue &queue : ioStep->mBodyPairQueues)
  628. num_body_pairs += queue.mWriteIdx - queue.mReadIdx;
  629. // Count how many active bodies we have waiting
  630. uint32 num_active_bodies = mBodyManager.GetNumActiveBodies(EBodyType::RigidBody) - ioStep->mActiveBodyReadIdx;
  631. // Calculate how many jobs we would like
  632. uint desired_num_jobs = min((num_body_pairs + cNarrowPhaseBatchSize - 1) / cNarrowPhaseBatchSize + (num_active_bodies + cActiveBodiesBatchSize - 1) / cActiveBodiesBatchSize, max_jobs);
  633. for (;;)
  634. {
  635. // Get the bit mask of active jobs and see if we can spawn more
  636. PhysicsUpdateContext::JobMask current_active_jobs = ioStep->mActiveFindCollisionJobs;
  637. if (CountBits(current_active_jobs) >= desired_num_jobs)
  638. break;
  639. // Loop through all possible job indices
  640. for (uint job_index = 0; job_index < max_jobs; ++job_index)
  641. {
  642. // Test if it has been started
  643. PhysicsUpdateContext::JobMask job_mask = PhysicsUpdateContext::JobMask(1) << job_index;
  644. if ((current_active_jobs & job_mask) == 0)
  645. {
  646. // Try to claim the job index
  647. PhysicsUpdateContext::JobMask prev_value = ioStep->mActiveFindCollisionJobs.fetch_or(job_mask);
  648. if ((prev_value & job_mask) == 0)
  649. {
  650. // Add dependencies from the find collisions job to the next jobs
  651. ioStep->mUpdateBroadphaseFinalize.AddDependency();
  652. ioStep->mFinalizeIslands.AddDependency();
  653. // Start the job
  654. JobHandle job = ioStep->mContext->mJobSystem->CreateJob("FindCollisions", cColorFindCollisions, [step = ioStep, job_index]()
  655. {
  656. step->mContext->mPhysicsSystem->JobFindCollisions(step, job_index);
  657. });
  658. // Add the job to the job barrier so the main updating thread can execute the job too
  659. ioStep->mContext->mBarrier->AddJob(job);
  660. // Spawn only 1 extra job at a time
  661. return;
  662. }
  663. }
  664. }
  665. }
  666. }
  667. static void sFinalizeContactAllocator(PhysicsUpdateContext::Step &ioStep, const ContactConstraintManager::ContactAllocator &inAllocator)
  668. {
  669. // Atomically accumulate the number of found manifolds and body pairs
  670. ioStep.mNumBodyPairs.fetch_add(inAllocator.mNumBodyPairs, memory_order_relaxed);
  671. ioStep.mNumManifolds.fetch_add(inAllocator.mNumManifolds, memory_order_relaxed);
  672. // Combine update errors
  673. ioStep.mContext->mErrors.fetch_or((uint32)inAllocator.mErrors, memory_order_relaxed);
  674. }
  675. // Disable TSAN for this function. It detects a false positive race condition on mBodyPairs.
  676. // We have written mBodyPairs before doing mWriteIdx++ and we check mWriteIdx before reading mBodyPairs, so this should be safe.
  677. JPH_TSAN_NO_SANITIZE
  678. void PhysicsSystem::JobFindCollisions(PhysicsUpdateContext::Step *ioStep, int inJobIndex)
  679. {
  680. #ifdef JPH_ENABLE_ASSERTS
  681. // We read positions and read velocities (for elastic collisions)
  682. BodyAccess::Grant grant(BodyAccess::EAccess::Read, BodyAccess::EAccess::Read);
  683. // Can only activate bodies
  684. BodyManager::GrantActiveBodiesAccess grant_active(true, false);
  685. #endif
  686. // Allocation context for allocating new contact points
  687. ContactAllocator contact_allocator(mContactManager.GetContactAllocator());
  688. // Determine initial queue to read pairs from if no broadphase work can be done
  689. // (always start looking at results from the next job)
  690. int read_queue_idx = (inJobIndex + 1) % ioStep->mBodyPairQueues.size();
  691. for (;;)
  692. {
  693. // Check if there are active bodies to be processed
  694. uint32 active_bodies_read_idx = ioStep->mActiveBodyReadIdx;
  695. uint32 num_active_bodies = mBodyManager.GetNumActiveBodies(EBodyType::RigidBody);
  696. if (active_bodies_read_idx < num_active_bodies)
  697. {
  698. // Take a batch of active bodies
  699. uint32 active_bodies_read_idx_end = min(num_active_bodies, active_bodies_read_idx + cActiveBodiesBatchSize);
  700. if (ioStep->mActiveBodyReadIdx.compare_exchange_strong(active_bodies_read_idx, active_bodies_read_idx_end))
  701. {
  702. // Callback when a new body pair is found
  703. class MyBodyPairCallback : public BodyPairCollector
  704. {
  705. public:
  706. // Constructor
  707. MyBodyPairCallback(PhysicsUpdateContext::Step *inStep, ContactAllocator &ioContactAllocator, int inJobIndex) :
  708. mStep(inStep),
  709. mContactAllocator(ioContactAllocator),
  710. mJobIndex(inJobIndex)
  711. {
  712. }
  713. // Callback function when a body pair is found
  714. virtual void AddHit(const BodyPair &inPair) override
  715. {
  716. // Check if we have space in our write queue
  717. PhysicsUpdateContext::BodyPairQueue &queue = mStep->mBodyPairQueues[mJobIndex];
  718. uint32 body_pairs_in_queue = queue.mWriteIdx - queue.mReadIdx;
  719. if (body_pairs_in_queue >= mStep->mMaxBodyPairsPerQueue)
  720. {
  721. // Buffer full, process the pair now
  722. mStep->mContext->mPhysicsSystem->ProcessBodyPair(mContactAllocator, inPair);
  723. }
  724. else
  725. {
  726. // Store the pair in our own queue
  727. mStep->mContext->mBodyPairs[mJobIndex * mStep->mMaxBodyPairsPerQueue + queue.mWriteIdx % mStep->mMaxBodyPairsPerQueue] = inPair;
  728. ++queue.mWriteIdx;
  729. }
  730. }
  731. private:
  732. PhysicsUpdateContext::Step * mStep;
  733. ContactAllocator & mContactAllocator;
  734. int mJobIndex;
  735. };
  736. MyBodyPairCallback add_pair(ioStep, contact_allocator, inJobIndex);
  737. // Copy active bodies to temporary array, broadphase will reorder them
  738. uint32 batch_size = active_bodies_read_idx_end - active_bodies_read_idx;
  739. BodyID *active_bodies = (BodyID *)JPH_STACK_ALLOC(batch_size * sizeof(BodyID));
  740. memcpy(active_bodies, mBodyManager.GetActiveBodiesUnsafe(EBodyType::RigidBody) + active_bodies_read_idx, batch_size * sizeof(BodyID));
  741. // Find pairs in the broadphase
  742. mBroadPhase->FindCollidingPairs(active_bodies, batch_size, mPhysicsSettings.mSpeculativeContactDistance, *mObjectVsBroadPhaseLayerFilter, *mObjectLayerPairFilter, add_pair);
  743. // Check if we have enough pairs in the buffer to start a new job
  744. const PhysicsUpdateContext::BodyPairQueue &queue = ioStep->mBodyPairQueues[inJobIndex];
  745. uint32 body_pairs_in_queue = queue.mWriteIdx - queue.mReadIdx;
  746. if (body_pairs_in_queue >= cNarrowPhaseBatchSize)
  747. TrySpawnJobFindCollisions(ioStep);
  748. }
  749. }
  750. else
  751. {
  752. // Lockless loop to get the next body pair from the pairs buffer
  753. const PhysicsUpdateContext *context = ioStep->mContext;
  754. int first_read_queue_idx = read_queue_idx;
  755. for (;;)
  756. {
  757. PhysicsUpdateContext::BodyPairQueue &queue = ioStep->mBodyPairQueues[read_queue_idx];
  758. // Get the next pair to process
  759. uint32 pair_idx = queue.mReadIdx;
  760. // If the pair hasn't been written yet
  761. if (pair_idx >= queue.mWriteIdx)
  762. {
  763. // Go to the next queue
  764. read_queue_idx = (read_queue_idx + 1) % ioStep->mBodyPairQueues.size();
  765. // If we're back at the first queue, we've looked at all of them and found nothing
  766. if (read_queue_idx == first_read_queue_idx)
  767. {
  768. // Collect information from the contact allocator and accumulate it in the step.
  769. sFinalizeContactAllocator(*ioStep, contact_allocator);
  770. // Mark this job as inactive
  771. ioStep->mActiveFindCollisionJobs.fetch_and(~PhysicsUpdateContext::JobMask(1 << inJobIndex));
  772. // Trigger the next jobs
  773. ioStep->mUpdateBroadphaseFinalize.RemoveDependency();
  774. ioStep->mFinalizeIslands.RemoveDependency();
  775. return;
  776. }
  777. // Try again reading from the next queue
  778. continue;
  779. }
  780. // Copy the body pair out of the buffer
  781. const BodyPair bp = context->mBodyPairs[read_queue_idx * ioStep->mMaxBodyPairsPerQueue + pair_idx % ioStep->mMaxBodyPairsPerQueue];
  782. // Mark this pair as taken
  783. if (queue.mReadIdx.compare_exchange_strong(pair_idx, pair_idx + 1))
  784. {
  785. // Process the actual body pair
  786. ProcessBodyPair(contact_allocator, bp);
  787. break;
  788. }
  789. }
  790. }
  791. }
  792. }
  793. void PhysicsSystem::ProcessBodyPair(ContactAllocator &ioContactAllocator, const BodyPair &inBodyPair)
  794. {
  795. JPH_PROFILE_FUNCTION();
  796. // Fetch body pair
  797. Body *body1 = &mBodyManager.GetBody(inBodyPair.mBodyA);
  798. Body *body2 = &mBodyManager.GetBody(inBodyPair.mBodyB);
  799. JPH_ASSERT(body1->IsActive());
  800. JPH_DET_LOG("ProcessBodyPair: id1: " << inBodyPair.mBodyA << " id2: " << inBodyPair.mBodyB << " p1: " << body1->GetCenterOfMassPosition() << " p2: " << body2->GetCenterOfMassPosition() << " r1: " << body1->GetRotation() << " r2: " << body2->GetRotation());
  801. // Check for soft bodies
  802. if (body2->IsSoftBody())
  803. {
  804. // If the 2nd body is a soft body and not active, we activate it now
  805. if (!body2->IsActive())
  806. mBodyManager.ActivateBodies(&inBodyPair.mBodyB, 1);
  807. // Soft body processing is done later in the pipeline
  808. return;
  809. }
  810. // Ensure that body1 has the higher motion type (i.e. dynamic trumps kinematic), this ensures that we do the collision detection in the space of a moving body,
  811. // which avoids accuracy problems when testing a very large static object against a small dynamic object
  812. // Ensure that body1 id < body2 id when motion types are the same.
  813. if (body1->GetMotionType() < body2->GetMotionType()
  814. || (body1->GetMotionType() == body2->GetMotionType() && inBodyPair.mBodyB < inBodyPair.mBodyA))
  815. swap(body1, body2);
  816. // Check if the contact points from the previous frame are reusable and if so copy them
  817. bool pair_handled = false, constraint_created = false;
  818. if (mPhysicsSettings.mUseBodyPairContactCache && !(body1->IsCollisionCacheInvalid() || body2->IsCollisionCacheInvalid()))
  819. mContactManager.GetContactsFromCache(ioContactAllocator, *body1, *body2, pair_handled, constraint_created);
  820. // If the cache hasn't handled this body pair do actual collision detection
  821. if (!pair_handled)
  822. {
  823. // Create entry in the cache for this body pair
  824. // Needs to happen irrespective if we found a collision or not (we want to remember that no collision was found too)
  825. ContactConstraintManager::BodyPairHandle body_pair_handle = mContactManager.AddBodyPair(ioContactAllocator, *body1, *body2);
  826. if (body_pair_handle == nullptr)
  827. return; // Out of cache space
  828. // If we want enhanced active edge detection for this body pair
  829. bool enhanced_active_edges = body1->GetEnhancedInternalEdgeRemovalWithBody(*body2);
  830. // Create the query settings
  831. CollideShapeSettings settings;
  832. settings.mCollectFacesMode = ECollectFacesMode::CollectFaces;
  833. settings.mActiveEdgeMode = mPhysicsSettings.mCheckActiveEdges && !enhanced_active_edges? EActiveEdgeMode::CollideOnlyWithActive : EActiveEdgeMode::CollideWithAll;
  834. settings.mMaxSeparationDistance = body1->IsSensor() || body2->IsSensor()? 0.0f : mPhysicsSettings.mSpeculativeContactDistance;
  835. settings.mActiveEdgeMovementDirection = body1->GetLinearVelocity() - body2->GetLinearVelocity();
  836. // Get transforms relative to body1
  837. RVec3 offset = body1->GetCenterOfMassPosition();
  838. Mat44 transform1 = Mat44::sRotation(body1->GetRotation());
  839. Mat44 transform2 = body2->GetCenterOfMassTransform().PostTranslated(-offset).ToMat44();
  840. if (mPhysicsSettings.mUseManifoldReduction // Check global flag
  841. && body1->GetUseManifoldReductionWithBody(*body2)) // Check body flag
  842. {
  843. // Version WITH contact manifold reduction
  844. class MyManifold : public ContactManifold
  845. {
  846. public:
  847. Vec3 mFirstWorldSpaceNormal;
  848. };
  849. // A temporary structure that allows us to keep track of the all manifolds between this body pair
  850. using Manifolds = StaticArray<MyManifold, 32>;
  851. // Create collector
  852. class ReductionCollideShapeCollector : public CollideShapeCollector
  853. {
  854. public:
  855. ReductionCollideShapeCollector(PhysicsSystem *inSystem, const Body *inBody1, const Body *inBody2) :
  856. mSystem(inSystem),
  857. mBody1(inBody1),
  858. mBody2(inBody2)
  859. {
  860. }
  861. virtual void AddHit(const CollideShapeResult &inResult) override
  862. {
  863. // The first body should be the one with the highest motion type
  864. JPH_ASSERT(mBody1->GetMotionType() >= mBody2->GetMotionType());
  865. JPH_ASSERT(!ShouldEarlyOut());
  866. // Test if we want to accept this hit
  867. if (mValidateBodyPair)
  868. {
  869. switch (mSystem->mContactManager.ValidateContactPoint(*mBody1, *mBody2, mBody1->GetCenterOfMassPosition(), inResult))
  870. {
  871. case ValidateResult::AcceptContact:
  872. // We're just accepting this one, nothing to do
  873. break;
  874. case ValidateResult::AcceptAllContactsForThisBodyPair:
  875. // Accept and stop calling the validate callback
  876. mValidateBodyPair = false;
  877. break;
  878. case ValidateResult::RejectContact:
  879. // Skip this contact
  880. return;
  881. case ValidateResult::RejectAllContactsForThisBodyPair:
  882. // Skip this and early out
  883. ForceEarlyOut();
  884. return;
  885. }
  886. }
  887. // Calculate normal
  888. Vec3 world_space_normal = inResult.mPenetrationAxis.Normalized();
  889. // Check if we can add it to an existing manifold
  890. Manifolds::iterator manifold;
  891. float contact_normal_cos_max_delta_rot = mSystem->mPhysicsSettings.mContactNormalCosMaxDeltaRotation;
  892. for (manifold = mManifolds.begin(); manifold != mManifolds.end(); ++manifold)
  893. if (world_space_normal.Dot(manifold->mFirstWorldSpaceNormal) >= contact_normal_cos_max_delta_rot)
  894. {
  895. // Update average normal
  896. manifold->mWorldSpaceNormal += world_space_normal;
  897. manifold->mPenetrationDepth = max(manifold->mPenetrationDepth, inResult.mPenetrationDepth);
  898. break;
  899. }
  900. if (manifold == mManifolds.end())
  901. {
  902. // Check if array is full
  903. if (mManifolds.size() == mManifolds.capacity())
  904. {
  905. // Full, find manifold with least amount of penetration
  906. manifold = mManifolds.begin();
  907. for (Manifolds::iterator m = mManifolds.begin() + 1; m < mManifolds.end(); ++m)
  908. if (m->mPenetrationDepth < manifold->mPenetrationDepth)
  909. manifold = m;
  910. // If this contacts penetration is smaller than the smallest manifold, we skip this contact
  911. if (inResult.mPenetrationDepth < manifold->mPenetrationDepth)
  912. return;
  913. // Replace the manifold
  914. *manifold = { { mBody1->GetCenterOfMassPosition(), world_space_normal, inResult.mPenetrationDepth, inResult.mSubShapeID1, inResult.mSubShapeID2, { }, { } }, world_space_normal };
  915. }
  916. else
  917. {
  918. // Not full, create new manifold
  919. mManifolds.push_back({ { mBody1->GetCenterOfMassPosition(), world_space_normal, inResult.mPenetrationDepth, inResult.mSubShapeID1, inResult.mSubShapeID2, { }, { } }, world_space_normal });
  920. manifold = mManifolds.end() - 1;
  921. }
  922. }
  923. // Determine contact points
  924. const PhysicsSettings &settings = mSystem->mPhysicsSettings;
  925. ManifoldBetweenTwoFaces(inResult.mContactPointOn1, inResult.mContactPointOn2, inResult.mPenetrationAxis, Square(settings.mSpeculativeContactDistance) + settings.mManifoldToleranceSq, inResult.mShape1Face, inResult.mShape2Face, manifold->mRelativeContactPointsOn1, manifold->mRelativeContactPointsOn2 JPH_IF_DEBUG_RENDERER(, mBody1->GetCenterOfMassPosition()));
  926. // Prune if we have more than 32 points (this means we could run out of space in the next iteration)
  927. if (manifold->mRelativeContactPointsOn1.size() > 32)
  928. PruneContactPoints(manifold->mFirstWorldSpaceNormal, manifold->mRelativeContactPointsOn1, manifold->mRelativeContactPointsOn2 JPH_IF_DEBUG_RENDERER(, manifold->mBaseOffset));
  929. }
  930. PhysicsSystem * mSystem;
  931. const Body * mBody1;
  932. const Body * mBody2;
  933. bool mValidateBodyPair = true;
  934. Manifolds mManifolds;
  935. };
  936. ReductionCollideShapeCollector collector(this, body1, body2);
  937. // Perform collision detection between the two shapes
  938. SubShapeIDCreator part1, part2;
  939. auto f = enhanced_active_edges? InternalEdgeRemovingCollector::sCollideShapeVsShape : CollisionDispatch::sCollideShapeVsShape;
  940. f(body1->GetShape(), body2->GetShape(), Vec3::sReplicate(1.0f), Vec3::sReplicate(1.0f), transform1, transform2, part1, part2, settings, collector, { });
  941. // Add the contacts
  942. for (ContactManifold &manifold : collector.mManifolds)
  943. {
  944. // Normalize the normal (is a sum of all normals from merged manifolds)
  945. manifold.mWorldSpaceNormal = manifold.mWorldSpaceNormal.Normalized();
  946. // If we still have too many points, prune them now
  947. if (manifold.mRelativeContactPointsOn1.size() > 4)
  948. PruneContactPoints(manifold.mWorldSpaceNormal, manifold.mRelativeContactPointsOn1, manifold.mRelativeContactPointsOn2 JPH_IF_DEBUG_RENDERER(, manifold.mBaseOffset));
  949. // Actually add the contact points to the manager
  950. constraint_created |= mContactManager.AddContactConstraint(ioContactAllocator, body_pair_handle, *body1, *body2, manifold);
  951. }
  952. }
  953. else
  954. {
  955. // Version WITHOUT contact manifold reduction
  956. // Create collector
  957. class NonReductionCollideShapeCollector : public CollideShapeCollector
  958. {
  959. public:
  960. NonReductionCollideShapeCollector(PhysicsSystem *inSystem, ContactAllocator &ioContactAllocator, Body *inBody1, Body *inBody2, const ContactConstraintManager::BodyPairHandle &inPairHandle) :
  961. mSystem(inSystem),
  962. mContactAllocator(ioContactAllocator),
  963. mBody1(inBody1),
  964. mBody2(inBody2),
  965. mBodyPairHandle(inPairHandle)
  966. {
  967. }
  968. virtual void AddHit(const CollideShapeResult &inResult) override
  969. {
  970. // The first body should be the one with the highest motion type
  971. JPH_ASSERT(mBody1->GetMotionType() >= mBody2->GetMotionType());
  972. JPH_ASSERT(!ShouldEarlyOut());
  973. // Test if we want to accept this hit
  974. if (mValidateBodyPair)
  975. {
  976. switch (mSystem->mContactManager.ValidateContactPoint(*mBody1, *mBody2, mBody1->GetCenterOfMassPosition(), inResult))
  977. {
  978. case ValidateResult::AcceptContact:
  979. // We're just accepting this one, nothing to do
  980. break;
  981. case ValidateResult::AcceptAllContactsForThisBodyPair:
  982. // Accept and stop calling the validate callback
  983. mValidateBodyPair = false;
  984. break;
  985. case ValidateResult::RejectContact:
  986. // Skip this contact
  987. return;
  988. case ValidateResult::RejectAllContactsForThisBodyPair:
  989. // Skip this and early out
  990. ForceEarlyOut();
  991. return;
  992. }
  993. }
  994. // Determine contact points
  995. ContactManifold manifold;
  996. manifold.mBaseOffset = mBody1->GetCenterOfMassPosition();
  997. const PhysicsSettings &settings = mSystem->mPhysicsSettings;
  998. ManifoldBetweenTwoFaces(inResult.mContactPointOn1, inResult.mContactPointOn2, inResult.mPenetrationAxis, Square(settings.mSpeculativeContactDistance) + settings.mManifoldToleranceSq, inResult.mShape1Face, inResult.mShape2Face, manifold.mRelativeContactPointsOn1, manifold.mRelativeContactPointsOn2 JPH_IF_DEBUG_RENDERER(, manifold.mBaseOffset));
  999. // Calculate normal
  1000. manifold.mWorldSpaceNormal = inResult.mPenetrationAxis.Normalized();
  1001. // Store penetration depth
  1002. manifold.mPenetrationDepth = inResult.mPenetrationDepth;
  1003. // Prune if we have more than 4 points
  1004. if (manifold.mRelativeContactPointsOn1.size() > 4)
  1005. PruneContactPoints(manifold.mWorldSpaceNormal, manifold.mRelativeContactPointsOn1, manifold.mRelativeContactPointsOn2 JPH_IF_DEBUG_RENDERER(, manifold.mBaseOffset));
  1006. // Set other properties
  1007. manifold.mSubShapeID1 = inResult.mSubShapeID1;
  1008. manifold.mSubShapeID2 = inResult.mSubShapeID2;
  1009. // Actually add the contact points to the manager
  1010. mConstraintCreated |= mSystem->mContactManager.AddContactConstraint(mContactAllocator, mBodyPairHandle, *mBody1, *mBody2, manifold);
  1011. }
  1012. PhysicsSystem * mSystem;
  1013. ContactAllocator & mContactAllocator;
  1014. Body * mBody1;
  1015. Body * mBody2;
  1016. ContactConstraintManager::BodyPairHandle mBodyPairHandle;
  1017. bool mValidateBodyPair = true;
  1018. bool mConstraintCreated = false;
  1019. };
  1020. NonReductionCollideShapeCollector collector(this, ioContactAllocator, body1, body2, body_pair_handle);
  1021. // Perform collision detection between the two shapes
  1022. SubShapeIDCreator part1, part2;
  1023. auto f = enhanced_active_edges? InternalEdgeRemovingCollector::sCollideShapeVsShape : CollisionDispatch::sCollideShapeVsShape;
  1024. f(body1->GetShape(), body2->GetShape(), Vec3::sReplicate(1.0f), Vec3::sReplicate(1.0f), transform1, transform2, part1, part2, settings, collector, { });
  1025. constraint_created = collector.mConstraintCreated;
  1026. }
  1027. }
  1028. // If a contact constraint was created, we need to do some extra work
  1029. if (constraint_created)
  1030. {
  1031. // Wake up sleeping bodies
  1032. BodyID body_ids[2];
  1033. int num_bodies = 0;
  1034. if (body1->IsDynamic() && !body1->IsActive())
  1035. body_ids[num_bodies++] = body1->GetID();
  1036. if (body2->IsDynamic() && !body2->IsActive())
  1037. body_ids[num_bodies++] = body2->GetID();
  1038. if (num_bodies > 0)
  1039. mBodyManager.ActivateBodies(body_ids, num_bodies);
  1040. // Link the two bodies
  1041. mIslandBuilder.LinkBodies(body1->GetIndexInActiveBodiesInternal(), body2->GetIndexInActiveBodiesInternal());
  1042. }
  1043. }
  1044. void PhysicsSystem::JobFinalizeIslands(PhysicsUpdateContext *ioContext)
  1045. {
  1046. #ifdef JPH_ENABLE_ASSERTS
  1047. // We only touch island data
  1048. BodyAccess::Grant grant(BodyAccess::EAccess::None, BodyAccess::EAccess::None);
  1049. #endif
  1050. // Finish collecting the islands, at this point the active body list doesn't change so it's safe to access
  1051. mIslandBuilder.Finalize(mBodyManager.GetActiveBodiesUnsafe(EBodyType::RigidBody), mBodyManager.GetNumActiveBodies(EBodyType::RigidBody), mContactManager.GetNumConstraints(), ioContext->mTempAllocator);
  1052. // Prepare the large island splitter
  1053. if (mPhysicsSettings.mUseLargeIslandSplitter)
  1054. mLargeIslandSplitter.Prepare(mIslandBuilder, mBodyManager.GetNumActiveBodies(EBodyType::RigidBody), ioContext->mTempAllocator);
  1055. }
  1056. void PhysicsSystem::JobBodySetIslandIndex()
  1057. {
  1058. #ifdef JPH_ENABLE_ASSERTS
  1059. // We only touch island data
  1060. BodyAccess::Grant grant(BodyAccess::EAccess::None, BodyAccess::EAccess::None);
  1061. #endif
  1062. // Loop through the result and tag all bodies with an island index
  1063. for (uint32 island_idx = 0, n = mIslandBuilder.GetNumIslands(); island_idx < n; ++island_idx)
  1064. {
  1065. BodyID *body_start, *body_end;
  1066. mIslandBuilder.GetBodiesInIsland(island_idx, body_start, body_end);
  1067. for (const BodyID *body = body_start; body < body_end; ++body)
  1068. mBodyManager.GetBody(*body).GetMotionProperties()->SetIslandIndexInternal(island_idx);
  1069. }
  1070. }
  1071. JPH_SUPPRESS_WARNING_PUSH
  1072. JPH_CLANG_SUPPRESS_WARNING("-Wundefined-func-template") // ConstraintManager::sWarmStartVelocityConstraints / ContactConstraintManager::WarmStartVelocityConstraints is instantiated in the cpp file
  1073. void PhysicsSystem::JobSolveVelocityConstraints(PhysicsUpdateContext *ioContext, PhysicsUpdateContext::Step *ioStep)
  1074. {
  1075. #ifdef JPH_ENABLE_ASSERTS
  1076. // We update velocities and need to read positions to do so
  1077. BodyAccess::Grant grant(BodyAccess::EAccess::ReadWrite, BodyAccess::EAccess::Read);
  1078. #endif
  1079. float delta_time = ioContext->mStepDeltaTime;
  1080. Constraint **active_constraints = ioContext->mActiveConstraints;
  1081. // Only the first step to correct for the delta time difference in the previous update
  1082. float warm_start_impulse_ratio = ioStep->mIsFirst? ioContext->mWarmStartImpulseRatio : 1.0f;
  1083. bool check_islands = true, check_split_islands = mPhysicsSettings.mUseLargeIslandSplitter;
  1084. do
  1085. {
  1086. // First try to get work from large islands
  1087. if (check_split_islands)
  1088. {
  1089. bool first_iteration;
  1090. uint split_island_index;
  1091. uint32 *constraints_begin, *constraints_end, *contacts_begin, *contacts_end;
  1092. switch (mLargeIslandSplitter.FetchNextBatch(split_island_index, constraints_begin, constraints_end, contacts_begin, contacts_end, first_iteration))
  1093. {
  1094. case LargeIslandSplitter::EStatus::BatchRetrieved:
  1095. {
  1096. if (first_iteration)
  1097. {
  1098. // Iteration 0 is used to warm start the batch (we added 1 to the number of iterations in LargeIslandSplitter::SplitIsland)
  1099. DummyCalculateSolverSteps dummy;
  1100. ConstraintManager::sWarmStartVelocityConstraints(active_constraints, constraints_begin, constraints_end, warm_start_impulse_ratio, dummy);
  1101. mContactManager.WarmStartVelocityConstraints(contacts_begin, contacts_end, warm_start_impulse_ratio, dummy);
  1102. }
  1103. else
  1104. {
  1105. // Solve velocity constraints
  1106. ConstraintManager::sSolveVelocityConstraints(active_constraints, constraints_begin, constraints_end, delta_time);
  1107. mContactManager.SolveVelocityConstraints(contacts_begin, contacts_end);
  1108. }
  1109. // Mark the batch as processed
  1110. bool last_iteration, final_batch;
  1111. mLargeIslandSplitter.MarkBatchProcessed(split_island_index, constraints_begin, constraints_end, contacts_begin, contacts_end, last_iteration, final_batch);
  1112. // Save back the lambdas in the contact cache for the warm start of the next physics update
  1113. if (last_iteration)
  1114. mContactManager.StoreAppliedImpulses(contacts_begin, contacts_end);
  1115. // We processed work, loop again
  1116. continue;
  1117. }
  1118. case LargeIslandSplitter::EStatus::WaitingForBatch:
  1119. break;
  1120. case LargeIslandSplitter::EStatus::AllBatchesDone:
  1121. check_split_islands = false;
  1122. break;
  1123. }
  1124. }
  1125. // If that didn't succeed try to process an island
  1126. if (check_islands)
  1127. {
  1128. // Next island
  1129. uint32 island_idx = ioStep->mSolveVelocityConstraintsNextIsland++;
  1130. if (island_idx >= mIslandBuilder.GetNumIslands())
  1131. {
  1132. // We processed all islands, stop checking islands
  1133. check_islands = false;
  1134. continue;
  1135. }
  1136. JPH_PROFILE("Island");
  1137. // Get iterators for this island
  1138. uint32 *constraints_begin, *constraints_end, *contacts_begin, *contacts_end;
  1139. bool has_constraints = mIslandBuilder.GetConstraintsInIsland(island_idx, constraints_begin, constraints_end);
  1140. bool has_contacts = mIslandBuilder.GetContactsInIsland(island_idx, contacts_begin, contacts_end);
  1141. // If we don't have any contacts or constraints, we know that none of the following islands have any contacts or constraints
  1142. // (because they're sorted by most constraints first). This means we're done.
  1143. if (!has_contacts && !has_constraints)
  1144. {
  1145. #ifdef JPH_ENABLE_ASSERTS
  1146. // Validate our assumption that the next islands don't have any constraints or contacts
  1147. for (; island_idx < mIslandBuilder.GetNumIslands(); ++island_idx)
  1148. {
  1149. JPH_ASSERT(!mIslandBuilder.GetConstraintsInIsland(island_idx, constraints_begin, constraints_end));
  1150. JPH_ASSERT(!mIslandBuilder.GetContactsInIsland(island_idx, contacts_begin, contacts_end));
  1151. }
  1152. #endif // JPH_ENABLE_ASSERTS
  1153. check_islands = false;
  1154. continue;
  1155. }
  1156. // Sorting is costly but needed for a deterministic simulation, allow the user to turn this off
  1157. if (mPhysicsSettings.mDeterministicSimulation)
  1158. {
  1159. // Sort constraints to give a deterministic simulation
  1160. ConstraintManager::sSortConstraints(active_constraints, constraints_begin, constraints_end);
  1161. // Sort contacts to give a deterministic simulation
  1162. mContactManager.SortContacts(contacts_begin, contacts_end);
  1163. }
  1164. // Split up large islands
  1165. CalculateSolverSteps steps_calculator(mPhysicsSettings);
  1166. if (mPhysicsSettings.mUseLargeIslandSplitter
  1167. && mLargeIslandSplitter.SplitIsland(island_idx, mIslandBuilder, mBodyManager, mContactManager, active_constraints, steps_calculator))
  1168. continue; // Loop again to try to fetch the newly split island
  1169. // We didn't create a split, just run the solver now for this entire island. Begin by warm starting.
  1170. ConstraintManager::sWarmStartVelocityConstraints(active_constraints, constraints_begin, constraints_end, warm_start_impulse_ratio, steps_calculator);
  1171. mContactManager.WarmStartVelocityConstraints(contacts_begin, contacts_end, warm_start_impulse_ratio, steps_calculator);
  1172. steps_calculator.Finalize();
  1173. // Store the number of position steps for later
  1174. mIslandBuilder.SetNumPositionSteps(island_idx, steps_calculator.GetNumPositionSteps());
  1175. // Solve velocity constraints
  1176. for (uint velocity_step = 0; velocity_step < steps_calculator.GetNumVelocitySteps(); ++velocity_step)
  1177. {
  1178. bool applied_impulse = ConstraintManager::sSolveVelocityConstraints(active_constraints, constraints_begin, constraints_end, delta_time);
  1179. applied_impulse |= mContactManager.SolveVelocityConstraints(contacts_begin, contacts_end);
  1180. if (!applied_impulse)
  1181. break;
  1182. }
  1183. // Save back the lambdas in the contact cache for the warm start of the next physics update
  1184. mContactManager.StoreAppliedImpulses(contacts_begin, contacts_end);
  1185. // We processed work, loop again
  1186. continue;
  1187. }
  1188. // If we didn't find any work, give up a time slice
  1189. std::this_thread::yield();
  1190. }
  1191. while (check_islands || check_split_islands);
  1192. }
  1193. JPH_SUPPRESS_WARNING_POP
  1194. void PhysicsSystem::JobPreIntegrateVelocity(PhysicsUpdateContext *ioContext, PhysicsUpdateContext::Step *ioStep)
  1195. {
  1196. // Reserve enough space for all bodies that may need a cast
  1197. TempAllocator *temp_allocator = ioContext->mTempAllocator;
  1198. JPH_ASSERT(ioStep->mCCDBodies == nullptr);
  1199. ioStep->mCCDBodiesCapacity = mBodyManager.GetNumActiveCCDBodies();
  1200. ioStep->mCCDBodies = (CCDBody *)temp_allocator->Allocate(ioStep->mCCDBodiesCapacity * sizeof(CCDBody));
  1201. // Initialize the mapping table between active body and CCD body
  1202. JPH_ASSERT(ioStep->mActiveBodyToCCDBody == nullptr);
  1203. ioStep->mNumActiveBodyToCCDBody = mBodyManager.GetNumActiveBodies(EBodyType::RigidBody);
  1204. ioStep->mActiveBodyToCCDBody = (int *)temp_allocator->Allocate(ioStep->mNumActiveBodyToCCDBody * sizeof(int));
  1205. // Prepare the split island builder for solving the position constraints
  1206. mLargeIslandSplitter.PrepareForSolvePositions();
  1207. }
  1208. void PhysicsSystem::JobIntegrateVelocity(const PhysicsUpdateContext *ioContext, PhysicsUpdateContext::Step *ioStep)
  1209. {
  1210. #ifdef JPH_ENABLE_ASSERTS
  1211. // We update positions and need velocity to do so, we also clamp velocities so need to write to them
  1212. BodyAccess::Grant grant(BodyAccess::EAccess::ReadWrite, BodyAccess::EAccess::ReadWrite);
  1213. #endif
  1214. float delta_time = ioContext->mStepDeltaTime;
  1215. const BodyID *active_bodies = mBodyManager.GetActiveBodiesUnsafe(EBodyType::RigidBody);
  1216. uint32 num_active_bodies = mBodyManager.GetNumActiveBodies(EBodyType::RigidBody);
  1217. uint32 num_active_bodies_after_find_collisions = ioStep->mActiveBodyReadIdx;
  1218. // We can move bodies that are not part of an island. In this case we need to notify the broadphase of the movement.
  1219. static constexpr int cBodiesBatch = 64;
  1220. BodyID *bodies_to_update_bounds = (BodyID *)JPH_STACK_ALLOC(cBodiesBatch * sizeof(BodyID));
  1221. int num_bodies_to_update_bounds = 0;
  1222. for (;;)
  1223. {
  1224. // Atomically fetch a batch of bodies
  1225. uint32 active_body_idx = ioStep->mIntegrateVelocityReadIdx.fetch_add(cIntegrateVelocityBatchSize);
  1226. if (active_body_idx >= num_active_bodies)
  1227. break;
  1228. // Calculate the end of the batch
  1229. uint32 active_body_idx_end = min(num_active_bodies, active_body_idx + cIntegrateVelocityBatchSize);
  1230. // Process the batch
  1231. while (active_body_idx < active_body_idx_end)
  1232. {
  1233. // Update the positions using an Symplectic Euler step (which integrates using the updated velocity v1' rather
  1234. // than the original velocity v1):
  1235. // x1' = x1 + h * v1'
  1236. // At this point the active bodies list does not change, so it is safe to access the array.
  1237. BodyID body_id = active_bodies[active_body_idx];
  1238. Body &body = mBodyManager.GetBody(body_id);
  1239. MotionProperties *mp = body.GetMotionProperties();
  1240. JPH_DET_LOG("JobIntegrateVelocity: id: " << body_id << " v: " << body.GetLinearVelocity() << " w: " << body.GetAngularVelocity());
  1241. // Clamp velocities (not for kinematic bodies)
  1242. if (body.IsDynamic())
  1243. {
  1244. mp->ClampLinearVelocity();
  1245. mp->ClampAngularVelocity();
  1246. }
  1247. // Update the rotation of the body according to the angular velocity
  1248. // For motion type discrete we need to do this anyway, for motion type linear cast we have multiple choices
  1249. // 1. Rotate the body first and then sweep
  1250. // 2. First sweep and then rotate the body at the end
  1251. // 3. Pick some in between rotation (e.g. half way), then sweep and finally rotate the remainder
  1252. // (1) has some clear advantages as when a long thin body hits a surface away from the center of mass, this will result in a large angular velocity and a limited reduction in linear velocity.
  1253. // When simulation the rotation first before doing the translation, the body will be able to rotate away from the contact point allowing the center of mass to approach the surface. When using
  1254. // approach (2) in this case what will happen is that we will immediately detect the same collision again (the body has not rotated and the body was already colliding at the end of the previous
  1255. // time step) resulting in a lot of stolen time and the body appearing to be frozen in an unnatural pose (like it is glued at an angle to the surface). (2) obviously has some negative side effects
  1256. // too as simulating the rotation first may cause it to tunnel through a small object that the linear cast might have otherwise detected. In any case a linear cast is not good for detecting
  1257. // tunneling due to angular rotation, so we don't care about that too much (you'd need a full cast to take angular effects into account).
  1258. body.AddRotationStep(body.GetAngularVelocity() * delta_time);
  1259. // Get delta position
  1260. Vec3 delta_pos = body.GetLinearVelocity() * delta_time;
  1261. // If the position should be updated (or if it is delayed because of CCD)
  1262. bool update_position = true;
  1263. switch (mp->GetMotionQuality())
  1264. {
  1265. case EMotionQuality::Discrete:
  1266. // No additional collision checking to be done
  1267. break;
  1268. case EMotionQuality::LinearCast:
  1269. if (body.IsDynamic() // Kinematic bodies cannot be stopped
  1270. && !body.IsSensor()) // We don't support CCD sensors
  1271. {
  1272. // Determine inner radius (the smallest sphere that fits into the shape)
  1273. float inner_radius = body.GetShape()->GetInnerRadius();
  1274. JPH_ASSERT(inner_radius > 0.0f, "The shape has no inner radius, this makes the shape unsuitable for the linear cast motion quality as we cannot move it without risking tunneling.");
  1275. // Measure translation in this step and check if it above the threshold to perform a linear cast
  1276. float linear_cast_threshold_sq = Square(mPhysicsSettings.mLinearCastThreshold * inner_radius);
  1277. if (delta_pos.LengthSq() > linear_cast_threshold_sq)
  1278. {
  1279. // This body needs a cast
  1280. uint32 ccd_body_idx = ioStep->mNumCCDBodies++;
  1281. JPH_ASSERT(active_body_idx < ioStep->mNumActiveBodyToCCDBody);
  1282. ioStep->mActiveBodyToCCDBody[active_body_idx] = ccd_body_idx;
  1283. new (&ioStep->mCCDBodies[ccd_body_idx]) CCDBody(body_id, delta_pos, linear_cast_threshold_sq, min(mPhysicsSettings.mPenetrationSlop, mPhysicsSettings.mLinearCastMaxPenetration * inner_radius));
  1284. update_position = false;
  1285. }
  1286. }
  1287. break;
  1288. }
  1289. if (update_position)
  1290. {
  1291. // Move the body now
  1292. body.AddPositionStep(delta_pos);
  1293. // If the body was activated due to an earlier CCD step it will have an index in the active
  1294. // body list that it higher than the highest one we processed during FindCollisions
  1295. // which means it hasn't been assigned an island and will not be updated by an island
  1296. // this means that we need to update its bounds manually
  1297. if (mp->GetIndexInActiveBodiesInternal() >= num_active_bodies_after_find_collisions)
  1298. {
  1299. body.CalculateWorldSpaceBoundsInternal();
  1300. bodies_to_update_bounds[num_bodies_to_update_bounds++] = body.GetID();
  1301. if (num_bodies_to_update_bounds == cBodiesBatch)
  1302. {
  1303. // Buffer full, flush now
  1304. mBroadPhase->NotifyBodiesAABBChanged(bodies_to_update_bounds, num_bodies_to_update_bounds, false);
  1305. num_bodies_to_update_bounds = 0;
  1306. }
  1307. }
  1308. // We did not create a CCD body
  1309. ioStep->mActiveBodyToCCDBody[active_body_idx] = -1;
  1310. }
  1311. active_body_idx++;
  1312. }
  1313. }
  1314. // Notify change bounds on requested bodies
  1315. if (num_bodies_to_update_bounds > 0)
  1316. mBroadPhase->NotifyBodiesAABBChanged(bodies_to_update_bounds, num_bodies_to_update_bounds, false);
  1317. }
  1318. void PhysicsSystem::JobPostIntegrateVelocity(PhysicsUpdateContext *ioContext, PhysicsUpdateContext::Step *ioStep) const
  1319. {
  1320. // Validate that our reservations were correct
  1321. JPH_ASSERT(ioStep->mNumCCDBodies <= mBodyManager.GetNumActiveCCDBodies());
  1322. if (ioStep->mNumCCDBodies == 0)
  1323. {
  1324. // No continuous collision detection jobs -> kick the next job ourselves
  1325. ioStep->mContactRemovedCallbacks.RemoveDependency();
  1326. }
  1327. else
  1328. {
  1329. // Run the continuous collision detection jobs
  1330. int num_continuous_collision_jobs = min(int(ioStep->mNumCCDBodies + cNumCCDBodiesPerJob - 1) / cNumCCDBodiesPerJob, ioContext->GetMaxConcurrency());
  1331. ioStep->mResolveCCDContacts.AddDependency(num_continuous_collision_jobs);
  1332. ioStep->mContactRemovedCallbacks.AddDependency(num_continuous_collision_jobs - 1); // Already had 1 dependency
  1333. for (int i = 0; i < num_continuous_collision_jobs; ++i)
  1334. {
  1335. JobHandle job = ioContext->mJobSystem->CreateJob("FindCCDContacts", cColorFindCCDContacts, [ioContext, ioStep]()
  1336. {
  1337. ioContext->mPhysicsSystem->JobFindCCDContacts(ioContext, ioStep);
  1338. ioStep->mResolveCCDContacts.RemoveDependency();
  1339. ioStep->mContactRemovedCallbacks.RemoveDependency();
  1340. });
  1341. ioContext->mBarrier->AddJob(job);
  1342. }
  1343. }
  1344. }
  1345. // Helper function to calculate the motion of a body during this CCD step
  1346. inline static Vec3 sCalculateBodyMotion(const Body &inBody, float inDeltaTime)
  1347. {
  1348. // If the body is linear casting, the body has not yet moved so we need to calculate its motion
  1349. if (inBody.IsDynamic() && inBody.GetMotionProperties()->GetMotionQuality() == EMotionQuality::LinearCast)
  1350. return inDeltaTime * inBody.GetLinearVelocity();
  1351. // Body has already moved, so we don't need to correct for anything
  1352. return Vec3::sZero();
  1353. }
  1354. // Helper function that finds the CCD body corresponding to a body (if it exists)
  1355. inline static PhysicsUpdateContext::Step::CCDBody *sGetCCDBody(const Body &inBody, PhysicsUpdateContext::Step *inStep)
  1356. {
  1357. // Only rigid bodies can have a CCD body
  1358. if (!inBody.IsRigidBody())
  1359. return nullptr;
  1360. // If the body has no motion properties it cannot have a CCD body
  1361. const MotionProperties *motion_properties = inBody.GetMotionPropertiesUnchecked();
  1362. if (motion_properties == nullptr)
  1363. return nullptr;
  1364. // If it is not active it cannot have a CCD body
  1365. uint32 active_index = motion_properties->GetIndexInActiveBodiesInternal();
  1366. if (active_index == Body::cInactiveIndex)
  1367. return nullptr;
  1368. // Check if the active body has a corresponding CCD body
  1369. JPH_ASSERT(active_index < inStep->mNumActiveBodyToCCDBody); // Ensure that the body has a mapping to CCD body
  1370. int ccd_index = inStep->mActiveBodyToCCDBody[active_index];
  1371. if (ccd_index < 0)
  1372. return nullptr;
  1373. PhysicsUpdateContext::Step::CCDBody *ccd_body = &inStep->mCCDBodies[ccd_index];
  1374. JPH_ASSERT(ccd_body->mBodyID1 == inBody.GetID(), "We found the wrong CCD body!");
  1375. return ccd_body;
  1376. }
  1377. void PhysicsSystem::JobFindCCDContacts(const PhysicsUpdateContext *ioContext, PhysicsUpdateContext::Step *ioStep)
  1378. {
  1379. #ifdef JPH_ENABLE_ASSERTS
  1380. // We only read positions, but the validate callback may read body positions and velocities
  1381. BodyAccess::Grant grant(BodyAccess::EAccess::Read, BodyAccess::EAccess::Read);
  1382. #endif
  1383. // Allocation context for allocating new contact points
  1384. ContactAllocator contact_allocator(mContactManager.GetContactAllocator());
  1385. // Settings
  1386. ShapeCastSettings settings;
  1387. settings.mUseShrunkenShapeAndConvexRadius = true;
  1388. settings.mBackFaceModeTriangles = EBackFaceMode::IgnoreBackFaces;
  1389. settings.mBackFaceModeConvex = EBackFaceMode::IgnoreBackFaces;
  1390. settings.mReturnDeepestPoint = true;
  1391. settings.mCollectFacesMode = ECollectFacesMode::CollectFaces;
  1392. settings.mActiveEdgeMode = mPhysicsSettings.mCheckActiveEdges? EActiveEdgeMode::CollideOnlyWithActive : EActiveEdgeMode::CollideWithAll;
  1393. for (;;)
  1394. {
  1395. // Fetch the next body to cast
  1396. uint32 idx = ioStep->mNextCCDBody++;
  1397. if (idx >= ioStep->mNumCCDBodies)
  1398. break;
  1399. CCDBody &ccd_body = ioStep->mCCDBodies[idx];
  1400. const Body &body = mBodyManager.GetBody(ccd_body.mBodyID1);
  1401. // Filter out layers
  1402. DefaultBroadPhaseLayerFilter broadphase_layer_filter = GetDefaultBroadPhaseLayerFilter(body.GetObjectLayer());
  1403. DefaultObjectLayerFilter object_layer_filter = GetDefaultLayerFilter(body.GetObjectLayer());
  1404. #ifdef JPH_DEBUG_RENDERER
  1405. // Draw start and end shape of cast
  1406. if (sDrawMotionQualityLinearCast)
  1407. {
  1408. RMat44 com = body.GetCenterOfMassTransform();
  1409. body.GetShape()->Draw(DebugRenderer::sInstance, com, Vec3::sReplicate(1.0f), Color::sGreen, false, true);
  1410. DebugRenderer::sInstance->DrawArrow(com.GetTranslation(), com.GetTranslation() + ccd_body.mDeltaPosition, Color::sGreen, 0.1f);
  1411. body.GetShape()->Draw(DebugRenderer::sInstance, com.PostTranslated(ccd_body.mDeltaPosition), Vec3::sReplicate(1.0f), Color::sRed, false, true);
  1412. }
  1413. #endif // JPH_DEBUG_RENDERER
  1414. // Create a collector that will find the maximum distance allowed to travel while not penetrating more than 'max penetration'
  1415. class CCDNarrowPhaseCollector : public CastShapeCollector
  1416. {
  1417. public:
  1418. CCDNarrowPhaseCollector(const BodyManager &inBodyManager, ContactConstraintManager &inContactConstraintManager, CCDBody &inCCDBody, ShapeCastResult &inResult, float inDeltaTime) :
  1419. mBodyManager(inBodyManager),
  1420. mContactConstraintManager(inContactConstraintManager),
  1421. mCCDBody(inCCDBody),
  1422. mResult(inResult),
  1423. mDeltaTime(inDeltaTime)
  1424. {
  1425. }
  1426. virtual void AddHit(const ShapeCastResult &inResult) override
  1427. {
  1428. JPH_PROFILE_FUNCTION();
  1429. // Check if this is a possible earlier hit than the one before
  1430. float fraction = inResult.mFraction;
  1431. if (fraction < mCCDBody.mFractionPlusSlop)
  1432. {
  1433. // Normalize normal
  1434. Vec3 normal = inResult.mPenetrationAxis.Normalized();
  1435. // Calculate how much we can add to the fraction to penetrate the collision point by mMaxPenetration.
  1436. // Note that the normal is pointing towards body 2!
  1437. // Let the extra distance that we can travel along delta_pos be 'dist': mMaxPenetration / dist = cos(angle between normal and delta_pos) = normal . delta_pos / |delta_pos|
  1438. // <=> dist = mMaxPenetration * |delta_pos| / normal . delta_pos
  1439. // Converting to a faction: delta_fraction = dist / |delta_pos| = mLinearCastTreshold / normal . delta_pos
  1440. float denominator = normal.Dot(mCCDBody.mDeltaPosition);
  1441. if (denominator > mCCDBody.mMaxPenetration) // Avoid dividing by zero, if extra hit fraction > 1 there's also no point in continuing
  1442. {
  1443. float fraction_plus_slop = fraction + mCCDBody.mMaxPenetration / denominator;
  1444. if (fraction_plus_slop < mCCDBody.mFractionPlusSlop)
  1445. {
  1446. const Body &body2 = mBodyManager.GetBody(inResult.mBodyID2);
  1447. // Check if we've already accepted all hits from this body
  1448. if (mValidateBodyPair)
  1449. {
  1450. // Validate the contact result
  1451. const Body &body1 = mBodyManager.GetBody(mCCDBody.mBodyID1);
  1452. ValidateResult validate_result = mContactConstraintManager.ValidateContactPoint(body1, body2, body1.GetCenterOfMassPosition(), inResult); // Note that the center of mass of body 1 is the start of the sweep and is used as base offset below
  1453. switch (validate_result)
  1454. {
  1455. case ValidateResult::AcceptContact:
  1456. // Just continue
  1457. break;
  1458. case ValidateResult::AcceptAllContactsForThisBodyPair:
  1459. // Accept this and all following contacts from this body
  1460. mValidateBodyPair = false;
  1461. break;
  1462. case ValidateResult::RejectContact:
  1463. return;
  1464. case ValidateResult::RejectAllContactsForThisBodyPair:
  1465. // Reject this and all following contacts from this body
  1466. mRejectAll = true;
  1467. ForceEarlyOut();
  1468. return;
  1469. }
  1470. }
  1471. // This is the earliest hit so far, store it
  1472. mCCDBody.mContactNormal = normal;
  1473. mCCDBody.mBodyID2 = inResult.mBodyID2;
  1474. mCCDBody.mSubShapeID2 = inResult.mSubShapeID2;
  1475. mCCDBody.mFraction = fraction;
  1476. mCCDBody.mFractionPlusSlop = fraction_plus_slop;
  1477. mResult = inResult;
  1478. // Result was assuming body 2 is not moving, but it is, so we need to correct for it
  1479. Vec3 movement2 = fraction * sCalculateBodyMotion(body2, mDeltaTime);
  1480. if (!movement2.IsNearZero())
  1481. {
  1482. mResult.mContactPointOn1 += movement2;
  1483. mResult.mContactPointOn2 += movement2;
  1484. for (Vec3 &v : mResult.mShape1Face)
  1485. v += movement2;
  1486. for (Vec3 &v : mResult.mShape2Face)
  1487. v += movement2;
  1488. }
  1489. // Update early out fraction
  1490. UpdateEarlyOutFraction(fraction_plus_slop);
  1491. }
  1492. }
  1493. }
  1494. }
  1495. bool mValidateBodyPair; ///< If we still have to call the ValidateContactPoint for this body pair
  1496. bool mRejectAll; ///< Reject all further contacts between this body pair
  1497. private:
  1498. const BodyManager & mBodyManager;
  1499. ContactConstraintManager & mContactConstraintManager;
  1500. CCDBody & mCCDBody;
  1501. ShapeCastResult & mResult;
  1502. float mDeltaTime;
  1503. BodyID mAcceptedBodyID;
  1504. };
  1505. // Narrowphase collector
  1506. ShapeCastResult cast_shape_result;
  1507. CCDNarrowPhaseCollector np_collector(mBodyManager, mContactManager, ccd_body, cast_shape_result, ioContext->mStepDeltaTime);
  1508. // This collector wraps the narrowphase collector and collects the closest hit
  1509. class CCDBroadPhaseCollector : public CastShapeBodyCollector
  1510. {
  1511. public:
  1512. CCDBroadPhaseCollector(const CCDBody &inCCDBody, const Body &inBody1, const RShapeCast &inShapeCast, ShapeCastSettings &inShapeCastSettings, CCDNarrowPhaseCollector &ioCollector, const BodyManager &inBodyManager, PhysicsUpdateContext::Step *inStep, float inDeltaTime) :
  1513. mCCDBody(inCCDBody),
  1514. mBody1(inBody1),
  1515. mBody1Extent(inShapeCast.mShapeWorldBounds.GetExtent()),
  1516. mShapeCast(inShapeCast),
  1517. mShapeCastSettings(inShapeCastSettings),
  1518. mCollector(ioCollector),
  1519. mBodyManager(inBodyManager),
  1520. mStep(inStep),
  1521. mDeltaTime(inDeltaTime)
  1522. {
  1523. }
  1524. virtual void AddHit(const BroadPhaseCastResult &inResult) override
  1525. {
  1526. JPH_PROFILE_FUNCTION();
  1527. JPH_ASSERT(inResult.mFraction <= GetEarlyOutFraction(), "This hit should not have been passed on to the collector");
  1528. // Test if we're colliding with ourselves
  1529. if (mBody1.GetID() == inResult.mBodyID)
  1530. return;
  1531. // Avoid treating duplicates, if both bodies are doing CCD then only consider collision if body ID < other body ID
  1532. const Body &body2 = mBodyManager.GetBody(inResult.mBodyID);
  1533. const CCDBody *ccd_body2 = sGetCCDBody(body2, mStep);
  1534. if (ccd_body2 != nullptr && mCCDBody.mBodyID1 > ccd_body2->mBodyID1)
  1535. return;
  1536. // Test group filter
  1537. if (!mBody1.GetCollisionGroup().CanCollide(body2.GetCollisionGroup()))
  1538. return;
  1539. // TODO: For now we ignore sensors
  1540. if (body2.IsSensor())
  1541. return;
  1542. // Get relative movement of these two bodies
  1543. Vec3 direction = mShapeCast.mDirection - sCalculateBodyMotion(body2, mDeltaTime);
  1544. // Test if the remaining movement is less than our movement threshold
  1545. if (direction.LengthSq() < mCCDBody.mLinearCastThresholdSq)
  1546. return;
  1547. // Get the bounds of 2, widen it by the extent of 1 and test a ray to see if it hits earlier than the current early out fraction
  1548. AABox bounds = body2.GetWorldSpaceBounds();
  1549. bounds.mMin -= mBody1Extent;
  1550. bounds.mMax += mBody1Extent;
  1551. float hit_fraction = RayAABox(Vec3(mShapeCast.mCenterOfMassStart.GetTranslation()), RayInvDirection(direction), bounds.mMin, bounds.mMax);
  1552. if (hit_fraction > GetPositiveEarlyOutFraction()) // If early out fraction <= 0, we have the possibility of finding a deeper hit so we need to clamp the early out fraction
  1553. return;
  1554. // Reset collector (this is a new body pair)
  1555. mCollector.ResetEarlyOutFraction(GetEarlyOutFraction());
  1556. mCollector.mValidateBodyPair = true;
  1557. mCollector.mRejectAll = false;
  1558. // Provide direction as hint for the active edges algorithm
  1559. mShapeCastSettings.mActiveEdgeMovementDirection = direction;
  1560. // Do narrow phase collision check
  1561. RShapeCast relative_cast(mShapeCast.mShape, mShapeCast.mScale, mShapeCast.mCenterOfMassStart, direction, mShapeCast.mShapeWorldBounds);
  1562. body2.GetTransformedShape().CastShape(relative_cast, mShapeCastSettings, mShapeCast.mCenterOfMassStart.GetTranslation(), mCollector);
  1563. // Update early out fraction based on narrow phase collector
  1564. if (!mCollector.mRejectAll)
  1565. UpdateEarlyOutFraction(mCollector.GetEarlyOutFraction());
  1566. }
  1567. const CCDBody & mCCDBody;
  1568. const Body & mBody1;
  1569. Vec3 mBody1Extent;
  1570. RShapeCast mShapeCast;
  1571. ShapeCastSettings & mShapeCastSettings;
  1572. CCDNarrowPhaseCollector & mCollector;
  1573. const BodyManager & mBodyManager;
  1574. PhysicsUpdateContext::Step *mStep;
  1575. float mDeltaTime;
  1576. };
  1577. // Check if we collide with any other body. Note that we use the non-locking interface as we know the broadphase cannot be modified at this point.
  1578. RShapeCast shape_cast(body.GetShape(), Vec3::sReplicate(1.0f), body.GetCenterOfMassTransform(), ccd_body.mDeltaPosition);
  1579. CCDBroadPhaseCollector bp_collector(ccd_body, body, shape_cast, settings, np_collector, mBodyManager, ioStep, ioContext->mStepDeltaTime);
  1580. mBroadPhase->CastAABoxNoLock({ shape_cast.mShapeWorldBounds, shape_cast.mDirection }, bp_collector, broadphase_layer_filter, object_layer_filter);
  1581. // Check if there was a hit
  1582. if (ccd_body.mFractionPlusSlop < 1.0f)
  1583. {
  1584. const Body &body2 = mBodyManager.GetBody(ccd_body.mBodyID2);
  1585. // Determine contact manifold
  1586. ContactManifold manifold;
  1587. manifold.mBaseOffset = shape_cast.mCenterOfMassStart.GetTranslation();
  1588. ManifoldBetweenTwoFaces(cast_shape_result.mContactPointOn1, cast_shape_result.mContactPointOn2, cast_shape_result.mPenetrationAxis, mPhysicsSettings.mManifoldToleranceSq, cast_shape_result.mShape1Face, cast_shape_result.mShape2Face, manifold.mRelativeContactPointsOn1, manifold.mRelativeContactPointsOn2 JPH_IF_DEBUG_RENDERER(, manifold.mBaseOffset));
  1589. manifold.mSubShapeID1 = cast_shape_result.mSubShapeID1;
  1590. manifold.mSubShapeID2 = cast_shape_result.mSubShapeID2;
  1591. manifold.mPenetrationDepth = cast_shape_result.mPenetrationDepth;
  1592. manifold.mWorldSpaceNormal = ccd_body.mContactNormal;
  1593. // Call contact point callbacks
  1594. mContactManager.OnCCDContactAdded(contact_allocator, body, body2, manifold, ccd_body.mContactSettings);
  1595. if (ccd_body.mContactSettings.mIsSensor)
  1596. {
  1597. // If this is a sensor, we don't want to solve the contact
  1598. ccd_body.mFractionPlusSlop = 1.0f;
  1599. ccd_body.mBodyID2 = BodyID();
  1600. }
  1601. else
  1602. {
  1603. // Calculate the average position from the manifold (this will result in the same impulse applied as when we apply impulses to all contact points)
  1604. if (manifold.mRelativeContactPointsOn2.size() > 1)
  1605. {
  1606. Vec3 average_contact_point = Vec3::sZero();
  1607. for (const Vec3 &v : manifold.mRelativeContactPointsOn2)
  1608. average_contact_point += v;
  1609. average_contact_point /= (float)manifold.mRelativeContactPointsOn2.size();
  1610. ccd_body.mContactPointOn2 = manifold.mBaseOffset + average_contact_point;
  1611. }
  1612. else
  1613. ccd_body.mContactPointOn2 = manifold.mBaseOffset + cast_shape_result.mContactPointOn2;
  1614. }
  1615. }
  1616. }
  1617. // Collect information from the contact allocator and accumulate it in the step.
  1618. sFinalizeContactAllocator(*ioStep, contact_allocator);
  1619. }
  1620. void PhysicsSystem::JobResolveCCDContacts(PhysicsUpdateContext *ioContext, PhysicsUpdateContext::Step *ioStep)
  1621. {
  1622. #ifdef JPH_ENABLE_ASSERTS
  1623. // Read/write body access
  1624. BodyAccess::Grant grant(BodyAccess::EAccess::ReadWrite, BodyAccess::EAccess::ReadWrite);
  1625. // We activate bodies that we collide with
  1626. BodyManager::GrantActiveBodiesAccess grant_active(true, false);
  1627. #endif
  1628. uint32 num_active_bodies_after_find_collisions = ioStep->mActiveBodyReadIdx;
  1629. TempAllocator *temp_allocator = ioContext->mTempAllocator;
  1630. // Check if there's anything to do
  1631. uint num_ccd_bodies = ioStep->mNumCCDBodies;
  1632. if (num_ccd_bodies > 0)
  1633. {
  1634. // Sort on fraction so that we process earliest collisions first
  1635. // This is needed to make the simulation deterministic and also to be able to stop contact processing
  1636. // between body pairs if an earlier hit was found involving the body by another CCD body
  1637. // (if it's body ID < this CCD body's body ID - see filtering logic in CCDBroadPhaseCollector)
  1638. CCDBody **sorted_ccd_bodies = (CCDBody **)temp_allocator->Allocate(num_ccd_bodies * sizeof(CCDBody *));
  1639. JPH_SCOPE_EXIT([temp_allocator, sorted_ccd_bodies, num_ccd_bodies]{ temp_allocator->Free(sorted_ccd_bodies, num_ccd_bodies * sizeof(CCDBody *)); });
  1640. {
  1641. JPH_PROFILE("Sort");
  1642. // We don't want to copy the entire struct (it's quite big), so we create a pointer array first
  1643. CCDBody *src_ccd_bodies = ioStep->mCCDBodies;
  1644. CCDBody **dst_ccd_bodies = sorted_ccd_bodies;
  1645. CCDBody **dst_ccd_bodies_end = dst_ccd_bodies + num_ccd_bodies;
  1646. while (dst_ccd_bodies < dst_ccd_bodies_end)
  1647. *(dst_ccd_bodies++) = src_ccd_bodies++;
  1648. // Which we then sort
  1649. QuickSort(sorted_ccd_bodies, sorted_ccd_bodies + num_ccd_bodies, [](const CCDBody *inBody1, const CCDBody *inBody2)
  1650. {
  1651. if (inBody1->mFractionPlusSlop != inBody2->mFractionPlusSlop)
  1652. return inBody1->mFractionPlusSlop < inBody2->mFractionPlusSlop;
  1653. return inBody1->mBodyID1 < inBody2->mBodyID1;
  1654. });
  1655. }
  1656. // We can collide with bodies that are not active, we track them here so we can activate them in one go at the end.
  1657. // This is also needed because we can't modify the active body array while we iterate it.
  1658. static constexpr int cBodiesBatch = 64;
  1659. BodyID *bodies_to_activate = (BodyID *)JPH_STACK_ALLOC(cBodiesBatch * sizeof(BodyID));
  1660. int num_bodies_to_activate = 0;
  1661. // We can move bodies that are not part of an island. In this case we need to notify the broadphase of the movement.
  1662. BodyID *bodies_to_update_bounds = (BodyID *)JPH_STACK_ALLOC(cBodiesBatch * sizeof(BodyID));
  1663. int num_bodies_to_update_bounds = 0;
  1664. for (uint i = 0; i < num_ccd_bodies; ++i)
  1665. {
  1666. const CCDBody *ccd_body = sorted_ccd_bodies[i];
  1667. Body &body1 = mBodyManager.GetBody(ccd_body->mBodyID1);
  1668. MotionProperties *body_mp = body1.GetMotionProperties();
  1669. // If there was a hit
  1670. if (!ccd_body->mBodyID2.IsInvalid())
  1671. {
  1672. Body &body2 = mBodyManager.GetBody(ccd_body->mBodyID2);
  1673. // Determine if the other body has a CCD body
  1674. CCDBody *ccd_body2 = sGetCCDBody(body2, ioStep);
  1675. if (ccd_body2 != nullptr)
  1676. {
  1677. JPH_ASSERT(ccd_body2->mBodyID2 != ccd_body->mBodyID1, "If we collided with another body, that other body should have ignored collisions with us!");
  1678. // Check if the other body found a hit that is further away
  1679. if (ccd_body2->mFraction > ccd_body->mFraction)
  1680. {
  1681. // Reset the colliding body of the other CCD body. The other body will shorten its distance traveled and will not do any collision response (we'll do that).
  1682. // This means that at this point we have triggered a contact point add/persist for our further hit by accident for the other body.
  1683. // We accept this as calling the contact point callbacks here would require persisting the manifolds up to this point and doing the callbacks single threaded.
  1684. ccd_body2->mBodyID2 = BodyID();
  1685. ccd_body2->mFractionPlusSlop = ccd_body->mFraction;
  1686. }
  1687. }
  1688. // If the other body moved less than us before hitting something, we're not colliding with it so we again have triggered contact point add/persist callbacks by accident.
  1689. // We'll just move to the collision position anyway (as that's the last position we know is good), but we won't do any collision response.
  1690. if (ccd_body2 == nullptr || ccd_body2->mFraction >= ccd_body->mFraction)
  1691. {
  1692. const ContactSettings &contact_settings = ccd_body->mContactSettings;
  1693. // Calculate contact point velocity for body 1
  1694. Vec3 r1_plus_u = Vec3(ccd_body->mContactPointOn2 - (body1.GetCenterOfMassPosition() + ccd_body->mFraction * ccd_body->mDeltaPosition));
  1695. Vec3 v1 = body1.GetPointVelocityCOM(r1_plus_u);
  1696. // Calculate inverse mass for body 1
  1697. float inv_m1 = contact_settings.mInvMassScale1 * body_mp->GetInverseMass();
  1698. if (body2.IsRigidBody())
  1699. {
  1700. // Calculate contact point velocity for body 2
  1701. Vec3 r2 = Vec3(ccd_body->mContactPointOn2 - body2.GetCenterOfMassPosition());
  1702. Vec3 v2 = body2.GetPointVelocityCOM(r2);
  1703. // Calculate relative contact velocity
  1704. Vec3 relative_velocity = v2 - v1;
  1705. float normal_velocity = relative_velocity.Dot(ccd_body->mContactNormal);
  1706. // Calculate velocity bias due to restitution
  1707. float normal_velocity_bias;
  1708. if (contact_settings.mCombinedRestitution > 0.0f && normal_velocity < -mPhysicsSettings.mMinVelocityForRestitution)
  1709. normal_velocity_bias = contact_settings.mCombinedRestitution * normal_velocity;
  1710. else
  1711. normal_velocity_bias = 0.0f;
  1712. // Get inverse mass of body 2
  1713. float inv_m2 = body2.GetMotionPropertiesUnchecked() != nullptr? contact_settings.mInvMassScale2 * body2.GetMotionPropertiesUnchecked()->GetInverseMassUnchecked() : 0.0f;
  1714. // Solve contact constraint
  1715. AxisConstraintPart contact_constraint;
  1716. contact_constraint.CalculateConstraintPropertiesWithMassOverride(body1, inv_m1, contact_settings.mInvInertiaScale1, r1_plus_u, body2, inv_m2, contact_settings.mInvInertiaScale2, r2, ccd_body->mContactNormal, normal_velocity_bias);
  1717. contact_constraint.SolveVelocityConstraintWithMassOverride(body1, inv_m1, body2, inv_m2, ccd_body->mContactNormal, -FLT_MAX, FLT_MAX);
  1718. // Apply friction
  1719. if (contact_settings.mCombinedFriction > 0.0f)
  1720. {
  1721. // Calculate friction direction by removing normal velocity from the relative velocity
  1722. Vec3 friction_direction = relative_velocity - normal_velocity * ccd_body->mContactNormal;
  1723. float friction_direction_len_sq = friction_direction.LengthSq();
  1724. if (friction_direction_len_sq > 1.0e-12f)
  1725. {
  1726. // Normalize friction direction
  1727. friction_direction /= sqrt(friction_direction_len_sq);
  1728. // Calculate max friction impulse
  1729. float max_lambda_f = contact_settings.mCombinedFriction * contact_constraint.GetTotalLambda();
  1730. AxisConstraintPart friction;
  1731. friction.CalculateConstraintPropertiesWithMassOverride(body1, inv_m1, contact_settings.mInvInertiaScale1, r1_plus_u, body2, inv_m2, contact_settings.mInvInertiaScale2, r2, friction_direction);
  1732. friction.SolveVelocityConstraintWithMassOverride(body1, inv_m1, body2, inv_m2, friction_direction, -max_lambda_f, max_lambda_f);
  1733. }
  1734. }
  1735. // Clamp velocity of body 2
  1736. if (body2.IsDynamic())
  1737. {
  1738. MotionProperties *body2_mp = body2.GetMotionProperties();
  1739. body2_mp->ClampLinearVelocity();
  1740. body2_mp->ClampAngularVelocity();
  1741. }
  1742. }
  1743. else
  1744. {
  1745. SoftBodyMotionProperties *soft_mp = static_cast<SoftBodyMotionProperties *>(body2.GetMotionProperties());
  1746. const SoftBodyShape *soft_shape = static_cast<const SoftBodyShape *>(body2.GetShape());
  1747. // Convert the sub shape ID of the soft body to a face
  1748. uint32 face_idx = soft_shape->GetFaceIndex(ccd_body->mSubShapeID2);
  1749. const SoftBodyMotionProperties::Face &face = soft_mp->GetFace(face_idx);
  1750. // Get vertices of the face
  1751. SoftBodyMotionProperties::Vertex &vtx0 = soft_mp->GetVertex(face.mVertex[0]);
  1752. SoftBodyMotionProperties::Vertex &vtx1 = soft_mp->GetVertex(face.mVertex[1]);
  1753. SoftBodyMotionProperties::Vertex &vtx2 = soft_mp->GetVertex(face.mVertex[2]);
  1754. // Inverse mass of the face
  1755. float vtx0_mass = vtx0.mInvMass > 0.0f? 1.0f / vtx0.mInvMass : 1.0e10f;
  1756. float vtx1_mass = vtx1.mInvMass > 0.0f? 1.0f / vtx1.mInvMass : 1.0e10f;
  1757. float vtx2_mass = vtx2.mInvMass > 0.0f? 1.0f / vtx2.mInvMass : 1.0e10f;
  1758. float inv_m2 = 1.0f / (vtx0_mass + vtx1_mass + vtx2_mass);
  1759. // Calculate barycentric coordinates of the contact point on the soft body's face
  1760. float u, v, w;
  1761. RMat44 inv_body2_transform = body2.GetInverseCenterOfMassTransform();
  1762. Vec3 local_contact = Vec3(inv_body2_transform * ccd_body->mContactPointOn2);
  1763. ClosestPoint::GetBaryCentricCoordinates(vtx0.mPosition - local_contact, vtx1.mPosition - local_contact, vtx2.mPosition - local_contact, u, v, w);
  1764. // Calculate contact point velocity for the face
  1765. Vec3 v2 = inv_body2_transform.Multiply3x3Transposed(u * vtx0.mVelocity + v * vtx1.mVelocity + w * vtx2.mVelocity);
  1766. float normal_velocity = (v2 - v1).Dot(ccd_body->mContactNormal);
  1767. // Calculate velocity bias due to restitution
  1768. float normal_velocity_bias;
  1769. if (contact_settings.mCombinedRestitution > 0.0f && normal_velocity < -mPhysicsSettings.mMinVelocityForRestitution)
  1770. normal_velocity_bias = contact_settings.mCombinedRestitution * normal_velocity;
  1771. else
  1772. normal_velocity_bias = 0.0f;
  1773. // Calculate resulting velocity change (the math here is similar to AxisConstraintPart but without an inertia term for body 2 as we treat it as a point mass)
  1774. Vec3 r1_plus_u_x_n = r1_plus_u.Cross(ccd_body->mContactNormal);
  1775. Vec3 invi1_r1_plus_u_x_n = contact_settings.mInvInertiaScale1 * body1.GetInverseInertia().Multiply3x3(r1_plus_u_x_n);
  1776. float jv = r1_plus_u_x_n.Dot(body_mp->GetAngularVelocity()) - normal_velocity - normal_velocity_bias;
  1777. float inv_effective_mass = inv_m1 + inv_m2 + invi1_r1_plus_u_x_n.Dot(r1_plus_u_x_n);
  1778. float lambda = jv / inv_effective_mass;
  1779. body_mp->SubLinearVelocityStep((lambda * inv_m1) * ccd_body->mContactNormal);
  1780. body_mp->SubAngularVelocityStep(lambda * invi1_r1_plus_u_x_n);
  1781. Vec3 delta_v2 = inv_body2_transform.Multiply3x3(lambda * ccd_body->mContactNormal);
  1782. vtx0.mVelocity += delta_v2 * vtx0.mInvMass;
  1783. vtx1.mVelocity += delta_v2 * vtx1.mInvMass;
  1784. vtx2.mVelocity += delta_v2 * vtx2.mInvMass;
  1785. }
  1786. // Clamp velocity of body 1
  1787. body_mp->ClampLinearVelocity();
  1788. body_mp->ClampAngularVelocity();
  1789. // Activate the 2nd body if it is not already active
  1790. if (body2.IsDynamic() && !body2.IsActive())
  1791. {
  1792. bodies_to_activate[num_bodies_to_activate++] = ccd_body->mBodyID2;
  1793. if (num_bodies_to_activate == cBodiesBatch)
  1794. {
  1795. // Batch is full, activate now
  1796. mBodyManager.ActivateBodies(bodies_to_activate, num_bodies_to_activate);
  1797. num_bodies_to_activate = 0;
  1798. }
  1799. }
  1800. #ifdef JPH_DEBUG_RENDERER
  1801. if (sDrawMotionQualityLinearCast)
  1802. {
  1803. // Draw the collision location
  1804. RMat44 collision_transform = body1.GetCenterOfMassTransform().PostTranslated(ccd_body->mFraction * ccd_body->mDeltaPosition);
  1805. body1.GetShape()->Draw(DebugRenderer::sInstance, collision_transform, Vec3::sReplicate(1.0f), Color::sYellow, false, true);
  1806. // Draw the collision location + slop
  1807. RMat44 collision_transform_plus_slop = body1.GetCenterOfMassTransform().PostTranslated(ccd_body->mFractionPlusSlop * ccd_body->mDeltaPosition);
  1808. body1.GetShape()->Draw(DebugRenderer::sInstance, collision_transform_plus_slop, Vec3::sReplicate(1.0f), Color::sOrange, false, true);
  1809. // Draw contact normal
  1810. DebugRenderer::sInstance->DrawArrow(ccd_body->mContactPointOn2, ccd_body->mContactPointOn2 - ccd_body->mContactNormal, Color::sYellow, 0.1f);
  1811. // Draw post contact velocity
  1812. DebugRenderer::sInstance->DrawArrow(collision_transform.GetTranslation(), collision_transform.GetTranslation() + body1.GetLinearVelocity(), Color::sOrange, 0.1f);
  1813. DebugRenderer::sInstance->DrawArrow(collision_transform.GetTranslation(), collision_transform.GetTranslation() + body1.GetAngularVelocity(), Color::sPurple, 0.1f);
  1814. }
  1815. #endif // JPH_DEBUG_RENDERER
  1816. }
  1817. }
  1818. // Update body position
  1819. body1.AddPositionStep(ccd_body->mDeltaPosition * ccd_body->mFractionPlusSlop);
  1820. // If the body was activated due to an earlier CCD step it will have an index in the active
  1821. // body list that it higher than the highest one we processed during FindCollisions
  1822. // which means it hasn't been assigned an island and will not be updated by an island
  1823. // this means that we need to update its bounds manually
  1824. if (body_mp->GetIndexInActiveBodiesInternal() >= num_active_bodies_after_find_collisions)
  1825. {
  1826. body1.CalculateWorldSpaceBoundsInternal();
  1827. bodies_to_update_bounds[num_bodies_to_update_bounds++] = body1.GetID();
  1828. if (num_bodies_to_update_bounds == cBodiesBatch)
  1829. {
  1830. // Buffer full, flush now
  1831. mBroadPhase->NotifyBodiesAABBChanged(bodies_to_update_bounds, num_bodies_to_update_bounds, false);
  1832. num_bodies_to_update_bounds = 0;
  1833. }
  1834. }
  1835. }
  1836. // Activate the requested bodies
  1837. if (num_bodies_to_activate > 0)
  1838. mBodyManager.ActivateBodies(bodies_to_activate, num_bodies_to_activate);
  1839. // Notify change bounds on requested bodies
  1840. if (num_bodies_to_update_bounds > 0)
  1841. mBroadPhase->NotifyBodiesAABBChanged(bodies_to_update_bounds, num_bodies_to_update_bounds, false);
  1842. }
  1843. // Ensure we free the CCD bodies array now, will not call the destructor!
  1844. temp_allocator->Free(ioStep->mActiveBodyToCCDBody, ioStep->mNumActiveBodyToCCDBody * sizeof(int));
  1845. ioStep->mActiveBodyToCCDBody = nullptr;
  1846. ioStep->mNumActiveBodyToCCDBody = 0;
  1847. temp_allocator->Free(ioStep->mCCDBodies, ioStep->mCCDBodiesCapacity * sizeof(CCDBody));
  1848. ioStep->mCCDBodies = nullptr;
  1849. ioStep->mCCDBodiesCapacity = 0;
  1850. }
  1851. void PhysicsSystem::JobContactRemovedCallbacks(const PhysicsUpdateContext::Step *ioStep)
  1852. {
  1853. #ifdef JPH_ENABLE_ASSERTS
  1854. // We don't touch any bodies
  1855. BodyAccess::Grant grant(BodyAccess::EAccess::None, BodyAccess::EAccess::None);
  1856. #endif
  1857. // Reset the Body::EFlags::InvalidateContactCache flag for all bodies
  1858. mBodyManager.ValidateContactCacheForAllBodies();
  1859. // Finalize the contact cache (this swaps the read and write versions of the contact cache)
  1860. // Trigger all contact removed callbacks by looking at last step contact points that have not been flagged as reused
  1861. mContactManager.FinalizeContactCacheAndCallContactPointRemovedCallbacks(ioStep->mNumBodyPairs, ioStep->mNumManifolds);
  1862. }
  1863. class PhysicsSystem::BodiesToSleep : public NonCopyable
  1864. {
  1865. public:
  1866. static constexpr int cBodiesToSleepSize = 512;
  1867. static constexpr int cMaxBodiesToPutInBuffer = 128;
  1868. inline BodiesToSleep(BodyManager &inBodyManager, BodyID *inBodiesToSleepBuffer) : mBodyManager(inBodyManager), mBodiesToSleepBuffer(inBodiesToSleepBuffer), mBodiesToSleepCur(inBodiesToSleepBuffer) { }
  1869. inline ~BodiesToSleep()
  1870. {
  1871. // Flush the bodies to sleep buffer
  1872. int num_bodies_in_buffer = int(mBodiesToSleepCur - mBodiesToSleepBuffer);
  1873. if (num_bodies_in_buffer > 0)
  1874. mBodyManager.DeactivateBodies(mBodiesToSleepBuffer, num_bodies_in_buffer);
  1875. }
  1876. inline void PutToSleep(const BodyID *inBegin, const BodyID *inEnd)
  1877. {
  1878. int num_bodies_to_sleep = int(inEnd - inBegin);
  1879. if (num_bodies_to_sleep > cMaxBodiesToPutInBuffer)
  1880. {
  1881. // Too many bodies, deactivate immediately
  1882. mBodyManager.DeactivateBodies(inBegin, num_bodies_to_sleep);
  1883. }
  1884. else
  1885. {
  1886. // Check if there's enough space in the bodies to sleep buffer
  1887. int num_bodies_in_buffer = int(mBodiesToSleepCur - mBodiesToSleepBuffer);
  1888. if (num_bodies_in_buffer + num_bodies_to_sleep > cBodiesToSleepSize)
  1889. {
  1890. // Flush the bodies to sleep buffer
  1891. mBodyManager.DeactivateBodies(mBodiesToSleepBuffer, num_bodies_in_buffer);
  1892. mBodiesToSleepCur = mBodiesToSleepBuffer;
  1893. }
  1894. // Copy the bodies in the buffer
  1895. memcpy(mBodiesToSleepCur, inBegin, num_bodies_to_sleep * sizeof(BodyID));
  1896. mBodiesToSleepCur += num_bodies_to_sleep;
  1897. }
  1898. }
  1899. private:
  1900. BodyManager & mBodyManager;
  1901. BodyID * mBodiesToSleepBuffer;
  1902. BodyID * mBodiesToSleepCur;
  1903. };
  1904. void PhysicsSystem::CheckSleepAndUpdateBounds(uint32 inIslandIndex, const PhysicsUpdateContext *ioContext, const PhysicsUpdateContext::Step *ioStep, BodiesToSleep &ioBodiesToSleep)
  1905. {
  1906. // Get the bodies that belong to this island
  1907. BodyID *bodies_begin, *bodies_end;
  1908. mIslandBuilder.GetBodiesInIsland(inIslandIndex, bodies_begin, bodies_end);
  1909. // Only check sleeping in the last step
  1910. // Also resets force and torque used during the apply gravity phase
  1911. if (ioStep->mIsLast)
  1912. {
  1913. JPH_PROFILE("Check Sleeping");
  1914. static_assert(int(ECanSleep::CannotSleep) == 0 && int(ECanSleep::CanSleep) == 1, "Loop below makes this assumption");
  1915. int all_can_sleep = mPhysicsSettings.mAllowSleeping? int(ECanSleep::CanSleep) : int(ECanSleep::CannotSleep);
  1916. float time_before_sleep = mPhysicsSettings.mTimeBeforeSleep;
  1917. float max_movement = mPhysicsSettings.mPointVelocitySleepThreshold * time_before_sleep;
  1918. for (const BodyID *body_id = bodies_begin; body_id < bodies_end; ++body_id)
  1919. {
  1920. Body &body = mBodyManager.GetBody(*body_id);
  1921. // Update bounding box
  1922. body.CalculateWorldSpaceBoundsInternal();
  1923. // Update sleeping
  1924. all_can_sleep &= int(body.UpdateSleepStateInternal(ioContext->mStepDeltaTime, max_movement, time_before_sleep));
  1925. // Reset force and torque
  1926. MotionProperties *mp = body.GetMotionProperties();
  1927. mp->ResetForce();
  1928. mp->ResetTorque();
  1929. }
  1930. // If all bodies indicate they can sleep we can deactivate them
  1931. if (all_can_sleep == int(ECanSleep::CanSleep))
  1932. ioBodiesToSleep.PutToSleep(bodies_begin, bodies_end);
  1933. }
  1934. else
  1935. {
  1936. JPH_PROFILE("Update Bounds");
  1937. // Update bounding box only for all other steps
  1938. for (const BodyID *body_id = bodies_begin; body_id < bodies_end; ++body_id)
  1939. {
  1940. Body &body = mBodyManager.GetBody(*body_id);
  1941. body.CalculateWorldSpaceBoundsInternal();
  1942. }
  1943. }
  1944. // Notify broadphase of changed objects (find ccd contacts can do linear casts in the next step, so we need to do this every step)
  1945. // Note: Shuffles the BodyID's around!!!
  1946. mBroadPhase->NotifyBodiesAABBChanged(bodies_begin, int(bodies_end - bodies_begin), false);
  1947. }
  1948. void PhysicsSystem::JobSolvePositionConstraints(PhysicsUpdateContext *ioContext, PhysicsUpdateContext::Step *ioStep)
  1949. {
  1950. #ifdef JPH_ENABLE_ASSERTS
  1951. // We fix up position errors
  1952. BodyAccess::Grant grant(BodyAccess::EAccess::None, BodyAccess::EAccess::ReadWrite);
  1953. // Can only deactivate bodies
  1954. BodyManager::GrantActiveBodiesAccess grant_active(false, true);
  1955. #endif
  1956. float delta_time = ioContext->mStepDeltaTime;
  1957. float baumgarte = mPhysicsSettings.mBaumgarte;
  1958. Constraint **active_constraints = ioContext->mActiveConstraints;
  1959. // Keep a buffer of bodies that need to go to sleep in order to not constantly lock the active bodies mutex and create contention between all solving threads
  1960. BodiesToSleep bodies_to_sleep(mBodyManager, (BodyID *)JPH_STACK_ALLOC(BodiesToSleep::cBodiesToSleepSize * sizeof(BodyID)));
  1961. bool check_islands = true, check_split_islands = mPhysicsSettings.mUseLargeIslandSplitter;
  1962. do
  1963. {
  1964. // First try to get work from large islands
  1965. if (check_split_islands)
  1966. {
  1967. bool first_iteration;
  1968. uint split_island_index;
  1969. uint32 *constraints_begin, *constraints_end, *contacts_begin, *contacts_end;
  1970. switch (mLargeIslandSplitter.FetchNextBatch(split_island_index, constraints_begin, constraints_end, contacts_begin, contacts_end, first_iteration))
  1971. {
  1972. case LargeIslandSplitter::EStatus::BatchRetrieved:
  1973. // Solve the batch
  1974. ConstraintManager::sSolvePositionConstraints(active_constraints, constraints_begin, constraints_end, delta_time, baumgarte);
  1975. mContactManager.SolvePositionConstraints(contacts_begin, contacts_end);
  1976. // Mark the batch as processed
  1977. bool last_iteration, final_batch;
  1978. mLargeIslandSplitter.MarkBatchProcessed(split_island_index, constraints_begin, constraints_end, contacts_begin, contacts_end, last_iteration, final_batch);
  1979. // The final batch will update all bounds and check sleeping
  1980. if (final_batch)
  1981. CheckSleepAndUpdateBounds(mLargeIslandSplitter.GetIslandIndex(split_island_index), ioContext, ioStep, bodies_to_sleep);
  1982. // We processed work, loop again
  1983. continue;
  1984. case LargeIslandSplitter::EStatus::WaitingForBatch:
  1985. break;
  1986. case LargeIslandSplitter::EStatus::AllBatchesDone:
  1987. check_split_islands = false;
  1988. break;
  1989. }
  1990. }
  1991. // If that didn't succeed try to process an island
  1992. if (check_islands)
  1993. {
  1994. // Next island
  1995. uint32 island_idx = ioStep->mSolvePositionConstraintsNextIsland++;
  1996. if (island_idx >= mIslandBuilder.GetNumIslands())
  1997. {
  1998. // We processed all islands, stop checking islands
  1999. check_islands = false;
  2000. continue;
  2001. }
  2002. JPH_PROFILE("Island");
  2003. // Get iterators for this island
  2004. uint32 *constraints_begin, *constraints_end, *contacts_begin, *contacts_end;
  2005. mIslandBuilder.GetConstraintsInIsland(island_idx, constraints_begin, constraints_end);
  2006. mIslandBuilder.GetContactsInIsland(island_idx, contacts_begin, contacts_end);
  2007. // If this island is a large island, it will be picked up as a batch and we don't need to do anything here
  2008. uint num_items = uint(constraints_end - constraints_begin) + uint(contacts_end - contacts_begin);
  2009. if (mPhysicsSettings.mUseLargeIslandSplitter
  2010. && num_items >= LargeIslandSplitter::cLargeIslandTreshold)
  2011. continue;
  2012. // Check if this island needs solving
  2013. if (num_items > 0)
  2014. {
  2015. // Iterate
  2016. uint num_position_steps = mIslandBuilder.GetNumPositionSteps(island_idx);
  2017. for (uint position_step = 0; position_step < num_position_steps; ++position_step)
  2018. {
  2019. bool applied_impulse = ConstraintManager::sSolvePositionConstraints(active_constraints, constraints_begin, constraints_end, delta_time, baumgarte);
  2020. applied_impulse |= mContactManager.SolvePositionConstraints(contacts_begin, contacts_end);
  2021. if (!applied_impulse)
  2022. break;
  2023. }
  2024. }
  2025. // After solving we will update all bounds and check sleeping
  2026. CheckSleepAndUpdateBounds(island_idx, ioContext, ioStep, bodies_to_sleep);
  2027. // We processed work, loop again
  2028. continue;
  2029. }
  2030. // If we didn't find any work, give up a time slice
  2031. std::this_thread::yield();
  2032. }
  2033. while (check_islands || check_split_islands);
  2034. }
  2035. void PhysicsSystem::JobSoftBodyPrepare(PhysicsUpdateContext *ioContext, PhysicsUpdateContext::Step *ioStep)
  2036. {
  2037. JPH_PROFILE_FUNCTION();
  2038. {
  2039. #ifdef JPH_ENABLE_ASSERTS
  2040. // Reading soft body positions
  2041. BodyAccess::Grant grant(BodyAccess::EAccess::None, BodyAccess::EAccess::Read);
  2042. #endif
  2043. // Get the active soft bodies
  2044. BodyIDVector active_bodies;
  2045. mBodyManager.GetActiveBodies(EBodyType::SoftBody, active_bodies);
  2046. // Quit if there are no active soft bodies
  2047. if (active_bodies.empty())
  2048. {
  2049. // Kick the next step
  2050. if (ioStep->mStartNextStep.IsValid())
  2051. ioStep->mStartNextStep.RemoveDependency();
  2052. return;
  2053. }
  2054. // Sort to get a deterministic update order
  2055. QuickSort(active_bodies.begin(), active_bodies.end());
  2056. // Allocate soft body contexts
  2057. ioContext->mNumSoftBodies = (uint)active_bodies.size();
  2058. ioContext->mSoftBodyUpdateContexts = (SoftBodyUpdateContext *)ioContext->mTempAllocator->Allocate(ioContext->mNumSoftBodies * sizeof(SoftBodyUpdateContext));
  2059. // Initialize soft body contexts
  2060. for (SoftBodyUpdateContext *sb_ctx = ioContext->mSoftBodyUpdateContexts, *sb_ctx_end = ioContext->mSoftBodyUpdateContexts + ioContext->mNumSoftBodies; sb_ctx < sb_ctx_end; ++sb_ctx)
  2061. {
  2062. new (sb_ctx) SoftBodyUpdateContext;
  2063. Body &body = mBodyManager.GetBody(active_bodies[sb_ctx - ioContext->mSoftBodyUpdateContexts]);
  2064. SoftBodyMotionProperties *mp = static_cast<SoftBodyMotionProperties *>(body.GetMotionProperties());
  2065. mp->InitializeUpdateContext(ioContext->mStepDeltaTime, body, *this, *sb_ctx);
  2066. }
  2067. }
  2068. // We're ready to collide the first soft body
  2069. ioContext->mSoftBodyToCollide.store(0, memory_order_release);
  2070. // Determine number of jobs to spawn
  2071. int num_soft_body_jobs = ioContext->GetMaxConcurrency();
  2072. // Create finalize job
  2073. ioStep->mSoftBodyFinalize = ioContext->mJobSystem->CreateJob("SoftBodyFinalize", cColorSoftBodyFinalize, [ioContext, ioStep]()
  2074. {
  2075. ioContext->mPhysicsSystem->JobSoftBodyFinalize(ioContext);
  2076. // Kick the next step
  2077. if (ioStep->mStartNextStep.IsValid())
  2078. ioStep->mStartNextStep.RemoveDependency();
  2079. }, num_soft_body_jobs); // depends on: soft body simulate
  2080. ioContext->mBarrier->AddJob(ioStep->mSoftBodyFinalize);
  2081. // Create simulate jobs
  2082. ioStep->mSoftBodySimulate.resize(num_soft_body_jobs);
  2083. for (int i = 0; i < num_soft_body_jobs; ++i)
  2084. ioStep->mSoftBodySimulate[i] = ioContext->mJobSystem->CreateJob("SoftBodySimulate", cColorSoftBodySimulate, [ioStep, i]()
  2085. {
  2086. ioStep->mContext->mPhysicsSystem->JobSoftBodySimulate(ioStep->mContext, i);
  2087. ioStep->mSoftBodyFinalize.RemoveDependency();
  2088. }, num_soft_body_jobs); // depends on: soft body collide
  2089. ioContext->mBarrier->AddJobs(ioStep->mSoftBodySimulate.data(), ioStep->mSoftBodySimulate.size());
  2090. // Create collision jobs
  2091. ioStep->mSoftBodyCollide.resize(num_soft_body_jobs);
  2092. for (int i = 0; i < num_soft_body_jobs; ++i)
  2093. ioStep->mSoftBodyCollide[i] = ioContext->mJobSystem->CreateJob("SoftBodyCollide", cColorSoftBodyCollide, [ioContext, ioStep]()
  2094. {
  2095. ioContext->mPhysicsSystem->JobSoftBodyCollide(ioContext);
  2096. for (const JobHandle &h : ioStep->mSoftBodySimulate)
  2097. h.RemoveDependency();
  2098. }); // depends on: nothing
  2099. ioContext->mBarrier->AddJobs(ioStep->mSoftBodyCollide.data(), ioStep->mSoftBodyCollide.size());
  2100. }
  2101. void PhysicsSystem::JobSoftBodyCollide(PhysicsUpdateContext *ioContext) const
  2102. {
  2103. #ifdef JPH_ENABLE_ASSERTS
  2104. // Reading rigid body positions and velocities
  2105. BodyAccess::Grant grant(BodyAccess::EAccess::Read, BodyAccess::EAccess::Read);
  2106. #endif
  2107. for (;;)
  2108. {
  2109. // Fetch the next soft body
  2110. uint sb_idx = ioContext->mSoftBodyToCollide.fetch_add(1, std::memory_order_acquire);
  2111. if (sb_idx >= ioContext->mNumSoftBodies)
  2112. break;
  2113. // Do a broadphase check
  2114. SoftBodyUpdateContext &sb_ctx = ioContext->mSoftBodyUpdateContexts[sb_idx];
  2115. sb_ctx.mMotionProperties->DetermineCollidingShapes(sb_ctx, *this, GetBodyLockInterfaceNoLock());
  2116. }
  2117. }
  2118. void PhysicsSystem::JobSoftBodySimulate(PhysicsUpdateContext *ioContext, uint inThreadIndex) const
  2119. {
  2120. #ifdef JPH_ENABLE_ASSERTS
  2121. // Updating velocities of soft bodies, allow the contact listener to read the soft body state
  2122. BodyAccess::Grant grant(BodyAccess::EAccess::ReadWrite, BodyAccess::EAccess::Read);
  2123. #endif
  2124. // Calculate at which body we start to distribute the workload across the threads
  2125. uint num_soft_bodies = ioContext->mNumSoftBodies;
  2126. uint start_idx = inThreadIndex * num_soft_bodies / ioContext->GetMaxConcurrency();
  2127. // Keep running partial updates until everything has been updated
  2128. uint status;
  2129. do
  2130. {
  2131. // Reset status
  2132. status = 0;
  2133. // Update all soft bodies
  2134. for (uint i = 0; i < num_soft_bodies; ++i)
  2135. {
  2136. // Fetch the soft body context
  2137. SoftBodyUpdateContext &sb_ctx = ioContext->mSoftBodyUpdateContexts[(start_idx + i) % num_soft_bodies];
  2138. // To avoid trashing the cache too much, we prefer to stick to one soft body until we cannot progress it any further
  2139. uint sb_status;
  2140. do
  2141. {
  2142. sb_status = (uint)sb_ctx.mMotionProperties->ParallelUpdate(sb_ctx, mPhysicsSettings);
  2143. status |= sb_status;
  2144. } while (sb_status == (uint)SoftBodyMotionProperties::EStatus::DidWork);
  2145. }
  2146. // If we didn't perform any work, yield the thread so that something else can run
  2147. if (!(status & (uint)SoftBodyMotionProperties::EStatus::DidWork))
  2148. std::this_thread::yield();
  2149. }
  2150. while (status != (uint)SoftBodyMotionProperties::EStatus::Done);
  2151. }
  2152. void PhysicsSystem::JobSoftBodyFinalize(PhysicsUpdateContext *ioContext)
  2153. {
  2154. #ifdef JPH_ENABLE_ASSERTS
  2155. // Updating rigid body velocities and soft body positions / velocities
  2156. BodyAccess::Grant grant(BodyAccess::EAccess::ReadWrite, BodyAccess::EAccess::ReadWrite);
  2157. // Can activate and deactivate bodies
  2158. BodyManager::GrantActiveBodiesAccess grant_active(true, true);
  2159. #endif
  2160. static constexpr int cBodiesBatch = 64;
  2161. BodyID *bodies_to_update_bounds = (BodyID *)JPH_STACK_ALLOC(cBodiesBatch * sizeof(BodyID));
  2162. int num_bodies_to_update_bounds = 0;
  2163. BodyID *bodies_to_put_to_sleep = (BodyID *)JPH_STACK_ALLOC(cBodiesBatch * sizeof(BodyID));
  2164. int num_bodies_to_put_to_sleep = 0;
  2165. for (SoftBodyUpdateContext *sb_ctx = ioContext->mSoftBodyUpdateContexts, *sb_ctx_end = ioContext->mSoftBodyUpdateContexts + ioContext->mNumSoftBodies; sb_ctx < sb_ctx_end; ++sb_ctx)
  2166. {
  2167. // Apply the rigid body velocity deltas
  2168. sb_ctx->mMotionProperties->UpdateRigidBodyVelocities(*sb_ctx, GetBodyInterfaceNoLock());
  2169. // Update the position
  2170. sb_ctx->mBody->SetPositionAndRotationInternal(sb_ctx->mBody->GetPosition() + sb_ctx->mDeltaPosition, sb_ctx->mBody->GetRotation(), false);
  2171. BodyID id = sb_ctx->mBody->GetID();
  2172. bodies_to_update_bounds[num_bodies_to_update_bounds++] = id;
  2173. if (num_bodies_to_update_bounds == cBodiesBatch)
  2174. {
  2175. // Buffer full, flush now
  2176. mBroadPhase->NotifyBodiesAABBChanged(bodies_to_update_bounds, num_bodies_to_update_bounds, false);
  2177. num_bodies_to_update_bounds = 0;
  2178. }
  2179. if (sb_ctx->mCanSleep == ECanSleep::CanSleep)
  2180. {
  2181. // This body should go to sleep
  2182. bodies_to_put_to_sleep[num_bodies_to_put_to_sleep++] = id;
  2183. if (num_bodies_to_put_to_sleep == cBodiesBatch)
  2184. {
  2185. mBodyManager.DeactivateBodies(bodies_to_put_to_sleep, num_bodies_to_put_to_sleep);
  2186. num_bodies_to_put_to_sleep = 0;
  2187. }
  2188. }
  2189. }
  2190. // Notify change bounds on requested bodies
  2191. if (num_bodies_to_update_bounds > 0)
  2192. mBroadPhase->NotifyBodiesAABBChanged(bodies_to_update_bounds, num_bodies_to_update_bounds, false);
  2193. // Notify bodies to go to sleep
  2194. if (num_bodies_to_put_to_sleep > 0)
  2195. mBodyManager.DeactivateBodies(bodies_to_put_to_sleep, num_bodies_to_put_to_sleep);
  2196. // Free soft body contexts
  2197. ioContext->mTempAllocator->Free(ioContext->mSoftBodyUpdateContexts, ioContext->mNumSoftBodies * sizeof(SoftBodyUpdateContext));
  2198. }
  2199. void PhysicsSystem::SaveState(StateRecorder &inStream, EStateRecorderState inState, const StateRecorderFilter *inFilter) const
  2200. {
  2201. JPH_PROFILE_FUNCTION();
  2202. inStream.Write(inState);
  2203. if (uint8(inState) & uint8(EStateRecorderState::Global))
  2204. {
  2205. inStream.Write(mPreviousStepDeltaTime);
  2206. inStream.Write(mGravity);
  2207. }
  2208. if (uint8(inState) & uint8(EStateRecorderState::Bodies))
  2209. mBodyManager.SaveState(inStream, inFilter);
  2210. if (uint8(inState) & uint8(EStateRecorderState::Contacts))
  2211. mContactManager.SaveState(inStream, inFilter);
  2212. if (uint8(inState) & uint8(EStateRecorderState::Constraints))
  2213. mConstraintManager.SaveState(inStream, inFilter);
  2214. }
  2215. bool PhysicsSystem::RestoreState(StateRecorder &inStream)
  2216. {
  2217. JPH_PROFILE_FUNCTION();
  2218. EStateRecorderState state = EStateRecorderState::All; // Set this value for validation. If a partial state is saved, validation will not work anyway.
  2219. inStream.Read(state);
  2220. if (uint8(state) & uint8(EStateRecorderState::Global))
  2221. {
  2222. inStream.Read(mPreviousStepDeltaTime);
  2223. inStream.Read(mGravity);
  2224. }
  2225. if (uint8(state) & uint8(EStateRecorderState::Bodies))
  2226. {
  2227. if (!mBodyManager.RestoreState(inStream))
  2228. return false;
  2229. // Update bounding boxes for all bodies in the broadphase
  2230. Array<BodyID> bodies;
  2231. for (const Body *b : mBodyManager.GetBodies())
  2232. if (BodyManager::sIsValidBodyPointer(b) && b->IsInBroadPhase())
  2233. bodies.push_back(b->GetID());
  2234. if (!bodies.empty())
  2235. mBroadPhase->NotifyBodiesAABBChanged(&bodies[0], (int)bodies.size());
  2236. }
  2237. if (uint8(state) & uint8(EStateRecorderState::Contacts))
  2238. {
  2239. if (!mContactManager.RestoreState(inStream))
  2240. return false;
  2241. }
  2242. if (uint8(state) & uint8(EStateRecorderState::Constraints))
  2243. {
  2244. if (!mConstraintManager.RestoreState(inStream))
  2245. return false;
  2246. }
  2247. return true;
  2248. }
  2249. void PhysicsSystem::SaveBodyState(const Body &inBody, StateRecorder &inStream) const
  2250. {
  2251. mBodyManager.SaveBodyState(inBody, inStream);
  2252. }
  2253. void PhysicsSystem::RestoreBodyState(Body &ioBody, StateRecorder &inStream)
  2254. {
  2255. mBodyManager.RestoreBodyState(ioBody, inStream);
  2256. BodyID id = ioBody.GetID();
  2257. mBroadPhase->NotifyBodiesAABBChanged(&id, 1);
  2258. }
  2259. JPH_NAMESPACE_END