123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745274627472748274927502751275227532754275527562757275827592760276127622763276427652766276727682769277027712772277327742775277627772778277927802781278227832784278527862787278827892790279127922793279427952796279727982799280028012802280328042805280628072808280928102811281228132814281528162817281828192820282128222823282428252826282728282829283028312832283328342835283628372838283928402841284228432844284528462847284828492850285128522853285428552856285728582859286028612862286328642865286628672868286928702871287228732874287528762877287828792880288128822883288428852886288728882889289028912892289328942895289628972898289929002901290229032904290529062907290829092910291129122913291429152916291729182919292029212922292329242925292629272928292929302931293229332934293529362937293829392940294129422943294429452946294729482949295029512952295329542955295629572958295929602961296229632964296529662967296829692970297129722973297429752976297729782979298029812982298329842985298629872988298929902991299229932994299529962997299829993000300130023003300430053006300730083009301030113012301330143015301630173018301930203021302230233024302530263027302830293030303130323033303430353036303730383039304030413042304330443045304630473048304930503051305230533054305530563057305830593060306130623063306430653066306730683069307030713072307330743075307630773078307930803081308230833084308530863087308830893090309130923093309430953096309730983099310031013102310331043105310631073108310931103111311231133114311531163117311831193120312131223123312431253126312731283129313031313132313331343135313631373138313931403141314231433144314531463147314831493150315131523153315431553156315731583159316031613162316331643165316631673168316931703171317231733174317531763177317831793180318131823183318431853186318731883189319031913192319331943195319631973198319932003201320232033204320532063207320832093210321132123213321432153216321732183219322032213222322332243225322632273228322932303231323232333234323532363237323832393240324132423243324432453246324732483249325032513252325332543255325632573258325932603261326232633264326532663267326832693270327132723273327432753276327732783279328032813282328332843285328632873288328932903291329232933294329532963297329832993300330133023303330433053306330733083309331033113312331333143315331633173318331933203321332233233324332533263327332833293330333133323333333433353336333733383339334033413342334333443345334633473348334933503351335233533354335533563357335833593360336133623363336433653366336733683369337033713372337333743375337633773378337933803381338233833384338533863387338833893390339133923393339433953396339733983399340034013402340334043405340634073408340934103411341234133414341534163417341834193420342134223423342434253426342734283429343034313432343334343435343634373438343934403441344234433444344534463447344834493450345134523453345434553456345734583459346034613462346334643465346634673468346934703471347234733474347534763477347834793480348134823483348434853486348734883489349034913492349334943495349634973498349935003501350235033504350535063507350835093510351135123513351435153516351735183519352035213522352335243525352635273528352935303531353235333534353535363537353835393540354135423543354435453546354735483549355035513552355335543555355635573558355935603561356235633564356535663567356835693570357135723573357435753576357735783579358035813582358335843585358635873588358935903591359235933594359535963597359835993600360136023603360436053606360736083609361036113612361336143615361636173618361936203621362236233624362536263627362836293630363136323633363436353636363736383639364036413642364336443645364636473648364936503651365236533654365536563657365836593660366136623663366436653666366736683669367036713672367336743675367636773678367936803681368236833684368536863687368836893690369136923693369436953696369736983699370037013702370337043705370637073708370937103711371237133714371537163717371837193720372137223723372437253726372737283729373037313732373337343735373637373738373937403741374237433744374537463747374837493750375137523753375437553756375737583759376037613762376337643765376637673768376937703771377237733774377537763777377837793780378137823783378437853786378737883789379037913792379337943795379637973798379938003801380238033804380538063807380838093810381138123813381438153816381738183819382038213822382338243825382638273828382938303831383238333834383538363837383838393840384138423843384438453846384738483849385038513852385338543855385638573858385938603861386238633864386538663867386838693870387138723873387438753876387738783879388038813882388338843885388638873888388938903891389238933894389538963897389838993900390139023903390439053906390739083909391039113912391339143915391639173918391939203921392239233924392539263927392839293930393139323933393439353936393739383939394039413942394339443945394639473948394939503951395239533954395539563957395839593960396139623963396439653966396739683969397039713972397339743975397639773978397939803981398239833984398539863987398839893990399139923993399439953996399739983999400040014002400340044005 |
- #include "qemu/osdep.h"
- #include <sys/ipc.h>
- #include <sys/msg.h>
- #include <sys/sem.h>
- #include <sys/shm.h>
- #include <sys/select.h>
- #include <sys/mount.h>
- #include <arpa/inet.h>
- #include <netinet/in.h>
- #include <netinet/tcp.h>
- #include <netinet/udp.h>
- #include <linux/if_packet.h>
- #include <linux/in6.h>
- #include <linux/netlink.h>
- #include <sched.h>
- #include "qemu.h"
- #include "user-internals.h"
- #include "strace.h"
- #include "signal-common.h"
- #include "target_mman.h"
- struct syscallname {
- int nr;
- const char *name;
- const char *format;
- void (*call)(CPUArchState *, const struct syscallname *,
- abi_long, abi_long, abi_long,
- abi_long, abi_long, abi_long);
- void (*result)(CPUArchState *, const struct syscallname *, abi_long,
- abi_long, abi_long, abi_long,
- abi_long, abi_long, abi_long);
- };
- /*
- * It is possible that target doesn't have syscall that uses
- * following flags but we don't want the compiler to warn
- * us about them being unused. Same applies to utility print
- * functions. It is ok to keep them while not used.
- */
- #define UNUSED __attribute__ ((unused))
- /*
- * Structure used to translate flag values into strings. This is
- * similar that is in the actual strace tool.
- */
- struct flags {
- abi_long f_value; /* flag */
- const char *f_string; /* stringified flag */
- };
- /* common flags for all architectures */
- #define FLAG_GENERIC(name) { name, #name }
- /* target specific flags (syscall_defs.h has TARGET_<flag>) */
- #define FLAG_TARGET(name) { TARGET_ ## name, #name }
- /* end of flags array */
- #define FLAG_END { 0, NULL }
- /* Structure used to translate enumerated values into strings */
- struct enums {
- abi_long e_value; /* enum value */
- const char *e_string; /* stringified enum */
- };
- /* common enums for all architectures */
- #define ENUM_GENERIC(name) { name, #name }
- /* target specific enums */
- #define ENUM_TARGET(name) { TARGET_ ## name, #name }
- /* end of enums array */
- #define ENUM_END { 0, NULL }
- UNUSED static const char *get_comma(int);
- UNUSED static void print_pointer(abi_long, int);
- UNUSED static void print_flags(const struct flags *, abi_long, int);
- UNUSED static void print_enums(const struct enums *, abi_long, int);
- UNUSED static void print_at_dirfd(abi_long, int);
- UNUSED static void print_file_mode(abi_long, int);
- UNUSED static void print_open_flags(abi_long, int);
- UNUSED static void print_syscall_prologue(const struct syscallname *);
- UNUSED static void print_syscall_epilogue(const struct syscallname *);
- UNUSED static void print_string(abi_long, int);
- UNUSED static void print_buf(abi_long addr, abi_long len, int last);
- UNUSED static void print_raw_param(const char *, abi_long, int);
- UNUSED static void print_timeval(abi_ulong, int);
- UNUSED static void print_timespec(abi_ulong, int);
- UNUSED static void print_timespec64(abi_ulong, int);
- UNUSED static void print_timezone(abi_ulong, int);
- UNUSED static void print_itimerval(abi_ulong, int);
- UNUSED static void print_number(abi_long, int);
- UNUSED static void print_signal(abi_ulong, int);
- UNUSED static void print_sockaddr(abi_ulong, abi_long, int);
- UNUSED static void print_socket_domain(int domain);
- UNUSED static void print_socket_type(int type);
- UNUSED static void print_socket_protocol(int domain, int type, int protocol);
- /*
- * Utility functions
- */
- static void
- print_ipc_cmd(int cmd)
- {
- #define output_cmd(val) \
- if( cmd == val ) { \
- qemu_log(#val); \
- return; \
- }
- cmd &= 0xff;
- /* General IPC commands */
- output_cmd( IPC_RMID );
- output_cmd( IPC_SET );
- output_cmd( IPC_STAT );
- output_cmd( IPC_INFO );
- /* msgctl() commands */
- output_cmd( MSG_STAT );
- output_cmd( MSG_INFO );
- /* shmctl() commands */
- output_cmd( SHM_LOCK );
- output_cmd( SHM_UNLOCK );
- output_cmd( SHM_STAT );
- output_cmd( SHM_INFO );
- /* semctl() commands */
- output_cmd( GETPID );
- output_cmd( GETVAL );
- output_cmd( GETALL );
- output_cmd( GETNCNT );
- output_cmd( GETZCNT );
- output_cmd( SETVAL );
- output_cmd( SETALL );
- output_cmd( SEM_STAT );
- output_cmd( SEM_INFO );
- output_cmd( IPC_RMID );
- output_cmd( IPC_RMID );
- output_cmd( IPC_RMID );
- output_cmd( IPC_RMID );
- output_cmd( IPC_RMID );
- output_cmd( IPC_RMID );
- output_cmd( IPC_RMID );
- output_cmd( IPC_RMID );
- output_cmd( IPC_RMID );
- /* Some value we don't recognize */
- qemu_log("%d", cmd);
- }
- static const char * const target_signal_name[] = {
- #define MAKE_SIG_ENTRY(sig) [TARGET_##sig] = #sig,
- MAKE_SIGNAL_LIST
- #undef MAKE_SIG_ENTRY
- };
- static void
- print_signal(abi_ulong arg, int last)
- {
- const char *signal_name = NULL;
- if (arg < ARRAY_SIZE(target_signal_name)) {
- signal_name = target_signal_name[arg];
- }
- if (signal_name == NULL) {
- print_raw_param("%ld", arg, last);
- return;
- }
- qemu_log("%s%s", signal_name, get_comma(last));
- }
- static void print_si_code(int arg)
- {
- const char *codename = NULL;
- switch (arg) {
- case SI_USER:
- codename = "SI_USER";
- break;
- case SI_KERNEL:
- codename = "SI_KERNEL";
- break;
- case SI_QUEUE:
- codename = "SI_QUEUE";
- break;
- case SI_TIMER:
- codename = "SI_TIMER";
- break;
- case SI_MESGQ:
- codename = "SI_MESGQ";
- break;
- case SI_ASYNCIO:
- codename = "SI_ASYNCIO";
- break;
- case SI_SIGIO:
- codename = "SI_SIGIO";
- break;
- case SI_TKILL:
- codename = "SI_TKILL";
- break;
- default:
- qemu_log("%d", arg);
- return;
- }
- qemu_log("%s", codename);
- }
- static void get_target_siginfo(target_siginfo_t *tinfo,
- const target_siginfo_t *info)
- {
- abi_ulong sival_ptr;
- int sig;
- int si_errno;
- int si_code;
- int si_type;
- __get_user(sig, &info->si_signo);
- __get_user(si_errno, &tinfo->si_errno);
- __get_user(si_code, &info->si_code);
- tinfo->si_signo = sig;
- tinfo->si_errno = si_errno;
- tinfo->si_code = si_code;
- /* Ensure we don't leak random junk to the guest later */
- memset(tinfo->_sifields._pad, 0, sizeof(tinfo->_sifields._pad));
- /* This is awkward, because we have to use a combination of
- * the si_code and si_signo to figure out which of the union's
- * members are valid. (Within the host kernel it is always possible
- * to tell, but the kernel carefully avoids giving userspace the
- * high 16 bits of si_code, so we don't have the information to
- * do this the easy way...) We therefore make our best guess,
- * bearing in mind that a guest can spoof most of the si_codes
- * via rt_sigqueueinfo() if it likes.
- *
- * Once we have made our guess, we record it in the top 16 bits of
- * the si_code, so that print_siginfo() later can use it.
- * print_siginfo() will strip these top bits out before printing
- * the si_code.
- */
- switch (si_code) {
- case SI_USER:
- case SI_TKILL:
- case SI_KERNEL:
- /* Sent via kill(), tkill() or tgkill(), or direct from the kernel.
- * These are the only unspoofable si_code values.
- */
- __get_user(tinfo->_sifields._kill._pid, &info->_sifields._kill._pid);
- __get_user(tinfo->_sifields._kill._uid, &info->_sifields._kill._uid);
- si_type = QEMU_SI_KILL;
- break;
- default:
- /* Everything else is spoofable. Make best guess based on signal */
- switch (sig) {
- case TARGET_SIGCHLD:
- __get_user(tinfo->_sifields._sigchld._pid,
- &info->_sifields._sigchld._pid);
- __get_user(tinfo->_sifields._sigchld._uid,
- &info->_sifields._sigchld._uid);
- __get_user(tinfo->_sifields._sigchld._status,
- &info->_sifields._sigchld._status);
- __get_user(tinfo->_sifields._sigchld._utime,
- &info->_sifields._sigchld._utime);
- __get_user(tinfo->_sifields._sigchld._stime,
- &info->_sifields._sigchld._stime);
- si_type = QEMU_SI_CHLD;
- break;
- case TARGET_SIGIO:
- __get_user(tinfo->_sifields._sigpoll._band,
- &info->_sifields._sigpoll._band);
- __get_user(tinfo->_sifields._sigpoll._fd,
- &info->_sifields._sigpoll._fd);
- si_type = QEMU_SI_POLL;
- break;
- default:
- /* Assume a sigqueue()/mq_notify()/rt_sigqueueinfo() source. */
- __get_user(tinfo->_sifields._rt._pid, &info->_sifields._rt._pid);
- __get_user(tinfo->_sifields._rt._uid, &info->_sifields._rt._uid);
- /* XXX: potential problem if 64 bit */
- __get_user(sival_ptr, &info->_sifields._rt._sigval.sival_ptr);
- tinfo->_sifields._rt._sigval.sival_ptr = sival_ptr;
- si_type = QEMU_SI_RT;
- break;
- }
- break;
- }
- tinfo->si_code = deposit32(si_code, 16, 16, si_type);
- }
- static void print_siginfo(const target_siginfo_t *tinfo)
- {
- /* Print a target_siginfo_t in the format desired for printing
- * signals being taken. We assume the target_siginfo_t is in the
- * internal form where the top 16 bits of si_code indicate which
- * part of the union is valid, rather than in the guest-visible
- * form where the bottom 16 bits are sign-extended into the top 16.
- */
- int si_type = extract32(tinfo->si_code, 16, 16);
- int si_code = sextract32(tinfo->si_code, 0, 16);
- qemu_log("{si_signo=");
- print_signal(tinfo->si_signo, 1);
- qemu_log(", si_code=");
- print_si_code(si_code);
- switch (si_type) {
- case QEMU_SI_KILL:
- qemu_log(", si_pid=%u, si_uid=%u",
- (unsigned int)tinfo->_sifields._kill._pid,
- (unsigned int)tinfo->_sifields._kill._uid);
- break;
- case QEMU_SI_TIMER:
- qemu_log(", si_timer1=%u, si_timer2=%u",
- tinfo->_sifields._timer._timer1,
- tinfo->_sifields._timer._timer2);
- break;
- case QEMU_SI_POLL:
- qemu_log(", si_band=%d, si_fd=%d",
- tinfo->_sifields._sigpoll._band,
- tinfo->_sifields._sigpoll._fd);
- break;
- case QEMU_SI_FAULT:
- qemu_log(", si_addr=");
- print_pointer(tinfo->_sifields._sigfault._addr, 1);
- break;
- case QEMU_SI_CHLD:
- qemu_log(", si_pid=%u, si_uid=%u, si_status=%d"
- ", si_utime=" TARGET_ABI_FMT_ld
- ", si_stime=" TARGET_ABI_FMT_ld,
- (unsigned int)(tinfo->_sifields._sigchld._pid),
- (unsigned int)(tinfo->_sifields._sigchld._uid),
- tinfo->_sifields._sigchld._status,
- tinfo->_sifields._sigchld._utime,
- tinfo->_sifields._sigchld._stime);
- break;
- case QEMU_SI_RT:
- qemu_log(", si_pid=%u, si_uid=%u, si_sigval=" TARGET_ABI_FMT_ld,
- (unsigned int)tinfo->_sifields._rt._pid,
- (unsigned int)tinfo->_sifields._rt._uid,
- tinfo->_sifields._rt._sigval.sival_ptr);
- break;
- default:
- g_assert_not_reached();
- }
- qemu_log("}");
- }
- static void
- print_sockaddr(abi_ulong addr, abi_long addrlen, int last)
- {
- struct target_sockaddr *sa;
- int i;
- int sa_family;
- sa = lock_user(VERIFY_READ, addr, addrlen, 1);
- if (sa) {
- sa_family = tswap16(sa->sa_family);
- switch (sa_family) {
- case AF_UNIX: {
- struct target_sockaddr_un *un = (struct target_sockaddr_un *)sa;
- int i;
- qemu_log("{sun_family=AF_UNIX,sun_path=\"");
- for (i = 0; i < addrlen -
- offsetof(struct target_sockaddr_un, sun_path) &&
- un->sun_path[i]; i++) {
- qemu_log("%c", un->sun_path[i]);
- }
- qemu_log("\"}");
- break;
- }
- case AF_INET: {
- struct target_sockaddr_in *in = (struct target_sockaddr_in *)sa;
- uint8_t *c = (uint8_t *)&in->sin_addr.s_addr;
- qemu_log("{sin_family=AF_INET,sin_port=htons(%d),",
- ntohs(in->sin_port));
- qemu_log("sin_addr=inet_addr(\"%d.%d.%d.%d\")",
- c[0], c[1], c[2], c[3]);
- qemu_log("}");
- break;
- }
- case AF_PACKET: {
- struct target_sockaddr_ll *ll = (struct target_sockaddr_ll *)sa;
- uint8_t *c = (uint8_t *)&ll->sll_addr;
- qemu_log("{sll_family=AF_PACKET,"
- "sll_protocol=htons(0x%04x),if%d,pkttype=",
- ntohs(ll->sll_protocol), ll->sll_ifindex);
- switch (ll->sll_pkttype) {
- case PACKET_HOST:
- qemu_log("PACKET_HOST");
- break;
- case PACKET_BROADCAST:
- qemu_log("PACKET_BROADCAST");
- break;
- case PACKET_MULTICAST:
- qemu_log("PACKET_MULTICAST");
- break;
- case PACKET_OTHERHOST:
- qemu_log("PACKET_OTHERHOST");
- break;
- case PACKET_OUTGOING:
- qemu_log("PACKET_OUTGOING");
- break;
- default:
- qemu_log("%d", ll->sll_pkttype);
- break;
- }
- qemu_log(",sll_addr=%02x:%02x:%02x:%02x:%02x:%02x:%02x:%02x",
- c[0], c[1], c[2], c[3], c[4], c[5], c[6], c[7]);
- qemu_log("}");
- break;
- }
- case AF_NETLINK: {
- struct target_sockaddr_nl *nl = (struct target_sockaddr_nl *)sa;
- qemu_log("{nl_family=AF_NETLINK,nl_pid=%u,nl_groups=%u}",
- tswap32(nl->nl_pid), tswap32(nl->nl_groups));
- break;
- }
- default:
- qemu_log("{sa_family=%d, sa_data={", sa->sa_family);
- for (i = 0; i < 13; i++) {
- qemu_log("%02x, ", sa->sa_data[i]);
- }
- qemu_log("%02x}", sa->sa_data[i]);
- qemu_log("}");
- break;
- }
- unlock_user(sa, addr, 0);
- } else {
- print_raw_param("0x"TARGET_ABI_FMT_lx, addr, 0);
- }
- qemu_log(", "TARGET_ABI_FMT_ld"%s", addrlen, get_comma(last));
- }
- static void
- print_socket_domain(int domain)
- {
- switch (domain) {
- case PF_UNIX:
- qemu_log("PF_UNIX");
- break;
- case PF_INET:
- qemu_log("PF_INET");
- break;
- case PF_NETLINK:
- qemu_log("PF_NETLINK");
- break;
- case PF_PACKET:
- qemu_log("PF_PACKET");
- break;
- default:
- qemu_log("%d", domain);
- break;
- }
- }
- static void
- print_socket_type(int type)
- {
- switch (type & TARGET_SOCK_TYPE_MASK) {
- case TARGET_SOCK_DGRAM:
- qemu_log("SOCK_DGRAM");
- break;
- case TARGET_SOCK_STREAM:
- qemu_log("SOCK_STREAM");
- break;
- case TARGET_SOCK_RAW:
- qemu_log("SOCK_RAW");
- break;
- case TARGET_SOCK_RDM:
- qemu_log("SOCK_RDM");
- break;
- case TARGET_SOCK_SEQPACKET:
- qemu_log("SOCK_SEQPACKET");
- break;
- case TARGET_SOCK_PACKET:
- qemu_log("SOCK_PACKET");
- break;
- }
- if (type & TARGET_SOCK_CLOEXEC) {
- qemu_log("|SOCK_CLOEXEC");
- }
- if (type & TARGET_SOCK_NONBLOCK) {
- qemu_log("|SOCK_NONBLOCK");
- }
- }
- static void
- print_socket_protocol(int domain, int type, int protocol)
- {
- if (domain == AF_PACKET ||
- (domain == AF_INET && type == TARGET_SOCK_PACKET)) {
- switch (protocol) {
- case 0x0003:
- qemu_log("ETH_P_ALL");
- break;
- default:
- qemu_log("%d", protocol);
- }
- return;
- }
- if (domain == PF_NETLINK) {
- switch (protocol) {
- case NETLINK_ROUTE:
- qemu_log("NETLINK_ROUTE");
- break;
- case NETLINK_AUDIT:
- qemu_log("NETLINK_AUDIT");
- break;
- case NETLINK_NETFILTER:
- qemu_log("NETLINK_NETFILTER");
- break;
- case NETLINK_KOBJECT_UEVENT:
- qemu_log("NETLINK_KOBJECT_UEVENT");
- break;
- case NETLINK_RDMA:
- qemu_log("NETLINK_RDMA");
- break;
- case NETLINK_CRYPTO:
- qemu_log("NETLINK_CRYPTO");
- break;
- default:
- qemu_log("%d", protocol);
- break;
- }
- return;
- }
- switch (protocol) {
- case IPPROTO_IP:
- qemu_log("IPPROTO_IP");
- break;
- case IPPROTO_TCP:
- qemu_log("IPPROTO_TCP");
- break;
- case IPPROTO_UDP:
- qemu_log("IPPROTO_UDP");
- break;
- case IPPROTO_RAW:
- qemu_log("IPPROTO_RAW");
- break;
- default:
- qemu_log("%d", protocol);
- break;
- }
- }
- #ifdef TARGET_NR__newselect
- static void
- print_fdset(int n, abi_ulong target_fds_addr)
- {
- int i;
- int first = 1;
- qemu_log("[");
- if( target_fds_addr ) {
- abi_long *target_fds;
- target_fds = lock_user(VERIFY_READ,
- target_fds_addr,
- sizeof(*target_fds)*(n / TARGET_ABI_BITS + 1),
- 1);
- if (!target_fds)
- return;
- for (i=n; i>=0; i--) {
- if ((tswapal(target_fds[i / TARGET_ABI_BITS]) >>
- (i & (TARGET_ABI_BITS - 1))) & 1) {
- qemu_log("%s%d", get_comma(first), i);
- first = 0;
- }
- }
- unlock_user(target_fds, target_fds_addr, 0);
- }
- qemu_log("]");
- }
- #endif
- /*
- * Sysycall specific output functions
- */
- /* select */
- #ifdef TARGET_NR__newselect
- static void
- print_newselect(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg1, abi_long arg2, abi_long arg3,
- abi_long arg4, abi_long arg5, abi_long arg6)
- {
- print_syscall_prologue(name);
- print_fdset(arg1, arg2);
- qemu_log(",");
- print_fdset(arg1, arg3);
- qemu_log(",");
- print_fdset(arg1, arg4);
- qemu_log(",");
- print_timeval(arg5, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_semctl
- static void
- print_semctl(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg1, abi_long arg2, abi_long arg3,
- abi_long arg4, abi_long arg5, abi_long arg6)
- {
- qemu_log("%s(" TARGET_ABI_FMT_ld "," TARGET_ABI_FMT_ld ",",
- name->name, arg1, arg2);
- print_ipc_cmd(arg3);
- qemu_log(",0x" TARGET_ABI_FMT_lx ")", arg4);
- }
- #endif
- static void
- print_execve(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg1, abi_long arg2, abi_long arg3,
- abi_long arg4, abi_long arg5, abi_long arg6)
- {
- abi_ulong arg_ptr_addr;
- char *s;
- if (!(s = lock_user_string(arg1)))
- return;
- qemu_log("%s(\"%s\",{", name->name, s);
- unlock_user(s, arg1, 0);
- for (arg_ptr_addr = arg2; ; arg_ptr_addr += sizeof(abi_ulong)) {
- abi_ulong *arg_ptr, arg_addr;
- arg_ptr = lock_user(VERIFY_READ, arg_ptr_addr, sizeof(abi_ulong), 1);
- if (!arg_ptr)
- return;
- arg_addr = tswapal(*arg_ptr);
- unlock_user(arg_ptr, arg_ptr_addr, 0);
- if (!arg_addr)
- break;
- if ((s = lock_user_string(arg_addr))) {
- qemu_log("\"%s\",", s);
- unlock_user(s, arg_addr, 0);
- }
- }
- qemu_log("NULL})");
- }
- #ifdef TARGET_NR_ipc
- static void
- print_ipc(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg1, abi_long arg2, abi_long arg3,
- abi_long arg4, abi_long arg5, abi_long arg6)
- {
- switch(arg1) {
- case IPCOP_semctl:
- qemu_log("semctl(" TARGET_ABI_FMT_ld "," TARGET_ABI_FMT_ld ",",
- arg1, arg2);
- print_ipc_cmd(arg3);
- qemu_log(",0x" TARGET_ABI_FMT_lx ")", arg4);
- break;
- default:
- qemu_log(("%s("
- TARGET_ABI_FMT_ld ","
- TARGET_ABI_FMT_ld ","
- TARGET_ABI_FMT_ld ","
- TARGET_ABI_FMT_ld
- ")"),
- name->name, arg1, arg2, arg3, arg4);
- }
- }
- #endif
- /*
- * Variants for the return value output function
- */
- static bool
- print_syscall_err(abi_long ret)
- {
- const char *errstr;
- qemu_log(" = ");
- if (is_error(ret)) {
- errstr = target_strerror(-ret);
- if (errstr) {
- qemu_log("-1 errno=%d (%s)", (int)-ret, errstr);
- return true;
- }
- }
- return false;
- }
- static void
- print_syscall_ret_addr(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long ret, abi_long arg0, abi_long arg1,
- abi_long arg2, abi_long arg3, abi_long arg4,
- abi_long arg5)
- {
- if (!print_syscall_err(ret)) {
- qemu_log("0x" TARGET_ABI_FMT_lx, ret);
- }
- qemu_log("\n");
- }
- #if 0 /* currently unused */
- static void
- print_syscall_ret_raw(struct syscallname *name, abi_long ret)
- {
- qemu_log(" = 0x" TARGET_ABI_FMT_lx "\n", ret);
- }
- #endif
- #ifdef TARGET_NR__newselect
- static void
- print_syscall_ret_newselect(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long ret, abi_long arg0, abi_long arg1,
- abi_long arg2, abi_long arg3, abi_long arg4,
- abi_long arg5)
- {
- if (!print_syscall_err(ret)) {
- qemu_log(" = 0x" TARGET_ABI_FMT_lx " (", ret);
- print_fdset(arg0, arg1);
- qemu_log(",");
- print_fdset(arg0, arg2);
- qemu_log(",");
- print_fdset(arg0, arg3);
- qemu_log(",");
- print_timeval(arg4, 1);
- qemu_log(")");
- }
- qemu_log("\n");
- }
- #endif
- /* special meanings of adjtimex()' non-negative return values */
- #define TARGET_TIME_OK 0 /* clock synchronized, no leap second */
- #define TARGET_TIME_INS 1 /* insert leap second */
- #define TARGET_TIME_DEL 2 /* delete leap second */
- #define TARGET_TIME_OOP 3 /* leap second in progress */
- #define TARGET_TIME_WAIT 4 /* leap second has occurred */
- #define TARGET_TIME_ERROR 5 /* clock not synchronized */
- #ifdef TARGET_NR_adjtimex
- static void
- print_syscall_ret_adjtimex(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long ret, abi_long arg0, abi_long arg1,
- abi_long arg2, abi_long arg3, abi_long arg4,
- abi_long arg5)
- {
- if (!print_syscall_err(ret)) {
- qemu_log(TARGET_ABI_FMT_ld, ret);
- switch (ret) {
- case TARGET_TIME_OK:
- qemu_log(" TIME_OK (clock synchronized, no leap second)");
- break;
- case TARGET_TIME_INS:
- qemu_log(" TIME_INS (insert leap second)");
- break;
- case TARGET_TIME_DEL:
- qemu_log(" TIME_DEL (delete leap second)");
- break;
- case TARGET_TIME_OOP:
- qemu_log(" TIME_OOP (leap second in progress)");
- break;
- case TARGET_TIME_WAIT:
- qemu_log(" TIME_WAIT (leap second has occurred)");
- break;
- case TARGET_TIME_ERROR:
- qemu_log(" TIME_ERROR (clock not synchronized)");
- break;
- }
- }
- qemu_log("\n");
- }
- #endif
- #if defined(TARGET_NR_clock_gettime) || defined(TARGET_NR_clock_getres)
- static void
- print_syscall_ret_clock_gettime(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long ret, abi_long arg0, abi_long arg1,
- abi_long arg2, abi_long arg3, abi_long arg4,
- abi_long arg5)
- {
- if (!print_syscall_err(ret)) {
- qemu_log(TARGET_ABI_FMT_ld, ret);
- qemu_log(" (");
- print_timespec(arg1, 1);
- qemu_log(")");
- }
- qemu_log("\n");
- }
- #define print_syscall_ret_clock_getres print_syscall_ret_clock_gettime
- #endif
- #if defined(TARGET_NR_clock_gettime64)
- static void
- print_syscall_ret_clock_gettime64(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long ret, abi_long arg0, abi_long arg1,
- abi_long arg2, abi_long arg3, abi_long arg4,
- abi_long arg5)
- {
- if (!print_syscall_err(ret)) {
- qemu_log(TARGET_ABI_FMT_ld, ret);
- qemu_log(" (");
- print_timespec64(arg1, 1);
- qemu_log(")");
- }
- qemu_log("\n");
- }
- #endif
- #ifdef TARGET_NR_gettimeofday
- static void
- print_syscall_ret_gettimeofday(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long ret, abi_long arg0, abi_long arg1,
- abi_long arg2, abi_long arg3, abi_long arg4,
- abi_long arg5)
- {
- if (!print_syscall_err(ret)) {
- qemu_log(TARGET_ABI_FMT_ld, ret);
- qemu_log(" (");
- print_timeval(arg0, 0);
- print_timezone(arg1, 1);
- qemu_log(")");
- }
- qemu_log("\n");
- }
- #endif
- #ifdef TARGET_NR_getitimer
- static void
- print_syscall_ret_getitimer(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long ret, abi_long arg0, abi_long arg1,
- abi_long arg2, abi_long arg3, abi_long arg4,
- abi_long arg5)
- {
- if (!print_syscall_err(ret)) {
- qemu_log(TARGET_ABI_FMT_ld, ret);
- qemu_log(" (");
- print_itimerval(arg1, 1);
- qemu_log(")");
- }
- qemu_log("\n");
- }
- #endif
- #ifdef TARGET_NR_getitimer
- static void
- print_syscall_ret_setitimer(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long ret, abi_long arg0, abi_long arg1,
- abi_long arg2, abi_long arg3, abi_long arg4,
- abi_long arg5)
- {
- if (!print_syscall_err(ret)) {
- qemu_log(TARGET_ABI_FMT_ld, ret);
- qemu_log(" (old_value = ");
- print_itimerval(arg2, 1);
- qemu_log(")");
- }
- qemu_log("\n");
- }
- #endif
- #if defined(TARGET_NR_listxattr) || defined(TARGET_NR_llistxattr) \
- || defined(TARGGET_NR_flistxattr)
- static void
- print_syscall_ret_listxattr(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long ret, abi_long arg0, abi_long arg1,
- abi_long arg2, abi_long arg3, abi_long arg4,
- abi_long arg5)
- {
- if (!print_syscall_err(ret)) {
- qemu_log(TARGET_ABI_FMT_ld, ret);
- qemu_log(" (list = ");
- if (arg1 != 0) {
- abi_long attr = arg1;
- while (ret) {
- if (attr != arg1) {
- qemu_log(",");
- }
- print_string(attr, 1);
- ret -= target_strlen(attr) + 1;
- attr += target_strlen(attr) + 1;
- }
- } else {
- qemu_log("NULL");
- }
- qemu_log(")");
- }
- qemu_log("\n");
- }
- #define print_syscall_ret_llistxattr print_syscall_ret_listxattr
- #define print_syscall_ret_flistxattr print_syscall_ret_listxattr
- #endif
- #ifdef TARGET_NR_ioctl
- static void
- print_syscall_ret_ioctl(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long ret, abi_long arg0, abi_long arg1,
- abi_long arg2, abi_long arg3, abi_long arg4,
- abi_long arg5)
- {
- if (!print_syscall_err(ret)) {
- qemu_log(TARGET_ABI_FMT_ld, ret);
- const IOCTLEntry *ie;
- const argtype *arg_type;
- void *argptr;
- int target_size;
- for (ie = ioctl_entries; ie->target_cmd != 0; ie++) {
- if (ie->target_cmd == arg1) {
- break;
- }
- }
- if (ie->target_cmd == arg1 &&
- (ie->access == IOC_R || ie->access == IOC_RW)) {
- arg_type = ie->arg_type;
- qemu_log(" (");
- arg_type++;
- target_size = thunk_type_size(arg_type, 0);
- argptr = lock_user(VERIFY_READ, arg2, target_size, 1);
- if (argptr) {
- thunk_print(argptr, arg_type);
- unlock_user(argptr, arg2, target_size);
- } else {
- print_pointer(arg2, 1);
- }
- qemu_log(")");
- }
- }
- qemu_log("\n");
- }
- #endif
- UNUSED static struct flags access_flags[] = {
- FLAG_GENERIC(F_OK),
- FLAG_GENERIC(R_OK),
- FLAG_GENERIC(W_OK),
- FLAG_GENERIC(X_OK),
- FLAG_END,
- };
- UNUSED static struct flags at_file_flags[] = {
- #ifdef AT_EACCESS
- FLAG_GENERIC(AT_EACCESS),
- #endif
- #ifdef AT_SYMLINK_NOFOLLOW
- FLAG_GENERIC(AT_SYMLINK_NOFOLLOW),
- #endif
- FLAG_END,
- };
- UNUSED static struct flags unlinkat_flags[] = {
- #ifdef AT_REMOVEDIR
- FLAG_GENERIC(AT_REMOVEDIR),
- #endif
- FLAG_END,
- };
- UNUSED static struct flags mode_flags[] = {
- FLAG_GENERIC(S_IFSOCK),
- FLAG_GENERIC(S_IFLNK),
- FLAG_GENERIC(S_IFREG),
- FLAG_GENERIC(S_IFBLK),
- FLAG_GENERIC(S_IFDIR),
- FLAG_GENERIC(S_IFCHR),
- FLAG_GENERIC(S_IFIFO),
- FLAG_END,
- };
- UNUSED static struct flags open_access_flags[] = {
- FLAG_TARGET(O_RDONLY),
- FLAG_TARGET(O_WRONLY),
- FLAG_TARGET(O_RDWR),
- FLAG_END,
- };
- UNUSED static struct flags open_flags[] = {
- FLAG_TARGET(O_APPEND),
- FLAG_TARGET(O_CREAT),
- FLAG_TARGET(O_DIRECTORY),
- FLAG_TARGET(O_EXCL),
- FLAG_TARGET(O_LARGEFILE),
- FLAG_TARGET(O_NOCTTY),
- FLAG_TARGET(O_NOFOLLOW),
- FLAG_TARGET(O_NONBLOCK), /* also O_NDELAY */
- FLAG_TARGET(O_DSYNC),
- FLAG_TARGET(__O_SYNC),
- FLAG_TARGET(O_TRUNC),
- #ifdef O_DIRECT
- FLAG_TARGET(O_DIRECT),
- #endif
- #ifdef O_NOATIME
- FLAG_TARGET(O_NOATIME),
- #endif
- #ifdef O_CLOEXEC
- FLAG_TARGET(O_CLOEXEC),
- #endif
- #ifdef O_PATH
- FLAG_TARGET(O_PATH),
- #endif
- #ifdef O_TMPFILE
- FLAG_TARGET(O_TMPFILE),
- FLAG_TARGET(__O_TMPFILE),
- #endif
- FLAG_END,
- };
- UNUSED static struct flags mount_flags[] = {
- #ifdef MS_BIND
- FLAG_GENERIC(MS_BIND),
- #endif
- #ifdef MS_DIRSYNC
- FLAG_GENERIC(MS_DIRSYNC),
- #endif
- FLAG_GENERIC(MS_MANDLOCK),
- #ifdef MS_MOVE
- FLAG_GENERIC(MS_MOVE),
- #endif
- FLAG_GENERIC(MS_NOATIME),
- FLAG_GENERIC(MS_NODEV),
- FLAG_GENERIC(MS_NODIRATIME),
- FLAG_GENERIC(MS_NOEXEC),
- FLAG_GENERIC(MS_NOSUID),
- FLAG_GENERIC(MS_RDONLY),
- #ifdef MS_RELATIME
- FLAG_GENERIC(MS_RELATIME),
- #endif
- FLAG_GENERIC(MS_REMOUNT),
- FLAG_GENERIC(MS_SYNCHRONOUS),
- FLAG_END,
- };
- UNUSED static struct flags umount2_flags[] = {
- #ifdef MNT_FORCE
- FLAG_GENERIC(MNT_FORCE),
- #endif
- #ifdef MNT_DETACH
- FLAG_GENERIC(MNT_DETACH),
- #endif
- #ifdef MNT_EXPIRE
- FLAG_GENERIC(MNT_EXPIRE),
- #endif
- FLAG_END,
- };
- UNUSED static struct flags mmap_prot_flags[] = {
- FLAG_GENERIC(PROT_NONE),
- FLAG_GENERIC(PROT_EXEC),
- FLAG_GENERIC(PROT_READ),
- FLAG_GENERIC(PROT_WRITE),
- FLAG_TARGET(PROT_SEM),
- FLAG_GENERIC(PROT_GROWSDOWN),
- FLAG_GENERIC(PROT_GROWSUP),
- FLAG_END,
- };
- UNUSED static struct flags mmap_flags[] = {
- FLAG_TARGET(MAP_SHARED),
- FLAG_TARGET(MAP_PRIVATE),
- FLAG_TARGET(MAP_ANONYMOUS),
- FLAG_TARGET(MAP_DENYWRITE),
- FLAG_TARGET(MAP_FIXED),
- FLAG_TARGET(MAP_GROWSDOWN),
- FLAG_TARGET(MAP_EXECUTABLE),
- #ifdef MAP_LOCKED
- FLAG_TARGET(MAP_LOCKED),
- #endif
- #ifdef MAP_NONBLOCK
- FLAG_TARGET(MAP_NONBLOCK),
- #endif
- FLAG_TARGET(MAP_NORESERVE),
- #ifdef MAP_POPULATE
- FLAG_TARGET(MAP_POPULATE),
- #endif
- #ifdef TARGET_MAP_UNINITIALIZED
- FLAG_TARGET(MAP_UNINITIALIZED),
- #endif
- FLAG_END,
- };
- UNUSED static struct flags clone_flags[] = {
- FLAG_GENERIC(CLONE_VM),
- FLAG_GENERIC(CLONE_FS),
- FLAG_GENERIC(CLONE_FILES),
- FLAG_GENERIC(CLONE_SIGHAND),
- FLAG_GENERIC(CLONE_PTRACE),
- FLAG_GENERIC(CLONE_VFORK),
- FLAG_GENERIC(CLONE_PARENT),
- FLAG_GENERIC(CLONE_THREAD),
- FLAG_GENERIC(CLONE_NEWNS),
- FLAG_GENERIC(CLONE_SYSVSEM),
- FLAG_GENERIC(CLONE_SETTLS),
- FLAG_GENERIC(CLONE_PARENT_SETTID),
- FLAG_GENERIC(CLONE_CHILD_CLEARTID),
- FLAG_GENERIC(CLONE_DETACHED),
- FLAG_GENERIC(CLONE_UNTRACED),
- FLAG_GENERIC(CLONE_CHILD_SETTID),
- #if defined(CLONE_NEWUTS)
- FLAG_GENERIC(CLONE_NEWUTS),
- #endif
- #if defined(CLONE_NEWIPC)
- FLAG_GENERIC(CLONE_NEWIPC),
- #endif
- #if defined(CLONE_NEWUSER)
- FLAG_GENERIC(CLONE_NEWUSER),
- #endif
- #if defined(CLONE_NEWPID)
- FLAG_GENERIC(CLONE_NEWPID),
- #endif
- #if defined(CLONE_NEWNET)
- FLAG_GENERIC(CLONE_NEWNET),
- #endif
- #if defined(CLONE_NEWCGROUP)
- FLAG_GENERIC(CLONE_NEWCGROUP),
- #endif
- #if defined(CLONE_NEWTIME)
- FLAG_GENERIC(CLONE_NEWTIME),
- #endif
- #if defined(CLONE_IO)
- FLAG_GENERIC(CLONE_IO),
- #endif
- FLAG_END,
- };
- UNUSED static struct flags msg_flags[] = {
- /* send */
- FLAG_GENERIC(MSG_CONFIRM),
- FLAG_GENERIC(MSG_DONTROUTE),
- FLAG_GENERIC(MSG_DONTWAIT),
- FLAG_GENERIC(MSG_EOR),
- FLAG_GENERIC(MSG_MORE),
- FLAG_GENERIC(MSG_NOSIGNAL),
- FLAG_GENERIC(MSG_OOB),
- /* recv */
- FLAG_GENERIC(MSG_CMSG_CLOEXEC),
- FLAG_GENERIC(MSG_ERRQUEUE),
- FLAG_GENERIC(MSG_PEEK),
- FLAG_GENERIC(MSG_TRUNC),
- FLAG_GENERIC(MSG_WAITALL),
- /* recvmsg */
- FLAG_GENERIC(MSG_CTRUNC),
- FLAG_END,
- };
- UNUSED static struct flags statx_flags[] = {
- #ifdef AT_EMPTY_PATH
- FLAG_GENERIC(AT_EMPTY_PATH),
- #endif
- #ifdef AT_NO_AUTOMOUNT
- FLAG_GENERIC(AT_NO_AUTOMOUNT),
- #endif
- #ifdef AT_SYMLINK_NOFOLLOW
- FLAG_GENERIC(AT_SYMLINK_NOFOLLOW),
- #endif
- #ifdef AT_STATX_SYNC_AS_STAT
- FLAG_GENERIC(AT_STATX_SYNC_AS_STAT),
- #endif
- #ifdef AT_STATX_FORCE_SYNC
- FLAG_GENERIC(AT_STATX_FORCE_SYNC),
- #endif
- #ifdef AT_STATX_DONT_SYNC
- FLAG_GENERIC(AT_STATX_DONT_SYNC),
- #endif
- FLAG_END,
- };
- UNUSED static struct flags statx_mask[] = {
- /* This must come first, because it includes everything. */
- #ifdef STATX_ALL
- FLAG_GENERIC(STATX_ALL),
- #endif
- /* This must come second; it includes everything except STATX_BTIME. */
- #ifdef STATX_BASIC_STATS
- FLAG_GENERIC(STATX_BASIC_STATS),
- #endif
- #ifdef STATX_TYPE
- FLAG_GENERIC(STATX_TYPE),
- #endif
- #ifdef STATX_MODE
- FLAG_GENERIC(STATX_MODE),
- #endif
- #ifdef STATX_NLINK
- FLAG_GENERIC(STATX_NLINK),
- #endif
- #ifdef STATX_UID
- FLAG_GENERIC(STATX_UID),
- #endif
- #ifdef STATX_GID
- FLAG_GENERIC(STATX_GID),
- #endif
- #ifdef STATX_ATIME
- FLAG_GENERIC(STATX_ATIME),
- #endif
- #ifdef STATX_MTIME
- FLAG_GENERIC(STATX_MTIME),
- #endif
- #ifdef STATX_CTIME
- FLAG_GENERIC(STATX_CTIME),
- #endif
- #ifdef STATX_INO
- FLAG_GENERIC(STATX_INO),
- #endif
- #ifdef STATX_SIZE
- FLAG_GENERIC(STATX_SIZE),
- #endif
- #ifdef STATX_BLOCKS
- FLAG_GENERIC(STATX_BLOCKS),
- #endif
- #ifdef STATX_BTIME
- FLAG_GENERIC(STATX_BTIME),
- #endif
- FLAG_END,
- };
- UNUSED static struct flags falloc_flags[] = {
- FLAG_GENERIC(FALLOC_FL_KEEP_SIZE),
- FLAG_GENERIC(FALLOC_FL_PUNCH_HOLE),
- #ifdef FALLOC_FL_NO_HIDE_STALE
- FLAG_GENERIC(FALLOC_FL_NO_HIDE_STALE),
- #endif
- #ifdef FALLOC_FL_COLLAPSE_RANGE
- FLAG_GENERIC(FALLOC_FL_COLLAPSE_RANGE),
- #endif
- #ifdef FALLOC_FL_ZERO_RANGE
- FLAG_GENERIC(FALLOC_FL_ZERO_RANGE),
- #endif
- #ifdef FALLOC_FL_INSERT_RANGE
- FLAG_GENERIC(FALLOC_FL_INSERT_RANGE),
- #endif
- #ifdef FALLOC_FL_UNSHARE_RANGE
- FLAG_GENERIC(FALLOC_FL_UNSHARE_RANGE),
- #endif
- };
- UNUSED static struct flags termios_iflags[] = {
- FLAG_TARGET(IGNBRK),
- FLAG_TARGET(BRKINT),
- FLAG_TARGET(IGNPAR),
- FLAG_TARGET(PARMRK),
- FLAG_TARGET(INPCK),
- FLAG_TARGET(ISTRIP),
- FLAG_TARGET(INLCR),
- FLAG_TARGET(IGNCR),
- FLAG_TARGET(ICRNL),
- FLAG_TARGET(IUCLC),
- FLAG_TARGET(IXON),
- FLAG_TARGET(IXANY),
- FLAG_TARGET(IXOFF),
- FLAG_TARGET(IMAXBEL),
- FLAG_TARGET(IUTF8),
- FLAG_END,
- };
- UNUSED static struct flags termios_oflags[] = {
- FLAG_TARGET(OPOST),
- FLAG_TARGET(OLCUC),
- FLAG_TARGET(ONLCR),
- FLAG_TARGET(OCRNL),
- FLAG_TARGET(ONOCR),
- FLAG_TARGET(ONLRET),
- FLAG_TARGET(OFILL),
- FLAG_TARGET(OFDEL),
- FLAG_END,
- };
- UNUSED static struct enums termios_oflags_NLDLY[] = {
- ENUM_TARGET(NL0),
- ENUM_TARGET(NL1),
- ENUM_END,
- };
- UNUSED static struct enums termios_oflags_CRDLY[] = {
- ENUM_TARGET(CR0),
- ENUM_TARGET(CR1),
- ENUM_TARGET(CR2),
- ENUM_TARGET(CR3),
- ENUM_END,
- };
- UNUSED static struct enums termios_oflags_TABDLY[] = {
- ENUM_TARGET(TAB0),
- ENUM_TARGET(TAB1),
- ENUM_TARGET(TAB2),
- ENUM_TARGET(TAB3),
- ENUM_END,
- };
- UNUSED static struct enums termios_oflags_VTDLY[] = {
- ENUM_TARGET(VT0),
- ENUM_TARGET(VT1),
- ENUM_END,
- };
- UNUSED static struct enums termios_oflags_FFDLY[] = {
- ENUM_TARGET(FF0),
- ENUM_TARGET(FF1),
- ENUM_END,
- };
- UNUSED static struct enums termios_oflags_BSDLY[] = {
- ENUM_TARGET(BS0),
- ENUM_TARGET(BS1),
- ENUM_END,
- };
- UNUSED static struct enums termios_cflags_CBAUD[] = {
- ENUM_TARGET(B0),
- ENUM_TARGET(B50),
- ENUM_TARGET(B75),
- ENUM_TARGET(B110),
- ENUM_TARGET(B134),
- ENUM_TARGET(B150),
- ENUM_TARGET(B200),
- ENUM_TARGET(B300),
- ENUM_TARGET(B600),
- ENUM_TARGET(B1200),
- ENUM_TARGET(B1800),
- ENUM_TARGET(B2400),
- ENUM_TARGET(B4800),
- ENUM_TARGET(B9600),
- ENUM_TARGET(B19200),
- ENUM_TARGET(B38400),
- ENUM_TARGET(B57600),
- ENUM_TARGET(B115200),
- ENUM_TARGET(B230400),
- ENUM_TARGET(B460800),
- ENUM_END,
- };
- UNUSED static struct enums termios_cflags_CSIZE[] = {
- ENUM_TARGET(CS5),
- ENUM_TARGET(CS6),
- ENUM_TARGET(CS7),
- ENUM_TARGET(CS8),
- ENUM_END,
- };
- UNUSED static struct flags termios_cflags[] = {
- FLAG_TARGET(CSTOPB),
- FLAG_TARGET(CREAD),
- FLAG_TARGET(PARENB),
- FLAG_TARGET(PARODD),
- FLAG_TARGET(HUPCL),
- FLAG_TARGET(CLOCAL),
- FLAG_TARGET(CRTSCTS),
- FLAG_END,
- };
- UNUSED static struct flags termios_lflags[] = {
- FLAG_TARGET(ISIG),
- FLAG_TARGET(ICANON),
- FLAG_TARGET(XCASE),
- FLAG_TARGET(ECHO),
- FLAG_TARGET(ECHOE),
- FLAG_TARGET(ECHOK),
- FLAG_TARGET(ECHONL),
- FLAG_TARGET(NOFLSH),
- FLAG_TARGET(TOSTOP),
- FLAG_TARGET(ECHOCTL),
- FLAG_TARGET(ECHOPRT),
- FLAG_TARGET(ECHOKE),
- FLAG_TARGET(FLUSHO),
- FLAG_TARGET(PENDIN),
- FLAG_TARGET(IEXTEN),
- FLAG_TARGET(EXTPROC),
- FLAG_END,
- };
- UNUSED static struct flags mlockall_flags[] = {
- FLAG_TARGET(MCL_CURRENT),
- FLAG_TARGET(MCL_FUTURE),
- #ifdef MCL_ONFAULT
- FLAG_TARGET(MCL_ONFAULT),
- #endif
- FLAG_END,
- };
- /* IDs of the various system clocks */
- #define TARGET_CLOCK_REALTIME 0
- #define TARGET_CLOCK_MONOTONIC 1
- #define TARGET_CLOCK_PROCESS_CPUTIME_ID 2
- #define TARGET_CLOCK_THREAD_CPUTIME_ID 3
- #define TARGET_CLOCK_MONOTONIC_RAW 4
- #define TARGET_CLOCK_REALTIME_COARSE 5
- #define TARGET_CLOCK_MONOTONIC_COARSE 6
- #define TARGET_CLOCK_BOOTTIME 7
- #define TARGET_CLOCK_REALTIME_ALARM 8
- #define TARGET_CLOCK_BOOTTIME_ALARM 9
- #define TARGET_CLOCK_SGI_CYCLE 10
- #define TARGET_CLOCK_TAI 11
- UNUSED static struct enums clockids[] = {
- ENUM_TARGET(CLOCK_REALTIME),
- ENUM_TARGET(CLOCK_MONOTONIC),
- ENUM_TARGET(CLOCK_PROCESS_CPUTIME_ID),
- ENUM_TARGET(CLOCK_THREAD_CPUTIME_ID),
- ENUM_TARGET(CLOCK_MONOTONIC_RAW),
- ENUM_TARGET(CLOCK_REALTIME_COARSE),
- ENUM_TARGET(CLOCK_MONOTONIC_COARSE),
- ENUM_TARGET(CLOCK_BOOTTIME),
- ENUM_TARGET(CLOCK_REALTIME_ALARM),
- ENUM_TARGET(CLOCK_BOOTTIME_ALARM),
- ENUM_TARGET(CLOCK_SGI_CYCLE),
- ENUM_TARGET(CLOCK_TAI),
- ENUM_END,
- };
- UNUSED static struct enums itimer_types[] = {
- ENUM_GENERIC(ITIMER_REAL),
- ENUM_GENERIC(ITIMER_VIRTUAL),
- ENUM_GENERIC(ITIMER_PROF),
- ENUM_END,
- };
- /*
- * print_xxx utility functions. These are used to print syscall
- * parameters in certain format. All of these have parameter
- * named 'last'. This parameter is used to add comma to output
- * when last == 0.
- */
- static const char *
- get_comma(int last)
- {
- return ((last) ? "" : ",");
- }
- static void
- print_flags(const struct flags *f, abi_long flags, int last)
- {
- const char *sep = "";
- int n;
- if ((flags == 0) && (f->f_value == 0)) {
- qemu_log("%s%s", f->f_string, get_comma(last));
- return;
- }
- for (n = 0; f->f_string != NULL; f++) {
- if ((f->f_value != 0) && ((flags & f->f_value) == f->f_value)) {
- qemu_log("%s%s", sep, f->f_string);
- flags &= ~f->f_value;
- sep = "|";
- n++;
- }
- }
- if (n > 0) {
- /* print rest of the flags as numeric */
- if (flags != 0) {
- qemu_log("%s%#x%s", sep, (unsigned int)flags, get_comma(last));
- } else {
- qemu_log("%s", get_comma(last));
- }
- } else {
- /* no string version of flags found, print them in hex then */
- qemu_log("%#x%s", (unsigned int)flags, get_comma(last));
- }
- }
- static void
- print_enums(const struct enums *e, abi_long enum_arg, int last)
- {
- for (; e->e_string != NULL; e++) {
- if (e->e_value == enum_arg) {
- qemu_log("%s", e->e_string);
- break;
- }
- }
- if (e->e_string == NULL) {
- qemu_log("%#x", (unsigned int)enum_arg);
- }
- qemu_log("%s", get_comma(last));
- }
- static void
- print_at_dirfd(abi_long dirfd, int last)
- {
- #ifdef AT_FDCWD
- if (dirfd == AT_FDCWD) {
- qemu_log("AT_FDCWD%s", get_comma(last));
- return;
- }
- #endif
- qemu_log("%d%s", (int)dirfd, get_comma(last));
- }
- static void
- print_file_mode(abi_long mode, int last)
- {
- const char *sep = "";
- const struct flags *m;
- if (mode == 0) {
- qemu_log("000%s", get_comma(last));
- return;
- }
- for (m = &mode_flags[0]; m->f_string != NULL; m++) {
- if ((m->f_value & mode) == m->f_value) {
- qemu_log("%s%s", m->f_string, sep);
- sep = "|";
- mode &= ~m->f_value;
- break;
- }
- }
- mode &= ~S_IFMT;
- /* print rest of the mode as octal */
- if (mode != 0)
- qemu_log("%s%#o", sep, (unsigned int)mode);
- qemu_log("%s", get_comma(last));
- }
- static void
- print_open_flags(abi_long flags, int last)
- {
- print_flags(open_access_flags, flags & TARGET_O_ACCMODE, 1);
- flags &= ~TARGET_O_ACCMODE;
- if (flags == 0) {
- qemu_log("%s", get_comma(last));
- return;
- }
- qemu_log("|");
- print_flags(open_flags, flags, last);
- }
- static void
- print_syscall_prologue(const struct syscallname *sc)
- {
- qemu_log("%s(", sc->name);
- }
- /*ARGSUSED*/
- static void
- print_syscall_epilogue(const struct syscallname *sc)
- {
- (void)sc;
- qemu_log(")");
- }
- static void
- print_string(abi_long addr, int last)
- {
- char *s;
- if ((s = lock_user_string(addr)) != NULL) {
- qemu_log("\"%s\"%s", s, get_comma(last));
- unlock_user(s, addr, 0);
- } else {
- /* can't get string out of it, so print it as pointer */
- print_pointer(addr, last);
- }
- }
- #define MAX_PRINT_BUF 40
- static void
- print_buf(abi_long addr, abi_long len, int last)
- {
- uint8_t *s;
- int i;
- s = lock_user(VERIFY_READ, addr, len, 1);
- if (s) {
- qemu_log("\"");
- for (i = 0; i < MAX_PRINT_BUF && i < len; i++) {
- if (isprint(s[i])) {
- qemu_log("%c", s[i]);
- } else {
- qemu_log("\\%o", s[i]);
- }
- }
- qemu_log("\"");
- if (i != len) {
- qemu_log("...");
- }
- if (!last) {
- qemu_log(",");
- }
- unlock_user(s, addr, 0);
- } else {
- print_pointer(addr, last);
- }
- }
- /*
- * Prints out raw parameter using given format. Caller needs
- * to do byte swapping if needed.
- */
- static void
- print_raw_param(const char *fmt, abi_long param, int last)
- {
- char format[64];
- (void) snprintf(format, sizeof (format), "%s%s", fmt, get_comma(last));
- qemu_log(format, param);
- }
- static void
- print_pointer(abi_long p, int last)
- {
- if (p == 0)
- qemu_log("NULL%s", get_comma(last));
- else
- qemu_log("0x" TARGET_ABI_FMT_lx "%s", p, get_comma(last));
- }
- /*
- * Reads 32-bit (int) number from guest address space from
- * address 'addr' and prints it.
- */
- static void
- print_number(abi_long addr, int last)
- {
- if (addr == 0) {
- qemu_log("NULL%s", get_comma(last));
- } else {
- int num;
- get_user_s32(num, addr);
- qemu_log("[%d]%s", num, get_comma(last));
- }
- }
- static void
- print_timeval(abi_ulong tv_addr, int last)
- {
- if( tv_addr ) {
- struct target_timeval *tv;
- tv = lock_user(VERIFY_READ, tv_addr, sizeof(*tv), 1);
- if (!tv) {
- print_pointer(tv_addr, last);
- return;
- }
- qemu_log("{tv_sec = " TARGET_ABI_FMT_ld
- ",tv_usec = " TARGET_ABI_FMT_ld "}%s",
- tswapal(tv->tv_sec), tswapal(tv->tv_usec), get_comma(last));
- unlock_user(tv, tv_addr, 0);
- } else
- qemu_log("NULL%s", get_comma(last));
- }
- static void
- print_timespec(abi_ulong ts_addr, int last)
- {
- if (ts_addr) {
- struct target_timespec *ts;
- ts = lock_user(VERIFY_READ, ts_addr, sizeof(*ts), 1);
- if (!ts) {
- print_pointer(ts_addr, last);
- return;
- }
- qemu_log("{tv_sec = " TARGET_ABI_FMT_ld
- ",tv_nsec = " TARGET_ABI_FMT_ld "}%s",
- tswapal(ts->tv_sec), tswapal(ts->tv_nsec), get_comma(last));
- unlock_user(ts, ts_addr, 0);
- } else {
- qemu_log("NULL%s", get_comma(last));
- }
- }
- static void
- print_timespec64(abi_ulong ts_addr, int last)
- {
- if (ts_addr) {
- struct target__kernel_timespec *ts;
- ts = lock_user(VERIFY_READ, ts_addr, sizeof(*ts), 1);
- if (!ts) {
- print_pointer(ts_addr, last);
- return;
- }
- qemu_log("{tv_sec = %lld"
- ",tv_nsec = %lld}%s",
- (long long)tswap64(ts->tv_sec), (long long)tswap64(ts->tv_nsec),
- get_comma(last));
- unlock_user(ts, ts_addr, 0);
- } else {
- qemu_log("NULL%s", get_comma(last));
- }
- }
- static void
- print_timezone(abi_ulong tz_addr, int last)
- {
- if (tz_addr) {
- struct target_timezone *tz;
- tz = lock_user(VERIFY_READ, tz_addr, sizeof(*tz), 1);
- if (!tz) {
- print_pointer(tz_addr, last);
- return;
- }
- qemu_log("{%d,%d}%s", tswap32(tz->tz_minuteswest),
- tswap32(tz->tz_dsttime), get_comma(last));
- unlock_user(tz, tz_addr, 0);
- } else {
- qemu_log("NULL%s", get_comma(last));
- }
- }
- static void
- print_itimerval(abi_ulong it_addr, int last)
- {
- if (it_addr) {
- qemu_log("{it_interval=");
- print_timeval(it_addr +
- offsetof(struct target_itimerval, it_interval), 0);
- qemu_log("it_value=");
- print_timeval(it_addr +
- offsetof(struct target_itimerval, it_value), 0);
- qemu_log("}%s", get_comma(last));
- } else {
- qemu_log("NULL%s", get_comma(last));
- }
- }
- void
- print_termios(void *arg)
- {
- const struct target_termios *target = arg;
- target_tcflag_t iflags = tswap32(target->c_iflag);
- target_tcflag_t oflags = tswap32(target->c_oflag);
- target_tcflag_t cflags = tswap32(target->c_cflag);
- target_tcflag_t lflags = tswap32(target->c_lflag);
- qemu_log("{");
- qemu_log("c_iflag = ");
- print_flags(termios_iflags, iflags, 0);
- qemu_log("c_oflag = ");
- target_tcflag_t oflags_clean = oflags & ~(TARGET_NLDLY | TARGET_CRDLY |
- TARGET_TABDLY | TARGET_BSDLY |
- TARGET_VTDLY | TARGET_FFDLY);
- print_flags(termios_oflags, oflags_clean, 0);
- if (oflags & TARGET_NLDLY) {
- print_enums(termios_oflags_NLDLY, oflags & TARGET_NLDLY, 0);
- }
- if (oflags & TARGET_CRDLY) {
- print_enums(termios_oflags_CRDLY, oflags & TARGET_CRDLY, 0);
- }
- if (oflags & TARGET_TABDLY) {
- print_enums(termios_oflags_TABDLY, oflags & TARGET_TABDLY, 0);
- }
- if (oflags & TARGET_BSDLY) {
- print_enums(termios_oflags_BSDLY, oflags & TARGET_BSDLY, 0);
- }
- if (oflags & TARGET_VTDLY) {
- print_enums(termios_oflags_VTDLY, oflags & TARGET_VTDLY, 0);
- }
- if (oflags & TARGET_FFDLY) {
- print_enums(termios_oflags_FFDLY, oflags & TARGET_FFDLY, 0);
- }
- qemu_log("c_cflag = ");
- if (cflags & TARGET_CBAUD) {
- print_enums(termios_cflags_CBAUD, cflags & TARGET_CBAUD, 0);
- }
- if (cflags & TARGET_CSIZE) {
- print_enums(termios_cflags_CSIZE, cflags & TARGET_CSIZE, 0);
- }
- target_tcflag_t cflags_clean = cflags & ~(TARGET_CBAUD | TARGET_CSIZE);
- print_flags(termios_cflags, cflags_clean, 0);
- qemu_log("c_lflag = ");
- print_flags(termios_lflags, lflags, 0);
- qemu_log("c_cc = ");
- qemu_log("\"%s\",", target->c_cc);
- qemu_log("c_line = ");
- print_raw_param("\'%c\'", target->c_line, 1);
- qemu_log("}");
- }
- #undef UNUSED
- #ifdef TARGET_NR_accept
- static void
- print_accept(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_pointer(arg1, 0);
- print_number(arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_access
- static void
- print_access(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_flags(access_flags, arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_acct
- static void
- print_acct(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_brk
- static void
- print_brk(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_pointer(arg0, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_chdir
- static void
- print_chdir(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_chroot
- static void
- print_chroot(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_chmod
- static void
- print_chmod(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_file_mode(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_chown) || defined(TARGET_NR_lchown)
- static void
- print_chown(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_raw_param("%d", arg1, 0);
- print_raw_param("%d", arg2, 1);
- print_syscall_epilogue(name);
- }
- #define print_lchown print_chown
- #endif
- #ifdef TARGET_NR_clock_adjtime
- static void
- print_clock_adjtime(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_enums(clockids, arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_clone
- static void do_print_clone(unsigned int flags, abi_ulong newsp,
- abi_ulong parent_tidptr, target_ulong newtls,
- abi_ulong child_tidptr)
- {
- print_flags(clone_flags, flags, 0);
- print_raw_param("child_stack=0x" TARGET_ABI_FMT_lx, newsp, 0);
- print_raw_param("parent_tidptr=0x" TARGET_ABI_FMT_lx, parent_tidptr, 0);
- print_raw_param("tls=0x" TARGET_ABI_FMT_lx, newtls, 0);
- print_raw_param("child_tidptr=0x" TARGET_ABI_FMT_lx, child_tidptr, 1);
- }
- static void
- print_clone(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg1, abi_long arg2, abi_long arg3,
- abi_long arg4, abi_long arg5, abi_long arg6)
- {
- print_syscall_prologue(name);
- #if defined(TARGET_MICROBLAZE)
- do_print_clone(arg1, arg2, arg4, arg6, arg5);
- #elif defined(TARGET_CLONE_BACKWARDS)
- do_print_clone(arg1, arg2, arg3, arg4, arg5);
- #elif defined(TARGET_CLONE_BACKWARDS2)
- do_print_clone(arg2, arg1, arg3, arg5, arg4);
- #else
- do_print_clone(arg1, arg2, arg3, arg5, arg4);
- #endif
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_creat
- static void
- print_creat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_file_mode(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_execv
- static void
- print_execv(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_raw_param("0x" TARGET_ABI_FMT_lx, arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_faccessat) || defined(TARGET_NR_faccessat2)
- static void
- print_faccessat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_flags(access_flags, arg2, 0);
- print_flags(at_file_flags, arg3, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_fallocate
- static void
- print_fallocate(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_flags(falloc_flags, arg1, 0);
- #if TARGET_ABI_BITS == 32
- print_raw_param("%" PRIu64, target_offset64(arg2, arg3), 0);
- print_raw_param("%" PRIu64, target_offset64(arg4, arg5), 1);
- #else
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 0);
- print_raw_param(TARGET_ABI_FMT_ld, arg3, 1);
- #endif
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_fchmodat
- static void
- print_fchmodat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_file_mode(arg2, 0);
- print_flags(at_file_flags, arg3, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_fchownat
- static void
- print_fchownat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_raw_param("%d", arg2, 0);
- print_raw_param("%d", arg3, 0);
- print_flags(at_file_flags, arg4, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_fcntl) || defined(TARGET_NR_fcntl64)
- static void
- print_fcntl(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- switch(arg1) {
- case TARGET_F_DUPFD:
- qemu_log("F_DUPFD,");
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 1);
- break;
- case TARGET_F_GETFD:
- qemu_log("F_GETFD");
- break;
- case TARGET_F_SETFD:
- qemu_log("F_SETFD,");
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 1);
- break;
- case TARGET_F_GETFL:
- qemu_log("F_GETFL");
- break;
- case TARGET_F_SETFL:
- qemu_log("F_SETFL,");
- print_open_flags(arg2, 1);
- break;
- case TARGET_F_GETLK:
- qemu_log("F_GETLK,");
- print_pointer(arg2, 1);
- break;
- case TARGET_F_SETLK:
- qemu_log("F_SETLK,");
- print_pointer(arg2, 1);
- break;
- case TARGET_F_SETLKW:
- qemu_log("F_SETLKW,");
- print_pointer(arg2, 1);
- break;
- case TARGET_F_GETOWN:
- qemu_log("F_GETOWN");
- break;
- case TARGET_F_SETOWN:
- qemu_log("F_SETOWN,");
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 0);
- break;
- case TARGET_F_GETSIG:
- qemu_log("F_GETSIG");
- break;
- case TARGET_F_SETSIG:
- qemu_log("F_SETSIG,");
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 0);
- break;
- #if TARGET_ABI_BITS == 32
- case TARGET_F_GETLK64:
- qemu_log("F_GETLK64,");
- print_pointer(arg2, 1);
- break;
- case TARGET_F_SETLK64:
- qemu_log("F_SETLK64,");
- print_pointer(arg2, 1);
- break;
- case TARGET_F_SETLKW64:
- qemu_log("F_SETLKW64,");
- print_pointer(arg2, 1);
- break;
- #endif
- case TARGET_F_OFD_GETLK:
- qemu_log("F_OFD_GETLK,");
- print_pointer(arg2, 1);
- break;
- case TARGET_F_OFD_SETLK:
- qemu_log("F_OFD_SETLK,");
- print_pointer(arg2, 1);
- break;
- case TARGET_F_OFD_SETLKW:
- qemu_log("F_OFD_SETLKW,");
- print_pointer(arg2, 1);
- break;
- case TARGET_F_SETLEASE:
- qemu_log("F_SETLEASE,");
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 1);
- break;
- case TARGET_F_GETLEASE:
- qemu_log("F_GETLEASE");
- break;
- #ifdef F_DUPFD_CLOEXEC
- case TARGET_F_DUPFD_CLOEXEC:
- qemu_log("F_DUPFD_CLOEXEC,");
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 1);
- break;
- #endif
- case TARGET_F_NOTIFY:
- qemu_log("F_NOTIFY,");
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 1);
- break;
- #ifdef F_GETOWN_EX
- case TARGET_F_GETOWN_EX:
- qemu_log("F_GETOWN_EX,");
- print_pointer(arg2, 1);
- break;
- #endif
- #ifdef F_SETOWN_EX
- case TARGET_F_SETOWN_EX:
- qemu_log("F_SETOWN_EX,");
- print_pointer(arg2, 1);
- break;
- #endif
- #ifdef F_SETPIPE_SZ
- case TARGET_F_SETPIPE_SZ:
- qemu_log("F_SETPIPE_SZ,");
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 1);
- break;
- case TARGET_F_GETPIPE_SZ:
- qemu_log("F_GETPIPE_SZ");
- break;
- #endif
- #ifdef F_ADD_SEALS
- case TARGET_F_ADD_SEALS:
- qemu_log("F_ADD_SEALS,");
- print_raw_param("0x"TARGET_ABI_FMT_lx, arg2, 1);
- break;
- case TARGET_F_GET_SEALS:
- qemu_log("F_GET_SEALS");
- break;
- #endif
- default:
- print_raw_param(TARGET_ABI_FMT_ld, arg1, 0);
- print_pointer(arg2, 1);
- break;
- }
- print_syscall_epilogue(name);
- }
- #define print_fcntl64 print_fcntl
- #endif
- #ifdef TARGET_NR_fgetxattr
- static void
- print_fgetxattr(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_string(arg1, 0);
- print_pointer(arg2, 0);
- print_raw_param(TARGET_FMT_lu, arg3, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_flistxattr
- static void
- print_flistxattr(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_pointer(arg1, 0);
- print_raw_param(TARGET_FMT_lu, arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_getxattr) || defined(TARGET_NR_lgetxattr)
- static void
- print_getxattr(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_string(arg1, 0);
- print_pointer(arg2, 0);
- print_raw_param(TARGET_FMT_lu, arg3, 1);
- print_syscall_epilogue(name);
- }
- #define print_lgetxattr print_getxattr
- #endif
- #if defined(TARGET_NR_listxattr) || defined(TARGET_NR_llistxattr)
- static void
- print_listxattr(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_pointer(arg1, 0);
- print_raw_param(TARGET_FMT_lu, arg2, 1);
- print_syscall_epilogue(name);
- }
- #define print_llistxattr print_listxattr
- #endif
- #if defined(TARGET_NR_fremovexattr)
- static void
- print_fremovexattr(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_string(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_removexattr) || defined(TARGET_NR_lremovexattr)
- static void
- print_removexattr(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_string(arg1, 1);
- print_syscall_epilogue(name);
- }
- #define print_lremovexattr print_removexattr
- #endif
- #ifdef TARGET_NR_futimesat
- static void
- print_futimesat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_timeval(arg2, 0);
- print_timeval(arg2 + sizeof (struct target_timeval), 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_gettimeofday
- static void
- print_gettimeofday(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_pointer(arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_settimeofday
- static void
- print_settimeofday(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_timeval(arg0, 0);
- print_timezone(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_clock_gettime) || defined(TARGET_NR_clock_getres)
- static void
- print_clock_gettime(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_enums(clockids, arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #define print_clock_getres print_clock_gettime
- #endif
- #if defined(TARGET_NR_clock_gettime64)
- static void
- print_clock_gettime64(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_enums(clockids, arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_clock_settime
- static void
- print_clock_settime(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_enums(clockids, arg0, 0);
- print_timespec(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_getitimer
- static void
- print_getitimer(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_enums(itimer_types, arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_setitimer
- static void
- print_setitimer(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_enums(itimer_types, arg0, 0);
- print_itimerval(arg1, 0);
- print_pointer(arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_link
- static void
- print_link(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_string(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_linkat
- static void
- print_linkat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_at_dirfd(arg2, 0);
- print_string(arg3, 0);
- print_flags(at_file_flags, arg4, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR__llseek) || defined(TARGET_NR_llseek)
- static void
- print__llseek(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- const char *whence = "UNKNOWN";
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_raw_param("%ld", arg1, 0);
- print_raw_param("%ld", arg2, 0);
- print_pointer(arg3, 0);
- switch(arg4) {
- case SEEK_SET: whence = "SEEK_SET"; break;
- case SEEK_CUR: whence = "SEEK_CUR"; break;
- case SEEK_END: whence = "SEEK_END"; break;
- }
- qemu_log("%s", whence);
- print_syscall_epilogue(name);
- }
- #define print_llseek print__llseek
- #endif
- #ifdef TARGET_NR_lseek
- static void
- print_lseek(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_raw_param(TARGET_ABI_FMT_ld, arg1, 0);
- switch (arg2) {
- case SEEK_SET:
- qemu_log("SEEK_SET"); break;
- case SEEK_CUR:
- qemu_log("SEEK_CUR"); break;
- case SEEK_END:
- qemu_log("SEEK_END"); break;
- #ifdef SEEK_DATA
- case SEEK_DATA:
- qemu_log("SEEK_DATA"); break;
- #endif
- #ifdef SEEK_HOLE
- case SEEK_HOLE:
- qemu_log("SEEK_HOLE"); break;
- #endif
- default:
- print_raw_param("%#x", arg2, 1);
- }
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_truncate
- static void
- print_truncate(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_raw_param(TARGET_ABI_FMT_ld, arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_truncate64
- static void
- print_truncate64(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- if (regpairs_aligned(cpu_env, TARGET_NR_truncate64)) {
- arg1 = arg2;
- arg2 = arg3;
- }
- print_raw_param("%" PRIu64, target_offset64(arg1, arg2), 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_ftruncate64
- static void
- print_ftruncate64(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- if (regpairs_aligned(cpu_env, TARGET_NR_ftruncate64)) {
- arg1 = arg2;
- arg2 = arg3;
- }
- print_raw_param("%" PRIu64, target_offset64(arg1, arg2), 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_mlockall
- static void
- print_mlockall(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_flags(mlockall_flags, arg0, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_socket)
- static void
- print_socket(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- abi_ulong domain = arg0, type = arg1, protocol = arg2;
- print_syscall_prologue(name);
- print_socket_domain(domain);
- qemu_log(",");
- print_socket_type(type);
- qemu_log(",");
- if (domain == AF_PACKET ||
- (domain == AF_INET && type == TARGET_SOCK_PACKET)) {
- protocol = tswap16(protocol);
- }
- print_socket_protocol(domain, type, protocol);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_socketcall) || defined(TARGET_NR_bind)
- static void print_sockfd(abi_long sockfd, int last)
- {
- print_raw_param(TARGET_ABI_FMT_ld, sockfd, last);
- }
- #endif
- #if defined(TARGET_NR_socketcall)
- #define get_user_ualx(x, gaddr, idx) \
- get_user_ual(x, (gaddr) + (idx) * sizeof(abi_long))
- static void do_print_socket(const char *name, abi_long arg1)
- {
- abi_ulong domain, type, protocol;
- get_user_ualx(domain, arg1, 0);
- get_user_ualx(type, arg1, 1);
- get_user_ualx(protocol, arg1, 2);
- qemu_log("%s(", name);
- print_socket_domain(domain);
- qemu_log(",");
- print_socket_type(type);
- qemu_log(",");
- if (domain == AF_PACKET ||
- (domain == AF_INET && type == TARGET_SOCK_PACKET)) {
- protocol = tswap16(protocol);
- }
- print_socket_protocol(domain, type, protocol);
- qemu_log(")");
- }
- static void do_print_sockaddr(const char *name, abi_long arg1)
- {
- abi_ulong sockfd, addr, addrlen;
- get_user_ualx(sockfd, arg1, 0);
- get_user_ualx(addr, arg1, 1);
- get_user_ualx(addrlen, arg1, 2);
- qemu_log("%s(", name);
- print_sockfd(sockfd, 0);
- print_sockaddr(addr, addrlen, 0);
- qemu_log(")");
- }
- static void do_print_listen(const char *name, abi_long arg1)
- {
- abi_ulong sockfd, backlog;
- get_user_ualx(sockfd, arg1, 0);
- get_user_ualx(backlog, arg1, 1);
- qemu_log("%s(", name);
- print_sockfd(sockfd, 0);
- print_raw_param(TARGET_ABI_FMT_ld, backlog, 1);
- qemu_log(")");
- }
- static void do_print_socketpair(const char *name, abi_long arg1)
- {
- abi_ulong domain, type, protocol, tab;
- get_user_ualx(domain, arg1, 0);
- get_user_ualx(type, arg1, 1);
- get_user_ualx(protocol, arg1, 2);
- get_user_ualx(tab, arg1, 3);
- qemu_log("%s(", name);
- print_socket_domain(domain);
- qemu_log(",");
- print_socket_type(type);
- qemu_log(",");
- print_socket_protocol(domain, type, protocol);
- qemu_log(",");
- print_raw_param(TARGET_ABI_FMT_lx, tab, 1);
- qemu_log(")");
- }
- static void do_print_sendrecv(const char *name, abi_long arg1)
- {
- abi_ulong sockfd, msg, len, flags;
- get_user_ualx(sockfd, arg1, 0);
- get_user_ualx(msg, arg1, 1);
- get_user_ualx(len, arg1, 2);
- get_user_ualx(flags, arg1, 3);
- qemu_log("%s(", name);
- print_sockfd(sockfd, 0);
- print_buf(msg, len, 0);
- print_raw_param(TARGET_ABI_FMT_ld, len, 0);
- print_flags(msg_flags, flags, 1);
- qemu_log(")");
- }
- static void do_print_msgaddr(const char *name, abi_long arg1)
- {
- abi_ulong sockfd, msg, len, flags, addr, addrlen;
- get_user_ualx(sockfd, arg1, 0);
- get_user_ualx(msg, arg1, 1);
- get_user_ualx(len, arg1, 2);
- get_user_ualx(flags, arg1, 3);
- get_user_ualx(addr, arg1, 4);
- get_user_ualx(addrlen, arg1, 5);
- qemu_log("%s(", name);
- print_sockfd(sockfd, 0);
- print_buf(msg, len, 0);
- print_raw_param(TARGET_ABI_FMT_ld, len, 0);
- print_flags(msg_flags, flags, 0);
- print_sockaddr(addr, addrlen, 0);
- qemu_log(")");
- }
- static void do_print_shutdown(const char *name, abi_long arg1)
- {
- abi_ulong sockfd, how;
- get_user_ualx(sockfd, arg1, 0);
- get_user_ualx(how, arg1, 1);
- qemu_log("shutdown(");
- print_sockfd(sockfd, 0);
- switch (how) {
- case SHUT_RD:
- qemu_log("SHUT_RD");
- break;
- case SHUT_WR:
- qemu_log("SHUT_WR");
- break;
- case SHUT_RDWR:
- qemu_log("SHUT_RDWR");
- break;
- default:
- print_raw_param(TARGET_ABI_FMT_ld, how, 1);
- break;
- }
- qemu_log(")");
- }
- static void do_print_msg(const char *name, abi_long arg1)
- {
- abi_ulong sockfd, msg, flags;
- get_user_ualx(sockfd, arg1, 0);
- get_user_ualx(msg, arg1, 1);
- get_user_ualx(flags, arg1, 2);
- qemu_log("%s(", name);
- print_sockfd(sockfd, 0);
- print_pointer(msg, 0);
- print_flags(msg_flags, flags, 1);
- qemu_log(")");
- }
- static void do_print_sockopt(const char *name, abi_long arg1)
- {
- abi_ulong sockfd, level, optname, optval, optlen;
- get_user_ualx(sockfd, arg1, 0);
- get_user_ualx(level, arg1, 1);
- get_user_ualx(optname, arg1, 2);
- get_user_ualx(optval, arg1, 3);
- get_user_ualx(optlen, arg1, 4);
- qemu_log("%s(", name);
- print_sockfd(sockfd, 0);
- switch (level) {
- case SOL_TCP:
- qemu_log("SOL_TCP,");
- print_raw_param(TARGET_ABI_FMT_ld, optname, 0);
- print_pointer(optval, 0);
- break;
- case SOL_UDP:
- qemu_log("SOL_UDP,");
- print_raw_param(TARGET_ABI_FMT_ld, optname, 0);
- print_pointer(optval, 0);
- break;
- case SOL_IP:
- qemu_log("SOL_IP,");
- print_raw_param(TARGET_ABI_FMT_ld, optname, 0);
- print_pointer(optval, 0);
- break;
- case SOL_RAW:
- qemu_log("SOL_RAW,");
- print_raw_param(TARGET_ABI_FMT_ld, optname, 0);
- print_pointer(optval, 0);
- break;
- case TARGET_SOL_SOCKET:
- qemu_log("SOL_SOCKET,");
- switch (optname) {
- case TARGET_SO_DEBUG:
- qemu_log("SO_DEBUG,");
- print_optint:
- print_number(optval, 0);
- break;
- case TARGET_SO_REUSEADDR:
- qemu_log("SO_REUSEADDR,");
- goto print_optint;
- case TARGET_SO_REUSEPORT:
- qemu_log("SO_REUSEPORT,");
- goto print_optint;
- case TARGET_SO_TYPE:
- qemu_log("SO_TYPE,");
- goto print_optint;
- case TARGET_SO_ERROR:
- qemu_log("SO_ERROR,");
- goto print_optint;
- case TARGET_SO_DONTROUTE:
- qemu_log("SO_DONTROUTE,");
- goto print_optint;
- case TARGET_SO_BROADCAST:
- qemu_log("SO_BROADCAST,");
- goto print_optint;
- case TARGET_SO_SNDBUF:
- qemu_log("SO_SNDBUF,");
- goto print_optint;
- case TARGET_SO_RCVBUF:
- qemu_log("SO_RCVBUF,");
- goto print_optint;
- case TARGET_SO_KEEPALIVE:
- qemu_log("SO_KEEPALIVE,");
- goto print_optint;
- case TARGET_SO_OOBINLINE:
- qemu_log("SO_OOBINLINE,");
- goto print_optint;
- case TARGET_SO_NO_CHECK:
- qemu_log("SO_NO_CHECK,");
- goto print_optint;
- case TARGET_SO_PRIORITY:
- qemu_log("SO_PRIORITY,");
- goto print_optint;
- case TARGET_SO_BSDCOMPAT:
- qemu_log("SO_BSDCOMPAT,");
- goto print_optint;
- case TARGET_SO_PASSCRED:
- qemu_log("SO_PASSCRED,");
- goto print_optint;
- case TARGET_SO_TIMESTAMP:
- qemu_log("SO_TIMESTAMP,");
- goto print_optint;
- case TARGET_SO_RCVLOWAT:
- qemu_log("SO_RCVLOWAT,");
- goto print_optint;
- case TARGET_SO_RCVTIMEO:
- qemu_log("SO_RCVTIMEO,");
- print_timeval(optval, 0);
- break;
- case TARGET_SO_SNDTIMEO:
- qemu_log("SO_SNDTIMEO,");
- print_timeval(optval, 0);
- break;
- case TARGET_SO_ATTACH_FILTER: {
- struct target_sock_fprog *fprog;
- qemu_log("SO_ATTACH_FILTER,");
- if (lock_user_struct(VERIFY_READ, fprog, optval, 0)) {
- struct target_sock_filter *filter;
- qemu_log("{");
- if (lock_user_struct(VERIFY_READ, filter,
- tswapal(fprog->filter), 0)) {
- int i;
- for (i = 0; i < tswap16(fprog->len) - 1; i++) {
- qemu_log("[%d]{0x%x,%d,%d,0x%x},",
- i, tswap16(filter[i].code),
- filter[i].jt, filter[i].jf,
- tswap32(filter[i].k));
- }
- qemu_log("[%d]{0x%x,%d,%d,0x%x}",
- i, tswap16(filter[i].code),
- filter[i].jt, filter[i].jf,
- tswap32(filter[i].k));
- } else {
- qemu_log(TARGET_ABI_FMT_lx, tswapal(fprog->filter));
- }
- qemu_log(",%d},", tswap16(fprog->len));
- unlock_user(fprog, optval, 0);
- } else {
- print_pointer(optval, 0);
- }
- break;
- }
- default:
- print_raw_param(TARGET_ABI_FMT_ld, optname, 0);
- print_pointer(optval, 0);
- break;
- }
- break;
- case SOL_IPV6:
- qemu_log("SOL_IPV6,");
- switch (optname) {
- case IPV6_MTU_DISCOVER:
- qemu_log("IPV6_MTU_DISCOVER,");
- goto print_optint;
- case IPV6_MTU:
- qemu_log("IPV6_MTU,");
- goto print_optint;
- case IPV6_V6ONLY:
- qemu_log("IPV6_V6ONLY,");
- goto print_optint;
- case IPV6_RECVPKTINFO:
- qemu_log("IPV6_RECVPKTINFO,");
- goto print_optint;
- case IPV6_UNICAST_HOPS:
- qemu_log("IPV6_UNICAST_HOPS,");
- goto print_optint;
- case IPV6_MULTICAST_HOPS:
- qemu_log("IPV6_MULTICAST_HOPS,");
- goto print_optint;
- case IPV6_MULTICAST_LOOP:
- qemu_log("IPV6_MULTICAST_LOOP,");
- goto print_optint;
- case IPV6_RECVERR:
- qemu_log("IPV6_RECVERR,");
- goto print_optint;
- case IPV6_RECVHOPLIMIT:
- qemu_log("IPV6_RECVHOPLIMIT,");
- goto print_optint;
- case IPV6_2292HOPLIMIT:
- qemu_log("IPV6_2292HOPLIMIT,");
- goto print_optint;
- case IPV6_CHECKSUM:
- qemu_log("IPV6_CHECKSUM,");
- goto print_optint;
- case IPV6_ADDRFORM:
- qemu_log("IPV6_ADDRFORM,");
- goto print_optint;
- case IPV6_2292PKTINFO:
- qemu_log("IPV6_2292PKTINFO,");
- goto print_optint;
- case IPV6_RECVTCLASS:
- qemu_log("IPV6_RECVTCLASS,");
- goto print_optint;
- case IPV6_RECVRTHDR:
- qemu_log("IPV6_RECVRTHDR,");
- goto print_optint;
- case IPV6_2292RTHDR:
- qemu_log("IPV6_2292RTHDR,");
- goto print_optint;
- case IPV6_RECVHOPOPTS:
- qemu_log("IPV6_RECVHOPOPTS,");
- goto print_optint;
- case IPV6_2292HOPOPTS:
- qemu_log("IPV6_2292HOPOPTS,");
- goto print_optint;
- case IPV6_RECVDSTOPTS:
- qemu_log("IPV6_RECVDSTOPTS,");
- goto print_optint;
- case IPV6_2292DSTOPTS:
- qemu_log("IPV6_2292DSTOPTS,");
- goto print_optint;
- case IPV6_TCLASS:
- qemu_log("IPV6_TCLASS,");
- goto print_optint;
- case IPV6_ADDR_PREFERENCES:
- qemu_log("IPV6_ADDR_PREFERENCES,");
- goto print_optint;
- #ifdef IPV6_RECVPATHMTU
- case IPV6_RECVPATHMTU:
- qemu_log("IPV6_RECVPATHMTU,");
- goto print_optint;
- #endif
- #ifdef IPV6_TRANSPARENT
- case IPV6_TRANSPARENT:
- qemu_log("IPV6_TRANSPARENT,");
- goto print_optint;
- #endif
- #ifdef IPV6_FREEBIND
- case IPV6_FREEBIND:
- qemu_log("IPV6_FREEBIND,");
- goto print_optint;
- #endif
- #ifdef IPV6_RECVORIGDSTADDR
- case IPV6_RECVORIGDSTADDR:
- qemu_log("IPV6_RECVORIGDSTADDR,");
- goto print_optint;
- #endif
- case IPV6_PKTINFO:
- qemu_log("IPV6_PKTINFO,");
- print_pointer(optval, 0);
- break;
- case IPV6_ADD_MEMBERSHIP:
- qemu_log("IPV6_ADD_MEMBERSHIP,");
- print_pointer(optval, 0);
- break;
- case IPV6_DROP_MEMBERSHIP:
- qemu_log("IPV6_DROP_MEMBERSHIP,");
- print_pointer(optval, 0);
- break;
- default:
- print_raw_param(TARGET_ABI_FMT_ld, optname, 0);
- print_pointer(optval, 0);
- break;
- }
- break;
- default:
- print_raw_param(TARGET_ABI_FMT_ld, level, 0);
- print_raw_param(TARGET_ABI_FMT_ld, optname, 0);
- print_pointer(optval, 0);
- break;
- }
- print_raw_param(TARGET_ABI_FMT_ld, optlen, 1);
- qemu_log(")");
- }
- #define PRINT_SOCKOP(name, func) \
- [TARGET_SYS_##name] = { #name, func }
- static struct {
- const char *name;
- void (*print)(const char *, abi_long);
- } scall[] = {
- PRINT_SOCKOP(SOCKET, do_print_socket),
- PRINT_SOCKOP(BIND, do_print_sockaddr),
- PRINT_SOCKOP(CONNECT, do_print_sockaddr),
- PRINT_SOCKOP(LISTEN, do_print_listen),
- PRINT_SOCKOP(ACCEPT, do_print_sockaddr),
- PRINT_SOCKOP(GETSOCKNAME, do_print_sockaddr),
- PRINT_SOCKOP(GETPEERNAME, do_print_sockaddr),
- PRINT_SOCKOP(SOCKETPAIR, do_print_socketpair),
- PRINT_SOCKOP(SEND, do_print_sendrecv),
- PRINT_SOCKOP(RECV, do_print_sendrecv),
- PRINT_SOCKOP(SENDTO, do_print_msgaddr),
- PRINT_SOCKOP(RECVFROM, do_print_msgaddr),
- PRINT_SOCKOP(SHUTDOWN, do_print_shutdown),
- PRINT_SOCKOP(SETSOCKOPT, do_print_sockopt),
- PRINT_SOCKOP(GETSOCKOPT, do_print_sockopt),
- PRINT_SOCKOP(SENDMSG, do_print_msg),
- PRINT_SOCKOP(RECVMSG, do_print_msg),
- PRINT_SOCKOP(ACCEPT4, NULL),
- PRINT_SOCKOP(RECVMMSG, NULL),
- PRINT_SOCKOP(SENDMMSG, NULL),
- };
- static void
- print_socketcall(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- if (arg0 >= 0 && arg0 < ARRAY_SIZE(scall) && scall[arg0].print) {
- scall[arg0].print(scall[arg0].name, arg1);
- return;
- }
- print_syscall_prologue(name);
- print_raw_param(TARGET_ABI_FMT_ld, arg0, 0);
- print_raw_param(TARGET_ABI_FMT_ld, arg1, 0);
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 0);
- print_raw_param(TARGET_ABI_FMT_ld, arg3, 0);
- print_raw_param(TARGET_ABI_FMT_ld, arg4, 0);
- print_raw_param(TARGET_ABI_FMT_ld, arg5, 0);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_bind)
- static void
- print_bind(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_sockfd(arg0, 0);
- print_sockaddr(arg1, arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_stat) || defined(TARGET_NR_stat64) || \
- defined(TARGET_NR_lstat) || defined(TARGET_NR_lstat64)
- static void
- print_stat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #define print_lstat print_stat
- #define print_stat64 print_stat
- #define print_lstat64 print_stat
- #endif
- #if defined(TARGET_NR_madvise)
- static struct enums madvise_advice[] = {
- ENUM_TARGET(MADV_NORMAL),
- ENUM_TARGET(MADV_RANDOM),
- ENUM_TARGET(MADV_SEQUENTIAL),
- ENUM_TARGET(MADV_WILLNEED),
- ENUM_TARGET(MADV_DONTNEED),
- ENUM_TARGET(MADV_FREE),
- ENUM_TARGET(MADV_REMOVE),
- ENUM_TARGET(MADV_DONTFORK),
- ENUM_TARGET(MADV_DOFORK),
- ENUM_TARGET(MADV_MERGEABLE),
- ENUM_TARGET(MADV_UNMERGEABLE),
- ENUM_TARGET(MADV_HUGEPAGE),
- ENUM_TARGET(MADV_NOHUGEPAGE),
- ENUM_TARGET(MADV_DONTDUMP),
- ENUM_TARGET(MADV_DODUMP),
- ENUM_TARGET(MADV_WIPEONFORK),
- ENUM_TARGET(MADV_KEEPONFORK),
- ENUM_TARGET(MADV_COLD),
- ENUM_TARGET(MADV_PAGEOUT),
- ENUM_TARGET(MADV_POPULATE_READ),
- ENUM_TARGET(MADV_POPULATE_WRITE),
- ENUM_TARGET(MADV_DONTNEED_LOCKED),
- ENUM_END,
- };
- static void
- print_madvise(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_pointer(arg0, 0);
- print_raw_param("%d", arg1, 0);
- print_enums(madvise_advice, arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_fstat) || defined(TARGET_NR_fstat64)
- static void
- print_fstat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #define print_fstat64 print_fstat
- #endif
- #ifdef TARGET_NR_mkdir
- static void
- print_mkdir(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_file_mode(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_mkdirat
- static void
- print_mkdirat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_file_mode(arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_rmdir
- static void
- print_rmdir(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_rt_sigaction
- static void
- print_rt_sigaction(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_signal(arg0, 0);
- print_pointer(arg1, 0);
- print_pointer(arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_rt_sigprocmask
- static void
- print_rt_sigprocmask(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- const char *how = "UNKNOWN";
- print_syscall_prologue(name);
- switch(arg0) {
- case TARGET_SIG_BLOCK: how = "SIG_BLOCK"; break;
- case TARGET_SIG_UNBLOCK: how = "SIG_UNBLOCK"; break;
- case TARGET_SIG_SETMASK: how = "SIG_SETMASK"; break;
- }
- qemu_log("%s,", how);
- print_pointer(arg1, 0);
- print_pointer(arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_rt_sigqueueinfo
- static void
- print_rt_sigqueueinfo(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- void *p;
- target_siginfo_t uinfo;
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_signal(arg1, 0);
- p = lock_user(VERIFY_READ, arg2, sizeof(target_siginfo_t), 1);
- if (p) {
- get_target_siginfo(&uinfo, p);
- print_siginfo(&uinfo);
- unlock_user(p, arg2, 0);
- } else {
- print_pointer(arg2, 1);
- }
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_rt_tgsigqueueinfo
- static void
- print_rt_tgsigqueueinfo(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- void *p;
- target_siginfo_t uinfo;
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_raw_param("%d", arg1, 0);
- print_signal(arg2, 0);
- p = lock_user(VERIFY_READ, arg3, sizeof(target_siginfo_t), 1);
- if (p) {
- get_target_siginfo(&uinfo, p);
- print_siginfo(&uinfo);
- unlock_user(p, arg3, 0);
- } else {
- print_pointer(arg3, 1);
- }
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_syslog
- static void
- print_syslog_action(abi_ulong arg, int last)
- {
- const char *type;
- switch (arg) {
- case TARGET_SYSLOG_ACTION_CLOSE: {
- type = "SYSLOG_ACTION_CLOSE";
- break;
- }
- case TARGET_SYSLOG_ACTION_OPEN: {
- type = "SYSLOG_ACTION_OPEN";
- break;
- }
- case TARGET_SYSLOG_ACTION_READ: {
- type = "SYSLOG_ACTION_READ";
- break;
- }
- case TARGET_SYSLOG_ACTION_READ_ALL: {
- type = "SYSLOG_ACTION_READ_ALL";
- break;
- }
- case TARGET_SYSLOG_ACTION_READ_CLEAR: {
- type = "SYSLOG_ACTION_READ_CLEAR";
- break;
- }
- case TARGET_SYSLOG_ACTION_CLEAR: {
- type = "SYSLOG_ACTION_CLEAR";
- break;
- }
- case TARGET_SYSLOG_ACTION_CONSOLE_OFF: {
- type = "SYSLOG_ACTION_CONSOLE_OFF";
- break;
- }
- case TARGET_SYSLOG_ACTION_CONSOLE_ON: {
- type = "SYSLOG_ACTION_CONSOLE_ON";
- break;
- }
- case TARGET_SYSLOG_ACTION_CONSOLE_LEVEL: {
- type = "SYSLOG_ACTION_CONSOLE_LEVEL";
- break;
- }
- case TARGET_SYSLOG_ACTION_SIZE_UNREAD: {
- type = "SYSLOG_ACTION_SIZE_UNREAD";
- break;
- }
- case TARGET_SYSLOG_ACTION_SIZE_BUFFER: {
- type = "SYSLOG_ACTION_SIZE_BUFFER";
- break;
- }
- default: {
- print_raw_param("%ld", arg, last);
- return;
- }
- }
- qemu_log("%s%s", type, get_comma(last));
- }
- static void
- print_syslog(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_syslog_action(arg0, 0);
- print_pointer(arg1, 0);
- print_raw_param("%d", arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_mknod
- static void
- print_mknod(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- int hasdev = (arg1 & (S_IFCHR|S_IFBLK));
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_file_mode(arg1, (hasdev == 0));
- if (hasdev) {
- print_raw_param("makedev(%d", major(arg2), 0);
- print_raw_param("%d)", minor(arg2), 1);
- }
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_mknodat
- static void
- print_mknodat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- int hasdev = (arg2 & (S_IFCHR|S_IFBLK));
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_file_mode(arg2, (hasdev == 0));
- if (hasdev) {
- print_raw_param("makedev(%d", major(arg3), 0);
- print_raw_param("%d)", minor(arg3), 1);
- }
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_mq_open
- static void
- print_mq_open(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- int is_creat = (arg1 & TARGET_O_CREAT);
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_open_flags(arg1, (is_creat == 0));
- if (is_creat) {
- print_file_mode(arg2, 0);
- print_pointer(arg3, 1);
- }
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_open
- static void
- print_open(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- int is_creat = (arg1 & TARGET_O_CREAT);
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_open_flags(arg1, (is_creat == 0));
- if (is_creat)
- print_file_mode(arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_openat
- static void
- print_openat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- int is_creat = (arg2 & TARGET_O_CREAT);
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_open_flags(arg2, (is_creat == 0));
- if (is_creat)
- print_file_mode(arg3, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_pidfd_send_signal
- static void
- print_pidfd_send_signal(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- void *p;
- target_siginfo_t uinfo;
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_signal(arg1, 0);
- p = lock_user(VERIFY_READ, arg2, sizeof(target_siginfo_t), 1);
- if (p) {
- get_target_siginfo(&uinfo, p);
- print_siginfo(&uinfo);
- unlock_user(p, arg2, 0);
- } else {
- print_pointer(arg2, 0);
- }
- print_raw_param("%u", arg3, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_mq_unlink
- static void
- print_mq_unlink(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_fstatat64) || defined(TARGET_NR_newfstatat)
- static void
- print_fstatat64(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_pointer(arg2, 0);
- print_flags(at_file_flags, arg3, 1);
- print_syscall_epilogue(name);
- }
- #define print_newfstatat print_fstatat64
- #endif
- #ifdef TARGET_NR_readlink
- static void
- print_readlink(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_pointer(arg1, 0);
- print_raw_param("%u", arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_readlinkat
- static void
- print_readlinkat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_pointer(arg2, 0);
- print_raw_param("%u", arg3, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_rename
- static void
- print_rename(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_string(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_renameat
- static void
- print_renameat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_at_dirfd(arg2, 0);
- print_string(arg3, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_statfs
- static void
- print_statfs(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_statfs64
- static void
- print_statfs64(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_symlink
- static void
- print_symlink(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_string(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_symlinkat
- static void
- print_symlinkat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_at_dirfd(arg1, 0);
- print_string(arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_mount
- static void
- print_mount(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_string(arg1, 0);
- print_string(arg2, 0);
- print_flags(mount_flags, arg3, 0);
- print_pointer(arg4, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_umount
- static void
- print_umount(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_umount2
- static void
- print_umount2(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_flags(umount2_flags, arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_unlink
- static void
- print_unlink(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_unlinkat
- static void
- print_unlinkat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_flags(unlinkat_flags, arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_unshare
- static void
- print_unshare(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_flags(clone_flags, arg0, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_clock_nanosleep
- static void
- print_clock_nanosleep(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_enums(clockids, arg0, 0);
- print_raw_param("%d", arg1, 0);
- print_timespec(arg2, 0);
- print_timespec(arg3, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_utime
- static void
- print_utime(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_utimes
- static void
- print_utimes(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_string(arg0, 0);
- print_pointer(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_utimensat
- static void
- print_utimensat(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_pointer(arg2, 0);
- print_flags(at_file_flags, arg3, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #if defined(TARGET_NR_mmap) || defined(TARGET_NR_mmap2)
- static void
- print_mmap(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_pointer(arg0, 0);
- print_raw_param("%d", arg1, 0);
- print_flags(mmap_prot_flags, arg2, 0);
- print_flags(mmap_flags, arg3, 0);
- print_raw_param("%d", arg4, 0);
- print_raw_param("%#x", arg5, 1);
- print_syscall_epilogue(name);
- }
- #define print_mmap2 print_mmap
- #endif
- #ifdef TARGET_NR_mprotect
- static void
- print_mprotect(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_pointer(arg0, 0);
- print_raw_param("%d", arg1, 0);
- print_flags(mmap_prot_flags, arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_munmap
- static void
- print_munmap(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_pointer(arg0, 0);
- print_raw_param("%d", arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_futex
- static void print_futex_op(int cmd, int last)
- {
- static const char * const futex_names[] = {
- #define NAME(X) [X] = #X
- NAME(FUTEX_WAIT),
- NAME(FUTEX_WAKE),
- NAME(FUTEX_FD),
- NAME(FUTEX_REQUEUE),
- NAME(FUTEX_CMP_REQUEUE),
- NAME(FUTEX_WAKE_OP),
- NAME(FUTEX_LOCK_PI),
- NAME(FUTEX_UNLOCK_PI),
- NAME(FUTEX_TRYLOCK_PI),
- NAME(FUTEX_WAIT_BITSET),
- NAME(FUTEX_WAKE_BITSET),
- NAME(FUTEX_WAIT_REQUEUE_PI),
- NAME(FUTEX_CMP_REQUEUE_PI),
- NAME(FUTEX_LOCK_PI2),
- #undef NAME
- };
- unsigned base_cmd = cmd & FUTEX_CMD_MASK;
- if (base_cmd < ARRAY_SIZE(futex_names)) {
- qemu_log("%s%s%s",
- (cmd & FUTEX_PRIVATE_FLAG ? "FUTEX_PRIVATE_FLAG|" : ""),
- (cmd & FUTEX_CLOCK_REALTIME ? "FUTEX_CLOCK_REALTIME|" : ""),
- futex_names[base_cmd]);
- } else {
- qemu_log("0x%x", cmd);
- }
- }
- static void
- print_futex(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- abi_long op = arg1 & FUTEX_CMD_MASK;
- print_syscall_prologue(name);
- print_pointer(arg0, 0);
- print_futex_op(arg1, 0);
- print_raw_param(",%d", arg2, 0);
- switch (op) {
- case FUTEX_WAIT:
- case FUTEX_WAIT_BITSET:
- case FUTEX_LOCK_PI:
- case FUTEX_LOCK_PI2:
- case FUTEX_WAIT_REQUEUE_PI:
- print_timespec(arg3, 0);
- break;
- default:
- print_pointer(arg3, 0);
- break;
- }
- print_pointer(arg4, 0);
- print_raw_param("%d", arg4, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_kill
- static void
- print_kill(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_signal(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_tkill
- static void
- print_tkill(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_signal(arg1, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_tgkill
- static void
- print_tgkill(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- print_raw_param("%d", arg1, 0);
- print_signal(arg2, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_statx
- static void
- print_statx(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_at_dirfd(arg0, 0);
- print_string(arg1, 0);
- print_flags(statx_flags, arg2, 0);
- print_flags(statx_mask, arg3, 0);
- print_pointer(arg4, 1);
- print_syscall_epilogue(name);
- }
- #endif
- #ifdef TARGET_NR_ioctl
- static void
- print_ioctl(CPUArchState *cpu_env, const struct syscallname *name,
- abi_long arg0, abi_long arg1, abi_long arg2,
- abi_long arg3, abi_long arg4, abi_long arg5)
- {
- print_syscall_prologue(name);
- print_raw_param("%d", arg0, 0);
- const IOCTLEntry *ie;
- const argtype *arg_type;
- void *argptr;
- int target_size;
- for (ie = ioctl_entries; ie->target_cmd != 0; ie++) {
- if (ie->target_cmd == arg1) {
- break;
- }
- }
- if (ie->target_cmd == 0) {
- print_raw_param("%#x", arg1, 0);
- print_raw_param("%#x", arg2, 1);
- } else {
- qemu_log("%s", ie->name);
- arg_type = ie->arg_type;
- if (arg_type[0] != TYPE_NULL) {
- qemu_log(",");
- switch (arg_type[0]) {
- case TYPE_PTRVOID:
- print_pointer(arg2, 1);
- break;
- case TYPE_CHAR:
- case TYPE_SHORT:
- case TYPE_INT:
- print_raw_param("%d", arg2, 1);
- break;
- case TYPE_LONG:
- print_raw_param(TARGET_ABI_FMT_ld, arg2, 1);
- break;
- case TYPE_ULONG:
- print_raw_param(TARGET_ABI_FMT_lu, arg2, 1);
- break;
- case TYPE_PTR:
- switch (ie->access) {
- case IOC_R:
- print_pointer(arg2, 1);
- break;
- case IOC_W:
- case IOC_RW:
- arg_type++;
- target_size = thunk_type_size(arg_type, 0);
- argptr = lock_user(VERIFY_READ, arg2, target_size, 1);
- if (argptr) {
- thunk_print(argptr, arg_type);
- unlock_user(argptr, arg2, target_size);
- } else {
- print_pointer(arg2, 1);
- }
- break;
- }
- break;
- default:
- g_assert_not_reached();
- }
- }
- }
- print_syscall_epilogue(name);
- }
- #endif
- /*
- * An array of all of the syscalls we know about
- */
- static const struct syscallname scnames[] = {
- #include "strace.list"
- };
- static int nsyscalls = ARRAY_SIZE(scnames);
- /*
- * The public interface to this module.
- */
- void
- print_syscall(CPUArchState *cpu_env, int num,
- abi_long arg1, abi_long arg2, abi_long arg3,
- abi_long arg4, abi_long arg5, abi_long arg6)
- {
- int i;
- FILE *f;
- const char *format = "%s(" TARGET_ABI_FMT_ld "," TARGET_ABI_FMT_ld ","
- TARGET_ABI_FMT_ld "," TARGET_ABI_FMT_ld ","
- TARGET_ABI_FMT_ld "," TARGET_ABI_FMT_ld ")";
- f = qemu_log_trylock();
- if (!f) {
- return;
- }
- fprintf(f, "%d ", getpid());
- for (i = 0; i < nsyscalls; i++) {
- if (scnames[i].nr == num) {
- if (scnames[i].call != NULL) {
- scnames[i].call(cpu_env, &scnames[i], arg1, arg2, arg3,
- arg4, arg5, arg6);
- } else {
- /* XXX: this format system is broken because it uses
- host types and host pointers for strings */
- if (scnames[i].format != NULL) {
- format = scnames[i].format;
- }
- fprintf(f, format, scnames[i].name, arg1, arg2,
- arg3, arg4, arg5, arg6);
- }
- qemu_log_unlock(f);
- return;
- }
- }
- fprintf(f, "Unknown syscall %d\n", num);
- qemu_log_unlock(f);
- }
- void
- print_syscall_ret(CPUArchState *cpu_env, int num, abi_long ret,
- abi_long arg1, abi_long arg2, abi_long arg3,
- abi_long arg4, abi_long arg5, abi_long arg6)
- {
- int i;
- FILE *f;
- f = qemu_log_trylock();
- if (!f) {
- return;
- }
- for (i = 0; i < nsyscalls; i++) {
- if (scnames[i].nr == num) {
- if (scnames[i].result != NULL) {
- scnames[i].result(cpu_env, &scnames[i], ret,
- arg1, arg2, arg3,
- arg4, arg5, arg6);
- } else {
- if (!print_syscall_err(ret)) {
- fprintf(f, TARGET_ABI_FMT_ld, ret);
- }
- fprintf(f, "\n");
- }
- break;
- }
- }
- qemu_log_unlock(f);
- }
- void print_taken_signal(int target_signum, const target_siginfo_t *tinfo)
- {
- /* Print the strace output for a signal being taken:
- * --- SIGSEGV {si_signo=SIGSEGV, si_code=SI_KERNEL, si_addr=0} ---
- */
- FILE *f;
- f = qemu_log_trylock();
- if (!f) {
- return;
- }
- fprintf(f, "--- ");
- print_signal(target_signum, 1);
- fprintf(f, " ");
- print_siginfo(tinfo);
- fprintf(f, " ---\n");
- qemu_log_unlock(f);
- }
|