123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745274627472748274927502751275227532754275527562757275827592760276127622763276427652766276727682769277027712772277327742775277627772778277927802781278227832784278527862787278827892790279127922793279427952796279727982799280028012802280328042805280628072808280928102811281228132814281528162817281828192820282128222823282428252826282728282829283028312832283328342835283628372838283928402841284228432844284528462847284828492850285128522853285428552856285728582859286028612862286328642865286628672868286928702871287228732874287528762877287828792880288128822883288428852886288728882889289028912892289328942895289628972898289929002901290229032904290529062907290829092910291129122913291429152916291729182919292029212922292329242925292629272928292929302931293229332934293529362937293829392940294129422943294429452946294729482949295029512952295329542955295629572958295929602961296229632964296529662967296829692970297129722973297429752976297729782979298029812982298329842985298629872988298929902991299229932994299529962997299829993000300130023003300430053006300730083009301030113012301330143015301630173018301930203021302230233024302530263027302830293030303130323033303430353036303730383039304030413042304330443045304630473048304930503051305230533054305530563057305830593060306130623063306430653066306730683069307030713072307330743075307630773078307930803081308230833084308530863087308830893090309130923093309430953096309730983099310031013102310331043105310631073108310931103111311231133114311531163117311831193120312131223123312431253126312731283129313031313132313331343135313631373138313931403141314231433144314531463147314831493150315131523153315431553156315731583159316031613162316331643165316631673168316931703171317231733174317531763177317831793180318131823183318431853186318731883189319031913192319331943195319631973198319932003201320232033204320532063207320832093210321132123213321432153216321732183219322032213222322332243225322632273228322932303231323232333234323532363237323832393240324132423243324432453246324732483249325032513252325332543255325632573258325932603261326232633264326532663267326832693270327132723273327432753276327732783279328032813282328332843285328632873288328932903291329232933294329532963297329832993300330133023303330433053306330733083309331033113312331333143315331633173318 |
- //
- // Copyright (c) 2009-2010 Mikko Mononen [email protected]
- //
- // This software is provided 'as-is', without any express or implied
- // warranty. In no event will the authors be held liable for any damages
- // arising from the use of this software.
- // Permission is granted to anyone to use this software for any purpose,
- // including commercial applications, and to alter it and redistribute it
- // freely, subject to the following restrictions:
- // 1. The origin of this software must not be misrepresented; you must not
- // claim that you wrote the original software. If you use this software
- // in a product, an acknowledgment in the product documentation would be
- // appreciated but is not required.
- // 2. Altered source versions must be plainly marked as such, and must not be
- // misrepresented as being the original software.
- // 3. This notice may not be removed or altered from any source distribution.
- //
- #include <math.h>
- #include <float.h>
- #include <string.h>
- #include "DetourNavMeshQuery.h"
- #include "DetourNavMesh.h"
- #include "DetourNode.h"
- #include "DetourCommon.h"
- #include "DetourAlloc.h"
- #include "DetourAssert.h"
- #include <new>
- /// @class dtQueryFilter
- ///
- /// <b>The Default Implementation</b>
- ///
- /// At construction: All area costs default to 1.0. All flags are included
- /// and none are excluded.
- ///
- /// If a polygon has both an include and an exclude flag, it will be excluded.
- ///
- /// The way filtering works, a navigation mesh polygon must have at least one flag
- /// set to ever be considered by a query. So a polygon with no flags will never
- /// be considered.
- ///
- /// Setting the include flags to 0 will result in all polygons being excluded.
- ///
- /// <b>Custom Implementations</b>
- ///
- /// DT_VIRTUAL_QUERYFILTER must be defined in order to extend this class.
- ///
- /// Implement a custom query filter by overriding the virtual passFilter()
- /// and getCost() functions. If this is done, both functions should be as
- /// fast as possible. Use cached local copies of data rather than accessing
- /// your own objects where possible.
- ///
- /// Custom implementations do not need to adhere to the flags or cost logic
- /// used by the default implementation.
- ///
- /// In order for A* searches to work properly, the cost should be proportional to
- /// the travel distance. Implementing a cost modifier less than 1.0 is likely
- /// to lead to problems during pathfinding.
- ///
- /// @see dtNavMeshQuery
- dtQueryFilter::dtQueryFilter() :
- m_includeFlags(0xffff),
- m_excludeFlags(0)
- {
- for (int i = 0; i < DT_MAX_AREAS; ++i)
- m_areaCost[i] = 1.0f;
- }
- #ifdef DT_VIRTUAL_QUERYFILTER
- bool dtQueryFilter::passFilter(const dtPolyRef /*ref*/,
- const dtMeshTile* /*tile*/,
- const dtPoly* poly) const
- {
- return (poly->flags & m_includeFlags) != 0 && (poly->flags & m_excludeFlags) == 0;
- }
- float dtQueryFilter::getCost(const float* pa, const float* pb,
- const dtPolyRef /*prevRef*/, const dtMeshTile* /*prevTile*/, const dtPoly* /*prevPoly*/,
- const dtPolyRef /*curRef*/, const dtMeshTile* /*curTile*/, const dtPoly* curPoly,
- const dtPolyRef /*nextRef*/, const dtMeshTile* /*nextTile*/, const dtPoly* /*nextPoly*/) const
- {
- return dtVdist(pa, pb) * m_areaCost[curPoly->getArea()];
- }
- #else
- inline bool dtQueryFilter::passFilter(const dtPolyRef /*ref*/,
- const dtMeshTile* /*tile*/,
- const dtPoly* poly) const
- {
- return (poly->flags & m_includeFlags) != 0 && (poly->flags & m_excludeFlags) == 0;
- }
- inline float dtQueryFilter::getCost(const float* pa, const float* pb,
- const dtPolyRef /*prevRef*/, const dtMeshTile* /*prevTile*/, const dtPoly* /*prevPoly*/,
- const dtPolyRef /*curRef*/, const dtMeshTile* /*curTile*/, const dtPoly* curPoly,
- const dtPolyRef /*nextRef*/, const dtMeshTile* /*nextTile*/, const dtPoly* /*nextPoly*/) const
- {
- return dtVdist(pa, pb) * m_areaCost[curPoly->getArea()];
- }
- #endif
-
- static const float H_SCALE = 0.999f; // Search heuristic scale.
- dtNavMeshQuery* dtAllocNavMeshQuery()
- {
- void* mem = dtAlloc(sizeof(dtNavMeshQuery), DT_ALLOC_PERM);
- if (!mem) return 0;
- return new(mem) dtNavMeshQuery;
- }
- void dtFreeNavMeshQuery(dtNavMeshQuery* navmesh)
- {
- if (!navmesh) return;
- navmesh->~dtNavMeshQuery();
- dtFree(navmesh);
- }
- //////////////////////////////////////////////////////////////////////////////////////////
- /// @class dtNavMeshQuery
- ///
- /// For methods that support undersized buffers, if the buffer is too small
- /// to hold the entire result set the return status of the method will include
- /// the #DT_BUFFER_TOO_SMALL flag.
- ///
- /// Constant member functions can be used by multiple clients without side
- /// effects. (E.g. No change to the closed list. No impact on an in-progress
- /// sliced path query. Etc.)
- ///
- /// Walls and portals: A @e wall is a polygon segment that is
- /// considered impassable. A @e portal is a passable segment between polygons.
- /// A portal may be treated as a wall based on the dtQueryFilter used for a query.
- ///
- /// @see dtNavMesh, dtQueryFilter, #dtAllocNavMeshQuery(), #dtAllocNavMeshQuery()
- dtNavMeshQuery::dtNavMeshQuery() :
- m_nav(0),
- m_tinyNodePool(0),
- m_nodePool(0),
- m_openList(0)
- {
- memset(&m_query, 0, sizeof(dtQueryData));
- }
- dtNavMeshQuery::~dtNavMeshQuery()
- {
- if (m_tinyNodePool)
- m_tinyNodePool->~dtNodePool();
- if (m_nodePool)
- m_nodePool->~dtNodePool();
- if (m_openList)
- m_openList->~dtNodeQueue();
- dtFree(m_tinyNodePool);
- dtFree(m_nodePool);
- dtFree(m_openList);
- }
- /// @par
- ///
- /// Must be the first function called after construction, before other
- /// functions are used.
- ///
- /// This function can be used multiple times.
- dtStatus dtNavMeshQuery::init(const dtNavMesh* nav, const int maxNodes)
- {
- m_nav = nav;
-
- if (!m_nodePool || m_nodePool->getMaxNodes() < maxNodes)
- {
- if (m_nodePool)
- {
- m_nodePool->~dtNodePool();
- dtFree(m_nodePool);
- m_nodePool = 0;
- }
- m_nodePool = new (dtAlloc(sizeof(dtNodePool), DT_ALLOC_PERM)) dtNodePool(maxNodes, dtNextPow2(maxNodes/4));
- if (!m_nodePool)
- return DT_FAILURE | DT_OUT_OF_MEMORY;
- }
- else
- {
- m_nodePool->clear();
- }
-
- if (!m_tinyNodePool)
- {
- m_tinyNodePool = new (dtAlloc(sizeof(dtNodePool), DT_ALLOC_PERM)) dtNodePool(64, 32);
- if (!m_tinyNodePool)
- return DT_FAILURE | DT_OUT_OF_MEMORY;
- }
- else
- {
- m_tinyNodePool->clear();
- }
-
- // TODO: check the open list size too.
- if (!m_openList || m_openList->getCapacity() < maxNodes)
- {
- if (m_openList)
- {
- m_openList->~dtNodeQueue();
- dtFree(m_openList);
- m_openList = 0;
- }
- m_openList = new (dtAlloc(sizeof(dtNodeQueue), DT_ALLOC_PERM)) dtNodeQueue(maxNodes);
- if (!m_openList)
- return DT_FAILURE | DT_OUT_OF_MEMORY;
- }
- else
- {
- m_openList->clear();
- }
-
- return DT_SUCCESS;
- }
- dtStatus dtNavMeshQuery::findRandomPoint(const dtQueryFilter* filter, float (*frand)(),
- dtPolyRef* randomRef, float* randomPt) const
- {
- dtAssert(m_nav);
-
- // Randomly pick one tile. Assume that all tiles cover roughly the same area.
- const dtMeshTile* tile = 0;
- float tsum = 0.0f;
- for (int i = 0; i < m_nav->getMaxTiles(); i++)
- {
- const dtMeshTile* t = m_nav->getTile(i);
- if (!t || !t->header) continue;
-
- // Choose random tile using reservoi sampling.
- const float area = 1.0f; // Could be tile area too.
- tsum += area;
- const float u = frand();
- if (u*tsum <= area)
- tile = t;
- }
- if (!tile)
- return DT_FAILURE;
- // Randomly pick one polygon weighted by polygon area.
- const dtPoly* poly = 0;
- dtPolyRef polyRef = 0;
- const dtPolyRef base = m_nav->getPolyRefBase(tile);
- float areaSum = 0.0f;
- for (int i = 0; i < tile->header->polyCount; ++i)
- {
- const dtPoly* p = &tile->polys[i];
- // Do not return off-mesh connection polygons.
- if (p->getType() != DT_POLYTYPE_GROUND)
- continue;
- // Must pass filter
- const dtPolyRef ref = base | (dtPolyRef)i;
- if (!filter->passFilter(ref, tile, p))
- continue;
- // Calc area of the polygon.
- float polyArea = 0.0f;
- for (int j = 2; j < p->vertCount; ++j)
- {
- const float* va = &tile->verts[p->verts[0]*3];
- const float* vb = &tile->verts[p->verts[j-1]*3];
- const float* vc = &tile->verts[p->verts[j]*3];
- polyArea += dtTriArea2D(va,vb,vc);
- }
- // Choose random polygon weighted by area, using reservoi sampling.
- areaSum += polyArea;
- const float u = frand();
- if (u*areaSum <= polyArea)
- {
- poly = p;
- polyRef = ref;
- }
- }
-
- if (!poly)
- return DT_FAILURE;
- // Randomly pick point on polygon.
- const float* v = &tile->verts[poly->verts[0]*3];
- float verts[3*DT_VERTS_PER_POLYGON];
- float areas[DT_VERTS_PER_POLYGON];
- dtVcopy(&verts[0*3],v);
- for (int j = 1; j < poly->vertCount; ++j)
- {
- v = &tile->verts[poly->verts[j]*3];
- dtVcopy(&verts[j*3],v);
- }
-
- const float s = frand();
- const float t = frand();
-
- float pt[3];
- dtRandomPointInConvexPoly(verts, poly->vertCount, areas, s, t, pt);
-
- float h = 0.0f;
- dtStatus status = getPolyHeight(polyRef, pt, &h);
- if (dtStatusFailed(status))
- return status;
- pt[1] = h;
-
- dtVcopy(randomPt, pt);
- *randomRef = polyRef;
- return DT_SUCCESS;
- }
- dtStatus dtNavMeshQuery::findRandomPointAroundCircle(dtPolyRef startRef, const float* centerPos, const float radius,
- const dtQueryFilter* filter, float (*frand)(),
- dtPolyRef* randomRef, float* randomPt) const
- {
- dtAssert(m_nav);
- dtAssert(m_nodePool);
- dtAssert(m_openList);
-
- // Validate input
- if (!startRef || !m_nav->isValidPolyRef(startRef))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- const dtMeshTile* startTile = 0;
- const dtPoly* startPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(startRef, &startTile, &startPoly);
- if (!filter->passFilter(startRef, startTile, startPoly))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- m_nodePool->clear();
- m_openList->clear();
-
- dtNode* startNode = m_nodePool->getNode(startRef);
- dtVcopy(startNode->pos, centerPos);
- startNode->pidx = 0;
- startNode->cost = 0;
- startNode->total = 0;
- startNode->id = startRef;
- startNode->flags = DT_NODE_OPEN;
- m_openList->push(startNode);
-
- dtStatus status = DT_SUCCESS;
-
- const float radiusSqr = dtSqr(radius);
- float areaSum = 0.0f;
- const dtMeshTile* randomTile = 0;
- const dtPoly* randomPoly = 0;
- dtPolyRef randomPolyRef = 0;
- while (!m_openList->empty())
- {
- dtNode* bestNode = m_openList->pop();
- bestNode->flags &= ~DT_NODE_OPEN;
- bestNode->flags |= DT_NODE_CLOSED;
-
- // Get poly and tile.
- // The API input has been cheked already, skip checking internal data.
- const dtPolyRef bestRef = bestNode->id;
- const dtMeshTile* bestTile = 0;
- const dtPoly* bestPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(bestRef, &bestTile, &bestPoly);
- // Place random locations on on ground.
- if (bestPoly->getType() == DT_POLYTYPE_GROUND)
- {
- // Calc area of the polygon.
- float polyArea = 0.0f;
- for (int j = 2; j < bestPoly->vertCount; ++j)
- {
- const float* va = &bestTile->verts[bestPoly->verts[0]*3];
- const float* vb = &bestTile->verts[bestPoly->verts[j-1]*3];
- const float* vc = &bestTile->verts[bestPoly->verts[j]*3];
- polyArea += dtTriArea2D(va,vb,vc);
- }
- // Choose random polygon weighted by area, using reservoi sampling.
- areaSum += polyArea;
- const float u = frand();
- if (u*areaSum <= polyArea)
- {
- randomTile = bestTile;
- randomPoly = bestPoly;
- randomPolyRef = bestRef;
- }
- }
-
-
- // Get parent poly and tile.
- dtPolyRef parentRef = 0;
- const dtMeshTile* parentTile = 0;
- const dtPoly* parentPoly = 0;
- if (bestNode->pidx)
- parentRef = m_nodePool->getNodeAtIdx(bestNode->pidx)->id;
- if (parentRef)
- m_nav->getTileAndPolyByRefUnsafe(parentRef, &parentTile, &parentPoly);
-
- for (unsigned int i = bestPoly->firstLink; i != DT_NULL_LINK; i = bestTile->links[i].next)
- {
- const dtLink* link = &bestTile->links[i];
- dtPolyRef neighbourRef = link->ref;
- // Skip invalid neighbours and do not follow back to parent.
- if (!neighbourRef || neighbourRef == parentRef)
- continue;
-
- // Expand to neighbour
- const dtMeshTile* neighbourTile = 0;
- const dtPoly* neighbourPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(neighbourRef, &neighbourTile, &neighbourPoly);
-
- // Do not advance if the polygon is excluded by the filter.
- if (!filter->passFilter(neighbourRef, neighbourTile, neighbourPoly))
- continue;
-
- // Find edge and calc distance to the edge.
- float va[3], vb[3];
- if (!getPortalPoints(bestRef, bestPoly, bestTile, neighbourRef, neighbourPoly, neighbourTile, va, vb))
- continue;
-
- // If the circle is not touching the next polygon, skip it.
- float tseg;
- float distSqr = dtDistancePtSegSqr2D(centerPos, va, vb, tseg);
- if (distSqr > radiusSqr)
- continue;
-
- dtNode* neighbourNode = m_nodePool->getNode(neighbourRef);
- if (!neighbourNode)
- {
- status |= DT_OUT_OF_NODES;
- continue;
- }
-
- if (neighbourNode->flags & DT_NODE_CLOSED)
- continue;
-
- // Cost
- if (neighbourNode->flags == 0)
- dtVlerp(neighbourNode->pos, va, vb, 0.5f);
-
- const float total = bestNode->total + dtVdist(bestNode->pos, neighbourNode->pos);
-
- // The node is already in open list and the new result is worse, skip.
- if ((neighbourNode->flags & DT_NODE_OPEN) && total >= neighbourNode->total)
- continue;
-
- neighbourNode->id = neighbourRef;
- neighbourNode->flags = (neighbourNode->flags & ~DT_NODE_CLOSED);
- neighbourNode->pidx = m_nodePool->getNodeIdx(bestNode);
- neighbourNode->total = total;
-
- if (neighbourNode->flags & DT_NODE_OPEN)
- {
- m_openList->modify(neighbourNode);
- }
- else
- {
- neighbourNode->flags = DT_NODE_OPEN;
- m_openList->push(neighbourNode);
- }
- }
- }
-
- if (!randomPoly)
- return DT_FAILURE;
-
- // Randomly pick point on polygon.
- const float* v = &randomTile->verts[randomPoly->verts[0]*3];
- float verts[3*DT_VERTS_PER_POLYGON];
- float areas[DT_VERTS_PER_POLYGON];
- dtVcopy(&verts[0*3],v);
- for (int j = 1; j < randomPoly->vertCount; ++j)
- {
- v = &randomTile->verts[randomPoly->verts[j]*3];
- dtVcopy(&verts[j*3],v);
- }
-
- const float s = frand();
- const float t = frand();
-
- float pt[3];
- dtRandomPointInConvexPoly(verts, randomPoly->vertCount, areas, s, t, pt);
-
- float h = 0.0f;
- dtStatus stat = getPolyHeight(randomPolyRef, pt, &h);
- if (dtStatusFailed(status))
- return stat;
- pt[1] = h;
-
- dtVcopy(randomPt, pt);
- *randomRef = randomPolyRef;
-
- return DT_SUCCESS;
- }
- //////////////////////////////////////////////////////////////////////////////////////////
- /// @par
- ///
- /// Uses the detail polygons to find the surface height. (Most accurate.)
- ///
- /// @p pos does not have to be within the bounds of the polygon or navigation mesh.
- ///
- /// See closestPointOnPolyBoundary() for a limited but faster option.
- ///
- dtStatus dtNavMeshQuery::closestPointOnPoly(dtPolyRef ref, const float* pos, float* closest) const
- {
- dtAssert(m_nav);
- const dtMeshTile* tile = 0;
- const dtPoly* poly = 0;
- if (dtStatusFailed(m_nav->getTileAndPolyByRef(ref, &tile, &poly)))
- return DT_FAILURE | DT_INVALID_PARAM;
- if (!tile)
- return DT_FAILURE | DT_INVALID_PARAM;
-
- closestPointOnPolyInTile(tile, poly, pos, closest);
-
- return DT_SUCCESS;
- }
- void dtNavMeshQuery::closestPointOnPolyInTile(const dtMeshTile* tile, const dtPoly* poly,
- const float* pos, float* closest) const
- {
- // Off-mesh connections don't have detail polygons.
- if (poly->getType() == DT_POLYTYPE_OFFMESH_CONNECTION)
- {
- const float* v0 = &tile->verts[poly->verts[0]*3];
- const float* v1 = &tile->verts[poly->verts[1]*3];
- const float d0 = dtVdist(pos, v0);
- const float d1 = dtVdist(pos, v1);
- const float u = d0 / (d0+d1);
- dtVlerp(closest, v0, v1, u);
- return;
- }
- const unsigned int ip = (unsigned int)(poly - tile->polys);
- const dtPolyDetail* pd = &tile->detailMeshes[ip];
- // TODO: The commented out version finds 'cylinder distance' instead of 'sphere distance' to the navmesh.
- // Test and enable.
- /*
- // Clamp point to be inside the polygon.
- float verts[DT_VERTS_PER_POLYGON*3];
- float edged[DT_VERTS_PER_POLYGON];
- float edget[DT_VERTS_PER_POLYGON];
- const int nv = poly->vertCount;
- for (int i = 0; i < nv; ++i)
- dtVcopy(&verts[i*3], &tile->verts[poly->verts[i]*3]);
-
- dtVcopy(closest, pos);
- if (!dtDistancePtPolyEdgesSqr(pos, verts, nv, edged, edget))
- {
- // Point is outside the polygon, dtClamp to nearest edge.
- float dmin = FLT_MAX;
- int imin = -1;
- for (int i = 0; i < nv; ++i)
- {
- if (edged[i] < dmin)
- {
- dmin = edged[i];
- imin = i;
- }
- }
- const float* va = &verts[imin*3];
- const float* vb = &verts[((imin+1)%nv)*3];
- dtVlerp(closest, va, vb, edget[imin]);
- }
- // Find height at the location.
- for (int j = 0; j < pd->triCount; ++j)
- {
- const unsigned char* t = &tile->detailTris[(pd->triBase+j)*4];
- const float* v[3];
- for (int k = 0; k < 3; ++k)
- {
- if (t[k] < poly->vertCount)
- v[k] = &tile->verts[poly->verts[t[k]]*3];
- else
- v[k] = &tile->detailVerts[(pd->vertBase+(t[k]-poly->vertCount))*3];
- }
- float h;
- if (dtClosestHeightPointTriangle(pos, v[0], v[1], v[2], h))
- {
- closest[1] = h;
- break;
- }
- }
- */
- float closestDistSqr = FLT_MAX;
- for (int j = 0; j < pd->triCount; ++j)
- {
- const unsigned char* t = &tile->detailTris[(pd->triBase+j)*4];
- const float* v[3];
- for (int k = 0; k < 3; ++k)
- {
- if (t[k] < poly->vertCount)
- v[k] = &tile->verts[poly->verts[t[k]]*3];
- else
- v[k] = &tile->detailVerts[(pd->vertBase+(t[k]-poly->vertCount))*3];
- }
- float pt[3];
- dtClosestPtPointTriangle(pt, pos, v[0], v[1], v[2]);
- float d = dtVdistSqr(pos, pt);
-
- if (d < closestDistSqr)
- {
- dtVcopy(closest, pt);
- closestDistSqr = d;
- }
- }
- }
- /// @par
- ///
- /// Much faster than closestPointOnPoly().
- ///
- /// If the provided position lies within the polygon's xz-bounds (above or below),
- /// then @p pos and @p closest will be equal.
- ///
- /// The height of @p closest will be the polygon boundary. The height detail is not used.
- ///
- /// @p pos does not have to be within the bounds of the polybon or the navigation mesh.
- ///
- dtStatus dtNavMeshQuery::closestPointOnPolyBoundary(dtPolyRef ref, const float* pos, float* closest) const
- {
- dtAssert(m_nav);
-
- const dtMeshTile* tile = 0;
- const dtPoly* poly = 0;
- if (dtStatusFailed(m_nav->getTileAndPolyByRef(ref, &tile, &poly)))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- // Collect vertices.
- float verts[DT_VERTS_PER_POLYGON*3];
- float edged[DT_VERTS_PER_POLYGON];
- float edget[DT_VERTS_PER_POLYGON];
- int nv = 0;
- for (int i = 0; i < (int)poly->vertCount; ++i)
- {
- dtVcopy(&verts[nv*3], &tile->verts[poly->verts[i]*3]);
- nv++;
- }
-
- bool inside = dtDistancePtPolyEdgesSqr(pos, verts, nv, edged, edget);
- if (inside)
- {
- // Point is inside the polygon, return the point.
- dtVcopy(closest, pos);
- }
- else
- {
- // Point is outside the polygon, dtClamp to nearest edge.
- float dmin = FLT_MAX;
- int imin = -1;
- for (int i = 0; i < nv; ++i)
- {
- if (edged[i] < dmin)
- {
- dmin = edged[i];
- imin = i;
- }
- }
- const float* va = &verts[imin*3];
- const float* vb = &verts[((imin+1)%nv)*3];
- dtVlerp(closest, va, vb, edget[imin]);
- }
-
- return DT_SUCCESS;
- }
- /// @par
- ///
- /// Will return #DT_FAILURE if the provided position is outside the xz-bounds
- /// of the polygon.
- ///
- dtStatus dtNavMeshQuery::getPolyHeight(dtPolyRef ref, const float* pos, float* height) const
- {
- dtAssert(m_nav);
- const dtMeshTile* tile = 0;
- const dtPoly* poly = 0;
- if (dtStatusFailed(m_nav->getTileAndPolyByRef(ref, &tile, &poly)))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- if (poly->getType() == DT_POLYTYPE_OFFMESH_CONNECTION)
- {
- const float* v0 = &tile->verts[poly->verts[0]*3];
- const float* v1 = &tile->verts[poly->verts[1]*3];
- const float d0 = dtVdist(pos, v0);
- const float d1 = dtVdist(pos, v1);
- const float u = d0 / (d0+d1);
- if (height)
- *height = v0[1] + (v1[1] - v0[1]) * u;
- return DT_SUCCESS;
- }
- else
- {
- const unsigned int ip = (unsigned int)(poly - tile->polys);
- const dtPolyDetail* pd = &tile->detailMeshes[ip];
- for (int j = 0; j < pd->triCount; ++j)
- {
- const unsigned char* t = &tile->detailTris[(pd->triBase+j)*4];
- const float* v[3];
- for (int k = 0; k < 3; ++k)
- {
- if (t[k] < poly->vertCount)
- v[k] = &tile->verts[poly->verts[t[k]]*3];
- else
- v[k] = &tile->detailVerts[(pd->vertBase+(t[k]-poly->vertCount))*3];
- }
- float h;
- if (dtClosestHeightPointTriangle(pos, v[0], v[1], v[2], h))
- {
- if (height)
- *height = h;
- return DT_SUCCESS;
- }
- }
- }
-
- return DT_FAILURE | DT_INVALID_PARAM;
- }
- /// @par
- ///
- /// @note If the search box does not intersect any polygons the search will
- /// return #DT_SUCCESS, but @p nearestRef will be zero. So if in doubt, check
- /// @p nearestRef before using @p nearestPt.
- ///
- /// @warning This function is not suitable for large area searches. If the search
- /// extents overlaps more than 128 polygons it may return an invalid result.
- ///
- dtStatus dtNavMeshQuery::findNearestPoly(const float* center, const float* extents,
- const dtQueryFilter* filter,
- dtPolyRef* nearestRef, float* nearestPt) const
- {
- dtAssert(m_nav);
- *nearestRef = 0;
-
- // Get nearby polygons from proximity grid.
- dtPolyRef polys[128];
- int polyCount = 0;
- if (dtStatusFailed(queryPolygons(center, extents, filter, polys, &polyCount, 128)))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- // Find nearest polygon amongst the nearby polygons.
- dtPolyRef nearest = 0;
- float nearestDistanceSqr = FLT_MAX;
- for (int i = 0; i < polyCount; ++i)
- {
- dtPolyRef ref = polys[i];
- float closestPtPoly[3];
- closestPointOnPoly(ref, center, closestPtPoly);
- float d = dtVdistSqr(center, closestPtPoly);
- if (d < nearestDistanceSqr)
- {
- if (nearestPt)
- dtVcopy(nearestPt, closestPtPoly);
- nearestDistanceSqr = d;
- nearest = ref;
- }
- }
-
- if (nearestRef)
- *nearestRef = nearest;
-
- return DT_SUCCESS;
- }
- dtPolyRef dtNavMeshQuery::findNearestPolyInTile(const dtMeshTile* tile, const float* center, const float* extents,
- const dtQueryFilter* filter, float* nearestPt) const
- {
- dtAssert(m_nav);
-
- float bmin[3], bmax[3];
- dtVsub(bmin, center, extents);
- dtVadd(bmax, center, extents);
-
- // Get nearby polygons from proximity grid.
- dtPolyRef polys[128];
- int polyCount = queryPolygonsInTile(tile, bmin, bmax, filter, polys, 128);
-
- // Find nearest polygon amongst the nearby polygons.
- dtPolyRef nearest = 0;
- float nearestDistanceSqr = FLT_MAX;
- for (int i = 0; i < polyCount; ++i)
- {
- dtPolyRef ref = polys[i];
- const dtPoly* poly = &tile->polys[m_nav->decodePolyIdPoly(ref)];
- float closestPtPoly[3];
- closestPointOnPolyInTile(tile, poly, center, closestPtPoly);
-
- float d = dtVdistSqr(center, closestPtPoly);
- if (d < nearestDistanceSqr)
- {
- if (nearestPt)
- dtVcopy(nearestPt, closestPtPoly);
- nearestDistanceSqr = d;
- nearest = ref;
- }
- }
-
- return nearest;
- }
- int dtNavMeshQuery::queryPolygonsInTile(const dtMeshTile* tile, const float* qmin, const float* qmax,
- const dtQueryFilter* filter,
- dtPolyRef* polys, const int maxPolys) const
- {
- dtAssert(m_nav);
- if (tile->bvTree)
- {
- const dtBVNode* node = &tile->bvTree[0];
- const dtBVNode* end = &tile->bvTree[tile->header->bvNodeCount];
- const float* tbmin = tile->header->bmin;
- const float* tbmax = tile->header->bmax;
- const float qfac = tile->header->bvQuantFactor;
-
- // Calculate quantized box
- unsigned short bmin[3], bmax[3];
- // dtClamp query box to world box.
- float minx = dtClamp(qmin[0], tbmin[0], tbmax[0]) - tbmin[0];
- float miny = dtClamp(qmin[1], tbmin[1], tbmax[1]) - tbmin[1];
- float minz = dtClamp(qmin[2], tbmin[2], tbmax[2]) - tbmin[2];
- float maxx = dtClamp(qmax[0], tbmin[0], tbmax[0]) - tbmin[0];
- float maxy = dtClamp(qmax[1], tbmin[1], tbmax[1]) - tbmin[1];
- float maxz = dtClamp(qmax[2], tbmin[2], tbmax[2]) - tbmin[2];
- // Quantize
- bmin[0] = (unsigned short)(qfac * minx) & 0xfffe;
- bmin[1] = (unsigned short)(qfac * miny) & 0xfffe;
- bmin[2] = (unsigned short)(qfac * minz) & 0xfffe;
- bmax[0] = (unsigned short)(qfac * maxx + 1) | 1;
- bmax[1] = (unsigned short)(qfac * maxy + 1) | 1;
- bmax[2] = (unsigned short)(qfac * maxz + 1) | 1;
-
- // Traverse tree
- const dtPolyRef base = m_nav->getPolyRefBase(tile);
- int n = 0;
- while (node < end)
- {
- const bool overlap = dtOverlapQuantBounds(bmin, bmax, node->bmin, node->bmax);
- const bool isLeafNode = node->i >= 0;
-
- if (isLeafNode && overlap)
- {
- dtPolyRef ref = base | (dtPolyRef)node->i;
- if (filter->passFilter(ref, tile, &tile->polys[node->i]))
- {
- if (n < maxPolys)
- polys[n++] = ref;
- }
- }
-
- if (overlap || isLeafNode)
- node++;
- else
- {
- const int escapeIndex = -node->i;
- node += escapeIndex;
- }
- }
-
- return n;
- }
- else
- {
- float bmin[3], bmax[3];
- int n = 0;
- const dtPolyRef base = m_nav->getPolyRefBase(tile);
- for (int i = 0; i < tile->header->polyCount; ++i)
- {
- const dtPoly* p = &tile->polys[i];
- // Do not return off-mesh connection polygons.
- if (p->getType() == DT_POLYTYPE_OFFMESH_CONNECTION)
- continue;
- // Must pass filter
- const dtPolyRef ref = base | (dtPolyRef)i;
- if (!filter->passFilter(ref, tile, p))
- continue;
- // Calc polygon bounds.
- const float* v = &tile->verts[p->verts[0]*3];
- dtVcopy(bmin, v);
- dtVcopy(bmax, v);
- for (int j = 1; j < p->vertCount; ++j)
- {
- v = &tile->verts[p->verts[j]*3];
- dtVmin(bmin, v);
- dtVmax(bmax, v);
- }
- if (dtOverlapBounds(qmin,qmax, bmin,bmax))
- {
- if (n < maxPolys)
- polys[n++] = ref;
- }
- }
- return n;
- }
- }
- /// @par
- ///
- /// If no polygons are found, the function will return #DT_SUCCESS with a
- /// @p polyCount of zero.
- ///
- /// If @p polys is too small to hold the entire result set, then the array will
- /// be filled to capacity. The method of choosing which polygons from the
- /// full set are included in the partial result set is undefined.
- ///
- dtStatus dtNavMeshQuery::queryPolygons(const float* center, const float* extents,
- const dtQueryFilter* filter,
- dtPolyRef* polys, int* polyCount, const int maxPolys) const
- {
- dtAssert(m_nav);
-
- float bmin[3], bmax[3];
- dtVsub(bmin, center, extents);
- dtVadd(bmax, center, extents);
-
- // Find tiles the query touches.
- int minx, miny, maxx, maxy;
- m_nav->calcTileLoc(bmin, &minx, &miny);
- m_nav->calcTileLoc(bmax, &maxx, &maxy);
- static const int MAX_NEIS = 32;
- const dtMeshTile* neis[MAX_NEIS];
-
- int n = 0;
- for (int y = miny; y <= maxy; ++y)
- {
- for (int x = minx; x <= maxx; ++x)
- {
- const int nneis = m_nav->getTilesAt(x,y,neis,MAX_NEIS);
- for (int j = 0; j < nneis; ++j)
- {
- n += queryPolygonsInTile(neis[j], bmin, bmax, filter, polys+n, maxPolys-n);
- if (n >= maxPolys)
- {
- *polyCount = n;
- return DT_SUCCESS | DT_BUFFER_TOO_SMALL;
- }
- }
- }
- }
- *polyCount = n;
-
- return DT_SUCCESS;
- }
- /// @par
- ///
- /// If the end polygon cannot be reached through the navigation graph,
- /// the last polygon in the path will be the nearest the end polygon.
- ///
- /// If the path array is to small to hold the full result, it will be filled as
- /// far as possible from the start polygon toward the end polygon.
- ///
- /// The start and end positions are used to calculate traversal costs.
- /// (The y-values impact the result.)
- ///
- dtStatus dtNavMeshQuery::findPath(dtPolyRef startRef, dtPolyRef endRef,
- const float* startPos, const float* endPos,
- const dtQueryFilter* filter,
- dtPolyRef* path, int* pathCount, const int maxPath) const
- {
- dtAssert(m_nav);
- dtAssert(m_nodePool);
- dtAssert(m_openList);
-
- *pathCount = 0;
-
- if (!startRef || !endRef)
- return DT_FAILURE | DT_INVALID_PARAM;
-
- if (!maxPath)
- return DT_FAILURE | DT_INVALID_PARAM;
-
- // Validate input
- if (!m_nav->isValidPolyRef(startRef) || !m_nav->isValidPolyRef(endRef))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- if (startRef == endRef)
- {
- path[0] = startRef;
- *pathCount = 1;
- return DT_SUCCESS;
- }
-
- m_nodePool->clear();
- m_openList->clear();
-
- dtNode* startNode = m_nodePool->getNode(startRef);
- dtVcopy(startNode->pos, startPos);
- startNode->pidx = 0;
- startNode->cost = 0;
- startNode->total = dtVdist(startPos, endPos) * H_SCALE;
- startNode->id = startRef;
- startNode->flags = DT_NODE_OPEN;
- m_openList->push(startNode);
-
- dtNode* lastBestNode = startNode;
- float lastBestNodeCost = startNode->total;
-
- dtStatus status = DT_SUCCESS;
-
- while (!m_openList->empty())
- {
- // Remove node from open list and put it in closed list.
- dtNode* bestNode = m_openList->pop();
- bestNode->flags &= ~DT_NODE_OPEN;
- bestNode->flags |= DT_NODE_CLOSED;
-
- // Reached the goal, stop searching.
- if (bestNode->id == endRef)
- {
- lastBestNode = bestNode;
- break;
- }
-
- // Get current poly and tile.
- // The API input has been cheked already, skip checking internal data.
- const dtPolyRef bestRef = bestNode->id;
- const dtMeshTile* bestTile = 0;
- const dtPoly* bestPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(bestRef, &bestTile, &bestPoly);
-
- // Get parent poly and tile.
- dtPolyRef parentRef = 0;
- const dtMeshTile* parentTile = 0;
- const dtPoly* parentPoly = 0;
- if (bestNode->pidx)
- parentRef = m_nodePool->getNodeAtIdx(bestNode->pidx)->id;
- if (parentRef)
- m_nav->getTileAndPolyByRefUnsafe(parentRef, &parentTile, &parentPoly);
-
- for (unsigned int i = bestPoly->firstLink; i != DT_NULL_LINK; i = bestTile->links[i].next)
- {
- dtPolyRef neighbourRef = bestTile->links[i].ref;
-
- // Skip invalid ids and do not expand back to where we came from.
- if (!neighbourRef || neighbourRef == parentRef)
- continue;
-
- // Get neighbour poly and tile.
- // The API input has been cheked already, skip checking internal data.
- const dtMeshTile* neighbourTile = 0;
- const dtPoly* neighbourPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(neighbourRef, &neighbourTile, &neighbourPoly);
-
- if (!filter->passFilter(neighbourRef, neighbourTile, neighbourPoly))
- continue;
- dtNode* neighbourNode = m_nodePool->getNode(neighbourRef);
- if (!neighbourNode)
- {
- status |= DT_OUT_OF_NODES;
- continue;
- }
-
- // If the node is visited the first time, calculate node position.
- if (neighbourNode->flags == 0)
- {
- getEdgeMidPoint(bestRef, bestPoly, bestTile,
- neighbourRef, neighbourPoly, neighbourTile,
- neighbourNode->pos);
- }
- // Calculate cost and heuristic.
- float cost = 0;
- float heuristic = 0;
-
- // Special case for last node.
- if (neighbourRef == endRef)
- {
- // Cost
- const float curCost = filter->getCost(bestNode->pos, neighbourNode->pos,
- parentRef, parentTile, parentPoly,
- bestRef, bestTile, bestPoly,
- neighbourRef, neighbourTile, neighbourPoly);
- const float endCost = filter->getCost(neighbourNode->pos, endPos,
- bestRef, bestTile, bestPoly,
- neighbourRef, neighbourTile, neighbourPoly,
- 0, 0, 0);
-
- cost = bestNode->cost + curCost + endCost;
- heuristic = 0;
- }
- else
- {
- // Cost
- const float curCost = filter->getCost(bestNode->pos, neighbourNode->pos,
- parentRef, parentTile, parentPoly,
- bestRef, bestTile, bestPoly,
- neighbourRef, neighbourTile, neighbourPoly);
- cost = bestNode->cost + curCost;
- heuristic = dtVdist(neighbourNode->pos, endPos)*H_SCALE;
- }
- const float total = cost + heuristic;
-
- // The node is already in open list and the new result is worse, skip.
- if ((neighbourNode->flags & DT_NODE_OPEN) && total >= neighbourNode->total)
- continue;
- // The node is already visited and process, and the new result is worse, skip.
- if ((neighbourNode->flags & DT_NODE_CLOSED) && total >= neighbourNode->total)
- continue;
-
- // Add or update the node.
- neighbourNode->pidx = m_nodePool->getNodeIdx(bestNode);
- neighbourNode->id = neighbourRef;
- neighbourNode->flags = (neighbourNode->flags & ~DT_NODE_CLOSED);
- neighbourNode->cost = cost;
- neighbourNode->total = total;
-
- if (neighbourNode->flags & DT_NODE_OPEN)
- {
- // Already in open, update node location.
- m_openList->modify(neighbourNode);
- }
- else
- {
- // Put the node in open list.
- neighbourNode->flags |= DT_NODE_OPEN;
- m_openList->push(neighbourNode);
- }
-
- // Update nearest node to target so far.
- if (heuristic < lastBestNodeCost)
- {
- lastBestNodeCost = heuristic;
- lastBestNode = neighbourNode;
- }
- }
- }
-
- if (lastBestNode->id != endRef)
- status |= DT_PARTIAL_RESULT;
-
- // Reverse the path.
- dtNode* prev = 0;
- dtNode* node = lastBestNode;
- do
- {
- dtNode* next = m_nodePool->getNodeAtIdx(node->pidx);
- node->pidx = m_nodePool->getNodeIdx(prev);
- prev = node;
- node = next;
- }
- while (node);
-
- // Store path
- node = prev;
- int n = 0;
- do
- {
- path[n++] = node->id;
- if (n >= maxPath)
- {
- status |= DT_BUFFER_TOO_SMALL;
- break;
- }
- node = m_nodePool->getNodeAtIdx(node->pidx);
- }
- while (node);
-
- *pathCount = n;
-
- return status;
- }
- /// @par
- ///
- /// @warning Calling any non-slice methods before calling finalizeSlicedFindPath()
- /// or finalizeSlicedFindPathPartial() may result in corrupted data!
- ///
- /// The @p filter pointer is stored and used for the duration of the sliced
- /// path query.
- ///
- dtStatus dtNavMeshQuery::initSlicedFindPath(dtPolyRef startRef, dtPolyRef endRef,
- const float* startPos, const float* endPos,
- const dtQueryFilter* filter)
- {
- dtAssert(m_nav);
- dtAssert(m_nodePool);
- dtAssert(m_openList);
- // Init path state.
- memset(&m_query, 0, sizeof(dtQueryData));
- m_query.status = DT_FAILURE;
- m_query.startRef = startRef;
- m_query.endRef = endRef;
- dtVcopy(m_query.startPos, startPos);
- dtVcopy(m_query.endPos, endPos);
- m_query.filter = filter;
-
- if (!startRef || !endRef)
- return DT_FAILURE | DT_INVALID_PARAM;
-
- // Validate input
- if (!m_nav->isValidPolyRef(startRef) || !m_nav->isValidPolyRef(endRef))
- return DT_FAILURE | DT_INVALID_PARAM;
- if (startRef == endRef)
- {
- m_query.status = DT_SUCCESS;
- return DT_SUCCESS;
- }
-
- m_nodePool->clear();
- m_openList->clear();
-
- dtNode* startNode = m_nodePool->getNode(startRef);
- dtVcopy(startNode->pos, startPos);
- startNode->pidx = 0;
- startNode->cost = 0;
- startNode->total = dtVdist(startPos, endPos) * H_SCALE;
- startNode->id = startRef;
- startNode->flags = DT_NODE_OPEN;
- m_openList->push(startNode);
-
- m_query.status = DT_IN_PROGRESS;
- m_query.lastBestNode = startNode;
- m_query.lastBestNodeCost = startNode->total;
-
- return m_query.status;
- }
-
- dtStatus dtNavMeshQuery::updateSlicedFindPath(const int maxIter, int* doneIters)
- {
- if (!dtStatusInProgress(m_query.status))
- return m_query.status;
- // Make sure the request is still valid.
- if (!m_nav->isValidPolyRef(m_query.startRef) || !m_nav->isValidPolyRef(m_query.endRef))
- {
- m_query.status = DT_FAILURE;
- return DT_FAILURE;
- }
-
- int iter = 0;
- while (iter < maxIter && !m_openList->empty())
- {
- iter++;
-
- // Remove node from open list and put it in closed list.
- dtNode* bestNode = m_openList->pop();
- bestNode->flags &= ~DT_NODE_OPEN;
- bestNode->flags |= DT_NODE_CLOSED;
-
- // Reached the goal, stop searching.
- if (bestNode->id == m_query.endRef)
- {
- m_query.lastBestNode = bestNode;
- const dtStatus details = m_query.status & DT_STATUS_DETAIL_MASK;
- m_query.status = DT_SUCCESS | details;
- if (doneIters)
- *doneIters = iter;
- return m_query.status;
- }
-
- // Get current poly and tile.
- // The API input has been cheked already, skip checking internal data.
- const dtPolyRef bestRef = bestNode->id;
- const dtMeshTile* bestTile = 0;
- const dtPoly* bestPoly = 0;
- if (dtStatusFailed(m_nav->getTileAndPolyByRef(bestRef, &bestTile, &bestPoly)))
- {
- // The polygon has disappeared during the sliced query, fail.
- m_query.status = DT_FAILURE;
- if (doneIters)
- *doneIters = iter;
- return m_query.status;
- }
-
- // Get parent poly and tile.
- dtPolyRef parentRef = 0;
- const dtMeshTile* parentTile = 0;
- const dtPoly* parentPoly = 0;
- if (bestNode->pidx)
- parentRef = m_nodePool->getNodeAtIdx(bestNode->pidx)->id;
- if (parentRef)
- {
- if (dtStatusFailed(m_nav->getTileAndPolyByRef(parentRef, &parentTile, &parentPoly)))
- {
- // The polygon has disappeared during the sliced query, fail.
- m_query.status = DT_FAILURE;
- if (doneIters)
- *doneIters = iter;
- return m_query.status;
- }
- }
-
- for (unsigned int i = bestPoly->firstLink; i != DT_NULL_LINK; i = bestTile->links[i].next)
- {
- dtPolyRef neighbourRef = bestTile->links[i].ref;
-
- // Skip invalid ids and do not expand back to where we came from.
- if (!neighbourRef || neighbourRef == parentRef)
- continue;
-
- // Get neighbour poly and tile.
- // The API input has been cheked already, skip checking internal data.
- const dtMeshTile* neighbourTile = 0;
- const dtPoly* neighbourPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(neighbourRef, &neighbourTile, &neighbourPoly);
-
- if (!m_query.filter->passFilter(neighbourRef, neighbourTile, neighbourPoly))
- continue;
-
- dtNode* neighbourNode = m_nodePool->getNode(neighbourRef);
- if (!neighbourNode)
- {
- m_query.status |= DT_OUT_OF_NODES;
- continue;
- }
-
- // If the node is visited the first time, calculate node position.
- if (neighbourNode->flags == 0)
- {
- getEdgeMidPoint(bestRef, bestPoly, bestTile,
- neighbourRef, neighbourPoly, neighbourTile,
- neighbourNode->pos);
- }
-
- // Calculate cost and heuristic.
- float cost = 0;
- float heuristic = 0;
-
- // Special case for last node.
- if (neighbourRef == m_query.endRef)
- {
- // Cost
- const float curCost = m_query.filter->getCost(bestNode->pos, neighbourNode->pos,
- parentRef, parentTile, parentPoly,
- bestRef, bestTile, bestPoly,
- neighbourRef, neighbourTile, neighbourPoly);
- const float endCost = m_query.filter->getCost(neighbourNode->pos, m_query.endPos,
- bestRef, bestTile, bestPoly,
- neighbourRef, neighbourTile, neighbourPoly,
- 0, 0, 0);
-
- cost = bestNode->cost + curCost + endCost;
- heuristic = 0;
- }
- else
- {
- // Cost
- const float curCost = m_query.filter->getCost(bestNode->pos, neighbourNode->pos,
- parentRef, parentTile, parentPoly,
- bestRef, bestTile, bestPoly,
- neighbourRef, neighbourTile, neighbourPoly);
- cost = bestNode->cost + curCost;
- heuristic = dtVdist(neighbourNode->pos, m_query.endPos)*H_SCALE;
- }
-
- const float total = cost + heuristic;
-
- // The node is already in open list and the new result is worse, skip.
- if ((neighbourNode->flags & DT_NODE_OPEN) && total >= neighbourNode->total)
- continue;
- // The node is already visited and process, and the new result is worse, skip.
- if ((neighbourNode->flags & DT_NODE_CLOSED) && total >= neighbourNode->total)
- continue;
-
- // Add or update the node.
- neighbourNode->pidx = m_nodePool->getNodeIdx(bestNode);
- neighbourNode->id = neighbourRef;
- neighbourNode->flags = (neighbourNode->flags & ~DT_NODE_CLOSED);
- neighbourNode->cost = cost;
- neighbourNode->total = total;
-
- if (neighbourNode->flags & DT_NODE_OPEN)
- {
- // Already in open, update node location.
- m_openList->modify(neighbourNode);
- }
- else
- {
- // Put the node in open list.
- neighbourNode->flags |= DT_NODE_OPEN;
- m_openList->push(neighbourNode);
- }
-
- // Update nearest node to target so far.
- if (heuristic < m_query.lastBestNodeCost)
- {
- m_query.lastBestNodeCost = heuristic;
- m_query.lastBestNode = neighbourNode;
- }
- }
- }
-
- // Exhausted all nodes, but could not find path.
- if (m_openList->empty())
- {
- const dtStatus details = m_query.status & DT_STATUS_DETAIL_MASK;
- m_query.status = DT_SUCCESS | details;
- }
- if (doneIters)
- *doneIters = iter;
- return m_query.status;
- }
- dtStatus dtNavMeshQuery::finalizeSlicedFindPath(dtPolyRef* path, int* pathCount, const int maxPath)
- {
- *pathCount = 0;
-
- if (dtStatusFailed(m_query.status))
- {
- // Reset query.
- memset(&m_query, 0, sizeof(dtQueryData));
- return DT_FAILURE;
- }
- int n = 0;
- if (m_query.startRef == m_query.endRef)
- {
- // Special case: the search starts and ends at same poly.
- path[n++] = m_query.startRef;
- }
- else
- {
- // Reverse the path.
- dtAssert(m_query.lastBestNode);
-
- if (m_query.lastBestNode->id != m_query.endRef)
- m_query.status |= DT_PARTIAL_RESULT;
-
- dtNode* prev = 0;
- dtNode* node = m_query.lastBestNode;
- do
- {
- dtNode* next = m_nodePool->getNodeAtIdx(node->pidx);
- node->pidx = m_nodePool->getNodeIdx(prev);
- prev = node;
- node = next;
- }
- while (node);
-
- // Store path
- node = prev;
- do
- {
- path[n++] = node->id;
- if (n >= maxPath)
- {
- m_query.status |= DT_BUFFER_TOO_SMALL;
- break;
- }
- node = m_nodePool->getNodeAtIdx(node->pidx);
- }
- while (node);
- }
-
- const dtStatus details = m_query.status & DT_STATUS_DETAIL_MASK;
- // Reset query.
- memset(&m_query, 0, sizeof(dtQueryData));
-
- *pathCount = n;
-
- return DT_SUCCESS | details;
- }
- dtStatus dtNavMeshQuery::finalizeSlicedFindPathPartial(const dtPolyRef* existing, const int existingSize,
- dtPolyRef* path, int* pathCount, const int maxPath)
- {
- *pathCount = 0;
-
- if (existingSize == 0)
- {
- return DT_FAILURE;
- }
-
- if (dtStatusFailed(m_query.status))
- {
- // Reset query.
- memset(&m_query, 0, sizeof(dtQueryData));
- return DT_FAILURE;
- }
-
- int n = 0;
-
- if (m_query.startRef == m_query.endRef)
- {
- // Special case: the search starts and ends at same poly.
- path[n++] = m_query.startRef;
- }
- else
- {
- // Find furthest existing node that was visited.
- dtNode* prev = 0;
- dtNode* node = 0;
- for (int i = existingSize-1; i >= 0; --i)
- {
- node = m_nodePool->findNode(existing[i]);
- if (node)
- break;
- }
-
- if (!node)
- {
- m_query.status |= DT_PARTIAL_RESULT;
- dtAssert(m_query.lastBestNode);
- node = m_query.lastBestNode;
- }
-
- // Reverse the path.
- do
- {
- dtNode* next = m_nodePool->getNodeAtIdx(node->pidx);
- node->pidx = m_nodePool->getNodeIdx(prev);
- prev = node;
- node = next;
- }
- while (node);
-
- // Store path
- node = prev;
- do
- {
- path[n++] = node->id;
- if (n >= maxPath)
- {
- m_query.status |= DT_BUFFER_TOO_SMALL;
- break;
- }
- node = m_nodePool->getNodeAtIdx(node->pidx);
- }
- while (node);
- }
-
- const dtStatus details = m_query.status & DT_STATUS_DETAIL_MASK;
- // Reset query.
- memset(&m_query, 0, sizeof(dtQueryData));
-
- *pathCount = n;
-
- return DT_SUCCESS | details;
- }
- /// @par
- ///
- /// This method peforms what is often called 'string pulling'.
- ///
- /// The start position is clamped to the first polygon in the path, and the
- /// end position is clamped to the last. So the start and end positions should
- /// normally be within or very near the first and last polygons respectively.
- ///
- /// The returned polygon references represent the reference id of the polygon
- /// that is entered at the associated path position. The reference id associated
- /// with the end point will always be zero. This allows, for example, matching
- /// off-mesh link points to their representative polygons.
- ///
- /// If the provided result buffers are too small for the entire result set,
- /// they will be filled as far as possible from the start toward the end
- /// position.
- ///
- dtStatus dtNavMeshQuery::findStraightPath(const float* startPos, const float* endPos,
- const dtPolyRef* path, const int pathSize,
- float* straightPath, unsigned char* straightPathFlags, dtPolyRef* straightPathRefs,
- int* straightPathCount, const int maxStraightPath) const
- {
- dtAssert(m_nav);
-
- *straightPathCount = 0;
-
- if (!maxStraightPath)
- return DT_FAILURE | DT_INVALID_PARAM;
-
- if (!path[0])
- return DT_FAILURE | DT_INVALID_PARAM;
-
- int n = 0;
-
- // TODO: Should this be callers responsibility?
- float closestStartPos[3];
- if (dtStatusFailed(closestPointOnPolyBoundary(path[0], startPos, closestStartPos)))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- // Add start point.
- dtVcopy(&straightPath[n*3], closestStartPos);
- if (straightPathFlags)
- straightPathFlags[n] = DT_STRAIGHTPATH_START;
- if (straightPathRefs)
- straightPathRefs[n] = path[0];
- n++;
- if (n >= maxStraightPath)
- {
- *straightPathCount = n;
- return DT_SUCCESS | DT_BUFFER_TOO_SMALL;
- }
-
- float closestEndPos[3];
- if (dtStatusFailed(closestPointOnPolyBoundary(path[pathSize-1], endPos, closestEndPos)))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- if (pathSize > 1)
- {
- float portalApex[3], portalLeft[3], portalRight[3];
- dtVcopy(portalApex, closestStartPos);
- dtVcopy(portalLeft, portalApex);
- dtVcopy(portalRight, portalApex);
- int apexIndex = 0;
- int leftIndex = 0;
- int rightIndex = 0;
-
- unsigned char leftPolyType = 0;
- unsigned char rightPolyType = 0;
-
- dtPolyRef leftPolyRef = path[0];
- dtPolyRef rightPolyRef = path[0];
-
- for (int i = 0; i < pathSize; ++i)
- {
- float left[3], right[3];
- unsigned char fromType, toType;
-
- if (i+1 < pathSize)
- {
- // Next portal.
- if (dtStatusFailed(getPortalPoints(path[i], path[i+1], left, right, fromType, toType)))
- {
- // Failed to get portal points, in practice this means that path[i+1] is invalid polygon.
- // Clamp the end point to path[i], and return the path so far.
-
- if (dtStatusFailed(closestPointOnPolyBoundary(path[i], endPos, closestEndPos)))
- {
- // This should only happen when the first polygon is invalid.
- return DT_FAILURE | DT_INVALID_PARAM;
- }
-
- dtVcopy(&straightPath[n*3], closestEndPos);
- if (straightPathFlags)
- straightPathFlags[n] = 0;
- if (straightPathRefs)
- straightPathRefs[n] = path[i];
- n++;
-
- *straightPathCount = n;
-
- return DT_SUCCESS | DT_PARTIAL_RESULT | ((n >= maxStraightPath) ? DT_BUFFER_TOO_SMALL : 0);
- }
-
- // If starting really close the portal, advance.
- if (i == 0)
- {
- float t;
- if (dtDistancePtSegSqr2D(portalApex, left, right, t) < dtSqr(0.001f))
- continue;
- }
- }
- else
- {
- // End of the path.
- dtVcopy(left, closestEndPos);
- dtVcopy(right, closestEndPos);
-
- fromType = toType = DT_POLYTYPE_GROUND;
- }
-
- // Right vertex.
- if (dtTriArea2D(portalApex, portalRight, right) <= 0.0f)
- {
- if (dtVequal(portalApex, portalRight) || dtTriArea2D(portalApex, portalLeft, right) > 0.0f)
- {
- dtVcopy(portalRight, right);
- rightPolyRef = (i+1 < pathSize) ? path[i+1] : 0;
- rightPolyType = toType;
- rightIndex = i;
- }
- else
- {
- dtVcopy(portalApex, portalLeft);
- apexIndex = leftIndex;
-
- unsigned char flags = 0;
- if (!leftPolyRef)
- flags = DT_STRAIGHTPATH_END;
- else if (leftPolyType == DT_POLYTYPE_OFFMESH_CONNECTION)
- flags = DT_STRAIGHTPATH_OFFMESH_CONNECTION;
- dtPolyRef ref = leftPolyRef;
-
- if (!dtVequal(&straightPath[(n-1)*3], portalApex))
- {
- // Append new vertex.
- dtVcopy(&straightPath[n*3], portalApex);
- if (straightPathFlags)
- straightPathFlags[n] = flags;
- if (straightPathRefs)
- straightPathRefs[n] = ref;
- n++;
- // If reached end of path or there is no space to append more vertices, return.
- if (flags == DT_STRAIGHTPATH_END || n >= maxStraightPath)
- {
- *straightPathCount = n;
- return DT_SUCCESS | ((n >= maxStraightPath) ? DT_BUFFER_TOO_SMALL : 0);
- }
- }
- else
- {
- // The vertices are equal, update flags and poly.
- if (straightPathFlags)
- straightPathFlags[n-1] = flags;
- if (straightPathRefs)
- straightPathRefs[n-1] = ref;
- }
-
- dtVcopy(portalLeft, portalApex);
- dtVcopy(portalRight, portalApex);
- leftIndex = apexIndex;
- rightIndex = apexIndex;
-
- // Restart
- i = apexIndex;
-
- continue;
- }
- }
-
- // Left vertex.
- if (dtTriArea2D(portalApex, portalLeft, left) >= 0.0f)
- {
- if (dtVequal(portalApex, portalLeft) || dtTriArea2D(portalApex, portalRight, left) < 0.0f)
- {
- dtVcopy(portalLeft, left);
- leftPolyRef = (i+1 < pathSize) ? path[i+1] : 0;
- leftPolyType = toType;
- leftIndex = i;
- }
- else
- {
- dtVcopy(portalApex, portalRight);
- apexIndex = rightIndex;
-
- unsigned char flags = 0;
- if (!rightPolyRef)
- flags = DT_STRAIGHTPATH_END;
- else if (rightPolyType == DT_POLYTYPE_OFFMESH_CONNECTION)
- flags = DT_STRAIGHTPATH_OFFMESH_CONNECTION;
- dtPolyRef ref = rightPolyRef;
-
- if (!dtVequal(&straightPath[(n-1)*3], portalApex))
- {
- // Append new vertex.
- dtVcopy(&straightPath[n*3], portalApex);
- if (straightPathFlags)
- straightPathFlags[n] = flags;
- if (straightPathRefs)
- straightPathRefs[n] = ref;
- n++;
- // If reached end of path or there is no space to append more vertices, return.
- if (flags == DT_STRAIGHTPATH_END || n >= maxStraightPath)
- {
- *straightPathCount = n;
- return DT_SUCCESS | ((n >= maxStraightPath) ? DT_BUFFER_TOO_SMALL : 0);
- }
- }
- else
- {
- // The vertices are equal, update flags and poly.
- if (straightPathFlags)
- straightPathFlags[n-1] = flags;
- if (straightPathRefs)
- straightPathRefs[n-1] = ref;
- }
-
- dtVcopy(portalLeft, portalApex);
- dtVcopy(portalRight, portalApex);
- leftIndex = apexIndex;
- rightIndex = apexIndex;
-
- // Restart
- i = apexIndex;
-
- continue;
- }
- }
- }
- }
-
- // If the point already exists, remove it and add reappend the actual end location.
- if (n > 0 && dtVequal(&straightPath[(n-1)*3], closestEndPos))
- n--;
-
- // Add end point.
- if (n < maxStraightPath)
- {
- dtVcopy(&straightPath[n*3], closestEndPos);
- if (straightPathFlags)
- straightPathFlags[n] = DT_STRAIGHTPATH_END;
- if (straightPathRefs)
- straightPathRefs[n] = 0;
- n++;
- }
-
- *straightPathCount = n;
-
- return DT_SUCCESS | ((n >= maxStraightPath) ? DT_BUFFER_TOO_SMALL : 0);
- }
- /// @par
- ///
- /// This method is optimized for small delta movement and a small number of
- /// polygons. If used for too great a distance, the result set will form an
- /// incomplete path.
- ///
- /// @p resultPos will equal the @p endPos if the end is reached.
- /// Otherwise the closest reachable position will be returned.
- ///
- /// @p resultPos is not projected onto the surface of the navigation
- /// mesh. Use #getPolyHeight if this is needed.
- ///
- /// This method treats the end position in the same manner as
- /// the #raycast method. (As a 2D point.) See that method's documentation
- /// for details.
- ///
- /// If the @p visited array is too small to hold the entire result set, it will
- /// be filled as far as possible from the start position toward the end
- /// position.
- ///
- dtStatus dtNavMeshQuery::moveAlongSurface(dtPolyRef startRef, const float* startPos, const float* endPos,
- const dtQueryFilter* filter,
- float* resultPos, dtPolyRef* visited, int* visitedCount, const int maxVisitedSize) const
- {
- dtAssert(m_nav);
- dtAssert(m_tinyNodePool);
- *visitedCount = 0;
-
- // Validate input
- if (!startRef)
- return DT_FAILURE | DT_INVALID_PARAM;
- if (!m_nav->isValidPolyRef(startRef))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- dtStatus status = DT_SUCCESS;
-
- static const int MAX_STACK = 48;
- dtNode* stack[MAX_STACK];
- int nstack = 0;
-
- m_tinyNodePool->clear();
-
- dtNode* startNode = m_tinyNodePool->getNode(startRef);
- startNode->pidx = 0;
- startNode->cost = 0;
- startNode->total = 0;
- startNode->id = startRef;
- startNode->flags = DT_NODE_CLOSED;
- stack[nstack++] = startNode;
-
- float bestPos[3];
- float bestDist = FLT_MAX;
- dtNode* bestNode = 0;
- dtVcopy(bestPos, startPos);
-
- // Search constraints
- float searchPos[3], searchRadSqr;
- dtVlerp(searchPos, startPos, endPos, 0.5f);
- searchRadSqr = dtSqr(dtVdist(startPos, endPos)/2.0f + 0.001f);
-
- float verts[DT_VERTS_PER_POLYGON*3];
-
- while (nstack)
- {
- // Pop front.
- dtNode* curNode = stack[0];
- for (int i = 0; i < nstack-1; ++i)
- stack[i] = stack[i+1];
- nstack--;
-
- // Get poly and tile.
- // The API input has been cheked already, skip checking internal data.
- const dtPolyRef curRef = curNode->id;
- const dtMeshTile* curTile = 0;
- const dtPoly* curPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(curRef, &curTile, &curPoly);
-
- // Collect vertices.
- const int nverts = curPoly->vertCount;
- for (int i = 0; i < nverts; ++i)
- dtVcopy(&verts[i*3], &curTile->verts[curPoly->verts[i]*3]);
-
- // If target is inside the poly, stop search.
- if (dtPointInPolygon(endPos, verts, nverts))
- {
- bestNode = curNode;
- dtVcopy(bestPos, endPos);
- break;
- }
-
- // Find wall edges and find nearest point inside the walls.
- for (int i = 0, j = (int)curPoly->vertCount-1; i < (int)curPoly->vertCount; j = i++)
- {
- // Find links to neighbours.
- static const int MAX_NEIS = 8;
- int nneis = 0;
- dtPolyRef neis[MAX_NEIS];
-
- if (curPoly->neis[j] & DT_EXT_LINK)
- {
- // Tile border.
- for (unsigned int k = curPoly->firstLink; k != DT_NULL_LINK; k = curTile->links[k].next)
- {
- const dtLink* link = &curTile->links[k];
- if (link->edge == j)
- {
- if (link->ref != 0)
- {
- const dtMeshTile* neiTile = 0;
- const dtPoly* neiPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(link->ref, &neiTile, &neiPoly);
- if (filter->passFilter(link->ref, neiTile, neiPoly))
- {
- if (nneis < MAX_NEIS)
- neis[nneis++] = link->ref;
- }
- }
- }
- }
- }
- else if (curPoly->neis[j])
- {
- const unsigned int idx = (unsigned int)(curPoly->neis[j]-1);
- const dtPolyRef ref = m_nav->getPolyRefBase(curTile) | idx;
- if (filter->passFilter(ref, curTile, &curTile->polys[idx]))
- {
- // Internal edge, encode id.
- neis[nneis++] = ref;
- }
- }
-
- if (!nneis)
- {
- // Wall edge, calc distance.
- const float* vj = &verts[j*3];
- const float* vi = &verts[i*3];
- float tseg;
- const float distSqr = dtDistancePtSegSqr2D(endPos, vj, vi, tseg);
- if (distSqr < bestDist)
- {
- // Update nearest distance.
- dtVlerp(bestPos, vj,vi, tseg);
- bestDist = distSqr;
- bestNode = curNode;
- }
- }
- else
- {
- for (int k = 0; k < nneis; ++k)
- {
- // Skip if no node can be allocated.
- dtNode* neighbourNode = m_tinyNodePool->getNode(neis[k]);
- if (!neighbourNode)
- continue;
- // Skip if already visited.
- if (neighbourNode->flags & DT_NODE_CLOSED)
- continue;
-
- // Skip the link if it is too far from search constraint.
- // TODO: Maybe should use getPortalPoints(), but this one is way faster.
- const float* vj = &verts[j*3];
- const float* vi = &verts[i*3];
- float tseg;
- float distSqr = dtDistancePtSegSqr2D(searchPos, vj, vi, tseg);
- if (distSqr > searchRadSqr)
- continue;
-
- // Mark as the node as visited and push to queue.
- if (nstack < MAX_STACK)
- {
- neighbourNode->pidx = m_tinyNodePool->getNodeIdx(curNode);
- neighbourNode->flags |= DT_NODE_CLOSED;
- stack[nstack++] = neighbourNode;
- }
- }
- }
- }
- }
-
- int n = 0;
- if (bestNode)
- {
- // Reverse the path.
- dtNode* prev = 0;
- dtNode* node = bestNode;
- do
- {
- dtNode* next = m_tinyNodePool->getNodeAtIdx(node->pidx);
- node->pidx = m_tinyNodePool->getNodeIdx(prev);
- prev = node;
- node = next;
- }
- while (node);
-
- // Store result
- node = prev;
- do
- {
- visited[n++] = node->id;
- if (n >= maxVisitedSize)
- {
- status |= DT_BUFFER_TOO_SMALL;
- break;
- }
- node = m_tinyNodePool->getNodeAtIdx(node->pidx);
- }
- while (node);
- }
-
- dtVcopy(resultPos, bestPos);
-
- *visitedCount = n;
-
- return status;
- }
- dtStatus dtNavMeshQuery::getPortalPoints(dtPolyRef from, dtPolyRef to, float* left, float* right,
- unsigned char& fromType, unsigned char& toType) const
- {
- dtAssert(m_nav);
-
- const dtMeshTile* fromTile = 0;
- const dtPoly* fromPoly = 0;
- if (dtStatusFailed(m_nav->getTileAndPolyByRef(from, &fromTile, &fromPoly)))
- return DT_FAILURE | DT_INVALID_PARAM;
- fromType = fromPoly->getType();
- const dtMeshTile* toTile = 0;
- const dtPoly* toPoly = 0;
- if (dtStatusFailed(m_nav->getTileAndPolyByRef(to, &toTile, &toPoly)))
- return DT_FAILURE | DT_INVALID_PARAM;
- toType = toPoly->getType();
-
- return getPortalPoints(from, fromPoly, fromTile, to, toPoly, toTile, left, right);
- }
- // Returns portal points between two polygons.
- dtStatus dtNavMeshQuery::getPortalPoints(dtPolyRef from, const dtPoly* fromPoly, const dtMeshTile* fromTile,
- dtPolyRef to, const dtPoly* toPoly, const dtMeshTile* toTile,
- float* left, float* right) const
- {
- // Find the link that points to the 'to' polygon.
- const dtLink* link = 0;
- for (unsigned int i = fromPoly->firstLink; i != DT_NULL_LINK; i = fromTile->links[i].next)
- {
- if (fromTile->links[i].ref == to)
- {
- link = &fromTile->links[i];
- break;
- }
- }
- if (!link)
- return DT_FAILURE | DT_INVALID_PARAM;
-
- // Handle off-mesh connections.
- if (fromPoly->getType() == DT_POLYTYPE_OFFMESH_CONNECTION)
- {
- // Find link that points to first vertex.
- for (unsigned int i = fromPoly->firstLink; i != DT_NULL_LINK; i = fromTile->links[i].next)
- {
- if (fromTile->links[i].ref == to)
- {
- const int v = fromTile->links[i].edge;
- dtVcopy(left, &fromTile->verts[fromPoly->verts[v]*3]);
- dtVcopy(right, &fromTile->verts[fromPoly->verts[v]*3]);
- return DT_SUCCESS;
- }
- }
- return DT_FAILURE | DT_INVALID_PARAM;
- }
-
- if (toPoly->getType() == DT_POLYTYPE_OFFMESH_CONNECTION)
- {
- for (unsigned int i = toPoly->firstLink; i != DT_NULL_LINK; i = toTile->links[i].next)
- {
- if (toTile->links[i].ref == from)
- {
- const int v = toTile->links[i].edge;
- dtVcopy(left, &toTile->verts[toPoly->verts[v]*3]);
- dtVcopy(right, &toTile->verts[toPoly->verts[v]*3]);
- return DT_SUCCESS;
- }
- }
- return DT_FAILURE | DT_INVALID_PARAM;
- }
-
- // Find portal vertices.
- const int v0 = fromPoly->verts[link->edge];
- const int v1 = fromPoly->verts[(link->edge+1) % (int)fromPoly->vertCount];
- dtVcopy(left, &fromTile->verts[v0*3]);
- dtVcopy(right, &fromTile->verts[v1*3]);
-
- // If the link is at tile boundary, dtClamp the vertices to
- // the link width.
- if (link->side != 0xff)
- {
- // Unpack portal limits.
- if (link->bmin != 0 || link->bmax != 255)
- {
- const float s = 1.0f/255.0f;
- const float tmin = link->bmin*s;
- const float tmax = link->bmax*s;
- dtVlerp(left, &fromTile->verts[v0*3], &fromTile->verts[v1*3], tmin);
- dtVlerp(right, &fromTile->verts[v0*3], &fromTile->verts[v1*3], tmax);
- }
- }
-
- return DT_SUCCESS;
- }
- // Returns edge mid point between two polygons.
- dtStatus dtNavMeshQuery::getEdgeMidPoint(dtPolyRef from, dtPolyRef to, float* mid) const
- {
- float left[3], right[3];
- unsigned char fromType, toType;
- if (dtStatusFailed(getPortalPoints(from, to, left,right, fromType, toType)))
- return DT_FAILURE | DT_INVALID_PARAM;
- mid[0] = (left[0]+right[0])*0.5f;
- mid[1] = (left[1]+right[1])*0.5f;
- mid[2] = (left[2]+right[2])*0.5f;
- return DT_SUCCESS;
- }
- dtStatus dtNavMeshQuery::getEdgeMidPoint(dtPolyRef from, const dtPoly* fromPoly, const dtMeshTile* fromTile,
- dtPolyRef to, const dtPoly* toPoly, const dtMeshTile* toTile,
- float* mid) const
- {
- float left[3], right[3];
- if (dtStatusFailed(getPortalPoints(from, fromPoly, fromTile, to, toPoly, toTile, left, right)))
- return DT_FAILURE | DT_INVALID_PARAM;
- mid[0] = (left[0]+right[0])*0.5f;
- mid[1] = (left[1]+right[1])*0.5f;
- mid[2] = (left[2]+right[2])*0.5f;
- return DT_SUCCESS;
- }
- /// @par
- ///
- /// This method is meant to be used for quick, short distance checks.
- ///
- /// If the path array is too small to hold the result, it will be filled as
- /// far as possible from the start postion toward the end position.
- ///
- /// <b>Using the Hit Parameter (t)</b>
- ///
- /// If the hit parameter is a very high value (FLT_MAX), then the ray has hit
- /// the end position. In this case the path represents a valid corridor to the
- /// end position and the value of @p hitNormal is undefined.
- ///
- /// If the hit parameter is zero, then the start position is on the wall that
- /// was hit and the value of @p hitNormal is undefined.
- ///
- /// If 0 < t < 1.0 then the following applies:
- ///
- /// @code
- /// distanceToHitBorder = distanceToEndPosition * t
- /// hitPoint = startPos + (endPos - startPos) * t
- /// @endcode
- ///
- /// <b>Use Case Restriction</b>
- ///
- /// The raycast ignores the y-value of the end position. (2D check.) This
- /// places significant limits on how it can be used. For example:
- ///
- /// Consider a scene where there is a main floor with a second floor balcony
- /// that hangs over the main floor. So the first floor mesh extends below the
- /// balcony mesh. The start position is somewhere on the first floor. The end
- /// position is on the balcony.
- ///
- /// The raycast will search toward the end position along the first floor mesh.
- /// If it reaches the end position's xz-coordinates it will indicate FLT_MAX
- /// (no wall hit), meaning it reached the end position. This is one example of why
- /// this method is meant for short distance checks.
- ///
- dtStatus dtNavMeshQuery::raycast(dtPolyRef startRef, const float* startPos, const float* endPos,
- const dtQueryFilter* filter,
- float* t, float* hitNormal, dtPolyRef* path, int* pathCount, const int maxPath) const
- {
- dtAssert(m_nav);
-
- *t = 0;
- if (pathCount)
- *pathCount = 0;
-
- // Validate input
- if (!startRef || !m_nav->isValidPolyRef(startRef))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- dtPolyRef curRef = startRef;
- float verts[DT_VERTS_PER_POLYGON*3];
- int n = 0;
-
- hitNormal[0] = 0;
- hitNormal[1] = 0;
- hitNormal[2] = 0;
-
- dtStatus status = DT_SUCCESS;
-
- while (curRef)
- {
- // Cast ray against current polygon.
-
- // The API input has been cheked already, skip checking internal data.
- const dtMeshTile* tile = 0;
- const dtPoly* poly = 0;
- m_nav->getTileAndPolyByRefUnsafe(curRef, &tile, &poly);
-
- // Collect vertices.
- int nv = 0;
- for (int i = 0; i < (int)poly->vertCount; ++i)
- {
- dtVcopy(&verts[nv*3], &tile->verts[poly->verts[i]*3]);
- nv++;
- }
-
- float tmin, tmax;
- int segMin, segMax;
- if (!dtIntersectSegmentPoly2D(startPos, endPos, verts, nv, tmin, tmax, segMin, segMax))
- {
- // Could not hit the polygon, keep the old t and report hit.
- if (pathCount)
- *pathCount = n;
- return status;
- }
- // Keep track of furthest t so far.
- if (tmax > *t)
- *t = tmax;
-
- // Store visited polygons.
- if (n < maxPath)
- path[n++] = curRef;
- else
- status |= DT_BUFFER_TOO_SMALL;
-
- // Ray end is completely inside the polygon.
- if (segMax == -1)
- {
- *t = FLT_MAX;
- if (pathCount)
- *pathCount = n;
- return status;
- }
-
- // Follow neighbours.
- dtPolyRef nextRef = 0;
-
- for (unsigned int i = poly->firstLink; i != DT_NULL_LINK; i = tile->links[i].next)
- {
- const dtLink* link = &tile->links[i];
-
- // Find link which contains this edge.
- if ((int)link->edge != segMax)
- continue;
-
- // Get pointer to the next polygon.
- const dtMeshTile* nextTile = 0;
- const dtPoly* nextPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(link->ref, &nextTile, &nextPoly);
-
- // Skip off-mesh connections.
- if (nextPoly->getType() == DT_POLYTYPE_OFFMESH_CONNECTION)
- continue;
-
- // Skip links based on filter.
- if (!filter->passFilter(link->ref, nextTile, nextPoly))
- continue;
-
- // If the link is internal, just return the ref.
- if (link->side == 0xff)
- {
- nextRef = link->ref;
- break;
- }
-
- // If the link is at tile boundary,
-
- // Check if the link spans the whole edge, and accept.
- if (link->bmin == 0 && link->bmax == 255)
- {
- nextRef = link->ref;
- break;
- }
-
- // Check for partial edge links.
- const int v0 = poly->verts[link->edge];
- const int v1 = poly->verts[(link->edge+1) % poly->vertCount];
- const float* left = &tile->verts[v0*3];
- const float* right = &tile->verts[v1*3];
-
- // Check that the intersection lies inside the link portal.
- if (link->side == 0 || link->side == 4)
- {
- // Calculate link size.
- const float s = 1.0f/255.0f;
- float lmin = left[2] + (right[2] - left[2])*(link->bmin*s);
- float lmax = left[2] + (right[2] - left[2])*(link->bmax*s);
- if (lmin > lmax) dtSwap(lmin, lmax);
-
- // Find Z intersection.
- float z = startPos[2] + (endPos[2]-startPos[2])*tmax;
- if (z >= lmin && z <= lmax)
- {
- nextRef = link->ref;
- break;
- }
- }
- else if (link->side == 2 || link->side == 6)
- {
- // Calculate link size.
- const float s = 1.0f/255.0f;
- float lmin = left[0] + (right[0] - left[0])*(link->bmin*s);
- float lmax = left[0] + (right[0] - left[0])*(link->bmax*s);
- if (lmin > lmax) dtSwap(lmin, lmax);
-
- // Find X intersection.
- float x = startPos[0] + (endPos[0]-startPos[0])*tmax;
- if (x >= lmin && x <= lmax)
- {
- nextRef = link->ref;
- break;
- }
- }
- }
-
- if (!nextRef)
- {
- // No neighbour, we hit a wall.
-
- // Calculate hit normal.
- const int a = segMax;
- const int b = segMax+1 < nv ? segMax+1 : 0;
- const float* va = &verts[a*3];
- const float* vb = &verts[b*3];
- const float dx = vb[0] - va[0];
- const float dz = vb[2] - va[2];
- hitNormal[0] = dz;
- hitNormal[1] = 0;
- hitNormal[2] = -dx;
- dtVnormalize(hitNormal);
-
- if (pathCount)
- *pathCount = n;
- return status;
- }
-
- // No hit, advance to neighbour polygon.
- curRef = nextRef;
- }
-
- if (pathCount)
- *pathCount = n;
-
- return status;
- }
- /// @par
- ///
- /// At least one result array must be provided.
- ///
- /// The order of the result set is from least to highest cost to reach the polygon.
- ///
- /// A common use case for this method is to perform Dijkstra searches.
- /// Candidate polygons are found by searching the graph beginning at the start polygon.
- ///
- /// If a polygon is not found via the graph search, even if it intersects the
- /// search circle, it will not be included in the result set. For example:
- ///
- /// polyA is the start polygon.
- /// polyB shares an edge with polyA. (Is adjacent.)
- /// polyC shares an edge with polyB, but not with polyA
- /// Even if the search circle overlaps polyC, it will not be included in the
- /// result set unless polyB is also in the set.
- ///
- /// The value of the center point is used as the start position for cost
- /// calculations. It is not projected onto the surface of the mesh, so its
- /// y-value will effect the costs.
- ///
- /// Intersection tests occur in 2D. All polygons and the search circle are
- /// projected onto the xz-plane. So the y-value of the center point does not
- /// effect intersection tests.
- ///
- /// If the result arrays are to small to hold the entire result set, they will be
- /// filled to capacity.
- ///
- dtStatus dtNavMeshQuery::findPolysAroundCircle(dtPolyRef startRef, const float* centerPos, const float radius,
- const dtQueryFilter* filter,
- dtPolyRef* resultRef, dtPolyRef* resultParent, float* resultCost,
- int* resultCount, const int maxResult) const
- {
- dtAssert(m_nav);
- dtAssert(m_nodePool);
- dtAssert(m_openList);
- *resultCount = 0;
-
- // Validate input
- if (!startRef || !m_nav->isValidPolyRef(startRef))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- m_nodePool->clear();
- m_openList->clear();
-
- dtNode* startNode = m_nodePool->getNode(startRef);
- dtVcopy(startNode->pos, centerPos);
- startNode->pidx = 0;
- startNode->cost = 0;
- startNode->total = 0;
- startNode->id = startRef;
- startNode->flags = DT_NODE_OPEN;
- m_openList->push(startNode);
-
- dtStatus status = DT_SUCCESS;
-
- int n = 0;
- if (n < maxResult)
- {
- if (resultRef)
- resultRef[n] = startNode->id;
- if (resultParent)
- resultParent[n] = 0;
- if (resultCost)
- resultCost[n] = 0;
- ++n;
- }
- else
- {
- status |= DT_BUFFER_TOO_SMALL;
- }
-
- const float radiusSqr = dtSqr(radius);
-
- while (!m_openList->empty())
- {
- dtNode* bestNode = m_openList->pop();
- bestNode->flags &= ~DT_NODE_OPEN;
- bestNode->flags |= DT_NODE_CLOSED;
-
- // Get poly and tile.
- // The API input has been cheked already, skip checking internal data.
- const dtPolyRef bestRef = bestNode->id;
- const dtMeshTile* bestTile = 0;
- const dtPoly* bestPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(bestRef, &bestTile, &bestPoly);
-
- // Get parent poly and tile.
- dtPolyRef parentRef = 0;
- const dtMeshTile* parentTile = 0;
- const dtPoly* parentPoly = 0;
- if (bestNode->pidx)
- parentRef = m_nodePool->getNodeAtIdx(bestNode->pidx)->id;
- if (parentRef)
- m_nav->getTileAndPolyByRefUnsafe(parentRef, &parentTile, &parentPoly);
-
- for (unsigned int i = bestPoly->firstLink; i != DT_NULL_LINK; i = bestTile->links[i].next)
- {
- const dtLink* link = &bestTile->links[i];
- dtPolyRef neighbourRef = link->ref;
- // Skip invalid neighbours and do not follow back to parent.
- if (!neighbourRef || neighbourRef == parentRef)
- continue;
-
- // Expand to neighbour
- const dtMeshTile* neighbourTile = 0;
- const dtPoly* neighbourPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(neighbourRef, &neighbourTile, &neighbourPoly);
-
- // Do not advance if the polygon is excluded by the filter.
- if (!filter->passFilter(neighbourRef, neighbourTile, neighbourPoly))
- continue;
-
- // Find edge and calc distance to the edge.
- float va[3], vb[3];
- if (!getPortalPoints(bestRef, bestPoly, bestTile, neighbourRef, neighbourPoly, neighbourTile, va, vb))
- continue;
-
- // If the circle is not touching the next polygon, skip it.
- float tseg;
- float distSqr = dtDistancePtSegSqr2D(centerPos, va, vb, tseg);
- if (distSqr > radiusSqr)
- continue;
-
- dtNode* neighbourNode = m_nodePool->getNode(neighbourRef);
- if (!neighbourNode)
- {
- status |= DT_OUT_OF_NODES;
- continue;
- }
-
- if (neighbourNode->flags & DT_NODE_CLOSED)
- continue;
-
- // Cost
- if (neighbourNode->flags == 0)
- dtVlerp(neighbourNode->pos, va, vb, 0.5f);
-
- const float total = bestNode->total + dtVdist(bestNode->pos, neighbourNode->pos);
-
- // The node is already in open list and the new result is worse, skip.
- if ((neighbourNode->flags & DT_NODE_OPEN) && total >= neighbourNode->total)
- continue;
-
- neighbourNode->id = neighbourRef;
- neighbourNode->flags = (neighbourNode->flags & ~DT_NODE_CLOSED);
- neighbourNode->pidx = m_nodePool->getNodeIdx(bestNode);
- neighbourNode->total = total;
-
- if (neighbourNode->flags & DT_NODE_OPEN)
- {
- m_openList->modify(neighbourNode);
- }
- else
- {
- if (n < maxResult)
- {
- if (resultRef)
- resultRef[n] = neighbourNode->id;
- if (resultParent)
- resultParent[n] = m_nodePool->getNodeAtIdx(neighbourNode->pidx)->id;
- if (resultCost)
- resultCost[n] = neighbourNode->total;
- ++n;
- }
- else
- {
- status |= DT_BUFFER_TOO_SMALL;
- }
- neighbourNode->flags = DT_NODE_OPEN;
- m_openList->push(neighbourNode);
- }
- }
- }
-
- *resultCount = n;
-
- return status;
- }
- /// @par
- ///
- /// The order of the result set is from least to highest cost.
- ///
- /// At least one result array must be provided.
- ///
- /// A common use case for this method is to perform Dijkstra searches.
- /// Candidate polygons are found by searching the graph beginning at the start
- /// polygon.
- ///
- /// The same intersection test restrictions that apply to findPolysAroundCircle()
- /// method apply to this method.
- ///
- /// The 3D centroid of the search polygon is used as the start position for cost
- /// calculations.
- ///
- /// Intersection tests occur in 2D. All polygons are projected onto the
- /// xz-plane. So the y-values of the vertices do not effect intersection tests.
- ///
- /// If the result arrays are is too small to hold the entire result set, they will
- /// be filled to capacity.
- ///
- dtStatus dtNavMeshQuery::findPolysAroundShape(dtPolyRef startRef, const float* verts, const int nverts,
- const dtQueryFilter* filter,
- dtPolyRef* resultRef, dtPolyRef* resultParent, float* resultCost,
- int* resultCount, const int maxResult) const
- {
- dtAssert(m_nav);
- dtAssert(m_nodePool);
- dtAssert(m_openList);
-
- *resultCount = 0;
-
- // Validate input
- if (!startRef || !m_nav->isValidPolyRef(startRef))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- m_nodePool->clear();
- m_openList->clear();
-
- float centerPos[3] = {0,0,0};
- for (int i = 0; i < nverts; ++i)
- dtVadd(centerPos,centerPos,&verts[i*3]);
- dtVscale(centerPos,centerPos,1.0f/nverts);
- dtNode* startNode = m_nodePool->getNode(startRef);
- dtVcopy(startNode->pos, centerPos);
- startNode->pidx = 0;
- startNode->cost = 0;
- startNode->total = 0;
- startNode->id = startRef;
- startNode->flags = DT_NODE_OPEN;
- m_openList->push(startNode);
-
- dtStatus status = DT_SUCCESS;
- int n = 0;
- if (n < maxResult)
- {
- if (resultRef)
- resultRef[n] = startNode->id;
- if (resultParent)
- resultParent[n] = 0;
- if (resultCost)
- resultCost[n] = 0;
- ++n;
- }
- else
- {
- status |= DT_BUFFER_TOO_SMALL;
- }
-
- while (!m_openList->empty())
- {
- dtNode* bestNode = m_openList->pop();
- bestNode->flags &= ~DT_NODE_OPEN;
- bestNode->flags |= DT_NODE_CLOSED;
-
- // Get poly and tile.
- // The API input has been cheked already, skip checking internal data.
- const dtPolyRef bestRef = bestNode->id;
- const dtMeshTile* bestTile = 0;
- const dtPoly* bestPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(bestRef, &bestTile, &bestPoly);
-
- // Get parent poly and tile.
- dtPolyRef parentRef = 0;
- const dtMeshTile* parentTile = 0;
- const dtPoly* parentPoly = 0;
- if (bestNode->pidx)
- parentRef = m_nodePool->getNodeAtIdx(bestNode->pidx)->id;
- if (parentRef)
- m_nav->getTileAndPolyByRefUnsafe(parentRef, &parentTile, &parentPoly);
-
- for (unsigned int i = bestPoly->firstLink; i != DT_NULL_LINK; i = bestTile->links[i].next)
- {
- const dtLink* link = &bestTile->links[i];
- dtPolyRef neighbourRef = link->ref;
- // Skip invalid neighbours and do not follow back to parent.
- if (!neighbourRef || neighbourRef == parentRef)
- continue;
-
- // Expand to neighbour
- const dtMeshTile* neighbourTile = 0;
- const dtPoly* neighbourPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(neighbourRef, &neighbourTile, &neighbourPoly);
-
- // Do not advance if the polygon is excluded by the filter.
- if (!filter->passFilter(neighbourRef, neighbourTile, neighbourPoly))
- continue;
-
- // Find edge and calc distance to the edge.
- float va[3], vb[3];
- if (!getPortalPoints(bestRef, bestPoly, bestTile, neighbourRef, neighbourPoly, neighbourTile, va, vb))
- continue;
-
- // If the poly is not touching the edge to the next polygon, skip the connection it.
- float tmin, tmax;
- int segMin, segMax;
- if (!dtIntersectSegmentPoly2D(va, vb, verts, nverts, tmin, tmax, segMin, segMax))
- continue;
- if (tmin > 1.0f || tmax < 0.0f)
- continue;
-
- dtNode* neighbourNode = m_nodePool->getNode(neighbourRef);
- if (!neighbourNode)
- {
- status |= DT_OUT_OF_NODES;
- continue;
- }
-
- if (neighbourNode->flags & DT_NODE_CLOSED)
- continue;
-
- // Cost
- if (neighbourNode->flags == 0)
- dtVlerp(neighbourNode->pos, va, vb, 0.5f);
-
- const float total = bestNode->total + dtVdist(bestNode->pos, neighbourNode->pos);
-
- // The node is already in open list and the new result is worse, skip.
- if ((neighbourNode->flags & DT_NODE_OPEN) && total >= neighbourNode->total)
- continue;
-
- neighbourNode->id = neighbourRef;
- neighbourNode->flags = (neighbourNode->flags & ~DT_NODE_CLOSED);
- neighbourNode->pidx = m_nodePool->getNodeIdx(bestNode);
- neighbourNode->total = total;
-
- if (neighbourNode->flags & DT_NODE_OPEN)
- {
- m_openList->modify(neighbourNode);
- }
- else
- {
- if (n < maxResult)
- {
- if (resultRef)
- resultRef[n] = neighbourNode->id;
- if (resultParent)
- resultParent[n] = m_nodePool->getNodeAtIdx(neighbourNode->pidx)->id;
- if (resultCost)
- resultCost[n] = neighbourNode->total;
- ++n;
- }
- else
- {
- status |= DT_BUFFER_TOO_SMALL;
- }
- neighbourNode->flags = DT_NODE_OPEN;
- m_openList->push(neighbourNode);
- }
- }
- }
-
- *resultCount = n;
-
- return status;
- }
- /// @par
- ///
- /// This method is optimized for a small search radius and small number of result
- /// polygons.
- ///
- /// Candidate polygons are found by searching the navigation graph beginning at
- /// the start polygon.
- ///
- /// The same intersection test restrictions that apply to the findPolysAroundCircle
- /// mehtod applies to this method.
- ///
- /// The value of the center point is used as the start point for cost calculations.
- /// It is not projected onto the surface of the mesh, so its y-value will effect
- /// the costs.
- ///
- /// Intersection tests occur in 2D. All polygons and the search circle are
- /// projected onto the xz-plane. So the y-value of the center point does not
- /// effect intersection tests.
- ///
- /// If the result arrays are is too small to hold the entire result set, they will
- /// be filled to capacity.
- ///
- dtStatus dtNavMeshQuery::findLocalNeighbourhood(dtPolyRef startRef, const float* centerPos, const float radius,
- const dtQueryFilter* filter,
- dtPolyRef* resultRef, dtPolyRef* resultParent,
- int* resultCount, const int maxResult) const
- {
- dtAssert(m_nav);
- dtAssert(m_tinyNodePool);
-
- *resultCount = 0;
- // Validate input
- if (!startRef || !m_nav->isValidPolyRef(startRef))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- static const int MAX_STACK = 48;
- dtNode* stack[MAX_STACK];
- int nstack = 0;
-
- m_tinyNodePool->clear();
-
- dtNode* startNode = m_tinyNodePool->getNode(startRef);
- startNode->pidx = 0;
- startNode->id = startRef;
- startNode->flags = DT_NODE_CLOSED;
- stack[nstack++] = startNode;
-
- const float radiusSqr = dtSqr(radius);
-
- float pa[DT_VERTS_PER_POLYGON*3];
- float pb[DT_VERTS_PER_POLYGON*3];
-
- dtStatus status = DT_SUCCESS;
-
- int n = 0;
- if (n < maxResult)
- {
- resultRef[n] = startNode->id;
- if (resultParent)
- resultParent[n] = 0;
- ++n;
- }
- else
- {
- status |= DT_BUFFER_TOO_SMALL;
- }
-
- while (nstack)
- {
- // Pop front.
- dtNode* curNode = stack[0];
- for (int i = 0; i < nstack-1; ++i)
- stack[i] = stack[i+1];
- nstack--;
-
- // Get poly and tile.
- // The API input has been cheked already, skip checking internal data.
- const dtPolyRef curRef = curNode->id;
- const dtMeshTile* curTile = 0;
- const dtPoly* curPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(curRef, &curTile, &curPoly);
-
- for (unsigned int i = curPoly->firstLink; i != DT_NULL_LINK; i = curTile->links[i].next)
- {
- const dtLink* link = &curTile->links[i];
- dtPolyRef neighbourRef = link->ref;
- // Skip invalid neighbours.
- if (!neighbourRef)
- continue;
-
- // Skip if cannot alloca more nodes.
- dtNode* neighbourNode = m_tinyNodePool->getNode(neighbourRef);
- if (!neighbourNode)
- continue;
- // Skip visited.
- if (neighbourNode->flags & DT_NODE_CLOSED)
- continue;
-
- // Expand to neighbour
- const dtMeshTile* neighbourTile = 0;
- const dtPoly* neighbourPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(neighbourRef, &neighbourTile, &neighbourPoly);
-
- // Skip off-mesh connections.
- if (neighbourPoly->getType() == DT_POLYTYPE_OFFMESH_CONNECTION)
- continue;
-
- // Do not advance if the polygon is excluded by the filter.
- if (!filter->passFilter(neighbourRef, neighbourTile, neighbourPoly))
- continue;
-
- // Find edge and calc distance to the edge.
- float va[3], vb[3];
- if (!getPortalPoints(curRef, curPoly, curTile, neighbourRef, neighbourPoly, neighbourTile, va, vb))
- continue;
-
- // If the circle is not touching the next polygon, skip it.
- float tseg;
- float distSqr = dtDistancePtSegSqr2D(centerPos, va, vb, tseg);
- if (distSqr > radiusSqr)
- continue;
-
- // Mark node visited, this is done before the overlap test so that
- // we will not visit the poly again if the test fails.
- neighbourNode->flags |= DT_NODE_CLOSED;
- neighbourNode->pidx = m_tinyNodePool->getNodeIdx(curNode);
-
- // Check that the polygon does not collide with existing polygons.
-
- // Collect vertices of the neighbour poly.
- const int npa = neighbourPoly->vertCount;
- for (int k = 0; k < npa; ++k)
- dtVcopy(&pa[k*3], &neighbourTile->verts[neighbourPoly->verts[k]*3]);
-
- bool overlap = false;
- for (int j = 0; j < n; ++j)
- {
- dtPolyRef pastRef = resultRef[j];
-
- // Connected polys do not overlap.
- bool connected = false;
- for (unsigned int k = curPoly->firstLink; k != DT_NULL_LINK; k = curTile->links[k].next)
- {
- if (curTile->links[k].ref == pastRef)
- {
- connected = true;
- break;
- }
- }
- if (connected)
- continue;
-
- // Potentially overlapping.
- const dtMeshTile* pastTile = 0;
- const dtPoly* pastPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(pastRef, &pastTile, &pastPoly);
-
- // Get vertices and test overlap
- const int npb = pastPoly->vertCount;
- for (int k = 0; k < npb; ++k)
- dtVcopy(&pb[k*3], &pastTile->verts[pastPoly->verts[k]*3]);
-
- if (dtOverlapPolyPoly2D(pa,npa, pb,npb))
- {
- overlap = true;
- break;
- }
- }
- if (overlap)
- continue;
-
- // This poly is fine, store and advance to the poly.
- if (n < maxResult)
- {
- resultRef[n] = neighbourRef;
- if (resultParent)
- resultParent[n] = curRef;
- ++n;
- }
- else
- {
- status |= DT_BUFFER_TOO_SMALL;
- }
-
- if (nstack < MAX_STACK)
- {
- stack[nstack++] = neighbourNode;
- }
- }
- }
-
- *resultCount = n;
-
- return status;
- }
- struct dtSegInterval
- {
- dtPolyRef ref;
- short tmin, tmax;
- };
- static void insertInterval(dtSegInterval* ints, int& nints, const int maxInts,
- const short tmin, const short tmax, const dtPolyRef ref)
- {
- if (nints+1 > maxInts) return;
- // Find insertion point.
- int idx = 0;
- while (idx < nints)
- {
- if (tmax <= ints[idx].tmin)
- break;
- idx++;
- }
- // Move current results.
- if (nints-idx)
- memmove(ints+idx+1, ints+idx, sizeof(dtSegInterval)*(nints-idx));
- // Store
- ints[idx].ref = ref;
- ints[idx].tmin = tmin;
- ints[idx].tmax = tmax;
- nints++;
- }
- /// @par
- ///
- /// If the @p segmentRefs parameter is provided, then all polygon segments will be returned.
- /// Otherwise only the wall segments are returned.
- ///
- /// A segment that is normally a portal will be included in the result set as a
- /// wall if the @p filter results in the neighbor polygon becoomming impassable.
- ///
- /// The @p segmentVerts and @p segmentRefs buffers should normally be sized for the
- /// maximum segments per polygon of the source navigation mesh.
- ///
- dtStatus dtNavMeshQuery::getPolyWallSegments(dtPolyRef ref, const dtQueryFilter* filter,
- float* segmentVerts, dtPolyRef* segmentRefs, int* segmentCount,
- const int maxSegments) const
- {
- dtAssert(m_nav);
-
- *segmentCount = 0;
-
- const dtMeshTile* tile = 0;
- const dtPoly* poly = 0;
- if (dtStatusFailed(m_nav->getTileAndPolyByRef(ref, &tile, &poly)))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- int n = 0;
- static const int MAX_INTERVAL = 16;
- dtSegInterval ints[MAX_INTERVAL];
- int nints;
-
- const bool storePortals = segmentRefs != 0;
-
- dtStatus status = DT_SUCCESS;
-
- for (int i = 0, j = (int)poly->vertCount-1; i < (int)poly->vertCount; j = i++)
- {
- // Skip non-solid edges.
- nints = 0;
- if (poly->neis[j] & DT_EXT_LINK)
- {
- // Tile border.
- for (unsigned int k = poly->firstLink; k != DT_NULL_LINK; k = tile->links[k].next)
- {
- const dtLink* link = &tile->links[k];
- if (link->edge == j)
- {
- if (link->ref != 0)
- {
- const dtMeshTile* neiTile = 0;
- const dtPoly* neiPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(link->ref, &neiTile, &neiPoly);
- if (filter->passFilter(link->ref, neiTile, neiPoly))
- {
- insertInterval(ints, nints, MAX_INTERVAL, link->bmin, link->bmax, link->ref);
- }
- }
- }
- }
- }
- else
- {
- // Internal edge
- dtPolyRef neiRef = 0;
- if (poly->neis[j])
- {
- const unsigned int idx = (unsigned int)(poly->neis[j]-1);
- neiRef = m_nav->getPolyRefBase(tile) | idx;
- if (!filter->passFilter(neiRef, tile, &tile->polys[idx]))
- neiRef = 0;
- }
- // If the edge leads to another polygon and portals are not stored, skip.
- if (neiRef != 0 && !storePortals)
- continue;
-
- if (n < maxSegments)
- {
- const float* vj = &tile->verts[poly->verts[j]*3];
- const float* vi = &tile->verts[poly->verts[i]*3];
- float* seg = &segmentVerts[n*6];
- dtVcopy(seg+0, vj);
- dtVcopy(seg+3, vi);
- if (segmentRefs)
- segmentRefs[n] = neiRef;
- n++;
- }
- else
- {
- status |= DT_BUFFER_TOO_SMALL;
- }
-
- continue;
- }
-
- // Add sentinels
- insertInterval(ints, nints, MAX_INTERVAL, -1, 0, 0);
- insertInterval(ints, nints, MAX_INTERVAL, 255, 256, 0);
-
- // Store segments.
- const float* vj = &tile->verts[poly->verts[j]*3];
- const float* vi = &tile->verts[poly->verts[i]*3];
- for (int k = 1; k < nints; ++k)
- {
- // Portal segment.
- if (storePortals && ints[k].ref)
- {
- const float tmin = ints[k].tmin/255.0f;
- const float tmax = ints[k].tmax/255.0f;
- if (n < maxSegments)
- {
- float* seg = &segmentVerts[n*6];
- dtVlerp(seg+0, vj,vi, tmin);
- dtVlerp(seg+3, vj,vi, tmax);
- if (segmentRefs)
- segmentRefs[n] = ints[k].ref;
- n++;
- }
- else
- {
- status |= DT_BUFFER_TOO_SMALL;
- }
- }
- // Wall segment.
- const int imin = ints[k-1].tmax;
- const int imax = ints[k].tmin;
- if (imin != imax)
- {
- const float tmin = imin/255.0f;
- const float tmax = imax/255.0f;
- if (n < maxSegments)
- {
- float* seg = &segmentVerts[n*6];
- dtVlerp(seg+0, vj,vi, tmin);
- dtVlerp(seg+3, vj,vi, tmax);
- if (segmentRefs)
- segmentRefs[n] = 0;
- n++;
- }
- else
- {
- status |= DT_BUFFER_TOO_SMALL;
- }
- }
- }
- }
-
- *segmentCount = n;
-
- return status;
- }
- /// @par
- ///
- /// @p hitPos is not adjusted using the height detail data.
- ///
- /// @p hitDist will equal the search radius if there is no wall within the
- /// radius. In this case the values of @p hitPos and @p hitNormal are
- /// undefined.
- ///
- /// The normal will become unpredicable if @p hitDist is a very small number.
- ///
- dtStatus dtNavMeshQuery::findDistanceToWall(dtPolyRef startRef, const float* centerPos, const float maxRadius,
- const dtQueryFilter* filter,
- float* hitDist, float* hitPos, float* hitNormal) const
- {
- dtAssert(m_nav);
- dtAssert(m_nodePool);
- dtAssert(m_openList);
-
- // Validate input
- if (!startRef || !m_nav->isValidPolyRef(startRef))
- return DT_FAILURE | DT_INVALID_PARAM;
-
- m_nodePool->clear();
- m_openList->clear();
-
- dtNode* startNode = m_nodePool->getNode(startRef);
- dtVcopy(startNode->pos, centerPos);
- startNode->pidx = 0;
- startNode->cost = 0;
- startNode->total = 0;
- startNode->id = startRef;
- startNode->flags = DT_NODE_OPEN;
- m_openList->push(startNode);
-
- float radiusSqr = dtSqr(maxRadius);
-
- dtStatus status = DT_SUCCESS;
-
- while (!m_openList->empty())
- {
- dtNode* bestNode = m_openList->pop();
- bestNode->flags &= ~DT_NODE_OPEN;
- bestNode->flags |= DT_NODE_CLOSED;
-
- // Get poly and tile.
- // The API input has been cheked already, skip checking internal data.
- const dtPolyRef bestRef = bestNode->id;
- const dtMeshTile* bestTile = 0;
- const dtPoly* bestPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(bestRef, &bestTile, &bestPoly);
-
- // Get parent poly and tile.
- dtPolyRef parentRef = 0;
- const dtMeshTile* parentTile = 0;
- const dtPoly* parentPoly = 0;
- if (bestNode->pidx)
- parentRef = m_nodePool->getNodeAtIdx(bestNode->pidx)->id;
- if (parentRef)
- m_nav->getTileAndPolyByRefUnsafe(parentRef, &parentTile, &parentPoly);
-
- // Hit test walls.
- for (int i = 0, j = (int)bestPoly->vertCount-1; i < (int)bestPoly->vertCount; j = i++)
- {
- // Skip non-solid edges.
- if (bestPoly->neis[j] & DT_EXT_LINK)
- {
- // Tile border.
- bool solid = true;
- for (unsigned int k = bestPoly->firstLink; k != DT_NULL_LINK; k = bestTile->links[k].next)
- {
- const dtLink* link = &bestTile->links[k];
- if (link->edge == j)
- {
- if (link->ref != 0)
- {
- const dtMeshTile* neiTile = 0;
- const dtPoly* neiPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(link->ref, &neiTile, &neiPoly);
- if (filter->passFilter(link->ref, neiTile, neiPoly))
- solid = false;
- }
- break;
- }
- }
- if (!solid) continue;
- }
- else if (bestPoly->neis[j])
- {
- // Internal edge
- const unsigned int idx = (unsigned int)(bestPoly->neis[j]-1);
- const dtPolyRef ref = m_nav->getPolyRefBase(bestTile) | idx;
- if (filter->passFilter(ref, bestTile, &bestTile->polys[idx]))
- continue;
- }
-
- // Calc distance to the edge.
- const float* vj = &bestTile->verts[bestPoly->verts[j]*3];
- const float* vi = &bestTile->verts[bestPoly->verts[i]*3];
- float tseg;
- float distSqr = dtDistancePtSegSqr2D(centerPos, vj, vi, tseg);
-
- // Edge is too far, skip.
- if (distSqr > radiusSqr)
- continue;
-
- // Hit wall, update radius.
- radiusSqr = distSqr;
- // Calculate hit pos.
- hitPos[0] = vj[0] + (vi[0] - vj[0])*tseg;
- hitPos[1] = vj[1] + (vi[1] - vj[1])*tseg;
- hitPos[2] = vj[2] + (vi[2] - vj[2])*tseg;
- }
-
- for (unsigned int i = bestPoly->firstLink; i != DT_NULL_LINK; i = bestTile->links[i].next)
- {
- const dtLink* link = &bestTile->links[i];
- dtPolyRef neighbourRef = link->ref;
- // Skip invalid neighbours and do not follow back to parent.
- if (!neighbourRef || neighbourRef == parentRef)
- continue;
-
- // Expand to neighbour.
- const dtMeshTile* neighbourTile = 0;
- const dtPoly* neighbourPoly = 0;
- m_nav->getTileAndPolyByRefUnsafe(neighbourRef, &neighbourTile, &neighbourPoly);
-
- // Skip off-mesh connections.
- if (neighbourPoly->getType() == DT_POLYTYPE_OFFMESH_CONNECTION)
- continue;
-
- // Calc distance to the edge.
- const float* va = &bestTile->verts[bestPoly->verts[link->edge]*3];
- const float* vb = &bestTile->verts[bestPoly->verts[(link->edge+1) % bestPoly->vertCount]*3];
- float tseg;
- float distSqr = dtDistancePtSegSqr2D(centerPos, va, vb, tseg);
-
- // If the circle is not touching the next polygon, skip it.
- if (distSqr > radiusSqr)
- continue;
-
- if (!filter->passFilter(neighbourRef, neighbourTile, neighbourPoly))
- continue;
- dtNode* neighbourNode = m_nodePool->getNode(neighbourRef);
- if (!neighbourNode)
- {
- status |= DT_OUT_OF_NODES;
- continue;
- }
-
- if (neighbourNode->flags & DT_NODE_CLOSED)
- continue;
-
- // Cost
- if (neighbourNode->flags == 0)
- {
- getEdgeMidPoint(bestRef, bestPoly, bestTile,
- neighbourRef, neighbourPoly, neighbourTile, neighbourNode->pos);
- }
-
- const float total = bestNode->total + dtVdist(bestNode->pos, neighbourNode->pos);
-
- // The node is already in open list and the new result is worse, skip.
- if ((neighbourNode->flags & DT_NODE_OPEN) && total >= neighbourNode->total)
- continue;
-
- neighbourNode->id = neighbourRef;
- neighbourNode->flags = (neighbourNode->flags & ~DT_NODE_CLOSED);
- neighbourNode->pidx = m_nodePool->getNodeIdx(bestNode);
- neighbourNode->total = total;
-
- if (neighbourNode->flags & DT_NODE_OPEN)
- {
- m_openList->modify(neighbourNode);
- }
- else
- {
- neighbourNode->flags |= DT_NODE_OPEN;
- m_openList->push(neighbourNode);
- }
- }
- }
-
- // Calc hit normal.
- dtVsub(hitNormal, centerPos, hitPos);
- dtVnormalize(hitNormal);
-
- *hitDist = sqrtf(radiusSqr);
-
- return status;
- }
- bool dtNavMeshQuery::isValidPolyRef(dtPolyRef ref, const dtQueryFilter* filter) const
- {
- const dtMeshTile* tile = 0;
- const dtPoly* poly = 0;
- dtStatus status = m_nav->getTileAndPolyByRef(ref, &tile, &poly);
- // If cannot get polygon, assume it does not exists and boundary is invalid.
- if (dtStatusFailed(status))
- return false;
- // If cannot pass filter, assume flags has changed and boundary is invalid.
- if (!filter->passFilter(ref, tile, poly))
- return false;
- return true;
- }
- /// @par
- ///
- /// The closed list is the list of polygons that were fully evaluated during
- /// the last navigation graph search. (A* or Dijkstra)
- ///
- bool dtNavMeshQuery::isInClosedList(dtPolyRef ref) const
- {
- if (!m_nodePool) return false;
- const dtNode* node = m_nodePool->findNode(ref);
- return node && node->flags & DT_NODE_CLOSED;
- }
|