| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745274627472748274927502751275227532754275527562757275827592760276127622763276427652766276727682769277027712772277327742775277627772778277927802781278227832784278527862787278827892790279127922793279427952796279727982799280028012802280328042805280628072808280928102811281228132814281528162817281828192820282128222823282428252826282728282829283028312832283328342835283628372838283928402841284228432844284528462847284828492850285128522853285428552856285728582859286028612862286328642865286628672868286928702871287228732874287528762877287828792880288128822883288428852886288728882889289028912892289328942895289628972898289929002901290229032904290529062907290829092910291129122913291429152916291729182919292029212922292329242925292629272928292929302931293229332934 |
- /*
- * Copyright (C) 2019 Intel Corporation. All rights reserved.
- * SPDX-License-Identifier: Apache-2.0 WITH LLVM-exception
- */
- #include "aot_compiler.h"
- #include "aot_emit_compare.h"
- #include "aot_emit_conversion.h"
- #include "aot_emit_memory.h"
- #include "aot_emit_variable.h"
- #include "aot_emit_const.h"
- #include "aot_emit_exception.h"
- #include "aot_emit_numberic.h"
- #include "aot_emit_control.h"
- #include "aot_emit_function.h"
- #include "aot_emit_parametric.h"
- #include "aot_emit_table.h"
- #include "simd/simd_access_lanes.h"
- #include "simd/simd_bitmask_extracts.h"
- #include "simd/simd_bit_shifts.h"
- #include "simd/simd_bitwise_ops.h"
- #include "simd/simd_bool_reductions.h"
- #include "simd/simd_comparisons.h"
- #include "simd/simd_conversions.h"
- #include "simd/simd_construct_values.h"
- #include "simd/simd_conversions.h"
- #include "simd/simd_floating_point.h"
- #include "simd/simd_int_arith.h"
- #include "simd/simd_load_store.h"
- #include "simd/simd_sat_int_arith.h"
- #include "../aot/aot_runtime.h"
- #include "../interpreter/wasm_opcode.h"
- #include <errno.h>
- #if WASM_ENABLE_DEBUG_AOT != 0
- #include "debug/dwarf_extractor.h"
- #endif
- #define CHECK_BUF(buf, buf_end, length) \
- do { \
- if (buf + length > buf_end) { \
- aot_set_last_error("read leb failed: unexpected end."); \
- return false; \
- } \
- } while (0)
- static bool
- read_leb(const uint8 *buf, const uint8 *buf_end, uint32 *p_offset,
- uint32 maxbits, bool sign, uint64 *p_result)
- {
- uint64 result = 0;
- uint32 shift = 0;
- uint32 bcnt = 0;
- uint64 byte;
- while (true) {
- CHECK_BUF(buf, buf_end, 1);
- byte = buf[*p_offset];
- *p_offset += 1;
- result |= ((byte & 0x7f) << shift);
- shift += 7;
- if ((byte & 0x80) == 0) {
- break;
- }
- bcnt += 1;
- }
- if (bcnt > (maxbits + 6) / 7) {
- aot_set_last_error("read leb failed: "
- "integer representation too long");
- return false;
- }
- if (sign && (shift < maxbits) && (byte & 0x40)) {
- /* Sign extend */
- result |= (~((uint64)0)) << shift;
- }
- *p_result = result;
- return true;
- }
- #define read_leb_uint32(p, p_end, res) \
- do { \
- uint32 off = 0; \
- uint64 res64; \
- if (!read_leb(p, p_end, &off, 32, false, &res64)) \
- return false; \
- p += off; \
- res = (uint32)res64; \
- } while (0)
- #define read_leb_int32(p, p_end, res) \
- do { \
- uint32 off = 0; \
- uint64 res64; \
- if (!read_leb(p, p_end, &off, 32, true, &res64)) \
- return false; \
- p += off; \
- res = (int32)res64; \
- } while (0)
- #define read_leb_int64(p, p_end, res) \
- do { \
- uint32 off = 0; \
- uint64 res64; \
- if (!read_leb(p, p_end, &off, 64, true, &res64)) \
- return false; \
- p += off; \
- res = (int64)res64; \
- } while (0)
- /**
- * Since Wamrc uses a full feature Wasm loader,
- * add a post-validator here to run checks according
- * to options, like enable_tail_call, enable_ref_types,
- * and so on.
- */
- static bool
- aot_validate_wasm(AOTCompContext *comp_ctx)
- {
- if (!comp_ctx->enable_ref_types) {
- /* Doesn't support multiple tables unless enabling reference type */
- if (comp_ctx->comp_data->import_table_count
- + comp_ctx->comp_data->table_count
- > 1) {
- aot_set_last_error("multiple tables");
- return false;
- }
- }
- return true;
- }
- #define COMPILE_ATOMIC_RMW(OP, NAME) \
- case WASM_OP_ATOMIC_RMW_I32_##NAME: \
- bytes = 4; \
- op_type = VALUE_TYPE_I32; \
- goto OP_ATOMIC_##OP; \
- case WASM_OP_ATOMIC_RMW_I64_##NAME: \
- bytes = 8; \
- op_type = VALUE_TYPE_I64; \
- goto OP_ATOMIC_##OP; \
- case WASM_OP_ATOMIC_RMW_I32_##NAME##8_U: \
- bytes = 1; \
- op_type = VALUE_TYPE_I32; \
- goto OP_ATOMIC_##OP; \
- case WASM_OP_ATOMIC_RMW_I32_##NAME##16_U: \
- bytes = 2; \
- op_type = VALUE_TYPE_I32; \
- goto OP_ATOMIC_##OP; \
- case WASM_OP_ATOMIC_RMW_I64_##NAME##8_U: \
- bytes = 1; \
- op_type = VALUE_TYPE_I64; \
- goto OP_ATOMIC_##OP; \
- case WASM_OP_ATOMIC_RMW_I64_##NAME##16_U: \
- bytes = 2; \
- op_type = VALUE_TYPE_I64; \
- goto OP_ATOMIC_##OP; \
- case WASM_OP_ATOMIC_RMW_I64_##NAME##32_U: \
- bytes = 4; \
- op_type = VALUE_TYPE_I64; \
- OP_ATOMIC_##OP : bin_op = LLVMAtomicRMWBinOp##OP; \
- goto build_atomic_rmw;
- static bool
- aot_compile_func(AOTCompContext *comp_ctx, uint32 func_index)
- {
- AOTFuncContext *func_ctx = comp_ctx->func_ctxes[func_index];
- uint8 *frame_ip = func_ctx->aot_func->code, opcode, *p_f32, *p_f64;
- uint8 *frame_ip_end = frame_ip + func_ctx->aot_func->code_size;
- uint8 *param_types = NULL;
- uint8 *result_types = NULL;
- uint8 value_type;
- uint16 param_count;
- uint16 result_count;
- uint32 br_depth, *br_depths, br_count;
- uint32 func_idx, type_idx, mem_idx, local_idx, global_idx, i;
- uint32 bytes = 4, align, offset;
- uint32 type_index;
- bool sign = true;
- int32 i32_const;
- int64 i64_const;
- float32 f32_const;
- float64 f64_const;
- AOTFuncType *func_type = NULL;
- #if WASM_ENABLE_DEBUG_AOT != 0
- LLVMMetadataRef location;
- #endif
- /* Start to translate the opcodes */
- LLVMPositionBuilderAtEnd(
- comp_ctx->builder,
- func_ctx->block_stack.block_list_head->llvm_entry_block);
- while (frame_ip < frame_ip_end) {
- opcode = *frame_ip++;
- #if WASM_ENABLE_DEBUG_AOT != 0
- location = dwarf_gen_location(
- comp_ctx, func_ctx,
- (frame_ip - 1) - comp_ctx->comp_data->wasm_module->buf_code);
- if (location != NULL) {
- LLVMSetCurrentDebugLocation2(comp_ctx->builder, location);
- }
- #endif
- switch (opcode) {
- case WASM_OP_UNREACHABLE:
- if (!aot_compile_op_unreachable(comp_ctx, func_ctx, &frame_ip))
- return false;
- break;
- case WASM_OP_NOP:
- break;
- case WASM_OP_BLOCK:
- case WASM_OP_LOOP:
- case WASM_OP_IF:
- {
- value_type = *frame_ip++;
- if (value_type == VALUE_TYPE_I32 || value_type == VALUE_TYPE_I64
- || value_type == VALUE_TYPE_F32
- || value_type == VALUE_TYPE_F64
- || value_type == VALUE_TYPE_V128
- || value_type == VALUE_TYPE_VOID
- || value_type == VALUE_TYPE_FUNCREF
- || value_type == VALUE_TYPE_EXTERNREF) {
- param_count = 0;
- param_types = NULL;
- if (value_type == VALUE_TYPE_VOID) {
- result_count = 0;
- result_types = NULL;
- }
- else {
- result_count = 1;
- result_types = &value_type;
- }
- }
- else {
- frame_ip--;
- read_leb_uint32(frame_ip, frame_ip_end, type_index);
- func_type = comp_ctx->comp_data->func_types[type_index];
- param_count = func_type->param_count;
- param_types = func_type->types;
- result_count = func_type->result_count;
- result_types = func_type->types + param_count;
- }
- if (!aot_compile_op_block(
- comp_ctx, func_ctx, &frame_ip, frame_ip_end,
- (uint32)(LABEL_TYPE_BLOCK + opcode - WASM_OP_BLOCK),
- param_count, param_types, result_count, result_types))
- return false;
- break;
- }
- case EXT_OP_BLOCK:
- case EXT_OP_LOOP:
- case EXT_OP_IF:
- {
- read_leb_uint32(frame_ip, frame_ip_end, type_index);
- func_type = comp_ctx->comp_data->func_types[type_index];
- param_count = func_type->param_count;
- param_types = func_type->types;
- result_count = func_type->result_count;
- result_types = func_type->types + param_count;
- if (!aot_compile_op_block(
- comp_ctx, func_ctx, &frame_ip, frame_ip_end,
- (uint32)(LABEL_TYPE_BLOCK + opcode - EXT_OP_BLOCK),
- param_count, param_types, result_count, result_types))
- return false;
- break;
- }
- case WASM_OP_ELSE:
- if (!aot_compile_op_else(comp_ctx, func_ctx, &frame_ip))
- return false;
- break;
- case WASM_OP_END:
- if (!aot_compile_op_end(comp_ctx, func_ctx, &frame_ip))
- return false;
- break;
- case WASM_OP_BR:
- read_leb_uint32(frame_ip, frame_ip_end, br_depth);
- if (!aot_compile_op_br(comp_ctx, func_ctx, br_depth, &frame_ip))
- return false;
- break;
- case WASM_OP_BR_IF:
- read_leb_uint32(frame_ip, frame_ip_end, br_depth);
- if (!aot_compile_op_br_if(comp_ctx, func_ctx, br_depth,
- &frame_ip))
- return false;
- break;
- case WASM_OP_BR_TABLE:
- read_leb_uint32(frame_ip, frame_ip_end, br_count);
- if (!(br_depths = wasm_runtime_malloc((uint32)sizeof(uint32)
- * (br_count + 1)))) {
- aot_set_last_error("allocate memory failed.");
- goto fail;
- }
- #if WASM_ENABLE_FAST_INTERP != 0
- for (i = 0; i <= br_count; i++)
- read_leb_uint32(frame_ip, frame_ip_end, br_depths[i]);
- #else
- for (i = 0; i <= br_count; i++)
- br_depths[i] = *frame_ip++;
- #endif
- if (!aot_compile_op_br_table(comp_ctx, func_ctx, br_depths,
- br_count, &frame_ip)) {
- wasm_runtime_free(br_depths);
- return false;
- }
- wasm_runtime_free(br_depths);
- break;
- #if WASM_ENABLE_FAST_INTERP == 0
- case EXT_OP_BR_TABLE_CACHE:
- {
- BrTableCache *node = bh_list_first_elem(
- comp_ctx->comp_data->wasm_module->br_table_cache_list);
- BrTableCache *node_next;
- uint8 *p_opcode = frame_ip - 1;
- read_leb_uint32(frame_ip, frame_ip_end, br_count);
- while (node) {
- node_next = bh_list_elem_next(node);
- if (node->br_table_op_addr == p_opcode) {
- br_depths = node->br_depths;
- if (!aot_compile_op_br_table(comp_ctx, func_ctx,
- br_depths, br_count,
- &frame_ip)) {
- return false;
- }
- break;
- }
- node = node_next;
- }
- bh_assert(node);
- break;
- }
- #endif
- case WASM_OP_RETURN:
- if (!aot_compile_op_return(comp_ctx, func_ctx, &frame_ip))
- return false;
- break;
- case WASM_OP_CALL:
- read_leb_uint32(frame_ip, frame_ip_end, func_idx);
- if (!aot_compile_op_call(comp_ctx, func_ctx, func_idx, false))
- return false;
- break;
- case WASM_OP_CALL_INDIRECT:
- {
- uint32 tbl_idx;
- read_leb_uint32(frame_ip, frame_ip_end, type_idx);
- #if WASM_ENABLE_REF_TYPES != 0
- if (comp_ctx->enable_ref_types) {
- read_leb_uint32(frame_ip, frame_ip_end, tbl_idx);
- }
- else
- #endif
- {
- frame_ip++;
- tbl_idx = 0;
- }
- if (!aot_compile_op_call_indirect(comp_ctx, func_ctx, type_idx,
- tbl_idx))
- return false;
- break;
- }
- #if WASM_ENABLE_TAIL_CALL != 0
- case WASM_OP_RETURN_CALL:
- if (!comp_ctx->enable_tail_call) {
- aot_set_last_error("unsupported opcode");
- return false;
- }
- read_leb_uint32(frame_ip, frame_ip_end, func_idx);
- if (!aot_compile_op_call(comp_ctx, func_ctx, func_idx, true))
- return false;
- if (!aot_compile_op_return(comp_ctx, func_ctx, &frame_ip))
- return false;
- break;
- case WASM_OP_RETURN_CALL_INDIRECT:
- {
- uint32 tbl_idx;
- if (!comp_ctx->enable_tail_call) {
- aot_set_last_error("unsupported opcode");
- return false;
- }
- read_leb_uint32(frame_ip, frame_ip_end, type_idx);
- #if WASM_ENABLE_REF_TYPES != 0
- if (comp_ctx->enable_ref_types) {
- read_leb_uint32(frame_ip, frame_ip_end, tbl_idx);
- }
- else
- #endif
- {
- frame_ip++;
- tbl_idx = 0;
- }
- if (!aot_compile_op_call_indirect(comp_ctx, func_ctx, type_idx,
- tbl_idx))
- return false;
- if (!aot_compile_op_return(comp_ctx, func_ctx, &frame_ip))
- return false;
- break;
- }
- #endif /* end of WASM_ENABLE_TAIL_CALL */
- case WASM_OP_DROP:
- if (!aot_compile_op_drop(comp_ctx, func_ctx, true))
- return false;
- break;
- case WASM_OP_DROP_64:
- if (!aot_compile_op_drop(comp_ctx, func_ctx, false))
- return false;
- break;
- case WASM_OP_SELECT:
- if (!aot_compile_op_select(comp_ctx, func_ctx, true))
- return false;
- break;
- case WASM_OP_SELECT_64:
- if (!aot_compile_op_select(comp_ctx, func_ctx, false))
- return false;
- break;
- #if WASM_ENABLE_REF_TYPES != 0
- case WASM_OP_SELECT_T:
- {
- uint32 vec_len;
- if (!comp_ctx->enable_ref_types) {
- goto unsupport_ref_types;
- }
- read_leb_uint32(frame_ip, frame_ip_end, vec_len);
- bh_assert(vec_len == 1);
- (void)vec_len;
- type_idx = *frame_ip++;
- if (!aot_compile_op_select(comp_ctx, func_ctx,
- (type_idx != VALUE_TYPE_I64)
- && (type_idx != VALUE_TYPE_F64)))
- return false;
- break;
- }
- case WASM_OP_TABLE_GET:
- {
- uint32 tbl_idx;
- if (!comp_ctx->enable_ref_types) {
- goto unsupport_ref_types;
- }
- read_leb_uint32(frame_ip, frame_ip_end, tbl_idx);
- if (!aot_compile_op_table_get(comp_ctx, func_ctx, tbl_idx))
- return false;
- break;
- }
- case WASM_OP_TABLE_SET:
- {
- uint32 tbl_idx;
- if (!comp_ctx->enable_ref_types) {
- goto unsupport_ref_types;
- }
- read_leb_uint32(frame_ip, frame_ip_end, tbl_idx);
- if (!aot_compile_op_table_set(comp_ctx, func_ctx, tbl_idx))
- return false;
- break;
- }
- case WASM_OP_REF_NULL:
- {
- uint32 type;
- if (!comp_ctx->enable_ref_types) {
- goto unsupport_ref_types;
- }
- read_leb_uint32(frame_ip, frame_ip_end, type);
- if (!aot_compile_op_ref_null(comp_ctx, func_ctx))
- return false;
- (void)type;
- break;
- }
- case WASM_OP_REF_IS_NULL:
- {
- if (!comp_ctx->enable_ref_types) {
- goto unsupport_ref_types;
- }
- if (!aot_compile_op_ref_is_null(comp_ctx, func_ctx))
- return false;
- break;
- }
- case WASM_OP_REF_FUNC:
- {
- if (!comp_ctx->enable_ref_types) {
- goto unsupport_ref_types;
- }
- read_leb_uint32(frame_ip, frame_ip_end, func_idx);
- if (!aot_compile_op_ref_func(comp_ctx, func_ctx, func_idx))
- return false;
- break;
- }
- #endif
- case WASM_OP_GET_LOCAL:
- read_leb_uint32(frame_ip, frame_ip_end, local_idx);
- if (!aot_compile_op_get_local(comp_ctx, func_ctx, local_idx))
- return false;
- break;
- case WASM_OP_SET_LOCAL:
- read_leb_uint32(frame_ip, frame_ip_end, local_idx);
- if (!aot_compile_op_set_local(comp_ctx, func_ctx, local_idx))
- return false;
- break;
- case WASM_OP_TEE_LOCAL:
- read_leb_uint32(frame_ip, frame_ip_end, local_idx);
- if (!aot_compile_op_tee_local(comp_ctx, func_ctx, local_idx))
- return false;
- break;
- case WASM_OP_GET_GLOBAL:
- case WASM_OP_GET_GLOBAL_64:
- read_leb_uint32(frame_ip, frame_ip_end, global_idx);
- if (!aot_compile_op_get_global(comp_ctx, func_ctx, global_idx))
- return false;
- break;
- case WASM_OP_SET_GLOBAL:
- case WASM_OP_SET_GLOBAL_64:
- case WASM_OP_SET_GLOBAL_AUX_STACK:
- read_leb_uint32(frame_ip, frame_ip_end, global_idx);
- if (!aot_compile_op_set_global(
- comp_ctx, func_ctx, global_idx,
- opcode == WASM_OP_SET_GLOBAL_AUX_STACK ? true : false))
- return false;
- break;
- case WASM_OP_I32_LOAD:
- bytes = 4;
- sign = true;
- goto op_i32_load;
- case WASM_OP_I32_LOAD8_S:
- case WASM_OP_I32_LOAD8_U:
- bytes = 1;
- sign = (opcode == WASM_OP_I32_LOAD8_S) ? true : false;
- goto op_i32_load;
- case WASM_OP_I32_LOAD16_S:
- case WASM_OP_I32_LOAD16_U:
- bytes = 2;
- sign = (opcode == WASM_OP_I32_LOAD16_S) ? true : false;
- op_i32_load:
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_op_i32_load(comp_ctx, func_ctx, align, offset,
- bytes, sign, false))
- return false;
- break;
- case WASM_OP_I64_LOAD:
- bytes = 8;
- sign = true;
- goto op_i64_load;
- case WASM_OP_I64_LOAD8_S:
- case WASM_OP_I64_LOAD8_U:
- bytes = 1;
- sign = (opcode == WASM_OP_I64_LOAD8_S) ? true : false;
- goto op_i64_load;
- case WASM_OP_I64_LOAD16_S:
- case WASM_OP_I64_LOAD16_U:
- bytes = 2;
- sign = (opcode == WASM_OP_I64_LOAD16_S) ? true : false;
- goto op_i64_load;
- case WASM_OP_I64_LOAD32_S:
- case WASM_OP_I64_LOAD32_U:
- bytes = 4;
- sign = (opcode == WASM_OP_I64_LOAD32_S) ? true : false;
- op_i64_load:
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_op_i64_load(comp_ctx, func_ctx, align, offset,
- bytes, sign, false))
- return false;
- break;
- case WASM_OP_F32_LOAD:
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_op_f32_load(comp_ctx, func_ctx, align, offset))
- return false;
- break;
- case WASM_OP_F64_LOAD:
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_op_f64_load(comp_ctx, func_ctx, align, offset))
- return false;
- break;
- case WASM_OP_I32_STORE:
- bytes = 4;
- goto op_i32_store;
- case WASM_OP_I32_STORE8:
- bytes = 1;
- goto op_i32_store;
- case WASM_OP_I32_STORE16:
- bytes = 2;
- op_i32_store:
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_op_i32_store(comp_ctx, func_ctx, align, offset,
- bytes, false))
- return false;
- break;
- case WASM_OP_I64_STORE:
- bytes = 8;
- goto op_i64_store;
- case WASM_OP_I64_STORE8:
- bytes = 1;
- goto op_i64_store;
- case WASM_OP_I64_STORE16:
- bytes = 2;
- goto op_i64_store;
- case WASM_OP_I64_STORE32:
- bytes = 4;
- op_i64_store:
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_op_i64_store(comp_ctx, func_ctx, align, offset,
- bytes, false))
- return false;
- break;
- case WASM_OP_F32_STORE:
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_op_f32_store(comp_ctx, func_ctx, align,
- offset))
- return false;
- break;
- case WASM_OP_F64_STORE:
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_op_f64_store(comp_ctx, func_ctx, align,
- offset))
- return false;
- break;
- case WASM_OP_MEMORY_SIZE:
- read_leb_uint32(frame_ip, frame_ip_end, mem_idx);
- if (!aot_compile_op_memory_size(comp_ctx, func_ctx))
- return false;
- (void)mem_idx;
- break;
- case WASM_OP_MEMORY_GROW:
- read_leb_uint32(frame_ip, frame_ip_end, mem_idx);
- if (!aot_compile_op_memory_grow(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I32_CONST:
- read_leb_int32(frame_ip, frame_ip_end, i32_const);
- if (!aot_compile_op_i32_const(comp_ctx, func_ctx, i32_const))
- return false;
- break;
- case WASM_OP_I64_CONST:
- read_leb_int64(frame_ip, frame_ip_end, i64_const);
- if (!aot_compile_op_i64_const(comp_ctx, func_ctx, i64_const))
- return false;
- break;
- case WASM_OP_F32_CONST:
- p_f32 = (uint8 *)&f32_const;
- for (i = 0; i < sizeof(float32); i++)
- *p_f32++ = *frame_ip++;
- if (!aot_compile_op_f32_const(comp_ctx, func_ctx, f32_const))
- return false;
- break;
- case WASM_OP_F64_CONST:
- p_f64 = (uint8 *)&f64_const;
- for (i = 0; i < sizeof(float64); i++)
- *p_f64++ = *frame_ip++;
- if (!aot_compile_op_f64_const(comp_ctx, func_ctx, f64_const))
- return false;
- break;
- case WASM_OP_I32_EQZ:
- case WASM_OP_I32_EQ:
- case WASM_OP_I32_NE:
- case WASM_OP_I32_LT_S:
- case WASM_OP_I32_LT_U:
- case WASM_OP_I32_GT_S:
- case WASM_OP_I32_GT_U:
- case WASM_OP_I32_LE_S:
- case WASM_OP_I32_LE_U:
- case WASM_OP_I32_GE_S:
- case WASM_OP_I32_GE_U:
- if (!aot_compile_op_i32_compare(
- comp_ctx, func_ctx, INT_EQZ + opcode - WASM_OP_I32_EQZ))
- return false;
- break;
- case WASM_OP_I64_EQZ:
- case WASM_OP_I64_EQ:
- case WASM_OP_I64_NE:
- case WASM_OP_I64_LT_S:
- case WASM_OP_I64_LT_U:
- case WASM_OP_I64_GT_S:
- case WASM_OP_I64_GT_U:
- case WASM_OP_I64_LE_S:
- case WASM_OP_I64_LE_U:
- case WASM_OP_I64_GE_S:
- case WASM_OP_I64_GE_U:
- if (!aot_compile_op_i64_compare(
- comp_ctx, func_ctx, INT_EQZ + opcode - WASM_OP_I64_EQZ))
- return false;
- break;
- case WASM_OP_F32_EQ:
- case WASM_OP_F32_NE:
- case WASM_OP_F32_LT:
- case WASM_OP_F32_GT:
- case WASM_OP_F32_LE:
- case WASM_OP_F32_GE:
- if (!aot_compile_op_f32_compare(
- comp_ctx, func_ctx, FLOAT_EQ + opcode - WASM_OP_F32_EQ))
- return false;
- break;
- case WASM_OP_F64_EQ:
- case WASM_OP_F64_NE:
- case WASM_OP_F64_LT:
- case WASM_OP_F64_GT:
- case WASM_OP_F64_LE:
- case WASM_OP_F64_GE:
- if (!aot_compile_op_f64_compare(
- comp_ctx, func_ctx, FLOAT_EQ + opcode - WASM_OP_F64_EQ))
- return false;
- break;
- case WASM_OP_I32_CLZ:
- if (!aot_compile_op_i32_clz(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I32_CTZ:
- if (!aot_compile_op_i32_ctz(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I32_POPCNT:
- if (!aot_compile_op_i32_popcnt(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I32_ADD:
- case WASM_OP_I32_SUB:
- case WASM_OP_I32_MUL:
- case WASM_OP_I32_DIV_S:
- case WASM_OP_I32_DIV_U:
- case WASM_OP_I32_REM_S:
- case WASM_OP_I32_REM_U:
- if (!aot_compile_op_i32_arithmetic(
- comp_ctx, func_ctx, INT_ADD + opcode - WASM_OP_I32_ADD,
- &frame_ip))
- return false;
- break;
- case WASM_OP_I32_AND:
- case WASM_OP_I32_OR:
- case WASM_OP_I32_XOR:
- if (!aot_compile_op_i32_bitwise(
- comp_ctx, func_ctx, INT_SHL + opcode - WASM_OP_I32_AND))
- return false;
- break;
- case WASM_OP_I32_SHL:
- case WASM_OP_I32_SHR_S:
- case WASM_OP_I32_SHR_U:
- case WASM_OP_I32_ROTL:
- case WASM_OP_I32_ROTR:
- if (!aot_compile_op_i32_shift(
- comp_ctx, func_ctx, INT_SHL + opcode - WASM_OP_I32_SHL))
- return false;
- break;
- case WASM_OP_I64_CLZ:
- if (!aot_compile_op_i64_clz(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I64_CTZ:
- if (!aot_compile_op_i64_ctz(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I64_POPCNT:
- if (!aot_compile_op_i64_popcnt(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I64_ADD:
- case WASM_OP_I64_SUB:
- case WASM_OP_I64_MUL:
- case WASM_OP_I64_DIV_S:
- case WASM_OP_I64_DIV_U:
- case WASM_OP_I64_REM_S:
- case WASM_OP_I64_REM_U:
- if (!aot_compile_op_i64_arithmetic(
- comp_ctx, func_ctx, INT_ADD + opcode - WASM_OP_I64_ADD,
- &frame_ip))
- return false;
- break;
- case WASM_OP_I64_AND:
- case WASM_OP_I64_OR:
- case WASM_OP_I64_XOR:
- if (!aot_compile_op_i64_bitwise(
- comp_ctx, func_ctx, INT_SHL + opcode - WASM_OP_I64_AND))
- return false;
- break;
- case WASM_OP_I64_SHL:
- case WASM_OP_I64_SHR_S:
- case WASM_OP_I64_SHR_U:
- case WASM_OP_I64_ROTL:
- case WASM_OP_I64_ROTR:
- if (!aot_compile_op_i64_shift(
- comp_ctx, func_ctx, INT_SHL + opcode - WASM_OP_I64_SHL))
- return false;
- break;
- case WASM_OP_F32_ABS:
- case WASM_OP_F32_NEG:
- case WASM_OP_F32_CEIL:
- case WASM_OP_F32_FLOOR:
- case WASM_OP_F32_TRUNC:
- case WASM_OP_F32_NEAREST:
- case WASM_OP_F32_SQRT:
- if (!aot_compile_op_f32_math(comp_ctx, func_ctx,
- FLOAT_ABS + opcode
- - WASM_OP_F32_ABS))
- return false;
- break;
- case WASM_OP_F32_ADD:
- case WASM_OP_F32_SUB:
- case WASM_OP_F32_MUL:
- case WASM_OP_F32_DIV:
- case WASM_OP_F32_MIN:
- case WASM_OP_F32_MAX:
- if (!aot_compile_op_f32_arithmetic(comp_ctx, func_ctx,
- FLOAT_ADD + opcode
- - WASM_OP_F32_ADD))
- return false;
- break;
- case WASM_OP_F32_COPYSIGN:
- if (!aot_compile_op_f32_copysign(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_F64_ABS:
- case WASM_OP_F64_NEG:
- case WASM_OP_F64_CEIL:
- case WASM_OP_F64_FLOOR:
- case WASM_OP_F64_TRUNC:
- case WASM_OP_F64_NEAREST:
- case WASM_OP_F64_SQRT:
- if (!aot_compile_op_f64_math(comp_ctx, func_ctx,
- FLOAT_ABS + opcode
- - WASM_OP_F64_ABS))
- return false;
- break;
- case WASM_OP_F64_ADD:
- case WASM_OP_F64_SUB:
- case WASM_OP_F64_MUL:
- case WASM_OP_F64_DIV:
- case WASM_OP_F64_MIN:
- case WASM_OP_F64_MAX:
- if (!aot_compile_op_f64_arithmetic(comp_ctx, func_ctx,
- FLOAT_ADD + opcode
- - WASM_OP_F64_ADD))
- return false;
- break;
- case WASM_OP_F64_COPYSIGN:
- if (!aot_compile_op_f64_copysign(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I32_WRAP_I64:
- if (!aot_compile_op_i32_wrap_i64(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I32_TRUNC_S_F32:
- case WASM_OP_I32_TRUNC_U_F32:
- sign = (opcode == WASM_OP_I32_TRUNC_S_F32) ? true : false;
- if (!aot_compile_op_i32_trunc_f32(comp_ctx, func_ctx, sign,
- false))
- return false;
- break;
- case WASM_OP_I32_TRUNC_S_F64:
- case WASM_OP_I32_TRUNC_U_F64:
- sign = (opcode == WASM_OP_I32_TRUNC_S_F64) ? true : false;
- if (!aot_compile_op_i32_trunc_f64(comp_ctx, func_ctx, sign,
- false))
- return false;
- break;
- case WASM_OP_I64_EXTEND_S_I32:
- case WASM_OP_I64_EXTEND_U_I32:
- sign = (opcode == WASM_OP_I64_EXTEND_S_I32) ? true : false;
- if (!aot_compile_op_i64_extend_i32(comp_ctx, func_ctx, sign))
- return false;
- break;
- case WASM_OP_I64_TRUNC_S_F32:
- case WASM_OP_I64_TRUNC_U_F32:
- sign = (opcode == WASM_OP_I64_TRUNC_S_F32) ? true : false;
- if (!aot_compile_op_i64_trunc_f32(comp_ctx, func_ctx, sign,
- false))
- return false;
- break;
- case WASM_OP_I64_TRUNC_S_F64:
- case WASM_OP_I64_TRUNC_U_F64:
- sign = (opcode == WASM_OP_I64_TRUNC_S_F64) ? true : false;
- if (!aot_compile_op_i64_trunc_f64(comp_ctx, func_ctx, sign,
- false))
- return false;
- break;
- case WASM_OP_F32_CONVERT_S_I32:
- case WASM_OP_F32_CONVERT_U_I32:
- sign = (opcode == WASM_OP_F32_CONVERT_S_I32) ? true : false;
- if (!aot_compile_op_f32_convert_i32(comp_ctx, func_ctx, sign))
- return false;
- break;
- case WASM_OP_F32_CONVERT_S_I64:
- case WASM_OP_F32_CONVERT_U_I64:
- sign = (opcode == WASM_OP_F32_CONVERT_S_I64) ? true : false;
- if (!aot_compile_op_f32_convert_i64(comp_ctx, func_ctx, sign))
- return false;
- break;
- case WASM_OP_F32_DEMOTE_F64:
- if (!aot_compile_op_f32_demote_f64(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_F64_CONVERT_S_I32:
- case WASM_OP_F64_CONVERT_U_I32:
- sign = (opcode == WASM_OP_F64_CONVERT_S_I32) ? true : false;
- if (!aot_compile_op_f64_convert_i32(comp_ctx, func_ctx, sign))
- return false;
- break;
- case WASM_OP_F64_CONVERT_S_I64:
- case WASM_OP_F64_CONVERT_U_I64:
- sign = (opcode == WASM_OP_F64_CONVERT_S_I64) ? true : false;
- if (!aot_compile_op_f64_convert_i64(comp_ctx, func_ctx, sign))
- return false;
- break;
- case WASM_OP_F64_PROMOTE_F32:
- if (!aot_compile_op_f64_promote_f32(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I32_REINTERPRET_F32:
- if (!aot_compile_op_i32_reinterpret_f32(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I64_REINTERPRET_F64:
- if (!aot_compile_op_i64_reinterpret_f64(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_F32_REINTERPRET_I32:
- if (!aot_compile_op_f32_reinterpret_i32(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_F64_REINTERPRET_I64:
- if (!aot_compile_op_f64_reinterpret_i64(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_I32_EXTEND8_S:
- if (!aot_compile_op_i32_extend_i32(comp_ctx, func_ctx, 8))
- return false;
- break;
- case WASM_OP_I32_EXTEND16_S:
- if (!aot_compile_op_i32_extend_i32(comp_ctx, func_ctx, 16))
- return false;
- break;
- case WASM_OP_I64_EXTEND8_S:
- if (!aot_compile_op_i64_extend_i64(comp_ctx, func_ctx, 8))
- return false;
- break;
- case WASM_OP_I64_EXTEND16_S:
- if (!aot_compile_op_i64_extend_i64(comp_ctx, func_ctx, 16))
- return false;
- break;
- case WASM_OP_I64_EXTEND32_S:
- if (!aot_compile_op_i64_extend_i64(comp_ctx, func_ctx, 32))
- return false;
- break;
- case WASM_OP_MISC_PREFIX:
- {
- uint32 opcode1;
- read_leb_uint32(frame_ip, frame_ip_end, opcode1);
- /* opcode1 was checked in loader and is no larger than
- UINT8_MAX */
- opcode = (uint8)opcode1;
- #if WASM_ENABLE_BULK_MEMORY != 0
- if (WASM_OP_MEMORY_INIT <= opcode
- && opcode <= WASM_OP_MEMORY_FILL
- && !comp_ctx->enable_bulk_memory) {
- goto unsupport_bulk_memory;
- }
- #endif
- #if WASM_ENABLE_REF_TYPES != 0
- if (WASM_OP_TABLE_INIT <= opcode && opcode <= WASM_OP_TABLE_FILL
- && !comp_ctx->enable_ref_types) {
- goto unsupport_ref_types;
- }
- #endif
- switch (opcode) {
- case WASM_OP_I32_TRUNC_SAT_S_F32:
- case WASM_OP_I32_TRUNC_SAT_U_F32:
- sign = (opcode == WASM_OP_I32_TRUNC_SAT_S_F32) ? true
- : false;
- if (!aot_compile_op_i32_trunc_f32(comp_ctx, func_ctx,
- sign, true))
- return false;
- break;
- case WASM_OP_I32_TRUNC_SAT_S_F64:
- case WASM_OP_I32_TRUNC_SAT_U_F64:
- sign = (opcode == WASM_OP_I32_TRUNC_SAT_S_F64) ? true
- : false;
- if (!aot_compile_op_i32_trunc_f64(comp_ctx, func_ctx,
- sign, true))
- return false;
- break;
- case WASM_OP_I64_TRUNC_SAT_S_F32:
- case WASM_OP_I64_TRUNC_SAT_U_F32:
- sign = (opcode == WASM_OP_I64_TRUNC_SAT_S_F32) ? true
- : false;
- if (!aot_compile_op_i64_trunc_f32(comp_ctx, func_ctx,
- sign, true))
- return false;
- break;
- case WASM_OP_I64_TRUNC_SAT_S_F64:
- case WASM_OP_I64_TRUNC_SAT_U_F64:
- sign = (opcode == WASM_OP_I64_TRUNC_SAT_S_F64) ? true
- : false;
- if (!aot_compile_op_i64_trunc_f64(comp_ctx, func_ctx,
- sign, true))
- return false;
- break;
- #if WASM_ENABLE_BULK_MEMORY != 0
- case WASM_OP_MEMORY_INIT:
- {
- uint32 seg_index;
- read_leb_uint32(frame_ip, frame_ip_end, seg_index);
- frame_ip++;
- if (!aot_compile_op_memory_init(comp_ctx, func_ctx,
- seg_index))
- return false;
- break;
- }
- case WASM_OP_DATA_DROP:
- {
- uint32 seg_index;
- read_leb_uint32(frame_ip, frame_ip_end, seg_index);
- if (!aot_compile_op_data_drop(comp_ctx, func_ctx,
- seg_index))
- return false;
- break;
- }
- case WASM_OP_MEMORY_COPY:
- {
- frame_ip += 2;
- if (!aot_compile_op_memory_copy(comp_ctx, func_ctx))
- return false;
- break;
- }
- case WASM_OP_MEMORY_FILL:
- {
- frame_ip++;
- if (!aot_compile_op_memory_fill(comp_ctx, func_ctx))
- return false;
- break;
- }
- #endif /* WASM_ENABLE_BULK_MEMORY */
- #if WASM_ENABLE_REF_TYPES != 0
- case WASM_OP_TABLE_INIT:
- {
- uint32 tbl_idx, tbl_seg_idx;
- read_leb_uint32(frame_ip, frame_ip_end, tbl_seg_idx);
- read_leb_uint32(frame_ip, frame_ip_end, tbl_idx);
- if (!aot_compile_op_table_init(comp_ctx, func_ctx,
- tbl_idx, tbl_seg_idx))
- return false;
- break;
- }
- case WASM_OP_ELEM_DROP:
- {
- uint32 tbl_seg_idx;
- read_leb_uint32(frame_ip, frame_ip_end, tbl_seg_idx);
- if (!aot_compile_op_elem_drop(comp_ctx, func_ctx,
- tbl_seg_idx))
- return false;
- break;
- }
- case WASM_OP_TABLE_COPY:
- {
- uint32 src_tbl_idx, dst_tbl_idx;
- read_leb_uint32(frame_ip, frame_ip_end, dst_tbl_idx);
- read_leb_uint32(frame_ip, frame_ip_end, src_tbl_idx);
- if (!aot_compile_op_table_copy(
- comp_ctx, func_ctx, src_tbl_idx, dst_tbl_idx))
- return false;
- break;
- }
- case WASM_OP_TABLE_GROW:
- {
- uint32 tbl_idx;
- read_leb_uint32(frame_ip, frame_ip_end, tbl_idx);
- if (!aot_compile_op_table_grow(comp_ctx, func_ctx,
- tbl_idx))
- return false;
- break;
- }
- case WASM_OP_TABLE_SIZE:
- {
- uint32 tbl_idx;
- read_leb_uint32(frame_ip, frame_ip_end, tbl_idx);
- if (!aot_compile_op_table_size(comp_ctx, func_ctx,
- tbl_idx))
- return false;
- break;
- }
- case WASM_OP_TABLE_FILL:
- {
- uint32 tbl_idx;
- read_leb_uint32(frame_ip, frame_ip_end, tbl_idx);
- if (!aot_compile_op_table_fill(comp_ctx, func_ctx,
- tbl_idx))
- return false;
- break;
- }
- #endif /* WASM_ENABLE_REF_TYPES */
- default:
- aot_set_last_error("unsupported opcode");
- return false;
- }
- break;
- }
- #if WASM_ENABLE_SHARED_MEMORY != 0
- case WASM_OP_ATOMIC_PREFIX:
- {
- uint8 bin_op, op_type;
- uint32 opcode1;
- read_leb_uint32(frame_ip, frame_ip_end, opcode1);
- /* opcode1 was checked in loader and is no larger than
- UINT8_MAX */
- opcode = (uint8)opcode1;
- if (opcode != WASM_OP_ATOMIC_FENCE) {
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- }
- switch (opcode) {
- case WASM_OP_ATOMIC_WAIT32:
- if (!aot_compile_op_atomic_wait(comp_ctx, func_ctx,
- VALUE_TYPE_I32, align,
- offset, 4))
- return false;
- break;
- case WASM_OP_ATOMIC_WAIT64:
- if (!aot_compile_op_atomic_wait(comp_ctx, func_ctx,
- VALUE_TYPE_I64, align,
- offset, 8))
- return false;
- break;
- case WASM_OP_ATOMIC_NOTIFY:
- if (!aot_compiler_op_atomic_notify(
- comp_ctx, func_ctx, align, offset, bytes))
- return false;
- break;
- case WASM_OP_ATOMIC_FENCE:
- /* Skip memory index */
- frame_ip++;
- if (!aot_compiler_op_atomic_fence(comp_ctx, func_ctx))
- return false;
- break;
- case WASM_OP_ATOMIC_I32_LOAD:
- bytes = 4;
- goto op_atomic_i32_load;
- case WASM_OP_ATOMIC_I32_LOAD8_U:
- bytes = 1;
- goto op_atomic_i32_load;
- case WASM_OP_ATOMIC_I32_LOAD16_U:
- bytes = 2;
- op_atomic_i32_load:
- if (!aot_compile_op_i32_load(comp_ctx, func_ctx, align,
- offset, bytes, sign, true))
- return false;
- break;
- case WASM_OP_ATOMIC_I64_LOAD:
- bytes = 8;
- goto op_atomic_i64_load;
- case WASM_OP_ATOMIC_I64_LOAD8_U:
- bytes = 1;
- goto op_atomic_i64_load;
- case WASM_OP_ATOMIC_I64_LOAD16_U:
- bytes = 2;
- goto op_atomic_i64_load;
- case WASM_OP_ATOMIC_I64_LOAD32_U:
- bytes = 4;
- op_atomic_i64_load:
- if (!aot_compile_op_i64_load(comp_ctx, func_ctx, align,
- offset, bytes, sign, true))
- return false;
- break;
- case WASM_OP_ATOMIC_I32_STORE:
- bytes = 4;
- goto op_atomic_i32_store;
- case WASM_OP_ATOMIC_I32_STORE8:
- bytes = 1;
- goto op_atomic_i32_store;
- case WASM_OP_ATOMIC_I32_STORE16:
- bytes = 2;
- op_atomic_i32_store:
- if (!aot_compile_op_i32_store(comp_ctx, func_ctx, align,
- offset, bytes, true))
- return false;
- break;
- case WASM_OP_ATOMIC_I64_STORE:
- bytes = 8;
- goto op_atomic_i64_store;
- case WASM_OP_ATOMIC_I64_STORE8:
- bytes = 1;
- goto op_atomic_i64_store;
- case WASM_OP_ATOMIC_I64_STORE16:
- bytes = 2;
- goto op_atomic_i64_store;
- case WASM_OP_ATOMIC_I64_STORE32:
- bytes = 4;
- op_atomic_i64_store:
- if (!aot_compile_op_i64_store(comp_ctx, func_ctx, align,
- offset, bytes, true))
- return false;
- break;
- case WASM_OP_ATOMIC_RMW_I32_CMPXCHG:
- bytes = 4;
- op_type = VALUE_TYPE_I32;
- goto op_atomic_cmpxchg;
- case WASM_OP_ATOMIC_RMW_I64_CMPXCHG:
- bytes = 8;
- op_type = VALUE_TYPE_I64;
- goto op_atomic_cmpxchg;
- case WASM_OP_ATOMIC_RMW_I32_CMPXCHG8_U:
- bytes = 1;
- op_type = VALUE_TYPE_I32;
- goto op_atomic_cmpxchg;
- case WASM_OP_ATOMIC_RMW_I32_CMPXCHG16_U:
- bytes = 2;
- op_type = VALUE_TYPE_I32;
- goto op_atomic_cmpxchg;
- case WASM_OP_ATOMIC_RMW_I64_CMPXCHG8_U:
- bytes = 1;
- op_type = VALUE_TYPE_I64;
- goto op_atomic_cmpxchg;
- case WASM_OP_ATOMIC_RMW_I64_CMPXCHG16_U:
- bytes = 2;
- op_type = VALUE_TYPE_I64;
- goto op_atomic_cmpxchg;
- case WASM_OP_ATOMIC_RMW_I64_CMPXCHG32_U:
- bytes = 4;
- op_type = VALUE_TYPE_I64;
- op_atomic_cmpxchg:
- if (!aot_compile_op_atomic_cmpxchg(comp_ctx, func_ctx,
- op_type, align,
- offset, bytes))
- return false;
- break;
- COMPILE_ATOMIC_RMW(Add, ADD);
- COMPILE_ATOMIC_RMW(Sub, SUB);
- COMPILE_ATOMIC_RMW(And, AND);
- COMPILE_ATOMIC_RMW(Or, OR);
- COMPILE_ATOMIC_RMW(Xor, XOR);
- COMPILE_ATOMIC_RMW(Xchg, XCHG);
- build_atomic_rmw:
- if (!aot_compile_op_atomic_rmw(comp_ctx, func_ctx,
- bin_op, op_type, align,
- offset, bytes))
- return false;
- break;
- default:
- aot_set_last_error("unsupported opcode");
- return false;
- }
- break;
- }
- #endif /* end of WASM_ENABLE_SHARED_MEMORY */
- #if WASM_ENABLE_SIMD != 0
- case WASM_OP_SIMD_PREFIX:
- {
- uint32 opcode1;
- if (!comp_ctx->enable_simd) {
- goto unsupport_simd;
- }
- read_leb_uint32(frame_ip, frame_ip_end, opcode1);
- /* opcode1 was checked in loader and is no larger than
- UINT8_MAX */
- opcode = (uint8)opcode1;
- /* follow the order of enum WASMSimdEXTOpcode in
- wasm_opcode.h */
- switch (opcode) {
- /* Memory instruction */
- case SIMD_v128_load:
- {
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_simd_v128_load(comp_ctx, func_ctx,
- align, offset))
- return false;
- break;
- }
- case SIMD_v128_load8x8_s:
- case SIMD_v128_load8x8_u:
- case SIMD_v128_load16x4_s:
- case SIMD_v128_load16x4_u:
- case SIMD_v128_load32x2_s:
- case SIMD_v128_load32x2_u:
- {
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_simd_load_extend(
- comp_ctx, func_ctx, opcode, align, offset))
- return false;
- break;
- }
- case SIMD_v128_load8_splat:
- case SIMD_v128_load16_splat:
- case SIMD_v128_load32_splat:
- case SIMD_v128_load64_splat:
- {
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_simd_load_splat(comp_ctx, func_ctx,
- opcode, align, offset))
- return false;
- break;
- }
- case SIMD_v128_store:
- {
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_simd_v128_store(comp_ctx, func_ctx,
- align, offset))
- return false;
- break;
- }
- /* Basic operation */
- case SIMD_v128_const:
- {
- if (!aot_compile_simd_v128_const(comp_ctx, func_ctx,
- frame_ip))
- return false;
- frame_ip += 16;
- break;
- }
- case SIMD_v8x16_shuffle:
- {
- if (!aot_compile_simd_shuffle(comp_ctx, func_ctx,
- frame_ip))
- return false;
- frame_ip += 16;
- break;
- }
- case SIMD_v8x16_swizzle:
- {
- if (!aot_compile_simd_swizzle(comp_ctx, func_ctx))
- return false;
- break;
- }
- /* Splat operation */
- case SIMD_i8x16_splat:
- case SIMD_i16x8_splat:
- case SIMD_i32x4_splat:
- case SIMD_i64x2_splat:
- case SIMD_f32x4_splat:
- case SIMD_f64x2_splat:
- {
- if (!aot_compile_simd_splat(comp_ctx, func_ctx, opcode))
- return false;
- break;
- }
- /* Lane operation */
- case SIMD_i8x16_extract_lane_s:
- case SIMD_i8x16_extract_lane_u:
- {
- if (!aot_compile_simd_extract_i8x16(
- comp_ctx, func_ctx, *frame_ip++,
- SIMD_i8x16_extract_lane_s == opcode))
- return false;
- break;
- }
- case SIMD_i8x16_replace_lane:
- {
- if (!aot_compile_simd_replace_i8x16(comp_ctx, func_ctx,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_i16x8_extract_lane_s:
- case SIMD_i16x8_extract_lane_u:
- {
- if (!aot_compile_simd_extract_i16x8(
- comp_ctx, func_ctx, *frame_ip++,
- SIMD_i16x8_extract_lane_s == opcode))
- return false;
- break;
- }
- case SIMD_i16x8_replace_lane:
- {
- if (!aot_compile_simd_replace_i16x8(comp_ctx, func_ctx,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_i32x4_extract_lane:
- {
- if (!aot_compile_simd_extract_i32x4(comp_ctx, func_ctx,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_i32x4_replace_lane:
- {
- if (!aot_compile_simd_replace_i32x4(comp_ctx, func_ctx,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_i64x2_extract_lane:
- {
- if (!aot_compile_simd_extract_i64x2(comp_ctx, func_ctx,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_i64x2_replace_lane:
- {
- if (!aot_compile_simd_replace_i64x2(comp_ctx, func_ctx,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_f32x4_extract_lane:
- {
- if (!aot_compile_simd_extract_f32x4(comp_ctx, func_ctx,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_f32x4_replace_lane:
- {
- if (!aot_compile_simd_replace_f32x4(comp_ctx, func_ctx,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_f64x2_extract_lane:
- {
- if (!aot_compile_simd_extract_f64x2(comp_ctx, func_ctx,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_f64x2_replace_lane:
- {
- if (!aot_compile_simd_replace_f64x2(comp_ctx, func_ctx,
- *frame_ip++))
- return false;
- break;
- }
- /* i8x16 Cmp */
- case SIMD_i8x16_eq:
- case SIMD_i8x16_ne:
- case SIMD_i8x16_lt_s:
- case SIMD_i8x16_lt_u:
- case SIMD_i8x16_gt_s:
- case SIMD_i8x16_gt_u:
- case SIMD_i8x16_le_s:
- case SIMD_i8x16_le_u:
- case SIMD_i8x16_ge_s:
- case SIMD_i8x16_ge_u:
- {
- if (!aot_compile_simd_i8x16_compare(
- comp_ctx, func_ctx,
- INT_EQ + opcode - SIMD_i8x16_eq))
- return false;
- break;
- }
- /* i16x8 Cmp */
- case SIMD_i16x8_eq:
- case SIMD_i16x8_ne:
- case SIMD_i16x8_lt_s:
- case SIMD_i16x8_lt_u:
- case SIMD_i16x8_gt_s:
- case SIMD_i16x8_gt_u:
- case SIMD_i16x8_le_s:
- case SIMD_i16x8_le_u:
- case SIMD_i16x8_ge_s:
- case SIMD_i16x8_ge_u:
- {
- if (!aot_compile_simd_i16x8_compare(
- comp_ctx, func_ctx,
- INT_EQ + opcode - SIMD_i16x8_eq))
- return false;
- break;
- }
- /* i32x4 Cmp */
- case SIMD_i32x4_eq:
- case SIMD_i32x4_ne:
- case SIMD_i32x4_lt_s:
- case SIMD_i32x4_lt_u:
- case SIMD_i32x4_gt_s:
- case SIMD_i32x4_gt_u:
- case SIMD_i32x4_le_s:
- case SIMD_i32x4_le_u:
- case SIMD_i32x4_ge_s:
- case SIMD_i32x4_ge_u:
- {
- if (!aot_compile_simd_i32x4_compare(
- comp_ctx, func_ctx,
- INT_EQ + opcode - SIMD_i32x4_eq))
- return false;
- break;
- }
- /* f32x4 Cmp */
- case SIMD_f32x4_eq:
- case SIMD_f32x4_ne:
- case SIMD_f32x4_lt:
- case SIMD_f32x4_gt:
- case SIMD_f32x4_le:
- case SIMD_f32x4_ge:
- {
- if (!aot_compile_simd_f32x4_compare(
- comp_ctx, func_ctx,
- FLOAT_EQ + opcode - SIMD_f32x4_eq))
- return false;
- break;
- }
- /* f64x2 Cmp */
- case SIMD_f64x2_eq:
- case SIMD_f64x2_ne:
- case SIMD_f64x2_lt:
- case SIMD_f64x2_gt:
- case SIMD_f64x2_le:
- case SIMD_f64x2_ge:
- {
- if (!aot_compile_simd_f64x2_compare(
- comp_ctx, func_ctx,
- FLOAT_EQ + opcode - SIMD_f64x2_eq))
- return false;
- break;
- }
- /* v128 Op */
- case SIMD_v128_not:
- case SIMD_v128_and:
- case SIMD_v128_andnot:
- case SIMD_v128_or:
- case SIMD_v128_xor:
- case SIMD_v128_bitselect:
- {
- if (!aot_compile_simd_v128_bitwise(comp_ctx, func_ctx,
- V128_NOT + opcode
- - SIMD_v128_not))
- return false;
- break;
- }
- case SIMD_v128_any_true:
- {
- if (!aot_compile_simd_v128_any_true(comp_ctx, func_ctx))
- return false;
- break;
- }
- /* Load Lane Op */
- case SIMD_v128_load8_lane:
- case SIMD_v128_load16_lane:
- case SIMD_v128_load32_lane:
- case SIMD_v128_load64_lane:
- {
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_simd_load_lane(comp_ctx, func_ctx,
- opcode, align, offset,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_v128_store8_lane:
- case SIMD_v128_store16_lane:
- case SIMD_v128_store32_lane:
- case SIMD_v128_store64_lane:
- {
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_simd_store_lane(comp_ctx, func_ctx,
- opcode, align, offset,
- *frame_ip++))
- return false;
- break;
- }
- case SIMD_v128_load32_zero:
- case SIMD_v128_load64_zero:
- {
- read_leb_uint32(frame_ip, frame_ip_end, align);
- read_leb_uint32(frame_ip, frame_ip_end, offset);
- if (!aot_compile_simd_load_zero(comp_ctx, func_ctx,
- opcode, align, offset))
- return false;
- break;
- }
- /* Float conversion */
- case SIMD_f32x4_demote_f64x2_zero:
- {
- if (!aot_compile_simd_f64x2_demote(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f64x2_promote_low_f32x4_zero:
- {
- if (!aot_compile_simd_f32x4_promote(comp_ctx, func_ctx))
- return false;
- break;
- }
- /* i8x16 Op */
- case SIMD_i8x16_abs:
- {
- if (!aot_compile_simd_i8x16_abs(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i8x16_neg:
- {
- if (!aot_compile_simd_i8x16_neg(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i8x16_popcnt:
- {
- if (!aot_compile_simd_i8x16_popcnt(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i8x16_all_true:
- {
- if (!aot_compile_simd_i8x16_all_true(comp_ctx,
- func_ctx))
- return false;
- break;
- }
- case SIMD_i8x16_bitmask:
- {
- if (!aot_compile_simd_i8x16_bitmask(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i8x16_narrow_i16x8_s:
- case SIMD_i8x16_narrow_i16x8_u:
- {
- if (!aot_compile_simd_i8x16_narrow_i16x8(
- comp_ctx, func_ctx,
- (opcode == SIMD_i8x16_narrow_i16x8_s)))
- return false;
- break;
- }
- case SIMD_f32x4_ceil:
- {
- if (!aot_compile_simd_f32x4_ceil(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f32x4_floor:
- {
- if (!aot_compile_simd_f32x4_floor(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f32x4_trunc:
- {
- if (!aot_compile_simd_f32x4_trunc(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f32x4_nearest:
- {
- if (!aot_compile_simd_f32x4_nearest(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i8x16_shl:
- case SIMD_i8x16_shr_s:
- case SIMD_i8x16_shr_u:
- {
- if (!aot_compile_simd_i8x16_shift(comp_ctx, func_ctx,
- INT_SHL + opcode
- - SIMD_i8x16_shl))
- return false;
- break;
- }
- case SIMD_i8x16_add:
- {
- if (!aot_compile_simd_i8x16_arith(comp_ctx, func_ctx,
- V128_ADD))
- return false;
- break;
- }
- case SIMD_i8x16_add_sat_s:
- case SIMD_i8x16_add_sat_u:
- {
- if (!aot_compile_simd_i8x16_saturate(
- comp_ctx, func_ctx, V128_ADD,
- opcode == SIMD_i8x16_add_sat_s))
- return false;
- break;
- }
- case SIMD_i8x16_sub:
- {
- if (!aot_compile_simd_i8x16_arith(comp_ctx, func_ctx,
- V128_SUB))
- return false;
- break;
- }
- case SIMD_i8x16_sub_sat_s:
- case SIMD_i8x16_sub_sat_u:
- {
- if (!aot_compile_simd_i8x16_saturate(
- comp_ctx, func_ctx, V128_SUB,
- opcode == SIMD_i8x16_sub_sat_s))
- return false;
- break;
- }
- case SIMD_f64x2_ceil:
- {
- if (!aot_compile_simd_f64x2_ceil(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f64x2_floor:
- {
- if (!aot_compile_simd_f64x2_floor(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i8x16_min_s:
- case SIMD_i8x16_min_u:
- {
- if (!aot_compile_simd_i8x16_cmp(
- comp_ctx, func_ctx, V128_MIN,
- opcode == SIMD_i8x16_min_s))
- return false;
- break;
- }
- case SIMD_i8x16_max_s:
- case SIMD_i8x16_max_u:
- {
- if (!aot_compile_simd_i8x16_cmp(
- comp_ctx, func_ctx, V128_MAX,
- opcode == SIMD_i8x16_max_s))
- return false;
- break;
- }
- case SIMD_f64x2_trunc:
- {
- if (!aot_compile_simd_f64x2_trunc(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i8x16_avgr_u:
- {
- if (!aot_compile_simd_i8x16_avgr_u(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i16x8_extadd_pairwise_i8x16_s:
- case SIMD_i16x8_extadd_pairwise_i8x16_u:
- {
- if (!aot_compile_simd_i16x8_extadd_pairwise_i8x16(
- comp_ctx, func_ctx,
- SIMD_i16x8_extadd_pairwise_i8x16_s == opcode))
- return false;
- break;
- }
- case SIMD_i32x4_extadd_pairwise_i16x8_s:
- case SIMD_i32x4_extadd_pairwise_i16x8_u:
- {
- if (!aot_compile_simd_i32x4_extadd_pairwise_i16x8(
- comp_ctx, func_ctx,
- SIMD_i32x4_extadd_pairwise_i16x8_s == opcode))
- return false;
- break;
- }
- /* i16x8 Op */
- case SIMD_i16x8_abs:
- {
- if (!aot_compile_simd_i16x8_abs(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i16x8_neg:
- {
- if (!aot_compile_simd_i16x8_neg(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i16x8_q15mulr_sat_s:
- {
- if (!aot_compile_simd_i16x8_q15mulr_sat(comp_ctx,
- func_ctx))
- return false;
- break;
- }
- case SIMD_i16x8_all_true:
- {
- if (!aot_compile_simd_i16x8_all_true(comp_ctx,
- func_ctx))
- return false;
- break;
- }
- case SIMD_i16x8_bitmask:
- {
- if (!aot_compile_simd_i16x8_bitmask(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i16x8_narrow_i32x4_s:
- case SIMD_i16x8_narrow_i32x4_u:
- {
- if (!aot_compile_simd_i16x8_narrow_i32x4(
- comp_ctx, func_ctx,
- SIMD_i16x8_narrow_i32x4_s == opcode))
- return false;
- break;
- }
- case SIMD_i16x8_extend_low_i8x16_s:
- case SIMD_i16x8_extend_high_i8x16_s:
- {
- if (!aot_compile_simd_i16x8_extend_i8x16(
- comp_ctx, func_ctx,
- SIMD_i16x8_extend_low_i8x16_s == opcode, true))
- return false;
- break;
- }
- case SIMD_i16x8_extend_low_i8x16_u:
- case SIMD_i16x8_extend_high_i8x16_u:
- {
- if (!aot_compile_simd_i16x8_extend_i8x16(
- comp_ctx, func_ctx,
- SIMD_i16x8_extend_low_i8x16_u == opcode, false))
- return false;
- break;
- }
- case SIMD_i16x8_shl:
- case SIMD_i16x8_shr_s:
- case SIMD_i16x8_shr_u:
- {
- if (!aot_compile_simd_i16x8_shift(comp_ctx, func_ctx,
- INT_SHL + opcode
- - SIMD_i16x8_shl))
- return false;
- break;
- }
- case SIMD_i16x8_add:
- {
- if (!aot_compile_simd_i16x8_arith(comp_ctx, func_ctx,
- V128_ADD))
- return false;
- break;
- }
- case SIMD_i16x8_add_sat_s:
- case SIMD_i16x8_add_sat_u:
- {
- if (!aot_compile_simd_i16x8_saturate(
- comp_ctx, func_ctx, V128_ADD,
- opcode == SIMD_i16x8_add_sat_s ? true : false))
- return false;
- break;
- }
- case SIMD_i16x8_sub:
- {
- if (!aot_compile_simd_i16x8_arith(comp_ctx, func_ctx,
- V128_SUB))
- return false;
- break;
- }
- case SIMD_i16x8_sub_sat_s:
- case SIMD_i16x8_sub_sat_u:
- {
- if (!aot_compile_simd_i16x8_saturate(
- comp_ctx, func_ctx, V128_SUB,
- opcode == SIMD_i16x8_sub_sat_s ? true : false))
- return false;
- break;
- }
- case SIMD_f64x2_nearest:
- {
- if (!aot_compile_simd_f64x2_nearest(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i16x8_mul:
- {
- if (!aot_compile_simd_i16x8_arith(comp_ctx, func_ctx,
- V128_MUL))
- return false;
- break;
- }
- case SIMD_i16x8_min_s:
- case SIMD_i16x8_min_u:
- {
- if (!aot_compile_simd_i16x8_cmp(
- comp_ctx, func_ctx, V128_MIN,
- opcode == SIMD_i16x8_min_s))
- return false;
- break;
- }
- case SIMD_i16x8_max_s:
- case SIMD_i16x8_max_u:
- {
- if (!aot_compile_simd_i16x8_cmp(
- comp_ctx, func_ctx, V128_MAX,
- opcode == SIMD_i16x8_max_s))
- return false;
- break;
- }
- case SIMD_i16x8_avgr_u:
- {
- if (!aot_compile_simd_i16x8_avgr_u(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i16x8_extmul_low_i8x16_s:
- case SIMD_i16x8_extmul_high_i8x16_s:
- {
- if (!(aot_compile_simd_i16x8_extmul_i8x16(
- comp_ctx, func_ctx,
- SIMD_i16x8_extmul_low_i8x16_s == opcode, true)))
- return false;
- break;
- }
- case SIMD_i16x8_extmul_low_i8x16_u:
- case SIMD_i16x8_extmul_high_i8x16_u:
- {
- if (!(aot_compile_simd_i16x8_extmul_i8x16(
- comp_ctx, func_ctx,
- SIMD_i16x8_extmul_low_i8x16_u == opcode,
- false)))
- return false;
- break;
- }
- /* i32x4 Op */
- case SIMD_i32x4_abs:
- {
- if (!aot_compile_simd_i32x4_abs(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i32x4_neg:
- {
- if (!aot_compile_simd_i32x4_neg(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i32x4_all_true:
- {
- if (!aot_compile_simd_i32x4_all_true(comp_ctx,
- func_ctx))
- return false;
- break;
- }
- case SIMD_i32x4_bitmask:
- {
- if (!aot_compile_simd_i32x4_bitmask(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i32x4_extend_low_i16x8_s:
- case SIMD_i32x4_extend_high_i16x8_s:
- {
- if (!aot_compile_simd_i32x4_extend_i16x8(
- comp_ctx, func_ctx,
- SIMD_i32x4_extend_low_i16x8_s == opcode, true))
- return false;
- break;
- }
- case SIMD_i32x4_extend_low_i16x8_u:
- case SIMD_i32x4_extend_high_i16x8_u:
- {
- if (!aot_compile_simd_i32x4_extend_i16x8(
- comp_ctx, func_ctx,
- SIMD_i32x4_extend_low_i16x8_u == opcode, false))
- return false;
- break;
- }
- case SIMD_i32x4_shl:
- case SIMD_i32x4_shr_s:
- case SIMD_i32x4_shr_u:
- {
- if (!aot_compile_simd_i32x4_shift(comp_ctx, func_ctx,
- INT_SHL + opcode
- - SIMD_i32x4_shl))
- return false;
- break;
- }
- case SIMD_i32x4_add:
- {
- if (!aot_compile_simd_i32x4_arith(comp_ctx, func_ctx,
- V128_ADD))
- return false;
- break;
- }
- case SIMD_i32x4_sub:
- {
- if (!aot_compile_simd_i32x4_arith(comp_ctx, func_ctx,
- V128_SUB))
- return false;
- break;
- }
- case SIMD_i32x4_mul:
- {
- if (!aot_compile_simd_i32x4_arith(comp_ctx, func_ctx,
- V128_MUL))
- return false;
- break;
- }
- case SIMD_i32x4_min_s:
- case SIMD_i32x4_min_u:
- {
- if (!aot_compile_simd_i32x4_cmp(
- comp_ctx, func_ctx, V128_MIN,
- SIMD_i32x4_min_s == opcode))
- return false;
- break;
- }
- case SIMD_i32x4_max_s:
- case SIMD_i32x4_max_u:
- {
- if (!aot_compile_simd_i32x4_cmp(
- comp_ctx, func_ctx, V128_MAX,
- SIMD_i32x4_max_s == opcode))
- return false;
- break;
- }
- case SIMD_i32x4_dot_i16x8_s:
- {
- if (!aot_compile_simd_i32x4_dot_i16x8(comp_ctx,
- func_ctx))
- return false;
- break;
- }
- case SIMD_i32x4_extmul_low_i16x8_s:
- case SIMD_i32x4_extmul_high_i16x8_s:
- {
- if (!aot_compile_simd_i32x4_extmul_i16x8(
- comp_ctx, func_ctx,
- SIMD_i32x4_extmul_low_i16x8_s == opcode, true))
- return false;
- break;
- }
- case SIMD_i32x4_extmul_low_i16x8_u:
- case SIMD_i32x4_extmul_high_i16x8_u:
- {
- if (!aot_compile_simd_i32x4_extmul_i16x8(
- comp_ctx, func_ctx,
- SIMD_i32x4_extmul_low_i16x8_u == opcode, false))
- return false;
- break;
- }
- /* i64x2 Op */
- case SIMD_i64x2_abs:
- {
- if (!aot_compile_simd_i64x2_abs(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i64x2_neg:
- {
- if (!aot_compile_simd_i64x2_neg(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i64x2_all_true:
- {
- if (!aot_compile_simd_i64x2_all_true(comp_ctx,
- func_ctx))
- return false;
- break;
- }
- case SIMD_i64x2_bitmask:
- {
- if (!aot_compile_simd_i64x2_bitmask(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_i64x2_extend_low_i32x4_s:
- case SIMD_i64x2_extend_high_i32x4_s:
- {
- if (!aot_compile_simd_i64x2_extend_i32x4(
- comp_ctx, func_ctx,
- SIMD_i64x2_extend_low_i32x4_s == opcode, true))
- return false;
- break;
- }
- case SIMD_i64x2_extend_low_i32x4_u:
- case SIMD_i64x2_extend_high_i32x4_u:
- {
- if (!aot_compile_simd_i64x2_extend_i32x4(
- comp_ctx, func_ctx,
- SIMD_i64x2_extend_low_i32x4_u == opcode, false))
- return false;
- break;
- }
- case SIMD_i64x2_shl:
- case SIMD_i64x2_shr_s:
- case SIMD_i64x2_shr_u:
- {
- if (!aot_compile_simd_i64x2_shift(comp_ctx, func_ctx,
- INT_SHL + opcode
- - SIMD_i64x2_shl))
- return false;
- break;
- }
- case SIMD_i64x2_add:
- {
- if (!aot_compile_simd_i64x2_arith(comp_ctx, func_ctx,
- V128_ADD))
- return false;
- break;
- }
- case SIMD_i64x2_sub:
- {
- if (!aot_compile_simd_i64x2_arith(comp_ctx, func_ctx,
- V128_SUB))
- return false;
- break;
- }
- case SIMD_i64x2_mul:
- {
- if (!aot_compile_simd_i64x2_arith(comp_ctx, func_ctx,
- V128_MUL))
- return false;
- break;
- }
- case SIMD_i64x2_eq:
- case SIMD_i64x2_ne:
- case SIMD_i64x2_lt_s:
- case SIMD_i64x2_gt_s:
- case SIMD_i64x2_le_s:
- case SIMD_i64x2_ge_s:
- {
- IntCond icond[] = { INT_EQ, INT_NE, INT_LT_S,
- INT_GT_S, INT_LE_S, INT_GE_S };
- if (!aot_compile_simd_i64x2_compare(
- comp_ctx, func_ctx,
- icond[opcode - SIMD_i64x2_eq]))
- return false;
- break;
- }
- case SIMD_i64x2_extmul_low_i32x4_s:
- case SIMD_i64x2_extmul_high_i32x4_s:
- {
- if (!aot_compile_simd_i64x2_extmul_i32x4(
- comp_ctx, func_ctx,
- SIMD_i64x2_extmul_low_i32x4_s == opcode, true))
- return false;
- break;
- }
- case SIMD_i64x2_extmul_low_i32x4_u:
- case SIMD_i64x2_extmul_high_i32x4_u:
- {
- if (!aot_compile_simd_i64x2_extmul_i32x4(
- comp_ctx, func_ctx,
- SIMD_i64x2_extmul_low_i32x4_u == opcode, false))
- return false;
- break;
- }
- /* f32x4 Op */
- case SIMD_f32x4_abs:
- {
- if (!aot_compile_simd_f32x4_abs(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f32x4_neg:
- {
- if (!aot_compile_simd_f32x4_neg(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f32x4_sqrt:
- {
- if (!aot_compile_simd_f32x4_sqrt(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f32x4_add:
- case SIMD_f32x4_sub:
- case SIMD_f32x4_mul:
- case SIMD_f32x4_div:
- {
- if (!aot_compile_simd_f32x4_arith(comp_ctx, func_ctx,
- FLOAT_ADD + opcode
- - SIMD_f32x4_add))
- return false;
- break;
- }
- case SIMD_f32x4_min:
- case SIMD_f32x4_max:
- {
- if (!aot_compile_simd_f32x4_min_max(
- comp_ctx, func_ctx, SIMD_f32x4_min == opcode))
- return false;
- break;
- }
- case SIMD_f32x4_pmin:
- case SIMD_f32x4_pmax:
- {
- if (!aot_compile_simd_f32x4_pmin_pmax(
- comp_ctx, func_ctx, SIMD_f32x4_pmin == opcode))
- return false;
- break;
- }
- /* f64x2 Op */
- case SIMD_f64x2_abs:
- {
- if (!aot_compile_simd_f64x2_abs(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f64x2_neg:
- {
- if (!aot_compile_simd_f64x2_neg(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f64x2_sqrt:
- {
- if (!aot_compile_simd_f64x2_sqrt(comp_ctx, func_ctx))
- return false;
- break;
- }
- case SIMD_f64x2_add:
- case SIMD_f64x2_sub:
- case SIMD_f64x2_mul:
- case SIMD_f64x2_div:
- {
- if (!aot_compile_simd_f64x2_arith(comp_ctx, func_ctx,
- FLOAT_ADD + opcode
- - SIMD_f64x2_add))
- return false;
- break;
- }
- case SIMD_f64x2_min:
- case SIMD_f64x2_max:
- {
- if (!aot_compile_simd_f64x2_min_max(
- comp_ctx, func_ctx, SIMD_f64x2_min == opcode))
- return false;
- break;
- }
- case SIMD_f64x2_pmin:
- case SIMD_f64x2_pmax:
- {
- if (!aot_compile_simd_f64x2_pmin_pmax(
- comp_ctx, func_ctx, SIMD_f64x2_pmin == opcode))
- return false;
- break;
- }
- /* Conversion Op */
- case SIMD_i32x4_trunc_sat_f32x4_s:
- case SIMD_i32x4_trunc_sat_f32x4_u:
- {
- if (!aot_compile_simd_i32x4_trunc_sat_f32x4(
- comp_ctx, func_ctx,
- SIMD_i32x4_trunc_sat_f32x4_s == opcode))
- return false;
- break;
- }
- case SIMD_f32x4_convert_i32x4_s:
- case SIMD_f32x4_convert_i32x4_u:
- {
- if (!aot_compile_simd_f32x4_convert_i32x4(
- comp_ctx, func_ctx,
- SIMD_f32x4_convert_i32x4_s == opcode))
- return false;
- break;
- }
- case SIMD_i32x4_trunc_sat_f64x2_s_zero:
- case SIMD_i32x4_trunc_sat_f64x2_u_zero:
- {
- if (!aot_compile_simd_i32x4_trunc_sat_f64x2(
- comp_ctx, func_ctx,
- SIMD_i32x4_trunc_sat_f64x2_s_zero == opcode))
- return false;
- break;
- }
- case SIMD_f64x2_convert_low_i32x4_s:
- case SIMD_f64x2_convert_low_i32x4_u:
- {
- if (!aot_compile_simd_f64x2_convert_i32x4(
- comp_ctx, func_ctx,
- SIMD_f64x2_convert_low_i32x4_s == opcode))
- return false;
- break;
- }
- default:
- aot_set_last_error("unsupported SIMD opcode");
- return false;
- }
- break;
- }
- #endif /* end of WASM_ENABLE_SIMD */
- default:
- aot_set_last_error("unsupported opcode");
- return false;
- }
- }
- /* Move func_return block to the bottom */
- if (func_ctx->func_return_block) {
- LLVMBasicBlockRef last_block = LLVMGetLastBasicBlock(func_ctx->func);
- if (last_block != func_ctx->func_return_block)
- LLVMMoveBasicBlockAfter(func_ctx->func_return_block, last_block);
- }
- /* Move got_exception block to the bottom */
- if (func_ctx->got_exception_block) {
- LLVMBasicBlockRef last_block = LLVMGetLastBasicBlock(func_ctx->func);
- if (last_block != func_ctx->got_exception_block)
- LLVMMoveBasicBlockAfter(func_ctx->got_exception_block, last_block);
- }
- return true;
- #if WASM_ENABLE_SIMD != 0
- unsupport_simd:
- aot_set_last_error("SIMD instruction was found, "
- "try removing --disable-simd option");
- return false;
- #endif
- #if WASM_ENABLE_REF_TYPES != 0
- unsupport_ref_types:
- aot_set_last_error("reference type instruction was found, "
- "try removing --disable-ref-types option");
- return false;
- #endif
- #if WASM_ENABLE_BULK_MEMORY != 0
- unsupport_bulk_memory:
- aot_set_last_error("bulk memory instruction was found, "
- "try removing --disable-bulk-memory option");
- return false;
- #endif
- fail:
- return false;
- }
- static bool
- verify_module(AOTCompContext *comp_ctx)
- {
- char *msg = NULL;
- bool ret;
- ret = LLVMVerifyModule(comp_ctx->module, LLVMPrintMessageAction, &msg);
- if (!ret && msg) {
- if (msg[0] != '\0') {
- aot_set_last_error(msg);
- LLVMDisposeMessage(msg);
- return false;
- }
- LLVMDisposeMessage(msg);
- }
- return true;
- }
- bool
- aot_compile_wasm(AOTCompContext *comp_ctx)
- {
- uint32 i;
- if (!aot_validate_wasm(comp_ctx)) {
- return false;
- }
- bh_print_time("Begin to compile WASM bytecode to LLVM IR");
- for (i = 0; i < comp_ctx->func_ctx_count; i++) {
- if (!aot_compile_func(comp_ctx, i)) {
- return false;
- }
- }
- #if WASM_ENABLE_DEBUG_AOT != 0
- LLVMDIBuilderFinalize(comp_ctx->debug_builder);
- #endif
- /* Disable LLVM module verification for jit mode to speedup
- the compilation process */
- if (!comp_ctx->is_jit_mode) {
- bh_print_time("Begin to verify LLVM module");
- if (!verify_module(comp_ctx)) {
- return false;
- }
- }
- /* Run IR optimization before feeding in ORCJIT and AOT codegen */
- if (comp_ctx->optimize) {
- /* Run passes for AOT/JIT mode.
- TODO: Apply these passes in the do_ir_transform callback of
- TransformLayer when compiling each jit function, so as to
- speedup the launch process. Now there are two issues in the
- JIT: one is memory leak in do_ir_transform, the other is
- possible core dump. */
- bh_print_time("Begin to run llvm optimization passes");
- aot_apply_llvm_new_pass_manager(comp_ctx, comp_ctx->module);
- bh_print_time("Finish llvm optimization passes");
- }
- #ifdef DUMP_MODULE
- LLVMDumpModule(comp_ctx->module);
- os_printf("\n");
- #endif
- if (comp_ctx->is_jit_mode) {
- LLVMErrorRef err;
- LLVMOrcJITDylibRef orc_main_dylib;
- LLVMOrcThreadSafeModuleRef orc_thread_safe_module;
- orc_main_dylib = LLVMOrcLLLazyJITGetMainJITDylib(comp_ctx->orc_jit);
- if (!orc_main_dylib) {
- aot_set_last_error(
- "failed to get orc orc_jit main dynmaic library");
- return false;
- }
- orc_thread_safe_module = LLVMOrcCreateNewThreadSafeModule(
- comp_ctx->module, comp_ctx->orc_thread_safe_context);
- if (!orc_thread_safe_module) {
- aot_set_last_error("failed to create thread safe module");
- return false;
- }
- if ((err = LLVMOrcLLLazyJITAddLLVMIRModule(
- comp_ctx->orc_jit, orc_main_dylib, orc_thread_safe_module))) {
- /* If adding the ThreadSafeModule fails then we need to clean it up
- by ourselves, otherwise the orc orc_jit will manage the memory.
- */
- LLVMOrcDisposeThreadSafeModule(orc_thread_safe_module);
- aot_handle_llvm_errmsg("failed to addIRModule", err);
- return false;
- }
- if (comp_ctx->stack_sizes != NULL) {
- LLVMOrcJITTargetAddress addr;
- if ((err = LLVMOrcLLLazyJITLookup(comp_ctx->orc_jit, &addr,
- aot_stack_sizes_alias_name))) {
- aot_handle_llvm_errmsg("failed to look up stack_sizes", err);
- return false;
- }
- comp_ctx->jit_stack_sizes = (uint32 *)addr;
- }
- }
- return true;
- }
- #if !(defined(_WIN32) || defined(_WIN32_))
- char *
- aot_generate_tempfile_name(const char *prefix, const char *extension,
- char *buffer, uint32 len)
- {
- int fd, name_len;
- name_len = snprintf(buffer, len, "%s-XXXXXX", prefix);
- if ((fd = mkstemp(buffer)) <= 0) {
- aot_set_last_error("make temp file failed.");
- return NULL;
- }
- /* close and remove temp file */
- close(fd);
- unlink(buffer);
- /* Check if buffer length is enough */
- /* name_len + '.' + extension + '\0' */
- if (name_len + 1 + strlen(extension) + 1 > len) {
- aot_set_last_error("temp file name too long.");
- return NULL;
- }
- snprintf(buffer + name_len, len - name_len, ".%s", extension);
- return buffer;
- }
- #else
- errno_t
- _mktemp_s(char *nameTemplate, size_t sizeInChars);
- char *
- aot_generate_tempfile_name(const char *prefix, const char *extension,
- char *buffer, uint32 len)
- {
- int name_len;
- name_len = snprintf(buffer, len, "%s-XXXXXX", prefix);
- if (_mktemp_s(buffer, name_len + 1) != 0) {
- return NULL;
- }
- /* Check if buffer length is enough */
- /* name_len + '.' + extension + '\0' */
- if (name_len + 1 + strlen(extension) + 1 > len) {
- aot_set_last_error("temp file name too long.");
- return NULL;
- }
- snprintf(buffer + name_len, len - name_len, ".%s", extension);
- return buffer;
- }
- #endif /* end of !(defined(_WIN32) || defined(_WIN32_)) */
- bool
- aot_emit_llvm_file(AOTCompContext *comp_ctx, const char *file_name)
- {
- char *err = NULL;
- bh_print_time("Begin to emit LLVM IR file");
- if (LLVMPrintModuleToFile(comp_ctx->module, file_name, &err) != 0) {
- if (err) {
- LLVMDisposeMessage(err);
- err = NULL;
- }
- aot_set_last_error("emit llvm ir to file failed.");
- return false;
- }
- return true;
- }
- static bool
- aot_move_file(const char *dest, const char *src)
- {
- FILE *dfp = fopen(dest, "w");
- FILE *sfp = fopen(src, "r");
- size_t rsz;
- char buf[128];
- bool success = false;
- if (dfp == NULL || sfp == NULL) {
- LOG_DEBUG("open error %s %s", dest, src);
- goto fail;
- }
- do {
- rsz = fread(buf, 1, sizeof(buf), sfp);
- if (rsz > 0) {
- size_t wsz = fwrite(buf, 1, rsz, dfp);
- if (wsz < rsz) {
- LOG_DEBUG("write error");
- goto fail;
- }
- }
- if (rsz < sizeof(buf)) {
- if (ferror(sfp)) {
- LOG_DEBUG("read error");
- goto fail;
- }
- }
- } while (rsz > 0);
- success = true;
- fail:
- if (dfp != NULL) {
- if (fclose(dfp)) {
- LOG_DEBUG("close error");
- success = false;
- }
- if (!success) {
- (void)unlink(dest);
- }
- }
- if (sfp != NULL) {
- (void)fclose(sfp);
- }
- if (success) {
- (void)unlink(src);
- }
- return success;
- }
- bool
- aot_emit_object_file(AOTCompContext *comp_ctx, char *file_name)
- {
- char *err = NULL;
- LLVMCodeGenFileType file_type = LLVMObjectFile;
- LLVMTargetRef target = LLVMGetTargetMachineTarget(comp_ctx->target_machine);
- bh_print_time("Begin to emit object file");
- #if !(defined(_WIN32) || defined(_WIN32_))
- if (comp_ctx->external_llc_compiler || comp_ctx->external_asm_compiler) {
- char cmd[1024];
- int ret;
- if (comp_ctx->external_llc_compiler) {
- const char *stack_usage_flag = "";
- char bc_file_name[64];
- char su_file_name[65]; /* See the comment below */
- if (comp_ctx->stack_usage_file != NULL) {
- /*
- * Note: we know the caller uses 64 byte buffer for
- * file_name. It will get 1 byte longer because we
- * replace ".o" with ".su".
- */
- size_t len = strlen(file_name);
- bh_assert(len + 1 <= sizeof(su_file_name));
- bh_assert(len > 3);
- bh_assert(file_name[len - 2] == '.');
- bh_assert(file_name[len - 1] == 'o');
- snprintf(su_file_name, sizeof(su_file_name), "%.*s.su",
- (int)(len - 2), file_name);
- stack_usage_flag = " -fstack-usage";
- }
- if (!aot_generate_tempfile_name("wamrc-bc", "bc", bc_file_name,
- sizeof(bc_file_name))) {
- return false;
- }
- if (LLVMWriteBitcodeToFile(comp_ctx->module, bc_file_name) != 0) {
- aot_set_last_error("emit llvm bitcode file failed.");
- return false;
- }
- snprintf(cmd, sizeof(cmd), "%s%s %s -o %s %s",
- comp_ctx->external_llc_compiler, stack_usage_flag,
- comp_ctx->llc_compiler_flags ? comp_ctx->llc_compiler_flags
- : "-O3 -c",
- file_name, bc_file_name);
- LOG_VERBOSE("invoking external LLC compiler:\n\t%s", cmd);
- ret = system(cmd);
- /* remove temp bitcode file */
- unlink(bc_file_name);
- if (ret != 0) {
- aot_set_last_error("failed to compile LLVM bitcode to obj file "
- "with external LLC compiler.");
- return false;
- }
- if (comp_ctx->stack_usage_file != NULL) {
- /*
- * move the temporary .su file to the specified location.
- *
- * Note: the former is automatimally inferred from the output
- * filename (file_name here) by clang.
- *
- * Note: the latter might be user-specified.
- * (wamrc --stack-usage=<file>)
- */
- if (!aot_move_file(comp_ctx->stack_usage_file, su_file_name)) {
- aot_set_last_error("failed to move su file.");
- (void)unlink(su_file_name);
- return false;
- }
- }
- }
- else if (comp_ctx->external_asm_compiler) {
- char asm_file_name[64];
- if (!aot_generate_tempfile_name("wamrc-asm", "s", asm_file_name,
- sizeof(asm_file_name))) {
- return false;
- }
- if (LLVMTargetMachineEmitToFile(comp_ctx->target_machine,
- comp_ctx->module, asm_file_name,
- LLVMAssemblyFile, &err)
- != 0) {
- if (err) {
- LLVMDisposeMessage(err);
- err = NULL;
- }
- aot_set_last_error("emit elf to assembly file failed.");
- return false;
- }
- snprintf(cmd, sizeof(cmd), "%s %s -o %s %s",
- comp_ctx->external_asm_compiler,
- comp_ctx->asm_compiler_flags ? comp_ctx->asm_compiler_flags
- : "-O3 -c",
- file_name, asm_file_name);
- LOG_VERBOSE("invoking external ASM compiler:\n\t%s", cmd);
- ret = system(cmd);
- /* remove temp assembly file */
- unlink(asm_file_name);
- if (ret != 0) {
- aot_set_last_error("failed to compile Assembly file to obj "
- "file with external ASM compiler.");
- return false;
- }
- }
- return true;
- }
- #endif /* end of !(defined(_WIN32) || defined(_WIN32_)) */
- if (!strncmp(LLVMGetTargetName(target), "arc", 3))
- /* Emit to assmelby file instead for arc target
- as it cannot emit to object file */
- file_type = LLVMAssemblyFile;
- if (LLVMTargetMachineEmitToFile(comp_ctx->target_machine, comp_ctx->module,
- file_name, file_type, &err)
- != 0) {
- if (err) {
- LLVMDisposeMessage(err);
- err = NULL;
- }
- aot_set_last_error("emit elf to object file failed.");
- return false;
- }
- return true;
- }
|