Implement filter bytecode support in lttng-session, and parse filter string
[lttng-tools.git] / src / bin / lttng-sessiond / main.c
index 7327c3cb2262ddf4337b46c08f2d02160f1136e7..e2ca01eb54fe6541323f971095c1d329f28cf747 100644 (file)
@@ -33,7 +33,6 @@
 #include <sys/stat.h>
 #include <sys/types.h>
 #include <sys/wait.h>
-#include <urcu/futex.h>
 #include <urcu/uatomic.h>
 #include <unistd.h>
 #include <config.h>
 #include <common/compat/socket.h>
 #include <common/defaults.h>
 #include <common/kernel-consumer/kernel-consumer.h>
-#include <common/ust-consumer/ust-consumer.h>
+#include <common/futex.h>
+#include <common/relayd/relayd.h>
 
 #include "lttng-sessiond.h"
 #include "channel.h"
+#include "consumer.h"
 #include "context.h"
 #include "event.h"
-#include "futex.h"
 #include "kernel.h"
+#include "kernel-consumer.h"
 #include "modprobe.h"
 #include "shm.h"
 #include "ust-ctl.h"
+#include "ust-consumer.h"
 #include "utils.h"
 #include "fd-limit.h"
+#include "filter.h"
 
 #define CONSUMERD_FILE "lttng-consumerd"
 
-struct consumer_data {
-       enum lttng_consumer_type type;
-
-       pthread_t thread;       /* Worker thread interacting with the consumer */
-       sem_t sem;
-
-       /* Mutex to control consumerd pid assignation */
-       pthread_mutex_t pid_mutex;
-       pid_t pid;
-
-       int err_sock;
-       int cmd_sock;
-
-       /* consumer error and command Unix socket path */
-       char err_unix_sock_path[PATH_MAX];
-       char cmd_unix_sock_path[PATH_MAX];
-};
-
 /* Const values */
 const char default_home_dir[] = DEFAULT_HOME_DIR;
 const char default_tracing_group[] = DEFAULT_TRACING_GROUP;
@@ -150,7 +135,6 @@ static pthread_t client_thread;
 static pthread_t kernel_thread;
 static pthread_t dispatch_thread;
 
-
 /*
  * UST registration command queue. This queue is tied with a futex and uses a N
  * wakers / 1 waiter implemented and detailed in futex.c/.h
@@ -214,6 +198,16 @@ enum consumerd_state {
 static enum consumerd_state ust_consumerd_state;
 static enum consumerd_state kernel_consumerd_state;
 
+/*
+ * Used to keep a unique index for each relayd socket created where this value
+ * is associated with streams on the consumer so it can match the right relayd
+ * to send to.
+ *
+ * This value should be incremented atomically for safety purposes and future
+ * possible concurrent access.
+ */
+static unsigned int relayd_net_seq_idx;
+
 static
 void setup_consumerd_path(void)
 {
@@ -425,7 +419,7 @@ static void stop_threads(void)
  */
 static void cleanup(void)
 {
-       int ret, i;
+       int ret;
        char *cmd;
        struct ltt_session *sess, *stmp;
 
@@ -475,34 +469,9 @@ static void cleanup(void)
                DBG("Unloading kernel modules");
                modprobe_remove_lttng_all();
        }
-
-       /*
-        * Closing all pipes used for communication between threads.
-        */
-       for (i = 0; i < 2; i++) {
-               if (kernel_poll_pipe[i] >= 0) {
-                       ret = close(kernel_poll_pipe[i]);
-                       if (ret) {
-                               PERROR("close");
-                       }
-               }
-       }
-       for (i = 0; i < 2; i++) {
-               if (thread_quit_pipe[i] >= 0) {
-                       ret = close(thread_quit_pipe[i]);
-                       if (ret) {
-                               PERROR("close");
-                       }
-               }
-       }
-       for (i = 0; i < 2; i++) {
-               if (apps_cmd_pipe[i] >= 0) {
-                       ret = close(apps_cmd_pipe[i]);
-                       if (ret) {
-                               PERROR("close");
-                       }
-               }
-       }
+       utils_close_pipe(kernel_poll_pipe);
+       utils_close_pipe(thread_quit_pipe);
+       utils_close_pipe(apps_cmd_pipe);
 
        /* <fun> */
        DBG("%c[%d;%dm*** assert failed :-) *** ==> %c[%dm%c[%d;%dm"
@@ -544,139 +513,6 @@ static void clean_command_ctx(struct command_ctx **cmd_ctx)
        }
 }
 
-/*
- * Send all stream fds of kernel channel to the consumer.
- */
-static int send_kconsumer_channel_streams(struct consumer_data *consumer_data,
-               int sock, struct ltt_kernel_channel *channel,
-               uid_t uid, gid_t gid)
-{
-       int ret;
-       struct ltt_kernel_stream *stream;
-       struct lttcomm_consumer_msg lkm;
-
-       DBG("Sending streams of channel %s to kernel consumer",
-                       channel->channel->name);
-
-       /* Send channel */
-       lkm.cmd_type = LTTNG_CONSUMER_ADD_CHANNEL;
-       lkm.u.channel.channel_key = channel->fd;
-       lkm.u.channel.max_sb_size = channel->channel->attr.subbuf_size;
-       lkm.u.channel.mmap_len = 0;     /* for kernel */
-       DBG("Sending channel %d to consumer", lkm.u.channel.channel_key);
-       ret = lttcomm_send_unix_sock(sock, &lkm, sizeof(lkm));
-       if (ret < 0) {
-               PERROR("send consumer channel");
-               goto error;
-       }
-
-       /* Send streams */
-       cds_list_for_each_entry(stream, &channel->stream_list.head, list) {
-               if (!stream->fd) {
-                       continue;
-               }
-               lkm.cmd_type = LTTNG_CONSUMER_ADD_STREAM;
-               lkm.u.stream.channel_key = channel->fd;
-               lkm.u.stream.stream_key = stream->fd;
-               lkm.u.stream.state = stream->state;
-               lkm.u.stream.output = channel->channel->attr.output;
-               lkm.u.stream.mmap_len = 0;      /* for kernel */
-               lkm.u.stream.uid = uid;
-               lkm.u.stream.gid = gid;
-               strncpy(lkm.u.stream.path_name, stream->pathname, PATH_MAX - 1);
-               lkm.u.stream.path_name[PATH_MAX - 1] = '\0';
-               DBG("Sending stream %d to consumer", lkm.u.stream.stream_key);
-               ret = lttcomm_send_unix_sock(sock, &lkm, sizeof(lkm));
-               if (ret < 0) {
-                       PERROR("send consumer stream");
-                       goto error;
-               }
-               ret = lttcomm_send_fds_unix_sock(sock, &stream->fd, 1);
-               if (ret < 0) {
-                       PERROR("send consumer stream ancillary data");
-                       goto error;
-               }
-       }
-
-       DBG("consumer channel streams sent");
-
-       return 0;
-
-error:
-       return ret;
-}
-
-/*
- * Send all stream fds of the kernel session to the consumer.
- */
-static int send_kconsumer_session_streams(struct consumer_data *consumer_data,
-               struct ltt_kernel_session *session)
-{
-       int ret;
-       struct ltt_kernel_channel *chan;
-       struct lttcomm_consumer_msg lkm;
-       int sock = session->consumer_fd;
-
-       DBG("Sending metadata stream fd");
-
-       /* Extra protection. It's NOT supposed to be set to -1 at this point */
-       if (session->consumer_fd < 0) {
-               session->consumer_fd = consumer_data->cmd_sock;
-       }
-
-       if (session->metadata_stream_fd >= 0) {
-               /* Send metadata channel fd */
-               lkm.cmd_type = LTTNG_CONSUMER_ADD_CHANNEL;
-               lkm.u.channel.channel_key = session->metadata->fd;
-               lkm.u.channel.max_sb_size = session->metadata->conf->attr.subbuf_size;
-               lkm.u.channel.mmap_len = 0;     /* for kernel */
-               DBG("Sending metadata channel %d to consumer", lkm.u.channel.channel_key);
-               ret = lttcomm_send_unix_sock(sock, &lkm, sizeof(lkm));
-               if (ret < 0) {
-                       PERROR("send consumer channel");
-                       goto error;
-               }
-
-               /* Send metadata stream fd */
-               lkm.cmd_type = LTTNG_CONSUMER_ADD_STREAM;
-               lkm.u.stream.channel_key = session->metadata->fd;
-               lkm.u.stream.stream_key = session->metadata_stream_fd;
-               lkm.u.stream.state = LTTNG_CONSUMER_ACTIVE_STREAM;
-               lkm.u.stream.output = DEFAULT_KERNEL_CHANNEL_OUTPUT;
-               lkm.u.stream.mmap_len = 0;      /* for kernel */
-               lkm.u.stream.uid = session->uid;
-               lkm.u.stream.gid = session->gid;
-               strncpy(lkm.u.stream.path_name, session->metadata->pathname, PATH_MAX - 1);
-               lkm.u.stream.path_name[PATH_MAX - 1] = '\0';
-               DBG("Sending metadata stream %d to consumer", lkm.u.stream.stream_key);
-               ret = lttcomm_send_unix_sock(sock, &lkm, sizeof(lkm));
-               if (ret < 0) {
-                       PERROR("send consumer stream");
-                       goto error;
-               }
-               ret = lttcomm_send_fds_unix_sock(sock, &session->metadata_stream_fd, 1);
-               if (ret < 0) {
-                       PERROR("send consumer stream");
-                       goto error;
-               }
-       }
-
-       cds_list_for_each_entry(chan, &session->channel_list.head, list) {
-               ret = send_kconsumer_channel_streams(consumer_data, sock, chan,
-                               session->uid, session->gid);
-               if (ret < 0) {
-                       goto error;
-               }
-       }
-
-       DBG("consumer fds (metadata and channel streams) sent");
-
-       return 0;
-
-error:
-       return ret;
-}
-
 /*
  * Notify UST applications using the shm mmap futex.
  */
@@ -817,10 +653,11 @@ static int update_kernel_stream(struct consumer_data *consumer_data, int fd)
                                 * that tracing is started so it is safe to send our updated
                                 * stream fds.
                                 */
-                               if (session->kernel_session->consumer_fds_sent == 1) {
-                                       ret = send_kconsumer_channel_streams(consumer_data,
+                               if (session->kernel_session->consumer_fds_sent == 1 &&
+                                               session->kernel_session->consumer != NULL) {
+                                       ret = kernel_consumer_send_channel_stream(
                                                        session->kernel_session->consumer_fd, channel,
-                                                       session->uid, session->gid);
+                                                       session->kernel_session);
                                        if (ret < 0) {
                                                goto error;
                                        }
@@ -1922,7 +1759,7 @@ static int init_kernel_tracing(struct ltt_kernel_session *session)
 {
        int ret = 0;
 
-       if (session->consumer_fds_sent == 0) {
+       if (session->consumer_fds_sent == 0 && session->consumer != NULL) {
                /*
                 * Assign default kernel consumer socket if no consumer assigned to the
                 * kernel session. At this point, it's NOT supposed to be -1 but this is
@@ -1932,13 +1769,11 @@ static int init_kernel_tracing(struct ltt_kernel_session *session)
                        session->consumer_fd = kconsumer_data.cmd_sock;
                }
 
-               ret = send_kconsumer_session_streams(&kconsumer_data, session);
+               ret = kernel_consumer_send_session(session->consumer_fd, session);
                if (ret < 0) {
                        ret = LTTCOMM_KERN_CONSUMER_FAIL;
                        goto error;
                }
-
-               session->consumer_fds_sent = 1;
        }
 
 error:
@@ -1946,178 +1781,467 @@ error:
 }
 
 /*
- * Create an UST session and add it to the session ust list.
+ * Create a socket to the relayd using the URI.
+ *
+ * On success, the relayd_sock pointer is set to the created socket.
+ * Else, it is untouched and an lttcomm error code is returned.
  */
-static int create_ust_session(struct ltt_session *session,
-               struct lttng_domain *domain)
+static int create_connect_relayd(struct consumer_output *output,
+               const char *session_name, struct lttng_uri *uri,
+               struct lttcomm_sock **relayd_sock)
 {
-       struct ltt_ust_session *lus = NULL;
        int ret;
+       struct lttcomm_sock *sock;
 
-       switch (domain->type) {
-       case LTTNG_DOMAIN_UST:
-               break;
-       default:
-               ret = LTTCOMM_UNKNOWN_DOMAIN;
+       /* Create socket object from URI */
+       sock = lttcomm_alloc_sock_from_uri(uri);
+       if (sock == NULL) {
+               ret = LTTCOMM_FATAL;
                goto error;
        }
 
-       DBG("Creating UST session");
-
-       lus = trace_ust_create_session(session->path, session->id, domain);
-       if (lus == NULL) {
-               ret = LTTCOMM_UST_SESS_FAIL;
+       ret = lttcomm_create_sock(sock);
+       if (ret < 0) {
+               ret = LTTCOMM_FATAL;
                goto error;
        }
 
-       ret = run_as_mkdir_recursive(lus->pathname, S_IRWXU | S_IRWXG,
-                       session->uid, session->gid);
+       /* Connect to relayd so we can proceed with a session creation. */
+       ret = relayd_connect(sock);
        if (ret < 0) {
-               if (ret != -EEXIST) {
-                       ERR("Trace directory creation error");
-                       ret = LTTCOMM_UST_SESS_FAIL;
-                       goto error;
-               }
+               ERR("Unable to reach lttng-relayd");
+               ret = LTTCOMM_RELAYD_SESSION_FAIL;
+               goto free_sock;
        }
 
-       /* The domain type dictate different actions on session creation */
-       switch (domain->type) {
-       case LTTNG_DOMAIN_UST:
-               /* No ustctl for the global UST domain */
-               break;
-       default:
-               ERR("Unknown UST domain on create session %d", domain->type);
-               goto error;
+       /* Create socket for control stream. */
+       if (uri->stype == LTTNG_STREAM_CONTROL) {
+               DBG3("Creating relayd stream socket from URI");
+
+               /* Check relayd version */
+               ret = relayd_version_check(sock, LTTNG_UST_COMM_MAJOR, 0);
+               if (ret < 0) {
+                       ret = LTTCOMM_RELAYD_VERSION_FAIL;
+                       goto close_sock;
+               }
+       } else if (uri->stype == LTTNG_STREAM_DATA) {
+               DBG3("Creating relayd data socket from URI");
+       } else {
+               /* Command is not valid */
+               ERR("Relayd invalid stream type: %d", uri->stype);
+               ret = LTTCOMM_INVALID;
+               goto close_sock;
        }
-       lus->uid = session->uid;
-       lus->gid = session->gid;
-       session->ust_session = lus;
+
+       *relayd_sock = sock;
 
        return LTTCOMM_OK;
 
+close_sock:
+       if (sock) {
+               (void) relayd_close(sock);
+       }
+free_sock:
+       if (sock) {
+               lttcomm_destroy_sock(sock);
+       }
 error:
-       free(lus);
        return ret;
 }
 
 /*
- * Create a kernel tracer session then create the default channel.
+ * Connect to the relayd using URI and send the socket to the right consumer.
  */
-static int create_kernel_session(struct ltt_session *session)
+static int send_socket_relayd_consumer(int domain, struct ltt_session *session,
+               struct lttng_uri *relayd_uri, struct consumer_output *consumer,
+               int consumer_fd)
 {
        int ret;
+       struct lttcomm_sock *sock = NULL;
 
-       DBG("Creating kernel session");
+       /* Set the network sequence index if not set. */
+       if (consumer->net_seq_index == -1) {
+               /*
+                * Increment net_seq_idx because we are about to transfer the
+                * new relayd socket to the consumer.
+                */
+               uatomic_inc(&relayd_net_seq_idx);
+               /* Assign unique key so the consumer can match streams */
+               consumer->net_seq_index = uatomic_read(&relayd_net_seq_idx);
+       }
 
-       ret = kernel_create_session(session, kernel_tracer_fd);
-       if (ret < 0) {
-               ret = LTTCOMM_KERN_SESS_FAIL;
-               goto error;
+       /* Connect to relayd and make version check if uri is the control. */
+       ret = create_connect_relayd(consumer, session->name, relayd_uri, &sock);
+       if (ret != LTTCOMM_OK) {
+               goto close_sock;
        }
 
-       /* Set kernel consumer socket fd */
-       if (kconsumer_data.cmd_sock >= 0) {
-               session->kernel_session->consumer_fd = kconsumer_data.cmd_sock;
+       /* If the control socket is connected, network session is ready */
+       if (relayd_uri->stype == LTTNG_STREAM_CONTROL) {
+               session->net_handle = 1;
        }
 
-       ret = run_as_mkdir_recursive(session->kernel_session->trace_path,
-                       S_IRWXU | S_IRWXG, session->uid, session->gid);
-       if (ret < 0) {
-               if (ret != -EEXIST) {
-                       ERR("Trace directory creation error");
-                       goto error;
+       switch (domain) {
+       case LTTNG_DOMAIN_KERNEL:
+               /* Send relayd socket to consumer. */
+               ret = kernel_consumer_send_relayd_socket(consumer_fd, sock,
+                               consumer, relayd_uri->stype);
+               if (ret < 0) {
+                       ret = LTTCOMM_ENABLE_CONSUMER_FAIL;
+                       goto close_sock;
+               }
+               break;
+       case LTTNG_DOMAIN_UST:
+               /* Send relayd socket to consumer. */
+               ret = ust_consumer_send_relayd_socket(consumer_fd, sock,
+                               consumer, relayd_uri->stype);
+               if (ret < 0) {
+                       ret = LTTCOMM_ENABLE_CONSUMER_FAIL;
+                       goto close_sock;
                }
+               break;
+       }
+
+       ret = LTTCOMM_OK;
+
+       /*
+        * Close socket which was dup on the consumer side. The session daemon does
+        * NOT keep track of the relayd socket(s) once transfer to the consumer.
+        */
+
+close_sock:
+       if (sock) {
+               (void) relayd_close(sock);
+               lttcomm_destroy_sock(sock);
        }
-       session->kernel_session->uid = session->uid;
-       session->kernel_session->gid = session->gid;
 
-error:
        return ret;
 }
 
 /*
- * Check if the UID or GID match the session. Root user has access to all
- * sessions.
+ * Send both relayd sockets to a specific consumer and domain.  This is a
+ * helper function to facilitate sending the information to the consumer for a
+ * session.
  */
-static int session_access_ok(struct ltt_session *session, uid_t uid, gid_t gid)
+static int send_sockets_relayd_consumer(int domain,
+               struct ltt_session *session, struct consumer_output *consumer, int fd)
 {
-       if (uid != session->uid && gid != session->gid && uid != 0) {
-               return 0;
-       } else {
-               return 1;
-       }
-}
+       int ret;
 
-static unsigned int lttng_sessions_count(uid_t uid, gid_t gid)
-{
-       unsigned int i = 0;
-       struct ltt_session *session;
+       /* Sending control relayd socket. */
+       ret = send_socket_relayd_consumer(domain, session,
+                       &consumer->dst.net.control, consumer, fd);
+       if (ret != LTTCOMM_OK) {
+               goto error;
+       }
 
-       DBG("Counting number of available session for UID %d GID %d",
-               uid, gid);
-       cds_list_for_each_entry(session, &session_list_ptr->head, list) {
-               /*
-                * Only list the sessions the user can control.
-                */
-               if (!session_access_ok(session, uid, gid)) {
-                       continue;
-               }
-               i++;
+       /* Sending data relayd socket. */
+       ret = send_socket_relayd_consumer(domain, session,
+                       &consumer->dst.net.data, consumer, fd);
+       if (ret != LTTCOMM_OK) {
+               goto error;
        }
-       return i;
+
+error:
+       return ret;
 }
 
 /*
- * Using the session list, filled a lttng_session array to send back to the
- * client for session listing.
- *
- * The session list lock MUST be acquired before calling this function. Use
- * session_lock_list() and session_unlock_list().
+ * Setup relayd connections for a tracing session. First creates the socket to
+ * the relayd and send them to the right domain consumer. Consumer type MUST be
+ * network.
  */
-static void list_lttng_sessions(struct lttng_session *sessions, uid_t uid,
-               gid_t gid)
+static int setup_relayd(struct ltt_session *session)
 {
-       unsigned int i = 0;
-       struct ltt_session *session;
+       int ret = LTTCOMM_OK;
+       struct ltt_ust_session *usess;
+       struct ltt_kernel_session *ksess;
 
-       DBG("Getting all available session for UID %d GID %d",
-               uid, gid);
-       /*
-        * Iterate over session list and append data after the control struct in
-        * the buffer.
-        */
-       cds_list_for_each_entry(session, &session_list_ptr->head, list) {
-               /*
-                * Only list the sessions the user can control.
-                */
-               if (!session_access_ok(session, uid, gid)) {
-                       continue;
+       assert(session);
+
+       usess = session->ust_session;
+       ksess = session->kernel_session;
+
+       DBG2("Setting relayd for session %s", session->name);
+
+       if (usess && usess->consumer->sock == -1 &&
+                       usess->consumer->type == CONSUMER_DST_NET &&
+                       usess->consumer->enabled) {
+               /* Setup relayd for 64 bits consumer */
+               if (ust_consumerd64_fd >= 0) {
+                       send_sockets_relayd_consumer(LTTNG_DOMAIN_UST, session,
+                                       usess->consumer, ust_consumerd64_fd);
+                       if (ret != LTTCOMM_OK) {
+                               goto error;
+                       }
+               }
+
+               /* Setup relayd for 32 bits consumer */
+               if (ust_consumerd32_fd >= 0) {
+                       send_sockets_relayd_consumer(LTTNG_DOMAIN_UST, session,
+                                       usess->consumer, ust_consumerd32_fd);
+                       if (ret != LTTCOMM_OK) {
+                               goto error;
+                       }
+               }
+       } else if (ksess && ksess->consumer->sock == -1 &&
+                       ksess->consumer->type == CONSUMER_DST_NET &&
+                       ksess->consumer->enabled) {
+               send_sockets_relayd_consumer(LTTNG_DOMAIN_KERNEL, session,
+                               ksess->consumer, ksess->consumer_fd);
+               if (ret != LTTCOMM_OK) {
+                       goto error;
                }
-               strncpy(sessions[i].path, session->path, PATH_MAX);
-               sessions[i].path[PATH_MAX - 1] = '\0';
-               strncpy(sessions[i].name, session->name, NAME_MAX);
-               sessions[i].name[NAME_MAX - 1] = '\0';
-               sessions[i].enabled = session->enabled;
-               i++;
        }
+
+error:
+       return ret;
 }
 
 /*
- * Fill lttng_channel array of all channels.
+ * Copy consumer output from the tracing session to the domain session. The
+ * function also applies the right modification on a per domain basis for the
+ * trace files destination directory.
  */
-static void list_lttng_channels(int domain, struct ltt_session *session,
-               struct lttng_channel *channels)
+static int copy_session_consumer(int domain, struct ltt_session *session)
 {
-       int i = 0;
-       struct ltt_kernel_channel *kchan;
-
-       DBG("Listing channels for session %s", session->name);
+       int ret;
+       const char *dir_name;
+       struct consumer_output *consumer;
 
        switch (domain) {
        case LTTNG_DOMAIN_KERNEL:
-               /* Kernel channels */
-               if (session->kernel_session != NULL) {
-                       cds_list_for_each_entry(kchan,
+               DBG3("Copying tracing session consumer output in kernel session");
+               session->kernel_session->consumer =
+                       consumer_copy_output(session->consumer);
+               /* Ease our life a bit for the next part */
+               consumer = session->kernel_session->consumer;
+               dir_name = DEFAULT_KERNEL_TRACE_DIR;
+               break;
+       case LTTNG_DOMAIN_UST:
+               DBG3("Copying tracing session consumer output in UST session");
+               session->ust_session->consumer =
+                       consumer_copy_output(session->consumer);
+               /* Ease our life a bit for the next part */
+               consumer = session->ust_session->consumer;
+               dir_name = DEFAULT_UST_TRACE_DIR;
+               break;
+       default:
+               ret = LTTCOMM_UNKNOWN_DOMAIN;
+               goto error;
+       }
+
+       /* Append correct directory to subdir */
+       strncat(consumer->subdir, dir_name, sizeof(consumer->subdir));
+       DBG3("Copy session consumer subdir %s", consumer->subdir);
+
+       /* Add default trace directory name */
+       if (consumer->type == CONSUMER_DST_LOCAL) {
+               strncat(consumer->dst.trace_path, dir_name,
+                               sizeof(consumer->dst.trace_path));
+       }
+
+       ret = LTTCOMM_OK;
+
+error:
+       return ret;
+}
+
+/*
+ * Create an UST session and add it to the session ust list.
+ */
+static int create_ust_session(struct ltt_session *session,
+               struct lttng_domain *domain)
+{
+       int ret;
+       struct ltt_ust_session *lus = NULL;
+
+       assert(session);
+       assert(session->consumer);
+
+       switch (domain->type) {
+       case LTTNG_DOMAIN_UST:
+               break;
+       default:
+               ERR("Unknown UST domain on create session %d", domain->type);
+               ret = LTTCOMM_UNKNOWN_DOMAIN;
+               goto error;
+       }
+
+       DBG("Creating UST session");
+
+       lus = trace_ust_create_session(session->path, session->id, domain);
+       if (lus == NULL) {
+               ret = LTTCOMM_UST_SESS_FAIL;
+               goto error;
+       }
+
+       if (session->consumer->type == CONSUMER_DST_LOCAL) {
+               ret = run_as_mkdir_recursive(lus->pathname, S_IRWXU | S_IRWXG,
+                               session->uid, session->gid);
+               if (ret < 0) {
+                       if (ret != -EEXIST) {
+                               ERR("Trace directory creation error");
+                               ret = LTTCOMM_UST_SESS_FAIL;
+                               goto error;
+                       }
+               }
+       }
+
+       lus->uid = session->uid;
+       lus->gid = session->gid;
+       session->ust_session = lus;
+
+       /* Copy session output to the newly created UST session */
+       ret = copy_session_consumer(domain->type, session);
+       if (ret != LTTCOMM_OK) {
+               goto error;
+       }
+
+       return LTTCOMM_OK;
+
+error:
+       free(lus);
+       session->ust_session = NULL;
+       return ret;
+}
+
+/*
+ * Create a kernel tracer session then create the default channel.
+ */
+static int create_kernel_session(struct ltt_session *session)
+{
+       int ret;
+
+       DBG("Creating kernel session");
+
+       ret = kernel_create_session(session, kernel_tracer_fd);
+       if (ret < 0) {
+               ret = LTTCOMM_KERN_SESS_FAIL;
+               goto error;
+       }
+
+       /* Set kernel consumer socket fd */
+       if (kconsumer_data.cmd_sock >= 0) {
+               session->kernel_session->consumer_fd = kconsumer_data.cmd_sock;
+       }
+
+       /* Copy session output to the newly created Kernel session */
+       ret = copy_session_consumer(LTTNG_DOMAIN_KERNEL, session);
+       if (ret != LTTCOMM_OK) {
+               goto error;
+       }
+
+       /* Create directory(ies) on local filesystem. */
+       if (session->consumer->type == CONSUMER_DST_LOCAL) {
+               ret = run_as_mkdir_recursive(
+                               session->kernel_session->consumer->dst.trace_path,
+                               S_IRWXU | S_IRWXG, session->uid, session->gid);
+               if (ret < 0) {
+                       if (ret != -EEXIST) {
+                               ERR("Trace directory creation error");
+                               goto error;
+                       }
+               }
+       }
+
+       session->kernel_session->uid = session->uid;
+       session->kernel_session->gid = session->gid;
+
+       return LTTCOMM_OK;
+
+error:
+       trace_kernel_destroy_session(session->kernel_session);
+       session->kernel_session = NULL;
+       return ret;
+}
+
+/*
+ * Check if the UID or GID match the session. Root user has access to all
+ * sessions.
+ */
+static int session_access_ok(struct ltt_session *session, uid_t uid, gid_t gid)
+{
+       if (uid != session->uid && gid != session->gid && uid != 0) {
+               return 0;
+       } else {
+               return 1;
+       }
+}
+
+/*
+ * Count number of session permitted by uid/gid.
+ */
+static unsigned int lttng_sessions_count(uid_t uid, gid_t gid)
+{
+       unsigned int i = 0;
+       struct ltt_session *session;
+
+       DBG("Counting number of available session for UID %d GID %d",
+               uid, gid);
+       cds_list_for_each_entry(session, &session_list_ptr->head, list) {
+               /*
+                * Only list the sessions the user can control.
+                */
+               if (!session_access_ok(session, uid, gid)) {
+                       continue;
+               }
+               i++;
+       }
+       return i;
+}
+
+/*
+ * Using the session list, filled a lttng_session array to send back to the
+ * client for session listing.
+ *
+ * The session list lock MUST be acquired before calling this function. Use
+ * session_lock_list() and session_unlock_list().
+ */
+static void list_lttng_sessions(struct lttng_session *sessions, uid_t uid,
+               gid_t gid)
+{
+       unsigned int i = 0;
+       struct ltt_session *session;
+
+       DBG("Getting all available session for UID %d GID %d",
+               uid, gid);
+       /*
+        * Iterate over session list and append data after the control struct in
+        * the buffer.
+        */
+       cds_list_for_each_entry(session, &session_list_ptr->head, list) {
+               /*
+                * Only list the sessions the user can control.
+                */
+               if (!session_access_ok(session, uid, gid)) {
+                       continue;
+               }
+               strncpy(sessions[i].path, session->path, PATH_MAX);
+               sessions[i].path[PATH_MAX - 1] = '\0';
+               strncpy(sessions[i].name, session->name, NAME_MAX);
+               sessions[i].name[NAME_MAX - 1] = '\0';
+               sessions[i].enabled = session->enabled;
+               i++;
+       }
+}
+
+/*
+ * Fill lttng_channel array of all channels.
+ */
+static void list_lttng_channels(int domain, struct ltt_session *session,
+               struct lttng_channel *channels)
+{
+       int i = 0;
+       struct ltt_kernel_channel *kchan;
+
+       DBG("Listing channels for session %s", session->name);
+
+       switch (domain) {
+       case LTTNG_DOMAIN_KERNEL:
+               /* Kernel channels */
+               if (session->kernel_session != NULL) {
+                       cds_list_for_each_entry(kchan,
                                        &session->kernel_session->channel_list.head, list) {
                                /* Copy lttng_channel struct to array */
                                memcpy(&channels[i], kchan->channel, sizeof(struct lttng_channel));
@@ -2608,6 +2732,46 @@ error:
        return ret;
 }
 
+/*
+ * Command LTTNG_SET_FILTER processed by the client thread.
+ */
+static int cmd_set_filter(struct ltt_session *session, int domain,
+               char *channel_name, char *event_name,
+               struct lttng_filter_bytecode *bytecode)
+{
+       int ret;
+
+       switch (domain) {
+       case LTTNG_DOMAIN_KERNEL:
+               ret = LTTCOMM_FATAL;
+               break;
+       case LTTNG_DOMAIN_UST:
+       {
+               struct ltt_ust_session *usess = session->ust_session;
+
+               ret = filter_ust_set(usess, domain, bytecode, event_name, channel_name);
+               if (ret != LTTCOMM_OK) {
+                       goto error;
+               }
+               break;
+       }
+#if 0
+       case LTTNG_DOMAIN_UST_EXEC_NAME:
+       case LTTNG_DOMAIN_UST_PID:
+       case LTTNG_DOMAIN_UST_PID_FOLLOW_CHILDREN:
+#endif
+       default:
+               ret = LTTCOMM_UND;
+               goto error;
+       }
+
+       ret = LTTCOMM_OK;
+
+error:
+       return ret;
+
+}
+
 /*
  * Command LTTNG_ENABLE_EVENT processed by the client thread.
  */
@@ -2891,6 +3055,36 @@ error:
        return -ret;
 }
 
+/*
+ * Command LTTNG_LIST_TRACEPOINT_FIELDS processed by the client thread.
+ */
+static ssize_t cmd_list_tracepoint_fields(int domain,
+                       struct lttng_event_field **fields)
+{
+       int ret;
+       ssize_t nb_fields = 0;
+
+       switch (domain) {
+       case LTTNG_DOMAIN_UST:
+               nb_fields = ust_app_list_event_fields(fields);
+               if (nb_fields < 0) {
+                       ret = LTTCOMM_UST_LIST_FAIL;
+                       goto error;
+               }
+               break;
+       case LTTNG_DOMAIN_KERNEL:
+       default:        /* fall-through */
+               ret = LTTCOMM_UND;
+               goto error;
+       }
+
+       return nb_fields;
+
+error:
+       /* Return negative value to differentiate return code */
+       return -ret;
+}
+
 /*
  * Command LTTNG_START_TRACE processed by the client thread.
  */
@@ -2899,8 +3093,9 @@ static int cmd_start_trace(struct ltt_session *session)
        int ret;
        struct ltt_kernel_session *ksession;
        struct ltt_ust_session *usess;
+       struct ltt_kernel_channel *kchan;
 
-       /* Short cut */
+       /* Ease our life a bit ;) */
        ksession = session->kernel_session;
        usess = session->ust_session;
 
@@ -2912,13 +3107,18 @@ static int cmd_start_trace(struct ltt_session *session)
 
        session->enabled = 1;
 
+       ret = setup_relayd(session);
+       if (ret != LTTCOMM_OK) {
+               ERR("Error setting up relayd for session %s", session->name);
+               goto error;
+       }
+
        /* Kernel tracing */
        if (ksession != NULL) {
-               struct ltt_kernel_channel *kchan;
-
                /* Open kernel metadata */
                if (ksession->metadata == NULL) {
-                       ret = kernel_open_metadata(ksession, ksession->trace_path);
+                       ret = kernel_open_metadata(ksession,
+                                       ksession->consumer->dst.trace_path);
                        if (ret < 0) {
                                ret = LTTCOMM_KERN_META_FAIL;
                                goto error;
@@ -3008,12 +3208,15 @@ static int cmd_stop_trace(struct ltt_session *session)
        if (ksession != NULL) {
                DBG("Stop kernel tracing");
 
-               /* Flush all buffers before stopping */
-               ret = kernel_metadata_flush_buffer(ksession->metadata_stream_fd);
-               if (ret < 0) {
-                       ERR("Kernel metadata flush failed");
+               /* Flush metadata if exist */
+               if (ksession->metadata_stream_fd >= 0) {
+                       ret = kernel_metadata_flush_buffer(ksession->metadata_stream_fd);
+                       if (ret < 0) {
+                               ERR("Kernel metadata flush failed");
+                       }
                }
 
+               /* Flush all buffers before stopping */
                cds_list_for_each_entry(kchan, &ksession->channel_list.head, list) {
                        ret = kernel_flush_buffer(kchan);
                        if (ret < 0) {
@@ -3047,19 +3250,108 @@ error:
 }
 
 /*
- * Command LTTNG_CREATE_SESSION processed by the client thread.
+ * Command LTTNG_CREATE_SESSION_URI processed by the client thread.
  */
-static int cmd_create_session(char *name, char *path, lttng_sock_cred *creds)
+static int cmd_create_session_uri(char *name, struct lttng_uri *ctrl_uri,
+               struct lttng_uri *data_uri, unsigned int enable_consumer,
+               lttng_sock_cred *creds)
 {
        int ret;
+       char *path = NULL;
+       struct ltt_session *session;
+       struct consumer_output *consumer;
+
+       /* Verify if the session already exist */
+       session = session_find_by_name(name);
+       if (session != NULL) {
+               ret = LTTCOMM_EXIST_SESS;
+               goto error;
+       }
+
+       /* TODO: validate URIs */
+
+       /* Create default consumer output */
+       consumer = consumer_create_output(CONSUMER_DST_LOCAL);
+       if (consumer == NULL) {
+               ret = LTTCOMM_FATAL;
+               goto error;
+       }
+       strncpy(consumer->subdir, ctrl_uri->subdir, sizeof(consumer->subdir));
+       DBG2("Consumer subdir set to %s", consumer->subdir);
+
+       switch (ctrl_uri->dtype) {
+       case LTTNG_DST_IPV4:
+       case LTTNG_DST_IPV6:
+               /* Set control URI into consumer output object */
+               ret = consumer_set_network_uri(consumer, ctrl_uri);
+               if (ret < 0) {
+                       ret = LTTCOMM_FATAL;
+                       goto error;
+               }
+
+               /* Set data URI into consumer output object */
+               ret = consumer_set_network_uri(consumer, data_uri);
+               if (ret < 0) {
+                       ret = LTTCOMM_FATAL;
+                       goto error;
+               }
+
+               /* Empty path since the session is network */
+               path = "";
+               break;
+       case LTTNG_DST_PATH:
+               /* Very volatile pointer. Only used for the create session. */
+               path = ctrl_uri->dst.path;
+               strncpy(consumer->dst.trace_path, path,
+                               sizeof(consumer->dst.trace_path));
+               break;
+       }
+
+       /* Set if the consumer is enabled or not */
+       consumer->enabled = enable_consumer;
 
        ret = session_create(name, path, LTTNG_SOCK_GET_UID_CRED(creds),
                        LTTNG_SOCK_GET_GID_CRED(creds));
        if (ret != LTTCOMM_OK) {
-               goto error;
+               goto consumer_error;
        }
 
-       ret = LTTCOMM_OK;
+       /* Get the newly created session pointer back */
+       session = session_find_by_name(name);
+       assert(session);
+
+       /* Assign consumer to session */
+       session->consumer = consumer;
+
+       return LTTCOMM_OK;
+
+consumer_error:
+       consumer_destroy_output(consumer);
+error:
+       return ret;
+}
+
+/*
+ * Command LTTNG_CREATE_SESSION processed by the client thread.
+ */
+static int cmd_create_session(char *name, char *path, lttng_sock_cred *creds)
+{
+       int ret;
+       struct lttng_uri uri;
+
+       /* Zeroed temporary URI */
+       memset(&uri, 0, sizeof(uri));
+
+       uri.dtype = LTTNG_DST_PATH;
+       uri.utype = LTTNG_URI_DST;
+       strncpy(uri.dst.path, path, sizeof(uri.dst.path));
+
+       /* TODO: Strip date-time from path and put it in uri's subdir */
+
+       ret = cmd_create_session_uri(name, &uri, NULL, 1, creds);
+       if (ret != LTTCOMM_OK) {
+               goto error;
+       }
 
 error:
        return ret;
@@ -3200,94 +3492,472 @@ static ssize_t cmd_list_domains(struct ltt_session *session,
                index++;
        }
 
-       if (session->ust_session != NULL) {
-               (*domains)[index].type = LTTNG_DOMAIN_UST;
-               index++;
+       if (session->ust_session != NULL) {
+               (*domains)[index].type = LTTNG_DOMAIN_UST;
+               index++;
+       }
+
+       return nb_dom;
+
+error:
+       return ret;
+}
+
+/*
+ * Command LTTNG_LIST_CHANNELS processed by the client thread.
+ */
+static ssize_t cmd_list_channels(int domain, struct ltt_session *session,
+               struct lttng_channel **channels)
+{
+       int ret;
+       ssize_t nb_chan = 0;
+
+       switch (domain) {
+       case LTTNG_DOMAIN_KERNEL:
+               if (session->kernel_session != NULL) {
+                       nb_chan = session->kernel_session->channel_count;
+               }
+               DBG3("Number of kernel channels %zd", nb_chan);
+               break;
+       case LTTNG_DOMAIN_UST:
+               if (session->ust_session != NULL) {
+                       nb_chan = lttng_ht_get_count(
+                                       session->ust_session->domain_global.channels);
+               }
+               DBG3("Number of UST global channels %zd", nb_chan);
+               break;
+       default:
+               *channels = NULL;
+               ret = -LTTCOMM_UND;
+               goto error;
+       }
+
+       if (nb_chan > 0) {
+               *channels = zmalloc(nb_chan * sizeof(struct lttng_channel));
+               if (*channels == NULL) {
+                       ret = -LTTCOMM_FATAL;
+                       goto error;
+               }
+
+               list_lttng_channels(domain, session, *channels);
+       } else {
+               *channels = NULL;
+       }
+
+       return nb_chan;
+
+error:
+       return ret;
+}
+
+/*
+ * Command LTTNG_LIST_EVENTS processed by the client thread.
+ */
+static ssize_t cmd_list_events(int domain, struct ltt_session *session,
+               char *channel_name, struct lttng_event **events)
+{
+       int ret = 0;
+       ssize_t nb_event = 0;
+
+       switch (domain) {
+       case LTTNG_DOMAIN_KERNEL:
+               if (session->kernel_session != NULL) {
+                       nb_event = list_lttng_kernel_events(channel_name,
+                                       session->kernel_session, events);
+               }
+               break;
+       case LTTNG_DOMAIN_UST:
+       {
+               if (session->ust_session != NULL) {
+                       nb_event = list_lttng_ust_global_events(channel_name,
+                                       &session->ust_session->domain_global, events);
+               }
+               break;
+       }
+       default:
+               ret = -LTTCOMM_UND;
+               goto error;
+       }
+
+       ret = nb_event;
+
+error:
+       return ret;
+}
+
+/*
+ * Command LTTNG_SET_CONSUMER_URI processed by the client thread.
+ */
+static int cmd_set_consumer_uri(int domain, struct ltt_session *session,
+               struct lttng_uri *uri)
+{
+       int ret;
+       struct ltt_kernel_session *ksess = session->kernel_session;
+       struct ltt_ust_session *usess = session->ust_session;
+       struct consumer_output *consumer;
+
+       /* Can't enable consumer after session started. */
+       if (session->enabled) {
+               ret = LTTCOMM_TRACE_ALREADY_STARTED;
+               goto error;
+       }
+
+       switch (domain) {
+       case LTTNG_DOMAIN_KERNEL:
+               /* Code flow error if we don't have a kernel session here. */
+               assert(ksess);
+
+               /* Create consumer output if none exists */
+               consumer = ksess->tmp_consumer;
+               if (consumer == NULL) {
+                       consumer = consumer_copy_output(ksess->consumer);
+                       if (consumer == NULL) {
+                               ret = LTTCOMM_FATAL;
+                               goto error;
+                       }
+                       /* Reassign new pointer */
+                       ksess->tmp_consumer = consumer;
+               }
+
+               switch (uri->dtype) {
+               case LTTNG_DST_IPV4:
+               case LTTNG_DST_IPV6:
+                       DBG2("Setting network URI for kernel session %s", session->name);
+
+                       /* Set URI into consumer output object */
+                       ret = consumer_set_network_uri(consumer, uri);
+                       if (ret < 0) {
+                               ret = LTTCOMM_FATAL;
+                               goto error;
+                       }
+
+                       /* On a new subdir, reappend the default trace dir. */
+                       if (strlen(uri->subdir) != 0) {
+                               strncat(consumer->subdir, DEFAULT_KERNEL_TRACE_DIR,
+                                               sizeof(consumer->subdir));
+                       }
+
+                       ret = send_socket_relayd_consumer(domain, session, uri, consumer,
+                                       ksess->consumer_fd);
+                       if (ret != LTTCOMM_OK) {
+                               goto error;
+                       }
+                       break;
+               case LTTNG_DST_PATH:
+                       DBG2("Setting trace directory path from URI to %s", uri->dst.path);
+                       memset(consumer->dst.trace_path, 0,
+                                       sizeof(consumer->dst.trace_path));
+                       strncpy(consumer->dst.trace_path, uri->dst.path,
+                                       sizeof(consumer->dst.trace_path));
+                       /* Append default kernel trace dir */
+                       strncat(consumer->dst.trace_path, DEFAULT_KERNEL_TRACE_DIR,
+                                       sizeof(consumer->dst.trace_path));
+                       break;
+               }
+
+               /* All good! */
+               break;
+       case LTTNG_DOMAIN_UST:
+               /* Code flow error if we don't have a kernel session here. */
+               assert(usess);
+
+               /* Create consumer output if none exists */
+               consumer = usess->tmp_consumer;
+               if (consumer == NULL) {
+                       consumer = consumer_copy_output(usess->consumer);
+                       if (consumer == NULL) {
+                               ret = LTTCOMM_FATAL;
+                               goto error;
+                       }
+                       /* Reassign new pointer */
+                       usess->tmp_consumer = consumer;
+               }
+
+               switch (uri->dtype) {
+               case LTTNG_DST_IPV4:
+               case LTTNG_DST_IPV6:
+               {
+                       DBG2("Setting network URI for UST session %s", session->name);
+
+                       /* Set URI into consumer object */
+                       ret = consumer_set_network_uri(consumer, uri);
+                       if (ret < 0) {
+                               ret = LTTCOMM_FATAL;
+                               goto error;
+                       }
+
+                       /* On a new subdir, reappend the default trace dir. */
+                       if (strlen(uri->subdir) != 0) {
+                               strncat(consumer->subdir, DEFAULT_UST_TRACE_DIR,
+                                               sizeof(consumer->subdir));
+                       }
+
+                       if (ust_consumerd64_fd >= 0) {
+                               ret = send_socket_relayd_consumer(domain, session, uri,
+                                               consumer, ust_consumerd64_fd);
+                               if (ret != LTTCOMM_OK) {
+                                       goto error;
+                               }
+                       }
+
+                       if (ust_consumerd32_fd >= 0) {
+                               ret = send_socket_relayd_consumer(domain, session, uri,
+                                               consumer, ust_consumerd32_fd);
+                               if (ret != LTTCOMM_OK) {
+                                       goto error;
+                               }
+                       }
+
+                       break;
+               }
+               case LTTNG_DST_PATH:
+                       DBG2("Setting trace directory path from URI to %s", uri->dst.path);
+                       memset(consumer->dst.trace_path, 0,
+                                       sizeof(consumer->dst.trace_path));
+                       strncpy(consumer->dst.trace_path, uri->dst.path,
+                                       sizeof(consumer->dst.trace_path));
+                       /* Append default UST trace dir */
+                       strncat(consumer->dst.trace_path, DEFAULT_UST_TRACE_DIR,
+                                       sizeof(consumer->dst.trace_path));
+                       break;
+               }
+               break;
        }
 
-       return nb_dom;
+       /* All good! */
+       ret = LTTCOMM_OK;
 
 error:
        return ret;
 }
 
 /*
- * Command LTTNG_LIST_CHANNELS processed by the client thread.
+ * Command LTTNG_DISABLE_CONSUMER processed by the client thread.
  */
-static ssize_t cmd_list_channels(int domain, struct ltt_session *session,
-               struct lttng_channel **channels)
+static int cmd_disable_consumer(int domain, struct ltt_session *session)
 {
        int ret;
-       ssize_t nb_chan = 0;
+       struct ltt_kernel_session *ksess = session->kernel_session;
+       struct ltt_ust_session *usess = session->ust_session;
+       struct consumer_output *consumer;
+
+       if (session->enabled) {
+               /* Can't disable consumer on an already started session */
+               ret = LTTCOMM_TRACE_ALREADY_STARTED;
+               goto error;
+       }
 
        switch (domain) {
        case LTTNG_DOMAIN_KERNEL:
-               if (session->kernel_session != NULL) {
-                       nb_chan = session->kernel_session->channel_count;
-               }
-               DBG3("Number of kernel channels %zd", nb_chan);
+               /* Code flow error if we don't have a kernel session here. */
+               assert(ksess);
+
+               DBG("Disabling kernel consumer");
+               consumer = ksess->consumer;
+
                break;
        case LTTNG_DOMAIN_UST:
-               if (session->ust_session != NULL) {
-                       nb_chan = lttng_ht_get_count(
-                                       session->ust_session->domain_global.channels);
-               }
-               DBG3("Number of UST global channels %zd", nb_chan);
+               /* Code flow error if we don't have a UST session here. */
+               assert(usess);
+
+               DBG("Disabling UST consumer");
+               consumer = usess->consumer;
+
                break;
        default:
-               *channels = NULL;
-               ret = -LTTCOMM_UND;
+               ret = LTTCOMM_UNKNOWN_DOMAIN;
                goto error;
        }
 
-       if (nb_chan > 0) {
-               *channels = zmalloc(nb_chan * sizeof(struct lttng_channel));
-               if (*channels == NULL) {
-                       ret = -LTTCOMM_FATAL;
-                       goto error;
-               }
-
-               list_lttng_channels(domain, session, *channels);
-       } else {
-               *channels = NULL;
-       }
+       assert(consumer);
+       consumer->enabled = 0;
 
-       return nb_chan;
+       /* Success at this point */
+       ret = LTTCOMM_OK;
 
 error:
        return ret;
 }
 
 /*
- * Command LTTNG_LIST_EVENTS processed by the client thread.
+ * Command LTTNG_ENABLE_CONSUMER processed by the client thread.
  */
-static ssize_t cmd_list_events(int domain, struct ltt_session *session,
-               char *channel_name, struct lttng_event **events)
+static int cmd_enable_consumer(int domain, struct ltt_session *session)
 {
-       int ret = 0;
-       ssize_t nb_event = 0;
+       int ret;
+       struct ltt_kernel_session *ksess = session->kernel_session;
+       struct ltt_ust_session *usess = session->ust_session;
+       struct consumer_output *tmp_out;
+
+       /* Can't enable consumer after session started. */
+       if (session->enabled) {
+               ret = LTTCOMM_TRACE_ALREADY_STARTED;
+               goto error;
+       }
 
        switch (domain) {
        case LTTNG_DOMAIN_KERNEL:
-               if (session->kernel_session != NULL) {
-                       nb_event = list_lttng_kernel_events(channel_name,
-                                       session->kernel_session, events);
+               /* Code flow error if we don't have a kernel session here. */
+               assert(ksess);
+
+               /*
+                * Check if we have already sent fds to the consumer. In that case,
+                * the enable-consumer command can't be used because a start trace
+                * had previously occured.
+                */
+               if (ksess->consumer_fds_sent) {
+                       ret = LTTCOMM_ENABLE_CONSUMER_FAIL;
+                       goto error;
+               }
+
+               tmp_out = ksess->tmp_consumer;
+               if (tmp_out == NULL) {
+                       /* No temp. consumer output exists. Using the current one. */
+                       DBG3("No temporary consumer. Using default");
+                       ret = LTTCOMM_OK;
+                       goto error;
+               }
+
+               switch (tmp_out->type) {
+               case CONSUMER_DST_LOCAL:
+                       DBG2("Consumer output is local. Creating directory(ies)");
+
+                       /* Create directory(ies) */
+                       ret = run_as_mkdir_recursive(tmp_out->dst.trace_path,
+                                       S_IRWXU | S_IRWXG, session->uid, session->gid);
+                       if (ret < 0) {
+                               if (ret != -EEXIST) {
+                                       ERR("Trace directory creation error");
+                                       ret = LTTCOMM_FATAL;
+                                       goto error;
+                               }
+                       }
+                       break;
+               case CONSUMER_DST_NET:
+                       DBG2("Consumer output is network. Validating URIs");
+                       /* Validate if we have both control and data path set. */
+                       if (!tmp_out->dst.net.control_isset) {
+                               ret = LTTCOMM_URI_CTRL_MISS;
+                               goto error;
+                       }
+
+                       if (!tmp_out->dst.net.data_isset) {
+                               ret = LTTCOMM_URI_DATA_MISS;
+                               goto error;
+                       }
+
+                       /* Check established network session state */
+                       if (session->net_handle == 0) {
+                               ret = LTTCOMM_ENABLE_CONSUMER_FAIL;
+                               ERR("Session network handle is not set on enable-consumer");
+                               goto error;
+                       }
+
+                       /* Append default kernel trace dir to subdir */
+                       strncat(ksess->consumer->subdir, DEFAULT_KERNEL_TRACE_DIR,
+                                       sizeof(ksess->consumer->subdir));
+
+                       break;
                }
+
+               /*
+                * @session-lock
+                * This is race free for now since the session lock is acquired before
+                * ending up in this function. No other threads can access this kernel
+                * session without this lock hence freeing the consumer output object
+                * is valid.
+                */
+               consumer_destroy_output(ksess->consumer);
+               ksess->consumer = tmp_out;
+               ksess->tmp_consumer = NULL;
+
                break;
        case LTTNG_DOMAIN_UST:
-       {
-               if (session->ust_session != NULL) {
-                       nb_event = list_lttng_ust_global_events(channel_name,
-                                       &session->ust_session->domain_global, events);
+               /* Code flow error if we don't have a UST session here. */
+               assert(usess);
+
+               /*
+                * Check if we have already sent fds to the consumer. In that case,
+                * the enable-consumer command can't be used because a start trace
+                * had previously occured.
+                */
+               if (usess->start_trace) {
+                       ret = LTTCOMM_ENABLE_CONSUMER_FAIL;
+                       goto error;
+               }
+
+               tmp_out = usess->tmp_consumer;
+               if (tmp_out == NULL) {
+                       /* No temp. consumer output exists. Using the current one. */
+                       DBG3("No temporary consumer. Using default");
+                       ret = LTTCOMM_OK;
+                       goto error;
+               }
+
+               switch (tmp_out->type) {
+               case CONSUMER_DST_LOCAL:
+                       DBG2("Consumer output is local. Creating directory(ies)");
+
+                       /* Create directory(ies) */
+                       ret = run_as_mkdir_recursive(tmp_out->dst.trace_path,
+                                       S_IRWXU | S_IRWXG, session->uid, session->gid);
+                       if (ret < 0) {
+                               if (ret != -EEXIST) {
+                                       ERR("Trace directory creation error");
+                                       ret = LTTCOMM_FATAL;
+                                       goto error;
+                               }
+                       }
+                       break;
+               case CONSUMER_DST_NET:
+                       DBG2("Consumer output is network. Validating URIs");
+                       /* Validate if we have both control and data path set. */
+                       if (!tmp_out->dst.net.control_isset) {
+                               ret = LTTCOMM_URI_CTRL_MISS;
+                               goto error;
+                       }
+
+                       if (!tmp_out->dst.net.data_isset) {
+                               ret = LTTCOMM_URI_DATA_MISS;
+                               goto error;
+                       }
+
+                       /* Check established network session state */
+                       if (session->net_handle == 0) {
+                               ret = LTTCOMM_ENABLE_CONSUMER_FAIL;
+                               DBG2("Session network handle is not set on enable-consumer");
+                               goto error;
+                       }
+
+                       if (tmp_out->net_seq_index == -1) {
+                               ret = LTTCOMM_ENABLE_CONSUMER_FAIL;
+                               DBG2("Network index is not set on the consumer");
+                               goto error;
+                       }
+
+                       /* Append default kernel trace dir to subdir */
+                       strncat(usess->consumer->subdir, DEFAULT_UST_TRACE_DIR,
+                                       sizeof(usess->consumer->subdir));
+
+                       break;
                }
+
+               /*
+                * @session-lock
+                * This is race free for now since the session lock is acquired before
+                * ending up in this function. No other threads can access this kernel
+                * session without this lock hence freeing the consumer output object
+                * is valid.
+                */
+               consumer_destroy_output(usess->consumer);
+               usess->consumer = tmp_out;
+               usess->tmp_consumer = NULL;
+
                break;
        }
-       default:
-               ret = -LTTCOMM_UND;
-               goto error;
-       }
 
-       ret = nb_event;
+       /* Success at this point */
+       ret = LTTCOMM_OK;
 
 error:
        return ret;
@@ -3299,8 +3969,11 @@ error:
  * is set and ready for transmission before returning.
  *
  * Return any error encountered or 0 for success.
+ *
+ * "sock" is only used for special-case var. len data.
  */
-static int process_client_msg(struct command_ctx *cmd_ctx)
+static int process_client_msg(struct command_ctx *cmd_ctx, int sock,
+               int *sock_error)
 {
        int ret = LTTCOMM_OK;
        int need_tracing_session = 1;
@@ -3308,8 +3981,11 @@ static int process_client_msg(struct command_ctx *cmd_ctx)
 
        DBG("Processing client command %d", cmd_ctx->lsm->cmd_type);
 
+       *sock_error = 0;
+
        switch (cmd_ctx->lsm->cmd_type) {
        case LTTNG_CREATE_SESSION:
+       case LTTNG_CREATE_SESSION_URI:
        case LTTNG_DESTROY_SESSION:
        case LTTNG_LIST_SESSIONS:
        case LTTNG_LIST_DOMAINS:
@@ -3339,6 +4015,7 @@ static int process_client_msg(struct command_ctx *cmd_ctx)
        switch(cmd_ctx->lsm->cmd_type) {
        case LTTNG_LIST_SESSIONS:
        case LTTNG_LIST_TRACEPOINTS:
+       case LTTNG_LIST_TRACEPOINT_FIELDS:
        case LTTNG_LIST_DOMAINS:
        case LTTNG_LIST_CHANNELS:
        case LTTNG_LIST_EVENTS:
@@ -3355,9 +4032,11 @@ static int process_client_msg(struct command_ctx *cmd_ctx)
        /* Commands that DO NOT need a session. */
        switch (cmd_ctx->lsm->cmd_type) {
        case LTTNG_CREATE_SESSION:
+       case LTTNG_CREATE_SESSION_URI:
        case LTTNG_CALIBRATE:
        case LTTNG_LIST_SESSIONS:
        case LTTNG_LIST_TRACEPOINTS:
+       case LTTNG_LIST_TRACEPOINT_FIELDS:
                need_tracing_session = 0;
                break;
        default:
@@ -3433,6 +4112,10 @@ static int process_client_msg(struct command_ctx *cmd_ctx)
                                        goto error;
                                }
                                uatomic_set(&kernel_consumerd_state, CONSUMER_STARTED);
+
+                               /* Set consumer fd of the session */
+                               cmd_ctx->session->kernel_session->consumer_fd =
+                                       kconsumer_data.cmd_sock;
                        } else {
                                pthread_mutex_unlock(&kconsumer_data.pid_mutex);
                        }
@@ -3455,6 +4138,7 @@ static int process_client_msg(struct command_ctx *cmd_ctx)
                                        goto error;
                                }
                        }
+
                        /* Start the UST consumer daemons */
                        /* 64-bit */
                        pthread_mutex_lock(&ustconsumer64_data.pid_mutex);
@@ -3562,12 +4246,22 @@ skip_domain:
                                cmd_ctx->lsm->u.disable.channel_name);
                break;
        }
+       case LTTNG_DISABLE_CONSUMER:
+       {
+               ret = cmd_disable_consumer(cmd_ctx->lsm->domain.type, cmd_ctx->session);
+               break;
+       }
        case LTTNG_ENABLE_CHANNEL:
        {
                ret = cmd_enable_channel(cmd_ctx->session, cmd_ctx->lsm->domain.type,
                                &cmd_ctx->lsm->u.channel.chan);
                break;
        }
+       case LTTNG_ENABLE_CONSUMER:
+       {
+               ret = cmd_enable_consumer(cmd_ctx->lsm->domain.type, cmd_ctx->session);
+               break;
+       }
        case LTTNG_ENABLE_EVENT:
        {
                ret = cmd_enable_event(cmd_ctx->session, cmd_ctx->lsm->domain.type,
@@ -3614,6 +4308,42 @@ skip_domain:
                ret = LTTCOMM_OK;
                break;
        }
+       case LTTNG_LIST_TRACEPOINT_FIELDS:
+       {
+               struct lttng_event_field *fields;
+               ssize_t nb_fields;
+
+               nb_fields = cmd_list_tracepoint_fields(cmd_ctx->lsm->domain.type, &fields);
+               if (nb_fields < 0) {
+                       ret = -nb_fields;
+                       goto error;
+               }
+
+               /*
+                * Setup lttng message with payload size set to the event list size in
+                * bytes and then copy list into the llm payload.
+                */
+               ret = setup_lttng_msg(cmd_ctx, sizeof(struct lttng_event_field) * nb_fields);
+               if (ret < 0) {
+                       free(fields);
+                       goto setup_error;
+               }
+
+               /* Copy event list into message payload */
+               memcpy(cmd_ctx->llm->payload, fields,
+                               sizeof(struct lttng_event_field) * nb_fields);
+
+               free(fields);
+
+               ret = LTTCOMM_OK;
+               break;
+       }
+       case LTTNG_SET_CONSUMER_URI:
+       {
+               ret = cmd_set_consumer_uri(cmd_ctx->lsm->domain.type, cmd_ctx->session,
+                               &cmd_ctx->lsm->u.uri);
+               break;
+       }
        case LTTNG_START_TRACE:
        {
                ret = cmd_start_trace(cmd_ctx->session);
@@ -3630,6 +4360,14 @@ skip_domain:
                                cmd_ctx->lsm->session.path, &cmd_ctx->creds);
                break;
        }
+       case LTTNG_CREATE_SESSION_URI:
+       {
+               ret = cmd_create_session_uri(cmd_ctx->lsm->session.name,
+                               &cmd_ctx->lsm->u.create_uri.ctrl_uri,
+                               &cmd_ctx->lsm->u.create_uri.data_uri,
+                               cmd_ctx->lsm->u.create_uri.enable_consumer, &cmd_ctx->creds);
+               break;
+       }
        case LTTNG_DESTROY_SESSION:
        {
                ret = cmd_destroy_session(cmd_ctx->session,
@@ -3668,7 +4406,7 @@ skip_domain:
        }
        case LTTNG_LIST_CHANNELS:
        {
-               size_t nb_chan;
+               int nb_chan;
                struct lttng_channel *channels;
 
                nb_chan = cmd_list_channels(cmd_ctx->lsm->domain.type,
@@ -3755,6 +4493,43 @@ skip_domain:
                                cmd_ctx->lsm->u.reg.path);
                break;
        }
+       case LTTNG_SET_FILTER:
+       {
+               struct lttng_filter_bytecode *bytecode;
+
+               if (cmd_ctx->lsm->u.filter.bytecode_len > 65336) {
+                       ret = LTTCOMM_FILTER_INVAL;
+                       goto error;
+               }
+               bytecode = zmalloc(cmd_ctx->lsm->u.filter.bytecode_len);
+               if (!bytecode) {
+                       ret = LTTCOMM_FILTER_NOMEM;
+                       goto error;
+               }
+               /* Receive var. len. data */
+               DBG("Receiving var len data from client ...");
+               ret = lttcomm_recv_unix_sock(sock, bytecode,
+                               cmd_ctx->lsm->u.filter.bytecode_len);
+               if (ret <= 0) {
+                       DBG("Nothing recv() from client var len data... continuing");
+                       *sock_error = 1;
+                       ret = LTTCOMM_FILTER_INVAL;
+                       goto error;
+               }
+
+               if (bytecode->len + sizeof(*bytecode)
+                               != cmd_ctx->lsm->u.filter.bytecode_len) {
+                       free(bytecode);
+                       ret = LTTCOMM_FILTER_INVAL;
+                       goto error;
+               }
+
+               ret = cmd_set_filter(cmd_ctx->session, cmd_ctx->lsm->domain.type,
+                               cmd_ctx->lsm->u.filter.channel_name,
+                               cmd_ctx->lsm->u.filter.event_name,
+                               bytecode);
+               break;
+       }
        default:
                ret = LTTCOMM_UND;
                break;
@@ -3787,6 +4562,7 @@ init_setup_error:
 static void *thread_manage_clients(void *data)
 {
        int sock = -1, ret, i, pollfd;
+       int sock_error;
        uint32_t revents, nb_fd;
        struct command_ctx *cmd_ctx = NULL;
        struct lttng_poll_event events;
@@ -3919,13 +4695,22 @@ static void *thread_manage_clients(void *data)
                 * informations for the client. The command context struct contains
                 * everything this function may needs.
                 */
-               ret = process_client_msg(cmd_ctx);
+               ret = process_client_msg(cmd_ctx, sock, &sock_error);
                rcu_thread_offline();
                if (ret < 0) {
+                       if (sock_error) {
+                               ret = close(sock);
+                               if (ret) {
+                                       PERROR("close");
+                               }
+                               sock = -1;
+                       }
                        /*
                         * TODO: Inform client somehow of the fatal error. At
                         * this point, ret < 0 means that a zmalloc failed
-                        * (ENOMEM). Error detected but still accept command.
+                        * (ENOMEM). Error detected but still accept
+                        * command, unless a socket error has been
+                        * detected.
                         */
                        clean_command_ctx(&cmd_ctx);
                        continue;
@@ -4198,13 +4983,15 @@ static int set_permissions(char *rundir)
        int ret;
        gid_t gid;
 
-       gid = allowed_group();
-       if (gid < 0) {
+       ret = allowed_group();
+       if (ret < 0) {
                WARN("No tracing group detected");
                ret = 0;
                goto end;
        }
 
+       gid = ret;
+
        /* Set lttng run dir */
        ret = chown(rundir, 0, gid);
        if (ret < 0) {
@@ -4253,58 +5040,6 @@ end:
        return ret;
 }
 
-/*
- * Create the pipe used to wake up the kernel thread.
- * Closed in cleanup().
- */
-static int create_kernel_poll_pipe(void)
-{
-       int ret, i;
-
-       ret = pipe(kernel_poll_pipe);
-       if (ret < 0) {
-               PERROR("kernel poll pipe");
-               goto error;
-       }
-
-       for (i = 0; i < 2; i++) {
-               ret = fcntl(kernel_poll_pipe[i], F_SETFD, FD_CLOEXEC);
-               if (ret < 0) {
-                       PERROR("fcntl kernel_poll_pipe");
-                       goto error;
-               }
-       }
-
-error:
-       return ret;
-}
-
-/*
- * Create the application command pipe to wake thread_manage_apps.
- * Closed in cleanup().
- */
-static int create_apps_cmd_pipe(void)
-{
-       int ret, i;
-
-       ret = pipe(apps_cmd_pipe);
-       if (ret < 0) {
-               PERROR("apps cmd pipe");
-               goto error;
-       }
-
-       for (i = 0; i < 2; i++) {
-               ret = fcntl(apps_cmd_pipe[i], F_SETFD, FD_CLOEXEC);
-               if (ret < 0) {
-                       PERROR("fcntl apps_cmd_pipe");
-                       goto error;
-               }
-       }
-
-error:
-       return ret;
-}
-
 /*
  * Create the lttng run directory needed for all global sockets and pipe.
  */
@@ -4483,11 +5218,6 @@ int main(int argc, char **argv)
 
        rcu_register_thread();
 
-       /* Create thread quit pipe */
-       if ((ret = init_thread_quit_pipe()) < 0) {
-               goto error;
-       }
-
        setup_consumerd_path();
 
        /* Parse arguments */
@@ -4498,11 +5228,31 @@ int main(int argc, char **argv)
 
        /* Daemonize */
        if (opt_daemon) {
+               int i;
+
+               /*
+                * fork
+                * child: setsid, close FD 0, 1, 2, chdir /
+                * parent: exit (if fork is successful)
+                */
                ret = daemon(0, 0);
                if (ret < 0) {
                        PERROR("daemon");
                        goto error;
                }
+               /*
+                * We are in the child. Make sure all other file
+                * descriptors are closed, in case we are called with
+                * more opened file descriptors than the standard ones.
+                */
+               for (i = 3; i < sysconf(_SC_OPEN_MAX); i++) {
+                       (void) close(i);
+               }
+       }
+
+       /* Create thread quit pipe */
+       if ((ret = init_thread_quit_pipe()) < 0) {
+               goto error;
        }
 
        /* Check if daemon is UID = 0 */
@@ -4688,12 +5438,12 @@ int main(int argc, char **argv)
        }
 
        /* Setup the kernel pipe for waking up the kernel thread */
-       if ((ret = create_kernel_poll_pipe()) < 0) {
+       if ((ret = utils_create_pipe_cloexec(kernel_poll_pipe)) < 0) {
                goto exit;
        }
 
        /* Setup the thread apps communication pipe. */
-       if ((ret = create_apps_cmd_pipe()) < 0) {
+       if ((ret = utils_create_pipe_cloexec(apps_cmd_pipe)) < 0) {
                goto exit;
        }
 
@@ -4709,6 +5459,12 @@ int main(int argc, char **argv)
        /* Set up max poll set size */
        lttng_poll_set_max_size();
 
+       /*
+        * Set network sequence index to 1 for streams to match a relayd socket on
+        * the consumer side.
+        */
+       uatomic_set(&relayd_net_seq_idx, 1);
+
        /* Create thread to manage the client socket */
        ret = pthread_create(&client_thread, NULL,
                        thread_manage_clients, (void *) NULL);
This page took 0.044291 seconds and 4 git commands to generate.