123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745274627472748274927502751275227532754275527562757275827592760276127622763276427652766276727682769277027712772277327742775277627772778277927802781278227832784278527862787278827892790279127922793279427952796279727982799280028012802280328042805280628072808280928102811281228132814281528162817281828192820282128222823282428252826282728282829283028312832283328342835283628372838283928402841284228432844284528462847284828492850285128522853285428552856285728582859286028612862286328642865286628672868286928702871287228732874287528762877287828792880288128822883288428852886288728882889289028912892289328942895289628972898289929002901290229032904290529062907290829092910291129122913291429152916291729182919292029212922292329242925292629272928292929302931293229332934293529362937293829392940294129422943294429452946294729482949295029512952295329542955295629572958295929602961296229632964296529662967296829692970297129722973297429752976297729782979298029812982298329842985298629872988298929902991299229932994299529962997299829993000300130023003300430053006300730083009301030113012301330143015301630173018301930203021302230233024302530263027302830293030303130323033303430353036303730383039304030413042304330443045304630473048304930503051305230533054305530563057305830593060306130623063306430653066306730683069307030713072307330743075307630773078307930803081308230833084308530863087308830893090309130923093309430953096309730983099310031013102310331043105310631073108310931103111311231133114311531163117311831193120312131223123312431253126312731283129313031313132313331343135313631373138313931403141314231433144314531463147314831493150315131523153315431553156315731583159316031613162316331643165316631673168316931703171317231733174317531763177317831793180318131823183318431853186318731883189319031913192319331943195319631973198319932003201320232033204320532063207320832093210321132123213321432153216321732183219322032213222322332243225322632273228322932303231323232333234323532363237323832393240324132423243324432453246324732483249325032513252325332543255325632573258325932603261326232633264326532663267326832693270327132723273327432753276327732783279328032813282328332843285328632873288328932903291329232933294329532963297329832993300330133023303330433053306330733083309331033113312331333143315331633173318331933203321332233233324332533263327332833293330333133323333333433353336333733383339334033413342334333443345334633473348334933503351335233533354335533563357335833593360336133623363336433653366336733683369337033713372337333743375337633773378337933803381338233833384338533863387338833893390339133923393339433953396339733983399340034013402340334043405340634073408340934103411341234133414341534163417341834193420342134223423342434253426342734283429343034313432343334343435343634373438343934403441344234433444344534463447344834493450345134523453345434553456345734583459346034613462 |
- // basisu_frontend.cpp
- // Copyright (C) 2019-2021 Binomial LLC. All Rights Reserved.
- //
- // Licensed under the Apache License, Version 2.0 (the "License");
- // you may not use this file except in compliance with the License.
- // You may obtain a copy of the License at
- //
- // http://www.apache.org/licenses/LICENSE-2.0
- //
- // Unless required by applicable law or agreed to in writing, software
- // distributed under the License is distributed on an "AS IS" BASIS,
- // WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- // See the License for the specific language governing permissions and
- // limitations under the License.
- //
- // TODO:
- // This code originally supported full ETC1 and ETC1S, so there's some legacy stuff to be cleaned up in here.
- // Add endpoint tiling support (where we force adjacent blocks to use the same endpoints during quantization), for a ~10% or more increase in bitrate at same SSIM. The backend already supports this.
- //
- #include "../transcoder/basisu.h"
- #include "basisu_frontend.h"
- #include "basisu_opencl.h"
- #include <unordered_set>
- #include <unordered_map>
- #if BASISU_SUPPORT_SSE
- #define CPPSPMD_NAME(a) a##_sse41
- #include "basisu_kernels_declares.h"
- #endif
- #define BASISU_FRONTEND_VERIFY(c) do { if (!(c)) handle_verify_failure(__LINE__); } while(0)
- namespace basisu
- {
- const uint32_t cMaxCodebookCreationThreads = 8;
- const uint32_t BASISU_MAX_ENDPOINT_REFINEMENT_STEPS = 3;
- //const uint32_t BASISU_MAX_SELECTOR_REFINEMENT_STEPS = 3;
- const uint32_t BASISU_ENDPOINT_PARENT_CODEBOOK_SIZE = 16;
- const uint32_t BASISU_SELECTOR_PARENT_CODEBOOK_SIZE_COMP_LEVEL_01 = 32;
- const uint32_t BASISU_SELECTOR_PARENT_CODEBOOK_SIZE_COMP_LEVEL_DEFAULT = 16;
-
- // TODO - How to handle internal verifies in the basisu lib
- static inline void handle_verify_failure(int line)
- {
- error_printf("basisu_frontend: verify check failed at line %i!\n", line);
- abort();
- }
-
- bool basisu_frontend::init(const params &p)
- {
- debug_printf("basisu_frontend::init: Multithreaded: %u, Job pool total threads: %u, NumEndpointClusters: %u, NumSelectorClusters: %u, Perceptual: %u, CompressionLevel: %u\n",
- p.m_multithreaded, p.m_pJob_pool ? p.m_pJob_pool->get_total_threads() : 0,
- p.m_max_endpoint_clusters, p.m_max_selector_clusters, p.m_perceptual, p.m_compression_level);
-
- if ((p.m_max_endpoint_clusters < 1) || (p.m_max_endpoint_clusters > cMaxEndpointClusters))
- return false;
- if ((p.m_max_selector_clusters < 1) || (p.m_max_selector_clusters > cMaxSelectorClusters))
- return false;
- m_source_blocks.resize(0);
- append_vector(m_source_blocks, p.m_pSource_blocks, p.m_num_source_blocks);
-
- m_params = p;
-
- if (m_params.m_pOpenCL_context)
- {
- BASISU_ASSUME(sizeof(cl_pixel_block) == sizeof(pixel_block));
- // Upload the RGBA pixel blocks a single time.
- if (!opencl_set_pixel_blocks(m_params.m_pOpenCL_context, m_source_blocks.size(), (cl_pixel_block*)m_source_blocks.data()))
- {
- // This is not fatal, we just won't use OpenCL.
- error_printf("basisu_frontend::init: opencl_set_pixel_blocks() failed\n");
- m_params.m_pOpenCL_context = nullptr;
- m_opencl_failed = true;
- }
- }
- m_encoded_blocks.resize(m_params.m_num_source_blocks);
- memset(&m_encoded_blocks[0], 0, m_encoded_blocks.size() * sizeof(m_encoded_blocks[0]));
-
- m_num_endpoint_codebook_iterations = 1;
- m_num_selector_codebook_iterations = 1;
- switch (p.m_compression_level)
- {
- case 0:
- {
- m_endpoint_refinement = false;
- m_use_hierarchical_endpoint_codebooks = true;
- m_use_hierarchical_selector_codebooks = true;
- break;
- }
- case 1:
- {
- m_endpoint_refinement = true;
- m_use_hierarchical_endpoint_codebooks = true;
- m_use_hierarchical_selector_codebooks = true;
- break;
- }
- case 2:
- {
- m_endpoint_refinement = true;
- m_use_hierarchical_endpoint_codebooks = true;
- m_use_hierarchical_selector_codebooks = true;
- break;
- }
- case 3:
- {
- m_endpoint_refinement = true;
- m_use_hierarchical_endpoint_codebooks = false;
- m_use_hierarchical_selector_codebooks = false;
- break;
- }
- case 4:
- {
- m_endpoint_refinement = true;
- m_use_hierarchical_endpoint_codebooks = true;
- m_use_hierarchical_selector_codebooks = true;
- m_num_endpoint_codebook_iterations = BASISU_MAX_ENDPOINT_REFINEMENT_STEPS;
- m_num_selector_codebook_iterations = BASISU_MAX_ENDPOINT_REFINEMENT_STEPS;
- break;
- }
- case 5:
- {
- m_endpoint_refinement = true;
- m_use_hierarchical_endpoint_codebooks = false;
- m_use_hierarchical_selector_codebooks = false;
- m_num_endpoint_codebook_iterations = BASISU_MAX_ENDPOINT_REFINEMENT_STEPS;
- m_num_selector_codebook_iterations = BASISU_MAX_ENDPOINT_REFINEMENT_STEPS;
- break;
- }
- case 6:
- default:
- {
- m_endpoint_refinement = true;
- m_use_hierarchical_endpoint_codebooks = false;
- m_use_hierarchical_selector_codebooks = false;
- m_num_endpoint_codebook_iterations = BASISU_MAX_ENDPOINT_REFINEMENT_STEPS*2;
- m_num_selector_codebook_iterations = BASISU_MAX_ENDPOINT_REFINEMENT_STEPS*2;
- break;
- }
- }
- if (m_params.m_disable_hierarchical_endpoint_codebooks)
- m_use_hierarchical_endpoint_codebooks = false;
- debug_printf("Endpoint refinement: %u, Hierarchical endpoint codebooks: %u, Hierarchical selector codebooks: %u, Endpoint codebook iters: %u, Selector codebook iters: %u\n",
- m_endpoint_refinement, m_use_hierarchical_endpoint_codebooks, m_use_hierarchical_selector_codebooks, m_num_endpoint_codebook_iterations, m_num_selector_codebook_iterations);
- return true;
- }
- bool basisu_frontend::compress()
- {
- debug_printf("basisu_frontend::compress\n");
- m_total_blocks = m_params.m_num_source_blocks;
- m_total_pixels = m_total_blocks * cPixelBlockTotalPixels;
- // Encode the initial high quality ETC1S texture
- init_etc1_images();
- // First quantize the ETC1S endpoints
- if (m_params.m_pGlobal_codebooks)
- {
- init_global_codebooks();
- }
- else
- {
- init_endpoint_training_vectors();
- generate_endpoint_clusters();
- for (uint32_t refine_endpoint_step = 0; refine_endpoint_step < m_num_endpoint_codebook_iterations; refine_endpoint_step++)
- {
- if (m_params.m_validate)
- {
- BASISU_FRONTEND_VERIFY(check_etc1s_constraints());
- BASISU_FRONTEND_VERIFY(validate_endpoint_cluster_hierarchy(false));
- }
- if (refine_endpoint_step)
- {
- introduce_new_endpoint_clusters();
- }
- if (m_params.m_validate)
- {
- BASISU_FRONTEND_VERIFY(validate_endpoint_cluster_hierarchy(false));
- }
- generate_endpoint_codebook(refine_endpoint_step);
- if ((m_params.m_debug_images) && (m_params.m_dump_endpoint_clusterization))
- {
- char buf[256];
- snprintf(buf, sizeof(buf), "endpoint_cluster_vis_pre_%u.png", refine_endpoint_step);
- dump_endpoint_clusterization_visualization(buf, false);
- }
- bool early_out = false;
- if (m_endpoint_refinement)
- {
- //dump_endpoint_clusterization_visualization("endpoint_clusters_before_refinement.png");
- if (!refine_endpoint_clusterization())
- early_out = true;
- if ((m_params.m_tex_type == basist::cBASISTexTypeVideoFrames) && (!refine_endpoint_step) && (m_num_endpoint_codebook_iterations == 1))
- {
- eliminate_redundant_or_empty_endpoint_clusters();
- generate_endpoint_codebook(basisu::maximum(1U, refine_endpoint_step));
- }
- if ((m_params.m_debug_images) && (m_params.m_dump_endpoint_clusterization))
- {
- char buf[256];
- snprintf(buf, sizeof(buf), "endpoint_cluster_vis_post_%u.png", refine_endpoint_step);
- dump_endpoint_clusterization_visualization(buf, false);
- snprintf(buf, sizeof(buf), "endpoint_cluster_colors_vis_post_%u.png", refine_endpoint_step);
- dump_endpoint_clusterization_visualization(buf, true);
- }
- }
- if (m_params.m_validate)
- {
- BASISU_FRONTEND_VERIFY(validate_endpoint_cluster_hierarchy(false));
- }
-
- eliminate_redundant_or_empty_endpoint_clusters();
- if (m_params.m_validate)
- {
- BASISU_FRONTEND_VERIFY(validate_endpoint_cluster_hierarchy(false));
- }
- if (m_params.m_debug_stats)
- debug_printf("Total endpoint clusters: %u\n", (uint32_t)m_endpoint_clusters.size());
- if (early_out)
- break;
- }
-
- if (m_params.m_validate)
- {
- BASISU_FRONTEND_VERIFY(check_etc1s_constraints());
- }
- generate_block_endpoint_clusters();
- create_initial_packed_texture();
- // Now quantize the ETC1S selectors
- generate_selector_clusters();
- if (m_use_hierarchical_selector_codebooks)
- compute_selector_clusters_within_each_parent_cluster();
-
- if (m_params.m_compression_level == 0)
- {
- create_optimized_selector_codebook(0);
- find_optimal_selector_clusters_for_each_block();
-
- introduce_special_selector_clusters();
- }
- else
- {
- const uint32_t num_refine_selector_steps = m_num_selector_codebook_iterations;
- for (uint32_t refine_selector_steps = 0; refine_selector_steps < num_refine_selector_steps; refine_selector_steps++)
- {
- create_optimized_selector_codebook(refine_selector_steps);
- find_optimal_selector_clusters_for_each_block();
- introduce_special_selector_clusters();
- if ((m_params.m_compression_level >= 4) || (m_params.m_tex_type == basist::cBASISTexTypeVideoFrames))
- {
- if (!refine_block_endpoints_given_selectors())
- break;
- }
- }
- }
-
- optimize_selector_codebook();
- if (m_params.m_debug_stats)
- debug_printf("Total selector clusters: %u\n", (uint32_t)m_selector_cluster_block_indices.size());
- }
- finalize();
- if (m_params.m_validate)
- {
- if (!validate_output())
- return false;
- }
- debug_printf("basisu_frontend::compress: Done\n");
- return true;
- }
- bool basisu_frontend::init_global_codebooks()
- {
- const basist::basisu_lowlevel_etc1s_transcoder* pTranscoder = m_params.m_pGlobal_codebooks;
- const basist::basisu_lowlevel_etc1s_transcoder::endpoint_vec& endpoints = pTranscoder->get_endpoints();
- const basist::basisu_lowlevel_etc1s_transcoder::selector_vec& selectors = pTranscoder->get_selectors();
-
- m_endpoint_cluster_etc_params.resize(endpoints.size());
- for (uint32_t i = 0; i < endpoints.size(); i++)
- {
- m_endpoint_cluster_etc_params[i].m_inten_table[0] = endpoints[i].m_inten5;
- m_endpoint_cluster_etc_params[i].m_inten_table[1] = endpoints[i].m_inten5;
- m_endpoint_cluster_etc_params[i].m_color_unscaled[0].set(endpoints[i].m_color5.r, endpoints[i].m_color5.g, endpoints[i].m_color5.b, 255);
- m_endpoint_cluster_etc_params[i].m_color_used[0] = true;
- m_endpoint_cluster_etc_params[i].m_valid = true;
- }
- m_optimized_cluster_selectors.resize(selectors.size());
- for (uint32_t i = 0; i < m_optimized_cluster_selectors.size(); i++)
- {
- for (uint32_t y = 0; y < 4; y++)
- for (uint32_t x = 0; x < 4; x++)
- m_optimized_cluster_selectors[i].set_selector(x, y, selectors[i].get_selector(x, y));
- }
- m_block_endpoint_clusters_indices.resize(m_total_blocks);
- m_orig_encoded_blocks.resize(m_total_blocks);
- m_block_selector_cluster_index.resize(m_total_blocks);
- #if 0
- for (uint32_t block_index_iter = 0; block_index_iter < m_total_blocks; block_index_iter += N)
- {
- const uint32_t first_index = block_index_iter;
- const uint32_t last_index = minimum<uint32_t>(m_total_blocks, first_index + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job([this, first_index, last_index] {
- #endif
- for (uint32_t block_index = first_index; block_index < last_index; block_index++)
- {
- const etc_block& blk = m_etc1_blocks_etc1s[block_index];
- const uint32_t block_endpoint_index = m_block_endpoint_clusters_indices[block_index][0];
- etc_block trial_blk;
- trial_blk.set_block_color5_etc1s(blk.m_color_unscaled[0]);
- trial_blk.set_flip_bit(true);
- uint64_t best_err = UINT64_MAX;
- uint32_t best_index = 0;
- for (uint32_t i = 0; i < m_optimized_cluster_selectors.size(); i++)
- {
- trial_blk.set_raw_selector_bits(m_optimized_cluster_selectors[i].get_raw_selector_bits());
- const uint64_t cur_err = trial_blk.evaluate_etc1_error(get_source_pixel_block(block_index).get_ptr(), m_params.m_perceptual);
- if (cur_err < best_err)
- {
- best_err = cur_err;
- best_index = i;
- if (!cur_err)
- break;
- }
- } // block_index
- m_block_selector_cluster_index[block_index] = best_index;
- }
- #ifndef __EMSCRIPTEN__
- });
- #endif
- }
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
- m_encoded_blocks.resize(m_total_blocks);
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- const uint32_t endpoint_index = m_block_endpoint_clusters_indices[block_index][0];
- const uint32_t selector_index = m_block_selector_cluster_index[block_index];
- etc_block& blk = m_encoded_blocks[block_index];
- blk.set_block_color5_etc1s(m_endpoint_cluster_etc_params[endpoint_index].m_color_unscaled[0]);
- blk.set_inten_tables_etc1s(m_endpoint_cluster_etc_params[endpoint_index].m_inten_table[0]);
- blk.set_flip_bit(true);
- blk.set_raw_selector_bits(m_optimized_cluster_selectors[selector_index].get_raw_selector_bits());
- }
- #endif
- // HACK HACK
- const uint32_t NUM_PASSES = 3;
- for (uint32_t pass = 0; pass < NUM_PASSES; pass++)
- {
- debug_printf("init_global_codebooks: pass %u\n", pass);
- const uint32_t N = 128;
- for (uint32_t block_index_iter = 0; block_index_iter < m_total_blocks; block_index_iter += N)
- {
- const uint32_t first_index = block_index_iter;
- const uint32_t last_index = minimum<uint32_t>(m_total_blocks, first_index + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job([this, first_index, last_index, pass] {
- #endif
-
- for (uint32_t block_index = first_index; block_index < last_index; block_index++)
- {
- const etc_block& blk = pass ? m_encoded_blocks[block_index] : m_etc1_blocks_etc1s[block_index];
- const uint32_t blk_raw_selector_bits = blk.get_raw_selector_bits();
- etc_block trial_blk(blk);
- trial_blk.set_raw_selector_bits(blk_raw_selector_bits);
- trial_blk.set_flip_bit(true);
- uint64_t best_err = UINT64_MAX;
- uint32_t best_index = 0;
- etc_block best_block(trial_blk);
-
- for (uint32_t i = 0; i < m_endpoint_cluster_etc_params.size(); i++)
- {
- if (m_endpoint_cluster_etc_params[i].m_inten_table[0] > blk.get_inten_table(0))
- continue;
- trial_blk.set_block_color5_etc1s(m_endpoint_cluster_etc_params[i].m_color_unscaled[0]);
- trial_blk.set_inten_tables_etc1s(m_endpoint_cluster_etc_params[i].m_inten_table[0]);
- const color_rgba* pSource_pixels = get_source_pixel_block(block_index).get_ptr();
- uint64_t cur_err;
- if (!pass)
- cur_err = trial_blk.determine_selectors(pSource_pixels, m_params.m_perceptual);
- else
- cur_err = trial_blk.evaluate_etc1_error(pSource_pixels, m_params.m_perceptual);
- if (cur_err < best_err)
- {
- best_err = cur_err;
- best_index = i;
- best_block = trial_blk;
- if (!cur_err)
- break;
- }
- }
- m_block_endpoint_clusters_indices[block_index][0] = best_index;
- m_block_endpoint_clusters_indices[block_index][1] = best_index;
- m_orig_encoded_blocks[block_index] = best_block;
- } // block_index
- #ifndef __EMSCRIPTEN__
- });
- #endif
- }
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
- m_endpoint_clusters.resize(0);
- m_endpoint_clusters.resize(endpoints.size());
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- const uint32_t endpoint_cluster_index = m_block_endpoint_clusters_indices[block_index][0];
- m_endpoint_clusters[endpoint_cluster_index].push_back(block_index * 2);
- m_endpoint_clusters[endpoint_cluster_index].push_back(block_index * 2 + 1);
- }
- m_block_selector_cluster_index.resize(m_total_blocks);
- for (uint32_t block_index_iter = 0; block_index_iter < m_total_blocks; block_index_iter += N)
- {
- const uint32_t first_index = block_index_iter;
- const uint32_t last_index = minimum<uint32_t>(m_total_blocks, first_index + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job([this, first_index, last_index] {
- #endif
- for (uint32_t block_index = first_index; block_index < last_index; block_index++)
- {
- const uint32_t block_endpoint_index = m_block_endpoint_clusters_indices[block_index][0];
- etc_block trial_blk;
- trial_blk.set_block_color5_etc1s(m_endpoint_cluster_etc_params[block_endpoint_index].m_color_unscaled[0]);
- trial_blk.set_inten_tables_etc1s(m_endpoint_cluster_etc_params[block_endpoint_index].m_inten_table[0]);
- trial_blk.set_flip_bit(true);
- uint64_t best_err = UINT64_MAX;
- uint32_t best_index = 0;
- for (uint32_t i = 0; i < m_optimized_cluster_selectors.size(); i++)
- {
- trial_blk.set_raw_selector_bits(m_optimized_cluster_selectors[i].get_raw_selector_bits());
- const uint64_t cur_err = trial_blk.evaluate_etc1_error(get_source_pixel_block(block_index).get_ptr(), m_params.m_perceptual);
- if (cur_err < best_err)
- {
- best_err = cur_err;
- best_index = i;
- if (!cur_err)
- break;
- }
- } // block_index
- m_block_selector_cluster_index[block_index] = best_index;
- }
- #ifndef __EMSCRIPTEN__
- });
- #endif
- }
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
- m_encoded_blocks.resize(m_total_blocks);
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- const uint32_t endpoint_index = m_block_endpoint_clusters_indices[block_index][0];
- const uint32_t selector_index = m_block_selector_cluster_index[block_index];
- etc_block& blk = m_encoded_blocks[block_index];
- blk.set_block_color5_etc1s(m_endpoint_cluster_etc_params[endpoint_index].m_color_unscaled[0]);
- blk.set_inten_tables_etc1s(m_endpoint_cluster_etc_params[endpoint_index].m_inten_table[0]);
- blk.set_flip_bit(true);
- blk.set_raw_selector_bits(m_optimized_cluster_selectors[selector_index].get_raw_selector_bits());
- }
- } // pass
- m_selector_cluster_block_indices.resize(selectors.size());
- for (uint32_t block_index = 0; block_index < m_etc1_blocks_etc1s.size(); block_index++)
- m_selector_cluster_block_indices[m_block_selector_cluster_index[block_index]].push_back(block_index);
-
- return true;
- }
- void basisu_frontend::introduce_special_selector_clusters()
- {
- debug_printf("introduce_special_selector_clusters\n");
- uint32_t total_blocks_relocated = 0;
- const uint32_t initial_selector_clusters = (uint32_t)m_selector_cluster_block_indices.size();
- bool_vec block_relocated_flags(m_total_blocks);
- // Make sure the selector codebook always has pure flat blocks for each possible selector, to avoid obvious artifacts.
- // optimize_selector_codebook() will clean up any redundant clusters we create here.
- for (uint32_t sel = 0; sel < 4; sel++)
- {
- etc_block blk;
- clear_obj(blk);
- for (uint32_t j = 0; j < 16; j++)
- blk.set_selector(j & 3, j >> 2, sel);
- int k;
- for (k = 0; k < (int)m_optimized_cluster_selectors.size(); k++)
- if (m_optimized_cluster_selectors[k].get_raw_selector_bits() == blk.get_raw_selector_bits())
- break;
- if (k < (int)m_optimized_cluster_selectors.size())
- continue;
- debug_printf("Introducing sel %u\n", sel);
- const uint32_t new_selector_cluster_index = (uint32_t)m_optimized_cluster_selectors.size();
- m_optimized_cluster_selectors.push_back(blk);
-
- vector_ensure_element_is_valid(m_selector_cluster_block_indices, new_selector_cluster_index);
-
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- if (m_orig_encoded_blocks[block_index].get_raw_selector_bits() != blk.get_raw_selector_bits())
- continue;
- // See if using flat selectors actually decreases the block's error.
- const uint32_t old_selector_cluster_index = m_block_selector_cluster_index[block_index];
-
- etc_block cur_blk;
- const uint32_t endpoint_cluster_index = get_subblock_endpoint_cluster_index(block_index, 0);
- cur_blk.set_block_color5_etc1s(get_endpoint_cluster_unscaled_color(endpoint_cluster_index, false));
- cur_blk.set_inten_tables_etc1s(get_endpoint_cluster_inten_table(endpoint_cluster_index, false));
- cur_blk.set_raw_selector_bits(get_selector_cluster_selector_bits(old_selector_cluster_index).get_raw_selector_bits());
- cur_blk.set_flip_bit(true);
- const uint64_t cur_err = cur_blk.evaluate_etc1_error(get_source_pixel_block(block_index).get_ptr(), m_params.m_perceptual);
- cur_blk.set_raw_selector_bits(blk.get_raw_selector_bits());
- const uint64_t new_err = cur_blk.evaluate_etc1_error(get_source_pixel_block(block_index).get_ptr(), m_params.m_perceptual);
- if (new_err >= cur_err)
- continue;
-
- // Change the block to use the new cluster
- m_block_selector_cluster_index[block_index] = new_selector_cluster_index;
-
- m_selector_cluster_block_indices[new_selector_cluster_index].push_back(block_index);
- block_relocated_flags[block_index] = true;
- #if 0
- int j = vector_find(m_selector_cluster_block_indices[old_selector_cluster_index], block_index);
- if (j >= 0)
- m_selector_cluster_block_indices[old_selector_cluster_index].erase(m_selector_cluster_block_indices[old_selector_cluster_index].begin() + j);
- #endif
- total_blocks_relocated++;
- m_encoded_blocks[block_index].set_raw_selector_bits(blk.get_raw_selector_bits());
- } // block_index
- } // sel
- if (total_blocks_relocated)
- {
- debug_printf("Fixing selector codebook\n");
- for (int selector_cluster_index = 0; selector_cluster_index < (int)initial_selector_clusters; selector_cluster_index++)
- {
- uint_vec& block_indices = m_selector_cluster_block_indices[selector_cluster_index];
- uint32_t dst_ofs = 0;
- for (uint32_t i = 0; i < block_indices.size(); i++)
- {
- const uint32_t block_index = block_indices[i];
- if (!block_relocated_flags[block_index])
- block_indices[dst_ofs++] = block_index;
- }
- block_indices.resize(dst_ofs);
- }
- }
- debug_printf("Total blocks relocated to new flat selector clusters: %u\n", total_blocks_relocated);
- }
- // This method will change the number and ordering of the selector codebook clusters.
- void basisu_frontend::optimize_selector_codebook()
- {
- debug_printf("optimize_selector_codebook\n");
- const uint32_t orig_total_selector_clusters = (uint32_t)m_optimized_cluster_selectors.size();
- bool_vec selector_cluster_was_used(m_optimized_cluster_selectors.size());
- for (uint32_t i = 0; i < m_total_blocks; i++)
- selector_cluster_was_used[m_block_selector_cluster_index[i]] = true;
- int_vec old_to_new(m_optimized_cluster_selectors.size());
- int_vec new_to_old;
- uint32_t total_new_entries = 0;
- std::unordered_map<uint32_t, uint32_t> selector_hashmap;
- for (int i = 0; i < static_cast<int>(m_optimized_cluster_selectors.size()); i++)
- {
- if (!selector_cluster_was_used[i])
- {
- old_to_new[i] = -1;
- continue;
- }
- const uint32_t raw_selector_bits = m_optimized_cluster_selectors[i].get_raw_selector_bits();
- auto find_res = selector_hashmap.insert(std::make_pair(raw_selector_bits, total_new_entries));
- if (!find_res.second)
- {
- old_to_new[i] = (find_res.first)->second;
- continue;
- }
-
- old_to_new[i] = total_new_entries++;
- new_to_old.push_back(i);
- }
- debug_printf("Original selector clusters: %u, new cluster selectors: %u\n", orig_total_selector_clusters, total_new_entries);
- for (uint32_t i = 0; i < m_block_selector_cluster_index.size(); i++)
- {
- BASISU_FRONTEND_VERIFY((old_to_new[m_block_selector_cluster_index[i]] >= 0) && (old_to_new[m_block_selector_cluster_index[i]] < (int)total_new_entries));
- m_block_selector_cluster_index[i] = old_to_new[m_block_selector_cluster_index[i]];
- }
- basisu::vector<etc_block> new_optimized_cluster_selectors(m_optimized_cluster_selectors.size() ? total_new_entries : 0);
- basisu::vector<uint_vec> new_selector_cluster_indices(m_selector_cluster_block_indices.size() ? total_new_entries : 0);
- for (uint32_t i = 0; i < total_new_entries; i++)
- {
- if (m_optimized_cluster_selectors.size())
- new_optimized_cluster_selectors[i] = m_optimized_cluster_selectors[new_to_old[i]];
- //if (m_selector_cluster_block_indices.size())
- // new_selector_cluster_indices[i] = m_selector_cluster_block_indices[new_to_old[i]];
- }
- for (uint32_t i = 0; i < m_block_selector_cluster_index.size(); i++)
- {
- new_selector_cluster_indices[m_block_selector_cluster_index[i]].push_back(i);
- }
-
- m_optimized_cluster_selectors.swap(new_optimized_cluster_selectors);
- m_selector_cluster_block_indices.swap(new_selector_cluster_indices);
- // This isn't strictly necessary - doing it for completeness/future sanity.
- if (m_selector_clusters_within_each_parent_cluster.size())
- {
- for (uint32_t i = 0; i < m_selector_clusters_within_each_parent_cluster.size(); i++)
- for (uint32_t j = 0; j < m_selector_clusters_within_each_parent_cluster[i].size(); j++)
- m_selector_clusters_within_each_parent_cluster[i][j] = old_to_new[m_selector_clusters_within_each_parent_cluster[i][j]];
- }
-
- debug_printf("optimize_selector_codebook: Before: %u After: %u\n", orig_total_selector_clusters, total_new_entries);
- }
- void basisu_frontend::init_etc1_images()
- {
- debug_printf("basisu_frontend::init_etc1_images\n");
- interval_timer tm;
- tm.start();
-
- m_etc1_blocks_etc1s.resize(m_total_blocks);
- bool use_cpu = true;
-
- if (m_params.m_pOpenCL_context)
- {
- uint32_t total_perms = 64;
- if (m_params.m_compression_level == 0)
- total_perms = 4;
- else if (m_params.m_compression_level == 1)
- total_perms = 16;
- else if (m_params.m_compression_level == BASISU_MAX_COMPRESSION_LEVEL)
- total_perms = OPENCL_ENCODE_ETC1S_MAX_PERMS;
-
- bool status = opencl_encode_etc1s_blocks(m_params.m_pOpenCL_context, m_etc1_blocks_etc1s.data(), m_params.m_perceptual, total_perms);
- if (status)
- use_cpu = false;
- else
- {
- error_printf("basisu_frontend::init_etc1_images: opencl_encode_etc1s_blocks() failed! Using CPU.\n");
- m_params.m_pOpenCL_context = nullptr;
- m_opencl_failed = true;
- }
- }
-
- if (use_cpu)
- {
- const uint32_t N = 4096;
- for (uint32_t block_index_iter = 0; block_index_iter < m_total_blocks; block_index_iter += N)
- {
- const uint32_t first_index = block_index_iter;
- const uint32_t last_index = minimum<uint32_t>(m_total_blocks, first_index + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job([this, first_index, last_index] {
- #endif
- for (uint32_t block_index = first_index; block_index < last_index; block_index++)
- {
- const pixel_block& source_blk = get_source_pixel_block(block_index);
- etc1_optimizer optimizer;
- etc1_optimizer::params optimizer_params;
- etc1_optimizer::results optimizer_results;
- if (m_params.m_compression_level == 0)
- optimizer_params.m_quality = cETCQualityFast;
- else if (m_params.m_compression_level == 1)
- optimizer_params.m_quality = cETCQualityMedium;
- else if (m_params.m_compression_level == BASISU_MAX_COMPRESSION_LEVEL)
- optimizer_params.m_quality = cETCQualityUber;
- optimizer_params.m_num_src_pixels = 16;
- optimizer_params.m_pSrc_pixels = source_blk.get_ptr();
- optimizer_params.m_perceptual = m_params.m_perceptual;
- uint8_t selectors[16];
- optimizer_results.m_pSelectors = selectors;
- optimizer_results.m_n = 16;
- optimizer.init(optimizer_params, optimizer_results);
- if (!optimizer.compute())
- BASISU_FRONTEND_VERIFY(false);
- etc_block& blk = m_etc1_blocks_etc1s[block_index];
- memset(&blk, 0, sizeof(blk));
- blk.set_block_color5_etc1s(optimizer_results.m_block_color_unscaled);
- blk.set_inten_tables_etc1s(optimizer_results.m_block_inten_table);
- blk.set_flip_bit(true);
- for (uint32_t y = 0; y < 4; y++)
- for (uint32_t x = 0; x < 4; x++)
- blk.set_selector(x, y, selectors[x + y * 4]);
- }
- #ifndef __EMSCRIPTEN__
- });
- #endif
- }
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
- } // use_cpu
-
- debug_printf("init_etc1_images: Elapsed time: %3.3f secs\n", tm.get_elapsed_secs());
- }
- void basisu_frontend::init_endpoint_training_vectors()
- {
- debug_printf("init_endpoint_training_vectors\n");
-
- vec6F_quantizer::array_of_weighted_training_vecs &training_vecs = m_endpoint_clusterizer.get_training_vecs();
-
- training_vecs.resize(m_total_blocks * 2);
- const uint32_t N = 16384;
- for (uint32_t block_index_iter = 0; block_index_iter < m_total_blocks; block_index_iter += N)
- {
- const uint32_t first_index = block_index_iter;
- const uint32_t last_index = minimum<uint32_t>(m_total_blocks, first_index + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job( [this, first_index, last_index, &training_vecs] {
- #endif
- for (uint32_t block_index = first_index; block_index < last_index; block_index++)
- {
- const etc_block &blk = m_etc1_blocks_etc1s[block_index];
- color_rgba block_colors[2];
- blk.get_block_low_high_colors(block_colors, 0);
-
- vec6F v;
- v[0] = block_colors[0].r * (1.0f / 255.0f);
- v[1] = block_colors[0].g * (1.0f / 255.0f);
- v[2] = block_colors[0].b * (1.0f / 255.0f);
- v[3] = block_colors[1].r * (1.0f / 255.0f);
- v[4] = block_colors[1].g * (1.0f / 255.0f);
- v[5] = block_colors[1].b * (1.0f / 255.0f);
-
- training_vecs[block_index * 2 + 0] = std::make_pair(v, 1);
- training_vecs[block_index * 2 + 1] = std::make_pair(v, 1);
- } // block_index;
- #ifndef __EMSCRIPTEN__
- } );
- #endif
- } // block_index_iter
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
- }
- void basisu_frontend::generate_endpoint_clusters()
- {
- debug_printf("Begin endpoint quantization\n");
- const uint32_t parent_codebook_size = (m_params.m_max_endpoint_clusters >= 256) ? BASISU_ENDPOINT_PARENT_CODEBOOK_SIZE : 0;
- uint32_t max_threads = 0;
- max_threads = m_params.m_multithreaded ? minimum<int>(std::thread::hardware_concurrency(), cMaxCodebookCreationThreads) : 0;
- if (m_params.m_pJob_pool)
- max_threads = minimum<int>((int)m_params.m_pJob_pool->get_total_threads(), max_threads);
- debug_printf("max_threads: %u\n", max_threads);
- bool status = generate_hierarchical_codebook_threaded(m_endpoint_clusterizer,
- m_params.m_max_endpoint_clusters, m_use_hierarchical_endpoint_codebooks ? parent_codebook_size : 0,
- m_endpoint_clusters,
- m_endpoint_parent_clusters,
- max_threads, m_params.m_pJob_pool, true);
- BASISU_FRONTEND_VERIFY(status);
- if (m_use_hierarchical_endpoint_codebooks)
- {
- if (!m_endpoint_parent_clusters.size())
- {
- m_endpoint_parent_clusters.resize(0);
- m_endpoint_parent_clusters.resize(1);
- for (uint32_t i = 0; i < m_total_blocks; i++)
- {
- m_endpoint_parent_clusters[0].push_back(i*2);
- m_endpoint_parent_clusters[0].push_back(i*2+1);
- }
- }
- BASISU_ASSUME(BASISU_ENDPOINT_PARENT_CODEBOOK_SIZE <= UINT8_MAX);
- m_block_parent_endpoint_cluster.resize(0);
- m_block_parent_endpoint_cluster.resize(m_total_blocks);
- vector_set_all(m_block_parent_endpoint_cluster, 0xFF);
- for (uint32_t parent_cluster_index = 0; parent_cluster_index < m_endpoint_parent_clusters.size(); parent_cluster_index++)
- {
- const uint_vec &cluster = m_endpoint_parent_clusters[parent_cluster_index];
- for (uint32_t j = 0; j < cluster.size(); j++)
- {
- const uint32_t block_index = cluster[j] >> 1;
- m_block_parent_endpoint_cluster[block_index] = static_cast<uint8_t>(parent_cluster_index);
- }
- }
- for (uint32_t i = 0; i < m_total_blocks; i++)
- {
- BASISU_FRONTEND_VERIFY(m_block_parent_endpoint_cluster[i] != 0xFF);
- }
- // Ensure that all the blocks within each cluster are all in the same parent cluster, or something is very wrong.
- for (uint32_t cluster_index = 0; cluster_index < m_endpoint_clusters.size(); cluster_index++)
- {
- const uint_vec &cluster = m_endpoint_clusters[cluster_index];
-
- uint32_t parent_cluster_index = 0;
- for (uint32_t j = 0; j < cluster.size(); j++)
- {
- const uint32_t block_index = cluster[j] >> 1;
-
- BASISU_FRONTEND_VERIFY(block_index < m_block_parent_endpoint_cluster.size());
- if (!j)
- {
- parent_cluster_index = m_block_parent_endpoint_cluster[block_index];
- }
- else
- {
- BASISU_FRONTEND_VERIFY(m_block_parent_endpoint_cluster[block_index] == parent_cluster_index);
- }
- }
- }
- }
-
- if (m_params.m_debug_stats)
- debug_printf("Total endpoint clusters: %u, parent clusters: %u\n", (uint32_t)m_endpoint_clusters.size(), (uint32_t)m_endpoint_parent_clusters.size());
- }
- // Iterate through each array of endpoint cluster block indices and set the m_block_endpoint_clusters_indices[][] array to indicaste which cluster index each block uses.
- void basisu_frontend::generate_block_endpoint_clusters()
- {
- m_block_endpoint_clusters_indices.resize(m_total_blocks);
- for (int cluster_index = 0; cluster_index < static_cast<int>(m_endpoint_clusters.size()); cluster_index++)
- {
- const basisu::vector<uint32_t>& cluster_indices = m_endpoint_clusters[cluster_index];
- for (uint32_t cluster_indices_iter = 0; cluster_indices_iter < cluster_indices.size(); cluster_indices_iter++)
- {
- const uint32_t block_index = cluster_indices[cluster_indices_iter] >> 1;
- const uint32_t subblock_index = cluster_indices[cluster_indices_iter] & 1;
- m_block_endpoint_clusters_indices[block_index][subblock_index] = cluster_index;
- } // cluster_indices_iter
- }
- if (m_params.m_validate)
- {
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- uint32_t cluster_0 = m_block_endpoint_clusters_indices[block_index][0];
- uint32_t cluster_1 = m_block_endpoint_clusters_indices[block_index][1];
- BASISU_FRONTEND_VERIFY(cluster_0 == cluster_1);
- }
- }
- }
- void basisu_frontend::compute_endpoint_clusters_within_each_parent_cluster()
- {
- generate_block_endpoint_clusters();
- m_endpoint_clusters_within_each_parent_cluster.resize(0);
- m_endpoint_clusters_within_each_parent_cluster.resize(m_endpoint_parent_clusters.size());
- // Note: It's possible that some blocks got moved into the same cluster, but live in different parent clusters.
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- const uint32_t cluster_index = m_block_endpoint_clusters_indices[block_index][0];
- const uint32_t parent_cluster_index = m_block_parent_endpoint_cluster[block_index];
- m_endpoint_clusters_within_each_parent_cluster[parent_cluster_index].push_back(cluster_index);
- }
- for (uint32_t i = 0; i < m_endpoint_clusters_within_each_parent_cluster.size(); i++)
- {
- uint_vec &cluster_indices = m_endpoint_clusters_within_each_parent_cluster[i];
- BASISU_FRONTEND_VERIFY(cluster_indices.size());
- vector_sort(cluster_indices);
-
- auto last = std::unique(cluster_indices.begin(), cluster_indices.end());
- cluster_indices.erase(last, cluster_indices.end());
- }
- }
- void basisu_frontend::compute_endpoint_subblock_error_vec()
- {
- m_subblock_endpoint_quant_err_vec.resize(0);
- const uint32_t N = 512;
- for (uint32_t cluster_index_iter = 0; cluster_index_iter < m_endpoint_clusters.size(); cluster_index_iter += N)
- {
- const uint32_t first_index = cluster_index_iter;
- const uint32_t last_index = minimum<uint32_t>((uint32_t)m_endpoint_clusters.size(), cluster_index_iter + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job( [this, first_index, last_index] {
- #endif
- for (uint32_t cluster_index = first_index; cluster_index < last_index; cluster_index++)
- {
- const basisu::vector<uint32_t>& cluster_indices = m_endpoint_clusters[cluster_index];
- assert(cluster_indices.size());
- for (uint32_t cluster_indices_iter = 0; cluster_indices_iter < cluster_indices.size(); cluster_indices_iter++)
- {
- basisu::vector<color_rgba> cluster_pixels(8);
- const uint32_t block_index = cluster_indices[cluster_indices_iter] >> 1;
- const uint32_t subblock_index = cluster_indices[cluster_indices_iter] & 1;
- const bool flipped = true;
- const color_rgba *pSource_block_pixels = get_source_pixel_block(block_index).get_ptr();
- for (uint32_t pixel_index = 0; pixel_index < 8; pixel_index++)
- {
- cluster_pixels[pixel_index] = pSource_block_pixels[g_etc1_pixel_indices[flipped][subblock_index][pixel_index]];
- }
- const endpoint_cluster_etc_params &etc_params = m_endpoint_cluster_etc_params[cluster_index];
- assert(etc_params.m_valid);
-
- color_rgba block_colors[4];
- etc_block::get_block_colors5(block_colors, etc_params.m_color_unscaled[0], etc_params.m_inten_table[0], true);
- uint64_t total_err = 0;
- for (uint32_t i = 0; i < 8; i++)
- {
- const color_rgba &c = cluster_pixels[i];
- uint64_t best_err = UINT64_MAX;
- //uint32_t best_index = 0;
- for (uint32_t s = 0; s < 4; s++)
- {
- uint64_t err = color_distance(m_params.m_perceptual, c, block_colors[s], false);
- if (err < best_err)
- {
- best_err = err;
- //best_index = s;
- }
- }
- total_err += best_err;
- }
- subblock_endpoint_quant_err quant_err;
- quant_err.m_total_err = total_err;
- quant_err.m_cluster_index = cluster_index;
- quant_err.m_cluster_subblock_index = cluster_indices_iter;
- quant_err.m_block_index = block_index;
- quant_err.m_subblock_index = subblock_index;
-
- {
- std::lock_guard<std::mutex> lock(m_lock);
- m_subblock_endpoint_quant_err_vec.push_back(quant_err);
- }
- }
- } // cluster_index
- #ifndef __EMSCRIPTEN__
- } );
- #endif
- } // cluster_index_iter
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
- vector_sort(m_subblock_endpoint_quant_err_vec);
- }
-
- void basisu_frontend::introduce_new_endpoint_clusters()
- {
- debug_printf("introduce_new_endpoint_clusters\n");
- generate_block_endpoint_clusters();
- int num_new_endpoint_clusters = m_params.m_max_endpoint_clusters - (uint32_t)m_endpoint_clusters.size();
- if (num_new_endpoint_clusters <= 0)
- return;
- compute_endpoint_subblock_error_vec();
- const uint32_t num_orig_endpoint_clusters = (uint32_t)m_endpoint_clusters.size();
- std::unordered_set<uint32_t> training_vector_was_relocated;
- uint_vec cluster_sizes(num_orig_endpoint_clusters);
- for (uint32_t i = 0; i < num_orig_endpoint_clusters; i++)
- cluster_sizes[i] = (uint32_t)m_endpoint_clusters[i].size();
- std::unordered_set<uint32_t> ignore_cluster;
- uint32_t total_new_clusters = 0;
- while (num_new_endpoint_clusters)
- {
- if (m_subblock_endpoint_quant_err_vec.size() == 0)
- break;
- subblock_endpoint_quant_err subblock_to_move(m_subblock_endpoint_quant_err_vec.back());
- m_subblock_endpoint_quant_err_vec.pop_back();
- if (unordered_set_contains(ignore_cluster, subblock_to_move.m_cluster_index))
- continue;
- uint32_t training_vector_index = subblock_to_move.m_block_index * 2 + subblock_to_move.m_subblock_index;
- if (cluster_sizes[subblock_to_move.m_cluster_index] <= 2)
- continue;
- if (unordered_set_contains(training_vector_was_relocated, training_vector_index))
- continue;
- if (unordered_set_contains(training_vector_was_relocated, training_vector_index ^ 1))
- continue;
- #if 0
- const uint32_t block_index = subblock_to_move.m_block_index;
- const etc_block& blk = m_etc1_blocks_etc1s[block_index];
- uint32_t ls, hs;
- blk.get_selector_range(ls, hs);
- if (ls != hs)
- continue;
- #endif
- //const uint32_t new_endpoint_cluster_index = (uint32_t)m_endpoint_clusters.size();
- enlarge_vector(m_endpoint_clusters, 1)->push_back(training_vector_index);
- enlarge_vector(m_endpoint_cluster_etc_params, 1);
- assert(m_endpoint_clusters.size() == m_endpoint_cluster_etc_params.size());
- training_vector_was_relocated.insert(training_vector_index);
- m_endpoint_clusters.back().push_back(training_vector_index ^ 1);
- training_vector_was_relocated.insert(training_vector_index ^ 1);
- BASISU_FRONTEND_VERIFY(cluster_sizes[subblock_to_move.m_cluster_index] >= 2);
- cluster_sizes[subblock_to_move.m_cluster_index] -= 2;
-
- ignore_cluster.insert(subblock_to_move.m_cluster_index);
-
- total_new_clusters++;
- num_new_endpoint_clusters--;
- }
- debug_printf("Introduced %i new endpoint clusters\n", total_new_clusters);
- for (uint32_t i = 0; i < num_orig_endpoint_clusters; i++)
- {
- uint_vec &cluster_indices = m_endpoint_clusters[i];
- uint_vec new_cluster_indices;
- for (uint32_t j = 0; j < cluster_indices.size(); j++)
- {
- uint32_t training_vector_index = cluster_indices[j];
- if (!unordered_set_contains(training_vector_was_relocated, training_vector_index))
- new_cluster_indices.push_back(training_vector_index);
- }
- if (cluster_indices.size() != new_cluster_indices.size())
- {
- BASISU_FRONTEND_VERIFY(new_cluster_indices.size() > 0);
- cluster_indices.swap(new_cluster_indices);
- }
- }
- generate_block_endpoint_clusters();
- }
- struct color_rgba_hasher
- {
- inline std::size_t operator()(const color_rgba& k) const
- {
- uint32_t v = *(const uint32_t*)&k;
-
- //return bitmix32(v);
-
- //v ^= (v << 10);
- //v ^= (v >> 12);
-
- return v;
- }
- };
-
- // Given each endpoint cluster, gather all the block pixels which are in that cluster and compute optimized ETC1S endpoints for them.
- // TODO: Don't optimize endpoint clusters which haven't changed.
- // If step>=1, we check to ensure the new endpoint values actually decrease quantization error.
- void basisu_frontend::generate_endpoint_codebook(uint32_t step)
- {
- debug_printf("generate_endpoint_codebook\n");
-
- interval_timer tm;
- tm.start();
- m_endpoint_cluster_etc_params.resize(m_endpoint_clusters.size());
- bool use_cpu = true;
- // TODO: Get this working when step>0
- if (m_params.m_pOpenCL_context && !step)
- {
- const uint32_t total_clusters = m_endpoint_clusters.size();
- basisu::vector<cl_pixel_cluster> pixel_clusters(total_clusters);
-
- std::vector<color_rgba> input_pixels;
- input_pixels.reserve(m_total_blocks * 16);
- std::vector<uint32_t> pixel_weights;
- pixel_weights.reserve(m_total_blocks * 16);
- uint_vec cluster_sizes(total_clusters);
- //typedef basisu::hash_map<color_rgba, uint32_t, color_rgba_hasher> color_hasher_type;
- //color_hasher_type color_hasher;
- //color_hasher.reserve(2048);
- interval_timer hash_tm;
- hash_tm.start();
- basisu::vector<uint32_t> colors, colors2;
- colors.reserve(65536);
- colors2.reserve(65536);
- for (uint32_t cluster_index = 0; cluster_index < m_endpoint_clusters.size(); cluster_index++)
- {
- const basisu::vector<uint32_t>& cluster_indices = m_endpoint_clusters[cluster_index];
- assert((cluster_indices.size() & 1) == 0);
- #if 0
- uint64_t first_pixel_index = input_pixels.size();
- const uint32_t total_pixels = 16 * (cluster_indices.size() / 2);
- input_pixels.resize(input_pixels.size() + total_pixels);
- pixel_weights.resize(pixel_weights.size() + total_pixels);
- uint64_t dst_ofs = first_pixel_index;
-
- uint64_t total_r = 0, total_g = 0, total_b = 0;
- for (uint32_t cluster_indices_iter = 0; cluster_indices_iter < cluster_indices.size(); cluster_indices_iter++)
- {
- const uint32_t subblock_index = cluster_indices[cluster_indices_iter] & 1;
- if (subblock_index)
- continue;
- const uint32_t block_index = cluster_indices[cluster_indices_iter] >> 1;
- const color_rgba* pBlock_pixels = get_source_pixel_block(block_index).get_ptr();
- for (uint32_t i = 0; i < 16; i++)
- {
- input_pixels[dst_ofs] = pBlock_pixels[i];
- pixel_weights[dst_ofs] = 1;
- dst_ofs++;
- total_r += pBlock_pixels[i].r;
- total_g += pBlock_pixels[i].g;
- total_b += pBlock_pixels[i].b;
- }
- }
- //printf("%i %f %f %f\n", cluster_index, total_r / (float)total_pixels, total_g / (float)total_pixels, total_b / (float)total_pixels);
- pixel_clusters[cluster_index].m_first_pixel_index = first_pixel_index;
- pixel_clusters[cluster_index].m_total_pixels = total_pixels;
- cluster_sizes[cluster_index] = total_pixels;
- #elif 1
- colors.resize(cluster_indices.size() * 8);
- colors2.resize(cluster_indices.size() * 8);
- uint32_t dst_ofs = 0;
- for (uint32_t cluster_indices_iter = 0; cluster_indices_iter < cluster_indices.size(); cluster_indices_iter++)
- {
- const uint32_t subblock_index = cluster_indices[cluster_indices_iter] & 1;
- if (subblock_index)
- continue;
- const uint32_t block_index = cluster_indices[cluster_indices_iter] >> 1;
- const color_rgba* pBlock_pixels = get_source_pixel_block(block_index).get_ptr();
- memcpy(colors.data() + dst_ofs, pBlock_pixels, sizeof(color_rgba) * 16);
- dst_ofs += 16;
- } // cluster_indices_iter
- uint32_t* pSorted = radix_sort(colors.size(), colors.data(), colors2.data(), 0, 3);
- const uint64_t first_pixel_index = input_pixels.size();
- uint32_t prev_color = 0, cur_weight = 0;
-
- for (uint32_t i = 0; i < colors.size(); i++)
- {
- uint32_t cur_color = pSorted[i];
- if (cur_color == prev_color)
- {
- if (++cur_weight == 0)
- cur_weight--;
- }
- else
- {
- if (cur_weight)
- {
- input_pixels.push_back(*(const color_rgba*)&prev_color);
- pixel_weights.push_back(cur_weight);
- }
- prev_color = cur_color;
- cur_weight = 1;
- }
- }
- if (cur_weight)
- {
- input_pixels.push_back(*(const color_rgba*)&prev_color);
- pixel_weights.push_back(cur_weight);
- }
- uint32_t total_unique_pixels = (uint32_t)(input_pixels.size() - first_pixel_index);
- pixel_clusters[cluster_index].m_first_pixel_index = first_pixel_index;
- pixel_clusters[cluster_index].m_total_pixels = total_unique_pixels;
- cluster_sizes[cluster_index] = total_unique_pixels;
- #else
- color_hasher.reset();
- for (uint32_t cluster_indices_iter = 0; cluster_indices_iter < cluster_indices.size(); cluster_indices_iter++)
- {
- const uint32_t subblock_index = cluster_indices[cluster_indices_iter] & 1;
- if (subblock_index)
- continue;
- const uint32_t block_index = cluster_indices[cluster_indices_iter] >> 1;
- const color_rgba* pBlock_pixels = get_source_pixel_block(block_index).get_ptr();
- uint32_t *pPrev_weight = nullptr;
- color_rgba prev_color;
-
- {
- color_rgba cur_color = pBlock_pixels[0];
- auto res = color_hasher.insert(cur_color, 0);
- uint32_t& weight = (res.first)->second;
- if (weight != UINT32_MAX)
- weight++;
- prev_color = cur_color;
- pPrev_weight = &(res.first)->second;
- }
-
- for (uint32_t i = 1; i < 16; i++)
- {
- color_rgba cur_color = pBlock_pixels[i];
- if (cur_color == prev_color)
- {
- if (*pPrev_weight != UINT32_MAX)
- *pPrev_weight = *pPrev_weight + 1;
- }
- else
- {
- auto res = color_hasher.insert(cur_color, 0);
- uint32_t& weight = (res.first)->second;
- if (weight != UINT32_MAX)
- weight++;
- prev_color = cur_color;
- pPrev_weight = &(res.first)->second;
- }
- }
- } // cluster_indices_iter
- const uint64_t first_pixel_index = input_pixels.size();
- uint32_t total_unique_pixels = color_hasher.size();
- pixel_clusters[cluster_index].m_first_pixel_index = first_pixel_index;
- pixel_clusters[cluster_index].m_total_pixels = total_unique_pixels;
- input_pixels.resize(first_pixel_index + total_unique_pixels);
- pixel_weights.resize(first_pixel_index + total_unique_pixels);
-
- uint32_t j = 0;
-
- for (auto it = color_hasher.begin(); it != color_hasher.end(); ++it, ++j)
- {
- input_pixels[first_pixel_index + j] = it->first;
- pixel_weights[first_pixel_index + j] = it->second;
- }
- cluster_sizes[cluster_index] = total_unique_pixels;
- #endif
- } // cluster_index
- debug_printf("Total hash time: %3.3f secs\n", hash_tm.get_elapsed_secs());
- debug_printf("Total unique colors: %llu\n", input_pixels.size());
- uint_vec sorted_cluster_indices_new_to_old(total_clusters);
- indirect_sort(total_clusters, sorted_cluster_indices_new_to_old.data(), cluster_sizes.data());
- //for (uint32_t i = 0; i < total_clusters; i++)
- // sorted_cluster_indices_new_to_old[i] = i;
- uint_vec sorted_cluster_indices_old_to_new(total_clusters);
- for (uint32_t i = 0; i < total_clusters; i++)
- sorted_cluster_indices_old_to_new[sorted_cluster_indices_new_to_old[i]] = i;
- basisu::vector<cl_pixel_cluster> sorted_pixel_clusters(total_clusters);
- for (uint32_t i = 0; i < total_clusters; i++)
- sorted_pixel_clusters[i] = pixel_clusters[sorted_cluster_indices_new_to_old[i]];
- uint32_t total_perms = 64;
- if (m_params.m_compression_level <= 1)
- total_perms = 16;
- else if (m_params.m_compression_level == BASISU_MAX_COMPRESSION_LEVEL)
- total_perms = OPENCL_ENCODE_ETC1S_MAX_PERMS;
- basisu::vector<etc_block> output_blocks(total_clusters);
- if (opencl_encode_etc1s_pixel_clusters(
- m_params.m_pOpenCL_context,
- output_blocks.data(),
- total_clusters,
- sorted_pixel_clusters.data(),
- input_pixels.size(),
- input_pixels.data(),
- pixel_weights.data(),
- m_params.m_perceptual, total_perms))
- {
- for (uint32_t old_cluster_index = 0; old_cluster_index < m_endpoint_clusters.size(); old_cluster_index++)
- {
- const uint32_t new_cluster_index = sorted_cluster_indices_old_to_new[old_cluster_index];
-
- const etc_block& blk = output_blocks[new_cluster_index];
- endpoint_cluster_etc_params& prev_etc_params = m_endpoint_cluster_etc_params[old_cluster_index];
- prev_etc_params.m_valid = true;
- etc_block::unpack_color5(prev_etc_params.m_color_unscaled[0], blk.get_base5_color(), false);
- prev_etc_params.m_inten_table[0] = blk.get_inten_table(0);
- prev_etc_params.m_color_error[0] = 0; // dummy value - we don't actually use this
- }
- use_cpu = false;
- }
- else
- {
- error_printf("basisu_frontend::generate_endpoint_codebook: opencl_encode_etc1s_pixel_clusters() failed! Using CPU.\n");
- m_params.m_pOpenCL_context = nullptr;
- m_opencl_failed = true;
- }
- } // if (opencl_is_available() && m_params.m_use_opencl)
- if (use_cpu)
- {
- const uint32_t N = 128;
- for (uint32_t cluster_index_iter = 0; cluster_index_iter < m_endpoint_clusters.size(); cluster_index_iter += N)
- {
- const uint32_t first_index = cluster_index_iter;
- const uint32_t last_index = minimum<uint32_t>((uint32_t)m_endpoint_clusters.size(), cluster_index_iter + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job([this, first_index, last_index, step] {
- #endif
- for (uint32_t cluster_index = first_index; cluster_index < last_index; cluster_index++)
- {
- const basisu::vector<uint32_t>& cluster_indices = m_endpoint_clusters[cluster_index];
- BASISU_FRONTEND_VERIFY(cluster_indices.size());
- const uint32_t total_pixels = (uint32_t)cluster_indices.size() * 8;
- basisu::vector<color_rgba> cluster_pixels(total_pixels);
- for (uint32_t cluster_indices_iter = 0; cluster_indices_iter < cluster_indices.size(); cluster_indices_iter++)
- {
- const uint32_t block_index = cluster_indices[cluster_indices_iter] >> 1;
- const uint32_t subblock_index = cluster_indices[cluster_indices_iter] & 1;
- const bool flipped = true;
- const color_rgba* pBlock_pixels = get_source_pixel_block(block_index).get_ptr();
- for (uint32_t pixel_index = 0; pixel_index < 8; pixel_index++)
- {
- const color_rgba& c = pBlock_pixels[g_etc1_pixel_indices[flipped][subblock_index][pixel_index]];
- cluster_pixels[cluster_indices_iter * 8 + pixel_index] = c;
- }
- }
- endpoint_cluster_etc_params new_subblock_params;
- {
- etc1_optimizer optimizer;
- etc1_solution_coordinates solutions[2];
- etc1_optimizer::params cluster_optimizer_params;
- cluster_optimizer_params.m_num_src_pixels = total_pixels;
- cluster_optimizer_params.m_pSrc_pixels = &cluster_pixels[0];
- cluster_optimizer_params.m_use_color4 = false;
- cluster_optimizer_params.m_perceptual = m_params.m_perceptual;
- if (m_params.m_compression_level <= 1)
- cluster_optimizer_params.m_quality = cETCQualityMedium;
- else if (m_params.m_compression_level == BASISU_MAX_COMPRESSION_LEVEL)
- cluster_optimizer_params.m_quality = cETCQualityUber;
- etc1_optimizer::results cluster_optimizer_results;
- basisu::vector<uint8_t> cluster_selectors(total_pixels);
- cluster_optimizer_results.m_n = total_pixels;
- cluster_optimizer_results.m_pSelectors = &cluster_selectors[0];
- optimizer.init(cluster_optimizer_params, cluster_optimizer_results);
- if (!optimizer.compute())
- BASISU_FRONTEND_VERIFY(false);
- new_subblock_params.m_color_unscaled[0] = cluster_optimizer_results.m_block_color_unscaled;
- new_subblock_params.m_inten_table[0] = cluster_optimizer_results.m_block_inten_table;
- new_subblock_params.m_color_error[0] = cluster_optimizer_results.m_error;
- }
- endpoint_cluster_etc_params& prev_etc_params = m_endpoint_cluster_etc_params[cluster_index];
- bool use_new_subblock_params = false;
- if ((!step) || (!prev_etc_params.m_valid))
- use_new_subblock_params = true;
- else
- {
- assert(prev_etc_params.m_valid);
- uint64_t total_prev_err = 0;
- {
- color_rgba block_colors[4];
- etc_block::get_block_colors5(block_colors, prev_etc_params.m_color_unscaled[0], prev_etc_params.m_inten_table[0], false);
- uint64_t total_err = 0;
- for (uint32_t i = 0; i < total_pixels; i++)
- {
- const color_rgba& c = cluster_pixels[i];
- uint64_t best_err = UINT64_MAX;
- //uint32_t best_index = 0;
- for (uint32_t s = 0; s < 4; s++)
- {
- uint64_t err = color_distance(m_params.m_perceptual, c, block_colors[s], false);
- if (err < best_err)
- {
- best_err = err;
- //best_index = s;
- }
- }
- total_err += best_err;
- }
- total_prev_err += total_err;
- }
- // See if we should update this cluster's endpoints (if the error has actually fallen)
- if (total_prev_err > new_subblock_params.m_color_error[0])
- {
- use_new_subblock_params = true;
- }
- }
- if (use_new_subblock_params)
- {
- new_subblock_params.m_valid = true;
- prev_etc_params = new_subblock_params;
- }
- } // cluster_index
- #ifndef __EMSCRIPTEN__
- });
- #endif
- } // cluster_index_iter
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
- }
- debug_printf("Elapsed time: %3.3f secs\n", tm.get_elapsed_secs());
- }
- bool basisu_frontend::check_etc1s_constraints() const
- {
- basisu::vector<vec2U> block_clusters(m_total_blocks);
- for (int cluster_index = 0; cluster_index < static_cast<int>(m_endpoint_clusters.size()); cluster_index++)
- {
- const basisu::vector<uint32_t>& cluster_indices = m_endpoint_clusters[cluster_index];
- for (uint32_t cluster_indices_iter = 0; cluster_indices_iter < cluster_indices.size(); cluster_indices_iter++)
- {
- const uint32_t block_index = cluster_indices[cluster_indices_iter] >> 1;
- const uint32_t subblock_index = cluster_indices[cluster_indices_iter] & 1;
- block_clusters[block_index][subblock_index] = cluster_index;
- } // cluster_indices_iter
- }
- for (uint32_t i = 0; i < m_total_blocks; i++)
- {
- if (block_clusters[i][0] != block_clusters[i][1])
- return false;
- }
- return true;
- }
- // For each block, determine which ETC1S endpoint cluster can encode that block with lowest error.
- // This reassigns blocks to different endpoint clusters.
- uint32_t basisu_frontend::refine_endpoint_clusterization()
- {
- debug_printf("refine_endpoint_clusterization\n");
-
- if (m_use_hierarchical_endpoint_codebooks)
- compute_endpoint_clusters_within_each_parent_cluster();
- // Note: It's possible that an endpoint cluster may live in more than one parent cluster after the first refinement step.
- basisu::vector<vec2U> block_clusters(m_total_blocks);
- for (int cluster_index = 0; cluster_index < static_cast<int>(m_endpoint_clusters.size()); cluster_index++)
- {
- const basisu::vector<uint32_t>& cluster_indices = m_endpoint_clusters[cluster_index];
- for (uint32_t cluster_indices_iter = 0; cluster_indices_iter < cluster_indices.size(); cluster_indices_iter++)
- {
- const uint32_t block_index = cluster_indices[cluster_indices_iter] >> 1;
- const uint32_t subblock_index = cluster_indices[cluster_indices_iter] & 1;
- block_clusters[block_index][subblock_index] = cluster_index;
- } // cluster_indices_iter
- }
-
- //----------------------------------------------------------
-
- // Create a new endpoint clusterization
- interval_timer tm;
- tm.start();
- uint_vec best_cluster_indices(m_total_blocks);
- bool use_cpu = true;
- // TODO: Support non-hierarchical endpoint codebooks here
- if (m_params.m_pOpenCL_context && m_use_hierarchical_endpoint_codebooks)
- {
- // For the OpenCL kernel, we order the parent endpoint clusters by smallest to largest for efficiency.
- // We also prepare an array of block info structs that point into this new parent endpoint cluster array.
- const uint32_t total_parent_clusters = m_endpoint_clusters_within_each_parent_cluster.size();
- basisu::vector<cl_block_info_struct> cl_block_info_structs(m_total_blocks);
-
- // the size of each parent cluster, in total clusters
- uint_vec parent_cluster_sizes(total_parent_clusters);
- for (uint32_t i = 0; i < total_parent_clusters; i++)
- parent_cluster_sizes[i] = m_endpoint_clusters_within_each_parent_cluster[i].size();
- uint_vec first_parent_cluster_ofs(total_parent_clusters);
- uint32_t cur_ofs = 0;
- for (uint32_t i = 0; i < total_parent_clusters; i++)
- {
- first_parent_cluster_ofs[i] = cur_ofs;
- cur_ofs += parent_cluster_sizes[i];
- }
-
- // Note: total_actual_endpoint_clusters is not necessarly equal to m_endpoint_clusters.size(), because clusters may live in multiple parent clusters after the first refinement step.
- BASISU_FRONTEND_VERIFY(cur_ofs >= m_endpoint_clusters.size());
- const uint32_t total_actual_endpoint_clusters = cur_ofs;
- basisu::vector<cl_endpoint_cluster_struct> cl_endpoint_cluster_structs(total_actual_endpoint_clusters);
- for (uint32_t i = 0; i < total_parent_clusters; i++)
- {
- const uint32_t dst_ofs = first_parent_cluster_ofs[i];
- const uint32_t parent_cluster_size = parent_cluster_sizes[i];
- assert(m_endpoint_clusters_within_each_parent_cluster[i].size() == parent_cluster_size);
- for (uint32_t j = 0; j < parent_cluster_size; j++)
- {
- const uint32_t endpoint_cluster_index = m_endpoint_clusters_within_each_parent_cluster[i][j];
- color_rgba cluster_etc_base_color(m_endpoint_cluster_etc_params[endpoint_cluster_index].m_color_unscaled[0]);
- uint32_t cluster_etc_inten = m_endpoint_cluster_etc_params[endpoint_cluster_index].m_inten_table[0];
- cl_endpoint_cluster_structs[dst_ofs + j].m_unscaled_color = cluster_etc_base_color;
- cl_endpoint_cluster_structs[dst_ofs + j].m_etc_inten = (uint8_t)cluster_etc_inten;
- cl_endpoint_cluster_structs[dst_ofs + j].m_cluster_index = (uint16_t)endpoint_cluster_index;
- }
- }
-
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- const uint32_t block_parent_endpoint_cluster_index = m_block_parent_endpoint_cluster[block_index];
-
- cl_block_info_structs[block_index].m_num_clusters = (uint16_t)(parent_cluster_sizes[block_parent_endpoint_cluster_index]);
- cl_block_info_structs[block_index].m_first_cluster_ofs = (uint16_t)(first_parent_cluster_ofs[block_parent_endpoint_cluster_index]);
- const uint32_t block_cluster_index = block_clusters[block_index][0];
- cl_block_info_structs[block_index].m_cur_cluster_index = (uint16_t)block_cluster_index;
- cl_block_info_structs[block_index].m_cur_cluster_etc_inten = (uint8_t)m_endpoint_cluster_etc_params[block_cluster_index].m_inten_table[0];
- }
- uint_vec block_cluster_indices(m_total_blocks);
- for (uint32_t i = 0; i < m_total_blocks; i++)
- block_cluster_indices[i] = block_clusters[i][0];
- uint_vec sorted_block_indices(m_total_blocks);
- indirect_sort(m_total_blocks, sorted_block_indices.data(), block_cluster_indices.data());
-
- bool status = opencl_refine_endpoint_clusterization(
- m_params.m_pOpenCL_context,
- cl_block_info_structs.data(),
- total_actual_endpoint_clusters,
- cl_endpoint_cluster_structs.data(),
- sorted_block_indices.data(),
- best_cluster_indices.data(),
- m_params.m_perceptual);
- if (status)
- {
- use_cpu = false;
- }
- else
- {
- error_printf("basisu_frontend::refine_endpoint_clusterization: opencl_refine_endpoint_clusterization() failed! Using CPU.\n");
- m_params.m_pOpenCL_context = nullptr;
- m_opencl_failed = true;
- }
- }
- if (use_cpu)
- {
- const uint32_t N = 1024;
- for (uint32_t block_index_iter = 0; block_index_iter < m_total_blocks; block_index_iter += N)
- {
- const uint32_t first_index = block_index_iter;
- const uint32_t last_index = minimum<uint32_t>(m_total_blocks, first_index + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job([this, first_index, last_index, &best_cluster_indices, &block_clusters] {
- #endif
- for (uint32_t block_index = first_index; block_index < last_index; block_index++)
- {
- const uint32_t cluster_index = block_clusters[block_index][0];
- BASISU_FRONTEND_VERIFY(cluster_index == block_clusters[block_index][1]);
- const color_rgba* pSubblock_pixels = get_source_pixel_block(block_index).get_ptr();
- const uint32_t num_subblock_pixels = 16;
- uint64_t best_cluster_err = INT64_MAX;
- uint32_t best_cluster_index = 0;
- const uint32_t block_parent_endpoint_cluster_index = m_block_parent_endpoint_cluster.size() ? m_block_parent_endpoint_cluster[block_index] : 0;
- const uint_vec* pCluster_indices = m_endpoint_clusters_within_each_parent_cluster.size() ? &m_endpoint_clusters_within_each_parent_cluster[block_parent_endpoint_cluster_index] : nullptr;
- const uint32_t total_clusters = m_use_hierarchical_endpoint_codebooks ? (uint32_t)pCluster_indices->size() : (uint32_t)m_endpoint_clusters.size();
- for (uint32_t i = 0; i < total_clusters; i++)
- {
- const uint32_t cluster_iter = m_use_hierarchical_endpoint_codebooks ? (*pCluster_indices)[i] : i;
- color_rgba cluster_etc_base_color(m_endpoint_cluster_etc_params[cluster_iter].m_color_unscaled[0]);
- uint32_t cluster_etc_inten = m_endpoint_cluster_etc_params[cluster_iter].m_inten_table[0];
- uint64_t total_err = 0;
- const uint32_t low_selector = 0;//subblock_etc_params_vec[j].m_low_selectors[0];
- const uint32_t high_selector = 3;//subblock_etc_params_vec[j].m_high_selectors[0];
- color_rgba subblock_colors[4];
- // Can't assign it here - may result in too much error when selector quant occurs
- if (cluster_etc_inten > m_endpoint_cluster_etc_params[cluster_index].m_inten_table[0])
- {
- total_err = INT64_MAX;
- goto skip_cluster;
- }
- etc_block::get_block_colors5(subblock_colors, cluster_etc_base_color, cluster_etc_inten);
- #if 0
- for (uint32_t p = 0; p < num_subblock_pixels; p++)
- {
- uint64_t best_err = UINT64_MAX;
- for (uint32_t r = low_selector; r <= high_selector; r++)
- {
- uint64_t err = color_distance(m_params.m_perceptual, pSubblock_pixels[p], subblock_colors[r], false);
- best_err = minimum(best_err, err);
- if (!best_err)
- break;
- }
- total_err += best_err;
- if (total_err > best_cluster_err)
- break;
- } // p
- #else
- if (m_params.m_perceptual)
- {
- if (!g_cpu_supports_sse41)
- {
- for (uint32_t p = 0; p < num_subblock_pixels; p++)
- {
- uint64_t best_err = UINT64_MAX;
- for (uint32_t r = low_selector; r <= high_selector; r++)
- {
- uint64_t err = color_distance(true, pSubblock_pixels[p], subblock_colors[r], false);
- best_err = minimum(best_err, err);
- if (!best_err)
- break;
- }
- total_err += best_err;
- if (total_err > best_cluster_err)
- break;
- } // p
- }
- else
- {
- #if BASISU_SUPPORT_SSE
- find_lowest_error_perceptual_rgb_4_N_sse41((int64_t*)&total_err, subblock_colors, pSubblock_pixels, num_subblock_pixels, best_cluster_err);
- #endif
- }
- }
- else
- {
- if (!g_cpu_supports_sse41)
- {
- for (uint32_t p = 0; p < num_subblock_pixels; p++)
- {
- uint64_t best_err = UINT64_MAX;
- for (uint32_t r = low_selector; r <= high_selector; r++)
- {
- uint64_t err = color_distance(false, pSubblock_pixels[p], subblock_colors[r], false);
- best_err = minimum(best_err, err);
- if (!best_err)
- break;
- }
- total_err += best_err;
- if (total_err > best_cluster_err)
- break;
- } // p
- }
- else
- {
- #if BASISU_SUPPORT_SSE
- find_lowest_error_linear_rgb_4_N_sse41((int64_t*)&total_err, subblock_colors, pSubblock_pixels, num_subblock_pixels, best_cluster_err);
- #endif
- }
- }
- #endif
- skip_cluster:
- if ((total_err < best_cluster_err) ||
- ((cluster_iter == cluster_index) && (total_err == best_cluster_err)))
- {
- best_cluster_err = total_err;
- best_cluster_index = cluster_iter;
- if (!best_cluster_err)
- break;
- }
- } // j
-
- best_cluster_indices[block_index] = best_cluster_index;
- } // block_index
- #ifndef __EMSCRIPTEN__
- });
- #endif
- } // block_index_iter
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
-
- } // use_cpu
-
- debug_printf("refine_endpoint_clusterization time: %3.3f secs\n", tm.get_elapsed_secs());
- basisu::vector<typename basisu::vector<uint32_t> > optimized_endpoint_clusters(m_endpoint_clusters.size());
- uint32_t total_subblocks_reassigned = 0;
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- const uint32_t training_vector_index = block_index * 2 + 0;
- const uint32_t orig_cluster_index = block_clusters[block_index][0];
- const uint32_t best_cluster_index = best_cluster_indices[block_index];
- optimized_endpoint_clusters[best_cluster_index].push_back(training_vector_index);
- optimized_endpoint_clusters[best_cluster_index].push_back(training_vector_index + 1);
- if (best_cluster_index != orig_cluster_index)
- {
- total_subblocks_reassigned++;
- }
- }
- debug_printf("total_subblocks_reassigned: %u\n", total_subblocks_reassigned);
- m_endpoint_clusters = optimized_endpoint_clusters;
- return total_subblocks_reassigned;
- }
- void basisu_frontend::eliminate_redundant_or_empty_endpoint_clusters()
- {
- debug_printf("eliminate_redundant_or_empty_endpoint_clusters\n");
- // Step 1: Sort endpoint clusters by the base colors/intens
- uint_vec sorted_endpoint_cluster_indices(m_endpoint_clusters.size());
- for (uint32_t i = 0; i < m_endpoint_clusters.size(); i++)
- sorted_endpoint_cluster_indices[i] = i;
- indirect_sort((uint32_t)m_endpoint_clusters.size(), &sorted_endpoint_cluster_indices[0], &m_endpoint_cluster_etc_params[0]);
- basisu::vector<basisu::vector<uint32_t> > new_endpoint_clusters(m_endpoint_clusters.size());
- basisu::vector<endpoint_cluster_etc_params> new_subblock_etc_params(m_endpoint_clusters.size());
-
- for (uint32_t i = 0; i < m_endpoint_clusters.size(); i++)
- {
- uint32_t j = sorted_endpoint_cluster_indices[i];
- new_endpoint_clusters[i] = m_endpoint_clusters[j];
- new_subblock_etc_params[i] = m_endpoint_cluster_etc_params[j];
- }
- new_endpoint_clusters.swap(m_endpoint_clusters);
- new_subblock_etc_params.swap(m_endpoint_cluster_etc_params);
- // Step 2: Eliminate redundant endpoint clusters, or empty endpoint clusters
- new_endpoint_clusters.resize(0);
- new_subblock_etc_params.resize(0);
-
- for (int i = 0; i < (int)m_endpoint_clusters.size(); )
- {
- if (!m_endpoint_clusters[i].size())
- {
- i++;
- continue;
- }
- int j;
- for (j = i + 1; j < (int)m_endpoint_clusters.size(); j++)
- {
- if (!(m_endpoint_cluster_etc_params[i] == m_endpoint_cluster_etc_params[j]))
- break;
- }
- new_endpoint_clusters.push_back(m_endpoint_clusters[i]);
- new_subblock_etc_params.push_back(m_endpoint_cluster_etc_params[i]);
-
- for (int k = i + 1; k < j; k++)
- {
- append_vector(new_endpoint_clusters.back(), m_endpoint_clusters[k]);
- }
- i = j;
- }
-
- if (m_endpoint_clusters.size() != new_endpoint_clusters.size())
- {
- if (m_params.m_debug_stats)
- debug_printf("Eliminated %u redundant or empty clusters\n", (uint32_t)(m_endpoint_clusters.size() - new_endpoint_clusters.size()));
- m_endpoint_clusters.swap(new_endpoint_clusters);
- m_endpoint_cluster_etc_params.swap(new_subblock_etc_params);
- }
- }
- void basisu_frontend::create_initial_packed_texture()
- {
- debug_printf("create_initial_packed_texture\n");
-
- interval_timer tm;
- tm.start();
- bool use_cpu = true;
- if ((m_params.m_pOpenCL_context) && (opencl_is_available()))
- {
- basisu::vector<color_rgba> block_etc5_color_intens(m_total_blocks);
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- uint32_t cluster0 = m_block_endpoint_clusters_indices[block_index][0];
-
- const color_rgba& color_unscaled = m_endpoint_cluster_etc_params[cluster0].m_color_unscaled[0];
- uint32_t inten = m_endpoint_cluster_etc_params[cluster0].m_inten_table[0];
- block_etc5_color_intens[block_index].set(color_unscaled.r, color_unscaled.g, color_unscaled.b, inten);
- }
- bool status = opencl_determine_selectors(m_params.m_pOpenCL_context, block_etc5_color_intens.data(),
- m_encoded_blocks.data(),
- m_params.m_perceptual);
- if (!status)
- {
- error_printf("basisu_frontend::create_initial_packed_texture: opencl_determine_selectors() failed! Using CPU.\n");
- m_params.m_pOpenCL_context = nullptr;
- m_opencl_failed = true;
- }
- else
- {
- use_cpu = false;
- }
- }
- if (use_cpu)
- {
- const uint32_t N = 4096;
- for (uint32_t block_index_iter = 0; block_index_iter < m_total_blocks; block_index_iter += N)
- {
- const uint32_t first_index = block_index_iter;
- const uint32_t last_index = minimum<uint32_t>(m_total_blocks, first_index + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job([this, first_index, last_index] {
- #endif
- for (uint32_t block_index = first_index; block_index < last_index; block_index++)
- {
- uint32_t cluster0 = m_block_endpoint_clusters_indices[block_index][0];
- uint32_t cluster1 = m_block_endpoint_clusters_indices[block_index][1];
- BASISU_FRONTEND_VERIFY(cluster0 == cluster1);
- const color_rgba* pSource_pixels = get_source_pixel_block(block_index).get_ptr();
- etc_block& blk = m_encoded_blocks[block_index];
- color_rgba unscaled[2] = { m_endpoint_cluster_etc_params[cluster0].m_color_unscaled[0], m_endpoint_cluster_etc_params[cluster1].m_color_unscaled[0] };
- uint32_t inten[2] = { m_endpoint_cluster_etc_params[cluster0].m_inten_table[0], m_endpoint_cluster_etc_params[cluster1].m_inten_table[0] };
- blk.set_block_color5(unscaled[0], unscaled[1]);
- blk.set_flip_bit(true);
- blk.set_inten_table(0, inten[0]);
- blk.set_inten_table(1, inten[1]);
- blk.determine_selectors(pSource_pixels, m_params.m_perceptual);
- } // block_index
- #ifndef __EMSCRIPTEN__
- });
- #endif
- } // block_index_iter
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
- } // use_cpu
-
- m_orig_encoded_blocks = m_encoded_blocks;
- debug_printf("Elapsed time: %3.3f secs\n", tm.get_elapsed_secs());
- }
- void basisu_frontend::compute_selector_clusters_within_each_parent_cluster()
- {
- uint_vec block_selector_cluster_indices(m_total_blocks);
- for (int cluster_index = 0; cluster_index < static_cast<int>(m_selector_cluster_block_indices.size()); cluster_index++)
- {
- const basisu::vector<uint32_t>& cluster_indices = m_selector_cluster_block_indices[cluster_index];
- for (uint32_t cluster_indices_iter = 0; cluster_indices_iter < cluster_indices.size(); cluster_indices_iter++)
- {
- const uint32_t block_index = cluster_indices[cluster_indices_iter];
-
- block_selector_cluster_indices[block_index] = cluster_index;
- } // cluster_indices_iter
- } // cluster_index
- m_selector_clusters_within_each_parent_cluster.resize(0);
- m_selector_clusters_within_each_parent_cluster.resize(m_selector_parent_cluster_block_indices.size());
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- const uint32_t cluster_index = block_selector_cluster_indices[block_index];
- const uint32_t parent_cluster_index = m_block_parent_selector_cluster[block_index];
- m_selector_clusters_within_each_parent_cluster[parent_cluster_index].push_back(cluster_index);
- }
- for (uint32_t i = 0; i < m_selector_clusters_within_each_parent_cluster.size(); i++)
- {
- uint_vec &cluster_indices = m_selector_clusters_within_each_parent_cluster[i];
- BASISU_FRONTEND_VERIFY(cluster_indices.size());
- vector_sort(cluster_indices);
-
- auto last = std::unique(cluster_indices.begin(), cluster_indices.end());
- cluster_indices.erase(last, cluster_indices.end());
- }
- }
- void basisu_frontend::generate_selector_clusters()
- {
- debug_printf("generate_selector_clusters\n");
-
- typedef tree_vector_quant<vec16F> vec16F_clusterizer;
-
- vec16F_clusterizer::array_of_weighted_training_vecs training_vecs(m_total_blocks);
-
- const uint32_t N = 4096;
- for (uint32_t block_index_iter = 0; block_index_iter < m_total_blocks; block_index_iter += N)
- {
- const uint32_t first_index = block_index_iter;
- const uint32_t last_index = minimum<uint32_t>(m_total_blocks, first_index + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job( [this, first_index, last_index, &training_vecs] {
- #endif
- for (uint32_t block_index = first_index; block_index < last_index; block_index++)
- {
- const etc_block &blk = m_encoded_blocks[block_index];
- vec16F v;
- for (uint32_t y = 0; y < 4; y++)
- for (uint32_t x = 0; x < 4; x++)
- v[x + y * 4] = static_cast<float>(blk.get_selector(x, y));
- const uint32_t subblock_index = (blk.get_inten_table(0) > blk.get_inten_table(1)) ? 0 : 1;
- color_rgba block_colors[2];
- blk.get_block_low_high_colors(block_colors, subblock_index);
- const uint32_t dist = color_distance(m_params.m_perceptual, block_colors[0], block_colors[1], false);
- const uint32_t cColorDistToWeight = 300;
- const uint32_t cMaxWeight = 4096;
- uint32_t weight = clamp<uint32_t>(dist / cColorDistToWeight, 1, cMaxWeight);
-
- training_vecs[block_index].first = v;
- training_vecs[block_index].second = weight;
-
- } // block_index
- #ifndef __EMSCRIPTEN__
- } );
- #endif
- } // block_index_iter
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
- vec16F_clusterizer selector_clusterizer;
- for (uint32_t i = 0; i < m_total_blocks; i++)
- selector_clusterizer.add_training_vec(training_vecs[i].first, training_vecs[i].second);
- const int selector_parent_codebook_size = (m_params.m_compression_level <= 1) ? BASISU_SELECTOR_PARENT_CODEBOOK_SIZE_COMP_LEVEL_01 : BASISU_SELECTOR_PARENT_CODEBOOK_SIZE_COMP_LEVEL_DEFAULT;
- const uint32_t parent_codebook_size = (m_params.m_max_selector_clusters >= 256) ? selector_parent_codebook_size : 0;
- debug_printf("Using selector parent codebook size %u\n", parent_codebook_size);
- uint32_t max_threads = 0;
- max_threads = m_params.m_multithreaded ? minimum<int>(std::thread::hardware_concurrency(), cMaxCodebookCreationThreads) : 0;
- if (m_params.m_pJob_pool)
- max_threads = minimum<int>((int)m_params.m_pJob_pool->get_total_threads(), max_threads);
- bool status = generate_hierarchical_codebook_threaded(selector_clusterizer,
- m_params.m_max_selector_clusters, m_use_hierarchical_selector_codebooks ? parent_codebook_size : 0,
- m_selector_cluster_block_indices,
- m_selector_parent_cluster_block_indices,
- max_threads, m_params.m_pJob_pool, false);
- BASISU_FRONTEND_VERIFY(status);
- if (m_use_hierarchical_selector_codebooks)
- {
- if (!m_selector_parent_cluster_block_indices.size())
- {
- m_selector_parent_cluster_block_indices.resize(0);
- m_selector_parent_cluster_block_indices.resize(1);
- for (uint32_t i = 0; i < m_total_blocks; i++)
- m_selector_parent_cluster_block_indices[0].push_back(i);
- }
- BASISU_ASSUME(BASISU_SELECTOR_PARENT_CODEBOOK_SIZE_COMP_LEVEL_01 <= UINT8_MAX);
- BASISU_ASSUME(BASISU_SELECTOR_PARENT_CODEBOOK_SIZE_COMP_LEVEL_DEFAULT <= UINT8_MAX);
- m_block_parent_selector_cluster.resize(0);
- m_block_parent_selector_cluster.resize(m_total_blocks);
- vector_set_all(m_block_parent_selector_cluster, 0xFF);
- for (uint32_t parent_cluster_index = 0; parent_cluster_index < m_selector_parent_cluster_block_indices.size(); parent_cluster_index++)
- {
- const uint_vec &cluster = m_selector_parent_cluster_block_indices[parent_cluster_index];
- for (uint32_t j = 0; j < cluster.size(); j++)
- m_block_parent_selector_cluster[cluster[j]] = static_cast<uint8_t>(parent_cluster_index);
- }
- for (uint32_t i = 0; i < m_total_blocks; i++)
- {
- BASISU_FRONTEND_VERIFY(m_block_parent_selector_cluster[i] != 0xFF);
- }
- // Ensure that all the blocks within each cluster are all in the same parent cluster, or something is very wrong.
- for (uint32_t cluster_index = 0; cluster_index < m_selector_cluster_block_indices.size(); cluster_index++)
- {
- const uint_vec &cluster = m_selector_cluster_block_indices[cluster_index];
-
- uint32_t parent_cluster_index = 0;
- for (uint32_t j = 0; j < cluster.size(); j++)
- {
- const uint32_t block_index = cluster[j];
- if (!j)
- {
- parent_cluster_index = m_block_parent_selector_cluster[block_index];
- }
- else
- {
- BASISU_FRONTEND_VERIFY(m_block_parent_selector_cluster[block_index] == parent_cluster_index);
- }
- }
- }
- }
- debug_printf("Total selector clusters: %u, total parent selector clusters: %u\n", (uint32_t)m_selector_cluster_block_indices.size(), (uint32_t)m_selector_parent_cluster_block_indices.size());
- }
- void basisu_frontend::create_optimized_selector_codebook(uint32_t iter)
- {
- debug_printf("create_optimized_selector_codebook\n");
- interval_timer tm;
- tm.start();
- const uint32_t total_selector_clusters = (uint32_t)m_selector_cluster_block_indices.size();
- debug_printf("Total selector clusters (from m_selector_cluster_block_indices.size()): %u\n", (uint32_t)m_selector_cluster_block_indices.size());
- m_optimized_cluster_selectors.resize(total_selector_clusters);
-
- // For each selector codebook entry, and for each of the 4x4 selectors, determine which selector minimizes the error across all the blocks that use that quantized selector.
- const uint32_t N = 256;
- for (uint32_t cluster_index_iter = 0; cluster_index_iter < total_selector_clusters; cluster_index_iter += N)
- {
- const uint32_t first_index = cluster_index_iter;
- const uint32_t last_index = minimum<uint32_t>((uint32_t)total_selector_clusters, cluster_index_iter + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job([this, first_index, last_index] {
- #endif
- for (uint32_t cluster_index = first_index; cluster_index < last_index; cluster_index++)
- {
- const basisu::vector<uint32_t>& cluster_block_indices = m_selector_cluster_block_indices[cluster_index];
- if (!cluster_block_indices.size())
- continue;
- uint64_t overall_best_err = 0;
- uint64_t total_err[4][4][4];
- clear_obj(total_err);
- for (uint32_t cluster_block_index = 0; cluster_block_index < cluster_block_indices.size(); cluster_block_index++)
- {
- const uint32_t block_index = cluster_block_indices[cluster_block_index];
- const etc_block& blk = m_encoded_blocks[block_index];
- color_rgba blk_colors[4];
- blk.get_block_colors(blk_colors, 0);
- for (uint32_t y = 0; y < 4; y++)
- {
- for (uint32_t x = 0; x < 4; x++)
- {
- const color_rgba& orig_color = get_source_pixel_block(block_index)(x, y);
- if (m_params.m_perceptual)
- {
- for (uint32_t s = 0; s < 4; s++)
- total_err[y][x][s] += color_distance(true, blk_colors[s], orig_color, false);
- }
- else
- {
- for (uint32_t s = 0; s < 4; s++)
- total_err[y][x][s] += color_distance(false, blk_colors[s], orig_color, false);
- }
- } // x
- } // y
- } // cluster_block_index
- for (uint32_t y = 0; y < 4; y++)
- {
- for (uint32_t x = 0; x < 4; x++)
- {
- uint64_t best_err = total_err[y][x][0];
- uint8_t best_sel = 0;
- for (uint32_t s = 1; s < 4; s++)
- {
- if (total_err[y][x][s] < best_err)
- {
- best_err = total_err[y][x][s];
- best_sel = (uint8_t)s;
- }
- }
- m_optimized_cluster_selectors[cluster_index].set_selector(x, y, best_sel);
- overall_best_err += best_err;
- } // x
- } // y
- } // cluster_index
- #ifndef __EMSCRIPTEN__
- });
- #endif
- } // cluster_index_iter
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
- debug_printf("Elapsed time: %3.3f secs\n", tm.get_elapsed_secs());
-
- if (m_params.m_debug_images)
- {
- uint32_t max_selector_cluster_size = 0;
- for (uint32_t i = 0; i < m_selector_cluster_block_indices.size(); i++)
- max_selector_cluster_size = maximum<uint32_t>(max_selector_cluster_size, (uint32_t)m_selector_cluster_block_indices[i].size());
- if ((max_selector_cluster_size * 5) < 32768)
- {
- const uint32_t x_spacer_len = 16;
- image selector_cluster_vis(x_spacer_len + max_selector_cluster_size * 5, (uint32_t)m_selector_cluster_block_indices.size() * 5);
- for (uint32_t selector_cluster_index = 0; selector_cluster_index < m_selector_cluster_block_indices.size(); selector_cluster_index++)
- {
- const basisu::vector<uint32_t> &cluster_block_indices = m_selector_cluster_block_indices[selector_cluster_index];
- for (uint32_t y = 0; y < 4; y++)
- for (uint32_t x = 0; x < 4; x++)
- selector_cluster_vis.set_clipped(x_spacer_len + x - 12, selector_cluster_index * 5 + y, color_rgba((m_optimized_cluster_selectors[selector_cluster_index].get_selector(x, y) * 255) / 3));
- for (uint32_t i = 0; i < cluster_block_indices.size(); i++)
- {
- uint32_t block_index = cluster_block_indices[i];
- const etc_block &blk = m_orig_encoded_blocks[block_index];
-
- for (uint32_t y = 0; y < 4; y++)
- for (uint32_t x = 0; x < 4; x++)
- selector_cluster_vis.set_clipped(x_spacer_len + x + 5 * i, selector_cluster_index * 5 + y, color_rgba((blk.get_selector(x, y) * 255) / 3));
- }
- }
- char buf[256];
- snprintf(buf, sizeof(buf), "selector_cluster_vis_%u.png", iter);
- save_png(buf, selector_cluster_vis);
- }
- }
- }
- // For each block: Determine which quantized selectors best encode that block, given its quantized endpoints.
- // Note that this method may leave some empty clusters (i.e. arrays with no block indices), including at the end.
- void basisu_frontend::find_optimal_selector_clusters_for_each_block()
- {
- debug_printf("find_optimal_selector_clusters_for_each_block\n");
- interval_timer tm;
- tm.start();
-
- if (m_params.m_validate)
- {
- // Sanity checks
- BASISU_FRONTEND_VERIFY(m_selector_cluster_block_indices.size() == m_optimized_cluster_selectors.size());
- for (uint32_t i = 0; i < m_selector_clusters_within_each_parent_cluster.size(); i++)
- {
- for (uint32_t j = 0; j < m_selector_clusters_within_each_parent_cluster[i].size(); j++)
- {
- BASISU_FRONTEND_VERIFY(m_selector_clusters_within_each_parent_cluster[i][j] < m_optimized_cluster_selectors.size());
- }
- }
- }
- m_block_selector_cluster_index.resize(m_total_blocks);
-
- if (m_params.m_compression_level == 0)
- {
- // Just leave the blocks in their original selector clusters.
- for (uint32_t selector_cluster_index = 0; selector_cluster_index < m_selector_cluster_block_indices.size(); selector_cluster_index++)
- {
- for (uint32_t j = 0; j < m_selector_cluster_block_indices[selector_cluster_index].size(); j++)
- {
- const uint32_t block_index = m_selector_cluster_block_indices[selector_cluster_index][j];
- m_block_selector_cluster_index[block_index] = selector_cluster_index;
- etc_block& blk = m_encoded_blocks[block_index];
- blk.set_raw_selector_bits(m_optimized_cluster_selectors[selector_cluster_index].get_raw_selector_bits());
- }
- }
- debug_printf("Elapsed time: %3.3f secs\n", tm.get_elapsed_secs());
- return;
- }
-
- bool use_cpu = true;
- if ((m_params.m_pOpenCL_context) && m_use_hierarchical_selector_codebooks)
- {
- const uint32_t num_parent_clusters = m_selector_clusters_within_each_parent_cluster.size();
- basisu::vector<fosc_selector_struct> selector_structs;
- selector_structs.reserve(m_optimized_cluster_selectors.size());
-
- uint_vec parent_selector_cluster_offsets(num_parent_clusters);
- uint_vec selector_cluster_indices;
- selector_cluster_indices.reserve(m_optimized_cluster_selectors.size());
-
- uint32_t cur_ofs = 0;
- for (uint32_t parent_index = 0; parent_index < num_parent_clusters; parent_index++)
- {
- parent_selector_cluster_offsets[parent_index] = cur_ofs;
-
- for (uint32_t j = 0; j < m_selector_clusters_within_each_parent_cluster[parent_index].size(); j++)
- {
- const uint32_t selector_cluster_index = m_selector_clusters_within_each_parent_cluster[parent_index][j];
- uint32_t sel_bits = 0;
- for (uint32_t p = 0; p < 16; p++)
- sel_bits |= (m_optimized_cluster_selectors[selector_cluster_index].get_selector(p & 3, p >> 2) << (p * 2));
- selector_structs.enlarge(1)->m_packed_selectors = sel_bits;
-
- selector_cluster_indices.push_back(selector_cluster_index);
- }
- cur_ofs += m_selector_clusters_within_each_parent_cluster[parent_index].size();
- }
- const uint32_t total_input_selectors = cur_ofs;
-
- basisu::vector<fosc_block_struct> block_structs(m_total_blocks);
- for (uint32_t i = 0; i < m_total_blocks; i++)
- {
- const uint32_t parent_selector_cluster = m_block_parent_selector_cluster[i];
- const etc_block& blk = m_encoded_blocks[i];
- blk.unpack_color5(block_structs[i].m_etc_color5_inten, blk.get_base5_color(), false);
- block_structs[i].m_etc_color5_inten.a = (uint8_t)blk.get_inten_table(0);
- block_structs[i].m_first_selector = parent_selector_cluster_offsets[parent_selector_cluster];
- block_structs[i].m_num_selectors = m_selector_clusters_within_each_parent_cluster[parent_selector_cluster].size();
- }
- uint_vec output_selector_cluster_indices(m_total_blocks);
- bool status = opencl_find_optimal_selector_clusters_for_each_block(
- m_params.m_pOpenCL_context,
- block_structs.data(),
- total_input_selectors,
- selector_structs.data(),
- selector_cluster_indices.data(),
- output_selector_cluster_indices.data(),
- m_params.m_perceptual);
-
- if (!status)
- {
- error_printf("basisu_frontend::find_optimal_selector_clusters_for_each_block: opencl_find_optimal_selector_clusters_for_each_block() failed! Using CPU.\n");
- m_params.m_pOpenCL_context = nullptr;
- m_opencl_failed = true;
- }
- else
- {
- for (uint32_t i = 0; i < m_selector_cluster_block_indices.size(); i++)
- {
- m_selector_cluster_block_indices[i].resize(0);
- m_selector_cluster_block_indices[i].reserve(128);
- }
-
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- etc_block& blk = m_encoded_blocks[block_index];
- uint32_t best_cluster_index = output_selector_cluster_indices[block_index];
- blk.set_raw_selector_bits(m_optimized_cluster_selectors[best_cluster_index].get_raw_selector_bits());
- m_block_selector_cluster_index[block_index] = best_cluster_index;
- vector_ensure_element_is_valid(m_selector_cluster_block_indices, best_cluster_index);
- m_selector_cluster_block_indices[best_cluster_index].push_back(block_index);
- }
- use_cpu = false;
- }
- }
- if (use_cpu)
- {
- basisu::vector<uint8_t> unpacked_optimized_cluster_selectors(16 * m_optimized_cluster_selectors.size());
- for (uint32_t cluster_index = 0; cluster_index < m_optimized_cluster_selectors.size(); cluster_index++)
- {
- for (uint32_t y = 0; y < 4; y++)
- {
- for (uint32_t x = 0; x < 4; x++)
- {
- unpacked_optimized_cluster_selectors[cluster_index * 16 + y * 4 + x] = (uint8_t)m_optimized_cluster_selectors[cluster_index].get_selector(x, y);
- }
- }
- }
-
- const uint32_t N = 2048;
- for (uint32_t block_index_iter = 0; block_index_iter < m_total_blocks; block_index_iter += N)
- {
- const uint32_t first_index = block_index_iter;
- const uint32_t last_index = minimum<uint32_t>(m_total_blocks, first_index + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job( [this, first_index, last_index, &unpacked_optimized_cluster_selectors] {
- #endif
- int prev_best_cluster_index = 0;
- for (uint32_t block_index = first_index; block_index < last_index; block_index++)
- {
- const pixel_block& block = get_source_pixel_block(block_index);
-
- etc_block& blk = m_encoded_blocks[block_index];
- if ((block_index > first_index) && (block == get_source_pixel_block(block_index - 1)))
- {
- blk.set_raw_selector_bits(m_optimized_cluster_selectors[prev_best_cluster_index].get_raw_selector_bits());
- m_block_selector_cluster_index[block_index] = prev_best_cluster_index;
-
- continue;
- }
-
- const color_rgba* pBlock_pixels = block.get_ptr();
-
- color_rgba trial_block_colors[4];
- blk.get_block_colors_etc1s(trial_block_colors);
- // precompute errors for the i-th block pixel and selector sel: [sel][i]
- uint32_t trial_errors[4][16];
-
- if (m_params.m_perceptual)
- {
- for (uint32_t sel = 0; sel < 4; ++sel)
- for (uint32_t i = 0; i < 16; ++i)
- trial_errors[sel][i] = color_distance(true, pBlock_pixels[i], trial_block_colors[sel], false);
- }
- else
- {
- for (uint32_t sel = 0; sel < 4; ++sel)
- for (uint32_t i = 0; i < 16; ++i)
- trial_errors[sel][i] = color_distance(false, pBlock_pixels[i], trial_block_colors[sel], false);
- }
- // Compute the minimum possible errors (given any selectors) for pixels 0-15
- uint64_t min_possible_error_0_15 = 0;
- for (uint32_t i = 0; i < 16; i++)
- min_possible_error_0_15 += basisu::minimum(trial_errors[0][i], trial_errors[1][i], trial_errors[2][i], trial_errors[3][i]);
- // Compute the minimum possible errors (given any selectors) for pixels 4-15
- uint64_t min_possible_error_4_15 = 0;
- for (uint32_t i = 4; i < 16; i++)
- min_possible_error_4_15 += basisu::minimum(trial_errors[0][i], trial_errors[1][i], trial_errors[2][i], trial_errors[3][i]);
- // Compute the minimum possible errors (given any selectors) for pixels 8-15
- uint64_t min_possible_error_8_15 = 0;
- for (uint32_t i = 8; i < 16; i++)
- min_possible_error_8_15 += basisu::minimum(trial_errors[0][i], trial_errors[1][i], trial_errors[2][i], trial_errors[3][i]);
- // Compute the minimum possible errors (given any selectors) for pixels 12-15
- uint64_t min_possible_error_12_15 = 0;
- for (uint32_t i = 12; i < 16; i++)
- min_possible_error_12_15 += basisu::minimum(trial_errors[0][i], trial_errors[1][i], trial_errors[2][i], trial_errors[3][i]);
- uint64_t best_cluster_err = INT64_MAX;
- uint32_t best_cluster_index = 0;
- const uint32_t parent_selector_cluster = m_block_parent_selector_cluster.size() ? m_block_parent_selector_cluster[block_index] : 0;
- const uint_vec *pCluster_indices = m_selector_clusters_within_each_parent_cluster.size() ? &m_selector_clusters_within_each_parent_cluster[parent_selector_cluster] : nullptr;
- const uint32_t total_clusters = m_use_hierarchical_selector_codebooks ? (uint32_t)pCluster_indices->size() : (uint32_t)m_selector_cluster_block_indices.size();
- #if 0
- for (uint32_t cluster_iter = 0; cluster_iter < total_clusters; cluster_iter++)
- {
- const uint32_t cluster_index = m_use_hierarchical_selector_codebooks ? (*pCluster_indices)[cluster_iter] : cluster_iter;
- const etc_block& cluster_blk = m_optimized_cluster_selectors[cluster_index];
- uint64_t trial_err = 0;
- for (int y = 0; y < 4; y++)
- {
- for (int x = 0; x < 4; x++)
- {
- const uint32_t sel = cluster_blk.get_selector(x, y);
- trial_err += color_distance(m_params.m_perceptual, trial_block_colors[sel], pBlock_pixels[x + y * 4], false);
- if (trial_err > best_cluster_err)
- goto early_out;
- }
- }
- if (trial_err < best_cluster_err)
- {
- best_cluster_err = trial_err;
- best_cluster_index = cluster_index;
- if (!best_cluster_err)
- break;
- }
- early_out:
- ;
- }
- #else
- for (uint32_t cluster_iter = 0; cluster_iter < total_clusters; cluster_iter++)
- {
- const uint32_t cluster_index = m_use_hierarchical_selector_codebooks ? (*pCluster_indices)[cluster_iter] : cluster_iter;
-
- const uint8_t* pSels = &unpacked_optimized_cluster_selectors[cluster_index * 16];
- uint64_t trial_err = (uint64_t)trial_errors[pSels[0]][0] + trial_errors[pSels[1]][1] + trial_errors[pSels[2]][2] + trial_errors[pSels[3]][3];
- if ((trial_err + min_possible_error_4_15) >= best_cluster_err)
- continue;
- trial_err += (uint64_t)trial_errors[pSels[4]][4] + trial_errors[pSels[5]][5] + trial_errors[pSels[6]][6] + trial_errors[pSels[7]][7];
- if ((trial_err + min_possible_error_8_15) >= best_cluster_err)
- continue;
- trial_err += (uint64_t)trial_errors[pSels[8]][8] + trial_errors[pSels[9]][9] + trial_errors[pSels[10]][10] + trial_errors[pSels[11]][11];
- if ((trial_err + min_possible_error_12_15) >= best_cluster_err)
- continue;
- trial_err += (uint64_t)trial_errors[pSels[12]][12] + trial_errors[pSels[13]][13] + trial_errors[pSels[14]][14] + trial_errors[pSels[15]][15];
- if (trial_err < best_cluster_err)
- {
- best_cluster_err = trial_err;
- best_cluster_index = cluster_index;
- if (best_cluster_err == min_possible_error_0_15)
- break;
- }
- } // cluster_iter
- #endif
- blk.set_raw_selector_bits(m_optimized_cluster_selectors[best_cluster_index].get_raw_selector_bits());
- m_block_selector_cluster_index[block_index] = best_cluster_index;
- prev_best_cluster_index = best_cluster_index;
-
- } // block_index
- #ifndef __EMSCRIPTEN__
- } );
- #endif
- } // block_index_iter
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
-
- for (uint32_t i = 0; i < m_selector_cluster_block_indices.size(); i++)
- {
- m_selector_cluster_block_indices[i].resize(0);
- m_selector_cluster_block_indices[i].reserve(128);
- }
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- const uint32_t best_cluster_index = m_block_selector_cluster_index[block_index];
- vector_ensure_element_is_valid(m_selector_cluster_block_indices, best_cluster_index);
- m_selector_cluster_block_indices[best_cluster_index].push_back(block_index);
- }
-
- } // if (use_cpu)
- debug_printf("Elapsed time: %3.3f secs\n", tm.get_elapsed_secs());
- }
- // TODO: Remove old ETC1 specific stuff, and thread this.
- uint32_t basisu_frontend::refine_block_endpoints_given_selectors()
- {
- debug_printf("refine_block_endpoints_given_selectors\n");
-
- for (int block_index = 0; block_index < static_cast<int>(m_total_blocks); block_index++)
- {
- //uint32_t selector_cluster = m_block_selector_cluster_index(block_x, block_y);
- vec2U &endpoint_clusters = m_block_endpoint_clusters_indices[block_index];
- m_endpoint_cluster_etc_params[endpoint_clusters[0]].m_subblocks.push_back(block_index * 2);
- m_endpoint_cluster_etc_params[endpoint_clusters[1]].m_subblocks.push_back(block_index * 2 + 1);
- }
- uint32_t total_subblocks_refined = 0;
- uint32_t total_subblocks_examined = 0;
- for (uint32_t endpoint_cluster_index = 0; endpoint_cluster_index < m_endpoint_cluster_etc_params.size(); endpoint_cluster_index++)
- {
- endpoint_cluster_etc_params &subblock_params = m_endpoint_cluster_etc_params[endpoint_cluster_index];
- const uint_vec &subblocks = subblock_params.m_subblocks;
- //uint32_t total_pixels = subblock.m_subblocks.size() * 8;
- basisu::vector<color_rgba> subblock_colors[2]; // [use_individual_mode]
- uint8_vec subblock_selectors[2];
- uint64_t cur_subblock_err[2] = { 0, 0 };
- for (uint32_t subblock_iter = 0; subblock_iter < subblocks.size(); subblock_iter++)
- {
- uint32_t training_vector_index = subblocks[subblock_iter];
- uint32_t block_index = training_vector_index >> 1;
- uint32_t subblock_index = training_vector_index & 1;
- const bool is_flipped = true;
- const etc_block &blk = m_encoded_blocks[block_index];
- const bool use_individual_mode = !blk.get_diff_bit();
- const color_rgba *pSource_block_pixels = get_source_pixel_block(block_index).get_ptr();
- color_rgba unpacked_block_pixels[16];
- unpack_etc1(blk, unpacked_block_pixels);
- for (uint32_t i = 0; i < 8; i++)
- {
- const uint32_t pixel_index = g_etc1_pixel_indices[is_flipped][subblock_index][i];
- const etc_coord2 &coords = g_etc1_pixel_coords[is_flipped][subblock_index][i];
- subblock_colors[use_individual_mode].push_back(pSource_block_pixels[pixel_index]);
- cur_subblock_err[use_individual_mode] += color_distance(m_params.m_perceptual, pSource_block_pixels[pixel_index], unpacked_block_pixels[pixel_index], false);
- subblock_selectors[use_individual_mode].push_back(static_cast<uint8_t>(blk.get_selector(coords.m_x, coords.m_y)));
- }
- } // subblock_iter
- etc1_optimizer::results cluster_optimizer_results[2];
- bool results_valid[2] = { false, false };
- clear_obj(cluster_optimizer_results);
- basisu::vector<uint8_t> cluster_selectors[2];
- for (uint32_t use_individual_mode = 0; use_individual_mode < 2; use_individual_mode++)
- {
- const uint32_t total_pixels = (uint32_t)subblock_colors[use_individual_mode].size();
- if (!total_pixels)
- continue;
- total_subblocks_examined += total_pixels / 8;
- etc1_optimizer optimizer;
- etc1_solution_coordinates solutions[2];
- etc1_optimizer::params cluster_optimizer_params;
- cluster_optimizer_params.m_num_src_pixels = total_pixels;
- cluster_optimizer_params.m_pSrc_pixels = &subblock_colors[use_individual_mode][0];
- cluster_optimizer_params.m_use_color4 = use_individual_mode != 0;
- cluster_optimizer_params.m_perceptual = m_params.m_perceptual;
- cluster_optimizer_params.m_pForce_selectors = &subblock_selectors[use_individual_mode][0];
- cluster_optimizer_params.m_quality = cETCQualityUber;
- cluster_selectors[use_individual_mode].resize(total_pixels);
- cluster_optimizer_results[use_individual_mode].m_n = total_pixels;
- cluster_optimizer_results[use_individual_mode].m_pSelectors = &cluster_selectors[use_individual_mode][0];
- optimizer.init(cluster_optimizer_params, cluster_optimizer_results[use_individual_mode]);
- if (!optimizer.compute())
- continue;
- if (cluster_optimizer_results[use_individual_mode].m_error < cur_subblock_err[use_individual_mode])
- results_valid[use_individual_mode] = true;
- } // use_individual_mode
- for (uint32_t use_individual_mode = 0; use_individual_mode < 2; use_individual_mode++)
- {
- if (!results_valid[use_individual_mode])
- continue;
- uint32_t num_passes = use_individual_mode ? 1 : 2;
- bool all_passed5 = true;
- for (uint32_t pass = 0; pass < num_passes; pass++)
- {
- for (uint32_t subblock_iter = 0; subblock_iter < subblocks.size(); subblock_iter++)
- {
- const uint32_t training_vector_index = subblocks[subblock_iter];
- const uint32_t block_index = training_vector_index >> 1;
- const uint32_t subblock_index = training_vector_index & 1;
- //const bool is_flipped = true;
- etc_block &blk = m_encoded_blocks[block_index];
- if (!blk.get_diff_bit() != static_cast<bool>(use_individual_mode != 0))
- continue;
- if (use_individual_mode)
- {
- blk.set_base4_color(subblock_index, etc_block::pack_color4(cluster_optimizer_results[1].m_block_color_unscaled, false));
- blk.set_inten_table(subblock_index, cluster_optimizer_results[1].m_block_inten_table);
- subblock_params.m_color_error[1] = cluster_optimizer_results[1].m_error;
- subblock_params.m_inten_table[1] = cluster_optimizer_results[1].m_block_inten_table;
- subblock_params.m_color_unscaled[1] = cluster_optimizer_results[1].m_block_color_unscaled;
- total_subblocks_refined++;
- }
- else
- {
- const uint16_t base_color5 = blk.get_base5_color();
- const uint16_t delta_color3 = blk.get_delta3_color();
- uint32_t r[2], g[2], b[2];
- etc_block::unpack_color5(r[0], g[0], b[0], base_color5, false);
- bool success = etc_block::unpack_color5(r[1], g[1], b[1], base_color5, delta_color3, false);
- assert(success);
- BASISU_NOTE_UNUSED(success);
- r[subblock_index] = cluster_optimizer_results[0].m_block_color_unscaled.r;
- g[subblock_index] = cluster_optimizer_results[0].m_block_color_unscaled.g;
- b[subblock_index] = cluster_optimizer_results[0].m_block_color_unscaled.b;
- color_rgba colors[2] = { color_rgba(r[0], g[0], b[0], 255), color_rgba(r[1], g[1], b[1], 255) };
- if (!etc_block::try_pack_color5_delta3(colors))
- {
- all_passed5 = false;
- break;
- }
- if ((pass == 1) && (all_passed5))
- {
- blk.set_block_color5(colors[0], colors[1]);
- blk.set_inten_table(subblock_index, cluster_optimizer_results[0].m_block_inten_table);
- subblock_params.m_color_error[0] = cluster_optimizer_results[0].m_error;
- subblock_params.m_inten_table[0] = cluster_optimizer_results[0].m_block_inten_table;
- subblock_params.m_color_unscaled[0] = cluster_optimizer_results[0].m_block_color_unscaled;
- total_subblocks_refined++;
- }
- }
- } // subblock_iter
- } // pass
- } // use_individual_mode
- } // endpoint_cluster_index
- if (m_params.m_debug_stats)
- debug_printf("Total subblock endpoints refined: %u (%3.1f%%)\n", total_subblocks_refined, total_subblocks_refined * 100.0f / total_subblocks_examined);
-
- return total_subblocks_refined;
- }
- void basisu_frontend::dump_endpoint_clusterization_visualization(const char *pFilename, bool vis_endpoint_colors)
- {
- debug_printf("dump_endpoint_clusterization_visualization\n");
- uint32_t max_endpoint_cluster_size = 0;
- basisu::vector<uint32_t> cluster_sizes(m_endpoint_clusters.size());
- basisu::vector<uint32_t> sorted_cluster_indices(m_endpoint_clusters.size());
- for (uint32_t i = 0; i < m_endpoint_clusters.size(); i++)
- {
- max_endpoint_cluster_size = maximum<uint32_t>(max_endpoint_cluster_size, (uint32_t)m_endpoint_clusters[i].size());
- cluster_sizes[i] = (uint32_t)m_endpoint_clusters[i].size();
- }
- if (!max_endpoint_cluster_size)
- return;
- for (uint32_t i = 0; i < m_endpoint_clusters.size(); i++)
- sorted_cluster_indices[i] = i;
- //indexed_heap_sort(endpoint_clusters.size(), cluster_sizes.get_ptr(), sorted_cluster_indices.get_ptr());
- image endpoint_cluster_vis(12 + minimum<uint32_t>(max_endpoint_cluster_size, 2048) * 5, (uint32_t)m_endpoint_clusters.size() * 3);
- for (uint32_t unsorted_cluster_iter = 0; unsorted_cluster_iter < m_endpoint_clusters.size(); unsorted_cluster_iter++)
- {
- const uint32_t cluster_iter = sorted_cluster_indices[unsorted_cluster_iter];
- etc_block blk;
- blk.clear();
- blk.set_flip_bit(false);
- blk.set_diff_bit(true);
- blk.set_inten_tables_etc1s(m_endpoint_cluster_etc_params[cluster_iter].m_inten_table[0]);
- blk.set_base5_color(etc_block::pack_color5(m_endpoint_cluster_etc_params[cluster_iter].m_color_unscaled[0], false));
- color_rgba blk_colors[4];
- blk.get_block_colors(blk_colors, 0);
- for (uint32_t i = 0; i < 4; i++)
- endpoint_cluster_vis.fill_box(i * 2, 3 * unsorted_cluster_iter, 2, 2, blk_colors[i]);
- for (uint32_t subblock_iter = 0; subblock_iter < m_endpoint_clusters[cluster_iter].size(); subblock_iter++)
- {
- uint32_t training_vector_index = m_endpoint_clusters[cluster_iter][subblock_iter];
- const uint32_t block_index = training_vector_index >> 1;
- const uint32_t subblock_index = training_vector_index & 1;
- const etc_block& blk2 = m_etc1_blocks_etc1s[block_index];
- const color_rgba *pBlock_pixels = get_source_pixel_block(block_index).get_ptr();
- color_rgba subblock_pixels[8];
- if (vis_endpoint_colors)
- {
- color_rgba colors[2];
- blk2.get_block_low_high_colors(colors, subblock_index);
- for (uint32_t i = 0; i < 8; i++)
- subblock_pixels[i] = colors[subblock_index];
- }
- else
- {
- for (uint32_t i = 0; i < 8; i++)
- subblock_pixels[i] = pBlock_pixels[g_etc1_pixel_indices[blk2.get_flip_bit()][subblock_index][i]];
- }
- endpoint_cluster_vis.set_block_clipped(subblock_pixels, 12 + 5 * subblock_iter, 3 * unsorted_cluster_iter, 4, 2);
- }
- }
- save_png(pFilename, endpoint_cluster_vis);
- debug_printf("Wrote debug visualization file %s\n", pFilename);
- }
- void basisu_frontend::finalize()
- {
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- for (uint32_t subblock_index = 0; subblock_index < 2; subblock_index++)
- {
- const uint32_t endpoint_cluster_index = get_subblock_endpoint_cluster_index(block_index, subblock_index);
- m_endpoint_cluster_etc_params[endpoint_cluster_index].m_color_used[0] = true;
- }
- }
- }
- // The backend has remapped the block endpoints while optimizing the output symbols for better rate distortion performance, so let's go and reoptimize the endpoint codebook.
- // This is currently the only place where the backend actually goes and changes the quantization and calls the frontend to fix things up.
- // This is basically a bottom up clusterization stage, where some leaves can be combined.
- void basisu_frontend::reoptimize_remapped_endpoints(const uint_vec &new_block_endpoints, int_vec &old_to_new_endpoint_cluster_indices, bool optimize_final_codebook, uint_vec *pBlock_selector_indices)
- {
- debug_printf("reoptimize_remapped_endpoints\n");
- basisu::vector<uint_vec> new_endpoint_cluster_block_indices(m_endpoint_clusters.size());
- for (uint32_t i = 0; i < new_block_endpoints.size(); i++)
- new_endpoint_cluster_block_indices[new_block_endpoints[i]].push_back(i);
- basisu::vector<uint8_t> cluster_valid(new_endpoint_cluster_block_indices.size());
- basisu::vector<uint8_t> cluster_improved(new_endpoint_cluster_block_indices.size());
-
- const uint32_t N = 256;
- for (uint32_t cluster_index_iter = 0; cluster_index_iter < new_endpoint_cluster_block_indices.size(); cluster_index_iter += N)
- {
- const uint32_t first_index = cluster_index_iter;
- const uint32_t last_index = minimum<uint32_t>((uint32_t)new_endpoint_cluster_block_indices.size(), cluster_index_iter + N);
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->add_job( [this, first_index, last_index, &cluster_improved, &cluster_valid, &new_endpoint_cluster_block_indices, &pBlock_selector_indices ] {
- #endif
- for (uint32_t cluster_index = first_index; cluster_index < last_index; cluster_index++)
- {
- const basisu::vector<uint32_t>& cluster_block_indices = new_endpoint_cluster_block_indices[cluster_index];
- if (!cluster_block_indices.size())
- continue;
- const uint32_t total_pixels = (uint32_t)cluster_block_indices.size() * 16;
- basisu::vector<color_rgba> cluster_pixels(total_pixels);
- uint8_vec force_selectors(total_pixels);
- etc_block blk;
- blk.set_block_color5_etc1s(get_endpoint_cluster_unscaled_color(cluster_index, false));
- blk.set_inten_tables_etc1s(get_endpoint_cluster_inten_table(cluster_index, false));
- blk.set_flip_bit(true);
-
- uint64_t cur_err = 0;
- for (uint32_t cluster_block_indices_iter = 0; cluster_block_indices_iter < cluster_block_indices.size(); cluster_block_indices_iter++)
- {
- const uint32_t block_index = cluster_block_indices[cluster_block_indices_iter];
-
- const color_rgba *pBlock_pixels = get_source_pixel_block(block_index).get_ptr();
- memcpy(&cluster_pixels[cluster_block_indices_iter * 16], pBlock_pixels, 16 * sizeof(color_rgba));
- const uint32_t selector_cluster_index = pBlock_selector_indices ? (*pBlock_selector_indices)[block_index] : get_block_selector_cluster_index(block_index);
- const etc_block &blk_selectors = get_selector_cluster_selector_bits(selector_cluster_index);
- blk.set_raw_selector_bits(blk_selectors.get_raw_selector_bits());
- cur_err += blk.evaluate_etc1_error(pBlock_pixels, m_params.m_perceptual);
-
- for (uint32_t y = 0; y < 4; y++)
- for (uint32_t x = 0; x < 4; x++)
- force_selectors[cluster_block_indices_iter * 16 + x + y * 4] = static_cast<uint8_t>(blk_selectors.get_selector(x, y));
- }
- endpoint_cluster_etc_params new_endpoint_cluster_etc_params;
-
- {
- etc1_optimizer optimizer;
- etc1_solution_coordinates solutions[2];
- etc1_optimizer::params cluster_optimizer_params;
- cluster_optimizer_params.m_num_src_pixels = total_pixels;
- cluster_optimizer_params.m_pSrc_pixels = &cluster_pixels[0];
- cluster_optimizer_params.m_use_color4 = false;
- cluster_optimizer_params.m_perceptual = m_params.m_perceptual;
- cluster_optimizer_params.m_pForce_selectors = &force_selectors[0];
- if (m_params.m_compression_level == BASISU_MAX_COMPRESSION_LEVEL)
- cluster_optimizer_params.m_quality = cETCQualityUber;
- else
- cluster_optimizer_params.m_quality = cETCQualitySlow;
- etc1_optimizer::results cluster_optimizer_results;
- basisu::vector<uint8_t> cluster_selectors(total_pixels);
- cluster_optimizer_results.m_n = total_pixels;
- cluster_optimizer_results.m_pSelectors = &cluster_selectors[0];
- optimizer.init(cluster_optimizer_params, cluster_optimizer_results);
- if (!optimizer.compute())
- BASISU_FRONTEND_VERIFY(false);
- new_endpoint_cluster_etc_params.m_color_unscaled[0] = cluster_optimizer_results.m_block_color_unscaled;
- new_endpoint_cluster_etc_params.m_inten_table[0] = cluster_optimizer_results.m_block_inten_table;
- new_endpoint_cluster_etc_params.m_color_error[0] = cluster_optimizer_results.m_error;
- new_endpoint_cluster_etc_params.m_color_used[0] = true;
- new_endpoint_cluster_etc_params.m_valid = true;
- }
- if (new_endpoint_cluster_etc_params.m_color_error[0] < cur_err)
- {
- m_endpoint_cluster_etc_params[cluster_index] = new_endpoint_cluster_etc_params;
-
- cluster_improved[cluster_index] = true;
- }
- cluster_valid[cluster_index] = true;
- } // cluster_index
- #ifndef __EMSCRIPTEN__
- } );
- #endif
- } // cluster_index_iter
- #ifndef __EMSCRIPTEN__
- m_params.m_pJob_pool->wait_for_all();
- #endif
-
- uint32_t total_unused_clusters = 0;
- uint32_t total_improved_clusters = 0;
-
- old_to_new_endpoint_cluster_indices.resize(m_endpoint_clusters.size());
- vector_set_all(old_to_new_endpoint_cluster_indices, -1);
-
- int total_new_endpoint_clusters = 0;
- for (uint32_t old_cluster_index = 0; old_cluster_index < m_endpoint_clusters.size(); old_cluster_index++)
- {
- if (!cluster_valid[old_cluster_index])
- total_unused_clusters++;
- else
- old_to_new_endpoint_cluster_indices[old_cluster_index] = total_new_endpoint_clusters++;
- if (cluster_improved[old_cluster_index])
- total_improved_clusters++;
- }
- debug_printf("Total unused clusters: %u\n", total_unused_clusters);
- debug_printf("Total improved_clusters: %u\n", total_improved_clusters);
- debug_printf("Total endpoint clusters: %u\n", total_new_endpoint_clusters);
- if (optimize_final_codebook)
- {
- cluster_subblock_etc_params_vec new_endpoint_cluster_etc_params(total_new_endpoint_clusters);
- for (uint32_t old_cluster_index = 0; old_cluster_index < m_endpoint_clusters.size(); old_cluster_index++)
- {
- if (old_to_new_endpoint_cluster_indices[old_cluster_index] >= 0)
- new_endpoint_cluster_etc_params[old_to_new_endpoint_cluster_indices[old_cluster_index]] = m_endpoint_cluster_etc_params[old_cluster_index];
- }
- debug_printf("basisu_frontend::reoptimize_remapped_endpoints: stage 1\n");
- basisu::vector<uint_vec> new_endpoint_clusters(total_new_endpoint_clusters);
- for (uint32_t block_index = 0; block_index < new_block_endpoints.size(); block_index++)
- {
- const uint32_t old_endpoint_cluster_index = new_block_endpoints[block_index];
-
- const int new_endpoint_cluster_index = old_to_new_endpoint_cluster_indices[old_endpoint_cluster_index];
- BASISU_FRONTEND_VERIFY(new_endpoint_cluster_index >= 0);
- BASISU_FRONTEND_VERIFY(new_endpoint_cluster_index < (int)new_endpoint_clusters.size());
- new_endpoint_clusters[new_endpoint_cluster_index].push_back(block_index * 2 + 0);
- new_endpoint_clusters[new_endpoint_cluster_index].push_back(block_index * 2 + 1);
- BASISU_FRONTEND_VERIFY(new_endpoint_cluster_index < (int)new_endpoint_cluster_etc_params.size());
- new_endpoint_cluster_etc_params[new_endpoint_cluster_index].m_subblocks.push_back(block_index * 2 + 0);
- new_endpoint_cluster_etc_params[new_endpoint_cluster_index].m_subblocks.push_back(block_index * 2 + 1);
-
- m_block_endpoint_clusters_indices[block_index][0] = new_endpoint_cluster_index;
- m_block_endpoint_clusters_indices[block_index][1] = new_endpoint_cluster_index;
- }
- debug_printf("basisu_frontend::reoptimize_remapped_endpoints: stage 2\n");
-
- m_endpoint_clusters = new_endpoint_clusters;
- m_endpoint_cluster_etc_params = new_endpoint_cluster_etc_params;
- eliminate_redundant_or_empty_endpoint_clusters();
- debug_printf("basisu_frontend::reoptimize_remapped_endpoints: stage 3\n");
- for (uint32_t new_cluster_index = 0; new_cluster_index < m_endpoint_clusters.size(); new_cluster_index++)
- {
- for (uint32_t cluster_block_iter = 0; cluster_block_iter < m_endpoint_clusters[new_cluster_index].size(); cluster_block_iter++)
- {
- const uint32_t subblock_index = m_endpoint_clusters[new_cluster_index][cluster_block_iter];
- const uint32_t block_index = subblock_index >> 1;
- m_block_endpoint_clusters_indices[block_index][0] = new_cluster_index;
- m_block_endpoint_clusters_indices[block_index][1] = new_cluster_index;
- const uint32_t old_cluster_index = new_block_endpoints[block_index];
- old_to_new_endpoint_cluster_indices[old_cluster_index] = new_cluster_index;
- }
- }
- debug_printf("basisu_frontend::reoptimize_remapped_endpoints: stage 4\n");
- for (uint32_t block_index = 0; block_index < m_encoded_blocks.size(); block_index++)
- {
- const uint32_t endpoint_cluster_index = get_subblock_endpoint_cluster_index(block_index, 0);
- m_encoded_blocks[block_index].set_block_color5_etc1s(get_endpoint_cluster_unscaled_color(endpoint_cluster_index, false));
- m_encoded_blocks[block_index].set_inten_tables_etc1s(get_endpoint_cluster_inten_table(endpoint_cluster_index, false));
- }
- debug_printf("Final (post-RDO) endpoint clusters: %u\n", m_endpoint_clusters.size());
- }
-
- //debug_printf("validate_output: %u\n", validate_output());
- }
- // Endpoint clusterization hierarchy integrity checker.
- // Note this doesn't check for empty clusters.
- bool basisu_frontend::validate_endpoint_cluster_hierarchy(bool ensure_clusters_have_same_parents) const
- {
- if (!m_endpoint_parent_clusters.size())
- return true;
- int_vec subblock_parent_indices(m_total_blocks * 2);
- subblock_parent_indices.set_all(-1);
- int_vec subblock_cluster_indices(m_total_blocks * 2);
- subblock_cluster_indices.set_all(-1);
- for (uint32_t parent_index = 0; parent_index < m_endpoint_parent_clusters.size(); parent_index++)
- {
- for (uint32_t i = 0; i < m_endpoint_parent_clusters[parent_index].size(); i++)
- {
- uint32_t subblock_index = m_endpoint_parent_clusters[parent_index][i];
- if (subblock_index >= m_total_blocks * 2)
- return false;
- // If the endpoint cluster lives in more than one parent node, that's wrong.
- if (subblock_parent_indices[subblock_index] != -1)
- return false;
-
- subblock_parent_indices[subblock_index] = parent_index;
- }
- }
- // Make sure all endpoint clusters are present in the parent cluster.
- for (uint32_t i = 0; i < subblock_parent_indices.size(); i++)
- {
- if (subblock_parent_indices[i] == -1)
- return false;
- }
- for (uint32_t cluster_index = 0; cluster_index < m_endpoint_clusters.size(); cluster_index++)
- {
- int parent_index = 0;
- for (uint32_t i = 0; i < m_endpoint_clusters[cluster_index].size(); i++)
- {
- uint32_t subblock_index = m_endpoint_clusters[cluster_index][i];
- if (subblock_index >= m_total_blocks * 2)
- return false;
- if (subblock_cluster_indices[subblock_index] != -1)
- return false;
-
- subblock_cluster_indices[subblock_index] = cluster_index;
- // There are transformations on the endpoint clusters that can break the strict tree requirement
- if (ensure_clusters_have_same_parents)
- {
- // Make sure all the subblocks are in the same parent cluster
- if (!i)
- parent_index = subblock_parent_indices[subblock_index];
- else if (subblock_parent_indices[subblock_index] != parent_index)
- return false;
- }
- }
- }
-
- // Make sure all endpoint clusters are present in the parent cluster.
- for (uint32_t i = 0; i < subblock_cluster_indices.size(); i++)
- {
- if (subblock_cluster_indices[i] == -1)
- return false;
- }
- return true;
- }
- // This is very slow and only intended for debugging/development. It's enabled using the "-validate_etc1s" command line option.
- bool basisu_frontend::validate_output() const
- {
- debug_printf("validate_output\n");
- if (!check_etc1s_constraints())
- return false;
- for (uint32_t block_index = 0; block_index < m_total_blocks; block_index++)
- {
- //#define CHECK(x) do { if (!(x)) { DebugBreak(); return false; } } while(0)
- #define CHECK(x) BASISU_FRONTEND_VERIFY(x);
- CHECK(get_output_block(block_index).get_flip_bit() == true);
-
- const bool diff_flag = get_diff_flag(block_index);
- CHECK(diff_flag == true);
- etc_block blk;
- memset(&blk, 0, sizeof(blk));
- blk.set_flip_bit(true);
- blk.set_diff_bit(true);
- const uint32_t endpoint_cluster0_index = get_subblock_endpoint_cluster_index(block_index, 0);
- const uint32_t endpoint_cluster1_index = get_subblock_endpoint_cluster_index(block_index, 1);
- // basisu only supports ETC1S, so these must be equal.
- CHECK(endpoint_cluster0_index == endpoint_cluster1_index);
-
- CHECK(blk.set_block_color5_check(get_endpoint_cluster_unscaled_color(endpoint_cluster0_index, false), get_endpoint_cluster_unscaled_color(endpoint_cluster1_index, false)));
- CHECK(get_endpoint_cluster_color_is_used(endpoint_cluster0_index, false));
-
- blk.set_inten_table(0, get_endpoint_cluster_inten_table(endpoint_cluster0_index, false));
- blk.set_inten_table(1, get_endpoint_cluster_inten_table(endpoint_cluster1_index, false));
- const uint32_t selector_cluster_index = get_block_selector_cluster_index(block_index);
- CHECK(selector_cluster_index < get_total_selector_clusters());
- CHECK(vector_find(get_selector_cluster_block_indices(selector_cluster_index), block_index) != -1);
- blk.set_raw_selector_bits(get_selector_cluster_selector_bits(selector_cluster_index).get_raw_selector_bits());
- const etc_block &rdo_output_block = get_output_block(block_index);
- CHECK(rdo_output_block.get_flip_bit() == blk.get_flip_bit());
- CHECK(rdo_output_block.get_diff_bit() == blk.get_diff_bit());
- CHECK(rdo_output_block.get_inten_table(0) == blk.get_inten_table(0));
- CHECK(rdo_output_block.get_inten_table(1) == blk.get_inten_table(1));
- CHECK(rdo_output_block.get_base5_color() == blk.get_base5_color());
- CHECK(rdo_output_block.get_delta3_color() == blk.get_delta3_color());
- CHECK(rdo_output_block.get_raw_selector_bits() == blk.get_raw_selector_bits());
-
- #undef CHECK
- }
- return true;
- }
- void basisu_frontend::dump_debug_image(const char *pFilename, uint32_t first_block, uint32_t num_blocks_x, uint32_t num_blocks_y, bool output_blocks)
- {
- gpu_image g;
- g.init(texture_format::cETC1, num_blocks_x * 4, num_blocks_y * 4);
- for (uint32_t y = 0; y < num_blocks_y; y++)
- {
- for (uint32_t x = 0; x < num_blocks_x; x++)
- {
- const uint32_t block_index = first_block + x + y * num_blocks_x;
- etc_block &blk = *(etc_block *)g.get_block_ptr(x, y);
- if (output_blocks)
- blk = get_output_block(block_index);
- else
- {
- const bool diff_flag = get_diff_flag(block_index);
- blk.set_diff_bit(diff_flag);
- blk.set_flip_bit(true);
- const uint32_t endpoint_cluster0_index = get_subblock_endpoint_cluster_index(block_index, 0);
- const uint32_t endpoint_cluster1_index = get_subblock_endpoint_cluster_index(block_index, 1);
- if (diff_flag)
- blk.set_block_color5(get_endpoint_cluster_unscaled_color(endpoint_cluster0_index, false), get_endpoint_cluster_unscaled_color(endpoint_cluster1_index, false));
- else
- blk.set_block_color4(get_endpoint_cluster_unscaled_color(endpoint_cluster0_index, true), get_endpoint_cluster_unscaled_color(endpoint_cluster1_index, true));
- blk.set_inten_table(0, get_endpoint_cluster_inten_table(endpoint_cluster0_index, !diff_flag));
- blk.set_inten_table(1, get_endpoint_cluster_inten_table(endpoint_cluster1_index, !diff_flag));
- const uint32_t selector_cluster_index = get_block_selector_cluster_index(block_index);
- blk.set_raw_selector_bits(get_selector_cluster_selector_bits(selector_cluster_index).get_raw_selector_bits());
- }
- }
- }
- image img;
- g.unpack(img);
- save_png(pFilename, img);
- }
- } // namespace basisu
|