123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745274627472748274927502751275227532754275527562757275827592760276127622763276427652766276727682769277027712772277327742775277627772778277927802781278227832784278527862787278827892790279127922793279427952796279727982799280028012802280328042805280628072808280928102811281228132814281528162817281828192820282128222823282428252826282728282829283028312832283328342835283628372838283928402841284228432844284528462847284828492850285128522853285428552856285728582859286028612862286328642865286628672868286928702871287228732874287528762877287828792880288128822883288428852886288728882889289028912892289328942895289628972898289929002901290229032904290529062907290829092910291129122913291429152916291729182919292029212922292329242925292629272928292929302931293229332934293529362937293829392940294129422943294429452946294729482949295029512952295329542955295629572958295929602961296229632964296529662967296829692970297129722973297429752976297729782979298029812982298329842985298629872988298929902991299229932994299529962997299829993000300130023003300430053006300730083009301030113012301330143015301630173018301930203021302230233024302530263027302830293030303130323033303430353036303730383039304030413042304330443045304630473048304930503051305230533054305530563057305830593060306130623063306430653066306730683069307030713072307330743075307630773078307930803081308230833084308530863087308830893090309130923093309430953096309730983099310031013102310331043105310631073108310931103111311231133114311531163117311831193120312131223123312431253126312731283129313031313132313331343135313631373138313931403141314231433144314531463147314831493150315131523153315431553156315731583159316031613162316331643165316631673168316931703171317231733174317531763177317831793180318131823183318431853186318731883189319031913192319331943195319631973198319932003201320232033204320532063207320832093210321132123213321432153216321732183219322032213222322332243225322632273228322932303231323232333234 |
- // Copyright (C) 2011-2016 Internet Systems Consortium, Inc. ("ISC")
- //
- // This Source Code Form is subject to the terms of the Mozilla Public
- // License, v. 2.0. If a copy of the MPL was not distributed with this
- // file, You can obtain one at http://mozilla.org/MPL/2.0/.
- #include <config.h>
- #include <asiolink/io_address.h>
- #include <dhcp_ddns/ncr_msg.h>
- #include <dhcp/dhcp6.h>
- #include <dhcp/docsis3_option_defs.h>
- #include <dhcp/duid.h>
- #include <dhcp/duid_factory.h>
- #include <dhcp/iface_mgr.h>
- #include <dhcp/libdhcp++.h>
- #include <dhcp/option6_addrlst.h>
- #include <dhcp/option6_client_fqdn.h>
- #include <dhcp/option6_ia.h>
- #include <dhcp/option6_iaaddr.h>
- #include <dhcp/option6_iaprefix.h>
- #include <dhcp/option6_status_code.h>
- #include <dhcp/option_custom.h>
- #include <dhcp/option_vendor.h>
- #include <dhcp/option_vendor_class.h>
- #include <dhcp/option_int_array.h>
- #include <dhcp/pkt6.h>
- #include <dhcp6/dhcp6to4_ipc.h>
- #include <dhcp6/dhcp6_log.h>
- #include <dhcp6/dhcp6_srv.h>
- #include <dhcpsrv/callout_handle_store.h>
- #include <dhcpsrv/cfg_host_operations.h>
- #include <dhcpsrv/cfgmgr.h>
- #include <dhcpsrv/lease_mgr.h>
- #include <dhcpsrv/lease_mgr_factory.h>
- #include <dhcpsrv/ncr_generator.h>
- #include <dhcpsrv/subnet.h>
- #include <dhcpsrv/subnet_selector.h>
- #include <dhcpsrv/utils.h>
- #include <eval/evaluate.h>
- #include <eval/eval_messages.h>
- #include <exceptions/exceptions.h>
- #include <hooks/callout_handle.h>
- #include <hooks/hooks_log.h>
- #include <hooks/hooks_manager.h>
- #include <stats/stats_mgr.h>
- #include <util/encode/hex.h>
- #include <util/io_utilities.h>
- #include <util/range_utilities.h>
- #include <log/logger.h>
- #include <cryptolink/cryptolink.h>
- #include <cfgrpt/config_report.h>
- #ifdef HAVE_MYSQL
- #include <dhcpsrv/mysql_lease_mgr.h>
- #endif
- #ifdef HAVE_PGSQL
- #include <dhcpsrv/pgsql_lease_mgr.h>
- #endif
- #ifdef HAVE_CQL
- #include <dhcpsrv/cql_lease_mgr.h>
- #endif
- #include <dhcpsrv/memfile_lease_mgr.h>
- #include <boost/bind.hpp>
- #include <boost/foreach.hpp>
- #include <boost/tokenizer.hpp>
- #include <boost/algorithm/string/erase.hpp>
- #include <boost/algorithm/string/join.hpp>
- #include <boost/algorithm/string/split.hpp>
- #include <stdlib.h>
- #include <time.h>
- #include <iomanip>
- #include <fstream>
- #include <sstream>
- using namespace isc;
- using namespace isc::asiolink;
- using namespace isc::cryptolink;
- using namespace isc::dhcp;
- using namespace isc::dhcp_ddns;
- using namespace isc::hooks;
- using namespace isc::log;
- using namespace isc::stats;
- using namespace isc::util;
- using namespace std;
- namespace {
- /// Structure that holds registered hook indexes
- struct Dhcp6Hooks {
- int hook_index_buffer6_receive_;///< index for "buffer6_receive" hook point
- int hook_index_pkt6_receive_; ///< index for "pkt6_receive" hook point
- int hook_index_subnet6_select_; ///< index for "subnet6_select" hook point
- int hook_index_lease6_release_; ///< index for "lease6_release" hook point
- int hook_index_pkt6_send_; ///< index for "pkt6_send" hook point
- int hook_index_buffer6_send_; ///< index for "buffer6_send" hook point
- int hook_index_lease6_decline_; ///< index for "lease6_decline" hook point
- /// Constructor that registers hook points for DHCPv6 engine
- Dhcp6Hooks() {
- hook_index_buffer6_receive_= HooksManager::registerHook("buffer6_receive");
- hook_index_pkt6_receive_ = HooksManager::registerHook("pkt6_receive");
- hook_index_subnet6_select_ = HooksManager::registerHook("subnet6_select");
- hook_index_lease6_release_ = HooksManager::registerHook("lease6_release");
- hook_index_pkt6_send_ = HooksManager::registerHook("pkt6_send");
- hook_index_buffer6_send_ = HooksManager::registerHook("buffer6_send");
- hook_index_lease6_decline_ = HooksManager::registerHook("lease6_decline");
- }
- };
- // Declare a Hooks object. As this is outside any function or method, it
- // will be instantiated (and the constructor run) when the module is loaded.
- // As a result, the hook indexes will be defined before any method in this
- // module is called.
- Dhcp6Hooks Hooks;
- /// @brief Creates instance of the Status Code option.
- ///
- /// This variant of the function is used when the Status Code option
- /// is added as a top-level option. It logs the debug message and
- /// includes the information about the client and transaction.
- ///
- /// @param pkt Reference to the client's message.
- /// @param status_code Numeric status code.
- /// @param status_message Status message.
- ///
- /// @return Pointer to the Status Code option.
- OptionPtr
- createStatusCode(const Pkt6& pkt, const uint16_t status_code,
- const std::string& status_message) {
- Option6StatusCodePtr option_status(new Option6StatusCode(status_code,
- status_message));
- LOG_DEBUG(options6_logger, DBG_DHCP6_DETAIL, DHCP6_ADD_GLOBAL_STATUS_CODE)
- .arg(pkt.getLabel())
- .arg(option_status->dataToText());
- return (option_status);
- }
- /// @brief Creates instance of the Status Code option.
- ///
- /// This variant of the function is used when the Status Code option
- /// is added to one of the IA options. It logs the debug message and
- /// includes the information about the client and transaction as well
- /// as IAID of the IA option.
- ///
- /// @param pkt Reference to the client's message.
- /// param ia Reference to the IA option to which the Status Code is
- /// being added.
- /// @param status_code Numeric status code.
- /// @param status_message Status message.
- ///
- /// @return Pointer to the Status Code option.
- OptionPtr
- createStatusCode(const Pkt6& pkt, const Option6IA& ia, const uint16_t status_code,
- const std::string& status_message) {
- Option6StatusCodePtr option_status(new Option6StatusCode(status_code,
- status_message));
- LOG_DEBUG(options6_logger, DBG_DHCP6_DETAIL, DHCP6_ADD_STATUS_CODE_FOR_IA)
- .arg(pkt.getLabel())
- .arg(ia.getIAID())
- .arg(option_status->dataToText());
- return (option_status);
- }
- }; // anonymous namespace
- namespace isc {
- namespace dhcp {
- const std::string Dhcpv6Srv::VENDOR_CLASS_PREFIX("VENDOR_CLASS_");
- Dhcpv6Srv::Dhcpv6Srv(uint16_t port)
- : port_(port), serverid_(), shutdown_(true), alloc_engine_()
- {
- LOG_DEBUG(dhcp6_logger, DBG_DHCP6_START, DHCP6_OPEN_SOCKET).arg(port);
- // Initialize objects required for DHCP server operation.
- try {
- // Port 0 is used for testing purposes where in most cases we don't
- // rely on the physical interfaces. Therefore, it should be possible
- // to create an object even when there are no usable interfaces.
- if ((port > 0) && (IfaceMgr::instance().countIfaces() == 0)) {
- LOG_ERROR(dhcp6_logger, DHCP6_NO_INTERFACES);
- return;
- }
- // Create a DUID instance but do not store it into a file.
- DUIDFactory duid_factory;
- DuidPtr duid = duid_factory.get();
- serverid_.reset(new Option(Option::V6, D6O_SERVERID, duid->getDuid()));
- // Instantiate allocation engine. The number of allocation attempts equal
- // to zero indicates that the allocation engine will use the number of
- // attempts depending on the pool size.
- alloc_engine_.reset(new AllocEngine(AllocEngine::ALLOC_ITERATIVE, 0));
- /// @todo call loadLibraries() when handling configuration changes
- } catch (const std::exception &e) {
- LOG_ERROR(dhcp6_logger, DHCP6_SRV_CONSTRUCT_ERROR).arg(e.what());
- return;
- }
- // All done, so can proceed
- shutdown_ = false;
- }
- Dhcpv6Srv::~Dhcpv6Srv() {
- try {
- stopD2();
- } catch(const std::exception& ex) {
- // Highly unlikely, but lets Report it but go on
- LOG_ERROR(dhcp6_logger, DHCP6_SRV_D2STOP_ERROR).arg(ex.what());
- }
- try {
- Dhcp6to4Ipc::instance().close();
- } catch(const std::exception& ex) {
- // Highly unlikely, but lets Report it but go on
- // LOG_ERROR(dhcp6_logger, DHCP6_SRV_DHCP4O6_ERROR).arg(ex.what());
- }
- IfaceMgr::instance().closeSockets();
- LeaseMgrFactory::destroy();
- // Explicitly unload hooks
- HooksManager::getHooksManager().unloadLibraries();
- }
- void Dhcpv6Srv::shutdown() {
- LOG_DEBUG(dhcp6_logger, DBG_DHCP6_BASIC, DHCP6_SHUTDOWN_REQUEST);
- shutdown_ = true;
- }
- Pkt6Ptr Dhcpv6Srv::receivePacket(int timeout) {
- return (IfaceMgr::instance().receive6(timeout));
- }
- void Dhcpv6Srv::sendPacket(const Pkt6Ptr& packet) {
- IfaceMgr::instance().send(packet);
- }
- bool
- Dhcpv6Srv::testServerID(const Pkt6Ptr& pkt) {
- /// @todo Currently we always check server identifier regardless if
- /// it is allowed in the received message or not (per RFC3315).
- /// If the server identifier is not allowed in the message, the
- /// sanityCheck function should deal with it.
- OptionPtr server_id = pkt->getOption(D6O_SERVERID);
- if (server_id){
- // Let us test received ServerID if it is same as ServerID
- // which is being used by server
- if (getServerID()->getData() != server_id->getData()){
- LOG_DEBUG(bad_packet6_logger, DBG_DHCP6_DETAIL_DATA,
- DHCP6_PACKET_DROP_SERVERID_MISMATCH)
- .arg(pkt->getLabel())
- .arg(duidToString(server_id))
- .arg(duidToString(getServerID()));
- return (false);
- }
- }
- // return True if: no serverid received or ServerIDs matching
- return (true);
- }
- bool
- Dhcpv6Srv::testUnicast(const Pkt6Ptr& pkt) const {
- switch (pkt->getType()) {
- case DHCPV6_SOLICIT:
- case DHCPV6_CONFIRM:
- case DHCPV6_REBIND:
- case DHCPV6_INFORMATION_REQUEST:
- if (pkt->relay_info_.empty() && !pkt->getLocalAddr().isV6Multicast()) {
- LOG_DEBUG(bad_packet6_logger, DBG_DHCP6_DETAIL, DHCP6_PACKET_DROP_UNICAST)
- .arg(pkt->getLabel())
- .arg(pkt->getName());
- return (false);
- }
- break;
- default:
- // do nothing
- ;
- }
- return (true);
- }
- void
- Dhcpv6Srv::initContext(const Pkt6Ptr& pkt, AllocEngine::ClientContext6& ctx) {
- ctx.subnet_ = selectSubnet(pkt);
- ctx.duid_ = pkt->getClientId(),
- ctx.fwd_dns_update_ = false;
- ctx.rev_dns_update_ = false;
- ctx.hostname_ = "";
- ctx.query_ = pkt;
- ctx.callout_handle_ = getCalloutHandle(pkt);
- ctx.hwaddr_ = getMAC(pkt);
- // Collect host identifiers if host reservations enabled. The identifiers
- // are stored in order of preference. The server will use them in that
- // order to search for host reservations.
- if (ctx.subnet_ &&
- (ctx.subnet_->getHostReservationMode() != Subnet::HR_DISABLED)) {
- const ConstCfgHostOperationsPtr cfg =
- CfgMgr::instance().getCurrentCfg()->getCfgHostOperations6();
- BOOST_FOREACH(const Host::IdentifierType& id_type,
- cfg->getIdentifierTypes()) {
- switch (id_type) {
- case Host::IDENT_DUID:
- if (ctx.duid_) {
- ctx.addHostIdentifier(id_type, ctx.duid_->getDuid());
- }
- break;
- case Host::IDENT_HWADDR:
- if (ctx.hwaddr_) {
- ctx.addHostIdentifier(id_type, ctx.hwaddr_->hwaddr_);
- }
- break;
- default:
- ;
- }
- }
- // Find host reservations using specified identifiers.
- alloc_engine_->findReservation(ctx);
- }
- }
- bool Dhcpv6Srv::run() {
- while (!shutdown_) {
- try {
- run_one();
- } catch (const std::exception& e) {
- // General catch-all standard exceptions that are not caught by more
- // specific catches.
- LOG_ERROR(packet6_logger, DHCP6_PACKET_PROCESS_STD_EXCEPTION)
- .arg(e.what());
- } catch (...) {
- // General catch-all non-standard exception that are not caught
- // by more specific catches.
- LOG_ERROR(packet6_logger, DHCP6_PACKET_PROCESS_EXCEPTION);
- }
- }
- return (true);
- }
- void Dhcpv6Srv::run_one() {
- // client's message and server's response
- Pkt6Ptr query;
- Pkt6Ptr rsp;
- try {
- uint32_t timeout = 1000;
- LOG_DEBUG(packet6_logger, DBG_DHCP6_DETAIL, DHCP6_BUFFER_WAIT).arg(timeout);
- query = receivePacket(timeout);
- // Log if packet has arrived. We can't log the detailed information
- // about the DHCP message because it hasn't been unpacked/parsed
- // yet, and it can't be parsed at this point because hooks will
- // have to process it first. The only information available at this
- // point are: the interface, source address and destination addresses
- // and ports.
- if (query) {
- LOG_DEBUG(packet6_logger, DBG_DHCP6_BASIC, DHCP6_BUFFER_RECEIVED)
- .arg(query->getRemoteAddr().toText())
- .arg(query->getRemotePort())
- .arg(query->getLocalAddr().toText())
- .arg(query->getLocalPort())
- .arg(query->getIface());
- // Log reception of the packet. We need to increase it early, as
- // any failures in unpacking will cause the packet to be dropped.
- // we will increase type specific packets further down the road.
- // See processStatsReceived().
- StatsMgr::instance().addValue("pkt6-received", static_cast<int64_t>(1));
- } else {
- LOG_DEBUG(packet6_logger, DBG_DHCP6_DETAIL, DHCP6_BUFFER_WAIT_INTERRUPTED)
- .arg(timeout);
- }
- } catch (const SignalInterruptOnSelect) {
- // Packet reception interrupted because a signal has been received.
- // This is not an error because we might have received a SIGTERM,
- // SIGINT or SIGHUP which are handled by the server. For signals
- // that are not handled by the server we rely on the default
- // behavior of the system.
- LOG_DEBUG(packet6_logger, DBG_DHCP6_DETAIL, DHCP6_BUFFER_WAIT_SIGNAL)
- .arg(signal_set_->getNext());
- } catch (const std::exception& e) {
- LOG_ERROR(packet6_logger, DHCP6_PACKET_RECEIVE_FAIL).arg(e.what());
- }
- // Handle next signal received by the process. It must be called after
- // an attempt to receive a packet to properly handle server shut down.
- // The SIGTERM or SIGINT will be received prior to, or during execution
- // of select() (select is invoked by receivePacket()). When that happens,
- // select will be interrupted. The signal handler will be invoked
- // immediately after select(). The handler will set the shutdown flag
- // and cause the process to terminate before the next select() function
- // is called. If the function was called before receivePacket the
- // process could wait up to the duration of timeout of select() to
- // terminate.
- try {
- handleSignal();
- } catch (const std::exception& e) {
- // An (a standard or ISC) exception occurred.
- LOG_ERROR(dhcp6_logger, DHCP6_HANDLE_SIGNAL_EXCEPTION)
- .arg(e.what());
- }
- // Timeout may be reached or signal received, which breaks select()
- // with no packet received
- if (!query) {
- return;
- }
- processPacket(query, rsp);
- if (!rsp) {
- return;
- }
- try {
- // Now all fields and options are constructed into output wire buffer.
- // Option objects modification does not make sense anymore. Hooks
- // can only manipulate wire buffer at this stage.
- // Let's execute all callouts registered for buffer6_send
- if (HooksManager::calloutsPresent(Hooks.hook_index_buffer6_send_)) {
- CalloutHandlePtr callout_handle = getCalloutHandle(query);
- // Delete previously set arguments
- callout_handle->deleteAllArguments();
- // Enable copying options from the packet within hook library.
- ScopedEnableOptionsCopy<Pkt6> response6_options_copy(rsp);
- // Pass incoming packet as argument
- callout_handle->setArgument("response6", rsp);
- // Call callouts
- HooksManager::callCallouts(Hooks.hook_index_buffer6_send_, *callout_handle);
- // Callouts decided to skip the next processing step. The next
- // processing step would to parse the packet, so skip at this
- // stage means drop.
- if (callout_handle->getStatus() == CalloutHandle::NEXT_STEP_SKIP) {
- LOG_DEBUG(hooks_logger, DBG_DHCP6_HOOKS, DHCP6_HOOK_BUFFER_SEND_SKIP)
- .arg(rsp->getLabel());
- return;
- }
- /// @todo: Add support for DROP status
- callout_handle->getArgument("response6", rsp);
- }
- LOG_DEBUG(packet6_logger, DBG_DHCP6_DETAIL_DATA, DHCP6_RESPONSE_DATA)
- .arg(static_cast<int>(rsp->getType())).arg(rsp->toText());
- sendPacket(rsp);
- // Update statistics accordingly for sent packet.
- processStatsSent(rsp);
- } catch (const std::exception& e) {
- LOG_ERROR(packet6_logger, DHCP6_PACKET_SEND_FAIL).arg(e.what());
- }
- }
- void
- Dhcpv6Srv::processPacket(Pkt6Ptr& query, Pkt6Ptr& rsp) {
- bool skip_unpack = false;
- // The packet has just been received so contains the uninterpreted wire
- // data; execute callouts registered for buffer6_receive.
- if (HooksManager::calloutsPresent(Hooks.hook_index_buffer6_receive_)) {
- CalloutHandlePtr callout_handle = getCalloutHandle(query);
- // Enable copying options from the packet within hook library.
- ScopedEnableOptionsCopy<Pkt6> query6_options_copy(query);
- // Delete previously set arguments
- callout_handle->deleteAllArguments();
- // Pass incoming packet as argument
- callout_handle->setArgument("query6", query);
- // Call callouts
- HooksManager::callCallouts(Hooks.hook_index_buffer6_receive_, *callout_handle);
- // Callouts decided to skip the next processing step. The next
- // processing step would to parse the packet, so skip at this
- // stage means that callouts did the parsing already, so server
- // should skip parsing.
- if (callout_handle->getStatus() == CalloutHandle::NEXT_STEP_SKIP) {
- LOG_DEBUG(hooks_logger, DBG_DHCP6_DETAIL, DHCP6_HOOK_BUFFER_RCVD_SKIP)
- .arg(query->getRemoteAddr().toText())
- .arg(query->getLocalAddr().toText())
- .arg(query->getIface());
- skip_unpack = true;
- }
- /// @todo: Add support for DROP status.
- callout_handle->getArgument("query6", query);
- }
- // Unpack the packet information unless the buffer6_receive callouts
- // indicated they did it
- if (!skip_unpack) {
- try {
- LOG_DEBUG(options6_logger, DBG_DHCP6_DETAIL, DHCP6_BUFFER_UNPACK)
- .arg(query->getRemoteAddr().toText())
- .arg(query->getLocalAddr().toText())
- .arg(query->getIface());
- query->unpack();
- } catch (const std::exception &e) {
- // Failed to parse the packet.
- LOG_DEBUG(bad_packet6_logger, DBG_DHCP6_DETAIL,
- DHCP6_PACKET_DROP_PARSE_FAIL)
- .arg(query->getRemoteAddr().toText())
- .arg(query->getLocalAddr().toText())
- .arg(query->getIface())
- .arg(e.what());
- // Increase the statistics of parse failures and dropped packets.
- StatsMgr::instance().addValue("pkt6-parse-failed",
- static_cast<int64_t>(1));
- StatsMgr::instance().addValue("pkt6-receive-drop",
- static_cast<int64_t>(1));
- return;
- }
- }
- // Update statistics accordingly for received packet.
- processStatsReceived(query);
- // Check if received query carries server identifier matching
- // server identifier being used by the server.
- if (!testServerID(query)) {
- // Increase the statistic of dropped packets.
- StatsMgr::instance().addValue("pkt6-receive-drop", static_cast<int64_t>(1));
- return;
- }
- // Check if the received query has been sent to unicast or multicast.
- // The Solicit, Confirm, Rebind and Information Request will be
- // discarded if sent to unicast address.
- if (!testUnicast(query)) {
- // Increase the statistic of dropped packets.
- StatsMgr::instance().addValue("pkt6-receive-drop", static_cast<int64_t>(1));
- return;
- }
- LOG_DEBUG(packet6_logger, DBG_DHCP6_BASIC_DATA, DHCP6_PACKET_RECEIVED)
- .arg(query->getLabel())
- .arg(query->getName())
- .arg(static_cast<int>(query->getType()))
- .arg(query->getRemoteAddr())
- .arg(query->getLocalAddr())
- .arg(query->getIface());
- LOG_DEBUG(packet6_logger, DBG_DHCP6_DETAIL_DATA, DHCP6_QUERY_DATA)
- .arg(query->getLabel())
- .arg(query->toText());
- // At this point the information in the packet has been unpacked into
- // the various packet fields and option objects has been created.
- // Execute callouts registered for packet6_receive.
- if (HooksManager::calloutsPresent(Hooks.hook_index_pkt6_receive_)) {
- CalloutHandlePtr callout_handle = getCalloutHandle(query);
- // Delete previously set arguments
- callout_handle->deleteAllArguments();
- // Enable copying options from the packet within hook library.
- ScopedEnableOptionsCopy<Pkt6> query6_options_copy(query);
- // Pass incoming packet as argument
- callout_handle->setArgument("query6", query);
- // Call callouts
- HooksManager::callCallouts(Hooks.hook_index_pkt6_receive_, *callout_handle);
- // Callouts decided to skip the next processing step. The next
- // processing step would to process the packet, so skip at this
- // stage means drop.
- if (callout_handle->getStatus() == CalloutHandle::NEXT_STEP_SKIP) {
- LOG_DEBUG(hooks_logger, DBG_DHCP6_HOOKS, DHCP6_HOOK_PACKET_RCVD_SKIP)
- .arg(query->getLabel());
- return;
- }
- /// @todo: Add support for DROP status.
- callout_handle->getArgument("query6", query);
- }
- // Assign this packet to a class, if possible
- classifyPacket(query);
- try {
- NameChangeRequestPtr ncr;
- switch (query->getType()) {
- case DHCPV6_SOLICIT:
- rsp = processSolicit(query);
- break;
- case DHCPV6_REQUEST:
- rsp = processRequest(query);
- break;
- case DHCPV6_RENEW:
- rsp = processRenew(query);
- break;
- case DHCPV6_REBIND:
- rsp = processRebind(query);
- break;
- case DHCPV6_CONFIRM:
- rsp = processConfirm(query);
- break;
- case DHCPV6_RELEASE:
- rsp = processRelease(query);
- break;
- case DHCPV6_DECLINE:
- rsp = processDecline(query);
- break;
- case DHCPV6_INFORMATION_REQUEST:
- rsp = processInfRequest(query);
- break;
- case DHCPV6_DHCPV4_QUERY:
- processDhcp4Query(query);
- break;
- default:
- // We received a packet type that we do not recognize.
- LOG_DEBUG(bad_packet6_logger, DBG_DHCP6_BASIC, DHCP6_UNKNOWN_MSG_RECEIVED)
- .arg(static_cast<int>(query->getType()))
- .arg(query->getIface());
- // Only action is to output a message if debug is enabled,
- // and that will be covered by the debug statement before
- // the "switch" statement.
- ;
- }
- } catch (const RFCViolation& e) {
- LOG_DEBUG(bad_packet6_logger, DBG_DHCP6_BASIC, DHCP6_REQUIRED_OPTIONS_CHECK_FAIL)
- .arg(query->getName())
- .arg(query->getRemoteAddr().toText())
- .arg(e.what());
- // Increase the statistic of dropped packets.
- StatsMgr::instance().addValue("pkt6-receive-drop", static_cast<int64_t>(1));
- } catch (const std::exception& e) {
- // Catch-all exception (at least for ones based on the isc Exception
- // class, which covers more or less all that are explicitly raised
- // in the Kea code), but also the standard one, which may possibly be
- // thrown from boost code. Just log the problem and ignore the packet.
- // (The problem is logged as a debug message because debug is
- // disabled by default - it prevents a DDOS attack based on the
- // sending of problem packets.)
- LOG_DEBUG(bad_packet6_logger, DBG_DHCP6_BASIC, DHCP6_PACKET_PROCESS_FAIL)
- .arg(query->getName())
- .arg(query->getRemoteAddr().toText())
- .arg(e.what());
- // Increase the statistic of dropped packets.
- StatsMgr::instance().addValue("pkt6-receive-drop", static_cast<int64_t>(1));
- }
- if (!rsp) {
- return;
- }
- // Process relay-supplied options. It is important to call this very
- // late in the process, because we now have all the options the
- // server wanted to send already set. This is important, because
- // RFC6422, section 6 states:
- //
- // The server SHOULD discard any options that appear in the RSOO
- // for which it already has one or more candidates.
- //
- // So we ignore any RSOO options if there's an option with the same
- // code already present.
- processRSOO(query, rsp);
- rsp->setRemoteAddr(query->getRemoteAddr());
- rsp->setLocalAddr(query->getLocalAddr());
- if (rsp->relay_info_.empty()) {
- // Direct traffic, send back to the client directly
- rsp->setRemotePort(DHCP6_CLIENT_PORT);
- } else {
- // Relayed traffic, send back to the relay agent
- rsp->setRemotePort(DHCP6_SERVER_PORT);
- }
- rsp->setLocalPort(DHCP6_SERVER_PORT);
- rsp->setIndex(query->getIndex());
- rsp->setIface(query->getIface());
- // Specifies if server should do the packing
- bool skip_pack = false;
- // Server's reply packet now has all options and fields set.
- // Options are represented by individual objects, but the
- // output wire data has not been prepared yet.
- // Execute all callouts registered for packet6_send
- if (HooksManager::calloutsPresent(Hooks.hook_index_pkt6_send_)) {
- CalloutHandlePtr callout_handle = getCalloutHandle(query);
- // Enable copying options from the packets within hook library.
- ScopedEnableOptionsCopy<Pkt6> query_resp_options_copy(query, rsp);
- // Delete all previous arguments
- callout_handle->deleteAllArguments();
- // Pass incoming packet as argument
- callout_handle->setArgument("query6", query);
- // Set our response
- callout_handle->setArgument("response6", rsp);
- // Call all installed callouts
- HooksManager::callCallouts(Hooks.hook_index_pkt6_send_, *callout_handle);
- // Callouts decided to skip the next processing step. The next
- // processing step would to pack the packet (create wire data).
- // That step will be skipped if any callout sets skip flag.
- // It essentially means that the callout already did packing,
- // so the server does not have to do it again.
- if (callout_handle->getStatus() == CalloutHandle::NEXT_STEP_SKIP) {
- LOG_DEBUG(hooks_logger, DBG_DHCP6_HOOKS, DHCP6_HOOK_PACKET_SEND_SKIP)
- .arg(rsp->getLabel());
- skip_pack = true;
- }
- /// @todo: Add support for DROP status
- }
- if (!skip_pack) {
- try {
- rsp->pack();
- } catch (const std::exception& e) {
- LOG_ERROR(options6_logger, DHCP6_PACK_FAIL).arg(e.what());
- return;
- }
- }
- }
- std::string
- Dhcpv6Srv::duidToString(const OptionPtr& opt) {
- stringstream tmp;
- OptionBuffer data = opt->getData();
- bool colon = false;
- for (OptionBufferConstIter it = data.begin(); it != data.end(); ++it) {
- if (colon) {
- tmp << ":";
- }
- tmp << hex << setw(2) << setfill('0') << static_cast<uint16_t>(*it);
- if (!colon) {
- colon = true;
- }
- }
- return tmp.str();
- }
- void
- Dhcpv6Srv::copyClientOptions(const Pkt6Ptr& question, Pkt6Ptr& answer) {
- // Add client-id.
- OptionPtr clientid = question->getOption(D6O_CLIENTID);
- if (clientid) {
- answer->addOption(clientid);
- }
- /// @todo: Should throw if there is no client-id (except anonymous INF-REQUEST)
- // If this is a relayed message, we need to copy relay information
- if (!question->relay_info_.empty()) {
- answer->copyRelayInfo(question);
- }
- }
- void
- Dhcpv6Srv::appendDefaultOptions(const Pkt6Ptr&, Pkt6Ptr& answer,
- const CfgOptionList&) {
- // add server-id
- answer->addOption(getServerID());
- }
- void
- Dhcpv6Srv::buildCfgOptionList(const Pkt6Ptr& question,
- AllocEngine::ClientContext6& ctx,
- CfgOptionList& co_list) {
- // Firstly, host specific options.
- if (ctx.host_ && !ctx.host_->getCfgOption6()->empty()) {
- co_list.push_back(ctx.host_->getCfgOption6());
- }
- // Secondly, pool specific options. Pools are defined within a subnet, so
- // if there is no subnet, there is nothing to do.
- if (ctx.subnet_) {
- BOOST_FOREACH(const AllocEngine::ResourceType& resource,
- ctx.allocated_resources_) {
- PoolPtr pool = ctx.subnet_->getPool(resource.second == 128 ?
- Lease::TYPE_NA : Lease::TYPE_PD,
- resource.first, false);
- if (pool && !pool->getCfgOption()->empty()) {
- co_list.push_back(pool->getCfgOption());
- }
- }
- };
- // Next, subnet configured options.
- if (ctx.subnet_ && !ctx.subnet_->getCfgOption()->empty()) {
- co_list.push_back(ctx.subnet_->getCfgOption());
- }
- // Each class in the incoming packet
- const ClientClasses& classes = question->getClasses();
- for (ClientClasses::const_iterator cclass = classes.begin();
- cclass != classes.end(); ++cclass) {
- // Find the client class definition for this class
- const ClientClassDefPtr& ccdef = CfgMgr::instance().getCurrentCfg()->
- getClientClassDictionary()->findClass(*cclass);
- if (!ccdef) {
- // Not found: the class is not configured
- if (((*cclass).size() <= VENDOR_CLASS_PREFIX.size()) ||
- ((*cclass).compare(0, VENDOR_CLASS_PREFIX.size(), VENDOR_CLASS_PREFIX) != 0)) {
- // Not a VENDOR_CLASS_* so should be configured
- LOG_DEBUG(dhcp6_logger, DBG_DHCP6_BASIC, DHCP6_CLASS_UNCONFIGURED)
- .arg(question->getLabel())
- .arg(*cclass);
- }
- // Skip it
- continue;
- }
- if (ccdef->getCfgOption()->empty()) {
- // Skip classes which don't configure options
- continue;
- }
- co_list.push_back(ccdef->getCfgOption());
- }
- // Last global options
- if (!CfgMgr::instance().getCurrentCfg()->getCfgOption()->empty()) {
- co_list.push_back(CfgMgr::instance().getCurrentCfg()->getCfgOption());
- }
- }
- void
- Dhcpv6Srv::appendRequestedOptions(const Pkt6Ptr& question, Pkt6Ptr& answer,
- const CfgOptionList& co_list) {
- // Client requests some options using ORO option. Try to
- // get this option from client's message.
- boost::shared_ptr<OptionIntArray<uint16_t> > option_oro =
- boost::dynamic_pointer_cast<OptionIntArray<uint16_t> >
- (question->getOption(D6O_ORO));
- // Option ORO not found? We're done here then.
- if (!option_oro || co_list.empty()) {
- return;
- }
- // Get the list of options that client requested.
- const std::vector<uint16_t>& requested_opts = option_oro->getValues();
- BOOST_FOREACH(uint16_t opt, requested_opts) {
- // Iterate on the configured option list
- for (CfgOptionList::const_iterator copts = co_list.begin();
- copts != co_list.end(); ++copts) {
- OptionDescriptor desc = (*copts)->get("dhcp6", opt);
- // Got it: add it and jump to the outer loop
- if (desc.option_) {
- answer->addOption(desc.option_);
- break;
- }
- }
- }
- }
- void
- Dhcpv6Srv::appendRequestedVendorOptions(const Pkt6Ptr& question,
- Pkt6Ptr& answer,
- AllocEngine::ClientContext6& ctx,
- const CfgOptionList& co_list) {
- // Leave if there is no subnet matching the incoming packet.
- // There is no need to log the error message here because
- // it will be logged in the assignLease() when it fails to
- // pick the suitable subnet. We don't want to duplicate
- // error messages in such case.
- if (!ctx.subnet_) {
- return;
- }
- // Try to get the vendor option
- boost::shared_ptr<OptionVendor> vendor_req =
- boost::dynamic_pointer_cast<OptionVendor>(question->getOption(D6O_VENDOR_OPTS));
- if (!vendor_req || co_list.empty()) {
- return;
- }
- // Let's try to get ORO within that vendor-option
- /// @todo This is very specific to vendor-id=4491 (Cable Labs). Other vendors
- /// may have different policies.
- boost::shared_ptr<OptionUint16Array> oro =
- boost::dynamic_pointer_cast<OptionUint16Array>(vendor_req->getOption(DOCSIS3_V6_ORO));
- // Option ORO not found. Don't do anything then.
- if (!oro) {
- return;
- }
- uint32_t vendor_id = vendor_req->getVendorId();
- boost::shared_ptr<OptionVendor> vendor_rsp(new OptionVendor(Option::V6, vendor_id));
- // Get the list of options that client requested.
- bool added = false;
- const std::vector<uint16_t>& requested_opts = oro->getValues();
- BOOST_FOREACH(uint16_t opt, requested_opts) {
- for (CfgOptionList::const_iterator copts = co_list.begin();
- copts != co_list.end(); ++copts) {
- OptionDescriptor desc = (*copts)->get(vendor_id, opt);
- if (desc.option_) {
- vendor_rsp->addOption(desc.option_);
- added = true;
- break;
- }
- }
- }
- if (added) {
- answer->addOption(vendor_rsp);
- }
- }
- void
- Dhcpv6Srv::sanityCheck(const Pkt6Ptr& pkt, RequirementLevel clientid,
- RequirementLevel serverid) {
- OptionCollection client_ids = pkt->getOptions(D6O_CLIENTID);
- switch (clientid) {
- case MANDATORY:
- if (client_ids.size() != 1) {
- isc_throw(RFCViolation, "Exactly 1 client-id option expected in "
- << pkt->getName() << ", but " << client_ids.size()
- << " received");
- }
- break;
- case OPTIONAL:
- if (client_ids.size() > 1) {
- isc_throw(RFCViolation, "Too many (" << client_ids.size()
- << ") client-id options received in " << pkt->getName());
- }
- break;
- case FORBIDDEN:
- // doesn't make sense - client-id is always allowed
- break;
- }
- OptionCollection server_ids = pkt->getOptions(D6O_SERVERID);
- switch (serverid) {
- case FORBIDDEN:
- if (!server_ids.empty()) {
- isc_throw(RFCViolation, "Server-id option was not expected, but "
- << server_ids.size() << " received in " << pkt->getName());
- }
- break;
- case MANDATORY:
- if (server_ids.size() != 1) {
- isc_throw(RFCViolation, "Invalid number of server-id options received ("
- << server_ids.size() << "), exactly 1 expected in message "
- << pkt->getName());
- }
- break;
- case OPTIONAL:
- if (server_ids.size() > 1) {
- isc_throw(RFCViolation, "Too many (" << server_ids.size()
- << ") server-id options received in " << pkt->getName());
- }
- }
- }
- Subnet6Ptr
- Dhcpv6Srv::selectSubnet(const Pkt6Ptr& question) {
- // Initialize subnet selector with the values used to select the subnet.
- SubnetSelector selector;
- selector.iface_name_ = question->getIface();
- selector.remote_address_ = question->getRemoteAddr();
- selector.first_relay_linkaddr_ = IOAddress("::");
- selector.client_classes_ = question->classes_;
- // Initialize fields specific to relayed messages.
- if (!question->relay_info_.empty()) {
- BOOST_REVERSE_FOREACH(Pkt6::RelayInfo relay, question->relay_info_) {
- if (!relay.linkaddr_.isV6Zero() &&
- !relay.linkaddr_.isV6LinkLocal()) {
- selector.first_relay_linkaddr_ = relay.linkaddr_;
- break;
- }
- }
- selector.interface_id_ =
- question->getAnyRelayOption(D6O_INTERFACE_ID,
- Pkt6::RELAY_GET_FIRST);
- }
- Subnet6Ptr subnet = CfgMgr::instance().getCurrentCfg()->
- getCfgSubnets6()->selectSubnet(selector);
- // Let's execute all callouts registered for subnet6_receive
- if (HooksManager::calloutsPresent(Hooks.hook_index_subnet6_select_)) {
- CalloutHandlePtr callout_handle = getCalloutHandle(question);
- // We're reusing callout_handle from previous calls
- callout_handle->deleteAllArguments();
- // Enable copying options from the packet within hook library.
- ScopedEnableOptionsCopy<Pkt6> query6_options_copy(question);
- // Set new arguments
- callout_handle->setArgument("query6", question);
- callout_handle->setArgument("subnet6", subnet);
- // We pass pointer to const collection for performance reasons.
- // Otherwise we would get a non-trivial performance penalty each
- // time subnet6_select is called.
- callout_handle->setArgument("subnet6collection",
- CfgMgr::instance().getCurrentCfg()->
- getCfgSubnets6()->getAll());
- // Call user (and server-side) callouts
- HooksManager::callCallouts(Hooks.hook_index_subnet6_select_, *callout_handle);
- // Callouts decided to skip this step. This means that no
- // subnet will be selected. Packet processing will continue,
- // but it will be severely limited (i.e. only global options
- // will be assigned)
- if (callout_handle->getStatus() == CalloutHandle::NEXT_STEP_SKIP) {
- LOG_DEBUG(hooks_logger, DBG_DHCP6_HOOKS, DHCP6_HOOK_SUBNET6_SELECT_SKIP)
- .arg(question->getLabel());
- return (Subnet6Ptr());
- }
- /// @todo: Add support for DROP status.
- // Use whatever subnet was specified by the callout
- callout_handle->getArgument("subnet6", subnet);
- }
- if (subnet) {
- // Log at higher debug level that subnet has been found.
- LOG_DEBUG(packet6_logger, DBG_DHCP6_BASIC_DATA, DHCP6_SUBNET_SELECTED)
- .arg(question->getLabel())
- .arg(subnet->getID());
- // Log detailed information about the selected subnet at the
- // lower debug level.
- LOG_DEBUG(packet6_logger, DBG_DHCP6_DETAIL_DATA, DHCP6_SUBNET_DATA)
- .arg(question->getLabel())
- .arg(subnet->toText());
- } else {
- LOG_DEBUG(packet6_logger, DBG_DHCP6_DETAIL, DHCP6_SUBNET_SELECTION_FAILED)
- .arg(question->getLabel());
- }
- return (subnet);
- }
- void
- Dhcpv6Srv::assignLeases(const Pkt6Ptr& question, Pkt6Ptr& answer,
- AllocEngine::ClientContext6& ctx) {
- // We need to allocate addresses for all IA_NA options in the client's
- // question (i.e. SOLICIT or REQUEST) message.
- // @todo add support for IA_TA
- // For the lease allocation it is critical that the client has sent
- // DUID. There is no need to check for the presence of the DUID here
- // because we have already checked it in the sanityCheck().
- // Now that we have all information about the client, let's iterate over all
- // received options and handle IA_NA options one by one and store our
- // responses in answer message (ADVERTISE or REPLY).
- //
- // @todo: IA_TA once we implement support for temporary addresses.
- for (OptionCollection::iterator opt = question->options_.begin();
- opt != question->options_.end(); ++opt) {
- switch (opt->second->getType()) {
- case D6O_IA_NA: {
- OptionPtr answer_opt = assignIA_NA(question, answer, ctx,
- boost::dynamic_pointer_cast<
- Option6IA>(opt->second));
- if (answer_opt) {
- answer->addOption(answer_opt);
- }
- break;
- }
- case D6O_IA_PD: {
- OptionPtr answer_opt = assignIA_PD(question, answer, ctx,
- boost::dynamic_pointer_cast<
- Option6IA>(opt->second));
- if (answer_opt) {
- answer->addOption(answer_opt);
- }
- }
- default:
- break;
- }
- }
- }
- void
- Dhcpv6Srv::processClientFqdn(const Pkt6Ptr& question, const Pkt6Ptr& answer,
- AllocEngine::ClientContext6& ctx) {
- D2ClientMgr& d2_mgr = CfgMgr::instance().getD2ClientMgr();
- // Get Client FQDN Option from the client's message. If this option hasn't
- // been included, do nothing.
- Option6ClientFqdnPtr fqdn = boost::dynamic_pointer_cast<
- Option6ClientFqdn>(question->getOption(D6O_CLIENT_FQDN));
- if (!fqdn) {
- D2ClientConfig::ReplaceClientNameMode replace_name_mode =
- d2_mgr.getD2ClientConfig()->getReplaceClientNameMode();
- if (d2_mgr.ddnsEnabled() &&
- (replace_name_mode == D2ClientConfig::RCM_ALWAYS ||
- replace_name_mode == D2ClientConfig::RCM_WHEN_NOT_PRESENT)) {
- // Fabricate an empty "client" FQDN with flags requesting
- // the server do all the updates. The flags will get modified
- // below according the configuration options, the name will
- // be supplied later on.
- fqdn.reset(new Option6ClientFqdn(Option6ClientFqdn::FLAG_S, "",
- Option6ClientFqdn::PARTIAL));
- LOG_DEBUG(ddns6_logger, DBG_DHCP6_DETAIL, DHCP6_DDNS_GENERATE_FQDN)
- .arg(question->getLabel());
- } else {
- // No FQDN so get the lease hostname from the host reservation if
- // there is one.
- if (ctx.host_) {
- ctx.hostname_ = ctx.host_->getHostname();
- }
- return;
- }
- }
- LOG_DEBUG(ddns6_logger, DBG_DHCP6_DETAIL, DHCP6_DDNS_RECEIVE_FQDN)
- .arg(question->getLabel())
- .arg(fqdn->toText());
- // Create the DHCPv6 Client FQDN Option to be included in the server's
- // response to a client.
- Option6ClientFqdnPtr fqdn_resp(new Option6ClientFqdn(*fqdn));
- // Set the server S, N, and O flags based on client's flags and
- // current configuration.
- d2_mgr.adjustFqdnFlags<Option6ClientFqdn>(*fqdn, *fqdn_resp);
- // If there's a reservation and it has a hostname specified, use it!
- if (ctx.host_ && !ctx.host_->getHostname().empty()) {
- // Add the qualifying suffix.
- // After #3765, this will only occur if the suffix is not empty.
- fqdn_resp->setDomainName(d2_mgr.qualifyName(ctx.host_->getHostname(),
- true),
- Option6ClientFqdn::FULL);
- } else {
- // Adjust the domain name based on domain name value and type sent by
- // the client and current configuration.
- d2_mgr.adjustDomainName<Option6ClientFqdn>(*fqdn, *fqdn_resp);
- }
- // Once we have the FQDN setup to use it for the lease hostname. This
- // only gets replaced later if the FQDN is to be generated from the address.
- ctx.hostname_ = fqdn_resp->getDomainName();
- // The FQDN has been processed successfully. Let's append it to the
- // response to be sent to a client. Note that the Client FQDN option is
- // always sent back to the client if Client FQDN was included in the
- // client's message.
- LOG_DEBUG(ddns6_logger, DBG_DHCP6_DETAIL, DHCP6_DDNS_RESPONSE_FQDN_DATA)
- .arg(question->getLabel())
- .arg(fqdn_resp->toText());
- answer->addOption(fqdn_resp);
- }
- void
- Dhcpv6Srv::createNameChangeRequests(const Pkt6Ptr& answer,
- AllocEngine::ClientContext6& ctx) {
- // Don't create NameChangeRequests if DNS updates are disabled.
- if (!CfgMgr::instance().ddnsEnabled()) {
- return;
- }
- // The response message instance is always required. For instance it
- // holds the Client Identifier. It is a programming error if supplied
- // message is NULL.
- if (!answer) {
- isc_throw(isc::Unexpected, "an instance of the object"
- << " encapsulating server's message must not be"
- << " NULL when creating DNS NameChangeRequest");
- }
- // It is likely that client haven't included the FQDN option. In such case,
- // FQDN option will be NULL. This is valid state, so we simply return.
- Option6ClientFqdnPtr opt_fqdn = boost::dynamic_pointer_cast<
- Option6ClientFqdn>(answer->getOption(D6O_CLIENT_FQDN));
- if (!opt_fqdn) {
- return;
- }
- // Get the update directions that should be performed based on our
- // response FQDN flags.
- bool do_fwd = false;
- bool do_rev = false;
- CfgMgr::instance().getD2ClientMgr().getUpdateDirections(*opt_fqdn,
- do_fwd, do_rev);
- if (!do_fwd && !do_rev) {
- // Flags indicate there is Nothing to do, get out now.
- // The Most likely scenario is that we are honoring the client's
- // request that no updates be done.
- return;
- }
- // Get the Client Id. It is mandatory and a function creating a response
- // would have thrown an exception if it was missing. Thus throwing
- // Unexpected if it is missing as it is a programming error.
- OptionPtr opt_duid = answer->getOption(D6O_CLIENTID);
- if (!opt_duid) {
- isc_throw(isc::Unexpected,
- "client identifier is required when creating a new"
- " DNS NameChangeRequest");
- }
- DuidPtr duid = DuidPtr(new DUID(opt_duid->getData()));
- // Get the FQDN in the on-wire format. It will be needed to compute
- // DHCID.
- OutputBuffer name_buf(1);
- opt_fqdn->packDomainName(name_buf);
- const uint8_t* name_data = static_cast<const uint8_t*>(name_buf.getData());
- // @todo currently D2Dhcid accepts a vector holding FQDN.
- // However, it will be faster if we used a pointer name_data.
- std::vector<uint8_t> buf_vec(name_data, name_data + name_buf.getLength());
- // Compute DHCID from Client Identifier and FQDN.
- isc::dhcp_ddns::D2Dhcid dhcid(*duid, buf_vec);
- // Get all IAs from the answer. For each IA, holding an address we will
- // create a corresponding NameChangeRequest.
- OptionCollection answer_ias = answer->getOptions(D6O_IA_NA);
- for (OptionCollection::const_iterator answer_ia =
- answer_ias.begin(); answer_ia != answer_ias.end(); ++answer_ia) {
- /// @todo IA_NA may contain multiple addresses. We should process
- /// each address individually. Currently we get only one.
- Option6IAAddrPtr iaaddr = boost::static_pointer_cast<
- Option6IAAddr>(answer_ia->second->getOption(D6O_IAADDR));
- // We need an address to create a name-to-address mapping.
- // If address is missing for any reason, go to the next IA.
- if (!iaaddr) {
- continue;
- }
- // If the lease for iaaddr is in the list of changed leases, we need
- // to determine if the changes included changes to the FQDN. If there
- // were changes to the FQDN then we need to update DNS, otherwise
- // we do not.
- bool extended_only = false;
- for (Lease6Collection::const_iterator l = ctx.currentIA().changed_leases_.begin();
- l != ctx.currentIA().changed_leases_.end(); ++l) {
- if ((*l)->addr_ == iaaddr->getAddress()) {
- if ((*l)->hostname_ == opt_fqdn->getDomainName() &&
- (*l)->fqdn_fwd_ == do_fwd && (*l)->fqdn_rev_ == do_rev) {
- extended_only = true;
- break;
- }
- }
- }
- if (extended_only) {
- continue;
- }
- // Create new NameChangeRequest. Use the domain name from the FQDN.
- // This is an FQDN included in the response to the client, so it
- // holds a fully qualified domain-name already (not partial).
- // Get the IP address from the lease.
- NameChangeRequestPtr ncr;
- ncr.reset(new NameChangeRequest(isc::dhcp_ddns::CHG_ADD,
- do_fwd, do_rev,
- opt_fqdn->getDomainName(),
- iaaddr->getAddress().toText(),
- dhcid, 0, iaaddr->getValid()));
- LOG_DEBUG(ddns6_logger, DBG_DHCP6_DETAIL,
- DHCP6_DDNS_CREATE_ADD_NAME_CHANGE_REQUEST).arg(ncr->toText());
- // Post the NCR to the D2ClientMgr.
- CfgMgr::instance().getD2ClientMgr().sendRequest(ncr);
- /// @todo Currently we create NCR with the first IPv6 address that
- /// is carried in one of the IA_NAs. In the future, the NCR API should
- /// be extended to map multiple IPv6 addresses to a single FQDN.
- /// In such case, this return statement will be removed.
- return;
- }
- }
- HWAddrPtr
- Dhcpv6Srv::getMAC(const Pkt6Ptr& pkt) {
- CfgMACSources mac_sources = CfgMgr::instance().getCurrentCfg()->
- getMACSources().get();
- HWAddrPtr hwaddr;
- for (CfgMACSources::const_iterator it = mac_sources.begin();
- it != mac_sources.end(); ++it) {
- hwaddr = pkt->getMAC(*it);
- if (hwaddr) {
- return (hwaddr);
- }
- }
- return (hwaddr);
- }
- OptionPtr
- Dhcpv6Srv::assignIA_NA(const Pkt6Ptr& query, const Pkt6Ptr& answer,
- AllocEngine::ClientContext6& ctx,
- boost::shared_ptr<Option6IA> ia) {
- // Check if the client sent us a hint in his IA_NA. Clients may send an
- // address in their IA_NA options as a suggestion (e.g. the last address
- // they used before).
- Option6IAAddrPtr hint_opt =
- boost::dynamic_pointer_cast<Option6IAAddr>(ia->getOption(D6O_IAADDR));
- IOAddress hint = IOAddress::IPV6_ZERO_ADDRESS();
- if (hint_opt) {
- hint = hint_opt->getAddress();
- }
- LOG_DEBUG(lease6_logger, DBG_DHCP6_DETAIL, DHCP6_PROCESS_IA_NA_REQUEST)
- .arg(query->getLabel())
- .arg(ia->getIAID())
- .arg(hint_opt ? hint.toText() : "(no hint)");
- // convenience values
- const Subnet6Ptr& subnet = ctx.subnet_;
- // If there is no subnet selected for handling this IA_NA, the only thing left to do is
- // to say that we are sorry, but the user won't get an address. As a convenience, we
- // use a different status text to indicate that (compare to the same status code,
- // but different wording below)
- if (!subnet) {
- // Create an empty IA_NA option with IAID matching the request.
- // Note that we don't use OptionDefinition class to create this option.
- // This is because we prefer using a constructor of Option6IA that
- // initializes IAID. Otherwise we would have to use setIAID() after
- // creation of the option which has some performance implications.
- boost::shared_ptr<Option6IA> ia_rsp(new Option6IA(D6O_IA_NA, ia->getIAID()));
- // Insert status code NoAddrsAvail.
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoAddrsAvail,
- "Server could not select subnet for"
- " this client"));
- return (ia_rsp);
- }
- // "Fake" allocation is the case when the server is processing the Solicit
- // message without the Rapid Commit option and advertises a lease to
- // the client, but doesn't commit this lease to the lease database. If
- // the Solicit contains the Rapid Commit option and the server is
- // configured to honor the Rapid Commit option, or the client has sent
- // the Request message, the lease will be committed to the lease
- // database. The type of the server's response may be used to determine
- // if this is the fake allocation case or not. When the server sends
- // Reply message it means that it is committing leases. Other message
- // type (Advertise) means that server is not committing leases (fake
- // allocation).
- bool fake_allocation = (answer->getType() != DHCPV6_REPLY);
- // Get DDNS update direction flags
- bool do_fwd = false;
- bool do_rev = false;
- Option6ClientFqdnPtr fqdn = boost::dynamic_pointer_cast<
- Option6ClientFqdn>(answer->getOption(D6O_CLIENT_FQDN));
- if (fqdn) {
- CfgMgr::instance().getD2ClientMgr().getUpdateDirections(*fqdn, do_fwd,
- do_rev);
- }
- // Update per-packet context values.
- ctx.fwd_dns_update_ = do_fwd;
- ctx.rev_dns_update_ = do_rev;
- ctx.fake_allocation_ = fake_allocation;
- // Set per-IA context values.
- ctx.createIAContext();
- ctx.currentIA().iaid_ = ia->getIAID();
- ctx.currentIA().addHint(hint);
- ctx.currentIA().type_ = Lease::TYPE_NA;
- // Use allocation engine to pick a lease for this client. Allocation engine
- // will try to honor the hint, but it is just a hint - some other address
- // may be used instead. If fake_allocation is set to false, the lease will
- // be inserted into the LeaseMgr as well.
- Lease6Collection leases = alloc_engine_->allocateLeases6(ctx);
- /// @todo: Handle more than one lease
- Lease6Ptr lease;
- if (!leases.empty()) {
- lease = *leases.begin();
- }
- // Create IA_NA that we will put in the response.
- // Do not use OptionDefinition to create option's instance so
- // as we can initialize IAID using a constructor.
- Option6IAPtr ia_rsp(new Option6IA(D6O_IA_NA, ia->getIAID()));
- if (lease) {
- // We have a lease! Let's wrap its content into IA_NA option
- // with IAADDR suboption.
- LOG_INFO(lease6_logger, fake_allocation ? DHCP6_LEASE_ADVERT : DHCP6_LEASE_ALLOC)
- .arg(query->getLabel())
- .arg(lease->addr_.toText())
- .arg(ia->getIAID());
- LOG_DEBUG(lease6_logger, DBG_DHCP6_DETAIL_DATA, DHCP6_LEASE_DATA)
- .arg(query->getLabel())
- .arg(ia->getIAID())
- .arg(lease->toText());
- ia_rsp->setT1(subnet->getT1());
- ia_rsp->setT2(subnet->getT2());
- Option6IAAddrPtr addr(new Option6IAAddr(D6O_IAADDR, lease->addr_,
- lease->preferred_lft_,
- lease->valid_lft_));
- ia_rsp->addOption(addr);
- // It would be possible to insert status code=0(success) as well,
- // but this is considered waste of bandwidth as absence of status
- // code is considered a success.
- } else {
- // Allocation engine did not allocate a lease. The engine logged
- // cause of that failure. The only thing left is to insert
- // status code to pass the sad news to the client.
- LOG_DEBUG(lease6_logger, DBG_DHCP6_DETAIL, fake_allocation ?
- DHCP6_LEASE_ADVERT_FAIL : DHCP6_LEASE_ALLOC_FAIL)
- .arg(query->getLabel())
- .arg(ia->getIAID());
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp,
- STATUS_NoAddrsAvail,
- "Sorry, no address could be"
- " allocated."));
- }
- return (ia_rsp);
- }
- OptionPtr
- Dhcpv6Srv::assignIA_PD(const Pkt6Ptr& query, const Pkt6Ptr& answer,
- AllocEngine::ClientContext6& ctx,
- boost::shared_ptr<Option6IA> ia) {
- // Check if the client sent us a hint in his IA_PD. Clients may send an
- // address in their IA_PD options as a suggestion (e.g. the last address
- // they used before). While the hint consists of a full prefix (prefix +
- // length), getting just the prefix is sufficient to identify a lease.
- Option6IAPrefixPtr hint_opt =
- boost::dynamic_pointer_cast<Option6IAPrefix>(ia->getOption(D6O_IAPREFIX));
- IOAddress hint = IOAddress::IPV6_ZERO_ADDRESS();
- if (hint_opt) {
- hint = hint_opt->getAddress();
- }
- LOG_DEBUG(lease6_logger, DBG_DHCP6_DETAIL, DHCP6_PROCESS_IA_PD_REQUEST)
- .arg(query->getLabel())
- .arg(ia->getIAID())
- .arg(hint_opt ? hint.toText() : "(no hint)");
- const Subnet6Ptr& subnet = ctx.subnet_;
- // Create IA_PD that we will put in the response.
- // Do not use OptionDefinition to create option's instance so
- // as we can initialize IAID using a constructor.
- boost::shared_ptr<Option6IA> ia_rsp(new Option6IA(D6O_IA_PD, ia->getIAID()));
- // If there is no subnet selected for handling this IA_PD, the only thing
- // left to do is to say that we are sorry, but the user won't get an address.
- // As a convenience, we use a different status text to indicate that
- // (compare to the same status code, but different wording below)
- if (!subnet) {
- // Insert status code NoAddrsAvail.
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoPrefixAvail,
- "Sorry, no subnet available."));
- return (ia_rsp);
- }
- // "Fake" allocation is the case when the server is processing the Solicit
- // message without the Rapid Commit option and advertises a lease to
- // the client, but doesn't commit this lease to the lease database. If
- // the Solicit contains the Rapid Commit option and the server is
- // configured to honor the Rapid Commit option, or the client has sent
- // the Request message, the lease will be committed to the lease
- // database. The type of the server's response may be used to determine
- // if this is the fake allocation case or not. When the server sends
- // Reply message it means that it is committing leases. Other message
- // type (Advertise) means that server is not committing leases (fake
- // allocation).
- ctx.fake_allocation_ = (answer->getType() != DHCPV6_REPLY);
- // Set per-IA context values.
- ctx.createIAContext();
- ctx.currentIA().iaid_ = ia->getIAID();
- ctx.currentIA().addHint(hint);
- ctx.currentIA().type_ = Lease::TYPE_PD;
- // Use allocation engine to pick a lease for this client. Allocation engine
- // will try to honor the hint, but it is just a hint - some other address
- // may be used instead. If fake_allocation is set to false, the lease will
- // be inserted into the LeaseMgr as well.
- Lease6Collection leases = alloc_engine_->allocateLeases6(ctx);
- if (!leases.empty()) {
- ia_rsp->setT1(subnet->getT1());
- ia_rsp->setT2(subnet->getT2());
- for (Lease6Collection::iterator l = leases.begin();
- l != leases.end(); ++l) {
- // We have a lease! Let's wrap its content into IA_PD option
- // with IAADDR suboption.
- LOG_INFO(lease6_logger, ctx.fake_allocation_ ?
- DHCP6_PD_LEASE_ADVERT : DHCP6_PD_LEASE_ALLOC)
- .arg(query->getLabel())
- .arg((*l)->addr_.toText())
- .arg(static_cast<int>((*l)->prefixlen_))
- .arg(ia->getIAID());
- boost::shared_ptr<Option6IAPrefix>
- addr(new Option6IAPrefix(D6O_IAPREFIX, (*l)->addr_,
- (*l)->prefixlen_, (*l)->preferred_lft_,
- (*l)->valid_lft_));
- ia_rsp->addOption(addr);
- }
- // It would be possible to insert status code=0(success) as well,
- // but this is considered waste of bandwidth as absence of status
- // code is considered a success.
- } else {
- // Allocation engine did not allocate a lease. The engine logged
- // cause of that failure. The only thing left is to insert
- // status code to pass the sad news to the client.
- LOG_DEBUG(lease6_logger, DBG_DHCP6_DETAIL, ctx.fake_allocation_ ?
- DHCP6_PD_LEASE_ADVERT_FAIL : DHCP6_PD_LEASE_ALLOC_FAIL)
- .arg(query->getLabel())
- .arg(ia->getIAID());
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp,
- STATUS_NoPrefixAvail,
- "Sorry, no prefixes could"
- " be allocated."));
- }
- return (ia_rsp);
- }
- OptionPtr
- Dhcpv6Srv::extendIA_NA(const Pkt6Ptr& query, const Pkt6Ptr& answer,
- AllocEngine::ClientContext6& ctx,
- boost::shared_ptr<Option6IA> ia) {
- LOG_DEBUG(lease6_logger, DBG_DHCP6_DETAIL, DHCP6_PROCESS_IA_NA_EXTEND)
- .arg(query->getLabel())
- .arg(ia->getIAID());
- // convenience values
- const Subnet6Ptr& subnet = ctx.subnet_;
- // Create empty IA_NA option with IAID matching the request.
- Option6IAPtr ia_rsp(new Option6IA(D6O_IA_NA, ia->getIAID()));
- if (!subnet) {
- /// @todo For simplicity and due to limitations of LeaseMgr we don't
- /// get the binding for the client for which we don't get subnet id.
- /// Subnet id is a required value when searching for the bindings.
- /// The fact that we can't identify the subnet for the returning client
- /// doesn't really mean that the client has no binding. It is possible
- /// that due to server's reconfiguration the subnet has been removed
- /// or modified since the client has got his lease. We may need to
- /// rethink whether it is appropriate to send no binding if the subnet
- /// hasn't been found for the client.
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoBinding,
- "Sorry, no known leases for this duid/iaid."));
- return (ia_rsp);
- }
- // Set up T1, T2 timers
- ia_rsp->setT1(subnet->getT1());
- ia_rsp->setT2(subnet->getT2());
- // Get DDNS udpate directions
- bool do_fwd = false;
- bool do_rev = false;
- Option6ClientFqdnPtr fqdn = boost::dynamic_pointer_cast<
- Option6ClientFqdn>(answer->getOption(D6O_CLIENT_FQDN));
- if (fqdn) {
- CfgMgr::instance().getD2ClientMgr().getUpdateDirections(*fqdn,
- do_fwd, do_rev);
- }
- // Set per-packet context values.
- ctx.fwd_dns_update_ = do_fwd;
- ctx.rev_dns_update_ = do_rev;
- // Set per-IA context values.
- ctx.createIAContext();
- ctx.currentIA().iaid_ = ia->getIAID();
- ctx.currentIA().type_ = Lease::TYPE_NA;
- ctx.currentIA().ia_rsp_ = ia_rsp;
- // Extract the addresses that the client is trying to obtain.
- OptionCollection addrs = ia->getOptions();
- for (OptionCollection::const_iterator it = addrs.begin();
- it != addrs.end(); ++it) {
- if (it->second->getType() != D6O_IAADDR) {
- continue;
- }
- Option6IAAddrPtr iaaddr = boost::dynamic_pointer_cast<Option6IAAddr>(it->second);
- if (!iaaddr) {
- // That's weird. Option code was ok, but the object type was not.
- // This should never happen. The only case would be with badly
- // mis-implemented hook libraries that insert invalid option objects.
- // There's no way to protect against this.
- continue;
- }
- ctx.currentIA().addHint(iaaddr->getAddress());
- }
- Lease6Collection leases = alloc_engine_->renewLeases6(ctx);
- // Ok, now we have the leases extended. We have:
- // - what the client tried to renew in ctx.hints_
- // - what we actually assigned in leases
- // - old leases that are no longer valid in ctx.old_leases_
- // For each IA inserted by the client we have to determine what to do
- // about included addresses and notify the client. We will iterate over
- // those prefixes and remove those that we have already processed. We
- // don't want to remove them from the context, so we need to copy them
- // into temporary container.
- AllocEngine::HintContainer hints = ctx.currentIA().hints_;
- // For all leases we have now, add the IAADDR with non-zero lifetimes.
- for (Lease6Collection::const_iterator l = leases.begin(); l != leases.end(); ++l) {
- Option6IAAddrPtr iaaddr(new Option6IAAddr(D6O_IAADDR,
- (*l)->addr_, (*l)->preferred_lft_, (*l)->valid_lft_));
- ia_rsp->addOption(iaaddr);
- LOG_INFO(lease6_logger, DHCP6_LEASE_RENEW)
- .arg(query->getLabel())
- .arg((*l)->addr_.toText())
- .arg(ia_rsp->getIAID());
- // Now remove this address from the hints list.
- AllocEngine::ResourceType hint_type((*l)->addr_, 128);
- hints.erase(std::remove(hints.begin(), hints.end(), hint_type),
- hints.end());
- }
- // For the leases that we just retired, send the addresses with 0 lifetimes.
- for (Lease6Collection::const_iterator l = ctx.currentIA().old_leases_.begin();
- l != ctx.currentIA().old_leases_.end(); ++l) {
- Option6IAAddrPtr iaaddr(new Option6IAAddr(D6O_IAADDR,
- (*l)->addr_, 0, 0));
- ia_rsp->addOption(iaaddr);
- // Now remove this address from the hints list.
- AllocEngine::ResourceType hint_type((*l)->addr_, 128);
- hints.erase(std::remove(hints.begin(), hints.end(), hint_type), hints.end());
- // If the new FQDN settings have changed for the lease, we need to
- // delete any existing FQDN records for this lease.
- if (((*l)->hostname_ != ctx.hostname_) || ((*l)->fqdn_fwd_ != do_fwd) ||
- ((*l)->fqdn_rev_ != do_rev)) {
- LOG_DEBUG(ddns6_logger, DBG_DHCP6_DETAIL,
- DHCP6_DDNS_LEASE_RENEW_FQDN_CHANGE)
- .arg(query->getLabel())
- .arg((*l)->toText())
- .arg(ctx.hostname_)
- .arg(do_rev ? "true" : "false")
- .arg(do_fwd ? "true" : "false");
- queueNCR(CHG_REMOVE, *l);
- }
- }
- // Finally, if there are any addresses requested that we haven't dealt with
- // already, inform the client that he can't have them.
- for (AllocEngine::HintContainer::const_iterator hint = hints.begin();
- hint != hints.end(); ++hint) {
- Option6IAAddrPtr iaaddr(new Option6IAAddr(D6O_IAADDR,
- hint->first, 0, 0));
- ia_rsp->addOption(iaaddr);
- }
- // All is left is to insert the status code.
- if (leases.empty()) {
- // The server wasn't able allocate new lease and renew an exising
- // lease. In that case, the server sends NoAddrsAvail per RFC7550.
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp,
- STATUS_NoAddrsAvail,
- "Sorry, no addresses could be"
- " assigned at this time."));
- }
- return (ia_rsp);
- }
- OptionPtr
- Dhcpv6Srv::extendIA_PD(const Pkt6Ptr& query,
- AllocEngine::ClientContext6& ctx,
- boost::shared_ptr<Option6IA> ia) {
- LOG_DEBUG(lease6_logger, DBG_DHCP6_DETAIL, DHCP6_PROCESS_IA_PD_EXTEND)
- .arg(query->getLabel())
- .arg(ia->getIAID());
- const Subnet6Ptr& subnet = ctx.subnet_;
- const DuidPtr& duid = ctx.duid_;
- // Let's create a IA_PD response and fill it in later
- Option6IAPtr ia_rsp(new Option6IA(D6O_IA_PD, ia->getIAID()));
- // If there is no subnet for the particular client, we can't retrieve
- // information about client's leases from lease database. We treat this
- // as no binding for the client.
- if (!subnet) {
- // Per RFC3633, section 12.2, if there is no binding and we are
- // processing a Renew, the NoBinding status code should be returned.
- if (query->getType() == DHCPV6_RENEW) {
- // Insert status code NoBinding
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoBinding,
- "Sorry, no known PD leases"
- " for this duid/iaid."));
- return (ia_rsp);
- // Per RFC3633, section 12.2, if there is no binding and we are
- // processing Rebind, the message has to be discarded (assuming that
- // the server doesn't know if the prefix in the IA_PD option is
- // appropriate for the client's link). The exception being thrown
- // here should propagate to the main loop and cause the message to
- // be discarded.
- } else {
- /// @todo: RFC3315bis will probably change that behavior. Client
- /// may rebind prefixes and addresses at the same time.
- isc_throw(DHCPv6DiscardMessageError, "no subnet found for the"
- " client sending Rebind to extend lifetime of the"
- " prefix (DUID=" << duid->toText() << ", IAID="
- << ia->getIAID() << ")");
- }
- }
- // Set up T1, T2 timers
- ia_rsp->setT1(subnet->getT1());
- ia_rsp->setT2(subnet->getT2());
- // Set per-IA context values.
- ctx.createIAContext();
- ctx.currentIA().iaid_ = ia->getIAID();
- ctx.currentIA().type_ = Lease::TYPE_PD;
- ctx.currentIA().ia_rsp_ = ia_rsp;
- // Extract prefixes that the client is trying to renew.
- OptionCollection addrs = ia->getOptions();
- for (OptionCollection::const_iterator it = addrs.begin();
- it != addrs.end(); ++it) {
- if (it->second->getType() != D6O_IAPREFIX) {
- continue;
- }
- Option6IAPrefixPtr prf = boost::dynamic_pointer_cast<Option6IAPrefix>(it->second);
- if (!prf) {
- // That's weird. Option code was ok, but the object type was not.
- // This should never happen. The only case would be with badly
- // mis-implemented hook libraries that insert invalid option objects.
- // There's no way to protect against this.
- continue;
- }
- // Put the client's prefix into the hints list.
- ctx.currentIA().addHint(prf->getAddress(), prf->getLength());
- }
- // Call Allocation Engine and attempt to renew leases. Number of things
- // may happen. Leases may be extended, revoked (if the lease is no longer
- // valid or reserved for someone else), or new leases may be added.
- // Important parameters are:
- // - returned container - current valid leases
- // - old_leases - leases that used to be, but are no longer valid
- // - changed_leases - leases that have FQDN changed (not really important
- // in PD context)
- Lease6Collection leases = alloc_engine_->renewLeases6(ctx);
- // For each IA inserted by the client we have to determine what to do
- // about included prefixes and notify the client. We will iterate over
- // those prefixes and remove those that we have already processed. We
- // don't want to remove them from the context, so we need to copy them
- // into temporary container.
- AllocEngine::HintContainer hints = ctx.currentIA().hints_;
- // For all the leases we have now, add the IAPPREFIX with non-zero lifetimes
- for (Lease6Collection::const_iterator l = leases.begin(); l != leases.end(); ++l) {
- Option6IAPrefixPtr prf(new Option6IAPrefix(D6O_IAPREFIX,
- (*l)->addr_, (*l)->prefixlen_,
- (*l)->preferred_lft_, (*l)->valid_lft_));
- ia_rsp->addOption(prf);
- LOG_INFO(lease6_logger, DHCP6_PD_LEASE_RENEW)
- .arg(query->getLabel())
- .arg((*l)->addr_.toText())
- .arg(static_cast<int>((*l)->prefixlen_))
- .arg(ia->getIAID());
- // Now remove this address from the hints list.
- AllocEngine::ResourceType hint_type((*l)->addr_, (*l)->prefixlen_);
- hints.erase(std::remove(hints.begin(), hints.end(), hint_type),
- hints.end());
- }
- /// @todo: Maybe we should iterate over ctx.old_leases_, i.e. the leases
- /// that used to be valid, but they are not anymore.
- // For all the leases the client had requested, but we didn't assign, put them with
- // zero lifetimes
- // Finally, if there are any addresses requested that we haven't dealt with
- // already, inform the client that he can't have them.
- for (AllocEngine::HintContainer::const_iterator prefix = hints.begin();
- prefix != hints.end(); ++prefix) {
- // Send the prefix with the zero lifetimes only if the prefix
- // contains non-zero value. A zero value indicates that the hint was
- // for the prefix length.
- if (!prefix->first.isV6Zero()) {
- OptionPtr prefix_opt(new Option6IAPrefix(D6O_IAPREFIX, prefix->first,
- prefix->second, 0, 0));
- ia_rsp->addOption(prefix_opt);
- }
- }
- // All is left is to insert the status code.
- if (leases.empty()) {
- // The server wasn't able allocate new lease and renew an exising
- // lease. In that case, the server sends NoPrefixAvail per RFC7550.
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp,
- STATUS_NoPrefixAvail,
- "Sorry, no prefixes could be"
- " assigned at this time."));
- }
- return (ia_rsp);
- }
- void
- Dhcpv6Srv::extendLeases(const Pkt6Ptr& query, Pkt6Ptr& reply,
- AllocEngine::ClientContext6& ctx) {
- // We will try to extend lease lifetime for all IA options in the client's
- // Renew or Rebind message.
- /// @todo add support for IA_TA
- // For the lease extension it is critical that the client has sent
- // DUID. There is no need to check for the presence of the DUID here
- // because we have already checked it in the sanityCheck().
- for (OptionCollection::iterator opt = query->options_.begin();
- opt != query->options_.end(); ++opt) {
- switch (opt->second->getType()) {
- case D6O_IA_NA: {
- OptionPtr answer_opt = extendIA_NA(query, reply, ctx,
- boost::dynamic_pointer_cast<
- Option6IA>(opt->second));
- if (answer_opt) {
- reply->addOption(answer_opt);
- }
- break;
- }
- case D6O_IA_PD: {
- OptionPtr answer_opt = extendIA_PD(query, ctx,
- boost::dynamic_pointer_cast<
- Option6IA>(opt->second));
- if (answer_opt) {
- reply->addOption(answer_opt);
- }
- break;
- }
- default:
- break;
- }
- }
- }
- void
- Dhcpv6Srv::releaseLeases(const Pkt6Ptr& release, Pkt6Ptr& reply,
- AllocEngine::ClientContext6& ctx) {
- // We need to release addresses for all IA_NA options in the client's
- // RELEASE message.
- // @todo Add support for IA_TA
- // @todo Add support for IA_PD
- // @todo Consider supporting more than one address in a single IA_NA.
- // That was envisaged by RFC3315, but it never happened. The only
- // software that supports that is Dibbler, but its author seriously doubts
- // if anyone is really using it. Clients that want more than one address
- // just include more instances of IA_NA options.
- // Let's set the status to be success by default. We can override it with
- // error status if needed. The important thing to understand here is that
- // the global status code may be set to success only if all IA options were
- // handled properly. Therefore the releaseIA_NA and releaseIA_PD options
- // may turn the status code to some error, but can't turn it back to success.
- int general_status = STATUS_Success;
- for (OptionCollection::iterator opt = release->options_.begin();
- opt != release->options_.end(); ++opt) {
- switch (opt->second->getType()) {
- case D6O_IA_NA: {
- OptionPtr answer_opt = releaseIA_NA(ctx.duid_, release, general_status,
- boost::dynamic_pointer_cast<Option6IA>(opt->second));
- if (answer_opt) {
- reply->addOption(answer_opt);
- }
- break;
- }
- case D6O_IA_PD: {
- OptionPtr answer_opt = releaseIA_PD(ctx.duid_, release, general_status,
- boost::dynamic_pointer_cast<Option6IA>(opt->second));
- if (answer_opt) {
- reply->addOption(answer_opt);
- }
- break;
- }
- // @todo: add support for IA_TA
- default:
- // remaining options are stateless and thus ignored in this context
- ;
- }
- }
- // To be pedantic, we should also include status code in the top-level
- // scope, not just in each IA_NA. See RFC3315, section 18.2.6.
- // This behavior will likely go away in RFC3315bis.
- reply->addOption(createStatusCode(*release, general_status,
- "Summary status for all processed IA_NAs"));
- }
- OptionPtr
- Dhcpv6Srv::releaseIA_NA(const DuidPtr& duid, const Pkt6Ptr& query,
- int& general_status, boost::shared_ptr<Option6IA> ia) {
- LOG_DEBUG(lease6_logger, DBG_DHCP6_DETAIL, DHCP6_PROCESS_IA_NA_RELEASE)
- .arg(query->getLabel())
- .arg(ia->getIAID());
- // Release can be done in one of two ways:
- // Approach 1: extract address from client's IA_NA and see if it belongs
- // to this particular client.
- // Approach 2: find a subnet for this client, get a lease for
- // this subnet/duid/iaid and check if its content matches to what the
- // client is asking us to release.
- //
- // This method implements approach 1.
- // That's our response
- boost::shared_ptr<Option6IA> ia_rsp(new Option6IA(D6O_IA_NA, ia->getIAID()));
- Option6IAAddrPtr release_addr = boost::dynamic_pointer_cast<Option6IAAddr>
- (ia->getOption(D6O_IAADDR));
- if (!release_addr) {
- ia_rsp->addOption(createStatusCode(*query, STATUS_NoBinding,
- "You did not include an address in your RELEASE"));
- general_status = STATUS_NoBinding;
- return (ia_rsp);
- }
- Lease6Ptr lease = LeaseMgrFactory::instance().getLease6(Lease::TYPE_NA,
- release_addr->getAddress());
- if (!lease) {
- // client releasing a lease that we don't know about.
- // Insert status code NoBinding.
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoBinding,
- "Sorry, no known leases for this duid/iaid, can't release."));
- general_status = STATUS_NoBinding;
- return (ia_rsp);
- }
- if (!lease->duid_) {
- // Something is gravely wrong here. We do have a lease, but it does not
- // have mandatory DUID information attached. Someone was messing with our
- // database.
- LOG_ERROR(lease6_logger, DHCP6_LEASE_NA_WITHOUT_DUID)
- .arg(query->getLabel())
- .arg(release_addr->getAddress().toText());
- general_status = STATUS_UnspecFail;
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_UnspecFail,
- "Database consistency check failed when trying to RELEASE"));
- return (ia_rsp);
- }
- if (*duid != *(lease->duid_)) {
- // Sorry, it's not your address. You can't release it.
- LOG_INFO(lease6_logger, DHCP6_RELEASE_NA_FAIL_WRONG_DUID)
- .arg(query->getLabel())
- .arg(release_addr->getAddress().toText())
- .arg(lease->duid_->toText());
- general_status = STATUS_NoBinding;
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoBinding,
- "This address does not belong to you, you can't release it"));
- return (ia_rsp);
- }
- if (ia->getIAID() != lease->iaid_) {
- // This address belongs to this client, but to a different IA
- LOG_WARN(lease6_logger, DHCP6_RELEASE_NA_FAIL_WRONG_IAID)
- .arg(query->getLabel())
- .arg(release_addr->getAddress().toText())
- .arg(lease->iaid_)
- .arg(ia->getIAID());
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoBinding,
- "This is your address, but you used wrong IAID"));
- general_status = STATUS_NoBinding;
- return (ia_rsp);
- }
- // It is not necessary to check if the address matches as we used
- // getLease6(addr) method that is supposed to return a proper lease.
- bool skip = false;
- // Execute all callouts registered for packet6_send
- if (HooksManager::calloutsPresent(Hooks.hook_index_lease6_release_)) {
- CalloutHandlePtr callout_handle = getCalloutHandle(query);
- // Enable copying options from the packet within hook library.
- ScopedEnableOptionsCopy<Pkt6> query6_options_copy(query);
- // Delete all previous arguments
- callout_handle->deleteAllArguments();
- // Pass the original packet
- callout_handle->setArgument("query6", query);
- // Pass the lease to be updated
- callout_handle->setArgument("lease6", lease);
- // Call all installed callouts
- HooksManager::callCallouts(Hooks.hook_index_lease6_release_, *callout_handle);
- // Callouts decided to skip the next processing step. The next
- // processing step would to send the packet, so skip at this
- // stage means "drop response".
- if (callout_handle->getStatus() == CalloutHandle::NEXT_STEP_SKIP) {
- skip = true;
- LOG_DEBUG(hooks_logger, DBG_DHCP6_HOOKS, DHCP6_HOOK_LEASE6_RELEASE_NA_SKIP)
- .arg(query->getLabel());
- }
- /// @todo: Add support for DROP status
- }
- // Ok, we've passed all checks. Let's release this address.
- bool success = false; // was the removal operation successful?
- if (!skip) {
- success = LeaseMgrFactory::instance().deleteLease(lease->addr_);
- }
- // Here the success should be true if we removed lease successfully
- // and false if skip flag was set or the removal failed for whatever reason
- if (!success) {
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_UnspecFail,
- "Server failed to release a lease"));
- LOG_ERROR(lease6_logger, DHCP6_RELEASE_NA_FAIL)
- .arg(query->getLabel())
- .arg(lease->addr_.toText())
- .arg(lease->iaid_);
- general_status = STATUS_UnspecFail;
- return (ia_rsp);
- } else {
- LOG_INFO(lease6_logger, DHCP6_RELEASE_NA)
- .arg(query->getLabel())
- .arg(lease->addr_.toText())
- .arg(lease->iaid_);
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_Success,
- "Lease released. Thank you, please come again."));
- // Need to decrease statistic for assigned addresses.
- StatsMgr::instance().addValue(
- StatsMgr::generateName("subnet", lease->subnet_id_, "assigned-nas"),
- static_cast<int64_t>(-1));
- // Check if a lease has flags indicating that the FQDN update has
- // been performed. If so, create NameChangeRequest which removes
- // the entries.
- queueNCR(CHG_REMOVE, lease);
- return (ia_rsp);
- }
- }
- OptionPtr
- Dhcpv6Srv::releaseIA_PD(const DuidPtr& duid, const Pkt6Ptr& query,
- int& general_status, boost::shared_ptr<Option6IA> ia) {
- // Release can be done in one of two ways:
- // Approach 1: extract address from client's IA_NA and see if it belongs
- // to this particular client.
- // Approach 2: find a subnet for this client, get a lease for
- // this subnet/duid/iaid and check if its content matches to what the
- // client is asking us to release.
- //
- // This method implements approach 1.
- // That's our response. We will fill it in as we check the lease to be
- // released.
- boost::shared_ptr<Option6IA> ia_rsp(new Option6IA(D6O_IA_PD, ia->getIAID()));
- boost::shared_ptr<Option6IAPrefix> release_prefix =
- boost::dynamic_pointer_cast<Option6IAPrefix>(ia->getOption(D6O_IAPREFIX));
- if (!release_prefix) {
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoBinding,
- "You did not include a prefix in your RELEASE"));
- general_status = STATUS_NoBinding;
- return (ia_rsp);
- }
- Lease6Ptr lease = LeaseMgrFactory::instance().getLease6(Lease::TYPE_PD,
- release_prefix->getAddress());
- if (!lease) {
- // Client releasing a lease that we don't know about.
- // Insert status code NoBinding.
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoBinding,
- "Sorry, no known leases for this duid/iaid, can't release."));
- general_status = STATUS_NoBinding;
- return (ia_rsp);
- }
- if (!lease->duid_) {
- // Something is gravely wrong here. We do have a lease, but it does not
- // have mandatory DUID information attached. Someone was messing with our
- // database.
- LOG_ERROR(lease6_logger, DHCP6_LEASE_PD_WITHOUT_DUID)
- .arg(query->getLabel())
- .arg(release_prefix->getAddress().toText())
- .arg(static_cast<int>(release_prefix->getLength()));
- general_status = STATUS_UnspecFail;
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_UnspecFail,
- "Database consistency check failed when trying to RELEASE"));
- return (ia_rsp);
- }
- if (*duid != *(lease->duid_)) {
- // Sorry, it's not your address. You can't release it.
- LOG_INFO(lease6_logger, DHCP6_RELEASE_PD_FAIL_WRONG_DUID)
- .arg(query->getLabel())
- .arg(release_prefix->getAddress().toText())
- .arg(static_cast<int>(release_prefix->getLength()))
- .arg(lease->duid_->toText());
- general_status = STATUS_NoBinding;
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoBinding,
- "This address does not belong to you, you can't release it"));
- return (ia_rsp);
- }
- if (ia->getIAID() != lease->iaid_) {
- // This address belongs to this client, but to a different IA
- LOG_WARN(lease6_logger, DHCP6_RELEASE_PD_FAIL_WRONG_IAID)
- .arg(query->getLabel())
- .arg(release_prefix->getAddress().toText())
- .arg(static_cast<int>(release_prefix->getLength()))
- .arg(lease->iaid_)
- .arg(ia->getIAID());
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_NoBinding,
- "This is your address, but you used wrong IAID"));
- general_status = STATUS_NoBinding;
- return (ia_rsp);
- }
- // It is not necessary to check if the address matches as we used
- // getLease6(addr) method that is supposed to return a proper lease.
- bool skip = false;
- // Execute all callouts registered for packet6_send
- if (HooksManager::calloutsPresent(Hooks.hook_index_lease6_release_)) {
- CalloutHandlePtr callout_handle = getCalloutHandle(query);
- // Delete all previous arguments
- callout_handle->deleteAllArguments();
- // Enable copying options from the packet within hook library.
- ScopedEnableOptionsCopy<Pkt6> query6_options_copy(query);
- // Pass the original packet
- callout_handle->setArgument("query6", query);
- // Pass the lease to be updated
- callout_handle->setArgument("lease6", lease);
- // Call all installed callouts
- HooksManager::callCallouts(Hooks.hook_index_lease6_release_, *callout_handle);
- skip = callout_handle->getStatus() == CalloutHandle::NEXT_STEP_SKIP;
- }
- // Ok, we've passed all checks. Let's release this prefix.
- bool success = false; // was the removal operation successful?
- if (!skip) {
- success = LeaseMgrFactory::instance().deleteLease(lease->addr_);
- } else {
- // Callouts decided to skip the next processing step. The next
- // processing step would to send the packet, so skip at this
- // stage means "drop response".
- LOG_DEBUG(hooks_logger, DBG_DHCP6_HOOKS, DHCP6_HOOK_LEASE6_RELEASE_PD_SKIP)
- .arg(query->getLabel());
- }
- // Here the success should be true if we removed lease successfully
- // and false if skip flag was set or the removal failed for whatever reason
- if (!success) {
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_UnspecFail,
- "Server failed to release a lease"));
- LOG_ERROR(lease6_logger, DHCP6_RELEASE_PD_FAIL)
- .arg(query->getLabel())
- .arg(lease->addr_.toText())
- .arg(static_cast<int>(lease->prefixlen_))
- .arg(lease->iaid_);
- general_status = STATUS_UnspecFail;
- } else {
- LOG_INFO(lease6_logger, DHCP6_RELEASE_PD)
- .arg(query->getLabel())
- .arg(lease->addr_.toText())
- .arg(static_cast<int>(lease->prefixlen_))
- .arg(lease->iaid_);
- ia_rsp->addOption(createStatusCode(*query, *ia_rsp, STATUS_Success,
- "Lease released. Thank you, please come again."));
- // Need to decrease statistic for assigned prefixes.
- StatsMgr::instance().addValue(
- StatsMgr::generateName("subnet", lease->subnet_id_, "assigned-pds"),
- static_cast<int64_t>(-1));
- }
- return (ia_rsp);
- }
- Pkt6Ptr
- Dhcpv6Srv::processSolicit(const Pkt6Ptr& solicit) {
- sanityCheck(solicit, MANDATORY, FORBIDDEN);
- // Let's create a simplified client context here.
- AllocEngine::ClientContext6 ctx;
- initContext(solicit, ctx);
- setReservedClientClasses(solicit, ctx);
- Pkt6Ptr response(new Pkt6(DHCPV6_ADVERTISE, solicit->getTransid()));
- // Handle Rapid Commit option, if present.
- if (ctx.subnet_ && ctx.subnet_->getRapidCommit()) {
- OptionPtr opt_rapid_commit = solicit->getOption(D6O_RAPID_COMMIT);
- if (opt_rapid_commit) {
- LOG_DEBUG(options6_logger, DBG_DHCP6_DETAIL, DHCP6_RAPID_COMMIT)
- .arg(solicit->getLabel());
- // If Rapid Commit has been sent by the client, change the
- // response type to Reply and include Rapid Commit option.
- response->setType(DHCPV6_REPLY);
- response->addOption(opt_rapid_commit);
- }
- }
- processClientFqdn(solicit, response, ctx);
- assignLeases(solicit, response, ctx);
- copyClientOptions(solicit, response);
- CfgOptionList co_list;
- buildCfgOptionList(solicit, ctx, co_list);
- appendDefaultOptions(solicit, response, co_list);
- appendRequestedOptions(solicit, response, co_list);
- appendRequestedVendorOptions(solicit, response, ctx, co_list);
- // Only generate name change requests if sending a Reply as a result
- // of receiving Rapid Commit option.
- if (response->getType() == DHCPV6_REPLY) {
- createNameChangeRequests(response, ctx);
- }
- return (response);
- }
- Pkt6Ptr
- Dhcpv6Srv::processRequest(const Pkt6Ptr& request) {
- sanityCheck(request, MANDATORY, MANDATORY);
- // Let's create a simplified client context here.
- AllocEngine::ClientContext6 ctx;
- initContext(request, ctx);
- setReservedClientClasses(request, ctx);
- Pkt6Ptr reply(new Pkt6(DHCPV6_REPLY, request->getTransid()));
- processClientFqdn(request, reply, ctx);
- assignLeases(request, reply, ctx);
- copyClientOptions(request, reply);
- CfgOptionList co_list;
- buildCfgOptionList(request, ctx, co_list);
- appendDefaultOptions(request, reply, co_list);
- appendRequestedOptions(request, reply, co_list);
- appendRequestedVendorOptions(request, reply, ctx, co_list);
- generateFqdn(reply);
- createNameChangeRequests(reply, ctx);
- return (reply);
- }
- Pkt6Ptr
- Dhcpv6Srv::processRenew(const Pkt6Ptr& renew) {
- sanityCheck(renew, MANDATORY, MANDATORY);
- // Let's create a simplified client context here.
- AllocEngine::ClientContext6 ctx;
- initContext(renew, ctx);
- setReservedClientClasses(renew, ctx);
- Pkt6Ptr reply(new Pkt6(DHCPV6_REPLY, renew->getTransid()));
- processClientFqdn(renew, reply, ctx);
- extendLeases(renew, reply, ctx);
- copyClientOptions(renew, reply);
- CfgOptionList co_list;
- buildCfgOptionList(renew, ctx, co_list);
- appendDefaultOptions(renew, reply, co_list);
- appendRequestedOptions(renew, reply, co_list);
- appendRequestedVendorOptions(renew, reply, ctx, co_list);
- generateFqdn(reply);
- createNameChangeRequests(reply, ctx);
- return (reply);
- }
- Pkt6Ptr
- Dhcpv6Srv::processRebind(const Pkt6Ptr& rebind) {
- sanityCheck(rebind, MANDATORY, FORBIDDEN);
- // Let's create a simplified client context here.
- AllocEngine::ClientContext6 ctx;
- initContext(rebind, ctx);
- setReservedClientClasses(rebind, ctx);
- Pkt6Ptr reply(new Pkt6(DHCPV6_REPLY, rebind->getTransid()));
- processClientFqdn(rebind, reply, ctx);
- extendLeases(rebind, reply, ctx);
- copyClientOptions(rebind, reply);
- CfgOptionList co_list;
- buildCfgOptionList(rebind, ctx, co_list);
- appendDefaultOptions(rebind, reply, co_list);
- appendRequestedOptions(rebind, reply, co_list);
- appendRequestedVendorOptions(rebind, reply, ctx, co_list);
- generateFqdn(reply);
- createNameChangeRequests(reply, ctx);
- return (reply);
- }
- Pkt6Ptr
- Dhcpv6Srv::processConfirm(const Pkt6Ptr& confirm) {
- sanityCheck(confirm, MANDATORY, FORBIDDEN);
- // Let's create a simplified client context here.
- AllocEngine::ClientContext6 ctx;
- initContext(confirm, ctx);
- setReservedClientClasses(confirm, ctx);
- // Get IA_NAs from the Confirm. If there are none, the message is
- // invalid and must be discarded. There is nothing more to do.
- OptionCollection ias = confirm->getOptions(D6O_IA_NA);
- if (ias.empty()) {
- return (Pkt6Ptr());
- }
- // The server sends Reply message in response to Confirm.
- Pkt6Ptr reply(new Pkt6(DHCPV6_REPLY, confirm->getTransid()));
- // Make sure that the necessary options are included.
- copyClientOptions(confirm, reply);
- CfgOptionList co_list;
- buildCfgOptionList(confirm, ctx, co_list);
- appendDefaultOptions(confirm, reply, co_list);
- appendRequestedOptions(confirm, reply, co_list);
- appendRequestedVendorOptions(confirm, reply, ctx, co_list);
- // Indicates if at least one address has been verified. If no addresses
- // are verified it means that the client has sent no IA_NA options
- // or no IAAddr options and that client's message has to be discarded.
- bool verified = false;
- // Check if subnet was selected for the message. If no subnet
- // has been selected, the client is not on link.
- SubnetPtr subnet = ctx.subnet_;
- // Regardless if the subnet has been selected or not, we will iterate
- // over the IA_NA options to check if they hold any addresses. If there
- // are no, the Confirm is discarded.
- // Check addresses in IA_NA options and make sure they are appropriate.
- for (OptionCollection::const_iterator ia = ias.begin();
- ia != ias.end(); ++ia) {
- const OptionCollection& opts = ia->second->getOptions();
- for (OptionCollection::const_iterator opt = opts.begin();
- opt != opts.end(); ++opt) {
- // Ignore options other than IAAddr.
- if (opt->second->getType() == D6O_IAADDR) {
- // Check that the address is in range in the subnet selected.
- Option6IAAddrPtr iaaddr = boost::dynamic_pointer_cast<
- Option6IAAddr>(opt->second);
- // If there is subnet selected and the address has been included
- // in IA_NA, mark it verified and verify that it belongs to the
- // subnet.
- if (iaaddr) {
- // If at least one address is not in range, then return
- // the NotOnLink status code.
- if (subnet && !subnet->inRange(iaaddr->getAddress())) {
- std::ostringstream status_msg;
- status_msg << "Address " << iaaddr->getAddress()
- << " is not on link.";
- reply->addOption(createStatusCode(*confirm,
- STATUS_NotOnLink,
- status_msg.str()));
- return (reply);
- }
- verified = true;
- } else {
- isc_throw(Unexpected, "failed to cast the IA Address option"
- " to the Option6IAAddrPtr. This is programming"
- " error and should be reported");
- }
- }
- }
- }
- // It seems that the client hasn't included any addresses in which case
- // the Confirm must be discarded.
- if (!verified) {
- return (Pkt6Ptr());
- }
- // If there is a subnet, there were addresses in IA_NA options and the
- // addresses where consistent with the subnet then the client is on link.
- if (subnet) {
- // All addresses in range, so return success.
- reply->addOption(createStatusCode(*confirm, STATUS_Success,
- "All addresses are on-link"));
- } else {
- reply->addOption(createStatusCode(*confirm, STATUS_NotOnLink,
- "No subnet selected"));
- }
- return (reply);
- }
- Pkt6Ptr
- Dhcpv6Srv::processRelease(const Pkt6Ptr& release) {
- sanityCheck(release, MANDATORY, MANDATORY);
- // Let's create a simplified client context here.
- AllocEngine::ClientContext6 ctx;
- initContext(release, ctx);
- setReservedClientClasses(release, ctx);
- Pkt6Ptr reply(new Pkt6(DHCPV6_REPLY, release->getTransid()));
- copyClientOptions(release, reply);
- CfgOptionList co_list;
- // buildCfgOptionList(release, ctx, co_list);
- appendDefaultOptions(release, reply, co_list);
- releaseLeases(release, reply, ctx);
- /// @todo If client sent a release and we should remove outstanding
- /// DNS records.
- return (reply);
- }
- Pkt6Ptr
- Dhcpv6Srv::processDecline(const Pkt6Ptr& decline) {
- // Do sanity check.
- sanityCheck(decline, MANDATORY, MANDATORY);
- // Create an empty Reply message.
- Pkt6Ptr reply(new Pkt6(DHCPV6_REPLY, decline->getTransid()));
- // Let's create a simplified client context here.
- AllocEngine::ClientContext6 ctx;
- initContext(decline, ctx);
- setReservedClientClasses(decline, ctx);
- // Copy client options (client-id, also relay information if present)
- copyClientOptions(decline, reply);
- // Get the configured option list
- CfgOptionList co_list;
- buildCfgOptionList(decline, ctx, co_list);
- // Include server-id
- appendDefaultOptions(decline, reply, co_list);
- if (declineLeases(decline, reply, ctx)) {
- return (reply);
- } else {
- // declineLeases returns false only if the hooks set the next step
- // status to DROP. We'll just doing as requested.
- return (Pkt6Ptr());
- }
- }
- bool
- Dhcpv6Srv::declineLeases(const Pkt6Ptr& decline, Pkt6Ptr& reply,
- AllocEngine::ClientContext6& ctx) {
- // We need to decline addresses for all IA_NA options in the client's
- // RELEASE message.
- // Let's set the status to be success by default. We can override it with
- // error status if needed. The important thing to understand here is that
- // the global status code may be set to success only if all IA options were
- // handled properly. Therefore the declineIA options
- // may turn the status code to some error, but can't turn it back to success.
- int general_status = STATUS_Success;
- for (OptionCollection::iterator opt = decline->options_.begin();
- opt != decline->options_.end(); ++opt) {
- switch (opt->second->getType()) {
- case D6O_IA_NA: {
- OptionPtr answer_opt = declineIA(decline, ctx.duid_, general_status,
- boost::dynamic_pointer_cast<Option6IA>(opt->second));
- if (answer_opt) {
- // We have an answer, let's use it.
- reply->addOption(answer_opt);
- } else {
- // The only case when declineIA could return NULL is if one of the
- // hook callouts set next step status to DROP. We just need to drop
- // this packet.
- return (false);
- }
- break;
- }
- default:
- // We don't care for the remaining options
- ;
- }
- }
- return (true);
- }
- OptionPtr
- Dhcpv6Srv::declineIA(const Pkt6Ptr& decline, const DuidPtr& duid,
- int& general_status, boost::shared_ptr<Option6IA> ia) {
- LOG_DEBUG(lease6_logger, DBG_DHCP6_DETAIL, DHCP6_DECLINE_PROCESS_IA)
- .arg(decline->getLabel())
- .arg(ia->getIAID());
- // Decline can be done in one of two ways:
- // Approach 1: extract address from client's IA_NA and see if it belongs
- // to this particular client.
- // Approach 2: find a subnet for this client, get a lease for
- // this subnet/duid/iaid and check if its content matches to what the
- // client is asking us to decline.
- //
- // This method implements approach 1.
- // That's our response
- boost::shared_ptr<Option6IA> ia_rsp(new Option6IA(D6O_IA_NA, ia->getIAID()));
- const OptionCollection& opts = ia->getOptions();
- int total_addrs = 0; // Let's count the total number of addresses.
- for (OptionCollection::const_iterator opt = opts.begin(); opt != opts.end();
- ++opt) {
- // Let's ignore nested options other than IAADDR (there shouldn't be anything
- // else in IA_NA in Decline message, but let's be on the safe side).
- if (opt->second->getType() != D6O_IAADDR) {
- continue;
- }
- Option6IAAddrPtr decline_addr = boost::dynamic_pointer_cast<Option6IAAddr>
- (opt->second);
- if (!decline_addr) {
- continue;
- }
- total_addrs++;
- Lease6Ptr lease = LeaseMgrFactory::instance().getLease6(Lease::TYPE_NA,
- decline_addr->getAddress());
- if (!lease) {
- // Client trying to decline a lease that we don't know about.
- LOG_INFO(lease6_logger, DHCP6_DECLINE_FAIL_NO_LEASE)
- .arg(decline->getLabel()).arg(decline_addr->getAddress().toText());
- // RFC3315, section 18.2.7: "For each IA in the Decline message for
- // which the server has no binding information, the server adds an
- // IA option using the IAID from the Release message and includes
- // a Status Code option with the value NoBinding in the IA option.
- setStatusCode(ia_rsp, createStatusCode(*decline, *ia_rsp, STATUS_NoBinding,
- "Server does not know about such an address."));
- // RFC3315, section 18.2.7: The server ignores addresses not
- // assigned to the IA (though it may choose to log an error if it
- // finds such an address).
- continue; // There may be other addresses.
- }
- if (!lease->duid_) {
- // Something is gravely wrong here. We do have a lease, but it does not
- // have mandatory DUID information attached. Someone was messing with our
- // database.
- LOG_ERROR(lease6_logger, DHCP6_DECLINE_FAIL_LEASE_WITHOUT_DUID)
- .arg(decline->getLabel())
- .arg(decline_addr->getAddress().toText());
- ia_rsp->addOption(createStatusCode(*decline, *ia_rsp, STATUS_UnspecFail,
- "Database consistency check failed when attempting Decline."));
- continue;
- }
- // Ok, there's a sane lease with an address. Let's check if DUID matches first.
- if (*duid != *(lease->duid_)) {
- // Sorry, it's not your address. You can't release it.
- LOG_INFO(lease6_logger, DHCP6_DECLINE_FAIL_DUID_MISMATCH)
- .arg(decline->getLabel())
- .arg(decline_addr->getAddress().toText())
- .arg(lease->duid_->toText());
- ia_rsp->addOption(createStatusCode(*decline, *ia_rsp, STATUS_NoBinding,
- "This address does not belong to you, you can't decline it"));
- continue;
- }
- // Let's check if IAID matches.
- if (ia->getIAID() != lease->iaid_) {
- // This address belongs to this client, but to a different IA
- LOG_INFO(lease6_logger, DHCP6_DECLINE_FAIL_IAID_MISMATCH)
- .arg(decline->getLabel())
- .arg(lease->addr_.toText())
- .arg(ia->getIAID())
- .arg(lease->iaid_);
- setStatusCode(ia_rsp, createStatusCode(*decline, *ia_rsp, STATUS_NoBinding,
- "This is your address, but you used wrong IAID"));
- continue;
- }
- // Ok, all is good. Decline this lease.
- if (!declineLease(decline, lease, ia_rsp)) {
- // declineLease returns false only when hook callouts set the next
- // step status to drop. We just propagate the bad news here.
- return (OptionPtr());
- }
- }
- if (total_addrs == 0) {
- setStatusCode(ia_rsp, createStatusCode(*decline, *ia_rsp, STATUS_NoBinding,
- "No addresses sent in IA_NA"));
- general_status = STATUS_NoBinding;
- }
- return (ia_rsp);
- }
- void
- Dhcpv6Srv::setStatusCode(boost::shared_ptr<isc::dhcp::Option6IA>& container,
- const OptionPtr& status) {
- // Let's delete any old status code we may have.
- container->delOption(D6O_STATUS_CODE);
- container->addOption(status);
- }
- bool
- Dhcpv6Srv::declineLease(const Pkt6Ptr& decline, const Lease6Ptr lease,
- boost::shared_ptr<Option6IA> ia_rsp) {
- // We do not want to decrease the assigned-nas at this time. While
- // technically a declined address is no longer allocated, the primary usage
- // of the assigned-addresses statistic is to monitor pool utilization. Most
- // people would forget to include declined-addresses in the calculation,
- // and simply do assigned-addresses/total-addresses. This would have a bias
- // towards under-representing pool utilization, if we decreased allocated
- // immediately after receiving DHCPDECLINE, rather than later when we recover
- // the address.
- // Let's call lease6_decline hooks if necessary.
- if (HooksManager::calloutsPresent(Hooks.hook_index_lease6_decline_)) {
- CalloutHandlePtr callout_handle = getCalloutHandle(decline);
- // Delete previously set arguments
- callout_handle->deleteAllArguments();
- // Enable copying options from the packet within hook library.
- ScopedEnableOptionsCopy<Pkt6> query6_options_copy(decline);
- // Pass incoming packet as argument
- callout_handle->setArgument("query6", decline);
- callout_handle->setArgument("lease6", lease);
- // Call callouts
- HooksManager::callCallouts(Hooks.hook_index_lease6_decline_,
- *callout_handle);
- // Callouts decided to SKIP the next processing step. The next
- // processing step would to actually decline the lease, so we'll
- // keep the lease as is.
- if (callout_handle->getStatus() == CalloutHandle::NEXT_STEP_SKIP) {
- LOG_DEBUG(hooks_logger, DBG_DHCP6_DETAIL, DHCP6_HOOK_DECLINE_SKIP)
- .arg(decline->getLabel())
- .arg(decline->getIface())
- .arg(lease->addr_.toText());
- return (true);
- }
- // Callouts decided to DROP the packet. Let's simply log it and
- // return false, so callers will act accordingly.
- if (callout_handle->getStatus() == CalloutHandle::NEXT_STEP_DROP) {
- LOG_DEBUG(hooks_logger, DBG_DHCP6_DETAIL, DHCP6_HOOK_DECLINE_DROP)
- .arg(decline->getLabel())
- .arg(decline->getIface())
- .arg(lease->addr_.toText());
- return (false);
- }
- }
- // Check if a lease has flags indicating that the FQDN update has
- // been performed. If so, create NameChangeRequest which removes
- // the entries. This method does all necessary checks.
- queueNCR(CHG_REMOVE, lease);
- // Bump up the subnet-specific statistic.
- StatsMgr::instance().addValue(
- StatsMgr::generateName("subnet", lease->subnet_id_, "declined-addresses"),
- static_cast<int64_t>(1));
- // Global declined addresses counter.
- StatsMgr::instance().addValue("declined-addresses", static_cast<int64_t>(1));
- // We need to disassociate the lease from the client. Once we move a lease
- // to declined state, it is no longer associated with the client in any
- // way.
- lease->decline(CfgMgr::instance().getCurrentCfg()->getDeclinePeriod());
- LeaseMgrFactory::instance().updateLease6(lease);
- LOG_INFO(lease6_logger, DHCP6_DECLINE_LEASE).arg(decline->getLabel())
- .arg(lease->addr_.toText()).arg(lease->valid_lft_);
- ia_rsp->addOption(createStatusCode(*decline, *ia_rsp, STATUS_Success,
- "Lease declined. Hopefully the next one will be better."));
- return (true);
- }
- Pkt6Ptr
- Dhcpv6Srv::processInfRequest(const Pkt6Ptr& inf_request) {
- sanityCheck(inf_request, OPTIONAL, OPTIONAL);
- // Let's create a simplified client context here.
- AllocEngine::ClientContext6 ctx;
- initContext(inf_request, ctx);
- setReservedClientClasses(inf_request, ctx);
- // Create a Reply packet, with the same trans-id as the client's.
- Pkt6Ptr reply(new Pkt6(DHCPV6_REPLY, inf_request->getTransid()));
- // Copy client options (client-id, also relay information if present)
- copyClientOptions(inf_request, reply);
- // Build the configured option list for append methods
- CfgOptionList co_list;
- buildCfgOptionList(inf_request, ctx, co_list);
- // Append default options, i.e. options that the server is supposed
- // to put in all messages it sends (server-id for now, but possibly other
- // options once we start supporting authentication)
- appendDefaultOptions(inf_request, reply, co_list);
- // Try to assign options that were requested by the client.
- appendRequestedOptions(inf_request, reply, co_list);
- // Try to assigne vendor options that were requested by the client.
- appendRequestedVendorOptions(inf_request, reply, ctx, co_list);
- return (reply);
- }
- void
- Dhcpv6Srv::processDhcp4Query(const Pkt6Ptr& dhcp4_query) {
- sanityCheck(dhcp4_query, OPTIONAL, OPTIONAL);
- // flags are in transid
- // uint32_t flags = dhcp4_query->getTransid();
- // do nothing with DHCPV4_QUERY_FLAGS_UNICAST
- // Get the DHCPv4 message option
- OptionPtr dhcp4_msg = dhcp4_query->getOption(D6O_DHCPV4_MSG);
- if (dhcp4_msg) {
- // Forward the whole message to the DHCPv4 server via IPC
- Dhcp6to4Ipc::instance().send(dhcp4_query);
- }
- // This method does not return anything as we always sent back
- // the response via Dhcp6To4Ipc.
- }
- void Dhcpv6Srv::classifyByVendor(const Pkt6Ptr& pkt, std::string& classes) {
- OptionVendorClassPtr vclass = boost::dynamic_pointer_cast<
- OptionVendorClass>(pkt->getOption(D6O_VENDOR_CLASS));
- if (!vclass || vclass->getTuplesNum() == 0) {
- return;
- }
- if (vclass->hasTuple(DOCSIS3_CLASS_MODEM)) {
- pkt->addClass(VENDOR_CLASS_PREFIX + DOCSIS3_CLASS_MODEM);
- classes += VENDOR_CLASS_PREFIX + DOCSIS3_CLASS_MODEM + " ";
- } else if (vclass->hasTuple(DOCSIS3_CLASS_EROUTER)) {
- pkt->addClass(VENDOR_CLASS_PREFIX + DOCSIS3_CLASS_EROUTER);
- classes += VENDOR_CLASS_PREFIX + DOCSIS3_CLASS_EROUTER + " ";
- } else {
- pkt->addClass(VENDOR_CLASS_PREFIX + vclass->getTuple(0).getText());
- classes + VENDOR_CLASS_PREFIX + vclass->getTuple(0).getText() + " ";
- }
- }
- void Dhcpv6Srv::classifyPacket(const Pkt6Ptr& pkt) {
- string classes = "";
- // First phase: built-in vendor class processing
- classifyByVendor(pkt, classes);
- // Run match expressions
- // Note getClientClassDictionary() cannot be null
- const ClientClassDefMapPtr& defs_ptr = CfgMgr::instance().getCurrentCfg()->
- getClientClassDictionary()->getClasses();
- for (ClientClassDefMap::const_iterator it = defs_ptr->begin();
- it != defs_ptr->end(); ++it) {
- // Note second cannot be null
- const ExpressionPtr& expr_ptr = it->second->getMatchExpr();
- // Nothing to do without an expression to evaluate
- if (!expr_ptr) {
- continue;
- }
- // Evaluate the expression which can return false (no match),
- // true (match) or raise an exception (error)
- try {
- bool status = evaluate(*expr_ptr, *pkt);
- if (status) {
- LOG_INFO(dhcp6_logger, EVAL_RESULT)
- .arg(it->first)
- .arg(status);
- // Matching: add the class
- pkt->addClass(it->first);
- classes += it->first + " ";
- } else {
- LOG_DEBUG(dhcp6_logger, DBG_DHCP6_DETAIL, EVAL_RESULT)
- .arg(it->first)
- .arg(status);
- }
- } catch (const Exception& ex) {
- LOG_ERROR(dhcp6_logger, EVAL_RESULT)
- .arg(it->first)
- .arg(ex.what());
- } catch (...) {
- LOG_ERROR(dhcp6_logger, EVAL_RESULT)
- .arg(it->first)
- .arg("get exception?");
- }
- }
- }
- void
- Dhcpv6Srv::setReservedClientClasses(const Pkt6Ptr& pkt,
- const AllocEngine::ClientContext6& ctx) {
- if (ctx.host_ && pkt) {
- BOOST_FOREACH(const std::string& client_class,
- ctx.host_->getClientClasses6()) {
- pkt->addClass(client_class);
- }
- }
- const ClientClasses& classes = pkt->getClasses();
- if (!classes.empty()) {
- std::string joined_classes = boost::algorithm::join(classes, ", ");
- LOG_DEBUG(dhcp6_logger, DBG_DHCP6_BASIC, DHCP6_CLASS_ASSIGNED)
- .arg(pkt->getLabel())
- .arg(joined_classes);
- }
- }
- void
- Dhcpv6Srv::generateFqdn(const Pkt6Ptr& answer) {
- if (!answer) {
- isc_throw(isc::Unexpected, "an instance of the object encapsulating"
- " a message must not be NULL when generating FQDN");
- }
- /// @todo Add proper logging for cases when we can't generate FQDN.
- /// See #3885 for details.
- // It is likely that client hasn't included the FQDN option. In such case,
- // FQDN option will be NULL. Also, there is nothing to do if the option
- // is present and conveys the non-empty FQDN.
- Option6ClientFqdnPtr fqdn = boost::dynamic_pointer_cast<
- Option6ClientFqdn>(answer->getOption(D6O_CLIENT_FQDN));
- if (!fqdn || !fqdn->getDomainName().empty()) {
- return;
- }
- // Get the first IA_NA acquired for the client.
- OptionPtr ia = answer->getOption(D6O_IA_NA);
- if (!ia) {
- return;
- }
- // If it has any IAAddr, use the first one to generate unique FQDN.
- Option6IAAddrPtr iaaddr = boost::dynamic_pointer_cast<
- Option6IAAddr>(ia->getOption(D6O_IAADDR));
- if (!iaaddr) {
- return;
- }
- // Get the IPv6 address acquired by the client.
- IOAddress addr = iaaddr->getAddress();
- std::string generated_name =
- CfgMgr::instance().getD2ClientMgr().generateFqdn(addr);
- LOG_DEBUG(ddns6_logger, DBG_DHCP6_DETAIL_DATA, DHCP6_DDNS_FQDN_GENERATED)
- .arg(answer->getLabel())
- .arg(generated_name);
- try {
- // The lease has been acquired but the FQDN for this lease hasn't
- // been updated in the lease database. We now have new FQDN
- // generated, so the lease database has to be updated here.
- // However, never update lease database for Advertise, just send
- // our notion of client's FQDN in the Client FQDN option.
- if (answer->getType() != DHCPV6_ADVERTISE) {
- Lease6Ptr lease =
- LeaseMgrFactory::instance().getLease6(Lease::TYPE_NA, addr);
- if (lease) {
- lease->hostname_ = generated_name;
- LeaseMgrFactory::instance().updateLease6(lease);
- } else {
- isc_throw(isc::Unexpected, "there is no lease in the database "
- " for address " << addr << ", so as it is impossible"
- " to update FQDN data. This is a programmatic error"
- " as the given address is now being handed to the"
- " client");
- }
- }
- // Set the generated FQDN in the Client FQDN option.
- fqdn->setDomainName(generated_name, Option6ClientFqdn::FULL);
- } catch (const Exception& ex) {
- LOG_ERROR(ddns6_logger, DHCP6_DDNS_GENERATED_FQDN_UPDATE_FAIL)
- .arg(answer->getLabel())
- .arg(addr.toText())
- .arg(ex.what());
- }
- }
- void
- Dhcpv6Srv::startD2() {
- D2ClientMgr& d2_mgr = CfgMgr::instance().getD2ClientMgr();
- if (d2_mgr.ddnsEnabled()) {
- // Updates are enabled, so lets start the sender, passing in
- // our error handler.
- // This may throw so wherever this is called needs to ready.
- d2_mgr.startSender(boost::bind(&Dhcpv6Srv::d2ClientErrorHandler,
- this, _1, _2));
- }
- }
- void
- Dhcpv6Srv::stopD2() {
- D2ClientMgr& d2_mgr = CfgMgr::instance().getD2ClientMgr();
- if (d2_mgr.ddnsEnabled()) {
- // Updates are enabled, so lets stop the sender
- d2_mgr.stopSender();
- }
- }
- void
- Dhcpv6Srv::d2ClientErrorHandler(const
- dhcp_ddns::NameChangeSender::Result result,
- dhcp_ddns::NameChangeRequestPtr& ncr) {
- LOG_ERROR(ddns6_logger, DHCP6_DDNS_REQUEST_SEND_FAILED).
- arg(result).arg((ncr ? ncr->toText() : " NULL "));
- // We cannot communicate with kea-dhcp-ddns, suspend further updates.
- /// @todo We may wish to revisit this, but for now we will simply turn
- /// them off.
- CfgMgr::instance().getD2ClientMgr().suspendUpdates();
- }
- // Refer to config_report so it will be embedded in the binary
- const char* const* dhcp6_config_report = isc::detail::config_report;
- std::string
- Dhcpv6Srv::getVersion(bool extended) {
- std::stringstream tmp;
- tmp << VERSION;
- if (extended) {
- tmp << endl << EXTENDED_VERSION << endl;
- tmp << "linked with:" << endl;
- tmp << Logger::getVersion() << endl;
- tmp << CryptoLink::getVersion() << endl;
- tmp << "database:" << endl;
- #ifdef HAVE_MYSQL
- tmp << MySqlLeaseMgr::getDBVersion() << endl;
- #endif
- #ifdef HAVE_PGSQL
- tmp << PgSqlLeaseMgr::getDBVersion() << endl;
- #endif
- #ifdef HAVE_CQL
- tmp << CqlLeaseMgr::getDBVersion() << endl;
- #endif
- tmp << Memfile_LeaseMgr::getDBVersion();
- // @todo: more details about database runtime
- }
- return (tmp.str());
- }
- void Dhcpv6Srv::processRSOO(const Pkt6Ptr& query, const Pkt6Ptr& rsp) {
- if (query->relay_info_.empty()) {
- // RSOO is inserted by relay agents, nothing to do here if it's
- // a direct message.
- return;
- }
- // Get RSOO configuration.
- ConstCfgRSOOPtr cfg_rsoo = CfgMgr::instance().getCurrentCfg()->getCfgRSOO();
- // Let's get over all relays (encapsulation levels). We need to do
- // it in the same order as the client packet traversed the relays.
- for (int i = query->relay_info_.size(); i > 0 ; --i) {
- OptionPtr rsoo_container = query->getRelayOption(D6O_RSOO, i - 1);
- if (rsoo_container) {
- // There are RSOO options. Let's get through them one by one
- // and if it's RSOO-enabled and there's no such option provided yet,
- // copy it to the server's response
- const OptionCollection& rsoo = rsoo_container->getOptions();
- for (OptionCollection::const_iterator opt = rsoo.begin();
- opt != rsoo.end(); ++opt) {
- // Echo option if it is RSOO enabled option and there is no such
- // option added yet.
- if (cfg_rsoo->enabled(opt->second->getType()) &&
- !rsp->getOption(opt->second->getType())) {
- rsp->addOption(opt->second);
- }
- }
- }
- }
- }
- void Dhcpv6Srv::processStatsReceived(const Pkt6Ptr& query) {
- // Note that we're not bumping pkt6-received statistic as it was
- // increased early in the packet reception code.
- string stat_name = "pkt6-unknown-received";
- switch (query->getType()) {
- case DHCPV6_SOLICIT:
- stat_name = "pkt6-solicit-received";
- break;
- case DHCPV6_ADVERTISE:
- // Should not happen, but let's keep a counter for it
- stat_name = "pkt6-advertise-received";
- break;
- case DHCPV6_REQUEST:
- stat_name = "pkt6-request-received";
- break;
- case DHCPV6_CONFIRM:
- stat_name = "pkt6-confirm-received";
- break;
- case DHCPV6_RENEW:
- stat_name = "pkt6-renew-received";
- break;
- case DHCPV6_REBIND:
- stat_name = "pkt6-rebind-received";
- break;
- case DHCPV6_REPLY:
- // Should not happen, but let's keep a counter for it
- stat_name = "pkt6-reply-received";
- break;
- case DHCPV6_RELEASE:
- stat_name = "pkt6-release-received";
- break;
- case DHCPV6_DECLINE:
- stat_name = "pkt6-decline-received";
- break;
- case DHCPV6_RECONFIGURE:
- stat_name = "pkt6-reconfigure-received";
- break;
- case DHCPV6_INFORMATION_REQUEST:
- stat_name = "pkt6-infrequest-received";
- break;
- case DHCPV6_DHCPV4_QUERY:
- stat_name = "pkt6-dhcpv4-query-received";
- break;
- case DHCPV6_DHCPV4_RESPONSE:
- // Should not happen, but let's keep a counter for it
- stat_name = "pkt6-dhcpv4-response-received";
- break;
- default:
- ; // do nothing
- }
- StatsMgr::instance().addValue(stat_name, static_cast<int64_t>(1));
- }
- void Dhcpv6Srv::processStatsSent(const Pkt6Ptr& response) {
- // Increase generic counter for sent packets.
- StatsMgr::instance().addValue("pkt6-sent", static_cast<int64_t>(1));
- // Increase packet type specific counter for packets sent.
- string stat_name;
- switch (response->getType()) {
- case DHCPV6_ADVERTISE:
- stat_name = "pkt6-advertise-sent";
- break;
- case DHCPV6_REPLY:
- stat_name = "pkt6-reply-sent";
- break;
- case DHCPV6_DHCPV4_RESPONSE:
- stat_name = "pkt6-dhcpv4-response-sent";
- break;
- default:
- // That should never happen
- return;
- }
- StatsMgr::instance().addValue(stat_name, static_cast<int64_t>(1));
- }
- int Dhcpv6Srv::getHookIndexBuffer6Send() {
- return (Hooks.hook_index_buffer6_send_);
- }
- };
- };
|