mirror of
				https://github.com/go-delve/delve.git
				synced 2025-10-31 10:47:27 +08:00 
			
		
		
		
	
		
			
				
	
	
		
			494 lines
		
	
	
		
			15 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
			
		
		
	
	
			494 lines
		
	
	
		
			15 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
| package core
 | |
| 
 | |
| import (
 | |
| 	"errors"
 | |
| 	"fmt"
 | |
| 	"io"
 | |
| 
 | |
| 	"github.com/go-delve/delve/pkg/dwarf/op"
 | |
| 	"github.com/go-delve/delve/pkg/elfwriter"
 | |
| 	"github.com/go-delve/delve/pkg/proc"
 | |
| 	"github.com/go-delve/delve/pkg/proc/internal/ebpf"
 | |
| )
 | |
| 
 | |
| // ErrNoThreads core file did not contain any threads.
 | |
| var ErrNoThreads = errors.New("no threads found in core file")
 | |
| 
 | |
| // A splicedMemory represents a memory space formed from multiple regions,
 | |
| // each of which may override previously regions. For example, in the following
 | |
| // core, the program text was loaded at 0x400000:
 | |
| // Start               End                 Page Offset
 | |
| // 0x0000000000400000  0x000000000044f000  0x0000000000000000
 | |
| // but then it's partially overwritten with an RW mapping whose data is stored
 | |
| // in the core file:
 | |
| //
 | |
| //	Type           Offset             VirtAddr           PhysAddr
 | |
| //	               FileSiz            MemSiz              Flags  Align
 | |
| //	LOAD           0x0000000000004000 0x000000000049a000 0x0000000000000000
 | |
| //	               0x0000000000002000 0x0000000000002000  RW     1000
 | |
| //
 | |
| // This can be represented in a SplicedMemory by adding the original region,
 | |
| // then putting the RW mapping on top of it.
 | |
| type splicedMemory struct {
 | |
| 	readers []readerEntry
 | |
| }
 | |
| 
 | |
| type readerEntry struct {
 | |
| 	offset uint64
 | |
| 	length uint64
 | |
| 	reader proc.MemoryReader
 | |
| }
 | |
| 
 | |
| // Add adds a new region to the SplicedMemory, which may override existing regions.
 | |
| func (r *splicedMemory) Add(reader proc.MemoryReader, off, length uint64) {
 | |
| 	if length == 0 {
 | |
| 		return
 | |
| 	}
 | |
| 	end := off + length - 1
 | |
| 	newReaders := make([]readerEntry, 0, len(r.readers))
 | |
| 	add := func(e readerEntry) {
 | |
| 		if e.length == 0 {
 | |
| 			return
 | |
| 		}
 | |
| 		newReaders = append(newReaders, e)
 | |
| 	}
 | |
| 	inserted := false
 | |
| 	// Walk through the list of regions, fixing up any that overlap and inserting the new one.
 | |
| 	for _, entry := range r.readers {
 | |
| 		entryEnd := entry.offset + entry.length - 1
 | |
| 		switch {
 | |
| 		case entryEnd < off:
 | |
| 			// Entry is completely before the new region.
 | |
| 			add(entry)
 | |
| 		case end < entry.offset:
 | |
| 			// Entry is completely after the new region.
 | |
| 			if !inserted {
 | |
| 				add(readerEntry{off, length, reader})
 | |
| 				inserted = true
 | |
| 			}
 | |
| 			add(entry)
 | |
| 		case off <= entry.offset && entryEnd <= end:
 | |
| 			// Entry is completely overwritten by the new region. Drop.
 | |
| 		case entry.offset < off && entryEnd <= end:
 | |
| 			// New region overwrites the end of the entry.
 | |
| 			entry.length = off - entry.offset
 | |
| 			add(entry)
 | |
| 		case off <= entry.offset && end < entryEnd:
 | |
| 			// New reader overwrites the beginning of the entry.
 | |
| 			if !inserted {
 | |
| 				add(readerEntry{off, length, reader})
 | |
| 				inserted = true
 | |
| 			}
 | |
| 			overlap := entry.offset - off
 | |
| 			entry.offset += overlap
 | |
| 			entry.length -= overlap
 | |
| 			add(entry)
 | |
| 		case entry.offset < off && end < entryEnd:
 | |
| 			// New region punches a hole in the entry. Split it in two and put the new region in the middle.
 | |
| 			add(readerEntry{entry.offset, off - entry.offset, entry.reader})
 | |
| 			add(readerEntry{off, length, reader})
 | |
| 			add(readerEntry{end + 1, entryEnd - end, entry.reader})
 | |
| 			inserted = true
 | |
| 		default:
 | |
| 			panic(fmt.Sprintf("Unhandled case: existing entry is %v len %v, new is %v len %v", entry.offset, entry.length, off, length))
 | |
| 		}
 | |
| 	}
 | |
| 	if !inserted {
 | |
| 		newReaders = append(newReaders, readerEntry{off, length, reader})
 | |
| 	}
 | |
| 	r.readers = newReaders
 | |
| }
 | |
| 
 | |
| // ReadMemory implements MemoryReader.ReadMemory.
 | |
| func (r *splicedMemory) ReadMemory(buf []byte, addr uint64) (n int, err error) {
 | |
| 	started := false
 | |
| 	for _, entry := range r.readers {
 | |
| 		if entry.offset+entry.length <= addr {
 | |
| 			if !started {
 | |
| 				continue
 | |
| 			}
 | |
| 			return n, fmt.Errorf("hit unmapped area at %v after %v bytes", addr, n)
 | |
| 		}
 | |
| 
 | |
| 		// The reading of the memory has been started after the first iteration
 | |
| 		started = true
 | |
| 
 | |
| 		// Don't go past the region.
 | |
| 		pb := buf
 | |
| 		if addr+uint64(len(buf)) > entry.offset+entry.length {
 | |
| 			pb = pb[:entry.offset+entry.length-addr]
 | |
| 		}
 | |
| 		pn, err := entry.reader.ReadMemory(pb, addr)
 | |
| 		n += pn
 | |
| 		if err != nil {
 | |
| 			return n, fmt.Errorf("error while reading spliced memory at %#x: %v", addr, err)
 | |
| 		}
 | |
| 		if pn != len(pb) {
 | |
| 			return n, nil
 | |
| 		}
 | |
| 		buf = buf[pn:]
 | |
| 		addr += uint64(pn)
 | |
| 		if len(buf) == 0 {
 | |
| 			// Done, don't bother scanning the rest.
 | |
| 			return n, nil
 | |
| 		}
 | |
| 	}
 | |
| 	if n == 0 {
 | |
| 		return 0, fmt.Errorf("offset %v did not match any regions", addr)
 | |
| 	}
 | |
| 	return n, nil
 | |
| }
 | |
| 
 | |
| // offsetReaderAt wraps a ReaderAt into a MemoryReader, subtracting a fixed
 | |
| // offset from the address. This is useful to represent a mapping in an address
 | |
| // space. For example, if program text is mapped in at 0x400000, an
 | |
| // OffsetReaderAt with offset 0x400000 can be wrapped around file.Open(program)
 | |
| // to return the results of a read in that part of the address space.
 | |
| type offsetReaderAt struct {
 | |
| 	reader io.ReaderAt
 | |
| 	offset uint64
 | |
| }
 | |
| 
 | |
| // ReadMemory will read the memory at addr-offset.
 | |
| func (r *offsetReaderAt) ReadMemory(buf []byte, addr uint64) (n int, err error) {
 | |
| 	return r.reader.ReadAt(buf, int64(addr-r.offset))
 | |
| }
 | |
| 
 | |
| // process represents a core file.
 | |
| type process struct {
 | |
| 	mem     proc.MemoryReader
 | |
| 	Threads map[int]*thread
 | |
| 	pid     int
 | |
| 
 | |
| 	entryPoint uint64
 | |
| 
 | |
| 	bi          *proc.BinaryInfo
 | |
| 	breakpoints proc.BreakpointMap
 | |
| }
 | |
| 
 | |
| // thread represents a thread in the core file being debugged.
 | |
| type thread struct {
 | |
| 	th     osThread
 | |
| 	p      *process
 | |
| 	common proc.CommonThread
 | |
| }
 | |
| 
 | |
| type osThread interface {
 | |
| 	registers() (proc.Registers, error)
 | |
| 	pid() int
 | |
| }
 | |
| 
 | |
| var (
 | |
| 	// ErrWriteCore is returned when attempting to write to the core
 | |
| 	// process memory.
 | |
| 	ErrWriteCore = errors.New("can not write to core process")
 | |
| 
 | |
| 	// ErrShortRead is returned on a short read.
 | |
| 	ErrShortRead = errors.New("short read")
 | |
| 
 | |
| 	// ErrContinueCore is returned when trying to continue execution of a core process.
 | |
| 	ErrContinueCore = errors.New("can not continue execution of core process")
 | |
| 
 | |
| 	// ErrChangeRegisterCore is returned when trying to change register values for core files.
 | |
| 	ErrChangeRegisterCore = errors.New("can not change register values of core process")
 | |
| )
 | |
| 
 | |
| type openFn func(string, string) (*process, proc.Thread, error)
 | |
| 
 | |
| var openFns = []openFn{readLinuxOrPlatformIndependentCore, readAMD64Minidump}
 | |
| 
 | |
| // ErrUnrecognizedFormat is returned when the core file is not recognized as
 | |
| // any of the supported formats.
 | |
| var ErrUnrecognizedFormat = errors.New("unrecognized core format")
 | |
| 
 | |
| // OpenCore will open the core file and return a Process struct.
 | |
| // If the DWARF information cannot be found in the binary, Delve will look
 | |
| // for external debug files in the directories passed in.
 | |
| func OpenCore(corePath, exePath string, debugInfoDirs []string) (*proc.Target, error) {
 | |
| 	var p *process
 | |
| 	var currentThread proc.Thread
 | |
| 	var err error
 | |
| 	for _, openFn := range openFns {
 | |
| 		p, currentThread, err = openFn(corePath, exePath)
 | |
| 		if err != ErrUnrecognizedFormat {
 | |
| 			break
 | |
| 		}
 | |
| 	}
 | |
| 	if err != nil {
 | |
| 		return nil, err
 | |
| 	}
 | |
| 
 | |
| 	if currentThread == nil {
 | |
| 		return nil, ErrNoThreads
 | |
| 	}
 | |
| 
 | |
| 	return proc.NewTarget(p, p.pid, currentThread, proc.NewTargetConfig{
 | |
| 		Path:                exePath,
 | |
| 		DebugInfoDirs:       debugInfoDirs,
 | |
| 		DisableAsyncPreempt: false,
 | |
| 		StopReason:          proc.StopAttached,
 | |
| 		CanDump:             false,
 | |
| 		ContinueOnce:        continueOnce,
 | |
| 	})
 | |
| }
 | |
| 
 | |
| // BinInfo will return the binary info.
 | |
| func (p *process) BinInfo() *proc.BinaryInfo {
 | |
| 	return p.bi
 | |
| }
 | |
| 
 | |
| // EntryPoint will return the entry point address for this core file.
 | |
| func (p *process) EntryPoint() (uint64, error) {
 | |
| 	return p.entryPoint, nil
 | |
| }
 | |
| 
 | |
| // WriteBreakpoint is a noop function since you
 | |
| // cannot write breakpoints into core files.
 | |
| func (p *process) WriteBreakpoint(*proc.Breakpoint) error {
 | |
| 	return errors.New("cannot write a breakpoint to a core file")
 | |
| }
 | |
| 
 | |
| // Recorded returns whether this is a live or recorded process. Always returns true for core files.
 | |
| func (p *process) Recorded() (bool, string) { return true, "" }
 | |
| 
 | |
| // Restart will only return an error for core files, as they are not executing.
 | |
| func (p *process) Restart(*proc.ContinueOnceContext, string) (proc.Thread, error) {
 | |
| 	return nil, ErrContinueCore
 | |
| }
 | |
| 
 | |
| // ChangeDirection will only return an error as you cannot continue a core process.
 | |
| func (p *process) ChangeDirection(proc.Direction) error { return ErrContinueCore }
 | |
| 
 | |
| // GetDirection will always return forward.
 | |
| func (p *process) GetDirection() proc.Direction { return proc.Forward }
 | |
| 
 | |
| // When does not apply to core files, it is to support the Mozilla 'rr' backend.
 | |
| func (p *process) When() (string, error) { return "", nil }
 | |
| 
 | |
| // Checkpoint for core files returns an error, there is no execution of a core file.
 | |
| func (p *process) Checkpoint(string) (int, error) { return -1, ErrContinueCore }
 | |
| 
 | |
| // Checkpoints returns nil on core files, you cannot set checkpoints when debugging core files.
 | |
| func (p *process) Checkpoints() ([]proc.Checkpoint, error) { return nil, nil }
 | |
| 
 | |
| // ClearCheckpoint clears a checkpoint, but will only return an error for core files.
 | |
| func (p *process) ClearCheckpoint(int) error { return errors.New("checkpoint not found") }
 | |
| 
 | |
| func (p *process) SupportsBPF() bool {
 | |
| 	return false
 | |
| }
 | |
| 
 | |
| func (dbp *process) SetUProbe(fnName string, goidOffset int64, args []ebpf.UProbeArgMap) error {
 | |
| 	panic("not implemented")
 | |
| }
 | |
| 
 | |
| // StartCallInjection notifies the backend that we are about to inject a function call.
 | |
| func (p *process) StartCallInjection() (func(), error) { return func() {}, nil }
 | |
| 
 | |
| func (dbp *process) EnableURetProbes() error {
 | |
| 	panic("not implemented")
 | |
| }
 | |
| 
 | |
| func (dbp *process) DisableURetProbes() error {
 | |
| 	panic("not implemented")
 | |
| }
 | |
| 
 | |
| // ReadMemory will return memory from the core file at the specified location and put the
 | |
| // read memory into `data`, returning the length read, and returning an error if
 | |
| // the length read is shorter than the length of the `data` buffer.
 | |
| func (p *process) ReadMemory(data []byte, addr uint64) (n int, err error) {
 | |
| 	n, err = p.mem.ReadMemory(data, addr)
 | |
| 	if err == nil && n != len(data) {
 | |
| 		err = ErrShortRead
 | |
| 	}
 | |
| 	return n, err
 | |
| }
 | |
| 
 | |
| // WriteMemory will only return an error for core files, you cannot write
 | |
| // to the memory of a core process.
 | |
| func (p *process) WriteMemory(addr uint64, data []byte) (int, error) {
 | |
| 	return 0, ErrWriteCore
 | |
| }
 | |
| 
 | |
| // ProcessMemory returns the memory of this thread's process.
 | |
| func (t *thread) ProcessMemory() proc.MemoryReadWriter {
 | |
| 	return t.p
 | |
| }
 | |
| 
 | |
| // Location returns the location of this thread based on
 | |
| // the value of the instruction pointer register.
 | |
| func (t *thread) Location() (*proc.Location, error) {
 | |
| 	regs, err := t.th.registers()
 | |
| 	if err != nil {
 | |
| 		return nil, err
 | |
| 	}
 | |
| 	pc := regs.PC()
 | |
| 	f, l, fn := t.p.bi.PCToLine(pc)
 | |
| 	return &proc.Location{PC: pc, File: f, Line: l, Fn: fn}, nil
 | |
| }
 | |
| 
 | |
| // Breakpoint returns the current breakpoint this thread is stopped at.
 | |
| // For core files this always returns an empty BreakpointState struct, as
 | |
| // there are no breakpoints when debugging core files.
 | |
| func (t *thread) Breakpoint() *proc.BreakpointState {
 | |
| 	return &proc.BreakpointState{}
 | |
| }
 | |
| 
 | |
| // ThreadID returns the ID for this thread.
 | |
| func (t *thread) ThreadID() int {
 | |
| 	return int(t.th.pid())
 | |
| }
 | |
| 
 | |
| // Registers returns the current value of the registers for this thread.
 | |
| func (t *thread) Registers() (proc.Registers, error) {
 | |
| 	return t.th.registers()
 | |
| }
 | |
| 
 | |
| // RestoreRegisters will only return an error for core files,
 | |
| // you cannot change register values for core files.
 | |
| func (t *thread) RestoreRegisters(proc.Registers) error {
 | |
| 	return ErrChangeRegisterCore
 | |
| }
 | |
| 
 | |
| // BinInfo returns information about the binary.
 | |
| func (t *thread) BinInfo() *proc.BinaryInfo {
 | |
| 	return t.p.bi
 | |
| }
 | |
| 
 | |
| // StepInstruction will only return an error for core files,
 | |
| // you cannot execute a core file.
 | |
| func (t *thread) StepInstruction() error {
 | |
| 	return ErrContinueCore
 | |
| }
 | |
| 
 | |
| // SetCurrentBreakpoint will always just return nil
 | |
| // for core files, as there are no breakpoints in core files.
 | |
| func (t *thread) SetCurrentBreakpoint(adjustPC bool) error {
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| // SoftExc returns true if this thread received a software exception during the last resume.
 | |
| func (t *thread) SoftExc() bool {
 | |
| 	return false
 | |
| }
 | |
| 
 | |
| // Common returns a struct containing common information
 | |
| // across thread implementations.
 | |
| func (t *thread) Common() *proc.CommonThread {
 | |
| 	return &t.common
 | |
| }
 | |
| 
 | |
| // SetPC will always return an error, you cannot
 | |
| // change register values when debugging core files.
 | |
| func (t *thread) SetPC(uint64) error {
 | |
| 	return ErrChangeRegisterCore
 | |
| }
 | |
| 
 | |
| // SetSP will always return an error, you cannot
 | |
| // change register values when debugging core files.
 | |
| func (t *thread) SetSP(uint64) error {
 | |
| 	return ErrChangeRegisterCore
 | |
| }
 | |
| 
 | |
| // SetDX will always return an error, you cannot
 | |
| // change register values when debugging core files.
 | |
| func (t *thread) SetDX(uint64) error {
 | |
| 	return ErrChangeRegisterCore
 | |
| }
 | |
| 
 | |
| // SetReg will always return an error, you cannot
 | |
| // change register values when debugging core files.
 | |
| func (t *thread) SetReg(regNum uint64, reg *op.DwarfRegister) error {
 | |
| 	return ErrChangeRegisterCore
 | |
| }
 | |
| 
 | |
| // Breakpoints will return all breakpoints for the process.
 | |
| func (p *process) Breakpoints() *proc.BreakpointMap {
 | |
| 	return &p.breakpoints
 | |
| }
 | |
| 
 | |
| // EraseBreakpoint will always return an error as you cannot set or clear
 | |
| // breakpoints on core files.
 | |
| func (p *process) EraseBreakpoint(bp *proc.Breakpoint) error {
 | |
| 	return proc.NoBreakpointError{Addr: bp.Addr}
 | |
| }
 | |
| 
 | |
| // ClearInternalBreakpoints will always return nil and have no
 | |
| // effect since you cannot set breakpoints on core files.
 | |
| func (p *process) ClearInternalBreakpoints() error {
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| func continueOnce(procs []proc.ProcessInternal, cctx *proc.ContinueOnceContext) (proc.Thread, proc.StopReason, error) {
 | |
| 	return nil, proc.StopUnknown, ErrContinueCore
 | |
| }
 | |
| 
 | |
| // StepInstruction will always return an error
 | |
| // as you cannot control execution of a core file.
 | |
| func (p *process) StepInstruction() error {
 | |
| 	return ErrContinueCore
 | |
| }
 | |
| 
 | |
| // RequestManualStop will return nil and have no effect
 | |
| // as you cannot control execution of a core file.
 | |
| func (p *process) RequestManualStop(cctx *proc.ContinueOnceContext) error {
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| // CheckAndClearManualStopRequest will always return false and
 | |
| // have no effect since there are no manual stop requests as
 | |
| // there is no controlling execution of a core file.
 | |
| func (p *process) CheckAndClearManualStopRequest() bool {
 | |
| 	return false
 | |
| }
 | |
| 
 | |
| // Memory returns the process memory.
 | |
| func (p *process) Memory() proc.MemoryReadWriter {
 | |
| 	return p
 | |
| }
 | |
| 
 | |
| // Detach will always return nil and have no
 | |
| // effect as you cannot detach from a core file
 | |
| // and have it continue execution or exit.
 | |
| func (p *process) Detach(bool) error {
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| // Valid returns whether the process is active. Always returns true
 | |
| // for core files as it cannot exit or be otherwise detached from.
 | |
| func (p *process) Valid() (bool, error) {
 | |
| 	return true, nil
 | |
| }
 | |
| 
 | |
| // ResumeNotify is a no-op on core files as we cannot
 | |
| // control execution.
 | |
| func (p *process) ResumeNotify(chan<- struct{}) {
 | |
| }
 | |
| 
 | |
| // ThreadList will return a list of all threads currently in the process.
 | |
| func (p *process) ThreadList() []proc.Thread {
 | |
| 	r := make([]proc.Thread, 0, len(p.Threads))
 | |
| 	for _, v := range p.Threads {
 | |
| 		r = append(r, v)
 | |
| 	}
 | |
| 	return r
 | |
| }
 | |
| 
 | |
| // FindThread will return the thread with the corresponding thread ID.
 | |
| func (p *process) FindThread(threadID int) (proc.Thread, bool) {
 | |
| 	t, ok := p.Threads[threadID]
 | |
| 	return t, ok
 | |
| }
 | |
| 
 | |
| func (p *process) MemoryMap() ([]proc.MemoryMapEntry, error) {
 | |
| 	return nil, proc.ErrMemoryMapNotSupported
 | |
| }
 | |
| 
 | |
| func (p *process) DumpProcessNotes(notes []elfwriter.Note, threadDone func()) (threadsDone bool, out []elfwriter.Note, err error) {
 | |
| 	return false, notes, nil
 | |
| }
 | |
| 
 | |
| func (dbp *process) GetBufferedTracepoints() []ebpf.RawUProbeParams {
 | |
| 	return nil
 | |
| }
 | 
