* alpha-nat.c: When compiling under Linux, include <asm/reg.h> and
<alpha/ptrace.h> instead of <machine/reg.h>
+Tue Jul 2 13:58:10 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (inf_validate_task_sc):
+ Give terminal to gdb while asking question.
+ (inf_resume): Don't validate the task suspend-count while execing.
+
+Thu Jun 13 11:04:52 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (inf_validate_task_sc): Query user before clearing any
+ additional suspend count.
+ (S_proc_wait_reply, gnu_attach): Don't call inf_validate_task_sc.
+ (inf_resume): Call inf_validate_task_sc here.
+ (gnu_resume): Call inf_update_procs to ensure noticing new threads.
+
+Fri Jun 7 17:00:43 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (gnu_create_inferior: attach_to_child): Return PID.
+
Thu May 23 15:13:56 1996 Jeffrey A Law (law@cygnus.com)
* h8300-tdep.c (IS_PUSH): Refine.
* remote.c (remote_detach): Send a command 'D' to the target
when detaching, update the function's comments.
+Thu Jun 6 16:11:38 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (thread_cmd_list): New declaration.
+ (parse_int_arg): New function.
+
+Wed Jun 5 17:28:04 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.h (struct proc): Add DETACH_SC field.
+ * gnu-nat.c (make_proc): Set DETACH_SC.
+ (struct inf): Add DETACH_SC & DEFAULT_THREAD_DETACH_SC fields.
+ (make_inf): Set DETACH_SC & DEFAULT_THREAD_DETACH_SC fields.
+ (add_thread_commands): Add set/show for detach-suspend-count.
+ Add takeover-suspend-count cmd.
+ (inf_detach): Set suspend counts to the detach SC, not 0.
+ (set_thread_detach_sc_cmd, show_thread_detach_sc_cmd,
+ set_task_detach_sc_cmd, show_task_detach_sc_cmd,
+ set_thread_default_thread_detach_sc_cmd,
+ show_thread_default_thread_detach_sc_cmd): New functions.
+ (show_task_cmd): Also show detach-suspend-count values.
+ (thread_takeover_sc_cmd): New function.
+
+Fri May 31 16:49:24 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (show_thread_run_cmd): Actually print state.
+
+Thu May 30 10:47:56 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (inf_signal): Make unforwardable exceptions an error.
+
+Tue May 28 17:06:36 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (inf_validate_stopped): proc_getprocinfo takes a
+ pointer to the flags now, not the flags themselves.
+
+Mon May 27 13:31:17 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (gnu_wait): Print debugging msgs for pending execs.
+ (gnu_create_inferior): Check return from ptrace.
+
+Sun May 26 16:56:35 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.h (struct proc): Add DEAD field.
+ * gnu-nat.c (make_proc): Initialize DEAD.
+ (inf_set_traced, inf_validate_task_sc, inf_validate_procs: Frob it.
+ (gnu_wait): Only abort for 0 threads if the task isn't dead.
+
+Sat May 25 17:06:05 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (inf_signal): Pass SIGCODE when posting a signal.
+
+Wed May 22 18:44:28 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (S_proc_wait_reply): Add SIGCODE argument.
+ (inf_set_traced): Only give no-signal-thread error message if
+ turning *on* tracing.
+
+Wed May 15 13:03:16 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (inf_validate_procs): If INF has no threads, always
+ set inf->threads_up_to_date to 0.
+ (inf_signal): Pass in new SIGCODE argument to msg_sig_post_untraced.
+ (gnu_wait): Pass in new TIMEOUT arg to interrupt_operation.
+ (proc_update_sc): Cast thread state arg to thread_set_state.
+ (proc_get_state): Cast thread state arg to thread_get_state.
+ (inf_validate_task_sc): Cast task_basic_info arg to task_info.
+ * i386gnu-nat.c (gnu_fetch_registers, gnu_store_registers): Call
+ inf_update_procs before we lookup the thread.
+ * config/i386/i386gnu.mh (MH_CFLAGS): New variable.
+
+Tue May 7 17:52:33 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (gnu_kill_inferior): Use inf_set_task to clear the task.
+
+Mon May 6 19:06:49 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (inf_set_traced): Use msg_set_init_int with
+ INIT_TRACEMASK instead of setting the exec flags.
+
+Fri May 3 19:10:57 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (inf_validate_procs): Don't clear INF->task if we find
+ the task's died, so others have a chance at it.
+ (gnu_resume): When single-stepping a single thread, given an error
+ if there is no such thread. When single-stepping one but running
+ the others, just given a warning and still run all the threads.
+ (gnu_wait): If there seem to be no threads, look harder, and
+ signal an error if there really aren't any.
+ (gnu_attach): Reset thread numbering to 0.
+
+ * i386gnu-nat.c (gnu_fetch_registers, gnu_store_registers): Give
+ thread name in warning messages.
+
+ * gnu-nat.c (active_inf): New function.
+ (show_sig_thread_cmd, show_stopped_cmd): Use it.
+ (info_port_rights, info_send_rights_cmd, info_port_sets_cmd,
+ info_recv_rights_cmd, info_port_rights_cmd, info_port_rights_cmd):
+ New functions.
+ (add_task_commands): Add new port-right info commands.
+
+Fri Apr 26 20:42:16 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (gnu_wait): Instead of _hurd_intr_rpc_mach_msg, just
+ use mach_msg with MACH_RCV_INTERRUPT.
+ (set_noninvasive_cmd): New function.
+ (add_task_commands): Add command entry for `set noninvasive'.
+
+Mon Mar 4 14:12:02 1996 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (gnu_read_inferior): Use hurd_safe_memmove, not safe_bcopy.
+ (safe_bcopy): Function removed.
+
+Mon Dec 4 14:18:26 1995 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c (proc_update_sc): Assert only threads can have state.
+ (make_proc): Initialize state_valid & state_changed fields.
+
+Tue Nov 28 17:51:21 1995 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * reply_mig_hack.awk: New file.
+
+Tue Nov 14 14:31:03 1995 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * breakpoint.c (breakpoint_1): Print breakpoint thread field.
+
+ * lynx-nat.c (child_wait): Return TARGET_WAITKIND_SPURIOUS for new
+ threads.
+
+Mon Nov 13 18:30:53 1995 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * target.c (debug_to_check_threads): New function.
+
+ * inflow.c (terminal_init_inferior_with_pgrp): New function.
+ (terminal_init_inferior): Call terminal_init_inferior_with_pgrp.
+ * inferior.h (terminal_init_inferior_with_pgrp): New declaration,
+ but only if PROCESS_GROUP_TYPE is defined.
+
+Mon Nov 6 16:42:09 1995 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * target.c (debug_to_thread_alive): Pass through the return value.
+
+Thu Nov 2 18:05:00 1995 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * target.c (signals, target_signal_from_host, target_signal_to_host):
+ Add mach exceptions.
+ * target.h (enum target_signal): Add mach exceptions.
+
+Mon Oct 30 16:41:04 1995 Miles Bader <miles@gnu.ai.mit.edu>
+
+ * gnu-nat.c: New file: gnu native backend.
+ * i386gnu-nat.c: New file: i386-specific part of gnu native backend.
+ * gnu-nat.h: New file.
+ * config/nm-gnu.h: New file.
+ * config/tm-i386gnu.h: New file.
+ * config/xm-i386gnu.h: New file.
+ * config/i386/i386gnu.mh: New file.
+ * config/i386/i386gnu.mt: New file.
+
Wed Feb 28 15:50:12 1996 Fred Fish <fnf@cygnus.com>
* Makefile.in (VERSION): Bump version to 4.15.2 to establish
#include <hurd/interrupt.h>
#include <hurd/sigpreempt.h>
+#include <portinfo.h>
+
#include "defs.h"
#include "inferior.h"
#include "symtab.h"
(pausing individual threads as necessary). */
int pause_sc;
+ /* The task suspend count left when detaching from a task. */
+ int detach_sc;
+
/* The initial values used for the run_sc and pause_sc of newly discovered
threads -- see the definition of those fields in struct proc. */
int default_thread_run_sc;
int default_thread_pause_sc;
+ int default_thread_detach_sc;
/* True if the process should be traced when started/attached. Newly
started processes *must* be traced at first to exec them properly, but
assert (proc_is_thread (proc));
proc_debug (proc, "storing back changed thread state");
err = thread_set_state (proc->port, THREAD_STATE_FLAVOR,
- &proc->state, THREAD_STATE_SIZE);
+ (thread_state_t)&proc->state, THREAD_STATE_SIZE);
if (! err)
proc->state_changed = 0;
}
mach_msg_type_number_t state_size = THREAD_STATE_SIZE;
error_t err =
thread_get_state (proc->port, THREAD_STATE_FLAVOR,
- &proc->state, &state_size);
+ (thread_state_t)&proc->state, &state_size);
proc_debug (proc, "getting thread state");
proc->state_valid = !err;
}
{
if (will_modify)
proc->state_changed = 1;
- return &proc->state;
+ return (thread_state_t)&proc->state;
}
else
return 0;
proc->next = 0;
proc->saved_exc_port = MACH_PORT_NULL;
proc->exc_port = MACH_PORT_NULL;
+
proc->sc = 0;
proc->cur_sc = 0;
+
+ /* Note that these are all the values for threads; the task simply uses the
+ corresponding field in INF directly. */
proc->run_sc = inf->default_thread_run_sc;
proc->pause_sc = inf->default_thread_pause_sc;
+ proc->detach_sc = inf->default_thread_detach_sc;
proc->resume_sc = proc->run_sc;
+
proc->aborted = 0;
+ proc->dead = 0;
proc->state_valid = 0;
proc->state_changed = 0;
inf->no_wait = 0;
inf->pending_execs = 0;
inf->pause_sc = 1;
+ inf->detach_sc = 0;
inf->default_thread_run_sc = 0;
inf->default_thread_pause_sc = 0;
+ inf->default_thread_detach_sc = 0;
inf->want_signals = 1; /* By default */
inf->want_exceptions = 1; /* By default */
mach_msg_type_number_t noise_len = 0;
struct procinfo *pi;
mach_msg_type_number_t pi_len = 0;
+ int info_flags = 0;
error_t err =
- proc_getprocinfo (proc_server, inf->pid, 0,
+ proc_getprocinfo (proc_server, inf->pid, &info_flags,
(procinfo_t *)&pi, &pi_len, &noise, &noise_len);
if (! err)
}
}
-/* Validates INF's task suspend count. */
+/* Validates INF's task suspend count. If it's higher than we expect, verify
+ with the user before `stealing' the extra count. */
static void
inf_validate_task_sc (struct inf *inf)
{
struct task_basic_info info;
mach_msg_type_number_t info_len = TASK_BASIC_INFO_COUNT;
- error_t err = task_info (inf->task->port, TASK_BASIC_INFO, &info, &info_len);
- if (! err)
+ error_t err =
+ task_info (inf->task->port, TASK_BASIC_INFO, (task_info_t)&info, &info_len);
+
+ if (err)
+ inf->task->dead = 1; /* oh well */
+ else if (inf->task->cur_sc < info.suspend_count)
{
- if (inf->task->cur_sc < info.suspend_count)
- warning ("Pid %d is suspended; continuing will clear existing suspend count.", inf->pid);
+ int abort;
+
+ target_terminal_ours (); /* Allow I/O. */
+ abort =
+ !query ("Pid %d has an additional task suspend count of %d; clear it? ",
+ inf->pid, info.suspend_count - inf->task->cur_sc);
+ target_terminal_inferior (); /* Give it back to the child. */
+
+ if (abort)
+ error ("Additional task suspend count left untouched.");
+
inf->task->cur_sc = info.suspend_count;
}
}
inf_set_traced (struct inf *inf, int on)
{
if (on != inf->traced)
- if (inf->task)
+ if (inf->task && !inf->task->dead)
/* Make it take effect immediately. */
{
- error_t (*f)(mach_port_t, mach_port_t, int) =
- on ? msg_set_some_exec_flags : msg_clear_some_exec_flags;
+ sigset_t mask = on ? ~(sigset_t)0 : 0;
error_t err =
- INF_RESUME_MSGPORT_RPC (inf, (*f)(msgport, refport, EXEC_TRACED));
+ INF_RESUME_MSGPORT_RPC (inf, msg_set_init_int (msgport, refport,
+ INIT_TRACEMASK, mask));
if (err == EIEIO)
- warning ("Can't modify tracing state for pid %d: No signal thread",
- inf->pid);
+ {
+ if (on)
+ warning ("Can't modify tracing state for pid %d: No signal thread",
+ inf->pid);
+ inf->traced = on;
+ }
else if (err)
warning ("Can't modify tracing state for pid %d: %s",
inf->pid, strerror (err));
unsigned num_threads;
struct proc *task = inf->task;
- inf->threads_up_to_date = !inf->running;
+ /* If no threads are currently running, this function will guarantee that
+ things are up to date. The exception is if there are zero threads --
+ then it is almost certainly in an odd state, and probably some outside
+ agent will create threads. */
+ inf->threads_up_to_date = inf->threads ? !inf->running : 0;
if (task)
{
if (err)
/* TASK must be dead. */
{
- task->port = MACH_PORT_NULL;
- _proc_free (task);
- task = inf->task = 0;
+ task->dead = 1;
+ task = 0;
}
}
thread->sc = thread->resume_sc;
if (inf->task)
- inf->task->sc = 0;
+ {
+ if (! inf->pending_execs)
+ /* Try to make sure our task count is correct -- in the case where
+ we're waiting for an exec though, things are too volatile, so just
+ assume things will be reasonable (which they usually will be). */
+ inf_validate_task_sc (inf);
+ inf->task->sc = 0;
+ }
inf_update_suspends (inf);
}
inf_signal (inf, TARGET_SIGNAL_0);
proc_restore_exc_port (task);
- task->sc = 0;
+ task->sc = inf->detach_sc;
for (thread = inf->threads; thread; thread = thread->next)
{
proc_restore_exc_port (thread);
- thread->sc = 0;
+ thread->sc = thread->detach_sc;
}
inf_update_suspends (inf);
e->exception, e->code, e->subcode);
}
else
- warning ("Can't forward spontaneous exception (%s).", NAME);
+ error ("Can't forward spontaneous exception (%s).", NAME);
}
else
/* A Unix signal. */
msg_sig_post_untraced_request (msgport,
inf->event_port,
MACH_MSG_TYPE_MAKE_SEND_ONCE,
- host_sig,
+ host_sig, 0,
refport));
if (! err)
/* Posting an untraced signal automatically continues it.
{
inf_debug (inf, "sending %s to unstopped process (so resuming signal thread)", NAME);
err =
- INF_RESUME_MSGPORT_RPC (inf,
- msg_sig_post_untraced (msgport,
- host_sig, refport));
+ INF_RESUME_MSGPORT_RPC (inf, msg_sig_post_untraced (msgport,
+ host_sig, 0, refport));
}
if (err == EIEIO)
struct proc *thread;
struct inf *inf = current_inferior;
+ assert (inf->task);
+
+ if (!inf->threads && !inf->pending_execs)
+ /* No threads! Assume that maybe some outside agency is frobbing our
+ task, and really look for new threads. If we can't find any, just tell
+ the user to try again later. */
+ {
+ inf_validate_procs (inf);
+ if (!inf->threads && !inf->task->dead)
+ error ("There are no threads; try again later.");
+ }
+
waiting_inf = inf;
inf_debug (inf, "waiting for: %d", tid);
outstanding wait request, so we have to cancel the previous one. */
{
inf_debug (inf, "cancelling previous wait on pid %d", proc_wait_pid);
- interrupt_operation (proc_server);
+ interrupt_operation (proc_server, 0);
}
err =
(3) wait reply from the proc server. */
inf_debug (inf, "waiting for an event...");
- err = _hurd_intr_rpc_mach_msg (&msg.hdr, MACH_RCV_MSG, 0,
- sizeof (struct msg),
- inf->event_port, MACH_PORT_NULL);
+ err = mach_msg (&msg.hdr, MACH_RCV_MSG | MACH_RCV_INTERRUPT,
+ 0, sizeof (struct msg), inf->event_port,
+ MACH_MSG_TIMEOUT_NONE, MACH_PORT_NULL);
/* Re-suspend the task. */
inf_suspend (inf);
- if (err == EINTR)
+ if (err == EMACH_RCV_INTERRUPTED)
inf_debug (inf, "interrupted");
else if (err)
error ("Couldn't wait for an event: %s", strerror (err));
/* Since gdb is actually counting the number of times the inferior
stops, expecting one stop per exec, we only return major events
while execing. */
- w->suppress = 1;
+ {
+ w->suppress = 1;
+ inf_debug (inf, "pending_execs = %d, ignoring minor event",
+ inf->pending_execs);
+ }
else if (kind == TARGET_WAITKIND_STOPPED
&& w->status.value.sig == TARGET_SIGNAL_TRAP)
/* Ah hah! A SIGTRAP from the inferior while starting up probably
means we've succesfully completed an exec! */
- if (--inf->pending_execs == 0)
- /* We're done! */
- {
- prune_threads (1); /* Get rid of the old shell threads */
- renumber_threads (0); /* Give our threads reasonable names. */
- }
+ {
+ if (--inf->pending_execs == 0)
+ /* We're done! */
+ {
+ prune_threads (1); /* Get rid of the old shell threads */
+ renumber_threads (0); /* Give our threads reasonable names. */
+ }
+ inf_debug (inf, "pending exec completed, pending_execs => %d",
+ inf->pending_execs);
+ }
}
if (inf->wait.suppress)
/* Record the exception so that we can forward it later. */
{
if (thread->exc_port == port)
- inf->wait.exc.handler = thread->saved_exc_port;
+ {
+ inf_debug (waiting_inf, "Handler is thread exeption port <%d>",
+ thread->saved_exc_port);
+ inf->wait.exc.handler = thread->saved_exc_port;
+ }
else
{
+ inf_debug (waiting_inf, "Handler is task exeption port <%d>",
+ inf->task->saved_exc_port);
inf->wait.exc.handler = inf->task->saved_exc_port;
assert (inf->task->exc_port == port);
}
inf->wait.status.kind = TARGET_WAITKIND_SIGNALLED;
inf->wait.status.value.sig = TARGET_SIGNAL_KILL;
}
-\f
-/* Notify server routines. The only real one is dead name notification. */
+/* Notify server routines. The only real one is dead name notification. */
error_t
do_mach_notify_dead_name (mach_port_t notify, mach_port_t dead_port)
{
return 0;
}
-
+\f
static error_t
ill_rpc (char *fun)
{
error_t
S_proc_wait_reply (mach_port_t reply, error_t err,
- int status, rusage_t rusage, pid_t pid)
+ int status, int sigcode, rusage_t rusage, pid_t pid)
{
struct inf *inf = waiting_inf;
- inf_debug (inf, "err = %s, pid = %d, status = 0x%x",
- err ? strerror (err) : "0", pid, status);
+ inf_debug (inf, "err = %s, pid = %d, status = 0x%x, sigcode = %d",
+ err ? strerror (err) : "0", pid, status, sigcode);
if (err && proc_wait_pid && (!inf->task || !inf->task->port))
/* Ack. The task has died, but the task-died notification code didn't
{
inf_debug (inf, "process has stopped itself");
inf->stopped = 1;
-
- /* We recheck the task suspend count here because the crash server
- messes with it in an unfriendly way, right before `stopping'. */
- inf_validate_task_sc (inf);
}
}
else
the process, as we're just going to stop it right away anyway. */
return;
+ inf_update_procs (inf);
+
if (tid < 0)
/* Allow all threads to run, except perhaps single-stepping one. */
{
/* Just allow a single thread to run. */
{
struct proc *thread = inf_tid_to_thread (inf, tid);
- assert (thread);
-
+ if (! thread)
+ error ("Can't run single thread id %d: no such thread!");
inf_debug (inf, "running one thread: %d/%d", inf->pid, thread->tid);
inf_set_threads_resume_sc (inf, thread, 0);
}
if (step)
{
step_thread = inf_tid_to_thread (inf, tid);
- assert (step_thread);
- inf_debug (inf, "stepping thread: %d/%d", inf->pid, step_thread->tid);
+ if (! step_thread)
+ warning ("Can't step thread id %d: no such thread.", tid);
+ else
+ inf_debug (inf, "stepping thread: %d/%d", inf->pid, step_thread->tid);
}
if (step_thread != inf->step_thread)
inf_set_step_thread (inf, step_thread);
{
proc_debug (task, "terminating...");
task_terminate (task->port);
- task->port = MACH_PORT_NULL;
- inf_validate_procs (current_inferior); /* Clear out the thread list &c */
+ inf_set_task (current_inferior, MACH_PORT_NULL);
}
target_mourn_inferior ();
}
{
/* We're in the child; make this process stop as soon as it execs. */
inf_debug (inf, "tracing self");
- ptrace (PTRACE_TRACEME, 0, 0, 0);
+ if (ptrace (PTRACE_TRACEME) != 0)
+ error ("ptrace (PTRACE_TRACEME) failed!");
}
- void attach_to_child (int pid)
+ int attach_to_child (int pid)
{
/* Attach to the now stopped child, which is actually a shell... */
inf_debug (inf, "attaching to child: %d", pid);
inf_resume (inf);
startup_inferior (pid, inf->pending_execs);
+
+ return pid;
}
inf_debug (inf, "creating inferior");
/* If the process was stopped before we attached, make it continue the next
time the user does a continue. */
inf_validate_stopped (inf);
- inf_validate_task_sc (inf);
+
+ renumber_threads (0); /* Give our threads reasonable names. */
}
\f
/* Take a program previously attached to and detaches it.
extern struct cmd_list_element *set_thread_default_cmd_list;
extern struct cmd_list_element *show_thread_default_cmd_list;
+static int
+parse_int_arg (char *args, char *cmd_prefix)
+{
+ if (args)
+ {
+ char *arg_end;
+ int val = strtoul (args, &arg_end, 10);
+ if (*args && *arg_end == '\0')
+ return val;
+ }
+ error ("Illegal argument for \"%s\" command, should be an integer.", cmd_prefix);
+}
+
static int
_parse_bool_arg (char *args, char *t_val, char *f_val, char *cmd_prefix)
{
return thread;
}
+/* Returns the current inferior, but signals an error if it has no task. */
+static struct inf *
+active_inf ()
+{
+ struct inf *inf = cur_inf ();
+ if (! inf->task)
+ error ("No current process.");
+ return inf;
+}
+\f
static void
set_task_pause_cmd (char *args, int from_tty)
{
: (inf->pause_sc == 0 ? "won't be" : "will be"));
}
+static void
+set_task_detach_sc_cmd (char *args, int from_tty)
+{
+ cur_inf ()->detach_sc = parse_int_arg (args, "set task detach-suspend-count");
+}
+
+static void
+show_task_detach_sc_cmd (char *args, int from_tty)
+{
+ check_empty (args, "show task detach-suspend-count");
+ printf_unfiltered ("The inferior task will be left with a suspend count of %d when detaching.\n",
+ cur_inf ()->detach_sc);
+}
+\f
static void
set_thread_default_pause_cmd (char *args, int from_tty)
{
check_empty (args, "show thread default pause");
printf_unfiltered ("New threads %s suspended while gdb has control%s.\n",
sc ? "are" : "aren't",
- !sc && inf->pause_sc ? "(but the task is)" : "");
+ !sc && inf->pause_sc ? " (but the task is)" : "");
}
static void
inf->default_thread_run_sc == 0 ? "are" : "aren't");
}
+static void
+set_thread_default_detach_sc_cmd (char *args, int from_tty)
+{
+ cur_inf ()->default_thread_detach_sc =
+ parse_int_arg (args, "set thread default detach-suspend-count");
+}
+
+static void
+show_thread_default_detach_sc_cmd (char *args, int from_tty)
+{
+ check_empty (args, "show thread default detach-suspend-count");
+ printf_unfiltered ("New threads will get a detach-suspend-count of %d.\n",
+ cur_inf ()->default_thread_detach_sc);
+}
+\f
/* Steal a send right called NAME in the inferior task, and make it PROC's
saved exception port. */
static void
proc_string (proc), strerror (err));
}
}
-
+\f
static void
set_task_exc_port_cmd (char *args, int from_tty)
{
steal_exc_port (inf->task, parse_and_eval_address (args));
}
-static void
-set_signals_cmd (char *args, int from_tty)
-{
- int trace;
- struct inf *inf = cur_inf ();
-
- inf->want_signals = parse_bool_arg (args, "set signals");
-
- if (inf->task && inf->want_signals != inf->traced)
- /* Make this take effect immediately in a running process. */
- inf_set_traced (inf, inf->want_signals);
-}
-
-static void
-show_signals_cmd (char *args, int from_tty)
-{
- struct inf *inf = cur_inf ();
- check_empty (args, "show signals");
- printf_unfiltered ("The inferior process's signals %s intercepted.\n",
- inf->task
- ? (inf->traced ? "are" : "aren't")
- : (inf->want_signals ? "will be" : "won't be"));
-}
-
static void
set_stopped_cmd (char *args, int from_tty)
{
static void
show_stopped_cmd (char *args, int from_tty)
{
- struct inf *inf = cur_inf ();
+ struct inf *inf = active_inf ();
check_empty (args, "show stopped");
- if (! inf->task)
- error ("No current process.");
printf_unfiltered ("The inferior process %s stopped.\n",
inf->stopped ? "is" : "isn't");
}
static void
show_sig_thread_cmd (char *args, int from_tty)
{
- struct inf *inf = cur_inf ();
+ struct inf *inf = active_inf ();
check_empty (args, "show signal-thread");
- if (! inf->task)
- error ("No current process.");
if (inf->signal_thread)
printf_unfiltered ("The signal thread is %s.\n",
proc_string (inf->signal_thread));
else
printf_unfiltered ("There is no signal thread.\n");
}
+\f
+static void
+set_signals_cmd (char *args, int from_tty)
+{
+ int trace;
+ struct inf *inf = cur_inf ();
+
+ inf->want_signals = parse_bool_arg (args, "set signals");
+
+ if (inf->task && inf->want_signals != inf->traced)
+ /* Make this take effect immediately in a running process. */
+ inf_set_traced (inf, inf->want_signals);
+}
+
+static void
+show_signals_cmd (char *args, int from_tty)
+{
+ struct inf *inf = cur_inf ();
+ check_empty (args, "show signals");
+ printf_unfiltered ("The inferior process's signals %s intercepted.\n",
+ inf->task
+ ? (inf->traced ? "are" : "aren't")
+ : (inf->want_signals ? "will be" : "won't be"));
+}
static void
set_exceptions_cmd (char *args, int from_tty)
? (inf->want_exceptions ? "are" : "aren't")
: (inf->want_exceptions ? "will be" : "won't be"));
}
-
+\f
static void
set_task_cmd (char *args, int from_tty)
{
show_stopped_cmd (0, from_tty);
show_sig_thread_cmd (0, from_tty);
}
+
+ if (inf->detach_sc != 0)
+ show_task_detach_sc_cmd (0, from_tty);
+ if (inf->default_thread_detach_sc != 0)
+ show_thread_default_detach_sc_cmd (0, from_tty);
+}
+\f
+static void
+set_noninvasive_cmd (char *args, int from_tty)
+{
+ /* Invert the sense of the arg for each component. */
+ char *inv_args = parse_bool_arg (args, "set noninvasive") ? "off" : "on";
+
+ set_task_pause_cmd (inv_args, from_tty);
+ set_signals_cmd (inv_args, from_tty);
+ set_exceptions_cmd (inv_args, from_tty);
+}
+\f
+static void
+info_port_rights (char *args, mach_port_type_t only)
+{
+ struct inf *inf = active_inf ();
+ value_ptr vmark = value_mark ();
+
+ if (args)
+ /* Explicit list of port rights. */
+ {
+ while (*args)
+ {
+ value_ptr val = parse_to_comma_and_eval (&args);
+ long right = value_as_long (val);
+ error_t err =
+ print_port_info (right, 0, inf->task->port, PORTINFO_DETAILS,
+ stdout);
+ if (err)
+ error ("%ld: %s.", right, strerror (err));
+ }
+ }
+ else
+ /* Print all of them. */
+ {
+ error_t err =
+ print_task_ports_info (inf->task->port, only, PORTINFO_DETAILS,
+ stdout);
+ if (err)
+ error ("%s.", strerror (err));
+ }
+
+ value_free_to_mark (vmark);
}
+static void
+info_send_rights_cmd (char *args, int from_tty)
+{
+ info_port_rights (args, MACH_PORT_TYPE_SEND);
+}
+static void
+info_recv_rights_cmd (char *args, int from_tty)
+{
+ info_port_rights (args, MACH_PORT_TYPE_RECEIVE);
+}
+static void
+info_port_sets_cmd (char *args, int from_tty)
+{
+ info_port_rights (args, MACH_PORT_TYPE_PORT_SET);
+}
+static void
+info_dead_names_cmd (char *args, int from_tty)
+{
+ info_port_rights (args, MACH_PORT_TYPE_DEAD_NAME);
+}
+static void
+info_port_rights_cmd (char *args, int from_tty)
+{
+ info_port_rights (args, ~0);
+}
+\f
static void add_task_commands ()
{
add_cmd ("pause", class_run, set_thread_default_pause_cmd,
"Show whether new threads are allowed to run (once gdb has noticed
them).",
&show_thread_default_cmd_list);
+ add_cmd ("detach-suspend-count", class_run, set_thread_default_detach_sc_cmd,
+ "Set the default detach-suspend-count value for new threads.",
+ &set_thread_default_cmd_list);
+ add_cmd ("detach-suspend-count", no_class, show_thread_default_detach_sc_cmd,
+ "Show the default detach-suspend-count value for new threads.",
+ &show_thread_default_cmd_list);
add_cmd ("signals", class_run, set_signals_cmd,
"Set whether the inferior process's signals will be intercepted.\n"
"Show whether exceptions in the inferior process will be trapped.",
&showlist);
-
-
add_prefix_cmd ("task", no_class, set_task_cmd,
"Command prefix for setting task attributes.",
&set_task_cmd_list, "set task ", 0, &setlist);
add_cmd ("pause", no_class, show_task_pause_cmd,
"Show whether the task is suspended while gdb has control.",
&show_task_cmd_list);
+ add_cmd ("detach-suspend-count", class_run, set_task_detach_sc_cmd,
+ "Set the suspend count will leave on the thread when detaching.",
+ &set_task_cmd_list);
+ add_cmd ("detach-suspend-count", no_class, show_task_detach_sc_cmd,
+ "Show the suspend count will leave on the thread when detaching.",
+ &show_task_cmd_list);
add_cmd ("exception-port", no_class, set_task_exc_port_cmd,
"Set the task exception port to which we forward exceptions.\n"
&set_task_cmd_list);
add_alias_cmd ("excp", "exception-port", no_class, 1, &set_task_cmd_list);
add_alias_cmd ("exc-port", "exception-port", no_class, 1, &set_task_cmd_list);
+
+ /* A convenient way of turning on all options require to noninvasively
+ debug running tasks. */
+ add_cmd ("noninvasive", no_class, set_noninvasive_cmd,
+ "Set task options so that we interfere as little as possible.\n"
+ "This is the same as setting `task pause', `exceptions', and"
+ "`signals' to the opposite value.",
+ &setlist);
+
+ /* Commands to show information about the task's ports. */
+ add_cmd ("send-rights", class_info, info_send_rights_cmd,
+ "Show information about the task's send rights",
+ &infolist);
+ add_cmd ("receive-rights", class_info, info_recv_rights_cmd,
+ "Show information about the task's receive rights",
+ &infolist);
+ add_cmd ("port-rights", class_info, info_send_rights_cmd,
+ "Show information about the task's port rights",
+ &infolist);
+ add_cmd ("port-sets", class_info, info_port_sets_cmd,
+ "Show information about the task's port sets",
+ &infolist);
+ add_cmd ("dead-names", class_info, info_dead_names_cmd,
+ "Show information about the task's dead names",
+ &infolist);
+ add_info_alias ("ports", "port-rights", 1);
+ add_info_alias ("port", "port-rights", 1);
+ add_info_alias ("psets", "port-sets", 1);
}
\f
/* User thread commands. */
extern struct cmd_list_element *set_thread_cmd_list;
extern struct cmd_list_element *show_thread_cmd_list;
+extern struct cmd_list_element *thread_cmd_list;
static void
set_thread_pause_cmd (char *args, int from_tty)
printf_unfiltered ("Thread %s %s suspended while gdb has control%s.\n",
proc_string (thread),
sc ? "is" : "isn't",
- !sc && thread->inf->pause_sc ? "(but the task is)" : "");
+ !sc && thread->inf->pause_sc ? " (but the task is)" : "");
}
static void
{
struct proc *thread = cur_thread ();
check_empty (args, "show thread run");
- printf_unfiltered ("Thread %s allowed to run.",
+ printf_unfiltered ("Thread %s %s allowed to run.",
proc_string (thread),
thread->run_sc == 0 ? "is" : "isn't");
}
+static void
+set_thread_detach_sc_cmd (char *args, int from_tty)
+{
+ cur_thread ()->detach_sc = parse_int_arg (args, "set thread detach-suspend-count");
+}
+
+static void
+show_thread_detach_sc_cmd (char *args, int from_tty)
+{
+ struct proc *thread = cur_thread ();
+ check_empty (args, "show thread detach-suspend-count");
+ printf_unfiltered ("Thread %s will be left with a suspend count of %d when detaching.\n",
+ proc_string (thread),
+ thread->detach_sc);
+}
+
static void
set_thread_exc_port_cmd (char *args, int from_tty)
{
static void
show_thread_cmd (char *args, int from_tty)
{
+ struct proc *thread = cur_thread ();
check_empty (args, "show thread");
show_thread_run_cmd (0, from_tty);
show_thread_pause_cmd (0, from_tty);
+ if (thread->detach_sc != 0)
+ show_thread_detach_sc_cmd (0, from_tty);
+}
+
+static void
+thread_takeover_sc_cmd (char *args, int from_tty)
+{
+ struct proc *thread = cur_thread ();
+ thread_basic_info_data_t _info;
+ thread_basic_info_t info = &_info;
+ mach_msg_type_number_t info_len = THREAD_BASIC_INFO_COUNT;
+ error_t err =
+ thread_info (thread->port, THREAD_BASIC_INFO, (int *)&info, &info_len);
+ if (err)
+ error ("%s.", strerror (err));
+ thread->sc = info->suspend_count;
+ if (from_tty)
+ printf_unfiltered ("Suspend count was %d.\n", thread->sc);
+ if (info != &_info)
+ vm_deallocate (mach_task_self (), (vm_address_t)info, info_len * sizeof (int));
}
add_thread_commands ()
"Show whether the current thread is allowed to run.",
&show_thread_cmd_list);
+ add_cmd ("detach-suspend-count", class_run, set_thread_detach_sc_cmd,
+ "Set the suspend count will leave on the thread when detaching.\n"
+ "Note that this is relative to suspend count when gdb noticed the thread;\n"
+ "use the `thread takeover-suspend-count' to force it to an absolute value.",
+ &set_thread_cmd_list);
+ add_cmd ("detach-suspend-count", no_class, show_thread_detach_sc_cmd,
+ "Show the suspend count will leave on the thread when detaching."
+ "Note that this is relative to suspend count when gdb noticed the thread;\n"
+ "use the `thread takeover-suspend-count' to force it to an absolute value.",
+ &show_thread_cmd_list);
+
add_cmd ("exception-port", no_class, set_thread_exc_port_cmd,
"Set the exception port to which we forward exceptions for the\n"
"current thread, overriding the task exception port.\n"
&set_thread_cmd_list);
add_alias_cmd ("excp", "exception-port", no_class, 1, &set_thread_cmd_list);
add_alias_cmd ("exc-port", "exception-port", no_class, 1, &set_thread_cmd_list);
+
+ add_cmd ("takeover-suspend-count", no_class, thread_takeover_sc_cmd,
+ "Force the threads absolute suspend-count to be gdb's.\n"
+ "Prior to giving this command, gdb's thread suspend-counts are relative to\n"
+ "the thread's initial suspend-count when gdb notices the threads.",
+ &thread_cmd_list);
}
\f
void
/* Variables that describe the inferior process running under GDB:
Where it is, why it stopped, and how to step it.
- Copyright 1986, 1989, 1992 Free Software Foundation, Inc.
+ Copyright 1986, 1989, 1992, 1996 Free Software Foundation, Inc.
This file is part of GDB.
You should have received a copy of the GNU General Public License
along with this program; if not, write to the Free Software
-Foundation, Inc., 675 Mass Ave, Cambridge, MA 02139, USA. */
+Foundation, Inc., 59 Temple Place - Suite 330, Boston, MA 02111-1307, USA. */
#if !defined (INFERIOR_H)
#define INFERIOR_H 1
/* For bpstat. */
#include "breakpoint.h"
-/* For FRAME_ADDR. */
-#include "frame.h"
-
/* For enum target_signal. */
#include "target.h"
-/*
- * Structure in which to save the status of the inferior. Save
- * through "save_inferior_status", restore through
- * "restore_inferior_status".
- * This pair of routines should be called around any transfer of
- * control to the inferior which you don't want showing up in your
- * control variables.
- */
+/* Structure in which to save the status of the inferior. Save
+ through "save_inferior_status", restore through
+ "restore_inferior_status".
+ This pair of routines should be called around any transfer of
+ control to the inferior which you don't want showing up in your
+ control variables. */
+
struct inferior_status {
enum target_signal stop_signal;
CORE_ADDR stop_pc;
- FRAME_ADDR stop_frame_address;
bpstat stop_bpstat;
int stop_step;
int stop_stack_dummy;
int trap_expected;
CORE_ADDR step_range_start;
CORE_ADDR step_range_end;
- FRAME_ADDR step_frame_address;
+ CORE_ADDR step_frame_address;
int step_over_calls;
CORE_ADDR step_resume_break_address;
int stop_after_trap;
int stop_soon_quietly;
- FRAME_ADDR selected_frame_address;
+ CORE_ADDR selected_frame_address;
int selected_level;
char stop_registers[REGISTER_BYTES];
int proceed_to_finish;
};
-extern void
-save_inferior_status PARAMS ((struct inferior_status *, int));
+/* This macro gives the number of registers actually in use by the
+ inferior. This may be less than the total number of registers,
+ perhaps depending on the actual CPU in use or program being run. */
+
+#ifndef ARCH_NUM_REGS
+#define ARCH_NUM_REGS NUM_REGS
+#endif
+
+extern void save_inferior_status PARAMS ((struct inferior_status *, int));
-extern void
-restore_inferior_status PARAMS ((struct inferior_status *));
+extern void restore_inferior_status PARAMS ((struct inferior_status *));
extern void set_sigint_trap PARAMS ((void));
+
extern void clear_sigint_trap PARAMS ((void));
extern void set_sigio_trap PARAMS ((void));
+
extern void clear_sigio_trap PARAMS ((void));
/* File name for default use for standard in/out in the inferior. */
extern int inferior_pid;
+/* Inferior environment. */
+
+extern struct environ *inferior_environ;
+
/* Character array containing an image of the inferior programs' registers. */
extern char registers[];
extern char register_valid[NUM_REGS];
-extern void
-clear_proceed_status PARAMS ((void));
+extern void clear_proceed_status PARAMS ((void));
-extern void
-proceed PARAMS ((CORE_ADDR, enum target_signal, int));
+extern void proceed PARAMS ((CORE_ADDR, enum target_signal, int));
-extern void
-kill_inferior PARAMS ((void));
+extern void kill_inferior PARAMS ((void));
-extern void
-generic_mourn_inferior PARAMS ((void));
+extern void generic_mourn_inferior PARAMS ((void));
-extern void
-terminal_ours PARAMS ((void));
+extern void terminal_ours PARAMS ((void));
extern int run_stack_dummy PARAMS ((CORE_ADDR, char [REGISTER_BYTES]));
-extern CORE_ADDR
-read_pc PARAMS ((void));
+extern CORE_ADDR read_pc PARAMS ((void));
-extern CORE_ADDR
-read_pc_pid PARAMS ((int));
+extern CORE_ADDR read_pc_pid PARAMS ((int));
-extern void
-write_pc PARAMS ((CORE_ADDR));
+extern void write_pc PARAMS ((CORE_ADDR));
-extern CORE_ADDR
-read_sp PARAMS ((void));
+extern CORE_ADDR read_sp PARAMS ((void));
-extern void
-write_sp PARAMS ((CORE_ADDR));
+extern void write_sp PARAMS ((CORE_ADDR));
-extern CORE_ADDR
-read_fp PARAMS ((void));
+extern CORE_ADDR read_fp PARAMS ((void));
-extern void
-write_fp PARAMS ((CORE_ADDR));
+extern void write_fp PARAMS ((CORE_ADDR));
-extern void
-wait_for_inferior PARAMS ((void));
+extern void wait_for_inferior PARAMS ((void));
-extern void
-init_wait_for_inferior PARAMS ((void));
+extern void init_wait_for_inferior PARAMS ((void));
-extern void
-close_exec_file PARAMS ((void));
+extern void close_exec_file PARAMS ((void));
-extern void
-reopen_exec_file PARAMS ((void));
+extern void reopen_exec_file PARAMS ((void));
/* The `resume' routine should only be called in special circumstances.
Normally, use `proceed', which handles a lot of bookkeeping. */
-extern void
-resume PARAMS ((int, enum target_signal));
+
+extern void resume PARAMS ((int, enum target_signal));
/* From misc files */
-extern void
-store_inferior_registers PARAMS ((int));
+extern void store_inferior_registers PARAMS ((int));
-extern void
-fetch_inferior_registers PARAMS ((int));
+extern void fetch_inferior_registers PARAMS ((int));
-extern void
-solib_create_inferior_hook PARAMS ((void));
+extern void solib_create_inferior_hook PARAMS ((void));
-extern void
-child_terminal_info PARAMS ((char *, int));
+extern void child_terminal_info PARAMS ((char *, int));
-extern void
-term_info PARAMS ((char *, int));
+extern void term_info PARAMS ((char *, int));
-extern void
-terminal_ours_for_output PARAMS ((void));
+extern void terminal_ours_for_output PARAMS ((void));
-extern void
-terminal_inferior PARAMS ((void));
+extern void terminal_inferior PARAMS ((void));
-extern void
-terminal_init_inferior PARAMS ((void));
+extern void terminal_init_inferior PARAMS ((void));
+
+#ifdef PROCESS_GROUP_TYPE
+extern void terminal_init_inferior_with_pgrp PARAMS ((PROCESS_GROUP_TYPE pgrp));
+#endif
/* From infptrace.c */
-extern int
-attach PARAMS ((int));
+extern int attach PARAMS ((int));
-void
-detach PARAMS ((int));
+void detach PARAMS ((int));
-extern void
-child_resume PARAMS ((int, int, enum target_signal));
+extern void child_resume PARAMS ((int, int, enum target_signal));
#ifndef PTRACE_ARG3_TYPE
#define PTRACE_ARG3_TYPE int /* Correct definition for most systems. */
#endif
-extern int
-call_ptrace PARAMS ((int, int, PTRACE_ARG3_TYPE, int));
+extern int call_ptrace PARAMS ((int, int, PTRACE_ARG3_TYPE, int));
/* From procfs.c */
-extern int
-proc_iterate_over_mappings PARAMS ((int (*) (int, CORE_ADDR)));
+extern int proc_iterate_over_mappings PARAMS ((int (*) (int, CORE_ADDR)));
/* From fork-child.c */
extern void fork_inferior PARAMS ((char *, char *, char **,
void (*) (void),
- void (*) (int), char *));
+ int (*) (int), char *));
extern void startup_inferior PARAMS ((int));
/* From inflow.c */
-extern void
-new_tty_prefork PARAMS ((char *));
+extern void new_tty_prefork PARAMS ((char *));
extern int gdb_has_a_terminal PARAMS ((void));
/* From infrun.c */
-extern void
-start_remote PARAMS ((void));
+extern void start_remote PARAMS ((void));
-extern void
-normal_stop PARAMS ((void));
+extern void normal_stop PARAMS ((void));
-extern int
-signal_stop_state PARAMS ((int));
+extern int signal_stop_state PARAMS ((int));
-extern int
-signal_print_state PARAMS ((int));
+extern int signal_print_state PARAMS ((int));
-extern int
-signal_pass_state PARAMS ((int));
+extern int signal_pass_state PARAMS ((int));
/* From infcmd.c */
-extern void
-tty_command PARAMS ((char *, int));
+extern void tty_command PARAMS ((char *, int));
-extern void
-attach_command PARAMS ((char *, int));
+extern void attach_command PARAMS ((char *, int));
/* Last signal that the inferior received (why it stopped). */
extern CORE_ADDR stop_pc;
-/* Stack frame when program stopped. */
-
-extern FRAME_ADDR stop_frame_address;
-
/* Chain containing status of breakpoint(s) that we have stopped at. */
extern bpstat stop_bpstat;
This is how we know when we step into a subroutine call,
and how to set the frame for the breakpoint used to step out. */
-extern FRAME_ADDR step_frame_address;
+extern CORE_ADDR step_frame_address;
+
+/* Our notion of the current stack pointer. */
+
+extern CORE_ADDR step_sp;
/* 1 means step over all subroutine calls.
-1 means step over calls to undebuggable functions. */