X-Git-Url: https://git.lttng.org/?a=blobdiff_plain;f=src%2Fcommon%2Fust-consumer%2Fust-consumer.c;h=31effcc234d9f2168cca2ba82ab1cbcd3f4dcc68;hb=a0377dfefe40662ba7d68617bce6ff467114136c;hp=27d346b33f72c2045c698ef432b72da63e967a44;hpb=b623cb6a788d9e666d9a93658ab04b06458863ef;p=lttng-tools.git diff --git a/src/common/ust-consumer/ust-consumer.c b/src/common/ust-consumer/ust-consumer.c index 27d346b33..31effcc23 100644 --- a/src/common/ust-consumer/ust-consumer.c +++ b/src/common/ust-consumer/ust-consumer.c @@ -8,8 +8,8 @@ */ #define _LGPL_SOURCE -#include #include +#include #include #include #include @@ -47,6 +47,8 @@ extern struct lttng_consumer_global_data the_consumer_data; extern int consumer_poll_timeout; +DEFINE_LTTNG_UST_SIGBUS_STATE(); + /* * Free channel object and all streams associated with it. This MUST be used * only and only if the channel has _NEVER_ been added to the global channel @@ -56,7 +58,7 @@ static void destroy_channel(struct lttng_consumer_channel *channel) { struct lttng_consumer_stream *stream, *stmp; - assert(channel); + LTTNG_ASSERT(channel); DBG("UST consumer cleaning stream list"); @@ -97,8 +99,8 @@ static int add_channel(struct lttng_consumer_channel *channel, { int ret = 0; - assert(channel); - assert(ctx); + LTTNG_ASSERT(channel); + LTTNG_ASSERT(ctx); if (ctx->on_recv_channel != NULL) { ret = ctx->on_recv_channel(channel); @@ -132,8 +134,8 @@ static struct lttng_consumer_stream *allocate_stream(int cpu, int key, int alloc_ret; struct lttng_consumer_stream *stream = NULL; - assert(channel); - assert(ctx); + LTTNG_ASSERT(channel); + LTTNG_ASSERT(ctx); stream = consumer_stream_create( channel, @@ -254,8 +256,8 @@ static int create_ust_streams(struct lttng_consumer_channel *channel, struct lttng_consumer_stream *stream; pthread_mutex_t *current_stream_lock = NULL; - assert(channel); - assert(ctx); + LTTNG_ASSERT(channel); + LTTNG_ASSERT(ctx); /* * While a stream is available from ustctl. When NULL is returned, we've @@ -389,10 +391,10 @@ static int create_ust_channel(struct lttng_consumer_channel *channel, int *stream_fds; struct lttng_ust_ctl_consumer_channel *ust_channel; - assert(channel); - assert(attr); - assert(ust_chanp); - assert(channel->buffer_credentials.is_set); + LTTNG_ASSERT(channel); + LTTNG_ASSERT(attr); + LTTNG_ASSERT(ust_chanp); + LTTNG_ASSERT(channel->buffer_credentials.is_set); DBG3("Creating channel to ustctl with attr: [overwrite: %d, " "subbuf_size: %" PRIu64 ", num_subbuf: %" PRIu64 ", " @@ -479,8 +481,8 @@ static int send_sessiond_stream(int sock, struct lttng_consumer_stream *stream) { int ret; - assert(stream); - assert(sock >= 0); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(sock >= 0); DBG("UST consumer sending stream %" PRIu64 " to sessiond", stream->key); @@ -507,9 +509,9 @@ static int send_channel_to_sessiond_and_relayd(int sock, struct lttng_consumer_stream *stream; uint64_t net_seq_idx = -1ULL; - assert(channel); - assert(ctx); - assert(sock >= 0); + LTTNG_ASSERT(channel); + LTTNG_ASSERT(ctx); + LTTNG_ASSERT(sock >= 0); DBG("UST consumer sending channel %s to sessiond", channel->name); @@ -602,9 +604,9 @@ static int ask_channel(struct lttng_consumer_local_data *ctx, { int ret; - assert(ctx); - assert(channel); - assert(attr); + LTTNG_ASSERT(ctx); + LTTNG_ASSERT(channel); + LTTNG_ASSERT(attr); /* * This value is still used by the kernel consumer since for the kernel, @@ -661,8 +663,8 @@ static int send_streams_to_thread(struct lttng_consumer_channel *channel, int ret = 0; struct lttng_consumer_stream *stream, *stmp; - assert(channel); - assert(ctx); + LTTNG_ASSERT(channel); + LTTNG_ASSERT(ctx); /* Send streams to the corresponding thread. */ cds_list_for_each_entry_safe(stream, stmp, &channel->streams.head, @@ -727,7 +729,14 @@ static int flush_channel(uint64_t chan_key) } if (!stream->quiescent) { - lttng_ust_ctl_flush_buffer(stream->ustream, 0); + ret = lttng_ust_ctl_flush_buffer(stream->ustream, 0); + if (ret) { + ERR("Failed to flush buffer while flushing channel: channel key = %" PRIu64 ", channel name = '%s'", + chan_key, channel->name); + ret = LTTNG_ERR_BUFFER_FLUSH_FAILED; + pthread_mutex_unlock(&stream->lock); + goto error; + } stream->quiescent = true; } next: @@ -926,7 +935,7 @@ static int setup_metadata(struct lttng_consumer_local_data *ctx, uint64_t key) goto send_streams_error; } /* List MUST be empty after or else it could be reused. */ - assert(cds_list_empty(&metadata->streams.head)); + LTTNG_ASSERT(cds_list_empty(&metadata->streams.head)); ret = 0; goto end; @@ -960,15 +969,15 @@ static int snapshot_metadata(struct lttng_consumer_channel *metadata_channel, int ret = 0; struct lttng_consumer_stream *metadata_stream; - assert(path); - assert(ctx); + LTTNG_ASSERT(path); + LTTNG_ASSERT(ctx); DBG("UST consumer snapshot metadata with key %" PRIu64 " at path %s", key, path); rcu_read_lock(); - assert(!metadata_channel->monitor); + LTTNG_ASSERT(!metadata_channel->monitor); health_code_update(); @@ -993,7 +1002,7 @@ static int snapshot_metadata(struct lttng_consumer_channel *metadata_channel, } metadata_stream = metadata_channel->metadata_stream; - assert(metadata_stream); + LTTNG_ASSERT(metadata_stream); pthread_mutex_lock(&metadata_stream->lock); if (relayd_id != (uint64_t) -1ULL) { @@ -1076,8 +1085,8 @@ static int snapshot_channel(struct lttng_consumer_channel *channel, unsigned long consumed_pos, produced_pos; struct lttng_consumer_stream *stream; - assert(path); - assert(ctx); + LTTNG_ASSERT(path); + LTTNG_ASSERT(ctx); rcu_read_lock(); @@ -1085,7 +1094,7 @@ static int snapshot_channel(struct lttng_consumer_channel *channel, use_relayd = 1; } - assert(!channel->monitor); + LTTNG_ASSERT(!channel->monitor); DBG("UST consumer snapshot channel %" PRIu64, key); cds_list_for_each_entry(stream, &channel->streams.head, send_node) { @@ -1093,7 +1102,7 @@ static int snapshot_channel(struct lttng_consumer_channel *channel, /* Lock stream because we are about to change its state. */ pthread_mutex_lock(&stream->lock); - assert(channel->trace_chunk); + LTTNG_ASSERT(channel->trace_chunk); if (!lttng_trace_chunk_get(channel->trace_chunk)) { /* * Can't happen barring an internal error as the channel @@ -1103,7 +1112,7 @@ static int snapshot_channel(struct lttng_consumer_channel *channel, ret = -1; goto error_unlock; } - assert(!stream->trace_chunk); + LTTNG_ASSERT(!stream->trace_chunk); stream->trace_chunk = channel->trace_chunk; stream->net_seq_idx = relayd_id; @@ -1128,7 +1137,12 @@ static int snapshot_channel(struct lttng_consumer_channel *channel, * Else, if quiescent, it has already been done by the prior stop. */ if (!stream->quiescent) { - lttng_ust_ctl_flush_buffer(stream->ustream, 0); + ret = lttng_ust_ctl_flush_buffer(stream->ustream, 0); + if (ret < 0) { + ERR("Failed to flush buffer during snapshot of channel: channel key = %" PRIu64 ", channel name = '%s'", + channel->key, channel->name); + goto error_unlock; + } } ret = lttng_ustconsumer_take_snapshot(stream); @@ -1393,7 +1407,7 @@ int lttng_ustconsumer_recv_cmd(struct lttng_consumer_local_data *ctx, health_code_update(); /* deprecated */ - assert(msg.cmd_type != LTTNG_CONSUMER_STOP); + LTTNG_ASSERT(msg.cmd_type != LTTNG_CONSUMER_STOP); health_code_update(); @@ -1547,7 +1561,7 @@ int lttng_ustconsumer_recv_cmd(struct lttng_consumer_local_data *ctx, attr.type = LTTNG_UST_ABI_CHAN_METADATA; break; default: - assert(0); + abort(); goto error_fatal; }; @@ -1680,7 +1694,7 @@ int lttng_ustconsumer_recv_cmd(struct lttng_consumer_local_data *ctx, goto error_get_channel_fatal; } /* List MUST be empty after or else it could be reused. */ - assert(cds_list_empty(&found_channel->streams.head)); + LTTNG_ASSERT(cds_list_empty(&found_channel->streams.head)); end_get_channel: goto end_msg_sessiond; error_get_channel_fatal: @@ -2314,13 +2328,13 @@ end: return ret_func; } -void lttng_lttng_ust_ctl_flush_buffer(struct lttng_consumer_stream *stream, +int lttng_ust_flush_buffer(struct lttng_consumer_stream *stream, int producer_active) { - assert(stream); - assert(stream->ustream); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); - lttng_ust_ctl_flush_buffer(stream->ustream, producer_active); + return lttng_ust_ctl_flush_buffer(stream->ustream, producer_active); } /* @@ -2330,8 +2344,8 @@ void lttng_lttng_ust_ctl_flush_buffer(struct lttng_consumer_stream *stream, */ int lttng_ustconsumer_take_snapshot(struct lttng_consumer_stream *stream) { - assert(stream); - assert(stream->ustream); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); return lttng_ust_ctl_snapshot(stream->ustream); } @@ -2344,8 +2358,8 @@ int lttng_ustconsumer_take_snapshot(struct lttng_consumer_stream *stream) int lttng_ustconsumer_sample_snapshot_positions( struct lttng_consumer_stream *stream) { - assert(stream); - assert(stream->ustream); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); return lttng_ust_ctl_snapshot_sample_positions(stream->ustream); } @@ -2358,9 +2372,9 @@ int lttng_ustconsumer_sample_snapshot_positions( int lttng_ustconsumer_get_produced_snapshot( struct lttng_consumer_stream *stream, unsigned long *pos) { - assert(stream); - assert(stream->ustream); - assert(pos); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); + LTTNG_ASSERT(pos); return lttng_ust_ctl_snapshot_get_produced(stream->ustream, pos); } @@ -2373,36 +2387,36 @@ int lttng_ustconsumer_get_produced_snapshot( int lttng_ustconsumer_get_consumed_snapshot( struct lttng_consumer_stream *stream, unsigned long *pos) { - assert(stream); - assert(stream->ustream); - assert(pos); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); + LTTNG_ASSERT(pos); return lttng_ust_ctl_snapshot_get_consumed(stream->ustream, pos); } -void lttng_ustconsumer_flush_buffer(struct lttng_consumer_stream *stream, +int lttng_ustconsumer_flush_buffer(struct lttng_consumer_stream *stream, int producer) { - assert(stream); - assert(stream->ustream); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); - lttng_ust_ctl_flush_buffer(stream->ustream, producer); + return lttng_ust_ctl_flush_buffer(stream->ustream, producer); } -void lttng_ustconsumer_clear_buffer(struct lttng_consumer_stream *stream) +int lttng_ustconsumer_clear_buffer(struct lttng_consumer_stream *stream) { - assert(stream); - assert(stream->ustream); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); - lttng_ust_ctl_clear_buffer(stream->ustream); + return lttng_ust_ctl_clear_buffer(stream->ustream); } int lttng_ustconsumer_get_current_timestamp( struct lttng_consumer_stream *stream, uint64_t *ts) { - assert(stream); - assert(stream->ustream); - assert(ts); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); + LTTNG_ASSERT(ts); return lttng_ust_ctl_get_current_timestamp(stream->ustream, ts); } @@ -2410,9 +2424,9 @@ int lttng_ustconsumer_get_current_timestamp( int lttng_ustconsumer_get_sequence_number( struct lttng_consumer_stream *stream, uint64_t *seq) { - assert(stream); - assert(stream->ustream); - assert(seq); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); + LTTNG_ASSERT(seq); return lttng_ust_ctl_get_sequence_number(stream->ustream, seq); } @@ -2422,13 +2436,16 @@ int lttng_ustconsumer_get_sequence_number( */ void lttng_ustconsumer_on_stream_hangup(struct lttng_consumer_stream *stream) { - assert(stream); - assert(stream->ustream); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); pthread_mutex_lock(&stream->lock); if (!stream->quiescent) { - lttng_ust_ctl_flush_buffer(stream->ustream, 0); - stream->quiescent = true; + if (lttng_ust_ctl_flush_buffer(stream->ustream, 0) < 0) { + ERR("Failed to flush buffer on stream hang-up"); + } else { + stream->quiescent = true; + } } pthread_mutex_unlock(&stream->lock); stream->hangup_flush_done = 1; @@ -2438,9 +2455,9 @@ void lttng_ustconsumer_del_channel(struct lttng_consumer_channel *chan) { int i; - assert(chan); - assert(chan->uchan); - assert(chan->buffer_credentials.is_set); + LTTNG_ASSERT(chan); + LTTNG_ASSERT(chan->uchan); + LTTNG_ASSERT(chan->buffer_credentials.is_set); if (chan->switch_timer_enabled == 1) { consumer_timer_switch_stop(chan); @@ -2473,9 +2490,9 @@ void lttng_ustconsumer_del_channel(struct lttng_consumer_channel *chan) void lttng_ustconsumer_free_channel(struct lttng_consumer_channel *chan) { - assert(chan); - assert(chan->uchan); - assert(chan->buffer_credentials.is_set); + LTTNG_ASSERT(chan); + LTTNG_ASSERT(chan->uchan); + LTTNG_ASSERT(chan->buffer_credentials.is_set); consumer_metadata_cache_destroy(chan); lttng_ust_ctl_destroy_channel(chan->uchan); @@ -2493,8 +2510,8 @@ void lttng_ustconsumer_free_channel(struct lttng_consumer_channel *chan) void lttng_ustconsumer_del_stream(struct lttng_consumer_stream *stream) { - assert(stream); - assert(stream->ustream); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); if (stream->chan->switch_timer_enabled == 1) { consumer_timer_switch_stop(stream->chan); @@ -2504,16 +2521,16 @@ void lttng_ustconsumer_del_stream(struct lttng_consumer_stream *stream) int lttng_ustconsumer_get_wakeup_fd(struct lttng_consumer_stream *stream) { - assert(stream); - assert(stream->ustream); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); return lttng_ust_ctl_stream_get_wakeup_fd(stream->ustream); } int lttng_ustconsumer_close_wakeup_fd(struct lttng_consumer_stream *stream) { - assert(stream); - assert(stream->ustream); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); return lttng_ust_ctl_stream_close_wakeup_fd(stream->ustream); } @@ -2572,7 +2589,7 @@ int commit_one_metadata_packet(struct lttng_consumer_stream *stream) &stream->chan->metadata_cache->contents.data[stream->ust_metadata_pushed], stream->chan->metadata_cache->contents.size - stream->ust_metadata_pushed); - assert(write_len != 0); + LTTNG_ASSERT(write_len != 0); if (write_len < 0) { ERR("Writing one metadata packet"); ret = write_len; @@ -2580,7 +2597,7 @@ int commit_one_metadata_packet(struct lttng_consumer_stream *stream) } stream->ust_metadata_pushed += write_len; - assert(stream->chan->metadata_cache->contents.size >= + LTTNG_ASSERT(stream->chan->metadata_cache->contents.size >= stream->ust_metadata_pushed); ret = write_len; @@ -2589,8 +2606,12 @@ int commit_one_metadata_packet(struct lttng_consumer_stream *stream) * a metadata packet. Since the subbuffer is fully filled (with padding, * if needed), the stream is "quiescent" after this commit. */ - lttng_ust_ctl_flush_buffer(stream->ustream, 1); - stream->quiescent = true; + if (lttng_ust_ctl_flush_buffer(stream->ustream, 1)) { + ERR("Failed to flush buffer while commiting one metadata packet"); + ret = -EIO; + } else { + stream->quiescent = true; + } end: pthread_mutex_unlock(&stream->chan->metadata_cache->lock); return ret; @@ -2615,8 +2636,8 @@ enum sync_metadata_status lttng_ustconsumer_sync_metadata( enum sync_metadata_status status; struct lttng_consumer_channel *metadata_channel; - assert(ctx); - assert(metadata_stream); + LTTNG_ASSERT(ctx); + LTTNG_ASSERT(metadata_stream); metadata_channel = metadata_stream->chan; pthread_mutex_unlock(&metadata_stream->lock); @@ -2680,8 +2701,8 @@ static int notify_if_more_data(struct lttng_consumer_stream *stream, int ret; struct lttng_ust_ctl_consumer_stream *ustream; - assert(stream); - assert(ctx); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(ctx); ustream = stream->ustream; @@ -2699,7 +2720,7 @@ static int notify_if_more_data(struct lttng_consumer_stream *stream, } ret = lttng_ust_ctl_put_subbuf(ustream); - assert(!ret); + LTTNG_ASSERT(!ret); /* This stream still has data. Flag it and wake up the data thread. */ stream->has_data = 1; @@ -2885,30 +2906,50 @@ static int get_next_subbuffer_common(struct lttng_consumer_stream *stream, subbuffer->buffer.buffer = lttng_buffer_view_init( addr, 0, subbuffer->info.data.padded_subbuf_size); - assert(subbuffer->buffer.buffer.data != NULL); + LTTNG_ASSERT(subbuffer->buffer.buffer.data != NULL); end: return ret; } -static int get_next_subbuffer(struct lttng_consumer_stream *stream, +static enum get_next_subbuffer_status get_next_subbuffer( + struct lttng_consumer_stream *stream, struct stream_subbuffer *subbuffer) { int ret; + enum get_next_subbuffer_status status; ret = lttng_ust_ctl_get_next_subbuf(stream->ustream); - if (ret) { + switch (ret) { + case 0: + status = GET_NEXT_SUBBUFFER_STATUS_OK; + break; + case -ENODATA: + case -EAGAIN: + /* + * The caller only expects -ENODATA when there is no data to + * read, but the kernel tracer returns -EAGAIN when there is + * currently no data for a non-finalized stream, and -ENODATA + * when there is no data for a finalized stream. Those can be + * combined into a -ENODATA return value. + */ + status = GET_NEXT_SUBBUFFER_STATUS_NO_DATA; + goto end; + default: + status = GET_NEXT_SUBBUFFER_STATUS_ERROR; goto end; } ret = get_next_subbuffer_common(stream, subbuffer); if (ret) { + status = GET_NEXT_SUBBUFFER_STATUS_ERROR; goto end; } end: - return ret; + return status; } -static int get_next_subbuffer_metadata(struct lttng_consumer_stream *stream, +static enum get_next_subbuffer_status get_next_subbuffer_metadata( + struct lttng_consumer_stream *stream, struct stream_subbuffer *subbuffer) { int ret; @@ -2917,6 +2958,7 @@ static int get_next_subbuffer_metadata(struct lttng_consumer_stream *stream, bool coherent; bool buffer_empty; unsigned long consumed_pos, produced_pos; + enum get_next_subbuffer_status status; do { ret = lttng_ust_ctl_get_next_subbuf(stream->ustream); @@ -2926,6 +2968,7 @@ static int get_next_subbuffer_metadata(struct lttng_consumer_stream *stream, got_subbuffer = false; if (ret != -EAGAIN) { /* Fatal error. */ + status = GET_NEXT_SUBBUFFER_STATUS_ERROR; goto end; } } @@ -2937,11 +2980,12 @@ static int get_next_subbuffer_metadata(struct lttng_consumer_stream *stream, if (!got_subbuffer) { ret = commit_one_metadata_packet(stream); if (ret < 0 && ret != -ENOBUFS) { + status = GET_NEXT_SUBBUFFER_STATUS_ERROR; goto end; } else if (ret == 0) { /* Not an error, the cache is empty. */ cache_empty = true; - ret = -ENODATA; + status = GET_NEXT_SUBBUFFER_STATUS_NO_DATA; goto end; } else { cache_empty = false; @@ -2957,6 +3001,7 @@ static int get_next_subbuffer_metadata(struct lttng_consumer_stream *stream, /* Populate sub-buffer infos and view. */ ret = get_next_subbuffer_common(stream, subbuffer); if (ret) { + status = GET_NEXT_SUBBUFFER_STATUS_ERROR; goto end; } @@ -2967,18 +3012,21 @@ static int get_next_subbuffer_metadata(struct lttng_consumer_stream *stream, * pushed the consumption position yet (on put_next). */ PERROR("Failed to take a snapshot of metadata buffer positions"); + status = GET_NEXT_SUBBUFFER_STATUS_ERROR; goto end; } ret = lttng_ustconsumer_get_consumed_snapshot(stream, &consumed_pos); if (ret) { PERROR("Failed to get metadata consumed position"); + status = GET_NEXT_SUBBUFFER_STATUS_ERROR; goto end; } ret = lttng_ustconsumer_get_produced_snapshot(stream, &produced_pos); if (ret) { PERROR("Failed to get metadata produced position"); + status = GET_NEXT_SUBBUFFER_STATUS_ERROR; goto end; } @@ -2994,8 +3042,9 @@ static int get_next_subbuffer_metadata(struct lttng_consumer_stream *stream, coherent = got_subbuffer && cache_empty && buffer_empty; LTTNG_OPTIONAL_SET(&subbuffer->info.metadata.coherent, coherent); + status = GET_NEXT_SUBBUFFER_STATUS_OK; end: - return ret; + return status; } static int put_next_subbuffer(struct lttng_consumer_stream *stream, @@ -3003,7 +3052,7 @@ static int put_next_subbuffer(struct lttng_consumer_stream *stream, { const int ret = lttng_ust_ctl_put_next_subbuf(stream->ustream); - assert(ret == 0); + LTTNG_ASSERT(ret == 0); return ret; } @@ -3061,7 +3110,7 @@ int lttng_ustconsumer_on_recv_stream(struct lttng_consumer_stream *stream) { int ret; - assert(stream); + LTTNG_ASSERT(stream); /* * Don't create anything if this is set for streaming or if there is @@ -3094,8 +3143,8 @@ int lttng_ustconsumer_data_pending(struct lttng_consumer_stream *stream) { int ret; - assert(stream); - assert(stream->ustream); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream->ustream); ASSERT_LOCKED(stream->lock); DBG("UST consumer checking data pending"); @@ -3126,7 +3175,7 @@ int lttng_ustconsumer_data_pending(struct lttng_consumer_stream *stream) */ DBG("UST consumer metadata pending check: contiguous %" PRIu64 " vs pushed %" PRIu64, contiguous, pushed); - assert(((int64_t) (contiguous - pushed)) >= 0); + LTTNG_ASSERT(((int64_t) (contiguous - pushed)) >= 0); if ((contiguous != pushed) || (((int64_t) contiguous - pushed) > 0 || contiguous == 0)) { ret = 1; /* Data is pending */ @@ -3140,7 +3189,7 @@ int lttng_ustconsumer_data_pending(struct lttng_consumer_stream *stream) * subbuffer. */ ret = lttng_ust_ctl_put_subbuf(stream->ustream); - assert(ret == 0); + LTTNG_ASSERT(ret == 0); ret = 1; /* Data is pending */ goto end; } @@ -3163,8 +3212,8 @@ void lttng_ustconsumer_close_metadata(struct lttng_consumer_channel *metadata) { int ret; - assert(metadata); - assert(metadata->type == CONSUMER_CHANNEL_TYPE_METADATA); + LTTNG_ASSERT(metadata); + LTTNG_ASSERT(metadata->type == CONSUMER_CHANNEL_TYPE_METADATA); DBG("Closing metadata channel key %" PRIu64, metadata->key); @@ -3206,8 +3255,8 @@ void lttng_ustconsumer_close_all_metadata(struct lttng_ht *metadata_ht) struct lttng_ht_iter iter; struct lttng_consumer_stream *stream; - assert(metadata_ht); - assert(metadata_ht->ht); + LTTNG_ASSERT(metadata_ht); + LTTNG_ASSERT(metadata_ht->ht); DBG("UST consumer closing all metadata streams"); @@ -3254,8 +3303,8 @@ int lttng_ustconsumer_request_metadata(struct lttng_consumer_local_data *ctx, uint64_t len, key, offset, version; int ret; - assert(channel); - assert(channel->metadata_cache); + LTTNG_ASSERT(channel); + LTTNG_ASSERT(channel->metadata_cache); memset(&request, 0, sizeof(request)); @@ -3333,7 +3382,7 @@ int lttng_ustconsumer_request_metadata(struct lttng_consumer_local_data *ctx, offset = msg.u.push_metadata.target_offset; version = msg.u.push_metadata.version; - assert(key == channel->key); + LTTNG_ASSERT(key == channel->key); if (len == 0) { DBG("No new metadata to receive for key %" PRIu64, key); } @@ -3377,8 +3426,13 @@ end: int lttng_ustconsumer_get_stream_id(struct lttng_consumer_stream *stream, uint64_t *stream_id) { - assert(stream); - assert(stream_id); + LTTNG_ASSERT(stream); + LTTNG_ASSERT(stream_id); return lttng_ust_ctl_get_stream_id(stream->ustream, stream_id); } + +void lttng_ustconsumer_sigbus_handle(void *addr) +{ + lttng_ust_ctl_sigbus_handle(addr); +}