[profiler] Revert the root_type field back to uleb128.
[mono.git] / mono / profiler / log.c
1 /*
2  * log.c: mono log profiler
3  *
4  * Authors:
5  *   Paolo Molaro (lupus@ximian.com)
6  *   Alex Rønne Petersen (alexrp@xamarin.com)
7  *
8  * Copyright 2010 Novell, Inc (http://www.novell.com)
9  * Copyright 2011 Xamarin Inc (http://www.xamarin.com)
10  * Licensed under the MIT license. See LICENSE file in the project root for full license information.
11  */
12
13 #include <config.h>
14 #include <mono/metadata/assembly.h>
15 #include <mono/metadata/class-internals.h>
16 #include <mono/metadata/debug-helpers.h>
17 #include <mono/metadata/loader.h>
18 #include <mono/metadata/metadata-internals.h>
19 #include <mono/metadata/mono-config.h>
20 #include <mono/metadata/mono-gc.h>
21 #include <mono/metadata/mono-perfcounters.h>
22 #include <mono/metadata/tabledefs.h>
23 #include <mono/utils/atomic.h>
24 #include <mono/utils/hazard-pointer.h>
25 #include <mono/utils/lock-free-alloc.h>
26 #include <mono/utils/lock-free-queue.h>
27 #include <mono/utils/mono-conc-hashtable.h>
28 #include <mono/utils/mono-coop-mutex.h>
29 #include <mono/utils/mono-counters.h>
30 #include <mono/utils/mono-logger-internals.h>
31 #include <mono/utils/mono-linked-list-set.h>
32 #include <mono/utils/mono-membar.h>
33 #include <mono/utils/mono-mmap.h>
34 #include <mono/utils/mono-os-mutex.h>
35 #include <mono/utils/mono-os-semaphore.h>
36 #include <mono/utils/mono-threads.h>
37 #include <mono/utils/mono-threads-api.h>
38 #include "log.h"
39
40 #ifdef HAVE_DLFCN_H
41 #include <dlfcn.h>
42 #endif
43 #include <fcntl.h>
44 #ifdef HAVE_LINK_H
45 #include <link.h>
46 #endif
47 #ifdef HAVE_UNISTD_H
48 #include <unistd.h>
49 #endif
50 #if defined(__APPLE__)
51 #include <mach/mach_time.h>
52 #endif
53 #include <netinet/in.h>
54 #ifdef HAVE_SYS_MMAN_H
55 #include <sys/mman.h>
56 #endif
57 #include <sys/socket.h>
58 #if defined (HAVE_SYS_ZLIB)
59 #include <zlib.h>
60 #endif
61
62 // Statistics for internal profiler data structures.
63 static gint32 sample_allocations_ctr,
64               buffer_allocations_ctr;
65
66 // Statistics for profiler events.
67 static gint32 sync_points_ctr,
68               heap_objects_ctr,
69               heap_starts_ctr,
70               heap_ends_ctr,
71               heap_roots_ctr,
72               gc_events_ctr,
73               gc_resizes_ctr,
74               gc_allocs_ctr,
75               gc_moves_ctr,
76               gc_handle_creations_ctr,
77               gc_handle_deletions_ctr,
78               finalize_begins_ctr,
79               finalize_ends_ctr,
80               finalize_object_begins_ctr,
81               finalize_object_ends_ctr,
82               image_loads_ctr,
83               image_unloads_ctr,
84               assembly_loads_ctr,
85               assembly_unloads_ctr,
86               class_loads_ctr,
87               class_unloads_ctr,
88               method_entries_ctr,
89               method_exits_ctr,
90               method_exception_exits_ctr,
91               method_jits_ctr,
92               code_buffers_ctr,
93               exception_throws_ctr,
94               exception_clauses_ctr,
95               monitor_events_ctr,
96               thread_starts_ctr,
97               thread_ends_ctr,
98               thread_names_ctr,
99               domain_loads_ctr,
100               domain_unloads_ctr,
101               domain_names_ctr,
102               context_loads_ctr,
103               context_unloads_ctr,
104               sample_ubins_ctr,
105               sample_usyms_ctr,
106               sample_hits_ctr,
107               counter_descriptors_ctr,
108               counter_samples_ctr,
109               perfcounter_descriptors_ctr,
110               perfcounter_samples_ctr,
111               coverage_methods_ctr,
112               coverage_statements_ctr,
113               coverage_classes_ctr,
114               coverage_assemblies_ctr;
115
116 // Pending data to be written to the log, for a single thread.
117 // Threads periodically flush their own LogBuffers by calling safe_send
118 typedef struct _LogBuffer LogBuffer;
119 struct _LogBuffer {
120         // Next (older) LogBuffer in processing queue
121         LogBuffer *next;
122
123         uint64_t time_base;
124         uint64_t last_time;
125         uintptr_t ptr_base;
126         uintptr_t method_base;
127         uintptr_t last_method;
128         uintptr_t obj_base;
129         uintptr_t thread_id;
130
131         // Bytes allocated for this LogBuffer
132         int size;
133
134         // Start of currently unused space in buffer
135         unsigned char* cursor;
136
137         // Pointer to start-of-structure-plus-size (for convenience)
138         unsigned char* buf_end;
139
140         // Start of data in buffer. Contents follow "buffer format" described above.
141         unsigned char buf [1];
142 };
143
144 typedef struct {
145         MonoLinkedListSetNode node;
146
147         // Was this thread added to the LLS?
148         gboolean attached;
149
150         // The current log buffer for this thread.
151         LogBuffer *buffer;
152
153         // Methods referenced by events in `buffer`, see `MethodInfo`.
154         GPtrArray *methods;
155
156         // Current call depth for enter/leave events.
157         int call_depth;
158
159         // Indicates whether this thread is currently writing to its `buffer`.
160         gboolean busy;
161
162         // Has this thread written a thread end event to `buffer`?
163         gboolean ended;
164
165         // Stored in `buffer_lock_state` to take the exclusive lock.
166         int small_id;
167 } MonoProfilerThread;
168
169 // Do not use these TLS macros directly unless you know what you're doing.
170
171 #ifdef HOST_WIN32
172
173 #define PROF_TLS_SET(VAL) (TlsSetValue (profiler_tls, (VAL)))
174 #define PROF_TLS_GET() ((MonoProfilerThread *) TlsGetValue (profiler_tls))
175 #define PROF_TLS_INIT() (profiler_tls = TlsAlloc ())
176 #define PROF_TLS_FREE() (TlsFree (profiler_tls))
177
178 static DWORD profiler_tls;
179
180 #elif HAVE_KW_THREAD
181
182 #define PROF_TLS_SET(VAL) (profiler_tls = (VAL))
183 #define PROF_TLS_GET() (profiler_tls)
184 #define PROF_TLS_INIT()
185 #define PROF_TLS_FREE()
186
187 static __thread MonoProfilerThread *profiler_tls;
188
189 #else
190
191 #define PROF_TLS_SET(VAL) (pthread_setspecific (profiler_tls, (VAL)))
192 #define PROF_TLS_GET() ((MonoProfilerThread *) pthread_getspecific (profiler_tls))
193 #define PROF_TLS_INIT() (pthread_key_create (&profiler_tls, NULL))
194 #define PROF_TLS_FREE() (pthread_key_delete (profiler_tls))
195
196 static pthread_key_t profiler_tls;
197
198 #endif
199
200 static uintptr_t
201 thread_id (void)
202 {
203         return (uintptr_t) mono_native_thread_id_get ();
204 }
205
206 static uintptr_t
207 process_id (void)
208 {
209 #ifdef HOST_WIN32
210         return (uintptr_t) GetCurrentProcessId ();
211 #else
212         return (uintptr_t) getpid ();
213 #endif
214 }
215
216 #define ENABLED(EVT) (!!(log_config.effective_mask & (EVT)))
217 #define ENABLE(EVT) do { log_config.effective_mask |= (EVT); } while (0)
218 #define DISABLE(EVT) do { log_config.effective_mask &= ~(EVT); } while (0)
219
220 /*
221  * These macros should be used when writing an event to a log buffer. They
222  * take care of a bunch of stuff that can be repetitive and error-prone, such
223  * as attaching the current thread, acquiring/releasing the buffer lock,
224  * incrementing the event counter, expanding the log buffer, etc. They also
225  * create a scope so that it's harder to leak the LogBuffer pointer, which can
226  * be problematic as the pointer is unstable when the buffer lock isn't
227  * acquired.
228  *
229  * If the calling thread is already attached, these macros will not alter its
230  * attach mode (i.e. whether it's added to the LLS). If the thread is not
231  * attached, init_thread () will be called with add_to_lls = TRUE.
232  */
233
234 #define ENTER_LOG(COUNTER, BUFFER, SIZE) \
235         do { \
236                 MonoProfilerThread *thread__ = get_thread (); \
237                 if (thread__->attached) \
238                         buffer_lock (); \
239                 g_assert (!thread__->busy && "Why are we trying to write a new event while already writing one?"); \
240                 thread__->busy = TRUE; \
241                 InterlockedIncrement ((COUNTER)); \
242                 LogBuffer *BUFFER = ensure_logbuf_unsafe (thread__, (SIZE))
243
244 #define EXIT_LOG_EXPLICIT(SEND) \
245                 thread__->busy = FALSE; \
246                 if ((SEND)) \
247                         send_log_unsafe (TRUE); \
248                 if (thread__->attached) \
249                         buffer_unlock (); \
250         } while (0)
251
252 // Pass these to EXIT_LOG_EXPLICIT () for easier reading.
253 #define DO_SEND TRUE
254 #define NO_SEND FALSE
255
256 #define EXIT_LOG EXIT_LOG_EXPLICIT (DO_SEND)
257
258 typedef struct _BinaryObject BinaryObject;
259 struct _BinaryObject {
260         BinaryObject *next;
261         void *addr;
262         char *name;
263 };
264
265 typedef struct MonoCounterAgent {
266         MonoCounter *counter;
267         // MonoCounterAgent specific data :
268         void *value;
269         size_t value_size;
270         guint32 index;
271         gboolean emitted;
272         struct MonoCounterAgent *next;
273 } MonoCounterAgent;
274
275 typedef struct _PerfCounterAgent PerfCounterAgent;
276 struct _PerfCounterAgent {
277         PerfCounterAgent *next;
278         guint32 index;
279         char *category_name;
280         char *name;
281         gint64 value;
282         gboolean emitted;
283         gboolean updated;
284         gboolean deleted;
285 };
286
287 struct _MonoProfiler {
288         MonoProfilerHandle handle;
289
290         FILE* file;
291 #if defined (HAVE_SYS_ZLIB)
292         gzFile gzfile;
293 #endif
294
295         char *args;
296         uint64_t startup_time;
297         int timer_overhead;
298
299 #ifdef __APPLE__
300         mach_timebase_info_data_t timebase_info;
301 #elif defined (HOST_WIN32)
302         LARGE_INTEGER pcounter_freq;
303 #endif
304
305         int pipe_output;
306         int command_port;
307         int server_socket;
308         int pipes [2];
309
310         MonoLinkedListSet profiler_thread_list;
311         volatile gint32 buffer_lock_state;
312         volatile gint32 buffer_lock_exclusive_intent;
313
314         volatile gint32 runtime_inited;
315         volatile gint32 in_shutdown;
316
317         MonoNativeThreadId helper_thread;
318
319         MonoNativeThreadId writer_thread;
320         volatile gint32 run_writer_thread;
321         MonoLockFreeQueue writer_queue;
322         MonoSemType writer_queue_sem;
323
324         MonoLockFreeAllocSizeClass writer_entry_size_class;
325         MonoLockFreeAllocator writer_entry_allocator;
326
327         MonoConcurrentHashTable *method_table;
328         mono_mutex_t method_table_mutex;
329
330         MonoNativeThreadId dumper_thread;
331         volatile gint32 run_dumper_thread;
332         MonoLockFreeQueue dumper_queue;
333         MonoSemType dumper_queue_sem;
334
335         MonoLockFreeAllocSizeClass sample_size_class;
336         MonoLockFreeAllocator sample_allocator;
337         MonoLockFreeQueue sample_reuse_queue;
338
339         BinaryObject *binary_objects;
340
341         volatile gint32 heapshot_requested;
342         guint64 gc_count;
343         guint64 last_hs_time;
344         gboolean do_heap_walk;
345
346         mono_mutex_t counters_mutex;
347         MonoCounterAgent *counters;
348         PerfCounterAgent *perfcounters;
349         guint32 counters_index;
350
351         mono_mutex_t coverage_mutex;
352         GPtrArray *coverage_data;
353
354         GPtrArray *coverage_filters;
355         MonoConcurrentHashTable *coverage_filtered_classes;
356         MonoConcurrentHashTable *coverage_suppressed_assemblies;
357
358         MonoConcurrentHashTable *coverage_methods;
359         MonoConcurrentHashTable *coverage_assemblies;
360         MonoConcurrentHashTable *coverage_classes;
361
362         MonoConcurrentHashTable *coverage_image_to_methods;
363
364         guint32 coverage_previous_offset;
365         guint32 coverage_method_id;
366
367         MonoCoopMutex api_mutex;
368 };
369
370 static ProfilerConfig log_config;
371 static struct _MonoProfiler log_profiler;
372
373 typedef struct {
374         MonoLockFreeQueueNode node;
375         GPtrArray *methods;
376         LogBuffer *buffer;
377 } WriterQueueEntry;
378
379 #define WRITER_ENTRY_BLOCK_SIZE (mono_pagesize ())
380
381 typedef struct {
382         MonoMethod *method;
383         MonoJitInfo *ji;
384         uint64_t time;
385 } MethodInfo;
386
387 #define TICKS_PER_SEC 1000000000LL
388
389 static uint64_t
390 current_time (void)
391 {
392 #ifdef __APPLE__
393         uint64_t time = mach_absolute_time ();
394
395         time *= log_profiler.timebase_info.numer;
396         time /= log_profiler.timebase_info.denom;
397
398         return time;
399 #elif defined (HOST_WIN32)
400         LARGE_INTEGER value;
401
402         QueryPerformanceCounter (&value);
403
404         return value.QuadPart * TICKS_PER_SEC / log_profiler.pcounter_freq.QuadPart;
405 #elif defined (CLOCK_MONOTONIC)
406         struct timespec tspec;
407
408         clock_gettime (CLOCK_MONOTONIC, &tspec);
409
410         return ((uint64_t) tspec.tv_sec * TICKS_PER_SEC + tspec.tv_nsec);
411 #else
412         struct timeval tv;
413
414         gettimeofday (&tv, NULL);
415
416         return ((uint64_t) tv.tv_sec * TICKS_PER_SEC + tv.tv_usec * 1000);
417 #endif
418 }
419
420 static void
421 init_time (void)
422 {
423 #ifdef __APPLE__
424         mach_timebase_info (&log_profiler.timebase_info);
425 #elif defined (HOST_WIN32)
426         QueryPerformanceFrequency (&log_profiler.pcounter_freq);
427 #endif
428
429         uint64_t time_start = current_time ();
430
431         for (int i = 0; i < 256; ++i)
432                 current_time ();
433
434         uint64_t time_end = current_time ();
435
436         log_profiler.timer_overhead = (time_end - time_start) / 256;
437 }
438
439 static char*
440 pstrdup (const char *s)
441 {
442         int len = strlen (s) + 1;
443         char *p = (char *) g_malloc (len);
444         memcpy (p, s, len);
445         return p;
446 }
447
448 #define BUFFER_SIZE (4096 * 16)
449
450 /* Worst-case size in bytes of a 64-bit value encoded with LEB128. */
451 #define LEB128_SIZE 10
452
453 /* Size of a value encoded as a single byte. */
454 #undef BYTE_SIZE // mach/i386/vm_param.h on OS X defines this to 8, but it isn't used for anything.
455 #define BYTE_SIZE 1
456
457 /* Size in bytes of the event prefix (ID + time). */
458 #define EVENT_SIZE (BYTE_SIZE + LEB128_SIZE)
459
460 static void *
461 alloc_buffer (int size)
462 {
463         return mono_valloc (NULL, size, MONO_MMAP_READ | MONO_MMAP_WRITE | MONO_MMAP_ANON | MONO_MMAP_PRIVATE, MONO_MEM_ACCOUNT_PROFILER);
464 }
465
466 static void
467 free_buffer (void *buf, int size)
468 {
469         mono_vfree (buf, size, MONO_MEM_ACCOUNT_PROFILER);
470 }
471
472 static LogBuffer*
473 create_buffer (uintptr_t tid, int bytes)
474 {
475         LogBuffer* buf = (LogBuffer *) alloc_buffer (MAX (BUFFER_SIZE, bytes));
476
477         InterlockedIncrement (&buffer_allocations_ctr);
478
479         buf->size = BUFFER_SIZE;
480         buf->time_base = current_time ();
481         buf->last_time = buf->time_base;
482         buf->buf_end = (unsigned char *) buf + buf->size;
483         buf->cursor = buf->buf;
484         buf->thread_id = tid;
485
486         return buf;
487 }
488
489 /*
490  * Must be called with the reader lock held if thread is the current thread, or
491  * the exclusive lock if thread is a different thread. However, if thread is
492  * the current thread, and init_thread () was called with add_to_lls = FALSE,
493  * then no locking is necessary.
494  */
495 static void
496 init_buffer_state (MonoProfilerThread *thread)
497 {
498         thread->buffer = create_buffer (thread->node.key, 0);
499         thread->methods = NULL;
500 }
501
502 static void
503 clear_hazard_pointers (MonoThreadHazardPointers *hp)
504 {
505         mono_hazard_pointer_clear (hp, 0);
506         mono_hazard_pointer_clear (hp, 1);
507         mono_hazard_pointer_clear (hp, 2);
508 }
509
510 static MonoProfilerThread *
511 init_thread (gboolean add_to_lls)
512 {
513         MonoProfilerThread *thread = PROF_TLS_GET ();
514
515         /*
516          * Sometimes we may try to initialize a thread twice. One example is the
517          * main thread: We initialize it when setting up the profiler, but we will
518          * also get a thread_start () callback for it. Another example is when
519          * attaching new threads to the runtime: We may get a gc_alloc () callback
520          * for that thread's thread object (where we initialize it), soon followed
521          * by a thread_start () callback.
522          *
523          * These cases are harmless anyhow. Just return if we've already done the
524          * initialization work.
525          */
526         if (thread)
527                 return thread;
528
529         thread = g_malloc (sizeof (MonoProfilerThread));
530         thread->node.key = thread_id ();
531         thread->attached = add_to_lls;
532         thread->call_depth = 0;
533         thread->busy = 0;
534         thread->ended = FALSE;
535
536         init_buffer_state (thread);
537
538         thread->small_id = mono_thread_info_register_small_id ();
539
540         /*
541          * Some internal profiler threads don't need to be cleaned up
542          * by the main thread on shutdown.
543          */
544         if (add_to_lls) {
545                 MonoThreadHazardPointers *hp = mono_hazard_pointer_get ();
546                 g_assert (mono_lls_insert (&log_profiler.profiler_thread_list, hp, &thread->node) && "Why can't we insert the thread in the LLS?");
547                 clear_hazard_pointers (hp);
548         }
549
550         PROF_TLS_SET (thread);
551
552         return thread;
553 }
554
555 // Only valid if init_thread () was called with add_to_lls = FALSE.
556 static void
557 deinit_thread (MonoProfilerThread *thread)
558 {
559         g_assert (!thread->attached && "Why are we manually freeing an attached thread?");
560
561         g_free (thread);
562         PROF_TLS_SET (NULL);
563 }
564
565 static MonoProfilerThread *
566 get_thread (void)
567 {
568         return init_thread (TRUE);
569 }
570
571 // Only valid if init_thread () was called with add_to_lls = FALSE.
572 static LogBuffer *
573 ensure_logbuf_unsafe (MonoProfilerThread *thread, int bytes)
574 {
575         LogBuffer *old = thread->buffer;
576
577         if (old->cursor + bytes < old->buf_end)
578                 return old;
579
580         LogBuffer *new_ = create_buffer (thread->node.key, bytes);
581         new_->next = old;
582         thread->buffer = new_;
583
584         return new_;
585 }
586
587 /*
588  * This is a reader/writer spin lock of sorts used to protect log buffers.
589  * When a thread modifies its own log buffer, it increments the reader
590  * count. When a thread wants to access log buffers of other threads, it
591  * takes the exclusive lock.
592  *
593  * `buffer_lock_state` holds the reader count in its lower 16 bits, and
594  * the small ID of the thread currently holding the exclusive (writer)
595  * lock in its upper 16 bits. Both can be zero. It's important that the
596  * whole lock state is a single word that can be read/written atomically
597  * to avoid race conditions where there could end up being readers while
598  * the writer lock is held.
599  *
600  * The lock is writer-biased. When a thread wants to take the exclusive
601  * lock, it increments `buffer_lock_exclusive_intent` which will make new
602  * readers spin until it's back to zero, then takes the exclusive lock
603  * once the reader count has reached zero. After releasing the exclusive
604  * lock, it decrements `buffer_lock_exclusive_intent`, which, when it
605  * reaches zero again, allows readers to increment the reader count.
606  *
607  * The writer bias is necessary because we take the exclusive lock in
608  * `gc_event ()` during STW. If the writer bias was not there, and a
609  * program had a large number of threads, STW-induced pauses could be
610  * significantly longer than they have to be. Also, we emit periodic
611  * sync points from the helper thread, which requires taking the
612  * exclusive lock, and we need those to arrive with a reasonably
613  * consistent frequency so that readers don't have to queue up too many
614  * events between sync points.
615  *
616  * The lock does not support recursion.
617  */
618
619 static void
620 buffer_lock (void)
621 {
622         /*
623          * If the thread holding the exclusive lock tries to modify the
624          * reader count, just make it a no-op. This way, we also avoid
625          * invoking the GC safe point macros below, which could break if
626          * done from a thread that is currently the initiator of STW.
627          *
628          * In other words, we rely on the fact that the GC thread takes
629          * the exclusive lock in the gc_event () callback when the world
630          * is about to stop.
631          */
632         if (InterlockedRead (&log_profiler.buffer_lock_state) != get_thread ()->small_id << 16) {
633                 MONO_ENTER_GC_SAFE;
634
635                 gint32 old, new_;
636
637                 do {
638                 restart:
639                         // Hold off if a thread wants to take the exclusive lock.
640                         while (InterlockedRead (&log_profiler.buffer_lock_exclusive_intent))
641                                 mono_thread_info_yield ();
642
643                         old = InterlockedRead (&log_profiler.buffer_lock_state);
644
645                         // Is a thread holding the exclusive lock?
646                         if (old >> 16) {
647                                 mono_thread_info_yield ();
648                                 goto restart;
649                         }
650
651                         new_ = old + 1;
652                 } while (InterlockedCompareExchange (&log_profiler.buffer_lock_state, new_, old) != old);
653
654                 MONO_EXIT_GC_SAFE;
655         }
656
657         mono_memory_barrier ();
658 }
659
660 static void
661 buffer_unlock (void)
662 {
663         mono_memory_barrier ();
664
665         gint32 state = InterlockedRead (&log_profiler.buffer_lock_state);
666
667         // See the comment in buffer_lock ().
668         if (state == PROF_TLS_GET ()->small_id << 16)
669                 return;
670
671         g_assert (state && "Why are we decrementing a zero reader count?");
672         g_assert (!(state >> 16) && "Why is the exclusive lock held?");
673
674         InterlockedDecrement (&log_profiler.buffer_lock_state);
675 }
676
677 static void
678 buffer_lock_excl (void)
679 {
680         gint32 new_ = get_thread ()->small_id << 16;
681
682         g_assert (InterlockedRead (&log_profiler.buffer_lock_state) != new_ && "Why are we taking the exclusive lock twice?");
683
684         InterlockedIncrement (&log_profiler.buffer_lock_exclusive_intent);
685
686         MONO_ENTER_GC_SAFE;
687
688         while (InterlockedCompareExchange (&log_profiler.buffer_lock_state, new_, 0))
689                 mono_thread_info_yield ();
690
691         MONO_EXIT_GC_SAFE;
692
693         mono_memory_barrier ();
694 }
695
696 static void
697 buffer_unlock_excl (void)
698 {
699         mono_memory_barrier ();
700
701         gint32 state = InterlockedRead (&log_profiler.buffer_lock_state);
702         gint32 excl = state >> 16;
703
704         g_assert (excl && "Why is the exclusive lock not held?");
705         g_assert (excl == PROF_TLS_GET ()->small_id && "Why does another thread hold the exclusive lock?");
706         g_assert (!(state & 0xFFFF) && "Why are there readers when the exclusive lock is held?");
707
708         InterlockedWrite (&log_profiler.buffer_lock_state, 0);
709         InterlockedDecrement (&log_profiler.buffer_lock_exclusive_intent);
710 }
711
712 static void
713 encode_uleb128 (uint64_t value, uint8_t *buf, uint8_t **endbuf)
714 {
715         uint8_t *p = buf;
716
717         do {
718                 uint8_t b = value & 0x7f;
719                 value >>= 7;
720
721                 if (value != 0) /* more bytes to come */
722                         b |= 0x80;
723
724                 *p ++ = b;
725         } while (value);
726
727         *endbuf = p;
728 }
729
730 static void
731 encode_sleb128 (intptr_t value, uint8_t *buf, uint8_t **endbuf)
732 {
733         int more = 1;
734         int negative = (value < 0);
735         unsigned int size = sizeof (intptr_t) * 8;
736         uint8_t byte;
737         uint8_t *p = buf;
738
739         while (more) {
740                 byte = value & 0x7f;
741                 value >>= 7;
742
743                 /* the following is unnecessary if the
744                  * implementation of >>= uses an arithmetic rather
745                  * than logical shift for a signed left operand
746                  */
747                 if (negative)
748                         /* sign extend */
749                         value |= - ((intptr_t) 1 <<(size - 7));
750
751                 /* sign bit of byte is second high order bit (0x40) */
752                 if ((value == 0 && !(byte & 0x40)) ||
753                     (value == -1 && (byte & 0x40)))
754                         more = 0;
755                 else
756                         byte |= 0x80;
757
758                 *p ++= byte;
759         }
760
761         *endbuf = p;
762 }
763
764 static void
765 emit_byte (LogBuffer *logbuffer, int value)
766 {
767         logbuffer->cursor [0] = value;
768         logbuffer->cursor++;
769
770         g_assert (logbuffer->cursor <= logbuffer->buf_end && "Why are we writing past the buffer end?");
771 }
772
773 static void
774 emit_value (LogBuffer *logbuffer, int value)
775 {
776         encode_uleb128 (value, logbuffer->cursor, &logbuffer->cursor);
777
778         g_assert (logbuffer->cursor <= logbuffer->buf_end && "Why are we writing past the buffer end?");
779 }
780
781 static void
782 emit_time (LogBuffer *logbuffer, uint64_t value)
783 {
784         uint64_t tdiff = value - logbuffer->last_time;
785         encode_uleb128 (tdiff, logbuffer->cursor, &logbuffer->cursor);
786         logbuffer->last_time = value;
787
788         g_assert (logbuffer->cursor <= logbuffer->buf_end && "Why are we writing past the buffer end?");
789 }
790
791 static void
792 emit_event_time (LogBuffer *logbuffer, int event, uint64_t time)
793 {
794         emit_byte (logbuffer, event);
795         emit_time (logbuffer, time);
796 }
797
798 static void
799 emit_event (LogBuffer *logbuffer, int event)
800 {
801         emit_event_time (logbuffer, event, current_time ());
802 }
803
804 static void
805 emit_svalue (LogBuffer *logbuffer, int64_t value)
806 {
807         encode_sleb128 (value, logbuffer->cursor, &logbuffer->cursor);
808
809         g_assert (logbuffer->cursor <= logbuffer->buf_end && "Why are we writing past the buffer end?");
810 }
811
812 static void
813 emit_uvalue (LogBuffer *logbuffer, uint64_t value)
814 {
815         encode_uleb128 (value, logbuffer->cursor, &logbuffer->cursor);
816
817         g_assert (logbuffer->cursor <= logbuffer->buf_end && "Why are we writing past the buffer end?");
818 }
819
820 static void
821 emit_ptr (LogBuffer *logbuffer, const void *ptr)
822 {
823         if (!logbuffer->ptr_base)
824                 logbuffer->ptr_base = (uintptr_t) ptr;
825
826         emit_svalue (logbuffer, (intptr_t) ptr - logbuffer->ptr_base);
827
828         g_assert (logbuffer->cursor <= logbuffer->buf_end && "Why are we writing past the buffer end?");
829 }
830
831 static void
832 emit_method_inner (LogBuffer *logbuffer, void *method)
833 {
834         if (!logbuffer->method_base) {
835                 logbuffer->method_base = (intptr_t) method;
836                 logbuffer->last_method = (intptr_t) method;
837         }
838
839         encode_sleb128 ((intptr_t) ((char *) method - (char *) logbuffer->last_method), logbuffer->cursor, &logbuffer->cursor);
840         logbuffer->last_method = (intptr_t) method;
841
842         g_assert (logbuffer->cursor <= logbuffer->buf_end && "Why are we writing past the buffer end?");
843 }
844
845 // The reader lock must be held.
846 static void
847 register_method_local (MonoMethod *method, MonoJitInfo *ji)
848 {
849         MonoProfilerThread *thread = get_thread ();
850
851         if (!mono_conc_hashtable_lookup (log_profiler.method_table, method)) {
852                 MethodInfo *info = (MethodInfo *) g_malloc (sizeof (MethodInfo));
853
854                 info->method = method;
855                 info->ji = ji;
856                 info->time = current_time ();
857
858                 GPtrArray *arr = thread->methods ? thread->methods : (thread->methods = g_ptr_array_new ());
859                 g_ptr_array_add (arr, info);
860         }
861 }
862
863 static void
864 emit_method (LogBuffer *logbuffer, MonoMethod *method)
865 {
866         register_method_local (method, NULL);
867         emit_method_inner (logbuffer, method);
868 }
869
870 static void
871 emit_obj (LogBuffer *logbuffer, void *ptr)
872 {
873         if (!logbuffer->obj_base)
874                 logbuffer->obj_base = (uintptr_t) ptr >> 3;
875
876         emit_svalue (logbuffer, ((uintptr_t) ptr >> 3) - logbuffer->obj_base);
877
878         g_assert (logbuffer->cursor <= logbuffer->buf_end && "Why are we writing past the buffer end?");
879 }
880
881 static void
882 emit_string (LogBuffer *logbuffer, const char *str, size_t size)
883 {
884         size_t i = 0;
885         if (str) {
886                 for (; i < size; i++) {
887                         if (str[i] == '\0')
888                                 break;
889                         emit_byte (logbuffer, str [i]);
890                 }
891         }
892         emit_byte (logbuffer, '\0');
893 }
894
895 static void
896 emit_double (LogBuffer *logbuffer, double value)
897 {
898         int i;
899         unsigned char buffer[8];
900         memcpy (buffer, &value, 8);
901 #if G_BYTE_ORDER == G_BIG_ENDIAN
902         for (i = 7; i >= 0; i--)
903 #else
904         for (i = 0; i < 8; i++)
905 #endif
906                 emit_byte (logbuffer, buffer[i]);
907 }
908
909 static char*
910 write_int16 (char *buf, int32_t value)
911 {
912         int i;
913         for (i = 0; i < 2; ++i) {
914                 buf [i] = value;
915                 value >>= 8;
916         }
917         return buf + 2;
918 }
919
920 static char*
921 write_int32 (char *buf, int32_t value)
922 {
923         int i;
924         for (i = 0; i < 4; ++i) {
925                 buf [i] = value;
926                 value >>= 8;
927         }
928         return buf + 4;
929 }
930
931 static char*
932 write_int64 (char *buf, int64_t value)
933 {
934         int i;
935         for (i = 0; i < 8; ++i) {
936                 buf [i] = value;
937                 value >>= 8;
938         }
939         return buf + 8;
940 }
941
942 static char *
943 write_header_string (char *p, const char *str)
944 {
945         size_t len = strlen (str) + 1;
946
947         p = write_int32 (p, len);
948         strcpy (p, str);
949
950         return p + len;
951 }
952
953 static void
954 dump_header (void)
955 {
956         const char *args = log_profiler.args;
957         const char *arch = mono_config_get_cpu ();
958         const char *os = mono_config_get_os ();
959
960         char *hbuf = g_malloc (
961                 sizeof (gint32) /* header id */ +
962                 sizeof (gint8) /* major version */ +
963                 sizeof (gint8) /* minor version */ +
964                 sizeof (gint8) /* data version */ +
965                 sizeof (gint8) /* word size */ +
966                 sizeof (gint64) /* startup time */ +
967                 sizeof (gint32) /* timer overhead */ +
968                 sizeof (gint32) /* flags */ +
969                 sizeof (gint32) /* process id */ +
970                 sizeof (gint16) /* command port */ +
971                 sizeof (gint32) + strlen (args) + 1 /* arguments */ +
972                 sizeof (gint32) + strlen (arch) + 1 /* architecture */ +
973                 sizeof (gint32) + strlen (os) + 1 /* operating system */
974         );
975         char *p = hbuf;
976
977         p = write_int32 (p, LOG_HEADER_ID);
978         *p++ = LOG_VERSION_MAJOR;
979         *p++ = LOG_VERSION_MINOR;
980         *p++ = LOG_DATA_VERSION;
981         *p++ = sizeof (void *);
982         p = write_int64 (p, ((uint64_t) time (NULL)) * 1000);
983         p = write_int32 (p, log_profiler.timer_overhead);
984         p = write_int32 (p, 0); /* flags */
985         p = write_int32 (p, process_id ());
986         p = write_int16 (p, log_profiler.command_port);
987         p = write_header_string (p, args);
988         p = write_header_string (p, arch);
989         p = write_header_string (p, os);
990
991 #if defined (HAVE_SYS_ZLIB)
992         if (log_profiler.gzfile) {
993                 gzwrite (log_profiler.gzfile, hbuf, p - hbuf);
994         } else
995 #endif
996         {
997                 fwrite (hbuf, p - hbuf, 1, log_profiler.file);
998                 fflush (log_profiler.file);
999         }
1000
1001         g_free (hbuf);
1002 }
1003
1004 /*
1005  * Must be called with the reader lock held if thread is the current thread, or
1006  * the exclusive lock if thread is a different thread. However, if thread is
1007  * the current thread, and init_thread () was called with add_to_lls = FALSE,
1008  * then no locking is necessary.
1009  */
1010 static void
1011 send_buffer (MonoProfilerThread *thread)
1012 {
1013         WriterQueueEntry *entry = mono_lock_free_alloc (&log_profiler.writer_entry_allocator);
1014         entry->methods = thread->methods;
1015         entry->buffer = thread->buffer;
1016
1017         mono_lock_free_queue_node_init (&entry->node, FALSE);
1018
1019         mono_lock_free_queue_enqueue (&log_profiler.writer_queue, &entry->node);
1020         mono_os_sem_post (&log_profiler.writer_queue_sem);
1021 }
1022
1023 static void
1024 free_thread (gpointer p)
1025 {
1026         MonoProfilerThread *thread = p;
1027
1028         if (!thread->ended) {
1029                 /*
1030                  * The thread is being cleaned up by the main thread during
1031                  * shutdown. This typically happens for internal runtime
1032                  * threads. We need to synthesize a thread end event.
1033                  */
1034
1035                 InterlockedIncrement (&thread_ends_ctr);
1036
1037                 LogBuffer *buf = ensure_logbuf_unsafe (thread,
1038                         EVENT_SIZE /* event */ +
1039                         BYTE_SIZE /* type */ +
1040                         LEB128_SIZE /* tid */
1041                 );
1042
1043                 emit_event (buf, TYPE_END_UNLOAD | TYPE_METADATA);
1044                 emit_byte (buf, TYPE_THREAD);
1045                 emit_ptr (buf, (void *) thread->node.key);
1046         }
1047
1048         send_buffer (thread);
1049
1050         g_free (thread);
1051 }
1052
1053 static void
1054 remove_thread (MonoProfilerThread *thread)
1055 {
1056         MonoThreadHazardPointers *hp = mono_hazard_pointer_get ();
1057
1058         if (mono_lls_remove (&log_profiler.profiler_thread_list, hp, &thread->node))
1059                 mono_thread_hazardous_try_free (thread, free_thread);
1060
1061         clear_hazard_pointers (hp);
1062 }
1063
1064 static void
1065 dump_buffer (LogBuffer *buf)
1066 {
1067         char hbuf [128];
1068         char *p = hbuf;
1069
1070         if (buf->next)
1071                 dump_buffer (buf->next);
1072
1073         if (buf->cursor - buf->buf) {
1074                 p = write_int32 (p, BUF_ID);
1075                 p = write_int32 (p, buf->cursor - buf->buf);
1076                 p = write_int64 (p, buf->time_base);
1077                 p = write_int64 (p, buf->ptr_base);
1078                 p = write_int64 (p, buf->obj_base);
1079                 p = write_int64 (p, buf->thread_id);
1080                 p = write_int64 (p, buf->method_base);
1081
1082 #if defined (HAVE_SYS_ZLIB)
1083                 if (log_profiler.gzfile) {
1084                         gzwrite (log_profiler.gzfile, hbuf, p - hbuf);
1085                         gzwrite (log_profiler.gzfile, buf->buf, buf->cursor - buf->buf);
1086                 } else
1087 #endif
1088                 {
1089                         fwrite (hbuf, p - hbuf, 1, log_profiler.file);
1090                         fwrite (buf->buf, buf->cursor - buf->buf, 1, log_profiler.file);
1091                         fflush (log_profiler.file);
1092                 }
1093         }
1094
1095         free_buffer (buf, buf->size);
1096 }
1097
1098 static void
1099 dump_buffer_threadless (LogBuffer *buf)
1100 {
1101         for (LogBuffer *iter = buf; iter; iter = iter->next)
1102                 iter->thread_id = 0;
1103
1104         dump_buffer (buf);
1105 }
1106
1107 // Only valid if init_thread () was called with add_to_lls = FALSE.
1108 static void
1109 send_log_unsafe (gboolean if_needed)
1110 {
1111         MonoProfilerThread *thread = PROF_TLS_GET ();
1112
1113         if (!if_needed || (if_needed && thread->buffer->next)) {
1114                 if (!thread->attached)
1115                         for (LogBuffer *iter = thread->buffer; iter; iter = iter->next)
1116                                 iter->thread_id = 0;
1117
1118                 send_buffer (thread);
1119                 init_buffer_state (thread);
1120         }
1121 }
1122
1123 // Assumes that the exclusive lock is held.
1124 static void
1125 sync_point_flush (void)
1126 {
1127         g_assert (InterlockedRead (&log_profiler.buffer_lock_state) == PROF_TLS_GET ()->small_id << 16 && "Why don't we hold the exclusive lock?");
1128
1129         MONO_LLS_FOREACH_SAFE (&log_profiler.profiler_thread_list, MonoProfilerThread, thread) {
1130                 g_assert (thread->attached && "Why is a thread in the LLS not attached?");
1131
1132                 send_buffer (thread);
1133                 init_buffer_state (thread);
1134         } MONO_LLS_FOREACH_SAFE_END
1135 }
1136
1137 // Assumes that the exclusive lock is held.
1138 static void
1139 sync_point_mark (MonoProfilerSyncPointType type)
1140 {
1141         g_assert (InterlockedRead (&log_profiler.buffer_lock_state) == PROF_TLS_GET ()->small_id << 16 && "Why don't we hold the exclusive lock?");
1142
1143         ENTER_LOG (&sync_points_ctr, logbuffer,
1144                 EVENT_SIZE /* event */ +
1145                 LEB128_SIZE /* type */
1146         );
1147
1148         emit_event (logbuffer, TYPE_META | TYPE_SYNC_POINT);
1149         emit_byte (logbuffer, type);
1150
1151         EXIT_LOG_EXPLICIT (NO_SEND);
1152
1153         send_log_unsafe (FALSE);
1154 }
1155
1156 // Assumes that the exclusive lock is held.
1157 static void
1158 sync_point (MonoProfilerSyncPointType type)
1159 {
1160         sync_point_flush ();
1161         sync_point_mark (type);
1162 }
1163
1164 static int
1165 gc_reference (MonoObject *obj, MonoClass *klass, uintptr_t size, uintptr_t num, MonoObject **refs, uintptr_t *offsets, void *data)
1166 {
1167         /* account for object alignment in the heap */
1168         size += 7;
1169         size &= ~7;
1170
1171         ENTER_LOG (&heap_objects_ctr, logbuffer,
1172                 EVENT_SIZE /* event */ +
1173                 LEB128_SIZE /* obj */ +
1174                 LEB128_SIZE /* klass */ +
1175                 LEB128_SIZE /* size */ +
1176                 LEB128_SIZE /* num */ +
1177                 num * (
1178                         LEB128_SIZE /* offset */ +
1179                         LEB128_SIZE /* ref */
1180                 )
1181         );
1182
1183         emit_event (logbuffer, TYPE_HEAP_OBJECT | TYPE_HEAP);
1184         emit_obj (logbuffer, obj);
1185         emit_ptr (logbuffer, klass);
1186         emit_value (logbuffer, size);
1187         emit_value (logbuffer, num);
1188
1189         uintptr_t last_offset = 0;
1190
1191         for (int i = 0; i < num; ++i) {
1192                 emit_value (logbuffer, offsets [i] - last_offset);
1193                 last_offset = offsets [i];
1194                 emit_obj (logbuffer, refs [i]);
1195         }
1196
1197         EXIT_LOG;
1198
1199         return 0;
1200 }
1201
1202 static void
1203 gc_roots (MonoProfiler *prof, MonoObject *const *objects, const MonoProfilerGCRootType *root_types, const uintptr_t *extra_info, uint64_t num)
1204 {
1205         ENTER_LOG (&heap_roots_ctr, logbuffer,
1206                 EVENT_SIZE /* event */ +
1207                 LEB128_SIZE /* num */ +
1208                 LEB128_SIZE /* collections */ +
1209                 num * (
1210                         LEB128_SIZE /* object */ +
1211                         LEB128_SIZE /* root type */ +
1212                         LEB128_SIZE /* extra info */
1213                 )
1214         );
1215
1216         emit_event (logbuffer, TYPE_HEAP_ROOT | TYPE_HEAP);
1217         emit_value (logbuffer, num);
1218         emit_value (logbuffer, mono_gc_collection_count (mono_gc_max_generation ()));
1219
1220         for (int i = 0; i < num; ++i) {
1221                 emit_obj (logbuffer, objects [i]);
1222                 emit_value (logbuffer, root_types [i]);
1223                 emit_value (logbuffer, extra_info [i]);
1224         }
1225
1226         EXIT_LOG;
1227 }
1228
1229
1230 static void
1231 trigger_on_demand_heapshot (void)
1232 {
1233         if (InterlockedRead (&log_profiler.heapshot_requested))
1234                 mono_gc_collect (mono_gc_max_generation ());
1235 }
1236
1237 #define ALL_GC_EVENTS_MASK (PROFLOG_GC_EVENTS | PROFLOG_GC_MOVE_EVENTS | PROFLOG_GC_ROOT_EVENTS)
1238
1239 static void
1240 gc_event (MonoProfiler *profiler, MonoProfilerGCEvent ev, uint32_t generation)
1241 {
1242         if (ENABLED (PROFLOG_GC_EVENTS)) {
1243                 ENTER_LOG (&gc_events_ctr, logbuffer,
1244                         EVENT_SIZE /* event */ +
1245                         BYTE_SIZE /* gc event */ +
1246                         BYTE_SIZE /* generation */
1247                 );
1248
1249                 emit_event (logbuffer, TYPE_GC_EVENT | TYPE_GC);
1250                 emit_byte (logbuffer, ev);
1251                 emit_byte (logbuffer, generation);
1252
1253                 EXIT_LOG;
1254         }
1255
1256         switch (ev) {
1257         case MONO_GC_EVENT_PRE_STOP_WORLD_LOCKED:
1258                 switch (log_config.hs_mode) {
1259                 case MONO_PROFILER_HEAPSHOT_NONE:
1260                         log_profiler.do_heap_walk = FALSE;
1261                         break;
1262                 case MONO_PROFILER_HEAPSHOT_MAJOR:
1263                         log_profiler.do_heap_walk = generation == mono_gc_max_generation ();
1264                         break;
1265                 case MONO_PROFILER_HEAPSHOT_ON_DEMAND:
1266                         log_profiler.do_heap_walk = InterlockedRead (&log_profiler.heapshot_requested);
1267                         break;
1268                 case MONO_PROFILER_HEAPSHOT_X_GC:
1269                         log_profiler.do_heap_walk = !(log_profiler.gc_count % log_config.hs_freq_gc);
1270                         break;
1271                 case MONO_PROFILER_HEAPSHOT_X_MS:
1272                         log_profiler.do_heap_walk = (current_time () - log_profiler.last_hs_time) / 1000 * 1000 >= log_config.hs_freq_ms;
1273                         break;
1274                 default:
1275                         g_assert_not_reached ();
1276                 }
1277
1278                 /*
1279                  * heapshot_requested is set either because on-demand heapshot is
1280                  * enabled and a heapshot was triggered, or because we're doing a
1281                  * shutdown heapshot. In the latter case, we won't check it in the
1282                  * switch above, so check it here and override any decision we made
1283                  * above.
1284                  */
1285                 if (InterlockedRead (&log_profiler.heapshot_requested))
1286                         log_profiler.do_heap_walk = TRUE;
1287
1288                 if (ENABLED (PROFLOG_GC_ROOT_EVENTS) && log_profiler.do_heap_walk)
1289                         mono_profiler_set_gc_roots_callback (log_profiler.handle, gc_roots);
1290
1291                 /*
1292                  * Ensure that no thread can be in the middle of writing to
1293                  * a buffer when the world stops...
1294                  */
1295                 buffer_lock_excl ();
1296
1297                 break;
1298         case MONO_GC_EVENT_POST_STOP_WORLD:
1299                 /*
1300                  * ... So that we now have a consistent view of all buffers.
1301                  * This allows us to flush them. We need to do this because
1302                  * they may contain object allocation events that need to be
1303                  * committed to the log file before any object move events
1304                  * that will be produced during this GC.
1305                  */
1306                 if (ENABLED (ALL_GC_EVENTS_MASK))
1307                         sync_point (SYNC_POINT_WORLD_STOP);
1308
1309                 // Surround heapshots with HEAP_START/HEAP_END events.
1310                 if (log_profiler.do_heap_walk) {
1311                         ENTER_LOG (&heap_starts_ctr, logbuffer,
1312                                 EVENT_SIZE /* event */
1313                         );
1314
1315                         emit_event (logbuffer, TYPE_HEAP_START | TYPE_HEAP);
1316
1317                         EXIT_LOG;
1318                 }
1319
1320                 break;
1321         case MONO_GC_EVENT_START:
1322                 if (generation == mono_gc_max_generation ())
1323                         log_profiler.gc_count++;
1324
1325                 break;
1326         case MONO_GC_EVENT_PRE_START_WORLD:
1327                 mono_profiler_set_gc_roots_callback (log_profiler.handle, NULL);
1328
1329                 if (log_profiler.do_heap_walk) {
1330                         mono_gc_walk_heap (0, gc_reference, NULL);
1331
1332                         ENTER_LOG (&heap_ends_ctr, logbuffer,
1333                                 EVENT_SIZE /* event */
1334                         );
1335
1336                         emit_event (logbuffer, TYPE_HEAP_END | TYPE_HEAP);
1337
1338                         EXIT_LOG;
1339
1340                         log_profiler.do_heap_walk = FALSE;
1341                         log_profiler.last_hs_time = current_time ();
1342
1343                         InterlockedWrite (&log_profiler.heapshot_requested, 0);
1344                 }
1345
1346                 /*
1347                  * Similarly, we must now make sure that any object moves
1348                  * written to the GC thread's buffer are flushed. Otherwise,
1349                  * object allocation events for certain addresses could come
1350                  * after the move events that made those addresses available.
1351                  */
1352                 if (ENABLED (ALL_GC_EVENTS_MASK))
1353                         sync_point_mark (SYNC_POINT_WORLD_START);
1354
1355                 break;
1356         case MONO_GC_EVENT_POST_START_WORLD_UNLOCKED:
1357                 /*
1358                  * Finally, it is safe to allow other threads to write to
1359                  * their buffers again.
1360                  */
1361                 buffer_unlock_excl ();
1362
1363                 break;
1364         default:
1365                 break;
1366         }
1367 }
1368
1369 static void
1370 gc_resize (MonoProfiler *profiler, uintptr_t new_size)
1371 {
1372         ENTER_LOG (&gc_resizes_ctr, logbuffer,
1373                 EVENT_SIZE /* event */ +
1374                 LEB128_SIZE /* new size */
1375         );
1376
1377         emit_event (logbuffer, TYPE_GC_RESIZE | TYPE_GC);
1378         emit_value (logbuffer, new_size);
1379
1380         EXIT_LOG;
1381 }
1382
1383 typedef struct {
1384         int count;
1385         MonoMethod* methods [MAX_FRAMES];
1386         int32_t il_offsets [MAX_FRAMES];
1387         int32_t native_offsets [MAX_FRAMES];
1388 } FrameData;
1389
1390 static mono_bool
1391 walk_stack (MonoMethod *method, int32_t native_offset, int32_t il_offset, mono_bool managed, void* data)
1392 {
1393         FrameData *frame = (FrameData *)data;
1394         if (method && frame->count < log_config.num_frames) {
1395                 frame->il_offsets [frame->count] = il_offset;
1396                 frame->native_offsets [frame->count] = native_offset;
1397                 frame->methods [frame->count++] = method;
1398         }
1399         return frame->count == log_config.num_frames;
1400 }
1401
1402 /*
1403  * a note about stack walks: they can cause more profiler events to fire,
1404  * so we need to make sure they don't happen after we started emitting an
1405  * event, hence the collect_bt/emit_bt split.
1406  */
1407 static void
1408 collect_bt (FrameData *data)
1409 {
1410         data->count = 0;
1411         mono_stack_walk_no_il (walk_stack, data);
1412 }
1413
1414 static void
1415 emit_bt (LogBuffer *logbuffer, FrameData *data)
1416 {
1417         emit_value (logbuffer, data->count);
1418
1419         while (data->count)
1420                 emit_method (logbuffer, data->methods [--data->count]);
1421 }
1422
1423 static void
1424 gc_alloc (MonoProfiler *prof, MonoObject *obj)
1425 {
1426         int do_bt = (!log_config.enter_leave && InterlockedRead (&log_profiler.runtime_inited) && log_config.num_frames) ? TYPE_ALLOC_BT : 0;
1427         FrameData data;
1428         uintptr_t len = mono_object_get_size (obj);
1429         /* account for object alignment in the heap */
1430         len += 7;
1431         len &= ~7;
1432
1433         if (do_bt)
1434                 collect_bt (&data);
1435
1436         ENTER_LOG (&gc_allocs_ctr, logbuffer,
1437                 EVENT_SIZE /* event */ +
1438                 LEB128_SIZE /* klass */ +
1439                 LEB128_SIZE /* obj */ +
1440                 LEB128_SIZE /* size */ +
1441                 (do_bt ? (
1442                         LEB128_SIZE /* count */ +
1443                         data.count * (
1444                                 LEB128_SIZE /* method */
1445                         )
1446                 ) : 0)
1447         );
1448
1449         emit_event (logbuffer, do_bt | TYPE_ALLOC);
1450         emit_ptr (logbuffer, mono_object_get_class (obj));
1451         emit_obj (logbuffer, obj);
1452         emit_value (logbuffer, len);
1453
1454         if (do_bt)
1455                 emit_bt (logbuffer, &data);
1456
1457         EXIT_LOG;
1458 }
1459
1460 static void
1461 gc_moves (MonoProfiler *prof, MonoObject *const *objects, uint64_t num)
1462 {
1463         ENTER_LOG (&gc_moves_ctr, logbuffer,
1464                 EVENT_SIZE /* event */ +
1465                 LEB128_SIZE /* num */ +
1466                 num * (
1467                         LEB128_SIZE /* object */
1468                 )
1469         );
1470
1471         emit_event (logbuffer, TYPE_GC_MOVE | TYPE_GC);
1472         emit_value (logbuffer, num);
1473
1474         for (int i = 0; i < num; ++i)
1475                 emit_obj (logbuffer, objects [i]);
1476
1477         EXIT_LOG;
1478 }
1479
1480 static void
1481 gc_handle (MonoProfiler *prof, int op, MonoGCHandleType type, uint32_t handle, MonoObject *obj)
1482 {
1483         int do_bt = !log_config.enter_leave && InterlockedRead (&log_profiler.runtime_inited) && log_config.num_frames;
1484         FrameData data;
1485
1486         if (do_bt)
1487                 collect_bt (&data);
1488
1489         gint32 *ctr = op == MONO_PROFILER_GC_HANDLE_CREATED ? &gc_handle_creations_ctr : &gc_handle_deletions_ctr;
1490
1491         ENTER_LOG (ctr, logbuffer,
1492                 EVENT_SIZE /* event */ +
1493                 LEB128_SIZE /* type */ +
1494                 LEB128_SIZE /* handle */ +
1495                 (op == MONO_PROFILER_GC_HANDLE_CREATED ? (
1496                         LEB128_SIZE /* obj */
1497                 ) : 0) +
1498                 (do_bt ? (
1499                         LEB128_SIZE /* count */ +
1500                         data.count * (
1501                                 LEB128_SIZE /* method */
1502                         )
1503                 ) : 0)
1504         );
1505
1506         if (op == MONO_PROFILER_GC_HANDLE_CREATED)
1507                 emit_event (logbuffer, (do_bt ? TYPE_GC_HANDLE_CREATED_BT : TYPE_GC_HANDLE_CREATED) | TYPE_GC);
1508         else if (op == MONO_PROFILER_GC_HANDLE_DESTROYED)
1509                 emit_event (logbuffer, (do_bt ? TYPE_GC_HANDLE_DESTROYED_BT : TYPE_GC_HANDLE_DESTROYED) | TYPE_GC);
1510         else
1511                 g_assert_not_reached ();
1512
1513         emit_value (logbuffer, type);
1514         emit_value (logbuffer, handle);
1515
1516         if (op == MONO_PROFILER_GC_HANDLE_CREATED)
1517                 emit_obj (logbuffer, obj);
1518
1519         if (do_bt)
1520                 emit_bt (logbuffer, &data);
1521
1522         EXIT_LOG;
1523 }
1524
1525 static void
1526 gc_handle_created (MonoProfiler *prof, uint32_t handle, MonoGCHandleType type, MonoObject *obj)
1527 {
1528         gc_handle (prof, MONO_PROFILER_GC_HANDLE_CREATED, type, handle, obj);
1529 }
1530
1531 static void
1532 gc_handle_deleted (MonoProfiler *prof, uint32_t handle, MonoGCHandleType type)
1533 {
1534         gc_handle (prof, MONO_PROFILER_GC_HANDLE_DESTROYED, type, handle, NULL);
1535 }
1536
1537 static void
1538 finalize_begin (MonoProfiler *prof)
1539 {
1540         ENTER_LOG (&finalize_begins_ctr, buf,
1541                 EVENT_SIZE /* event */
1542         );
1543
1544         emit_event (buf, TYPE_GC_FINALIZE_START | TYPE_GC);
1545
1546         EXIT_LOG;
1547 }
1548
1549 static void
1550 finalize_end (MonoProfiler *prof)
1551 {
1552         trigger_on_demand_heapshot ();
1553         if (ENABLED (PROFLOG_GC_FINALIZATION_EVENTS)) {
1554                 ENTER_LOG (&finalize_ends_ctr, buf,
1555                         EVENT_SIZE /* event */
1556                 );
1557
1558                 emit_event (buf, TYPE_GC_FINALIZE_END | TYPE_GC);
1559
1560                 EXIT_LOG;
1561         }
1562 }
1563
1564 static void
1565 finalize_object_begin (MonoProfiler *prof, MonoObject *obj)
1566 {
1567         ENTER_LOG (&finalize_object_begins_ctr, buf,
1568                 EVENT_SIZE /* event */ +
1569                 LEB128_SIZE /* obj */
1570         );
1571
1572         emit_event (buf, TYPE_GC_FINALIZE_OBJECT_START | TYPE_GC);
1573         emit_obj (buf, obj);
1574
1575         EXIT_LOG;
1576 }
1577
1578 static void
1579 finalize_object_end (MonoProfiler *prof, MonoObject *obj)
1580 {
1581         ENTER_LOG (&finalize_object_ends_ctr, buf,
1582                 EVENT_SIZE /* event */ +
1583                 LEB128_SIZE /* obj */
1584         );
1585
1586         emit_event (buf, TYPE_GC_FINALIZE_OBJECT_END | TYPE_GC);
1587         emit_obj (buf, obj);
1588
1589         EXIT_LOG;
1590 }
1591
1592 static char*
1593 push_nesting (char *p, MonoClass *klass)
1594 {
1595         MonoClass *nesting;
1596         const char *name;
1597         const char *nspace;
1598         nesting = mono_class_get_nesting_type (klass);
1599         if (nesting) {
1600                 p = push_nesting (p, nesting);
1601                 *p++ = '/';
1602                 *p = 0;
1603         }
1604         name = mono_class_get_name (klass);
1605         nspace = mono_class_get_namespace (klass);
1606         if (*nspace) {
1607                 strcpy (p, nspace);
1608                 p += strlen (nspace);
1609                 *p++ = '.';
1610                 *p = 0;
1611         }
1612         strcpy (p, name);
1613         p += strlen (name);
1614         return p;
1615 }
1616
1617 static char*
1618 type_name (MonoClass *klass)
1619 {
1620         char buf [1024];
1621         char *p;
1622         push_nesting (buf, klass);
1623         p = (char *) g_malloc (strlen (buf) + 1);
1624         strcpy (p, buf);
1625         return p;
1626 }
1627
1628 static void
1629 image_loaded (MonoProfiler *prof, MonoImage *image)
1630 {
1631         const char *name = mono_image_get_filename (image);
1632         int nlen = strlen (name) + 1;
1633
1634         ENTER_LOG (&image_loads_ctr, logbuffer,
1635                 EVENT_SIZE /* event */ +
1636                 BYTE_SIZE /* type */ +
1637                 LEB128_SIZE /* image */ +
1638                 nlen /* name */
1639         );
1640
1641         emit_event (logbuffer, TYPE_END_LOAD | TYPE_METADATA);
1642         emit_byte (logbuffer, TYPE_IMAGE);
1643         emit_ptr (logbuffer, image);
1644         memcpy (logbuffer->cursor, name, nlen);
1645         logbuffer->cursor += nlen;
1646
1647         EXIT_LOG;
1648 }
1649
1650 static void
1651 image_unloaded (MonoProfiler *prof, MonoImage *image)
1652 {
1653         const char *name = mono_image_get_filename (image);
1654         int nlen = strlen (name) + 1;
1655
1656         ENTER_LOG (&image_unloads_ctr, logbuffer,
1657                 EVENT_SIZE /* event */ +
1658                 BYTE_SIZE /* type */ +
1659                 LEB128_SIZE /* image */ +
1660                 nlen /* name */
1661         );
1662
1663         emit_event (logbuffer, TYPE_END_UNLOAD | TYPE_METADATA);
1664         emit_byte (logbuffer, TYPE_IMAGE);
1665         emit_ptr (logbuffer, image);
1666         memcpy (logbuffer->cursor, name, nlen);
1667         logbuffer->cursor += nlen;
1668
1669         EXIT_LOG;
1670 }
1671
1672 static void
1673 assembly_loaded (MonoProfiler *prof, MonoAssembly *assembly)
1674 {
1675         char *name = mono_stringify_assembly_name (mono_assembly_get_name (assembly));
1676         int nlen = strlen (name) + 1;
1677         MonoImage *image = mono_assembly_get_image (assembly);
1678
1679         ENTER_LOG (&assembly_loads_ctr, logbuffer,
1680                 EVENT_SIZE /* event */ +
1681                 BYTE_SIZE /* type */ +
1682                 LEB128_SIZE /* assembly */ +
1683                 LEB128_SIZE /* image */ +
1684                 nlen /* name */
1685         );
1686
1687         emit_event (logbuffer, TYPE_END_LOAD | TYPE_METADATA);
1688         emit_byte (logbuffer, TYPE_ASSEMBLY);
1689         emit_ptr (logbuffer, assembly);
1690         emit_ptr (logbuffer, image);
1691         memcpy (logbuffer->cursor, name, nlen);
1692         logbuffer->cursor += nlen;
1693
1694         EXIT_LOG;
1695
1696         mono_free (name);
1697 }
1698
1699 static void
1700 assembly_unloaded (MonoProfiler *prof, MonoAssembly *assembly)
1701 {
1702         char *name = mono_stringify_assembly_name (mono_assembly_get_name (assembly));
1703         int nlen = strlen (name) + 1;
1704         MonoImage *image = mono_assembly_get_image (assembly);
1705
1706         ENTER_LOG (&assembly_unloads_ctr, logbuffer,
1707                 EVENT_SIZE /* event */ +
1708                 BYTE_SIZE /* type */ +
1709                 LEB128_SIZE /* assembly */ +
1710                 LEB128_SIZE /* image */ +
1711                 nlen /* name */
1712         );
1713
1714         emit_event (logbuffer, TYPE_END_UNLOAD | TYPE_METADATA);
1715         emit_byte (logbuffer, TYPE_ASSEMBLY);
1716         emit_ptr (logbuffer, assembly);
1717         emit_ptr (logbuffer, image);
1718         memcpy (logbuffer->cursor, name, nlen);
1719         logbuffer->cursor += nlen;
1720
1721         EXIT_LOG;
1722
1723         mono_free (name);
1724 }
1725
1726 static void
1727 class_loaded (MonoProfiler *prof, MonoClass *klass)
1728 {
1729         char *name;
1730
1731         if (InterlockedRead (&log_profiler.runtime_inited))
1732                 name = mono_type_get_name (mono_class_get_type (klass));
1733         else
1734                 name = type_name (klass);
1735
1736         int nlen = strlen (name) + 1;
1737         MonoImage *image = mono_class_get_image (klass);
1738
1739         ENTER_LOG (&class_loads_ctr, logbuffer,
1740                 EVENT_SIZE /* event */ +
1741                 BYTE_SIZE /* type */ +
1742                 LEB128_SIZE /* klass */ +
1743                 LEB128_SIZE /* image */ +
1744                 nlen /* name */
1745         );
1746
1747         emit_event (logbuffer, TYPE_END_LOAD | TYPE_METADATA);
1748         emit_byte (logbuffer, TYPE_CLASS);
1749         emit_ptr (logbuffer, klass);
1750         emit_ptr (logbuffer, image);
1751         memcpy (logbuffer->cursor, name, nlen);
1752         logbuffer->cursor += nlen;
1753
1754         EXIT_LOG;
1755
1756         if (InterlockedRead (&log_profiler.runtime_inited))
1757                 mono_free (name);
1758         else
1759                 g_free (name);
1760 }
1761
1762 static void
1763 method_enter (MonoProfiler *prof, MonoMethod *method, MonoProfilerCallContext *ctx)
1764 {
1765         if (get_thread ()->call_depth++ <= log_config.max_call_depth) {
1766                 ENTER_LOG (&method_entries_ctr, logbuffer,
1767                         EVENT_SIZE /* event */ +
1768                         LEB128_SIZE /* method */
1769                 );
1770
1771                 emit_event (logbuffer, TYPE_ENTER | TYPE_METHOD);
1772                 emit_method (logbuffer, method);
1773
1774                 EXIT_LOG;
1775         }
1776 }
1777
1778 static void
1779 method_leave (MonoProfiler *prof, MonoMethod *method, MonoProfilerCallContext *ctx)
1780 {
1781         if (--get_thread ()->call_depth <= log_config.max_call_depth) {
1782                 ENTER_LOG (&method_exits_ctr, logbuffer,
1783                         EVENT_SIZE /* event */ +
1784                         LEB128_SIZE /* method */
1785                 );
1786
1787                 emit_event (logbuffer, TYPE_LEAVE | TYPE_METHOD);
1788                 emit_method (logbuffer, method);
1789
1790                 EXIT_LOG;
1791         }
1792 }
1793
1794 static void
1795 tail_call (MonoProfiler *prof, MonoMethod *method, MonoMethod *target)
1796 {
1797         method_leave (prof, method, NULL);
1798 }
1799
1800 static void
1801 method_exc_leave (MonoProfiler *prof, MonoMethod *method, MonoObject *exc)
1802 {
1803         if (--get_thread ()->call_depth <= log_config.max_call_depth) {
1804                 ENTER_LOG (&method_exception_exits_ctr, logbuffer,
1805                         EVENT_SIZE /* event */ +
1806                         LEB128_SIZE /* method */
1807                 );
1808
1809                 emit_event (logbuffer, TYPE_EXC_LEAVE | TYPE_METHOD);
1810                 emit_method (logbuffer, method);
1811
1812                 EXIT_LOG;
1813         }
1814 }
1815
1816 static MonoProfilerCallInstrumentationFlags
1817 method_filter (MonoProfiler *prof, MonoMethod *method)
1818 {
1819         return MONO_PROFILER_CALL_INSTRUMENTATION_ENTER |
1820                MONO_PROFILER_CALL_INSTRUMENTATION_LEAVE |
1821                MONO_PROFILER_CALL_INSTRUMENTATION_TAIL_CALL |
1822                MONO_PROFILER_CALL_INSTRUMENTATION_EXCEPTION_LEAVE;
1823 }
1824
1825 static void
1826 method_jitted (MonoProfiler *prof, MonoMethod *method, MonoJitInfo *ji)
1827 {
1828         buffer_lock ();
1829
1830         register_method_local (method, ji);
1831
1832         buffer_unlock ();
1833 }
1834
1835 static void
1836 code_buffer_new (MonoProfiler *prof, const mono_byte *buffer, uint64_t size, MonoProfilerCodeBufferType type, const void *data)
1837 {
1838         const char *name;
1839         int nlen;
1840
1841         if (type == MONO_PROFILER_CODE_BUFFER_SPECIFIC_TRAMPOLINE) {
1842                 name = (const char *) data;
1843                 nlen = strlen (name) + 1;
1844         } else {
1845                 name = NULL;
1846                 nlen = 0;
1847         }
1848
1849         ENTER_LOG (&code_buffers_ctr, logbuffer,
1850                 EVENT_SIZE /* event */ +
1851                 BYTE_SIZE /* type */ +
1852                 LEB128_SIZE /* buffer */ +
1853                 LEB128_SIZE /* size */ +
1854                 (name ? (
1855                         nlen /* name */
1856                 ) : 0)
1857         );
1858
1859         emit_event (logbuffer, TYPE_JITHELPER | TYPE_RUNTIME);
1860         emit_byte (logbuffer, type);
1861         emit_ptr (logbuffer, buffer);
1862         emit_value (logbuffer, size);
1863
1864         if (name) {
1865                 memcpy (logbuffer->cursor, name, nlen);
1866                 logbuffer->cursor += nlen;
1867         }
1868
1869         EXIT_LOG;
1870 }
1871
1872 static void
1873 throw_exc (MonoProfiler *prof, MonoObject *object)
1874 {
1875         int do_bt = (!log_config.enter_leave && InterlockedRead (&log_profiler.runtime_inited) && log_config.num_frames) ? TYPE_THROW_BT : 0;
1876         FrameData data;
1877
1878         if (do_bt)
1879                 collect_bt (&data);
1880
1881         ENTER_LOG (&exception_throws_ctr, logbuffer,
1882                 EVENT_SIZE /* event */ +
1883                 LEB128_SIZE /* object */ +
1884                 (do_bt ? (
1885                         LEB128_SIZE /* count */ +
1886                         data.count * (
1887                                 LEB128_SIZE /* method */
1888                         )
1889                 ) : 0)
1890         );
1891
1892         emit_event (logbuffer, do_bt | TYPE_EXCEPTION);
1893         emit_obj (logbuffer, object);
1894
1895         if (do_bt)
1896                 emit_bt (logbuffer, &data);
1897
1898         EXIT_LOG;
1899 }
1900
1901 static void
1902 clause_exc (MonoProfiler *prof, MonoMethod *method, uint32_t clause_num, MonoExceptionEnum clause_type, MonoObject *exc)
1903 {
1904         ENTER_LOG (&exception_clauses_ctr, logbuffer,
1905                 EVENT_SIZE /* event */ +
1906                 BYTE_SIZE /* clause type */ +
1907                 LEB128_SIZE /* clause num */ +
1908                 LEB128_SIZE /* method */
1909         );
1910
1911         emit_event (logbuffer, TYPE_EXCEPTION | TYPE_CLAUSE);
1912         emit_byte (logbuffer, clause_type);
1913         emit_value (logbuffer, clause_num);
1914         emit_method (logbuffer, method);
1915         emit_obj (logbuffer, exc);
1916
1917         EXIT_LOG;
1918 }
1919
1920 static void
1921 monitor_event (MonoProfiler *profiler, MonoObject *object, MonoProfilerMonitorEvent ev)
1922 {
1923         int do_bt = (!log_config.enter_leave && InterlockedRead (&log_profiler.runtime_inited) && log_config.num_frames) ? TYPE_MONITOR_BT : 0;
1924         FrameData data;
1925
1926         if (do_bt)
1927                 collect_bt (&data);
1928
1929         ENTER_LOG (&monitor_events_ctr, logbuffer,
1930                 EVENT_SIZE /* event */ +
1931                 BYTE_SIZE /* ev */ +
1932                 LEB128_SIZE /* object */ +
1933                 (do_bt ? (
1934                         LEB128_SIZE /* count */ +
1935                         data.count * (
1936                                 LEB128_SIZE /* method */
1937                         )
1938                 ) : 0)
1939         );
1940
1941         emit_event (logbuffer, do_bt | TYPE_MONITOR);
1942         emit_byte (logbuffer, ev);
1943         emit_obj (logbuffer, object);
1944
1945         if (do_bt)
1946                 emit_bt (logbuffer, &data);
1947
1948         EXIT_LOG;
1949 }
1950
1951 static void
1952 monitor_contention (MonoProfiler *prof, MonoObject *object)
1953 {
1954         monitor_event (prof, object, MONO_PROFILER_MONITOR_CONTENTION);
1955 }
1956
1957 static void
1958 monitor_acquired (MonoProfiler *prof, MonoObject *object)
1959 {
1960         monitor_event (prof, object, MONO_PROFILER_MONITOR_DONE);
1961 }
1962
1963 static void
1964 monitor_failed (MonoProfiler *prof, MonoObject *object)
1965 {
1966         monitor_event (prof, object, MONO_PROFILER_MONITOR_FAIL);
1967 }
1968
1969 static void
1970 thread_start (MonoProfiler *prof, uintptr_t tid)
1971 {
1972         ENTER_LOG (&thread_starts_ctr, logbuffer,
1973                 EVENT_SIZE /* event */ +
1974                 BYTE_SIZE /* type */ +
1975                 LEB128_SIZE /* tid */
1976         );
1977
1978         emit_event (logbuffer, TYPE_END_LOAD | TYPE_METADATA);
1979         emit_byte (logbuffer, TYPE_THREAD);
1980         emit_ptr (logbuffer, (void*) tid);
1981
1982         EXIT_LOG;
1983 }
1984
1985 static void
1986 thread_end (MonoProfiler *prof, uintptr_t tid)
1987 {
1988         ENTER_LOG (&thread_ends_ctr, logbuffer,
1989                 EVENT_SIZE /* event */ +
1990                 BYTE_SIZE /* type */ +
1991                 LEB128_SIZE /* tid */
1992         );
1993
1994         emit_event (logbuffer, TYPE_END_UNLOAD | TYPE_METADATA);
1995         emit_byte (logbuffer, TYPE_THREAD);
1996         emit_ptr (logbuffer, (void*) tid);
1997
1998         EXIT_LOG_EXPLICIT (NO_SEND);
1999
2000         MonoProfilerThread *thread = get_thread ();
2001
2002         thread->ended = TRUE;
2003         remove_thread (thread);
2004
2005         PROF_TLS_SET (NULL);
2006 }
2007
2008 static void
2009 thread_name (MonoProfiler *prof, uintptr_t tid, const char *name)
2010 {
2011         int len = strlen (name) + 1;
2012
2013         ENTER_LOG (&thread_names_ctr, logbuffer,
2014                 EVENT_SIZE /* event */ +
2015                 BYTE_SIZE /* type */ +
2016                 LEB128_SIZE /* tid */ +
2017                 len /* name */
2018         );
2019
2020         emit_event (logbuffer, TYPE_METADATA);
2021         emit_byte (logbuffer, TYPE_THREAD);
2022         emit_ptr (logbuffer, (void*)tid);
2023         memcpy (logbuffer->cursor, name, len);
2024         logbuffer->cursor += len;
2025
2026         EXIT_LOG;
2027 }
2028
2029 static void
2030 domain_loaded (MonoProfiler *prof, MonoDomain *domain)
2031 {
2032         ENTER_LOG (&domain_loads_ctr, logbuffer,
2033                 EVENT_SIZE /* event */ +
2034                 BYTE_SIZE /* type */ +
2035                 LEB128_SIZE /* domain id */
2036         );
2037
2038         emit_event (logbuffer, TYPE_END_LOAD | TYPE_METADATA);
2039         emit_byte (logbuffer, TYPE_DOMAIN);
2040         emit_ptr (logbuffer, (void*)(uintptr_t) mono_domain_get_id (domain));
2041
2042         EXIT_LOG;
2043 }
2044
2045 static void
2046 domain_unloaded (MonoProfiler *prof, MonoDomain *domain)
2047 {
2048         ENTER_LOG (&domain_unloads_ctr, logbuffer,
2049                 EVENT_SIZE /* event */ +
2050                 BYTE_SIZE /* type */ +
2051                 LEB128_SIZE /* domain id */
2052         );
2053
2054         emit_event (logbuffer, TYPE_END_UNLOAD | TYPE_METADATA);
2055         emit_byte (logbuffer, TYPE_DOMAIN);
2056         emit_ptr (logbuffer, (void*)(uintptr_t) mono_domain_get_id (domain));
2057
2058         EXIT_LOG;
2059 }
2060
2061 static void
2062 domain_name (MonoProfiler *prof, MonoDomain *domain, const char *name)
2063 {
2064         int nlen = strlen (name) + 1;
2065
2066         ENTER_LOG (&domain_names_ctr, logbuffer,
2067                 EVENT_SIZE /* event */ +
2068                 BYTE_SIZE /* type */ +
2069                 LEB128_SIZE /* domain id */ +
2070                 nlen /* name */
2071         );
2072
2073         emit_event (logbuffer, TYPE_METADATA);
2074         emit_byte (logbuffer, TYPE_DOMAIN);
2075         emit_ptr (logbuffer, (void*)(uintptr_t) mono_domain_get_id (domain));
2076         memcpy (logbuffer->cursor, name, nlen);
2077         logbuffer->cursor += nlen;
2078
2079         EXIT_LOG;
2080 }
2081
2082 static void
2083 context_loaded (MonoProfiler *prof, MonoAppContext *context)
2084 {
2085         ENTER_LOG (&context_loads_ctr, logbuffer,
2086                 EVENT_SIZE /* event */ +
2087                 BYTE_SIZE /* type */ +
2088                 LEB128_SIZE /* context id */ +
2089                 LEB128_SIZE /* domain id */
2090         );
2091
2092         emit_event (logbuffer, TYPE_END_LOAD | TYPE_METADATA);
2093         emit_byte (logbuffer, TYPE_CONTEXT);
2094         emit_ptr (logbuffer, (void*)(uintptr_t) mono_context_get_id (context));
2095         emit_ptr (logbuffer, (void*)(uintptr_t) mono_context_get_domain_id (context));
2096
2097         EXIT_LOG;
2098 }
2099
2100 static void
2101 context_unloaded (MonoProfiler *prof, MonoAppContext *context)
2102 {
2103         ENTER_LOG (&context_unloads_ctr, logbuffer,
2104                 EVENT_SIZE /* event */ +
2105                 BYTE_SIZE /* type */ +
2106                 LEB128_SIZE /* context id */ +
2107                 LEB128_SIZE /* domain id */
2108         );
2109
2110         emit_event (logbuffer, TYPE_END_UNLOAD | TYPE_METADATA);
2111         emit_byte (logbuffer, TYPE_CONTEXT);
2112         emit_ptr (logbuffer, (void*)(uintptr_t) mono_context_get_id (context));
2113         emit_ptr (logbuffer, (void*)(uintptr_t) mono_context_get_domain_id (context));
2114
2115         EXIT_LOG;
2116 }
2117
2118 typedef struct {
2119         MonoMethod *method;
2120         MonoDomain *domain;
2121         void *base_address;
2122         int offset;
2123 } AsyncFrameInfo;
2124
2125 typedef struct {
2126         MonoLockFreeQueueNode node;
2127         uint64_t time;
2128         uintptr_t tid;
2129         const void *ip;
2130         int count;
2131         AsyncFrameInfo frames [MONO_ZERO_LEN_ARRAY];
2132 } SampleHit;
2133
2134 static mono_bool
2135 async_walk_stack (MonoMethod *method, MonoDomain *domain, void *base_address, int offset, void *data)
2136 {
2137         SampleHit *sample = (SampleHit *) data;
2138
2139         if (sample->count < log_config.num_frames) {
2140                 int i = sample->count;
2141
2142                 sample->frames [i].method = method;
2143                 sample->frames [i].domain = domain;
2144                 sample->frames [i].base_address = base_address;
2145                 sample->frames [i].offset = offset;
2146
2147                 sample->count++;
2148         }
2149
2150         return sample->count == log_config.num_frames;
2151 }
2152
2153 #define SAMPLE_SLOT_SIZE(FRAMES) (sizeof (SampleHit) + sizeof (AsyncFrameInfo) * (FRAMES - MONO_ZERO_LEN_ARRAY))
2154 #define SAMPLE_BLOCK_SIZE (mono_pagesize ())
2155
2156 static void
2157 enqueue_sample_hit (gpointer p)
2158 {
2159         SampleHit *sample = p;
2160
2161         mono_lock_free_queue_node_unpoison (&sample->node);
2162         mono_lock_free_queue_enqueue (&log_profiler.dumper_queue, &sample->node);
2163         mono_os_sem_post (&log_profiler.dumper_queue_sem);
2164 }
2165
2166 static void
2167 mono_sample_hit (MonoProfiler *profiler, const mono_byte *ip, const void *context)
2168 {
2169         /*
2170          * Please note: We rely on the runtime loading the profiler with
2171          * MONO_DL_EAGER (RTLD_NOW) so that references to runtime functions within
2172          * this function (and its siblings) are resolved when the profiler is
2173          * loaded. Otherwise, we would potentially invoke the dynamic linker when
2174          * invoking runtime functions, which is not async-signal-safe.
2175          */
2176
2177         if (InterlockedRead (&log_profiler.in_shutdown))
2178                 return;
2179
2180         SampleHit *sample = (SampleHit *) mono_lock_free_queue_dequeue (&profiler->sample_reuse_queue);
2181
2182         if (!sample) {
2183                 /*
2184                  * If we're out of reusable sample events and we're not allowed to
2185                  * allocate more, we have no choice but to drop the event.
2186                  */
2187                 if (InterlockedRead (&sample_allocations_ctr) >= log_config.max_allocated_sample_hits)
2188                         return;
2189
2190                 sample = mono_lock_free_alloc (&profiler->sample_allocator);
2191                 mono_lock_free_queue_node_init (&sample->node, TRUE);
2192
2193                 InterlockedIncrement (&sample_allocations_ctr);
2194         }
2195
2196         sample->count = 0;
2197         mono_stack_walk_async_safe (&async_walk_stack, (void *) context, sample);
2198
2199         sample->time = current_time ();
2200         sample->tid = thread_id ();
2201         sample->ip = ip;
2202
2203         mono_thread_hazardous_try_free (sample, enqueue_sample_hit);
2204 }
2205
2206 static uintptr_t *code_pages = 0;
2207 static int num_code_pages = 0;
2208 static int size_code_pages = 0;
2209 #define CPAGE_SHIFT (9)
2210 #define CPAGE_SIZE (1 << CPAGE_SHIFT)
2211 #define CPAGE_MASK (~(CPAGE_SIZE - 1))
2212 #define CPAGE_ADDR(p) ((p) & CPAGE_MASK)
2213
2214 static uintptr_t
2215 add_code_page (uintptr_t *hash, uintptr_t hsize, uintptr_t page)
2216 {
2217         uintptr_t i;
2218         uintptr_t start_pos;
2219         start_pos = (page >> CPAGE_SHIFT) % hsize;
2220         i = start_pos;
2221         do {
2222                 if (hash [i] && CPAGE_ADDR (hash [i]) == CPAGE_ADDR (page)) {
2223                         return 0;
2224                 } else if (!hash [i]) {
2225                         hash [i] = page;
2226                         return 1;
2227                 }
2228                 /* wrap around */
2229                 if (++i == hsize)
2230                         i = 0;
2231         } while (i != start_pos);
2232         g_assert_not_reached ();
2233         return 0;
2234 }
2235
2236 static void
2237 add_code_pointer (uintptr_t ip)
2238 {
2239         uintptr_t i;
2240         if (num_code_pages * 2 >= size_code_pages) {
2241                 uintptr_t *n;
2242                 uintptr_t old_size = size_code_pages;
2243                 size_code_pages *= 2;
2244                 if (size_code_pages == 0)
2245                         size_code_pages = 16;
2246                 n = (uintptr_t *) g_calloc (sizeof (uintptr_t) * size_code_pages, 1);
2247                 for (i = 0; i < old_size; ++i) {
2248                         if (code_pages [i])
2249                                 add_code_page (n, size_code_pages, code_pages [i]);
2250                 }
2251                 if (code_pages)
2252                         g_free (code_pages);
2253                 code_pages = n;
2254         }
2255         num_code_pages += add_code_page (code_pages, size_code_pages, ip & CPAGE_MASK);
2256 }
2257
2258 /* ELF code crashes on some systems. */
2259 //#if defined(HAVE_DL_ITERATE_PHDR) && defined(ELFMAG0)
2260 #if 0
2261 static void
2262 dump_ubin (const char *filename, uintptr_t load_addr, uint64_t offset, uintptr_t size)
2263 {
2264         int len = strlen (filename) + 1;
2265
2266         ENTER_LOG (&sample_ubins_ctr, logbuffer,
2267                 EVENT_SIZE /* event */ +
2268                 LEB128_SIZE /* load address */ +
2269                 LEB128_SIZE /* offset */ +
2270                 LEB128_SIZE /* size */ +
2271                 nlen /* file name */
2272         );
2273
2274         emit_event (logbuffer, TYPE_SAMPLE | TYPE_SAMPLE_UBIN);
2275         emit_ptr (logbuffer, load_addr);
2276         emit_uvalue (logbuffer, offset);
2277         emit_uvalue (logbuffer, size);
2278         memcpy (logbuffer->cursor, filename, len);
2279         logbuffer->cursor += len;
2280
2281         EXIT_LOG;
2282 }
2283 #endif
2284
2285 static void
2286 dump_usym (const char *name, uintptr_t value, uintptr_t size)
2287 {
2288         int len = strlen (name) + 1;
2289
2290         ENTER_LOG (&sample_usyms_ctr, logbuffer,
2291                 EVENT_SIZE /* event */ +
2292                 LEB128_SIZE /* value */ +
2293                 LEB128_SIZE /* size */ +
2294                 len /* name */
2295         );
2296
2297         emit_event (logbuffer, TYPE_SAMPLE | TYPE_SAMPLE_USYM);
2298         emit_ptr (logbuffer, (void*)value);
2299         emit_value (logbuffer, size);
2300         memcpy (logbuffer->cursor, name, len);
2301         logbuffer->cursor += len;
2302
2303         EXIT_LOG;
2304 }
2305
2306 /* ELF code crashes on some systems. */
2307 //#if defined(ELFMAG0)
2308 #if 0
2309
2310 #if SIZEOF_VOID_P == 4
2311 #define ELF_WSIZE 32
2312 #else
2313 #define ELF_WSIZE 64
2314 #endif
2315 #ifndef ElfW
2316 #define ElfW(type)      _ElfW (Elf, ELF_WSIZE, type)
2317 #define _ElfW(e,w,t)    _ElfW_1 (e, w, _##t)
2318 #define _ElfW_1(e,w,t)  e##w##t
2319 #endif
2320
2321 static void
2322 dump_elf_symbols (ElfW(Sym) *symbols, int num_symbols, const char *strtab, void *load_addr)
2323 {
2324         int i;
2325         for (i = 0; i < num_symbols; ++i) {
2326                 const char* sym;
2327                 sym =  strtab + symbols [i].st_name;
2328                 if (!symbols [i].st_name || !symbols [i].st_size || (symbols [i].st_info & 0xf) != STT_FUNC)
2329                         continue;
2330                 dump_usym (sym, (uintptr_t)load_addr + symbols [i].st_value, symbols [i].st_size);
2331         }
2332 }
2333
2334 static int
2335 read_elf_symbols (MonoProfiler *prof, const char *filename, void *load_addr)
2336 {
2337         int fd, i;
2338         void *data;
2339         struct stat statb;
2340         uint64_t file_size;
2341         ElfW(Ehdr) *header;
2342         ElfW(Shdr) *sheader;
2343         ElfW(Shdr) *shstrtabh;
2344         ElfW(Shdr) *symtabh = NULL;
2345         ElfW(Shdr) *strtabh = NULL;
2346         ElfW(Sym) *symbols = NULL;
2347         const char *strtab;
2348         int num_symbols;
2349
2350         fd = open (filename, O_RDONLY);
2351         if (fd < 0)
2352                 return 0;
2353         if (fstat (fd, &statb) != 0) {
2354                 close (fd);
2355                 return 0;
2356         }
2357         file_size = statb.st_size;
2358         data = mmap (NULL, file_size, PROT_READ, MAP_PRIVATE, fd, 0);
2359         close (fd);
2360         if (data == MAP_FAILED)
2361                 return 0;
2362         header = data;
2363         if (header->e_ident [EI_MAG0] != ELFMAG0 ||
2364                         header->e_ident [EI_MAG1] != ELFMAG1 ||
2365                         header->e_ident [EI_MAG2] != ELFMAG2 ||
2366                         header->e_ident [EI_MAG3] != ELFMAG3 ) {
2367                 munmap (data, file_size);
2368                 return 0;
2369         }
2370         sheader = (void*)((char*)data + header->e_shoff);
2371         shstrtabh = (void*)((char*)sheader + (header->e_shentsize * header->e_shstrndx));
2372         strtab = (const char*)data + shstrtabh->sh_offset;
2373         for (i = 0; i < header->e_shnum; ++i) {
2374                 if (sheader->sh_type == SHT_SYMTAB) {
2375                         symtabh = sheader;
2376                         strtabh = (void*)((char*)data + header->e_shoff + sheader->sh_link * header->e_shentsize);
2377                         break;
2378                 }
2379                 sheader = (void*)((char*)sheader + header->e_shentsize);
2380         }
2381         if (!symtabh || !strtabh) {
2382                 munmap (data, file_size);
2383                 return 0;
2384         }
2385         strtab = (const char*)data + strtabh->sh_offset;
2386         num_symbols = symtabh->sh_size / symtabh->sh_entsize;
2387         symbols = (void*)((char*)data + symtabh->sh_offset);
2388         dump_elf_symbols (symbols, num_symbols, strtab, load_addr);
2389         munmap (data, file_size);
2390         return 1;
2391 }
2392 #endif
2393
2394 /* ELF code crashes on some systems. */
2395 //#if defined(HAVE_DL_ITERATE_PHDR) && defined(ELFMAG0)
2396 #if 0
2397 static int
2398 elf_dl_callback (struct dl_phdr_info *info, size_t size, void *data)
2399 {
2400         char buf [256];
2401         const char *filename;
2402         BinaryObject *obj;
2403         char *a = (void*)info->dlpi_addr;
2404         int i, num_sym;
2405         ElfW(Dyn) *dyn = NULL;
2406         ElfW(Sym) *symtab = NULL;
2407         ElfW(Word) *hash_table = NULL;
2408         ElfW(Ehdr) *header = NULL;
2409         const char* strtab = NULL;
2410         for (obj = log_profiler.binary_objects; obj; obj = obj->next) {
2411                 if (obj->addr == a)
2412                         return 0;
2413         }
2414         filename = info->dlpi_name;
2415         if (!filename)
2416                 return 0;
2417         if (!info->dlpi_addr && !filename [0]) {
2418                 int l = readlink ("/proc/self/exe", buf, sizeof (buf) - 1);
2419                 if (l > 0) {
2420                         buf [l] = 0;
2421                         filename = buf;
2422                 }
2423         }
2424         obj = g_calloc (sizeof (BinaryObject), 1);
2425         obj->addr = (void*)info->dlpi_addr;
2426         obj->name = pstrdup (filename);
2427         obj->next = log_profiler.binary_objects;
2428         log_profiler.binary_objects = obj;
2429         a = NULL;
2430         for (i = 0; i < info->dlpi_phnum; ++i) {
2431                 if (info->dlpi_phdr[i].p_type == PT_LOAD && !header) {
2432                         header = (ElfW(Ehdr)*)(info->dlpi_addr + info->dlpi_phdr[i].p_vaddr);
2433                         if (header->e_ident [EI_MAG0] != ELFMAG0 ||
2434                                         header->e_ident [EI_MAG1] != ELFMAG1 ||
2435                                         header->e_ident [EI_MAG2] != ELFMAG2 ||
2436                                         header->e_ident [EI_MAG3] != ELFMAG3 ) {
2437                                 header = NULL;
2438                         }
2439                         dump_ubin (filename, info->dlpi_addr + info->dlpi_phdr[i].p_vaddr, info->dlpi_phdr[i].p_offset, info->dlpi_phdr[i].p_memsz);
2440                 } else if (info->dlpi_phdr[i].p_type == PT_DYNAMIC) {
2441                         dyn = (ElfW(Dyn) *)(info->dlpi_addr + info->dlpi_phdr[i].p_vaddr);
2442                 }
2443         }
2444         if (read_elf_symbols (filename, (void*)info->dlpi_addr))
2445                 return 0;
2446         if (!info->dlpi_name || !info->dlpi_name[0])
2447                 return 0;
2448         if (!dyn)
2449                 return 0;
2450         for (i = 0; dyn [i].d_tag != DT_NULL; ++i) {
2451                 if (dyn [i].d_tag == DT_SYMTAB) {
2452                         symtab = (ElfW(Sym) *)(a + dyn [i].d_un.d_ptr);
2453                 } else if (dyn [i].d_tag == DT_HASH) {
2454                         hash_table = (ElfW(Word) *)(a + dyn [i].d_un.d_ptr);
2455                 } else if (dyn [i].d_tag == DT_STRTAB) {
2456                         strtab = (const char*)(a + dyn [i].d_un.d_ptr);
2457                 }
2458         }
2459         if (!hash_table)
2460                 return 0;
2461         num_sym = hash_table [1];
2462         dump_elf_symbols (symtab, num_sym, strtab, (void*)info->dlpi_addr);
2463         return 0;
2464 }
2465
2466 static int
2467 load_binaries (void)
2468 {
2469         dl_iterate_phdr (elf_dl_callback, NULL);
2470         return 1;
2471 }
2472 #else
2473 static int
2474 load_binaries (void)
2475 {
2476         return 0;
2477 }
2478 #endif
2479
2480 static const char*
2481 symbol_for (uintptr_t code)
2482 {
2483 #ifdef HAVE_DLADDR
2484         void *ip = (void*)code;
2485         Dl_info di;
2486         if (dladdr (ip, &di)) {
2487                 if (di.dli_sname)
2488                         return di.dli_sname;
2489         } else {
2490         /*      char **names;
2491                 names = backtrace_symbols (&ip, 1);
2492                 if (names) {
2493                         const char* p = names [0];
2494                         g_free (names);
2495                         return p;
2496                 }
2497                 */
2498         }
2499 #endif
2500         return NULL;
2501 }
2502
2503 static void
2504 dump_unmanaged_coderefs (void)
2505 {
2506         int i;
2507         const char* last_symbol;
2508         uintptr_t addr, page_end;
2509
2510         if (load_binaries ())
2511                 return;
2512         for (i = 0; i < size_code_pages; ++i) {
2513                 const char* sym;
2514                 if (!code_pages [i] || code_pages [i] & 1)
2515                         continue;
2516                 last_symbol = NULL;
2517                 addr = CPAGE_ADDR (code_pages [i]);
2518                 page_end = addr + CPAGE_SIZE;
2519                 code_pages [i] |= 1;
2520                 /* we dump the symbols for the whole page */
2521                 for (; addr < page_end; addr += 16) {
2522                         sym = symbol_for (addr);
2523                         if (sym && sym == last_symbol)
2524                                 continue;
2525                         last_symbol = sym;
2526                         if (!sym)
2527                                 continue;
2528                         dump_usym (sym, addr, 0); /* let's not guess the size */
2529                 }
2530         }
2531 }
2532
2533 static void
2534 counters_add_agent (MonoCounter *counter)
2535 {
2536         if (InterlockedRead (&log_profiler.in_shutdown))
2537                 return;
2538
2539         MonoCounterAgent *agent, *item;
2540
2541         mono_os_mutex_lock (&log_profiler.counters_mutex);
2542
2543         for (agent = log_profiler.counters; agent; agent = agent->next) {
2544                 if (agent->counter == counter) {
2545                         agent->value_size = 0;
2546                         if (agent->value) {
2547                                 g_free (agent->value);
2548                                 agent->value = NULL;
2549                         }
2550                         goto done;
2551                 }
2552         }
2553
2554         agent = (MonoCounterAgent *) g_malloc (sizeof (MonoCounterAgent));
2555         agent->counter = counter;
2556         agent->value = NULL;
2557         agent->value_size = 0;
2558         agent->index = log_profiler.counters_index++;
2559         agent->emitted = FALSE;
2560         agent->next = NULL;
2561
2562         if (!log_profiler.counters) {
2563                 log_profiler.counters = agent;
2564         } else {
2565                 item = log_profiler.counters;
2566                 while (item->next)
2567                         item = item->next;
2568                 item->next = agent;
2569         }
2570
2571 done:
2572         mono_os_mutex_unlock (&log_profiler.counters_mutex);
2573 }
2574
2575 static mono_bool
2576 counters_init_foreach_callback (MonoCounter *counter, gpointer data)
2577 {
2578         counters_add_agent (counter);
2579         return TRUE;
2580 }
2581
2582 static void
2583 counters_init (void)
2584 {
2585         mono_os_mutex_init (&log_profiler.counters_mutex);
2586
2587         log_profiler.counters_index = 1;
2588
2589         mono_counters_on_register (&counters_add_agent);
2590         mono_counters_foreach (counters_init_foreach_callback, NULL);
2591 }
2592
2593 static void
2594 counters_emit (void)
2595 {
2596         MonoCounterAgent *agent;
2597         int len = 0;
2598         int size =
2599                 EVENT_SIZE /* event */ +
2600                 LEB128_SIZE /* len */
2601         ;
2602
2603         mono_os_mutex_lock (&log_profiler.counters_mutex);
2604
2605         for (agent = log_profiler.counters; agent; agent = agent->next) {
2606                 if (agent->emitted)
2607                         continue;
2608
2609                 size +=
2610                         LEB128_SIZE /* section */ +
2611                         strlen (mono_counter_get_name (agent->counter)) + 1 /* name */ +
2612                         BYTE_SIZE /* type */ +
2613                         BYTE_SIZE /* unit */ +
2614                         BYTE_SIZE /* variance */ +
2615                         LEB128_SIZE /* index */
2616                 ;
2617
2618                 len++;
2619         }
2620
2621         if (!len)
2622                 goto done;
2623
2624         ENTER_LOG (&counter_descriptors_ctr, logbuffer, size);
2625
2626         emit_event (logbuffer, TYPE_SAMPLE_COUNTERS_DESC | TYPE_SAMPLE);
2627         emit_value (logbuffer, len);
2628
2629         for (agent = log_profiler.counters; agent; agent = agent->next) {
2630                 const char *name;
2631
2632                 if (agent->emitted)
2633                         continue;
2634
2635                 name = mono_counter_get_name (agent->counter);
2636                 emit_value (logbuffer, mono_counter_get_section (agent->counter));
2637                 emit_string (logbuffer, name, strlen (name) + 1);
2638                 emit_byte (logbuffer, mono_counter_get_type (agent->counter));
2639                 emit_byte (logbuffer, mono_counter_get_unit (agent->counter));
2640                 emit_byte (logbuffer, mono_counter_get_variance (agent->counter));
2641                 emit_value (logbuffer, agent->index);
2642
2643                 agent->emitted = TRUE;
2644         }
2645
2646         EXIT_LOG;
2647
2648 done:
2649         mono_os_mutex_unlock (&log_profiler.counters_mutex);
2650 }
2651
2652 static void
2653 counters_sample (uint64_t timestamp)
2654 {
2655         MonoCounterAgent *agent;
2656         MonoCounter *counter;
2657         int type;
2658         int buffer_size;
2659         void *buffer;
2660         int size;
2661
2662         counters_emit ();
2663
2664         buffer_size = 8;
2665         buffer = g_calloc (1, buffer_size);
2666
2667         mono_os_mutex_lock (&log_profiler.counters_mutex);
2668
2669         size =
2670                 EVENT_SIZE /* event */
2671         ;
2672
2673         for (agent = log_profiler.counters; agent; agent = agent->next) {
2674                 size +=
2675                         LEB128_SIZE /* index */ +
2676                         BYTE_SIZE /* type */ +
2677                         mono_counter_get_size (agent->counter) /* value */
2678                 ;
2679         }
2680
2681         size +=
2682                 LEB128_SIZE /* stop marker */
2683         ;
2684
2685         ENTER_LOG (&counter_samples_ctr, logbuffer, size);
2686
2687         emit_event_time (logbuffer, TYPE_SAMPLE_COUNTERS | TYPE_SAMPLE, timestamp);
2688
2689         for (agent = log_profiler.counters; agent; agent = agent->next) {
2690                 size_t size;
2691
2692                 counter = agent->counter;
2693
2694                 size = mono_counter_get_size (counter);
2695
2696                 if (size > buffer_size) {
2697                         buffer_size = size;
2698                         buffer = g_realloc (buffer, buffer_size);
2699                 }
2700
2701                 memset (buffer, 0, buffer_size);
2702
2703                 g_assert (mono_counters_sample (counter, buffer, size));
2704
2705                 type = mono_counter_get_type (counter);
2706
2707                 if (!agent->value) {
2708                         agent->value = g_calloc (1, size);
2709                         agent->value_size = size;
2710                 } else {
2711                         if (type == MONO_COUNTER_STRING) {
2712                                 if (strcmp (agent->value, buffer) == 0)
2713                                         continue;
2714                         } else {
2715                                 if (agent->value_size == size && memcmp (agent->value, buffer, size) == 0)
2716                                         continue;
2717                         }
2718                 }
2719
2720                 emit_uvalue (logbuffer, agent->index);
2721                 emit_byte (logbuffer, type);
2722                 switch (type) {
2723                 case MONO_COUNTER_INT:
2724 #if SIZEOF_VOID_P == 4
2725                 case MONO_COUNTER_WORD:
2726 #endif
2727                         emit_svalue (logbuffer, *(int*)buffer - *(int*)agent->value);
2728                         break;
2729                 case MONO_COUNTER_UINT:
2730                         emit_uvalue (logbuffer, *(guint*)buffer - *(guint*)agent->value);
2731                         break;
2732                 case MONO_COUNTER_TIME_INTERVAL:
2733                 case MONO_COUNTER_LONG:
2734 #if SIZEOF_VOID_P == 8
2735                 case MONO_COUNTER_WORD:
2736 #endif
2737                         emit_svalue (logbuffer, *(gint64*)buffer - *(gint64*)agent->value);
2738                         break;
2739                 case MONO_COUNTER_ULONG:
2740                         emit_uvalue (logbuffer, *(guint64*)buffer - *(guint64*)agent->value);
2741                         break;
2742                 case MONO_COUNTER_DOUBLE:
2743                         emit_double (logbuffer, *(double*)buffer);
2744                         break;
2745                 case MONO_COUNTER_STRING:
2746                         if (size == 0) {
2747                                 emit_byte (logbuffer, 0);
2748                         } else {
2749                                 emit_byte (logbuffer, 1);
2750                                 emit_string (logbuffer, (char*)buffer, size);
2751                         }
2752                         break;
2753                 default:
2754                         g_assert_not_reached ();
2755                 }
2756
2757                 if (type == MONO_COUNTER_STRING && size > agent->value_size) {
2758                         agent->value = g_realloc (agent->value, size);
2759                         agent->value_size = size;
2760                 }
2761
2762                 if (size > 0)
2763                         memcpy (agent->value, buffer, size);
2764         }
2765         g_free (buffer);
2766
2767         emit_value (logbuffer, 0);
2768
2769         EXIT_LOG;
2770
2771         mono_os_mutex_unlock (&log_profiler.counters_mutex);
2772 }
2773
2774 static void
2775 perfcounters_emit (void)
2776 {
2777         PerfCounterAgent *pcagent;
2778         int len = 0;
2779         int size =
2780                 EVENT_SIZE /* event */ +
2781                 LEB128_SIZE /* len */
2782         ;
2783
2784         for (pcagent = log_profiler.perfcounters; pcagent; pcagent = pcagent->next) {
2785                 if (pcagent->emitted)
2786                         continue;
2787
2788                 size +=
2789                         LEB128_SIZE /* section */ +
2790                         strlen (pcagent->category_name) + 1 /* category name */ +
2791                         strlen (pcagent->name) + 1 /* name */ +
2792                         BYTE_SIZE /* type */ +
2793                         BYTE_SIZE /* unit */ +
2794                         BYTE_SIZE /* variance */ +
2795                         LEB128_SIZE /* index */
2796                 ;
2797
2798                 len++;
2799         }
2800
2801         if (!len)
2802                 return;
2803
2804         ENTER_LOG (&perfcounter_descriptors_ctr, logbuffer, size);
2805
2806         emit_event (logbuffer, TYPE_SAMPLE_COUNTERS_DESC | TYPE_SAMPLE);
2807         emit_value (logbuffer, len);
2808
2809         for (pcagent = log_profiler.perfcounters; pcagent; pcagent = pcagent->next) {
2810                 if (pcagent->emitted)
2811                         continue;
2812
2813                 emit_value (logbuffer, MONO_COUNTER_PERFCOUNTERS);
2814                 emit_string (logbuffer, pcagent->category_name, strlen (pcagent->category_name) + 1);
2815                 emit_string (logbuffer, pcagent->name, strlen (pcagent->name) + 1);
2816                 emit_byte (logbuffer, MONO_COUNTER_LONG);
2817                 emit_byte (logbuffer, MONO_COUNTER_RAW);
2818                 emit_byte (logbuffer, MONO_COUNTER_VARIABLE);
2819                 emit_value (logbuffer, pcagent->index);
2820
2821                 pcagent->emitted = TRUE;
2822         }
2823
2824         EXIT_LOG;
2825 }
2826
2827 static gboolean
2828 perfcounters_foreach (char *category_name, char *name, unsigned char type, gint64 value, gpointer user_data)
2829 {
2830         PerfCounterAgent *pcagent;
2831
2832         for (pcagent = log_profiler.perfcounters; pcagent; pcagent = pcagent->next) {
2833                 if (strcmp (pcagent->category_name, category_name) != 0 || strcmp (pcagent->name, name) != 0)
2834                         continue;
2835                 if (pcagent->value == value)
2836                         return TRUE;
2837
2838                 pcagent->value = value;
2839                 pcagent->updated = TRUE;
2840                 pcagent->deleted = FALSE;
2841                 return TRUE;
2842         }
2843
2844         pcagent = g_new0 (PerfCounterAgent, 1);
2845         pcagent->next = log_profiler.perfcounters;
2846         pcagent->index = log_profiler.counters_index++;
2847         pcagent->category_name = g_strdup (category_name);
2848         pcagent->name = g_strdup (name);
2849         pcagent->value = value;
2850         pcagent->emitted = FALSE;
2851         pcagent->updated = TRUE;
2852         pcagent->deleted = FALSE;
2853
2854         log_profiler.perfcounters = pcagent;
2855
2856         return TRUE;
2857 }
2858
2859 static void
2860 perfcounters_sample (uint64_t timestamp)
2861 {
2862         PerfCounterAgent *pcagent;
2863         int len = 0;
2864         int size;
2865
2866         mono_os_mutex_lock (&log_profiler.counters_mutex);
2867
2868         /* mark all perfcounters as deleted, foreach will unmark them as necessary */
2869         for (pcagent = log_profiler.perfcounters; pcagent; pcagent = pcagent->next)
2870                 pcagent->deleted = TRUE;
2871
2872         mono_perfcounter_foreach (perfcounters_foreach, NULL);
2873
2874         perfcounters_emit ();
2875
2876         size =
2877                 EVENT_SIZE /* event */
2878         ;
2879
2880         for (pcagent = log_profiler.perfcounters; pcagent; pcagent = pcagent->next) {
2881                 if (pcagent->deleted || !pcagent->updated)
2882                         continue;
2883
2884                 size +=
2885                         LEB128_SIZE /* index */ +
2886                         BYTE_SIZE /* type */ +
2887                         LEB128_SIZE /* value */
2888                 ;
2889
2890                 len++;
2891         }
2892
2893         if (!len)
2894                 goto done;
2895
2896         size +=
2897                 LEB128_SIZE /* stop marker */
2898         ;
2899
2900         ENTER_LOG (&perfcounter_samples_ctr, logbuffer, size);
2901
2902         emit_event_time (logbuffer, TYPE_SAMPLE_COUNTERS | TYPE_SAMPLE, timestamp);
2903
2904         for (pcagent = log_profiler.perfcounters; pcagent; pcagent = pcagent->next) {
2905                 if (pcagent->deleted || !pcagent->updated)
2906                         continue;
2907                 emit_uvalue (logbuffer, pcagent->index);
2908                 emit_byte (logbuffer, MONO_COUNTER_LONG);
2909                 emit_svalue (logbuffer, pcagent->value);
2910
2911                 pcagent->updated = FALSE;
2912         }
2913
2914         emit_value (logbuffer, 0);
2915
2916         EXIT_LOG;
2917
2918 done:
2919         mono_os_mutex_unlock (&log_profiler.counters_mutex);
2920 }
2921
2922 static void
2923 counters_and_perfcounters_sample (void)
2924 {
2925         uint64_t now = current_time ();
2926
2927         counters_sample (now);
2928         perfcounters_sample (now);
2929 }
2930
2931 typedef struct {
2932         MonoLockFreeQueueNode node;
2933         MonoMethod *method;
2934 } MethodNode;
2935
2936 typedef struct {
2937         int offset;
2938         int counter;
2939         char *filename;
2940         int line;
2941         int column;
2942 } CoverageEntry;
2943
2944 static void
2945 free_coverage_entry (gpointer data, gpointer userdata)
2946 {
2947         CoverageEntry *entry = (CoverageEntry *)data;
2948         g_free (entry->filename);
2949         g_free (entry);
2950 }
2951
2952 static void
2953 obtain_coverage_for_method (MonoProfiler *prof, const MonoProfilerCoverageData *entry)
2954 {
2955         int offset = entry->il_offset - log_profiler.coverage_previous_offset;
2956         CoverageEntry *e = g_new (CoverageEntry, 1);
2957
2958         log_profiler.coverage_previous_offset = entry->il_offset;
2959
2960         e->offset = offset;
2961         e->counter = entry->counter;
2962         e->filename = g_strdup(entry->file_name ? entry->file_name : "");
2963         e->line = entry->line;
2964         e->column = entry->column;
2965
2966         g_ptr_array_add (log_profiler.coverage_data, e);
2967 }
2968
2969 static char *
2970 parse_generic_type_names(char *name)
2971 {
2972         char *new_name, *ret;
2973         int within_generic_declaration = 0, generic_members = 1;
2974
2975         if (name == NULL || *name == '\0')
2976                 return g_strdup ("");
2977
2978         if (!(ret = new_name = (char *) g_calloc (strlen (name) * 4 + 1, sizeof (char))))
2979                 return NULL;
2980
2981         do {
2982                 switch (*name) {
2983                         case '<':
2984                                 within_generic_declaration = 1;
2985                                 break;
2986
2987                         case '>':
2988                                 within_generic_declaration = 0;
2989
2990                                 if (*(name - 1) != '<') {
2991                                         *new_name++ = '`';
2992                                         *new_name++ = '0' + generic_members;
2993                                 } else {
2994                                         memcpy (new_name, "&lt;&gt;", 8);
2995                                         new_name += 8;
2996                                 }
2997
2998                                 generic_members = 0;
2999                                 break;
3000
3001                         case ',':
3002                                 generic_members++;
3003                                 break;
3004
3005                         default:
3006                                 if (!within_generic_declaration)
3007                                         *new_name++ = *name;
3008
3009                                 break;
3010                 }
3011         } while (*name++);
3012
3013         return ret;
3014 }
3015
3016 static void
3017 build_method_buffer (gpointer key, gpointer value, gpointer userdata)
3018 {
3019         MonoMethod *method = (MonoMethod *)value;
3020         MonoClass *klass;
3021         MonoImage *image;
3022         char *class_name;
3023         const char *image_name, *method_name, *sig, *first_filename;
3024         guint i;
3025
3026         log_profiler.coverage_previous_offset = 0;
3027         log_profiler.coverage_data = g_ptr_array_new ();
3028
3029         mono_profiler_get_coverage_data (log_profiler.handle, method, obtain_coverage_for_method);
3030
3031         klass = mono_method_get_class (method);
3032         image = mono_class_get_image (klass);
3033         image_name = mono_image_get_name (image);
3034
3035         sig = mono_signature_get_desc (mono_method_signature (method), TRUE);
3036         class_name = parse_generic_type_names (mono_type_get_name (mono_class_get_type (klass)));
3037         method_name = mono_method_get_name (method);
3038
3039         if (log_profiler.coverage_data->len != 0) {
3040                 CoverageEntry *entry = (CoverageEntry *)log_profiler.coverage_data->pdata[0];
3041                 first_filename = entry->filename ? entry->filename : "";
3042         } else
3043                 first_filename = "";
3044
3045         image_name = image_name ? image_name : "";
3046         sig = sig ? sig : "";
3047         method_name = method_name ? method_name : "";
3048
3049         ENTER_LOG (&coverage_methods_ctr, logbuffer,
3050                 EVENT_SIZE /* event */ +
3051                 strlen (image_name) + 1 /* image name */ +
3052                 strlen (class_name) + 1 /* class name */ +
3053                 strlen (method_name) + 1 /* method name */ +
3054                 strlen (sig) + 1 /* signature */ +
3055                 strlen (first_filename) + 1 /* first file name */ +
3056                 LEB128_SIZE /* token */ +
3057                 LEB128_SIZE /* method id */ +
3058                 LEB128_SIZE /* entries */
3059         );
3060
3061         emit_event (logbuffer, TYPE_COVERAGE_METHOD | TYPE_COVERAGE);
3062         emit_string (logbuffer, image_name, strlen (image_name) + 1);
3063         emit_string (logbuffer, class_name, strlen (class_name) + 1);
3064         emit_string (logbuffer, method_name, strlen (method_name) + 1);
3065         emit_string (logbuffer, sig, strlen (sig) + 1);
3066         emit_string (logbuffer, first_filename, strlen (first_filename) + 1);
3067
3068         emit_uvalue (logbuffer, mono_method_get_token (method));
3069         emit_uvalue (logbuffer, log_profiler.coverage_method_id);
3070         emit_value (logbuffer, log_profiler.coverage_data->len);
3071
3072         EXIT_LOG;
3073
3074         for (i = 0; i < log_profiler.coverage_data->len; i++) {
3075                 CoverageEntry *entry = (CoverageEntry *)log_profiler.coverage_data->pdata[i];
3076
3077                 ENTER_LOG (&coverage_statements_ctr, logbuffer,
3078                         EVENT_SIZE /* event */ +
3079                         LEB128_SIZE /* method id */ +
3080                         LEB128_SIZE /* offset */ +
3081                         LEB128_SIZE /* counter */ +
3082                         LEB128_SIZE /* line */ +
3083                         LEB128_SIZE /* column */
3084                 );
3085
3086                 emit_event (logbuffer, TYPE_COVERAGE_STATEMENT | TYPE_COVERAGE);
3087                 emit_uvalue (logbuffer, log_profiler.coverage_method_id);
3088                 emit_uvalue (logbuffer, entry->offset);
3089                 emit_uvalue (logbuffer, entry->counter);
3090                 emit_uvalue (logbuffer, entry->line);
3091                 emit_uvalue (logbuffer, entry->column);
3092
3093                 EXIT_LOG;
3094         }
3095
3096         log_profiler.coverage_method_id++;
3097
3098         g_free (class_name);
3099
3100         g_ptr_array_foreach (log_profiler.coverage_data, free_coverage_entry, NULL);
3101         g_ptr_array_free (log_profiler.coverage_data, TRUE);
3102 }
3103
3104 /* This empties the queue */
3105 static guint
3106 count_queue (MonoLockFreeQueue *queue)
3107 {
3108         MonoLockFreeQueueNode *node;
3109         guint count = 0;
3110
3111         while ((node = mono_lock_free_queue_dequeue (queue))) {
3112                 count++;
3113                 mono_thread_hazardous_try_free (node, g_free);
3114         }
3115
3116         return count;
3117 }
3118
3119 static void
3120 build_class_buffer (gpointer key, gpointer value, gpointer userdata)
3121 {
3122         MonoClass *klass = (MonoClass *)key;
3123         MonoLockFreeQueue *class_methods = (MonoLockFreeQueue *)value;
3124         MonoImage *image;
3125         char *class_name;
3126         const char *assembly_name;
3127         int number_of_methods, partially_covered;
3128         guint fully_covered;
3129
3130         image = mono_class_get_image (klass);
3131         assembly_name = mono_image_get_name (image);
3132         class_name = mono_type_get_name (mono_class_get_type (klass));
3133
3134         assembly_name = assembly_name ? assembly_name : "";
3135         number_of_methods = mono_class_num_methods (klass);
3136         fully_covered = count_queue (class_methods);
3137         /* We don't handle partial covered yet */
3138         partially_covered = 0;
3139
3140         ENTER_LOG (&coverage_classes_ctr, logbuffer,
3141                 EVENT_SIZE /* event */ +
3142                 strlen (assembly_name) + 1 /* assembly name */ +
3143                 strlen (class_name) + 1 /* class name */ +
3144                 LEB128_SIZE /* no. methods */ +
3145                 LEB128_SIZE /* fully covered */ +
3146                 LEB128_SIZE /* partially covered */
3147         );
3148
3149         emit_event (logbuffer, TYPE_COVERAGE_CLASS | TYPE_COVERAGE);
3150         emit_string (logbuffer, assembly_name, strlen (assembly_name) + 1);
3151         emit_string (logbuffer, class_name, strlen (class_name) + 1);
3152         emit_uvalue (logbuffer, number_of_methods);
3153         emit_uvalue (logbuffer, fully_covered);
3154         emit_uvalue (logbuffer, partially_covered);
3155
3156         EXIT_LOG;
3157
3158         g_free (class_name);
3159 }
3160
3161 static void
3162 get_coverage_for_image (MonoImage *image, int *number_of_methods, guint *fully_covered, int *partially_covered)
3163 {
3164         MonoLockFreeQueue *image_methods = (MonoLockFreeQueue *)mono_conc_hashtable_lookup (log_profiler.coverage_image_to_methods, image);
3165
3166         *number_of_methods = mono_image_get_table_rows (image, MONO_TABLE_METHOD);
3167         if (image_methods)
3168                 *fully_covered = count_queue (image_methods);
3169         else
3170                 *fully_covered = 0;
3171
3172         // FIXME: We don't handle partially covered yet.
3173         *partially_covered = 0;
3174 }
3175
3176 static void
3177 build_assembly_buffer (gpointer key, gpointer value, gpointer userdata)
3178 {
3179         MonoAssembly *assembly = (MonoAssembly *)value;
3180         MonoImage *image = mono_assembly_get_image (assembly);
3181         const char *name, *guid, *filename;
3182         int number_of_methods = 0, partially_covered = 0;
3183         guint fully_covered = 0;
3184
3185         name = mono_image_get_name (image);
3186         guid = mono_image_get_guid (image);
3187         filename = mono_image_get_filename (image);
3188
3189         name = name ? name : "";
3190         guid = guid ? guid : "";
3191         filename = filename ? filename : "";
3192
3193         get_coverage_for_image (image, &number_of_methods, &fully_covered, &partially_covered);
3194
3195         ENTER_LOG (&coverage_assemblies_ctr, logbuffer,
3196                 EVENT_SIZE /* event */ +
3197                 strlen (name) + 1 /* name */ +
3198                 strlen (guid) + 1 /* guid */ +
3199                 strlen (filename) + 1 /* file name */ +
3200                 LEB128_SIZE /* no. methods */ +
3201                 LEB128_SIZE /* fully covered */ +
3202                 LEB128_SIZE /* partially covered */
3203         );
3204
3205         emit_event (logbuffer, TYPE_COVERAGE_ASSEMBLY | TYPE_COVERAGE);
3206         emit_string (logbuffer, name, strlen (name) + 1);
3207         emit_string (logbuffer, guid, strlen (guid) + 1);
3208         emit_string (logbuffer, filename, strlen (filename) + 1);
3209         emit_uvalue (logbuffer, number_of_methods);
3210         emit_uvalue (logbuffer, fully_covered);
3211         emit_uvalue (logbuffer, partially_covered);
3212
3213         EXIT_LOG;
3214 }
3215
3216 static void
3217 dump_coverage (void)
3218 {
3219         mono_os_mutex_lock (&log_profiler.coverage_mutex);
3220         mono_conc_hashtable_foreach (log_profiler.coverage_assemblies, build_assembly_buffer, NULL);
3221         mono_conc_hashtable_foreach (log_profiler.coverage_classes, build_class_buffer, NULL);
3222         mono_conc_hashtable_foreach (log_profiler.coverage_methods, build_method_buffer, NULL);
3223         mono_os_mutex_unlock (&log_profiler.coverage_mutex);
3224 }
3225
3226 static MonoLockFreeQueueNode *
3227 create_method_node (MonoMethod *method)
3228 {
3229         MethodNode *node = (MethodNode *) g_malloc (sizeof (MethodNode));
3230         mono_lock_free_queue_node_init ((MonoLockFreeQueueNode *) node, FALSE);
3231         node->method = method;
3232
3233         return (MonoLockFreeQueueNode *) node;
3234 }
3235
3236 static gboolean
3237 coverage_filter (MonoProfiler *prof, MonoMethod *method)
3238 {
3239         MonoError error;
3240         MonoClass *klass;
3241         MonoImage *image;
3242         MonoAssembly *assembly;
3243         MonoMethodHeader *header;
3244         guint32 iflags, flags, code_size;
3245         char *fqn, *classname;
3246         gboolean has_positive, found;
3247         MonoLockFreeQueue *image_methods, *class_methods;
3248         MonoLockFreeQueueNode *node;
3249
3250         flags = mono_method_get_flags (method, &iflags);
3251         if ((iflags & METHOD_IMPL_ATTRIBUTE_INTERNAL_CALL) ||
3252             (flags & METHOD_ATTRIBUTE_PINVOKE_IMPL))
3253                 return FALSE;
3254
3255         // Don't need to do anything else if we're already tracking this method
3256         if (mono_conc_hashtable_lookup (log_profiler.coverage_methods, method))
3257                 return TRUE;
3258
3259         klass = mono_method_get_class (method);
3260         image = mono_class_get_image (klass);
3261
3262         // Don't handle coverage for the core assemblies
3263         if (mono_conc_hashtable_lookup (log_profiler.coverage_suppressed_assemblies, (gpointer) mono_image_get_name (image)) != NULL)
3264                 return FALSE;
3265
3266         if (prof->coverage_filters) {
3267                 /* Check already filtered classes first */
3268                 if (mono_conc_hashtable_lookup (log_profiler.coverage_filtered_classes, klass))
3269                         return FALSE;
3270
3271                 classname = mono_type_get_name (mono_class_get_type (klass));
3272
3273                 fqn = g_strdup_printf ("[%s]%s", mono_image_get_name (image), classname);
3274
3275                 // Check positive filters first
3276                 has_positive = FALSE;
3277                 found = FALSE;
3278                 for (guint i = 0; i < prof->coverage_filters->len; ++i) {
3279                         char *filter = (char *)g_ptr_array_index (prof->coverage_filters, i);
3280
3281                         if (filter [0] == '+') {
3282                                 filter = &filter [1];
3283
3284                                 if (strstr (fqn, filter) != NULL)
3285                                         found = TRUE;
3286
3287                                 has_positive = TRUE;
3288                         }
3289                 }
3290
3291                 if (has_positive && !found) {
3292                         mono_os_mutex_lock (&log_profiler.coverage_mutex);
3293                         mono_conc_hashtable_insert (log_profiler.coverage_filtered_classes, klass, klass);
3294                         mono_os_mutex_unlock (&log_profiler.coverage_mutex);
3295                         g_free (fqn);
3296                         g_free (classname);
3297
3298                         return FALSE;
3299                 }
3300
3301                 for (guint i = 0; i < prof->coverage_filters->len; ++i) {
3302                         // FIXME: Is substring search sufficient?
3303                         char *filter = (char *)g_ptr_array_index (prof->coverage_filters, i);
3304                         if (filter [0] == '+')
3305                                 continue;
3306
3307                         // Skip '-'
3308                         filter = &filter [1];
3309
3310                         if (strstr (fqn, filter) != NULL) {
3311                                 mono_os_mutex_lock (&log_profiler.coverage_mutex);
3312                                 mono_conc_hashtable_insert (log_profiler.coverage_filtered_classes, klass, klass);
3313                                 mono_os_mutex_unlock (&log_profiler.coverage_mutex);
3314                                 g_free (fqn);
3315                                 g_free (classname);
3316
3317                                 return FALSE;
3318                         }
3319                 }
3320
3321                 g_free (fqn);
3322                 g_free (classname);
3323         }
3324
3325         header = mono_method_get_header_checked (method, &error);
3326         mono_error_cleanup (&error);
3327
3328         mono_method_header_get_code (header, &code_size, NULL);
3329
3330         assembly = mono_image_get_assembly (image);
3331
3332         // Need to keep the assemblies around for as long as they are kept in the hashtable
3333         // Nunit, for example, has a habit of unloading them before the coverage statistics are
3334         // generated causing a crash. See https://bugzilla.xamarin.com/show_bug.cgi?id=39325
3335         mono_assembly_addref (assembly);
3336
3337         mono_os_mutex_lock (&log_profiler.coverage_mutex);
3338         mono_conc_hashtable_insert (log_profiler.coverage_methods, method, method);
3339         mono_conc_hashtable_insert (log_profiler.coverage_assemblies, assembly, assembly);
3340         mono_os_mutex_unlock (&log_profiler.coverage_mutex);
3341
3342         image_methods = (MonoLockFreeQueue *)mono_conc_hashtable_lookup (log_profiler.coverage_image_to_methods, image);
3343
3344         if (image_methods == NULL) {
3345                 image_methods = (MonoLockFreeQueue *) g_malloc (sizeof (MonoLockFreeQueue));
3346                 mono_lock_free_queue_init (image_methods);
3347                 mono_os_mutex_lock (&log_profiler.coverage_mutex);
3348                 mono_conc_hashtable_insert (log_profiler.coverage_image_to_methods, image, image_methods);
3349                 mono_os_mutex_unlock (&log_profiler.coverage_mutex);
3350         }
3351
3352         node = create_method_node (method);
3353         mono_lock_free_queue_enqueue (image_methods, node);
3354
3355         class_methods = (MonoLockFreeQueue *)mono_conc_hashtable_lookup (log_profiler.coverage_classes, klass);
3356
3357         if (class_methods == NULL) {
3358                 class_methods = (MonoLockFreeQueue *) g_malloc (sizeof (MonoLockFreeQueue));
3359                 mono_lock_free_queue_init (class_methods);
3360                 mono_os_mutex_lock (&log_profiler.coverage_mutex);
3361                 mono_conc_hashtable_insert (log_profiler.coverage_classes, klass, class_methods);
3362                 mono_os_mutex_unlock (&log_profiler.coverage_mutex);
3363         }
3364
3365         node = create_method_node (method);
3366         mono_lock_free_queue_enqueue (class_methods, node);
3367
3368         return TRUE;
3369 }
3370
3371 #define LINE_BUFFER_SIZE 4096
3372 /* Max file limit of 128KB */
3373 #define MAX_FILE_SIZE 128 * 1024
3374 static char *
3375 get_file_content (FILE *stream)
3376 {
3377         char *buffer;
3378         ssize_t bytes_read;
3379         long filesize;
3380         int res, offset = 0;
3381
3382         res = fseek (stream, 0, SEEK_END);
3383         if (res < 0)
3384           return NULL;
3385
3386         filesize = ftell (stream);
3387         if (filesize < 0)
3388           return NULL;
3389
3390         res = fseek (stream, 0, SEEK_SET);
3391         if (res < 0)
3392           return NULL;
3393
3394         if (filesize > MAX_FILE_SIZE)
3395           return NULL;
3396
3397         buffer = (char *) g_malloc ((filesize + 1) * sizeof (char));
3398         while ((bytes_read = fread (buffer + offset, 1, LINE_BUFFER_SIZE, stream)) > 0)
3399                 offset += bytes_read;
3400
3401         /* NULL terminate our buffer */
3402         buffer[filesize] = '\0';
3403         return buffer;
3404 }
3405
3406 static char *
3407 get_next_line (char *contents, char **next_start)
3408 {
3409         char *p = contents;
3410
3411         if (p == NULL || *p == '\0') {
3412                 *next_start = NULL;
3413                 return NULL;
3414         }
3415
3416         while (*p != '\n' && *p != '\0')
3417                 p++;
3418
3419         if (*p == '\n') {
3420                 *p = '\0';
3421                 *next_start = p + 1;
3422         } else
3423                 *next_start = NULL;
3424
3425         return contents;
3426 }
3427
3428 static void
3429 init_suppressed_assemblies (void)
3430 {
3431         char *content;
3432         char *line;
3433         FILE *sa_file;
3434
3435         log_profiler.coverage_suppressed_assemblies = mono_conc_hashtable_new (g_str_hash, g_str_equal);
3436         sa_file = fopen (SUPPRESSION_DIR "/mono-profiler-log.suppression", "r");
3437         if (sa_file == NULL)
3438                 return;
3439
3440         /* Don't need to free @content as it is referred to by the lines stored in @suppressed_assemblies */
3441         content = get_file_content (sa_file);
3442         if (content == NULL)
3443                 g_error ("mono-profiler-log.suppression is greater than 128kb - aborting.");
3444
3445         while ((line = get_next_line (content, &content))) {
3446                 line = g_strchomp (g_strchug (line));
3447                 /* No locking needed as we're doing initialization */
3448                 mono_conc_hashtable_insert (log_profiler.coverage_suppressed_assemblies, line, line);
3449         }
3450
3451         fclose (sa_file);
3452 }
3453
3454 static void
3455 parse_cov_filter_file (GPtrArray *filters, const char *file)
3456 {
3457         FILE *filter_file = fopen (file, "r");
3458
3459         if (filter_file == NULL) {
3460                 mono_profiler_printf_err ("Could not open coverage filter file '%s'.", file);
3461                 return;
3462         }
3463
3464         /* Don't need to free content as it is referred to by the lines stored in @filters */
3465         char *content = get_file_content (filter_file);
3466
3467         if (content == NULL)
3468                 mono_profiler_printf_err ("Coverage filter file '%s' is larger than 128kb - ignoring.", file);
3469
3470         char *line;
3471
3472         while ((line = get_next_line (content, &content)))
3473                 g_ptr_array_add (filters, g_strchug (g_strchomp (line)));
3474
3475         fclose (filter_file);
3476 }
3477
3478 static void
3479 coverage_init (void)
3480 {
3481         mono_os_mutex_init (&log_profiler.coverage_mutex);
3482         log_profiler.coverage_methods = mono_conc_hashtable_new (NULL, NULL);
3483         log_profiler.coverage_assemblies = mono_conc_hashtable_new (NULL, NULL);
3484         log_profiler.coverage_classes = mono_conc_hashtable_new (NULL, NULL);
3485         log_profiler.coverage_filtered_classes = mono_conc_hashtable_new (NULL, NULL);
3486         log_profiler.coverage_image_to_methods = mono_conc_hashtable_new (NULL, NULL);
3487         init_suppressed_assemblies ();
3488 }
3489
3490 static void
3491 unref_coverage_assemblies (gpointer key, gpointer value, gpointer userdata)
3492 {
3493         MonoAssembly *assembly = (MonoAssembly *)value;
3494         mono_assembly_close (assembly);
3495 }
3496
3497 static void
3498 free_sample_hit (gpointer p)
3499 {
3500         mono_lock_free_free (p, SAMPLE_BLOCK_SIZE);
3501 }
3502
3503 static void
3504 cleanup_reusable_samples (void)
3505 {
3506         SampleHit *sample;
3507
3508         while ((sample = (SampleHit *) mono_lock_free_queue_dequeue (&log_profiler.sample_reuse_queue)))
3509                 mono_thread_hazardous_try_free (sample, free_sample_hit);
3510 }
3511
3512 static void
3513 log_early_shutdown (MonoProfiler *prof)
3514 {
3515         if (log_config.hs_on_shutdown) {
3516                 InterlockedWrite (&log_profiler.heapshot_requested, 1);
3517                 mono_gc_collect (mono_gc_max_generation ());
3518         }
3519 }
3520
3521 static void
3522 log_shutdown (MonoProfiler *prof)
3523 {
3524         InterlockedWrite (&log_profiler.in_shutdown, 1);
3525
3526         if (ENABLED (PROFLOG_COUNTER_EVENTS))
3527                 counters_and_perfcounters_sample ();
3528
3529         if (log_config.collect_coverage)
3530                 dump_coverage ();
3531
3532         char c = 1;
3533
3534         if (write (prof->pipes [1], &c, 1) != 1) {
3535                 mono_profiler_printf_err ("Could not write to log profiler pipe: %s", g_strerror (errno));
3536                 exit (1);
3537         }
3538
3539         mono_native_thread_join (prof->helper_thread);
3540
3541         mono_os_mutex_destroy (&log_profiler.counters_mutex);
3542
3543         MonoCounterAgent *mc_next;
3544
3545         for (MonoCounterAgent *cur = log_profiler.counters; cur; cur = mc_next) {
3546                 mc_next = cur->next;
3547                 g_free (cur);
3548         }
3549
3550         PerfCounterAgent *pc_next;
3551
3552         for (PerfCounterAgent *cur = log_profiler.perfcounters; cur; cur = pc_next) {
3553                 pc_next = cur->next;
3554                 g_free (cur);
3555         }
3556
3557         /*
3558          * Ensure that we empty the LLS completely, even if some nodes are
3559          * not immediately removed upon calling mono_lls_remove (), by
3560          * iterating until the head is NULL.
3561          */
3562         while (log_profiler.profiler_thread_list.head) {
3563                 MONO_LLS_FOREACH_SAFE (&log_profiler.profiler_thread_list, MonoProfilerThread, thread) {
3564                         g_assert (thread->attached && "Why is a thread in the LLS not attached?");
3565
3566                         remove_thread (thread);
3567                 } MONO_LLS_FOREACH_SAFE_END
3568         }
3569
3570         /*
3571          * Ensure that all threads have been freed, so that we don't miss any
3572          * buffers when we shut down the writer thread below.
3573          */
3574         mono_thread_hazardous_try_free_all ();
3575
3576         InterlockedWrite (&prof->run_dumper_thread, 0);
3577         mono_os_sem_post (&prof->dumper_queue_sem);
3578         mono_native_thread_join (prof->dumper_thread);
3579         mono_os_sem_destroy (&prof->dumper_queue_sem);
3580
3581         InterlockedWrite (&prof->run_writer_thread, 0);
3582         mono_os_sem_post (&prof->writer_queue_sem);
3583         mono_native_thread_join (prof->writer_thread);
3584         mono_os_sem_destroy (&prof->writer_queue_sem);
3585
3586         /*
3587          * Free all writer queue entries, and ensure that all sample hits will be
3588          * added to the sample reuse queue.
3589          */
3590         mono_thread_hazardous_try_free_all ();
3591
3592         cleanup_reusable_samples ();
3593
3594         /*
3595          * Finally, make sure that all sample hits are freed. This should cover all
3596          * hazardous data from the profiler. We can now be sure that the runtime
3597          * won't later invoke free functions in the profiler library after it has
3598          * been unloaded.
3599          */
3600         mono_thread_hazardous_try_free_all ();
3601
3602         gint32 state = InterlockedRead (&log_profiler.buffer_lock_state);
3603
3604         g_assert (!(state & 0xFFFF) && "Why is the reader count still non-zero?");
3605         g_assert (!(state >> 16) && "Why is the exclusive lock still held?");
3606
3607 #if defined (HAVE_SYS_ZLIB)
3608         if (prof->gzfile)
3609                 gzclose (prof->gzfile);
3610 #endif
3611         if (prof->pipe_output)
3612                 pclose (prof->file);
3613         else
3614                 fclose (prof->file);
3615
3616         mono_conc_hashtable_destroy (prof->method_table);
3617         mono_os_mutex_destroy (&prof->method_table_mutex);
3618
3619         if (log_config.collect_coverage) {
3620                 mono_os_mutex_lock (&log_profiler.coverage_mutex);
3621                 mono_conc_hashtable_foreach (log_profiler.coverage_assemblies, unref_coverage_assemblies, NULL);
3622                 mono_os_mutex_unlock (&log_profiler.coverage_mutex);
3623
3624                 mono_conc_hashtable_destroy (log_profiler.coverage_methods);
3625                 mono_conc_hashtable_destroy (log_profiler.coverage_assemblies);
3626                 mono_conc_hashtable_destroy (log_profiler.coverage_classes);
3627                 mono_conc_hashtable_destroy (log_profiler.coverage_filtered_classes);
3628
3629                 mono_conc_hashtable_destroy (log_profiler.coverage_image_to_methods);
3630                 mono_conc_hashtable_destroy (log_profiler.coverage_suppressed_assemblies);
3631                 mono_os_mutex_destroy (&log_profiler.coverage_mutex);
3632         }
3633
3634         mono_coop_mutex_destroy (&log_profiler.api_mutex);
3635
3636         PROF_TLS_FREE ();
3637
3638         g_free (prof->args);
3639 }
3640
3641 static char*
3642 new_filename (const char* filename)
3643 {
3644         time_t t = time (NULL);
3645         int pid = process_id ();
3646         char pid_buf [16];
3647         char time_buf [16];
3648         char *res, *d;
3649         const char *p;
3650         int count_dates = 0;
3651         int count_pids = 0;
3652         int s_date, s_pid;
3653         struct tm *ts;
3654         for (p = filename; *p; p++) {
3655                 if (*p != '%')
3656                         continue;
3657                 p++;
3658                 if (*p == 't')
3659                         count_dates++;
3660                 else if (*p == 'p')
3661                         count_pids++;
3662                 else if (*p == 0)
3663                         break;
3664         }
3665         if (!count_dates && !count_pids)
3666                 return pstrdup (filename);
3667         snprintf (pid_buf, sizeof (pid_buf), "%d", pid);
3668         ts = gmtime (&t);
3669         snprintf (time_buf, sizeof (time_buf), "%d%02d%02d%02d%02d%02d",
3670                 1900 + ts->tm_year, 1 + ts->tm_mon, ts->tm_mday, ts->tm_hour, ts->tm_min, ts->tm_sec);
3671         s_date = strlen (time_buf);
3672         s_pid = strlen (pid_buf);
3673         d = res = (char *) g_malloc (strlen (filename) + s_date * count_dates + s_pid * count_pids);
3674         for (p = filename; *p; p++) {
3675                 if (*p != '%') {
3676                         *d++ = *p;
3677                         continue;
3678                 }
3679                 p++;
3680                 if (*p == 't') {
3681                         strcpy (d, time_buf);
3682                         d += s_date;
3683                         continue;
3684                 } else if (*p == 'p') {
3685                         strcpy (d, pid_buf);
3686                         d += s_pid;
3687                         continue;
3688                 } else if (*p == '%') {
3689                         *d++ = '%';
3690                         continue;
3691                 } else if (*p == 0)
3692                         break;
3693                 *d++ = '%';
3694                 *d++ = *p;
3695         }
3696         *d = 0;
3697         return res;
3698 }
3699
3700 static void
3701 add_to_fd_set (fd_set *set, int fd, int *max_fd)
3702 {
3703         /*
3704          * This should only trigger for the basic FDs (server socket, pipes) at
3705          * startup if for some mysterious reason they're too large. In this case,
3706          * the profiler really can't function, and we're better off printing an
3707          * error and exiting.
3708          */
3709         if (fd >= FD_SETSIZE) {
3710                 mono_profiler_printf_err ("File descriptor is out of bounds for fd_set: %d", fd);
3711                 exit (1);
3712         }
3713
3714         FD_SET (fd, set);
3715
3716         if (*max_fd < fd)
3717                 *max_fd = fd;
3718 }
3719
3720 static void *
3721 helper_thread (void *arg)
3722 {
3723         mono_threads_attach_tools_thread ();
3724         mono_native_thread_set_name (mono_native_thread_id_get (), "Profiler helper");
3725
3726         MonoProfilerThread *thread = init_thread (FALSE);
3727
3728         GArray *command_sockets = g_array_new (FALSE, FALSE, sizeof (int));
3729
3730         while (1) {
3731                 fd_set rfds;
3732                 int max_fd = -1;
3733
3734                 FD_ZERO (&rfds);
3735
3736                 add_to_fd_set (&rfds, log_profiler.server_socket, &max_fd);
3737                 add_to_fd_set (&rfds, log_profiler.pipes [0], &max_fd);
3738
3739                 for (gint i = 0; i < command_sockets->len; i++)
3740                         add_to_fd_set (&rfds, g_array_index (command_sockets, int, i), &max_fd);
3741
3742                 struct timeval tv = { .tv_sec = 1, .tv_usec = 0 };
3743
3744                 // Sleep for 1sec or until a file descriptor has data.
3745                 if (select (max_fd + 1, &rfds, NULL, NULL, &tv) == -1) {
3746                         if (errno == EINTR)
3747                                 continue;
3748
3749                         mono_profiler_printf_err ("Could not poll in log profiler helper thread: %s", g_strerror (errno));
3750                         exit (1);
3751                 }
3752
3753                 if (ENABLED (PROFLOG_COUNTER_EVENTS))
3754                         counters_and_perfcounters_sample ();
3755
3756                 buffer_lock_excl ();
3757
3758                 sync_point (SYNC_POINT_PERIODIC);
3759
3760                 buffer_unlock_excl ();
3761
3762                 // Are we shutting down?
3763                 if (FD_ISSET (log_profiler.pipes [0], &rfds)) {
3764                         char c;
3765                         read (log_profiler.pipes [0], &c, 1);
3766                         break;
3767                 }
3768
3769                 for (gint i = 0; i < command_sockets->len; i++) {
3770                         int fd = g_array_index (command_sockets, int, i);
3771
3772                         if (!FD_ISSET (fd, &rfds))
3773                                 continue;
3774
3775                         char buf [64];
3776                         int len = read (fd, buf, sizeof (buf) - 1);
3777
3778                         if (len == -1)
3779                                 continue;
3780
3781                         if (!len) {
3782                                 // The other end disconnected.
3783                                 g_array_remove_index (command_sockets, i);
3784                                 close (fd);
3785
3786                                 continue;
3787                         }
3788
3789                         buf [len] = 0;
3790
3791                         if (log_config.hs_mode == MONO_PROFILER_HEAPSHOT_ON_DEMAND && !strcmp (buf, "heapshot\n")) {
3792                                 // Rely on the finalization callback triggering a GC.
3793                                 InterlockedWrite (&log_profiler.heapshot_requested, 1);
3794                                 mono_gc_finalize_notify ();
3795                         }
3796                 }
3797
3798                 if (FD_ISSET (log_profiler.server_socket, &rfds)) {
3799                         int fd = accept (log_profiler.server_socket, NULL, NULL);
3800
3801                         if (fd != -1) {
3802                                 if (fd >= FD_SETSIZE)
3803                                         close (fd);
3804                                 else
3805                                         g_array_append_val (command_sockets, fd);
3806                         }
3807                 }
3808         }
3809
3810         for (gint i = 0; i < command_sockets->len; i++)
3811                 close (g_array_index (command_sockets, int, i));
3812
3813         g_array_free (command_sockets, TRUE);
3814
3815         send_log_unsafe (FALSE);
3816         deinit_thread (thread);
3817
3818         mono_thread_info_detach ();
3819
3820         return NULL;
3821 }
3822
3823 static void
3824 start_helper_thread (void)
3825 {
3826         if (pipe (log_profiler.pipes) == -1) {
3827                 mono_profiler_printf_err ("Could not create log profiler pipe: %s", g_strerror (errno));
3828                 exit (1);
3829         }
3830
3831         log_profiler.server_socket = socket (PF_INET, SOCK_STREAM, 0);
3832
3833         if (log_profiler.server_socket == -1) {
3834                 mono_profiler_printf_err ("Could not create log profiler server socket: %s", g_strerror (errno));
3835                 exit (1);
3836         }
3837
3838         struct sockaddr_in server_address;
3839
3840         memset (&server_address, 0, sizeof (server_address));
3841         server_address.sin_family = AF_INET;
3842         server_address.sin_addr.s_addr = INADDR_ANY;
3843         server_address.sin_port = htons (log_profiler.command_port);
3844
3845         if (bind (log_profiler.server_socket, (struct sockaddr *) &server_address, sizeof (server_address)) == -1) {
3846                 mono_profiler_printf_err ("Could not bind log profiler server socket on port %d: %s", log_profiler.command_port, g_strerror (errno));
3847                 close (log_profiler.server_socket);
3848                 exit (1);
3849         }
3850
3851         if (listen (log_profiler.server_socket, 1) == -1) {
3852                 mono_profiler_printf_err ("Could not listen on log profiler server socket: %s", g_strerror (errno));
3853                 close (log_profiler.server_socket);
3854                 exit (1);
3855         }
3856
3857         socklen_t slen = sizeof (server_address);
3858
3859         if (getsockname (log_profiler.server_socket, (struct sockaddr *) &server_address, &slen)) {
3860                 mono_profiler_printf_err ("Could not retrieve assigned port for log profiler server socket: %s", g_strerror (errno));
3861                 close (log_profiler.server_socket);
3862                 exit (1);
3863         }
3864
3865         log_profiler.command_port = ntohs (server_address.sin_port);
3866
3867         if (!mono_native_thread_create (&log_profiler.helper_thread, helper_thread, NULL)) {
3868                 mono_profiler_printf_err ("Could not start log profiler helper thread");
3869                 close (log_profiler.server_socket);
3870                 exit (1);
3871         }
3872 }
3873
3874 static void
3875 free_writer_entry (gpointer p)
3876 {
3877         mono_lock_free_free (p, WRITER_ENTRY_BLOCK_SIZE);
3878 }
3879
3880 static gboolean
3881 handle_writer_queue_entry (void)
3882 {
3883         WriterQueueEntry *entry;
3884
3885         if ((entry = (WriterQueueEntry *) mono_lock_free_queue_dequeue (&log_profiler.writer_queue))) {
3886                 if (!entry->methods)
3887                         goto no_methods;
3888
3889                 gboolean wrote_methods = FALSE;
3890
3891                 /*
3892                  * Encode the method events in a temporary log buffer that we
3893                  * flush to disk before the main buffer, ensuring that all
3894                  * methods have metadata emitted before they're referenced.
3895                  *
3896                  * We use a 'proper' thread-local buffer for this as opposed
3897                  * to allocating and freeing a buffer by hand because the call
3898                  * to mono_method_full_name () below may trigger class load
3899                  * events when it retrieves the signature of the method. So a
3900                  * thread-local buffer needs to exist when such events occur.
3901                  */
3902                 for (guint i = 0; i < entry->methods->len; i++) {
3903                         MethodInfo *info = (MethodInfo *) g_ptr_array_index (entry->methods, i);
3904
3905                         if (mono_conc_hashtable_lookup (log_profiler.method_table, info->method))
3906                                 goto free_info; // This method already has metadata emitted.
3907
3908                         /*
3909                          * Other threads use this hash table to get a general
3910                          * idea of whether a method has already been emitted to
3911                          * the stream. Due to the way we add to this table, it
3912                          * can easily happen that multiple threads queue up the
3913                          * same methods, but that's OK since eventually all
3914                          * methods will be in this table and the thread-local
3915                          * method lists will just be empty for the rest of the
3916                          * app's lifetime.
3917                          */
3918                         mono_os_mutex_lock (&log_profiler.method_table_mutex);
3919                         mono_conc_hashtable_insert (log_profiler.method_table, info->method, info->method);
3920                         mono_os_mutex_unlock (&log_profiler.method_table_mutex);
3921
3922                         char *name = mono_method_full_name (info->method, 1);
3923                         int nlen = strlen (name) + 1;
3924                         void *cstart = info->ji ? mono_jit_info_get_code_start (info->ji) : NULL;
3925                         int csize = info->ji ? mono_jit_info_get_code_size (info->ji) : 0;
3926
3927                         ENTER_LOG (&method_jits_ctr, logbuffer,
3928                                 EVENT_SIZE /* event */ +
3929                                 LEB128_SIZE /* method */ +
3930                                 LEB128_SIZE /* start */ +
3931                                 LEB128_SIZE /* size */ +
3932                                 nlen /* name */
3933                         );
3934
3935                         emit_event_time (logbuffer, TYPE_JIT | TYPE_METHOD, info->time);
3936                         emit_method_inner (logbuffer, info->method);
3937                         emit_ptr (logbuffer, cstart);
3938                         emit_value (logbuffer, csize);
3939
3940                         memcpy (logbuffer->cursor, name, nlen);
3941                         logbuffer->cursor += nlen;
3942
3943                         EXIT_LOG_EXPLICIT (NO_SEND);
3944
3945                         mono_free (name);
3946
3947                         wrote_methods = TRUE;
3948
3949                 free_info:
3950                         g_free (info);
3951                 }
3952
3953                 g_ptr_array_free (entry->methods, TRUE);
3954
3955                 if (wrote_methods) {
3956                         MonoProfilerThread *thread = PROF_TLS_GET ();
3957
3958                         dump_buffer_threadless (thread->buffer);
3959                         init_buffer_state (thread);
3960                 }
3961
3962         no_methods:
3963                 dump_buffer (entry->buffer);
3964
3965                 mono_thread_hazardous_try_free (entry, free_writer_entry);
3966
3967                 return TRUE;
3968         }
3969
3970         return FALSE;
3971 }
3972
3973 static void *
3974 writer_thread (void *arg)
3975 {
3976         mono_threads_attach_tools_thread ();
3977         mono_native_thread_set_name (mono_native_thread_id_get (), "Profiler writer");
3978
3979         dump_header ();
3980
3981         MonoProfilerThread *thread = init_thread (FALSE);
3982
3983         while (InterlockedRead (&log_profiler.run_writer_thread)) {
3984                 mono_os_sem_wait (&log_profiler.writer_queue_sem, MONO_SEM_FLAGS_NONE);
3985                 handle_writer_queue_entry ();
3986         }
3987
3988         /* Drain any remaining entries on shutdown. */
3989         while (handle_writer_queue_entry ());
3990
3991         free_buffer (thread->buffer, thread->buffer->size);
3992         deinit_thread (thread);
3993
3994         mono_thread_info_detach ();
3995
3996         return NULL;
3997 }
3998
3999 static void
4000 start_writer_thread (void)
4001 {
4002         InterlockedWrite (&log_profiler.run_writer_thread, 1);
4003
4004         if (!mono_native_thread_create (&log_profiler.writer_thread, writer_thread, NULL)) {
4005                 mono_profiler_printf_err ("Could not start log profiler writer thread");
4006                 exit (1);
4007         }
4008 }
4009
4010 static void
4011 reuse_sample_hit (gpointer p)
4012 {
4013         SampleHit *sample = p;
4014
4015         mono_lock_free_queue_node_unpoison (&sample->node);
4016         mono_lock_free_queue_enqueue (&log_profiler.sample_reuse_queue, &sample->node);
4017 }
4018
4019 static gboolean
4020 handle_dumper_queue_entry (void)
4021 {
4022         SampleHit *sample;
4023
4024         if ((sample = (SampleHit *) mono_lock_free_queue_dequeue (&log_profiler.dumper_queue))) {
4025                 for (int i = 0; i < sample->count; ++i) {
4026                         MonoMethod *method = sample->frames [i].method;
4027                         MonoDomain *domain = sample->frames [i].domain;
4028                         void *address = sample->frames [i].base_address;
4029
4030                         if (!method) {
4031                                 g_assert (domain && "What happened to the domain pointer?");
4032                                 g_assert (address && "What happened to the instruction pointer?");
4033
4034                                 MonoJitInfo *ji = mono_jit_info_table_find (domain, (char *) address);
4035
4036                                 if (ji)
4037                                         sample->frames [i].method = mono_jit_info_get_method (ji);
4038                         }
4039                 }
4040
4041                 ENTER_LOG (&sample_hits_ctr, logbuffer,
4042                         EVENT_SIZE /* event */ +
4043                         LEB128_SIZE /* tid */ +
4044                         LEB128_SIZE /* count */ +
4045                         1 * (
4046                                 LEB128_SIZE /* ip */
4047                         ) +
4048                         LEB128_SIZE /* managed count */ +
4049                         sample->count * (
4050                                 LEB128_SIZE /* method */
4051                         )
4052                 );
4053
4054                 emit_event_time (logbuffer, TYPE_SAMPLE | TYPE_SAMPLE_HIT, sample->time);
4055                 emit_ptr (logbuffer, (void *) sample->tid);
4056                 emit_value (logbuffer, 1);
4057
4058                 // TODO: Actual native unwinding.
4059                 for (int i = 0; i < 1; ++i) {
4060                         emit_ptr (logbuffer, sample->ip);
4061                         add_code_pointer ((uintptr_t) sample->ip);
4062                 }
4063
4064                 /* new in data version 6 */
4065                 emit_uvalue (logbuffer, sample->count);
4066
4067                 for (int i = 0; i < sample->count; ++i)
4068                         emit_method (logbuffer, sample->frames [i].method);
4069
4070                 EXIT_LOG;
4071
4072                 mono_thread_hazardous_try_free (sample, reuse_sample_hit);
4073
4074                 dump_unmanaged_coderefs ();
4075         }
4076
4077         return FALSE;
4078 }
4079
4080 static void *
4081 dumper_thread (void *arg)
4082 {
4083         mono_threads_attach_tools_thread ();
4084         mono_native_thread_set_name (mono_native_thread_id_get (), "Profiler dumper");
4085
4086         MonoProfilerThread *thread = init_thread (FALSE);
4087
4088         while (InterlockedRead (&log_profiler.run_dumper_thread)) {
4089                 /*
4090                  * Flush samples every second so it doesn't seem like the profiler is
4091                  * not working if the program is mostly idle.
4092                  */
4093                 if (mono_os_sem_timedwait (&log_profiler.dumper_queue_sem, 1000, MONO_SEM_FLAGS_NONE) == MONO_SEM_TIMEDWAIT_RET_TIMEDOUT)
4094                         send_log_unsafe (FALSE);
4095
4096                 handle_dumper_queue_entry ();
4097         }
4098
4099         /* Drain any remaining entries on shutdown. */
4100         while (handle_dumper_queue_entry ());
4101
4102         send_log_unsafe (FALSE);
4103         deinit_thread (thread);
4104
4105         mono_thread_info_detach ();
4106
4107         return NULL;
4108 }
4109
4110 static void
4111 start_dumper_thread (void)
4112 {
4113         InterlockedWrite (&log_profiler.run_dumper_thread, 1);
4114
4115         if (!mono_native_thread_create (&log_profiler.dumper_thread, dumper_thread, NULL)) {
4116                 mono_profiler_printf_err ("Could not start log profiler dumper thread");
4117                 exit (1);
4118         }
4119 }
4120
4121 static void
4122 register_counter (const char *name, gint32 *counter)
4123 {
4124         mono_counters_register (name, MONO_COUNTER_UINT | MONO_COUNTER_PROFILER | MONO_COUNTER_MONOTONIC, counter);
4125 }
4126
4127 ICALL_EXPORT gint32
4128 proflog_icall_GetMaxStackTraceFrames (void)
4129 {
4130         return MAX_FRAMES;
4131 }
4132
4133 ICALL_EXPORT gint32
4134 proflog_icall_GetStackTraceFrames (void)
4135 {
4136         return log_config.num_frames;
4137 }
4138
4139 ICALL_EXPORT void
4140 proflog_icall_SetStackTraceFrames (gint32 value)
4141 {
4142         log_config.num_frames = value;
4143 }
4144
4145 ICALL_EXPORT MonoProfilerHeapshotMode
4146 proflog_icall_GetHeapshotMode (void)
4147 {
4148         return log_config.hs_mode;
4149 }
4150
4151 ICALL_EXPORT void
4152 proflog_icall_SetHeapshotMode (MonoProfilerHeapshotMode value)
4153 {
4154         log_config.hs_mode = value;
4155 }
4156
4157 ICALL_EXPORT gint32
4158 proflog_icall_GetHeapshotMillisecondsFrequency (void)
4159 {
4160         return log_config.hs_freq_ms;
4161 }
4162
4163 ICALL_EXPORT void
4164 proflog_icall_SetHeapshotMillisecondsFrequency (gint32 value)
4165 {
4166         log_config.hs_freq_ms = value;
4167 }
4168
4169 ICALL_EXPORT gint32
4170 proflog_icall_GetHeapshotCollectionsFrequency (void)
4171 {
4172         return log_config.hs_freq_gc;
4173 }
4174
4175 ICALL_EXPORT void
4176 proflog_icall_SetHeapshotCollectionsFrequency (gint32 value)
4177 {
4178         log_config.hs_freq_gc = value;
4179 }
4180
4181 ICALL_EXPORT gint32
4182 proflog_icall_GetCallDepth (void)
4183 {
4184         return log_config.max_call_depth;
4185 }
4186
4187 ICALL_EXPORT void
4188 proflog_icall_SetCallDepth (gint32 value)
4189 {
4190         log_config.max_call_depth = value;
4191 }
4192
4193 ICALL_EXPORT void
4194 proflog_icall_GetSampleMode (MonoProfilerSampleMode *mode, gint32 *frequency)
4195 {
4196         uint32_t freq;
4197
4198         mono_profiler_get_sample_mode (log_profiler.handle, mode, &freq);
4199
4200         *frequency = freq;
4201 }
4202
4203 ICALL_EXPORT MonoBoolean
4204 proflog_icall_SetSampleMode (MonoProfilerSampleMode mode, gint32 frequency)
4205 {
4206         mono_coop_mutex_lock (&log_profiler.api_mutex);
4207
4208         mono_bool result = mono_profiler_set_sample_mode (log_profiler.handle, mode, frequency);
4209
4210         if (mode != MONO_PROFILER_SAMPLE_MODE_NONE) {
4211                 ENABLE (PROFLOG_SAMPLE_EVENTS);
4212                 mono_profiler_set_sample_hit_callback (log_profiler.handle, mono_sample_hit);
4213         } else {
4214                 DISABLE (PROFLOG_SAMPLE_EVENTS);
4215                 mono_profiler_set_sample_hit_callback (log_profiler.handle, NULL);
4216         }
4217
4218         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4219
4220         return result;
4221 }
4222
4223 ICALL_EXPORT MonoBoolean
4224 proflog_icall_GetExceptionEvents (void)
4225 {
4226         return ENABLED (PROFLOG_EXCEPTION_EVENTS);
4227 }
4228
4229 ICALL_EXPORT void
4230 proflog_icall_SetExceptionEvents (MonoBoolean value)
4231 {
4232         mono_coop_mutex_lock (&log_profiler.api_mutex);
4233
4234         if (value) {
4235                 ENABLE (PROFLOG_EXCEPTION_EVENTS);
4236                 mono_profiler_set_exception_throw_callback (log_profiler.handle, throw_exc);
4237                 mono_profiler_set_exception_clause_callback (log_profiler.handle, clause_exc);
4238         } else {
4239                 DISABLE (PROFLOG_EXCEPTION_EVENTS);
4240                 mono_profiler_set_exception_throw_callback (log_profiler.handle, NULL);
4241                 mono_profiler_set_exception_clause_callback (log_profiler.handle, NULL);
4242         }
4243
4244         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4245 }
4246
4247 ICALL_EXPORT MonoBoolean
4248 proflog_icall_GetMonitorEvents (void)
4249 {
4250         return ENABLED (PROFLOG_MONITOR_EVENTS);
4251 }
4252
4253 ICALL_EXPORT void
4254 proflog_icall_SetMonitorEvents (MonoBoolean value)
4255 {
4256         mono_coop_mutex_lock (&log_profiler.api_mutex);
4257
4258         if (value) {
4259                 ENABLE (PROFLOG_MONITOR_EVENTS);
4260                 mono_profiler_set_monitor_contention_callback (log_profiler.handle, monitor_contention);
4261                 mono_profiler_set_monitor_acquired_callback (log_profiler.handle, monitor_acquired);
4262                 mono_profiler_set_monitor_failed_callback (log_profiler.handle, monitor_failed);
4263         } else {
4264                 DISABLE (PROFLOG_MONITOR_EVENTS);
4265                 mono_profiler_set_monitor_contention_callback (log_profiler.handle, NULL);
4266                 mono_profiler_set_monitor_acquired_callback (log_profiler.handle, NULL);
4267                 mono_profiler_set_monitor_failed_callback (log_profiler.handle, NULL);
4268         }
4269
4270         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4271 }
4272
4273 ICALL_EXPORT MonoBoolean
4274 proflog_icall_GetGCEvents (void)
4275 {
4276         return ENABLED (PROFLOG_GC_EVENTS);
4277 }
4278
4279 ICALL_EXPORT void
4280 proflog_icall_SetGCEvents (MonoBoolean value)
4281 {
4282         mono_coop_mutex_lock (&log_profiler.api_mutex);
4283
4284         if (value)
4285                 ENABLE (PROFLOG_GC_EVENTS);
4286         else
4287                 DISABLE (PROFLOG_GC_EVENTS);
4288
4289         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4290 }
4291
4292 ICALL_EXPORT MonoBoolean
4293 proflog_icall_GetGCAllocationEvents (void)
4294 {
4295         return ENABLED (PROFLOG_GC_ALLOCATION_EVENTS);
4296 }
4297
4298 ICALL_EXPORT void
4299 proflog_icall_SetGCAllocationEvents (MonoBoolean value)
4300 {
4301         mono_coop_mutex_lock (&log_profiler.api_mutex);
4302
4303         if (value) {
4304                 ENABLE (PROFLOG_GC_ALLOCATION_EVENTS);
4305                 mono_profiler_set_gc_allocation_callback (log_profiler.handle, gc_alloc);
4306         } else {
4307                 DISABLE (PROFLOG_GC_ALLOCATION_EVENTS);
4308                 mono_profiler_set_gc_allocation_callback (log_profiler.handle, NULL);
4309         }
4310
4311         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4312 }
4313
4314 ICALL_EXPORT MonoBoolean
4315 proflog_icall_GetGCMoveEvents (void)
4316 {
4317         return ENABLED (PROFLOG_GC_MOVE_EVENTS);
4318 }
4319
4320 ICALL_EXPORT void
4321 proflog_icall_SetGCMoveEvents (MonoBoolean value)
4322 {
4323         mono_coop_mutex_lock (&log_profiler.api_mutex);
4324
4325         if (value) {
4326                 ENABLE (PROFLOG_GC_MOVE_EVENTS);
4327                 mono_profiler_set_gc_moves_callback (log_profiler.handle, gc_moves);
4328         } else {
4329                 DISABLE (PROFLOG_GC_MOVE_EVENTS);
4330                 mono_profiler_set_gc_moves_callback (log_profiler.handle, NULL);
4331         }
4332
4333         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4334 }
4335
4336 ICALL_EXPORT MonoBoolean
4337 proflog_icall_GetGCRootEvents (void)
4338 {
4339         return ENABLED (PROFLOG_GC_ROOT_EVENTS);
4340 }
4341
4342 ICALL_EXPORT void
4343 proflog_icall_SetGCRootEvents (MonoBoolean value)
4344 {
4345         mono_coop_mutex_lock (&log_profiler.api_mutex);
4346
4347         if (value)
4348                 ENABLE (PROFLOG_GC_ROOT_EVENTS);
4349         else
4350                 DISABLE (PROFLOG_GC_ROOT_EVENTS);
4351
4352         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4353 }
4354
4355 ICALL_EXPORT MonoBoolean
4356 proflog_icall_GetGCHandleEvents (void)
4357 {
4358         return ENABLED (PROFLOG_GC_HANDLE_EVENTS);
4359 }
4360
4361 ICALL_EXPORT void
4362 proflog_icall_SetGCHandleEvents (MonoBoolean value)
4363 {
4364         mono_coop_mutex_lock (&log_profiler.api_mutex);
4365
4366         if (value) {
4367                 ENABLE (PROFLOG_GC_HANDLE_EVENTS);
4368                 mono_profiler_set_gc_handle_created_callback (log_profiler.handle, gc_handle_created);
4369                 mono_profiler_set_gc_handle_deleted_callback (log_profiler.handle, gc_handle_deleted);
4370         } else {
4371                 DISABLE (PROFLOG_GC_HANDLE_EVENTS);
4372                 mono_profiler_set_gc_handle_created_callback (log_profiler.handle, NULL);
4373                 mono_profiler_set_gc_handle_deleted_callback (log_profiler.handle, NULL);
4374         }
4375
4376         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4377 }
4378
4379 ICALL_EXPORT MonoBoolean
4380 proflog_icall_GetGCFinalizationEvents (void)
4381 {
4382         return ENABLED (PROFLOG_GC_FINALIZATION_EVENTS);
4383 }
4384
4385 ICALL_EXPORT void
4386 proflog_icall_SetGCFinalizationEvents (MonoBoolean value)
4387 {
4388         mono_coop_mutex_lock (&log_profiler.api_mutex);
4389
4390         if (value) {
4391                 ENABLE (PROFLOG_GC_FINALIZATION_EVENTS);
4392                 mono_profiler_set_gc_finalizing_callback (log_profiler.handle, finalize_begin);
4393                 mono_profiler_set_gc_finalizing_object_callback (log_profiler.handle, finalize_object_begin);
4394                 mono_profiler_set_gc_finalized_object_callback (log_profiler.handle, finalize_object_end);
4395         } else {
4396                 DISABLE (PROFLOG_GC_FINALIZATION_EVENTS);
4397                 mono_profiler_set_gc_finalizing_callback (log_profiler.handle, NULL);
4398                 mono_profiler_set_gc_finalizing_object_callback (log_profiler.handle, NULL);
4399                 mono_profiler_set_gc_finalized_object_callback (log_profiler.handle, NULL);
4400         }
4401
4402         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4403 }
4404
4405 ICALL_EXPORT MonoBoolean
4406 proflog_icall_GetCounterEvents (void)
4407 {
4408         return ENABLED (PROFLOG_COUNTER_EVENTS);
4409 }
4410
4411 ICALL_EXPORT void
4412 proflog_icall_SetCounterEvents (MonoBoolean value)
4413 {
4414         mono_coop_mutex_lock (&log_profiler.api_mutex);
4415
4416         if (value)
4417                 ENABLE (PROFLOG_COUNTER_EVENTS);
4418         else
4419                 DISABLE (PROFLOG_COUNTER_EVENTS);
4420
4421         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4422 }
4423
4424 ICALL_EXPORT MonoBoolean
4425 proflog_icall_GetJitEvents (void)
4426 {
4427         return ENABLED (PROFLOG_JIT_EVENTS);
4428 }
4429
4430 ICALL_EXPORT void
4431 proflog_icall_SetJitEvents (MonoBoolean value)
4432 {
4433         mono_coop_mutex_lock (&log_profiler.api_mutex);
4434
4435         if (value) {
4436                 ENABLE (PROFLOG_JIT_EVENTS);
4437                 mono_profiler_set_jit_code_buffer_callback (log_profiler.handle, code_buffer_new);
4438         } else {
4439                 DISABLE (PROFLOG_JIT_EVENTS);
4440                 mono_profiler_set_jit_code_buffer_callback (log_profiler.handle, NULL);
4441         }
4442
4443         mono_coop_mutex_unlock (&log_profiler.api_mutex);
4444 }
4445
4446 static void
4447 runtime_initialized (MonoProfiler *profiler)
4448 {
4449         InterlockedWrite (&log_profiler.runtime_inited, 1);
4450
4451         register_counter ("Sample events allocated", &sample_allocations_ctr);
4452         register_counter ("Log buffers allocated", &buffer_allocations_ctr);
4453
4454         register_counter ("Event: Sync points", &sync_points_ctr);
4455         register_counter ("Event: Heap objects", &heap_objects_ctr);
4456         register_counter ("Event: Heap starts", &heap_starts_ctr);
4457         register_counter ("Event: Heap ends", &heap_ends_ctr);
4458         register_counter ("Event: Heap roots", &heap_roots_ctr);
4459         register_counter ("Event: GC events", &gc_events_ctr);
4460         register_counter ("Event: GC resizes", &gc_resizes_ctr);
4461         register_counter ("Event: GC allocations", &gc_allocs_ctr);
4462         register_counter ("Event: GC moves", &gc_moves_ctr);
4463         register_counter ("Event: GC handle creations", &gc_handle_creations_ctr);
4464         register_counter ("Event: GC handle deletions", &gc_handle_deletions_ctr);
4465         register_counter ("Event: GC finalize starts", &finalize_begins_ctr);
4466         register_counter ("Event: GC finalize ends", &finalize_ends_ctr);
4467         register_counter ("Event: GC finalize object starts", &finalize_object_begins_ctr);
4468         register_counter ("Event: GC finalize object ends", &finalize_object_ends_ctr);
4469         register_counter ("Event: Image loads", &image_loads_ctr);
4470         register_counter ("Event: Image unloads", &image_unloads_ctr);
4471         register_counter ("Event: Assembly loads", &assembly_loads_ctr);
4472         register_counter ("Event: Assembly unloads", &assembly_unloads_ctr);
4473         register_counter ("Event: Class loads", &class_loads_ctr);
4474         register_counter ("Event: Class unloads", &class_unloads_ctr);
4475         register_counter ("Event: Method entries", &method_entries_ctr);
4476         register_counter ("Event: Method exits", &method_exits_ctr);
4477         register_counter ("Event: Method exception leaves", &method_exception_exits_ctr);
4478         register_counter ("Event: Method JITs", &method_jits_ctr);
4479         register_counter ("Event: Code buffers", &code_buffers_ctr);
4480         register_counter ("Event: Exception throws", &exception_throws_ctr);
4481         register_counter ("Event: Exception clauses", &exception_clauses_ctr);
4482         register_counter ("Event: Monitor events", &monitor_events_ctr);
4483         register_counter ("Event: Thread starts", &thread_starts_ctr);
4484         register_counter ("Event: Thread ends", &thread_ends_ctr);
4485         register_counter ("Event: Thread names", &thread_names_ctr);
4486         register_counter ("Event: Domain loads", &domain_loads_ctr);
4487         register_counter ("Event: Domain unloads", &domain_unloads_ctr);
4488         register_counter ("Event: Domain names", &domain_names_ctr);
4489         register_counter ("Event: Context loads", &context_loads_ctr);
4490         register_counter ("Event: Context unloads", &context_unloads_ctr);
4491         register_counter ("Event: Sample binaries", &sample_ubins_ctr);
4492         register_counter ("Event: Sample symbols", &sample_usyms_ctr);
4493         register_counter ("Event: Sample hits", &sample_hits_ctr);
4494         register_counter ("Event: Counter descriptors", &counter_descriptors_ctr);
4495         register_counter ("Event: Counter samples", &counter_samples_ctr);
4496         register_counter ("Event: Performance counter descriptors", &perfcounter_descriptors_ctr);
4497         register_counter ("Event: Performance counter samples", &perfcounter_samples_ctr);
4498         register_counter ("Event: Coverage methods", &coverage_methods_ctr);
4499         register_counter ("Event: Coverage statements", &coverage_statements_ctr);
4500         register_counter ("Event: Coverage classes", &coverage_classes_ctr);
4501         register_counter ("Event: Coverage assemblies", &coverage_assemblies_ctr);
4502
4503         counters_init ();
4504
4505         /*
4506          * We must start the helper thread before the writer thread. This is
4507          * because the helper thread sets up the command port which is written to
4508          * the log header by the writer thread.
4509          */
4510         start_helper_thread ();
4511         start_writer_thread ();
4512         start_dumper_thread ();
4513
4514         mono_coop_mutex_init (&log_profiler.api_mutex);
4515
4516 #define ADD_ICALL(NAME) \
4517         mono_add_internal_call ("Mono.Profiler.Log.LogProfiler::" EGLIB_STRINGIFY (NAME), proflog_icall_ ## NAME);
4518
4519         ADD_ICALL (GetMaxStackTraceFrames);
4520         ADD_ICALL (GetStackTraceFrames);
4521         ADD_ICALL (SetStackTraceFrames);
4522         ADD_ICALL (GetHeapshotMode);
4523         ADD_ICALL (SetHeapshotMode);
4524         ADD_ICALL (GetHeapshotMillisecondsFrequency);
4525         ADD_ICALL (SetHeapshotMillisecondsFrequency);
4526         ADD_ICALL (GetHeapshotCollectionsFrequency);
4527         ADD_ICALL (SetHeapshotCollectionsFrequency);
4528         ADD_ICALL (GetCallDepth);
4529         ADD_ICALL (SetCallDepth);
4530         ADD_ICALL (GetSampleMode);
4531         ADD_ICALL (SetSampleMode);
4532         ADD_ICALL (GetExceptionEvents);
4533         ADD_ICALL (SetExceptionEvents);
4534         ADD_ICALL (GetMonitorEvents);
4535         ADD_ICALL (SetMonitorEvents);
4536         ADD_ICALL (GetGCEvents);
4537         ADD_ICALL (SetGCEvents);
4538         ADD_ICALL (GetGCAllocationEvents);
4539         ADD_ICALL (SetGCAllocationEvents);
4540         ADD_ICALL (GetGCMoveEvents);
4541         ADD_ICALL (SetGCMoveEvents);
4542         ADD_ICALL (GetGCRootEvents);
4543         ADD_ICALL (SetGCRootEvents);
4544         ADD_ICALL (GetGCHandleEvents);
4545         ADD_ICALL (SetGCHandleEvents);
4546         ADD_ICALL (GetGCFinalizationEvents);
4547         ADD_ICALL (SetGCFinalizationEvents);
4548         ADD_ICALL (GetCounterEvents);
4549         ADD_ICALL (SetCounterEvents);
4550         ADD_ICALL (GetJitEvents);
4551         ADD_ICALL (SetJitEvents);
4552
4553 #undef ADD_ICALL
4554 }
4555
4556 static void
4557 create_profiler (const char *args, const char *filename, GPtrArray *filters)
4558 {
4559         char *nf;
4560
4561         log_profiler.args = pstrdup (args);
4562         log_profiler.command_port = log_config.command_port;
4563
4564         //If filename begin with +, append the pid at the end
4565         if (filename && *filename == '+')
4566                 filename = g_strdup_printf ("%s.%d", filename + 1, getpid ());
4567
4568         if (!filename) {
4569                 if (log_config.do_report)
4570                         filename = "|mprof-report -";
4571                 else
4572                         filename = "output.mlpd";
4573                 nf = (char*)filename;
4574         } else {
4575                 nf = new_filename (filename);
4576                 if (log_config.do_report) {
4577                         int s = strlen (nf) + 32;
4578                         char *p = (char *) g_malloc (s);
4579                         snprintf (p, s, "|mprof-report '--out=%s' -", nf);
4580                         g_free (nf);
4581                         nf = p;
4582                 }
4583         }
4584         if (*nf == '|') {
4585                 log_profiler.file = popen (nf + 1, "w");
4586                 log_profiler.pipe_output = 1;
4587         } else if (*nf == '#') {
4588                 int fd = strtol (nf + 1, NULL, 10);
4589                 log_profiler.file = fdopen (fd, "a");
4590         } else
4591                 log_profiler.file = fopen (nf, "wb");
4592
4593         if (!log_profiler.file) {
4594                 mono_profiler_printf_err ("Could not create log profiler output file '%s'.", nf);
4595                 exit (1);
4596         }
4597
4598 #if defined (HAVE_SYS_ZLIB)
4599         if (log_config.use_zip)
4600                 log_profiler.gzfile = gzdopen (fileno (log_profiler.file), "wb");
4601 #endif
4602
4603         /*
4604          * If you hit this assert while increasing MAX_FRAMES, you need to increase
4605          * SAMPLE_BLOCK_SIZE as well.
4606          */
4607         g_assert (SAMPLE_SLOT_SIZE (MAX_FRAMES) * 2 < LOCK_FREE_ALLOC_SB_USABLE_SIZE (SAMPLE_BLOCK_SIZE));
4608
4609         // FIXME: We should free this stuff too.
4610         mono_lock_free_allocator_init_size_class (&log_profiler.sample_size_class, SAMPLE_SLOT_SIZE (log_config.num_frames), SAMPLE_BLOCK_SIZE);
4611         mono_lock_free_allocator_init_allocator (&log_profiler.sample_allocator, &log_profiler.sample_size_class, MONO_MEM_ACCOUNT_PROFILER);
4612
4613         mono_lock_free_queue_init (&log_profiler.sample_reuse_queue);
4614
4615         g_assert (sizeof (WriterQueueEntry) * 2 < LOCK_FREE_ALLOC_SB_USABLE_SIZE (WRITER_ENTRY_BLOCK_SIZE));
4616
4617         // FIXME: We should free this stuff too.
4618         mono_lock_free_allocator_init_size_class (&log_profiler.writer_entry_size_class, sizeof (WriterQueueEntry), WRITER_ENTRY_BLOCK_SIZE);
4619         mono_lock_free_allocator_init_allocator (&log_profiler.writer_entry_allocator, &log_profiler.writer_entry_size_class, MONO_MEM_ACCOUNT_PROFILER);
4620
4621         mono_lock_free_queue_init (&log_profiler.writer_queue);
4622         mono_os_sem_init (&log_profiler.writer_queue_sem, 0);
4623
4624         mono_lock_free_queue_init (&log_profiler.dumper_queue);
4625         mono_os_sem_init (&log_profiler.dumper_queue_sem, 0);
4626
4627         mono_os_mutex_init (&log_profiler.method_table_mutex);
4628         log_profiler.method_table = mono_conc_hashtable_new (NULL, NULL);
4629
4630         if (log_config.collect_coverage)
4631                 coverage_init ();
4632
4633         log_profiler.coverage_filters = filters;
4634
4635         log_profiler.startup_time = current_time ();
4636 }
4637
4638 MONO_API void
4639 mono_profiler_init_log (const char *desc);
4640
4641 void
4642 mono_profiler_init_log (const char *desc)
4643 {
4644         GPtrArray *filters = NULL;
4645
4646         proflog_parse_args (&log_config, desc [3] == ':' ? desc + 4 : "");
4647
4648         if (log_config.cov_filter_files) {
4649                 filters = g_ptr_array_new ();
4650                 int i;
4651                 for (i = 0; i < log_config.cov_filter_files->len; ++i) {
4652                         const char *name = log_config.cov_filter_files->pdata [i];
4653                         parse_cov_filter_file (filters, name);
4654                 }
4655         }
4656
4657         init_time ();
4658
4659         PROF_TLS_INIT ();
4660
4661         create_profiler (desc, log_config.output_filename, filters);
4662
4663         mono_lls_init (&log_profiler.profiler_thread_list, NULL);
4664
4665         MonoProfilerHandle handle = log_profiler.handle = mono_profiler_create (&log_profiler);
4666
4667         /*
4668          * Required callbacks. These are either necessary for the profiler itself
4669          * to function, or provide metadata that's needed if other events (e.g.
4670          * allocations, exceptions) are dynamically enabled/disabled.
4671          */
4672
4673         mono_profiler_set_runtime_shutdown_begin_callback (handle, log_early_shutdown);
4674         mono_profiler_set_runtime_shutdown_end_callback (handle, log_shutdown);
4675         mono_profiler_set_runtime_initialized_callback (handle, runtime_initialized);
4676
4677         mono_profiler_set_gc_event_callback (handle, gc_event);
4678
4679         mono_profiler_set_thread_started_callback (handle, thread_start);
4680         mono_profiler_set_thread_stopped_callback (handle, thread_end);
4681         mono_profiler_set_thread_name_callback (handle, thread_name);
4682
4683         mono_profiler_set_domain_loaded_callback (handle, domain_loaded);
4684         mono_profiler_set_domain_unloading_callback (handle, domain_unloaded);
4685         mono_profiler_set_domain_name_callback (handle, domain_name);
4686
4687         mono_profiler_set_context_loaded_callback (handle, context_loaded);
4688         mono_profiler_set_context_unloaded_callback (handle, context_unloaded);
4689
4690         mono_profiler_set_assembly_loaded_callback (handle, assembly_loaded);
4691         mono_profiler_set_assembly_unloading_callback (handle, assembly_unloaded);
4692
4693         mono_profiler_set_image_loaded_callback (handle, image_loaded);
4694         mono_profiler_set_image_unloading_callback (handle, image_unloaded);
4695
4696         mono_profiler_set_class_loaded_callback (handle, class_loaded);
4697
4698         mono_profiler_set_jit_done_callback (handle, method_jitted);
4699
4700         if (ENABLED (PROFLOG_EXCEPTION_EVENTS)) {
4701                 mono_profiler_set_exception_throw_callback (handle, throw_exc);
4702                 mono_profiler_set_exception_clause_callback (handle, clause_exc);
4703         }
4704
4705         if (ENABLED (PROFLOG_MONITOR_EVENTS)) {
4706                 mono_profiler_set_monitor_contention_callback (handle, monitor_contention);
4707                 mono_profiler_set_monitor_acquired_callback (handle, monitor_acquired);
4708                 mono_profiler_set_monitor_failed_callback (handle, monitor_failed);
4709         }
4710
4711         if (ENABLED (PROFLOG_GC_EVENTS))
4712                 mono_profiler_set_gc_resize_callback (handle, gc_resize);
4713
4714         if (ENABLED (PROFLOG_GC_ALLOCATION_EVENTS))
4715                 mono_profiler_set_gc_allocation_callback (handle, gc_alloc);
4716
4717         if (ENABLED (PROFLOG_GC_MOVE_EVENTS))
4718                 mono_profiler_set_gc_moves_callback (handle, gc_moves);
4719
4720         if (ENABLED (PROFLOG_GC_ROOT_EVENTS))
4721                 mono_profiler_set_gc_roots_callback (handle, gc_roots);
4722
4723         if (ENABLED (PROFLOG_GC_HANDLE_EVENTS)) {
4724                 mono_profiler_set_gc_handle_created_callback (handle, gc_handle_created);
4725                 mono_profiler_set_gc_handle_deleted_callback (handle, gc_handle_deleted);
4726         }
4727
4728         if (ENABLED (PROFLOG_GC_FINALIZATION_EVENTS)) {
4729                 mono_profiler_set_gc_finalizing_callback (handle, finalize_begin);
4730                 mono_profiler_set_gc_finalized_callback (handle, finalize_end);
4731                 mono_profiler_set_gc_finalizing_object_callback (handle, finalize_object_begin);
4732         }
4733
4734         //On Demand heapshot uses the finalizer thread to force a collection and thus a heapshot
4735         mono_profiler_set_gc_finalized_callback (handle, finalize_end);
4736
4737         if (ENABLED (PROFLOG_SAMPLE_EVENTS))
4738                 mono_profiler_set_sample_hit_callback (handle, mono_sample_hit);
4739
4740         if (ENABLED (PROFLOG_JIT_EVENTS))
4741                 mono_profiler_set_jit_code_buffer_callback (handle, code_buffer_new);
4742
4743         if (log_config.enter_leave) {
4744                 mono_profiler_set_call_instrumentation_filter_callback (handle, method_filter);
4745                 mono_profiler_set_method_enter_callback (handle, method_enter);
4746                 mono_profiler_set_method_leave_callback (handle, method_leave);
4747                 mono_profiler_set_method_tail_call_callback (handle, tail_call);
4748                 mono_profiler_set_method_exception_leave_callback (handle, method_exc_leave);
4749         }
4750
4751         if (log_config.collect_coverage) {
4752                 mono_profiler_enable_coverage ();
4753                 mono_profiler_set_coverage_filter_callback (handle, coverage_filter);
4754         }
4755
4756         mono_profiler_enable_allocations ();
4757         mono_profiler_enable_sampling (handle);
4758
4759         /*
4760          * If no sample option was given by the user, this just leaves the sampling
4761          * thread in idle mode. We do this even if no option was given so that we
4762          * can warn if another profiler controls sampling parameters.
4763          */
4764         if (!mono_profiler_set_sample_mode (handle, log_config.sampling_mode, log_config.sample_freq))
4765                 mono_profiler_printf_err ("Another profiler controls sampling parameters; the log profiler will not be able to modify them.");
4766 }