1  
     2  
     3  
     4  
     5  package wasm
     6  
     7  import (
     8  	"bytes"
     9  	"cmd/internal/obj"
    10  	"cmd/internal/obj/wasm"
    11  	"cmd/internal/objabi"
    12  	"cmd/link/internal/ld"
    13  	"cmd/link/internal/loader"
    14  	"cmd/link/internal/sym"
    15  	"fmt"
    16  	"internal/abi"
    17  	"internal/buildcfg"
    18  	"io"
    19  	"regexp"
    20  )
    21  
    22  const (
    23  	I32 = 0x7F
    24  	I64 = 0x7E
    25  	F32 = 0x7D
    26  	F64 = 0x7C
    27  )
    28  
    29  const (
    30  	sectionCustom   = 0
    31  	sectionType     = 1
    32  	sectionImport   = 2
    33  	sectionFunction = 3
    34  	sectionTable    = 4
    35  	sectionMemory   = 5
    36  	sectionGlobal   = 6
    37  	sectionExport   = 7
    38  	sectionStart    = 8
    39  	sectionElement  = 9
    40  	sectionCode     = 10
    41  	sectionData     = 11
    42  )
    43  
    44  
    45  const funcValueOffset = 0x1000 
    46  
    47  func gentext(ctxt *ld.Link, ldr *loader.Loader) {
    48  }
    49  
    50  type wasmFunc struct {
    51  	Module string
    52  	Name   string
    53  	Type   uint32
    54  	Code   []byte
    55  }
    56  
    57  type wasmFuncType struct {
    58  	Params  []byte
    59  	Results []byte
    60  }
    61  
    62  func readWasmImport(ldr *loader.Loader, s loader.Sym) obj.WasmImport {
    63  	var wi obj.WasmImport
    64  	wi.Read(ldr.Data(s))
    65  	return wi
    66  }
    67  
    68  var wasmFuncTypes = map[string]*wasmFuncType{
    69  	"_rt0_wasm_js":            {Params: []byte{}},                                         
    70  	"_rt0_wasm_wasip1":        {Params: []byte{}},                                         
    71  	"_rt0_wasm_wasip1_lib":    {Params: []byte{}},                                         
    72  	"wasm_export__start":      {},                                                         
    73  	"wasm_export_run":         {Params: []byte{I32, I32}},                                 
    74  	"wasm_export_resume":      {Params: []byte{}},                                         
    75  	"wasm_export_getsp":       {Results: []byte{I32}},                                     
    76  	"wasm_pc_f_loop":          {Params: []byte{}},                                         
    77  	"wasm_pc_f_loop_export":   {Params: []byte{I32}},                                      
    78  	"runtime.wasmDiv":         {Params: []byte{I64, I64}, Results: []byte{I64}},           
    79  	"runtime.wasmTruncS":      {Params: []byte{F64}, Results: []byte{I64}},                
    80  	"runtime.wasmTruncU":      {Params: []byte{F64}, Results: []byte{I64}},                
    81  	"gcWriteBarrier":          {Params: []byte{I64}, Results: []byte{I64}},                
    82  	"runtime.gcWriteBarrier1": {Results: []byte{I64}},                                     
    83  	"runtime.gcWriteBarrier2": {Results: []byte{I64}},                                     
    84  	"runtime.gcWriteBarrier3": {Results: []byte{I64}},                                     
    85  	"runtime.gcWriteBarrier4": {Results: []byte{I64}},                                     
    86  	"runtime.gcWriteBarrier5": {Results: []byte{I64}},                                     
    87  	"runtime.gcWriteBarrier6": {Results: []byte{I64}},                                     
    88  	"runtime.gcWriteBarrier7": {Results: []byte{I64}},                                     
    89  	"runtime.gcWriteBarrier8": {Results: []byte{I64}},                                     
    90  	"runtime.notInitialized":  {},                                                         
    91  	"cmpbody":                 {Params: []byte{I64, I64, I64, I64}, Results: []byte{I64}}, 
    92  	"memeqbody":               {Params: []byte{I64, I64, I64}, Results: []byte{I64}},      
    93  	"memcmp":                  {Params: []byte{I32, I32, I32}, Results: []byte{I32}},      
    94  	"memchr":                  {Params: []byte{I32, I32, I32}, Results: []byte{I32}},      
    95  }
    96  
    97  func assignAddress(ldr *loader.Loader, sect *sym.Section, n int, s loader.Sym, va uint64, isTramp bool) (*sym.Section, int, uint64) {
    98  	
    99  	
   100  	
   101  	
   102  	
   103  	
   104  	
   105  	
   106  	
   107  	
   108  	
   109  	
   110  	
   111  	
   112  	ldr.SetSymSect(s, sect)
   113  	ldr.SetSymValue(s, int64(funcValueOffset+va/abi.MINFUNC)<<16) 
   114  	va += uint64(abi.MINFUNC)
   115  	return sect, n, va
   116  }
   117  
   118  type wasmDataSect struct {
   119  	sect *sym.Section
   120  	data []byte
   121  }
   122  
   123  var dataSects []wasmDataSect
   124  
   125  func asmb(ctxt *ld.Link, ldr *loader.Loader) {
   126  	sections := []*sym.Section{
   127  		ldr.SymSect(ldr.Lookup("runtime.rodata", 0)),
   128  		ldr.SymSect(ldr.Lookup("runtime.typelink", 0)),
   129  		ldr.SymSect(ldr.Lookup("runtime.itablink", 0)),
   130  		ldr.SymSect(ldr.Lookup("runtime.symtab", 0)),
   131  		ldr.SymSect(ldr.Lookup("runtime.pclntab", 0)),
   132  		ldr.SymSect(ldr.Lookup("runtime.noptrdata", 0)),
   133  		ldr.SymSect(ldr.Lookup("runtime.data", 0)),
   134  	}
   135  
   136  	dataSects = make([]wasmDataSect, len(sections))
   137  	for i, sect := range sections {
   138  		data := ld.DatblkBytes(ctxt, int64(sect.Vaddr), int64(sect.Length))
   139  		dataSects[i] = wasmDataSect{sect, data}
   140  	}
   141  }
   142  
   143  
   144  
   145  func asmb2(ctxt *ld.Link, ldr *loader.Loader) {
   146  	types := []*wasmFuncType{
   147  		
   148  		
   149  		
   150  		
   151  		{Params: []byte{I32}, Results: []byte{I32}},
   152  	}
   153  
   154  	
   155  	
   156  	
   157  	
   158  	var hostImports []*wasmFunc
   159  	hostImportMap := make(map[loader.Sym]int64)
   160  	for _, fn := range ctxt.Textp {
   161  		relocs := ldr.Relocs(fn)
   162  		for ri := 0; ri < relocs.Count(); ri++ {
   163  			r := relocs.At(ri)
   164  			if r.Type() == objabi.R_WASMIMPORT {
   165  				if wsym := ldr.WasmImportSym(fn); wsym != 0 {
   166  					wi := readWasmImport(ldr, wsym)
   167  					hostImportMap[fn] = int64(len(hostImports))
   168  					hostImports = append(hostImports, &wasmFunc{
   169  						Module: wi.Module,
   170  						Name:   wi.Name,
   171  						Type: lookupType(&wasmFuncType{
   172  							Params:  fieldsToTypes(wi.Params),
   173  							Results: fieldsToTypes(wi.Results),
   174  						}, &types),
   175  					})
   176  				} else {
   177  					panic(fmt.Sprintf("missing wasm symbol for %s", ldr.SymName(r.Sym())))
   178  				}
   179  			}
   180  		}
   181  	}
   182  
   183  	
   184  	var buildid []byte
   185  	fns := make([]*wasmFunc, len(ctxt.Textp))
   186  	for i, fn := range ctxt.Textp {
   187  		wfn := new(bytes.Buffer)
   188  		if ldr.SymName(fn) == "go:buildid" {
   189  			writeUleb128(wfn, 0) 
   190  			writeI32Const(wfn, 0)
   191  			wfn.WriteByte(0x0b) 
   192  			buildid = ldr.Data(fn)
   193  		} else {
   194  			
   195  			relocs := ldr.Relocs(fn)
   196  			P := ldr.Data(fn)
   197  			off := int32(0)
   198  			for ri := 0; ri < relocs.Count(); ri++ {
   199  				r := relocs.At(ri)
   200  				if r.Siz() == 0 {
   201  					continue 
   202  				}
   203  				wfn.Write(P[off:r.Off()])
   204  				off = r.Off()
   205  				rs := r.Sym()
   206  				switch r.Type() {
   207  				case objabi.R_ADDR:
   208  					writeSleb128(wfn, ldr.SymValue(rs)+r.Add())
   209  				case objabi.R_CALL:
   210  					writeSleb128(wfn, int64(len(hostImports))+ldr.SymValue(rs)>>16-funcValueOffset)
   211  				case objabi.R_WASMIMPORT:
   212  					writeSleb128(wfn, hostImportMap[rs])
   213  				default:
   214  					ldr.Errorf(fn, "bad reloc type %d (%s)", r.Type(), sym.RelocName(ctxt.Arch, r.Type()))
   215  					continue
   216  				}
   217  			}
   218  			wfn.Write(P[off:])
   219  		}
   220  
   221  		typ := uint32(0)
   222  		if sig, ok := wasmFuncTypes[ldr.SymName(fn)]; ok {
   223  			typ = lookupType(sig, &types)
   224  		}
   225  		if s := ldr.WasmTypeSym(fn); s != 0 {
   226  			var o obj.WasmFuncType
   227  			o.Read(ldr.Data(s))
   228  			t := &wasmFuncType{
   229  				Params:  fieldsToTypes(o.Params),
   230  				Results: fieldsToTypes(o.Results),
   231  			}
   232  			typ = lookupType(t, &types)
   233  		}
   234  
   235  		name := nameRegexp.ReplaceAllString(ldr.SymName(fn), "_")
   236  		fns[i] = &wasmFunc{Name: name, Type: typ, Code: wfn.Bytes()}
   237  	}
   238  
   239  	ctxt.Out.Write([]byte{0x00, 0x61, 0x73, 0x6d}) 
   240  	ctxt.Out.Write([]byte{0x01, 0x00, 0x00, 0x00}) 
   241  
   242  	
   243  	if len(buildid) != 0 {
   244  		writeBuildID(ctxt, buildid)
   245  	}
   246  
   247  	writeTypeSec(ctxt, types)
   248  	writeImportSec(ctxt, hostImports)
   249  	writeFunctionSec(ctxt, fns)
   250  	writeTableSec(ctxt, fns)
   251  	writeMemorySec(ctxt, ldr)
   252  	writeGlobalSec(ctxt)
   253  	writeExportSec(ctxt, ldr, len(hostImports))
   254  	writeElementSec(ctxt, uint64(len(hostImports)), uint64(len(fns)))
   255  	writeCodeSec(ctxt, fns)
   256  	writeDataSec(ctxt)
   257  	writeProducerSec(ctxt)
   258  	if !*ld.FlagS {
   259  		writeNameSec(ctxt, len(hostImports), fns)
   260  	}
   261  }
   262  
   263  func lookupType(sig *wasmFuncType, types *[]*wasmFuncType) uint32 {
   264  	for i, t := range *types {
   265  		if bytes.Equal(sig.Params, t.Params) && bytes.Equal(sig.Results, t.Results) {
   266  			return uint32(i)
   267  		}
   268  	}
   269  	*types = append(*types, sig)
   270  	return uint32(len(*types) - 1)
   271  }
   272  
   273  func writeSecHeader(ctxt *ld.Link, id uint8) int64 {
   274  	ctxt.Out.WriteByte(id)
   275  	sizeOffset := ctxt.Out.Offset()
   276  	ctxt.Out.Write(make([]byte, 5)) 
   277  	return sizeOffset
   278  }
   279  
   280  func writeSecSize(ctxt *ld.Link, sizeOffset int64) {
   281  	endOffset := ctxt.Out.Offset()
   282  	ctxt.Out.SeekSet(sizeOffset)
   283  	writeUleb128FixedLength(ctxt.Out, uint64(endOffset-sizeOffset-5), 5)
   284  	ctxt.Out.SeekSet(endOffset)
   285  }
   286  
   287  func writeBuildID(ctxt *ld.Link, buildid []byte) {
   288  	sizeOffset := writeSecHeader(ctxt, sectionCustom)
   289  	writeName(ctxt.Out, "go:buildid")
   290  	ctxt.Out.Write(buildid)
   291  	writeSecSize(ctxt, sizeOffset)
   292  }
   293  
   294  
   295  
   296  func writeTypeSec(ctxt *ld.Link, types []*wasmFuncType) {
   297  	sizeOffset := writeSecHeader(ctxt, sectionType)
   298  
   299  	writeUleb128(ctxt.Out, uint64(len(types)))
   300  
   301  	for _, t := range types {
   302  		ctxt.Out.WriteByte(0x60) 
   303  		writeUleb128(ctxt.Out, uint64(len(t.Params)))
   304  		for _, v := range t.Params {
   305  			ctxt.Out.WriteByte(byte(v))
   306  		}
   307  		writeUleb128(ctxt.Out, uint64(len(t.Results)))
   308  		for _, v := range t.Results {
   309  			ctxt.Out.WriteByte(byte(v))
   310  		}
   311  	}
   312  
   313  	writeSecSize(ctxt, sizeOffset)
   314  }
   315  
   316  
   317  
   318  func writeImportSec(ctxt *ld.Link, hostImports []*wasmFunc) {
   319  	sizeOffset := writeSecHeader(ctxt, sectionImport)
   320  
   321  	writeUleb128(ctxt.Out, uint64(len(hostImports))) 
   322  	for _, fn := range hostImports {
   323  		if fn.Module != "" {
   324  			writeName(ctxt.Out, fn.Module)
   325  		} else {
   326  			writeName(ctxt.Out, wasm.GojsModule) 
   327  		}
   328  		writeName(ctxt.Out, fn.Name)
   329  		ctxt.Out.WriteByte(0x00) 
   330  		writeUleb128(ctxt.Out, uint64(fn.Type))
   331  	}
   332  
   333  	writeSecSize(ctxt, sizeOffset)
   334  }
   335  
   336  
   337  
   338  func writeFunctionSec(ctxt *ld.Link, fns []*wasmFunc) {
   339  	sizeOffset := writeSecHeader(ctxt, sectionFunction)
   340  
   341  	writeUleb128(ctxt.Out, uint64(len(fns)))
   342  	for _, fn := range fns {
   343  		writeUleb128(ctxt.Out, uint64(fn.Type))
   344  	}
   345  
   346  	writeSecSize(ctxt, sizeOffset)
   347  }
   348  
   349  
   350  
   351  
   352  func writeTableSec(ctxt *ld.Link, fns []*wasmFunc) {
   353  	sizeOffset := writeSecHeader(ctxt, sectionTable)
   354  
   355  	numElements := uint64(funcValueOffset + len(fns))
   356  	writeUleb128(ctxt.Out, 1)           
   357  	ctxt.Out.WriteByte(0x70)            
   358  	ctxt.Out.WriteByte(0x00)            
   359  	writeUleb128(ctxt.Out, numElements) 
   360  
   361  	writeSecSize(ctxt, sizeOffset)
   362  }
   363  
   364  
   365  
   366  func writeMemorySec(ctxt *ld.Link, ldr *loader.Loader) {
   367  	sizeOffset := writeSecHeader(ctxt, sectionMemory)
   368  
   369  	dataEnd := uint64(ldr.SymValue(ldr.Lookup("runtime.end", 0)))
   370  	var initialSize = dataEnd + 1<<20 
   371  
   372  	const wasmPageSize = 64 << 10 
   373  
   374  	writeUleb128(ctxt.Out, 1)                        
   375  	ctxt.Out.WriteByte(0x00)                         
   376  	writeUleb128(ctxt.Out, initialSize/wasmPageSize) 
   377  
   378  	writeSecSize(ctxt, sizeOffset)
   379  }
   380  
   381  
   382  func writeGlobalSec(ctxt *ld.Link) {
   383  	sizeOffset := writeSecHeader(ctxt, sectionGlobal)
   384  
   385  	globalRegs := []byte{
   386  		I32, 
   387  		I64, 
   388  		I64, 
   389  		I64, 
   390  		I64, 
   391  		I64, 
   392  		I64, 
   393  		I32, 
   394  	}
   395  
   396  	writeUleb128(ctxt.Out, uint64(len(globalRegs))) 
   397  
   398  	for _, typ := range globalRegs {
   399  		ctxt.Out.WriteByte(typ)
   400  		ctxt.Out.WriteByte(0x01) 
   401  		switch typ {
   402  		case I32:
   403  			writeI32Const(ctxt.Out, 0)
   404  		case I64:
   405  			writeI64Const(ctxt.Out, 0)
   406  		}
   407  		ctxt.Out.WriteByte(0x0b) 
   408  	}
   409  
   410  	writeSecSize(ctxt, sizeOffset)
   411  }
   412  
   413  
   414  
   415  
   416  func writeExportSec(ctxt *ld.Link, ldr *loader.Loader, lenHostImports int) {
   417  	sizeOffset := writeSecHeader(ctxt, sectionExport)
   418  
   419  	switch buildcfg.GOOS {
   420  	case "wasip1":
   421  		writeUleb128(ctxt.Out, uint64(2+len(ldr.WasmExports))) 
   422  		var entry, entryExpName string
   423  		switch ctxt.BuildMode {
   424  		case ld.BuildModeExe:
   425  			entry = "_rt0_wasm_wasip1"
   426  			entryExpName = "_start"
   427  		case ld.BuildModeCShared:
   428  			entry = "_rt0_wasm_wasip1_lib"
   429  			entryExpName = "_initialize"
   430  		}
   431  		s := ldr.Lookup(entry, 0)
   432  		if s == 0 {
   433  			ld.Errorf("export symbol %s not defined", entry)
   434  		}
   435  		idx := uint32(lenHostImports) + uint32(ldr.SymValue(s)>>16) - funcValueOffset
   436  		writeName(ctxt.Out, entryExpName)   
   437  		ctxt.Out.WriteByte(0x00)            
   438  		writeUleb128(ctxt.Out, uint64(idx)) 
   439  		for _, s := range ldr.WasmExports {
   440  			idx := uint32(lenHostImports) + uint32(ldr.SymValue(s)>>16) - funcValueOffset
   441  			writeName(ctxt.Out, ldr.SymName(s))
   442  			ctxt.Out.WriteByte(0x00)            
   443  			writeUleb128(ctxt.Out, uint64(idx)) 
   444  		}
   445  		writeName(ctxt.Out, "memory") 
   446  		ctxt.Out.WriteByte(0x02)      
   447  		writeUleb128(ctxt.Out, 0)     
   448  	case "js":
   449  		writeUleb128(ctxt.Out, uint64(4+len(ldr.WasmExports))) 
   450  		for _, name := range []string{"run", "resume", "getsp"} {
   451  			s := ldr.Lookup("wasm_export_"+name, 0)
   452  			if s == 0 {
   453  				ld.Errorf("export symbol %s not defined", "wasm_export_"+name)
   454  			}
   455  			idx := uint32(lenHostImports) + uint32(ldr.SymValue(s)>>16) - funcValueOffset
   456  			writeName(ctxt.Out, name)           
   457  			ctxt.Out.WriteByte(0x00)            
   458  			writeUleb128(ctxt.Out, uint64(idx)) 
   459  		}
   460  		for _, s := range ldr.WasmExports {
   461  			idx := uint32(lenHostImports) + uint32(ldr.SymValue(s)>>16) - funcValueOffset
   462  			writeName(ctxt.Out, ldr.SymName(s))
   463  			ctxt.Out.WriteByte(0x00)            
   464  			writeUleb128(ctxt.Out, uint64(idx)) 
   465  		}
   466  		writeName(ctxt.Out, "mem") 
   467  		ctxt.Out.WriteByte(0x02)   
   468  		writeUleb128(ctxt.Out, 0)  
   469  	default:
   470  		ld.Exitf("internal error: writeExportSec: unrecognized GOOS %s", buildcfg.GOOS)
   471  	}
   472  
   473  	writeSecSize(ctxt, sizeOffset)
   474  }
   475  
   476  
   477  
   478  
   479  func writeElementSec(ctxt *ld.Link, numImports, numFns uint64) {
   480  	sizeOffset := writeSecHeader(ctxt, sectionElement)
   481  
   482  	writeUleb128(ctxt.Out, 1) 
   483  
   484  	writeUleb128(ctxt.Out, 0) 
   485  	writeI32Const(ctxt.Out, funcValueOffset)
   486  	ctxt.Out.WriteByte(0x0b) 
   487  
   488  	writeUleb128(ctxt.Out, numFns) 
   489  	for i := uint64(0); i < numFns; i++ {
   490  		writeUleb128(ctxt.Out, numImports+i)
   491  	}
   492  
   493  	writeSecSize(ctxt, sizeOffset)
   494  }
   495  
   496  
   497  
   498  func writeCodeSec(ctxt *ld.Link, fns []*wasmFunc) {
   499  	sizeOffset := writeSecHeader(ctxt, sectionCode)
   500  
   501  	writeUleb128(ctxt.Out, uint64(len(fns))) 
   502  	for _, fn := range fns {
   503  		writeUleb128(ctxt.Out, uint64(len(fn.Code)))
   504  		ctxt.Out.Write(fn.Code)
   505  	}
   506  
   507  	writeSecSize(ctxt, sizeOffset)
   508  }
   509  
   510  
   511  func writeDataSec(ctxt *ld.Link) {
   512  	sizeOffset := writeSecHeader(ctxt, sectionData)
   513  
   514  	type dataSegment struct {
   515  		offset int32
   516  		data   []byte
   517  	}
   518  
   519  	
   520  	
   521  	
   522  	const segmentOverhead = 8
   523  
   524  	
   525  	const maxNumSegments = 100000
   526  
   527  	var segments []*dataSegment
   528  	for secIndex, ds := range dataSects {
   529  		data := ds.data
   530  		offset := int32(ds.sect.Vaddr)
   531  
   532  		
   533  		for len(data) > 0 && data[0] == 0 {
   534  			data = data[1:]
   535  			offset++
   536  		}
   537  
   538  		for len(data) > 0 {
   539  			dataLen := int32(len(data))
   540  			var segmentEnd, zeroEnd int32
   541  			if len(segments)+(len(dataSects)-secIndex) == maxNumSegments {
   542  				segmentEnd = dataLen
   543  				zeroEnd = dataLen
   544  			} else {
   545  				for {
   546  					
   547  					for segmentEnd < dataLen && data[segmentEnd] != 0 {
   548  						segmentEnd++
   549  					}
   550  					
   551  					zeroEnd = segmentEnd
   552  					for zeroEnd < dataLen && data[zeroEnd] == 0 {
   553  						zeroEnd++
   554  					}
   555  					
   556  					if zeroEnd-segmentEnd >= segmentOverhead || zeroEnd == dataLen {
   557  						break
   558  					}
   559  					segmentEnd = zeroEnd
   560  				}
   561  			}
   562  
   563  			segments = append(segments, &dataSegment{
   564  				offset: offset,
   565  				data:   data[:segmentEnd],
   566  			})
   567  			data = data[zeroEnd:]
   568  			offset += zeroEnd
   569  		}
   570  	}
   571  
   572  	writeUleb128(ctxt.Out, uint64(len(segments))) 
   573  	for _, seg := range segments {
   574  		writeUleb128(ctxt.Out, 0) 
   575  		writeI32Const(ctxt.Out, seg.offset)
   576  		ctxt.Out.WriteByte(0x0b) 
   577  		writeUleb128(ctxt.Out, uint64(len(seg.data)))
   578  		ctxt.Out.Write(seg.data)
   579  	}
   580  
   581  	writeSecSize(ctxt, sizeOffset)
   582  }
   583  
   584  
   585  func writeProducerSec(ctxt *ld.Link) {
   586  	sizeOffset := writeSecHeader(ctxt, sectionCustom)
   587  	writeName(ctxt.Out, "producers")
   588  
   589  	writeUleb128(ctxt.Out, 2) 
   590  
   591  	writeName(ctxt.Out, "language")       
   592  	writeUleb128(ctxt.Out, 1)             
   593  	writeName(ctxt.Out, "Go")             
   594  	writeName(ctxt.Out, buildcfg.Version) 
   595  
   596  	writeName(ctxt.Out, "processed-by")   
   597  	writeUleb128(ctxt.Out, 1)             
   598  	writeName(ctxt.Out, "Go cmd/compile") 
   599  	writeName(ctxt.Out, buildcfg.Version) 
   600  
   601  	writeSecSize(ctxt, sizeOffset)
   602  }
   603  
   604  var nameRegexp = regexp.MustCompile(`[^\w.]`)
   605  
   606  
   607  
   608  
   609  func writeNameSec(ctxt *ld.Link, firstFnIndex int, fns []*wasmFunc) {
   610  	sizeOffset := writeSecHeader(ctxt, sectionCustom)
   611  	writeName(ctxt.Out, "name")
   612  
   613  	sizeOffset2 := writeSecHeader(ctxt, 0x01) 
   614  	writeUleb128(ctxt.Out, uint64(len(fns)))
   615  	for i, fn := range fns {
   616  		writeUleb128(ctxt.Out, uint64(firstFnIndex+i))
   617  		writeName(ctxt.Out, fn.Name)
   618  	}
   619  	writeSecSize(ctxt, sizeOffset2)
   620  
   621  	writeSecSize(ctxt, sizeOffset)
   622  }
   623  
   624  type nameWriter interface {
   625  	io.ByteWriter
   626  	io.Writer
   627  }
   628  
   629  func writeI32Const(w io.ByteWriter, v int32) {
   630  	w.WriteByte(0x41) 
   631  	writeSleb128(w, int64(v))
   632  }
   633  
   634  func writeI64Const(w io.ByteWriter, v int64) {
   635  	w.WriteByte(0x42) 
   636  	writeSleb128(w, v)
   637  }
   638  
   639  func writeName(w nameWriter, name string) {
   640  	writeUleb128(w, uint64(len(name)))
   641  	w.Write([]byte(name))
   642  }
   643  
   644  func writeUleb128(w io.ByteWriter, v uint64) {
   645  	if v < 128 {
   646  		w.WriteByte(uint8(v))
   647  		return
   648  	}
   649  	more := true
   650  	for more {
   651  		c := uint8(v & 0x7f)
   652  		v >>= 7
   653  		more = v != 0
   654  		if more {
   655  			c |= 0x80
   656  		}
   657  		w.WriteByte(c)
   658  	}
   659  }
   660  
   661  func writeUleb128FixedLength(w io.ByteWriter, v uint64, length int) {
   662  	for i := 0; i < length; i++ {
   663  		c := uint8(v & 0x7f)
   664  		v >>= 7
   665  		if i < length-1 {
   666  			c |= 0x80
   667  		}
   668  		w.WriteByte(c)
   669  	}
   670  	if v != 0 {
   671  		panic("writeUleb128FixedLength: length too small")
   672  	}
   673  }
   674  
   675  func writeSleb128(w io.ByteWriter, v int64) {
   676  	more := true
   677  	for more {
   678  		c := uint8(v & 0x7f)
   679  		s := uint8(v & 0x40)
   680  		v >>= 7
   681  		more = !((v == 0 && s == 0) || (v == -1 && s != 0))
   682  		if more {
   683  			c |= 0x80
   684  		}
   685  		w.WriteByte(c)
   686  	}
   687  }
   688  
   689  func fieldsToTypes(fields []obj.WasmField) []byte {
   690  	b := make([]byte, len(fields))
   691  	for i, f := range fields {
   692  		switch f.Type {
   693  		case obj.WasmI32, obj.WasmPtr, obj.WasmBool:
   694  			b[i] = I32
   695  		case obj.WasmI64:
   696  			b[i] = I64
   697  		case obj.WasmF32:
   698  			b[i] = F32
   699  		case obj.WasmF64:
   700  			b[i] = F64
   701  		default:
   702  			panic(fmt.Sprintf("fieldsToTypes: unknown field type: %d", f.Type))
   703  		}
   704  	}
   705  	return b
   706  }
   707  
View as plain text