]> rtime.felk.cvut.cz Git - frescor/fwp.git/blob - wme_test/wclient.c
wme_test: Send timing reworked
[frescor/fwp.git] / wme_test / wclient.c
1 #include <errno.h>
2 #include <error.h>
3 #include <sys/types.h>
4 #include <sys/socket.h>
5 #include <netinet/in.h>
6 #include <arpa/inet.h>
7 #include <netdb.h>
8 #include <signal.h>
9 #include <sys/wait.h>
10 #include <stdio.h>
11 #include <unistd.h>
12 #include <fcntl.h>
13 #include <time.h>
14 #include <string.h>
15 #include <pthread.h>
16 #include <string.h>
17 #include <stdlib.h>
18 #include <stdbool.h>
19 #include "common.h"
20 #include <semaphore.h>
21 #include <sys/ioctl.h>
22 #include <net/if.h>
23 #include <inttypes.h>
24 #include <ncurses.h>
25
26 #ifdef WITH_FWP
27 #include <ul_logreg.h>
28 #endif
29
30 #ifdef WITH_FWP
31 #include <frsh.h>
32 #include <fwp_res.h>
33
34 /* static UL_LOG_CUST(ulogd); */
35 /* static ul_log_domain_t ulogd = {UL_LOGL_MSG, "wclient"}; */
36 /* UL_LOGREG_SINGLE_DOMAIN_INIT_FUNCTION(init_ulogd_wclient, ulogd); */
37
38 #endif
39
40 #define MAX_STREAMS  10 
41 #define MIN_GRANULARITY 100
42
43 unsigned opt_packet_size = 800;
44 int opt_send_buf_size = -1;
45 unsigned opt_period_usec = 10*MSEC_TO_USEC;
46 char    *opt_interface;
47 unsigned opt_jitter = 0;
48 char    *opt_output = "delay_stats";
49 unsigned opt_count_sec = 0;
50 unsigned opt_def_bandwidth = 50;
51 unsigned opt_def_period_msec = 0;
52 int opt_granularity_usec = MIN_GRANULARITY;
53 bool opt_wait_for_queue_is_full; /* Don't gather any statistics until any queue is full */
54 char *opt_comment = NULL;
55 bool opt_gui = false;
56
57 bool some_queue_is_full = false;
58 uint64_t reset_timestamp; /* [nsec] */
59
60 bool some_contract_not_accepted = false;
61
62 /* Locked when some queue is full to prevent multiple resets of
63    statstics. */
64 pthread_mutex_t queue_full_mutex = PTHREAD_MUTEX_INITIALIZER;
65
66 int ac_sockfd[AC_NUM];
67
68 struct receiver {
69         bool valid;
70         pthread_t thread;
71         unsigned received, last_received;
72 };
73
74 struct receiver receivers[AC_NUM];
75
76 FILE* logfd;
77 char* server_addr; 
78 char logfname[100];
79
80 /* maximal traffic delay in ms - 10 s*/
81 #define MAX_DELAY_US 10000000
82
83 struct delay_stat {
84         unsigned csc;           /* Client-server-client delay divided by 2 */
85         unsigned cs;            /* Client-server delay */
86         unsigned sc;            /* Server-client delay */
87 };
88
89 struct delay_stat delay_stats[AC_NUM][MAX_DELAY_US/MIN_GRANULARITY];
90 pthread_mutex_t delay_stats_mutex = PTHREAD_MUTEX_INITIALIZER;
91
92 /*struct ac_stats[AC_NUM] {
93    unsigned long int min_trans_time;
94    unsigned long int sum_trans_time;
95    struct timespec   recv_timestamp;
96    struct timespec   send_timestamp; 
97 };*/
98
99 struct stream {
100         /* Input parameters */
101         enum ac ac;             /*  */
102         int bandwidth_bps;      /* bits per second */
103         int jitter;             /* percent */
104         /* Mulualy exclusive input parameters */
105         int packet_size;
106         long period_usec;       /* all time units are in microseconds */
107
108         /* Internal fields */
109 #ifndef WITH_FWP
110         struct sockaddr_in rem_addr;
111 #else
112         frsh_send_endpoint_t endpoint;
113         frsh_receive_endpoint_t resp_endpoint;
114         frsh_vres_id_t vres, vres_rcv;
115         uint16_t resp_port;
116         struct receiver receiver;
117 #endif
118
119         /* Statistics */
120         pthread_mutex_t mutex;
121         unsigned long long sent, really_sent, received;
122         long wc_delay;          /* worst-case delay  */
123 };
124
125 static struct cmsg_ipi {
126         struct cmsghdr cm;
127         struct in_pktinfo ipi;
128 } cmsg = { {sizeof(struct cmsg_ipi), SOL_IP, IP_PKTINFO},
129            {0, }};
130 int cmsg_len = 0;
131
132 /*
133 struct send_endpoint sepoint[] = {
134         { .ac = AC_VO, .period_usec=200*MSEC_TO_USEC, .bandwidth_bps = 34*Kbit },
135         { .ac = AC_VI, .period_usec=25*MSEC_TO_USEC, .bandwidth_bps =  480*Kbit },
136         { .ac = AC_BE, .period_usec=40*MSEC_TO_USEC, .bandwidth_bps =  300*Kbit },
137         { .ac = AC_BK, .period_usec=40*MSEC_TO_USEC, .bandwidth_bps =  300*Kbit },
138 //      { .ac = AC_VI, .period_usec=17*MSEC_TO_USEC, .bandwidth_bps =  675*Kbit },
139 };
140 */
141
142 struct stream streams[MAX_STREAMS];
143
144 unsigned int nr_streams = 0;
145
146 sem_t sem_thread_finished;
147
148 bool exit_flag = false;
149
150 #ifdef WITH_FWP
151 #define negotiate_contract_for_stream(s) negotiate_contract_for_stream_fwp(s)
152 #define create_stream_endpoint(s) create_stream_endpoint_fwp(s)
153 #define send_packet(s, b) send_packet_fwp(s, b)
154 #define recv_packet(s, b) recv_packet_fwp(s, b)
155 #define wait_for_all_threads_to_finish() wait_for_all_threads_to_finish_fwp()
156 #else
157 #define negotiate_contract_for_stream(s) 0
158 #define create_stream_endpoint(s) create_stream_endpoint_native(s)
159 #define send_packet(s, b) send_packet_native(s, b)
160 #define recv_packet(s, b) recv_packet_native(s, b)
161 #define wait_for_all_threads_to_finish() wait_for_all_threads_to_finish_native()
162 #endif
163
164 void stopper()
165 {
166         int i;
167         exit_flag = true;
168
169         /* Interrupt all receivers */
170 #ifdef WITH_FWP
171         for (i=0; i < nr_streams; i++) {
172                 if (streams[i].receiver.valid) pthread_kill(streams[i].receiver.thread, SIGUSR1);
173         }
174 #else
175         for (i=0; i < AC_NUM; i++) {
176                 pthread_kill(receivers[i].thread, SIGUSR1);
177         }       
178 #endif
179 }
180
181 void stream_to_text(char *stream_desc, size_t n, struct stream *stream, long long useconds)
182 {
183         char buf[3][12];
184         char real[100];
185
186         if (useconds) {
187                 snprintf(real, sizeof(real), "; real: %s sent %lld (%lld/s), received %lld (%lld/s)",
188                          bandwidth_to_text(buf[0], (long long)stream->really_sent*stream->packet_size*8*SEC_TO_USEC/useconds),
189                          stream->sent, stream->sent*SEC_TO_USEC/useconds,
190                          stream->received, stream->received*SEC_TO_USEC/useconds);
191         } else {
192                 real[0]=0;
193         }
194         
195         snprintf(stream_desc, n, "%"PRIdPTR": %s %s (%d bytes per %s +-%s, %d packets/s)%s",
196                  stream-streams, ac_to_text[stream->ac], bandwidth_to_text(buf[0], stream->bandwidth_bps),
197                  stream->packet_size, usec_to_text(buf[1], stream->period_usec),
198                  usec_to_text(buf[2], stream->jitter*stream->period_usec/100),
199                  (int)(SEC_TO_USEC/stream->period_usec), real);
200 }
201
202 void save_results(int argc, char *argv[], int useconds)
203 {
204         int ac, i, maxi;
205         const int mini = 3000/opt_granularity_usec;
206         bool allzeros;
207         unsigned send_count[AC_NUM];
208
209         fprintf(stderr, "Writing data to %s... ", logfname);
210         fflush(stderr);
211
212         fprintf(logfd, "# Invoked as: ");
213         for (i=0; i<argc; i++) fprintf(logfd, "%s ", argv[i]);
214         if (opt_comment) {
215                 fprintf(logfd, "(%s)", opt_comment);
216         }
217         fprintf(logfd, "\n");
218
219         if (useconds/SEC_TO_USEC != opt_count_sec) {
220                 char buf[20];
221                 usec_to_text(buf, useconds);
222                 fprintf(logfd, "# Data gathered for %s.\n", buf);
223         }
224                 
225         for (i = 0; i < nr_streams; i++) {
226                 char stream_desc[200];
227                 stream_to_text(stream_desc, sizeof(stream_desc), &streams[i], useconds);
228                 fprintf(logfd, "# Stream %s\n", stream_desc);
229         }
230
231         /* Find maximal delay */
232         allzeros = true;
233         for (maxi = MAX_DELAY_US/opt_granularity_usec - 1; maxi >= 0; maxi--) {
234                 for (ac = 0; ac < AC_NUM; ac++) {
235                         if ((delay_stats[ac][maxi].csc != 0) ||
236                             (delay_stats[ac][maxi].cs != 0) ||
237                             (delay_stats[ac][maxi].sc != 0))
238                                 allzeros = false;
239                 }
240                 if (!allzeros) break;
241         }
242         maxi++;
243         if (maxi < mini) maxi = mini;
244
245         /* Calculate total number of sent packets per AC */
246         memset(send_count, 0, sizeof(send_count));
247         for (i = 0; i < nr_streams; i++) {
248                 ac = streams[i].ac;
249                 send_count[ac] += streams[i].sent;
250         }
251
252 #if 0
253         /* Write pdf */
254         for ( i = 0 ; i < maxi; i++) {
255                 fprintf(logfd,"\n%f", i*opt_granularity_usec/1000.0);
256                 for (ac = 0; ac < AC_NUM; ac++) { 
257                         if (sum[ac])
258                                 val = (double)delay_stats[ac][i]*100.0 / sum[ac];
259                         else val = -1; /* Don't display this ac */
260                         fprintf(logfd," %lf", val);
261                 }
262         }
263         
264         fprintf(logfd,"\n\n");
265 #endif
266         
267         fprintf(logfd,"## Format: msec csc%% cs%% sc%%\n");
268
269         /* Write PDF */
270         for (ac = 0; ac < AC_NUM; ac++) {
271                 struct delay_stat integral = {0,0,0}, last = {-1,-1,-1};
272
273                 fprintf(logfd,"%f %f %f %f\n", 0.0, 0.0, 0.0, 0.0);
274
275                 if (send_count[ac] != 0) {
276                         i=0;
277                         while ((delay_stats[ac][i].csc == 0) &&
278                                (delay_stats[ac][i].cs == 0) &&
279                                (delay_stats[ac][i].sc == 0)) i++;
280                 
281                         for (i++; i < maxi+1; i++) {
282                                 if (memcmp(&last, &integral, sizeof(last))) {
283                                         char buf[3][20];
284                                         snprintf(buf[0], sizeof(buf[0]), "%f", (double)integral.csc*100.0 / send_count[ac]);
285                                         snprintf(buf[1], sizeof(buf[1]), "%f", (double)integral.cs *100.0 / send_count[ac]);
286                                         snprintf(buf[2], sizeof(buf[2]), "%f", (double)integral.sc *100.0 / send_count[ac]);
287                                                  
288                                         fprintf(logfd,"%f %s %s %s\n", i*opt_granularity_usec/1000.0,
289                                                 integral.csc != last.csc ? buf[0] : "-",
290                                                 integral.cs  != last.cs  ? buf[1] : "-",
291                                                 integral.sc  != last.sc  ? buf[2] : "-"
292                                                 );
293                                         last = integral;
294                                 }
295                                 if (i>0) {
296                                         integral.csc += delay_stats[ac][i-1].csc;
297                                         integral.sc  += delay_stats[ac][i-1].sc;
298                                         integral.cs  += delay_stats[ac][i-1].cs;
299                                 }
300                         }
301                 }
302                 fprintf(logfd,"\n\n");
303         }
304         
305         fprintf(stderr, "finished.\n");
306         fclose(logfd);
307
308         exit(0);
309 }
310
311 int create_ac_socket(intptr_t ac) 
312 {
313         int sockfd;
314         unsigned int yes=1, tos;
315
316
317         if ((sockfd = socket(PF_INET, SOCK_DGRAM, IPPROTO_UDP)) < 0)
318         {
319                 error(0, errno, "Unable to open socket");
320                 return -1;
321         }
322         if (fcntl(sockfd, F_SETFL, O_NONBLOCK) != 0) {
323                 error(0, errno, "set non-blocking socket");
324                 return -1;
325         }
326         if (setsockopt(sockfd,SOL_SOCKET,SO_REUSEADDR,&yes,sizeof(int)) == -1) {
327                 error(0, errno, "Unable to set socket");
328                 return -1;
329         }
330
331         if (opt_send_buf_size >= 0) {
332                 if (setsockopt(sockfd,SOL_SOCKET,SO_SNDBUF,&opt_send_buf_size,sizeof(opt_send_buf_size)) == -1) {
333                         error(0, errno, "Unable to set socket buffer size");
334                         return -1;
335                 }
336         }
337
338         
339         //tos = ((AC_NUM - ac) *2 - 1)*32;
340         tos = ac_to_tos[ac];
341         if (setsockopt(sockfd, SOL_IP, IP_TOS, &tos, sizeof(tos))) {
342                 error(0, errno, "Unable to set TOS");
343                 close(sockfd);
344                 return -1;
345         }
346
347         return sockfd;
348 }
349
350 void empty_handler()
351 {
352 }
353
354 void reset_statistics()
355 {
356         int i;
357         struct timespec ts;
358         for (i = 0; i < nr_streams; i++) {
359                 pthread_mutex_lock(&streams[i].mutex);
360                 streams[i].sent = 0;
361                 streams[i].really_sent = 0;
362                 streams[i].received = 0;
363                 pthread_mutex_unlock(&streams[i].mutex);
364         }
365         pthread_mutex_lock(&delay_stats_mutex);
366         clock_gettime(CLOCK_REALTIME, &ts);
367         reset_timestamp = ts.tv_sec*1000000000LL + ts.tv_nsec;
368         memset(delay_stats, 0, sizeof(delay_stats));
369         pthread_mutex_unlock(&delay_stats_mutex);
370 }
371
372 #ifndef WITH_FWP
373 int recv_packet_native(intptr_t ac, struct msg_t *msg)
374 {
375         int     mlen, ret;
376         fd_set fdset;
377         struct  sockaddr_in rem_addr;
378         unsigned int rem_addr_length; 
379
380         FD_ZERO(&fdset);
381         FD_SET(ac_sockfd[ac], &fdset);
382         rem_addr_length = sizeof(rem_addr);
383         mlen = -1;
384         while (!exit_flag) {
385                 ret = select(ac_sockfd[ac]+1, &fdset, NULL, NULL, NULL);
386                 if (ret < 0) {
387                         if (errno == EINTR) continue;
388                         error(0, errno, "receiver select");
389                         return -1;
390                 }
391                 mlen = recvfrom(ac_sockfd[ac], msg, sizeof(*msg), 0,
392                                 (struct sockaddr*)&rem_addr, &rem_addr_length);
393                 break;
394         }
395         return mlen;
396 }
397 #else
398 int recv_packet_fwp(struct stream *stream, struct msg_t *msg)
399 {
400         int ret;
401         size_t mlen;
402
403         ret = frsh_receive_sync(stream->resp_endpoint, msg, sizeof(*msg), &mlen, NULL);
404         return mlen;
405 }
406 #endif
407
408 void* receiver(void* arg)
409 {
410         struct msg_t    msg;
411         long long int trans_time_usec, client_to_server_usec, server_to_client_usec;
412         long long int min_trans_time;
413         struct timespec ts;
414         uint64_t send_timestamp, server_timestamp, recv_timestamp;
415         int     mlen;
416         intptr_t ac;
417         
418         min_trans_time = ~0;
419         
420         block_signals();
421         set_rt_prio(99);
422
423         while (!exit_flag) {
424 #ifdef WITH_FWP
425                 struct stream *stream = arg;
426                 ac = stream->ac;
427                 mlen = recv_packet_fwp(stream, &msg);
428 #else
429                 ac = (intptr_t)arg;
430                 mlen = recv_packet_native(ac, &msg);
431 #endif
432                 if (mlen < 0) {
433                         if (errno != EINTR)
434                                 error(0, errno, "receive_packet error");
435                         goto out;
436                 }       
437                 clock_gettime(CLOCK_REALTIME,&ts);
438                 recv_timestamp = ts.tv_sec*1000000000LL + ts.tv_nsec;
439                 send_timestamp = msg.send_timestamp;
440                 server_timestamp = msg.sendback_timestamp;
441
442                 /* Check whether this message was sent after reset_statistics() */
443
444                 if (send_timestamp < reset_timestamp) {
445                         continue; /* If so, don't count it */
446                 }
447
448                 trans_time_usec = (recv_timestamp - send_timestamp) / 2 / 1000;
449                 client_to_server_usec = (server_timestamp - send_timestamp) / 1000;
450                 server_to_client_usec = (recv_timestamp - server_timestamp) / 1000;
451
452                 pthread_mutex_lock(&delay_stats_mutex);
453                 if (trans_time_usec < MAX_DELAY_US && trans_time_usec >= 0) {
454                         delay_stats[ac][trans_time_usec/opt_granularity_usec].csc++;
455                 }
456                 if (client_to_server_usec < MAX_DELAY_US && client_to_server_usec >= 0) {
457                         delay_stats[ac][client_to_server_usec/opt_granularity_usec].cs++;
458                 }
459                 if (server_to_client_usec < MAX_DELAY_US && server_to_client_usec >= 0) {
460                         delay_stats[ac][server_to_client_usec/opt_granularity_usec].sc++;
461                 }
462                 pthread_mutex_unlock(&delay_stats_mutex);
463
464                 if (trans_time_usec > streams[msg.stream].wc_delay) {
465                         streams[msg.stream].wc_delay = trans_time_usec;
466                 }
467                 receivers[ac].received++;
468                 
469                 pthread_mutex_lock(&streams[msg.stream].mutex);
470                 streams[msg.stream].received++;
471                 pthread_mutex_unlock(&streams[msg.stream].mutex);
472         
473                 /*if (trans_time_nsec < min_trans_time) 
474                         min_trans_time = trans_time_nsec;*/
475                 /*printf("seqn= %lu tos= %d start= %lu(s).%lu(ns)"\
476                          "stop= %lu(s).%lu(ns)\n trans_time = %lums\n",\
477                          msg.seqn, msg.tos, send_timestamp.tv_sec,\
478                          send_timestamp.tv_nsec,recv_timestamp.tv_sec,\
479                          recv_timestamp.tv_nsec, trans_time_msec); */
480         }
481 out:
482         sem_post(&sem_thread_finished);
483         return NULL;
484 }
485
486 /** 
487  * Send a packet.
488  * 
489  * @return -1 in case of error, 1 in case of sucessfull send and 0
490  *         when all buffers are full.
491  */
492 #ifndef WITH_FWP
493 static inline int 
494 send_packet_native(struct stream* stream, union msg_buff* buff)
495 {
496         struct iovec  iov;
497         struct msghdr msg;
498
499         iov.iov_base = buff;
500         iov.iov_len = stream->packet_size;
501         msg.msg_name = (void*)&stream->rem_addr;
502         msg.msg_namelen = sizeof(stream->rem_addr);
503         msg.msg_iov = &iov;
504         msg.msg_iovlen = 1;
505         msg.msg_flags = 0;
506         msg.msg_control = &cmsg;
507         msg.msg_controllen = cmsg_len;
508
509         int ret = 1;
510         
511         while (sendmsg(ac_sockfd[stream->ac], &msg, 0) < 0) {
512                 if (errno == EINTR) continue;
513                 if (errno == EAGAIN) {
514                         if (opt_wait_for_queue_is_full && 
515                             !some_queue_is_full && 
516                             /* We use mutex as atomic test and set */
517                             (pthread_mutex_trylock(&queue_full_mutex) != EBUSY)) {
518                                 some_queue_is_full = true;
519                                 reset_statistics();
520                         }
521                         ret = 0;
522                         break;
523                 } else {
524                         error(0, errno, "Error while sending");
525                         ret = -1;
526                         break;
527                 }
528         }
529         return ret;
530 }
531 #else
532 static inline int 
533 send_packet_fwp(struct stream* stream, union msg_buff* buff)
534 {
535         int ret = 0;
536
537         buff->msg.resp_port = htons(stream->resp_port);
538         ret = frsh_send_async(stream->endpoint, buff, stream->packet_size);
539         if (ret) {
540                 char msg[1024];
541                 frsh_strerror(ret, msg, sizeof(msg));
542                 fprintf(stderr, "frsh_send error: %s\n", msg);
543         }
544         return (ret == 0) ? 0 : -1;
545 }
546 #endif
547
548 static inline void
549 wait_for_next_send(struct stream* stream, struct timespec *last_send_time)
550 {
551         struct timespec time_to_wait, current_time, period, interval;
552         unsigned delay_usec, period_usec = stream->period_usec;
553
554         /*           |~~~+~~~| jitter interval (width = 2*stream->jitter percentage from period)*/
555         /* |-------------|     nominal period*/
556         if (stream->jitter) {
557                 delay_usec = period_usec*(100-stream->jitter)/100
558                         + rand() % (2*period_usec*stream->jitter/100);
559         } else {
560                 delay_usec = period_usec;
561         }
562         period.tv_nsec = USEC_TO_NSEC*(delay_usec%SEC_TO_USEC);
563         period.tv_sec = delay_usec/SEC_TO_USEC;
564         
565         timespec_add(&time_to_wait, last_send_time, &period);
566         clock_gettime(CLOCK_MONOTONIC,&current_time);
567         timespec_sub(&interval,&time_to_wait,&current_time);
568         if (interval.tv_sec >= 0) {
569                 nanosleep(&interval,NULL);
570                 *last_send_time = time_to_wait;
571         } else {
572                 *last_send_time = current_time;
573         }
574 }
575
576
577 void* sender(void* arg)
578 {
579         union msg_buff buff;
580         unsigned long int seqn;
581         struct stream* stream = (struct stream*) arg;
582         struct timespec timer = { 0, 0 }, ts;
583         int ret;
584
585         if (!opt_gui) {
586                 char stream_desc[100];
587                 stream_to_text(stream_desc, sizeof(stream_desc), stream, 0);
588                 printf("%s\n", stream_desc);
589         }
590         if (stream->bandwidth_bps == 0)
591                 goto out;
592
593         seqn = 0;
594         
595         block_signals();
596         set_rt_prio(90-stream->ac);
597
598         while (!exit_flag) {
599                 wait_for_next_send(stream, &timer);
600
601 /*              buff.msg.seqn = seqn++; */
602 /*              buff.msg.tos = ac_to_tos[stream->ac]; */
603                 buff.msg.stream = stream-streams;
604                 
605                 clock_gettime(CLOCK_REALTIME,&ts);
606                 buff.msg.send_timestamp = ts.tv_sec*1000000000LL + ts.tv_nsec;
607
608                 ret = send_packet(stream, &buff);
609                 if (ret < 0) {
610                         stopper();
611                         goto out;
612                 }
613
614                 pthread_mutex_lock(&stream->mutex);
615                 stream->sent++;
616                 if (ret > 0)
617                         stream->really_sent++;
618                 pthread_mutex_unlock(&stream->mutex);
619
620 #ifdef DEBUG
621                 printf("%d", stream->ac);
622                 fflush(stdout);
623 #endif
624
625         }
626 out:
627         sem_post(&sem_thread_finished);
628         return NULL;
629 }
630
631 #ifdef WITH_FWP
632 static int negotiate_contract_for_stream_fwp(struct stream *stream)
633 {
634         frsh_contract_t contract;
635         int ret;
636         frsh_rel_time_t budget, period, deadline;
637         frsh_signal_info_t si;
638
639         /* Contract for client->server stream */
640         frsh_contract_init(&contract);
641         frsh_contract_set_resource_and_label(&contract, FRSH_RT_NETWORK, FRSH_NETPF_FWP, NULL);
642         frsh_network_bytes_to_budget(FRSH_NETPF_FWP, stream->packet_size, &budget);
643         period = frsh_usec_to_rel_time(stream->period_usec);
644         frsh_contract_set_basic_params(&contract, &budget, &period, FRSH_WT_BOUNDED, FRSH_CT_REGULAR);
645         deadline = frsh_usec_to_rel_time(3*stream->period_usec);
646         frsh_contract_set_timing_reqs(&contract, false, &deadline, 0, si, 0, si);
647         
648         ret = frsh_contract_negotiate(&contract, &stream->vres);
649         frsh_contract_destroy(&contract);
650         if (ret != 0) {
651                 stream->vres = NULL;
652                 fprintf(stderr, "Send contract was not accepted\n");
653                 return ret;
654         }
655
656         /* Contract for server->client stream */
657         /* TODO: Use group negotiation for these two contracts */
658         frsh_contract_init(&contract);
659         frsh_contract_set_resource_and_label(&contract, FRSH_RT_NETWORK, FRSH_NETPF_FWP, NULL);
660         frsh_network_bytes_to_budget(FRSH_NETPF_FWP, stream->packet_size, &budget);
661         period = frsh_usec_to_rel_time(stream->period_usec);
662         frsh_contract_set_basic_params(&contract, &budget, &period, FRSH_WT_BOUNDED, FRSH_CT_DUMMY);
663         deadline = frsh_usec_to_rel_time(3*stream->period_usec);
664         frsh_contract_set_timing_reqs(&contract, false, &deadline, 0, si, 0, si);
665
666         ret = frsh_contract_negotiate(&contract, &stream->vres_rcv);
667         frsh_contract_destroy(&contract);
668         if (ret != 0) {
669                 fprintf(stderr, "Receive contract was not accepted\n");
670                 return ret;
671         }
672
673         /* We don't use the vres at server, since the server doesn't
674          * know the parameters. Instread, server uses plain
675          * sockets. */
676         
677         return ret;
678 }
679 #endif
680
681 #ifdef WITH_FWP
682 static void create_stream_endpoint_fwp(struct stream *stream)
683 {
684 /*      fwp_endpoint_attr_t  attr; */
685         int ret;
686         struct hostent* ph;
687         frsh_contract_t c;
688         fres_block_fwp_sched *fwp_sched;
689
690         frsh_vres_get_contract(stream->vres, &c);
691         fwp_sched = fres_contract_get_fwp_sched(c);
692
693         stream->ac = fwp_sched->ac_id;
694
695 /*      fwp_endpoint_attr_init(&attr); */
696 /*      fwp_endpoint_attr_setreliability(&attr, FWP_EPOINT_BESTEFFORT); */
697
698         ph = gethostbyname(server_addr);
699         if (ph && ph->h_addr_list[0]) {
700                 struct in_addr *a = (struct in_addr *)(ph->h_addr_list[0]);
701                 frsh_send_endpoint_protocol_info_t    spi = { NULL, 0 };
702                 frsh_receive_endpoint_protocol_info_t rpi = { NULL, 0 };
703                 frsh_endpoint_queueing_info_t qi = { .queue_size=0, .queue_policy=FRSH_QRP_OLDEST };
704                 ret = frsh_send_endpoint_create(FRSH_NETPF_FWP, a->s_addr, BASE_PORT + stream->ac, 
705                                                 spi, &stream->endpoint);
706                 if (ret < 0) error(1, errno, "frsh_send_endpoint_create()");
707                 
708                 ret = frsh_send_endpoint_bind(stream->vres, stream->endpoint);
709                 if (ret != 0) error(1, errno, "frsh_send_endpoint_bind");
710
711                 ret = frsh_receive_endpoint_create(FRSH_NETPF_FWP, 0, qi, rpi,
712                                                    &stream->resp_endpoint);
713                 if (ret != 0) error(1, errno, "fwp_receive_endpoint_create");
714                 
715                 unsigned int port;
716                 frsh_receive_endpoint_get_params(stream->resp_endpoint, NULL, &port, NULL, NULL);
717                 stream->resp_port = port;
718
719                 ret = pthread_create(&stream->receiver.thread, NULL, receiver, (void*)stream);
720                 if (ret) error(1, ret, "Error while creating receiver");
721                 
722                 stream->receiver.valid = true;
723         }
724         else {
725                 error(1, errno, "gethostbyname(%s)", server_addr);
726         }
727
728 }
729 #else
730 static void create_stream_endpoint_native(struct stream *stream)
731 {
732         struct hostent* ph;
733
734         memset(&stream->rem_addr,0, sizeof(stream->rem_addr));
735
736         stream->rem_addr.sin_family = AF_INET;
737         ph = gethostbyname(server_addr);
738         if (ph)
739                 stream->rem_addr.sin_addr = *((struct in_addr *)ph->h_addr);
740         else {
741                 error(1, errno, "gethostbyname(%s)", server_addr);
742         }
743         stream->rem_addr.sin_port = htons(BASE_PORT + stream->ac);
744 }
745 #endif
746
747 static inline void
748 calc_stream_params(struct stream *stream)
749 {
750         int packet_size;
751         unsigned period_usec;
752         int bandwidth;
753         int ret;
754
755         /* If some parameters are not set explicitely, use default values. */
756         if (stream->bandwidth_bps < 0) stream->bandwidth_bps = opt_def_bandwidth * Kbit;
757         if (stream->packet_size < 0) stream->packet_size = opt_packet_size;
758         if (stream->period_usec < 0) stream->period_usec = opt_def_period_msec * MSEC_TO_USEC;
759
760         bandwidth = stream->bandwidth_bps;
761
762         /* Avoid arithmetic exception. Server thread will exit if
763            stream->bandwidth_bps == 0. */
764         if (bandwidth == 0) bandwidth = 1;
765
766         if (stream->packet_size) {
767                 packet_size = stream->packet_size;
768                 period_usec = SEC_TO_USEC*packet_size*8/bandwidth;
769                 if (period_usec == 0) period_usec = 1;
770         } else if (stream->period_usec) {
771                 period_usec = stream->period_usec;
772                 packet_size = (long long)bandwidth/8 * period_usec/SEC_TO_USEC;
773         } else {
774                 char buf[200];
775                 stream_to_text(buf, sizeof(buf), stream, 0);
776                 error(1, 0, "Neither packet size nor period was specified for a stream %s", buf);
777         }
778
779         if (packet_size < sizeof(struct msg_t)) {
780                 error(1, 0, "Packet size too small (min %zd)", sizeof(struct msg_t));
781         }
782
783         stream->packet_size = packet_size;
784         stream->period_usec = period_usec;
785         stream->jitter = opt_jitter;
786
787         ret = negotiate_contract_for_stream(stream);
788         if (ret == 0) {
789                 create_stream_endpoint(stream);
790         } else {
791                 char buf[200];
792                 stream_to_text(buf, sizeof(buf), stream, 0);
793                 fprintf(stderr, "Contract hasn't been accepted:\n%s\n", buf);
794                 stream->bandwidth_bps = 0;
795                 some_contract_not_accepted = true;
796         }
797 }
798
799 /** 
800  * Parse -b parameter.
801  * 
802  * @param params String to parse
803  * 
804  * @return NULL in case of success, pointer to a problematic character
805  *         on error.
806  */
807 char* parse_bandwidths(char *params)
808 {
809         struct stream *sp = &streams[nr_streams];
810
811         while (*params && nr_streams < MAX_STREAMS) {
812                 char *ac_ids[AC_NUM] = { [AC_VO]="VO", [AC_VI]="VI", [AC_BE]="BE", [AC_BK]="BK" };
813                 int i;
814                 char *next_char;
815
816                 if (strlen(params) < 2)
817                         return params;
818                 for (i=0; i<AC_NUM; i++) {
819                         if (strncmp(params, ac_ids[i], 2) == 0) {
820                                 sp->ac = i;
821                                 params+=strlen(ac_ids[i]);
822                                 break;
823                         }
824                 }
825                 if (i==AC_NUM)
826                         return params;
827
828                 long bw;
829                 if (*params == ':') {
830                         params++;
831
832                         bw = strtol(params, &next_char, 10);
833                         if (next_char == params)
834                                 return params;
835                         params = next_char;
836                 } else
837                         bw = -1;
838                 
839                 sp->bandwidth_bps = bw*Kbit;
840
841                 long period = 0;
842                 long packet_size = 0;
843                 if (*params == '@') {
844                         params++;
845                         period = strtol(params, &next_char, 10);
846                         if (period == 0)
847                                 return params;
848                         params = next_char;
849                 }
850                 else {
851                         if (*params == '/') {
852                                 params++;
853                                 packet_size = strtol(params, &next_char, 10);
854                                 if (packet_size == 0)
855                                         return params;
856                                 params = next_char;
857                         } else {
858                                 packet_size = -1; 
859                                 period = -1;
860                         }
861                 }
862                 sp->period_usec = period*MSEC_TO_USEC;
863                 sp->packet_size = packet_size;
864
865                 
866
867                 if (*params != '\0' && *params != ',')
868                         return params;
869                 nr_streams++;
870                 sp++;
871                 if (*params == ',')
872                         params++;
873         }
874         return NULL;
875 }
876
877 #ifdef WITH_FWP
878 void wait_for_all_threads_to_finish_fwp(void)
879 {
880         int i;
881         /* wait for all threads to finish */
882         for (i=0; i < 2*nr_streams; i++) {
883                 sem_wait(&sem_thread_finished);
884         }
885 }
886 #else
887 void wait_for_all_threads_to_finish_native(void)
888 {
889         int i;
890         /* Wait for all threads to finish */
891         for (i=0; i < nr_streams + AC_NUM; i++) {
892                 sem_wait(&sem_thread_finished);
893         }
894 }
895 #endif
896
897 WINDOW *logwin;
898
899 #if 0
900 struct log_params {
901         ul_log_domain_t *domain;
902         int level;
903         const char *format;
904         va_list ap;
905 };
906
907
908 int locked_log(WINDOW *logwin, void *arg)
909 {
910         struct log_params *p = arg;
911         if(!(p->level&UL_LOGL_CONT)) {
912                 p->level&=UL_LOGL_MASK;
913                 if(p->level)
914                         wprintw(logwin,"<%d>", p->level);
915                 if(p->domain && p->domain->name)
916                         wprintw(logwin,"%s: ",p->domain->name);
917         }
918         vwprintw(logwin, p->format, p->ap);
919         wnoutrefresh(logwin);
920         return 0;
921 }
922
923 void
924 wclient_log_fnc(ul_log_domain_t *domain, int level,
925                 const char *format, va_list ap)
926 {
927         struct log_params p = {
928                 .domain = domain,
929                 .level = level,
930                 .format = format,
931         };
932         va_copy(p.ap, ap);
933         va_end(ap);
934
935         use_window(logwin, locked_log, (void*)&p);
936 }
937 #endif
938
939
940 void init_gui()
941 {
942         if (opt_gui) {
943                 initscr();
944                 cbreak();
945                 noecho();
946 /*              nonl(); */
947 /*              intrflush(stdscr, FALSE); */
948 /*              keypad(stdscr, TRUE); */
949
950                 logwin = newwin(0, 0, LINES/2, 0);
951                 if (logwin) {
952                         scrollok(logwin, TRUE);
953 /*              ul_log_redir(wclient_log_fnc, 0); */
954                 }
955         }
956 }
957
958 void end_gui()
959 {
960         if (opt_gui) {
961                 endwin();
962                 if (logwin) {
963 /*              ul_log_redir(NULL, 0); */
964                 }
965         }
966 }
967
968
969 #define addfield(title, format, ...)                                    \
970         move(y, x);                                                     \
971         x+=strlen(title)+1;                                             \
972         if (i == 0) addstr(title);                                      \
973         else {                                                          \
974                 snprintf(str, sizeof(str), format, __VA_ARGS__);        \
975                 addstr(str);                                            \
976         }
977
978 void print_status_gui(int seconds)
979 {
980         int i;
981         char str[200], s1[20];
982         int x = 0, y;
983         struct stream *s = NULL;
984         
985         for (i = 0; i <= nr_streams; i++) {
986                 if (i>0) s = &streams[i-1];
987                 y=i;
988                 x=0;
989                 addfield("Stream", "%d", i);
990                 addfield("Bandwidth", "%s", bandwidth_to_text(s1, s->bandwidth_bps));
991                 addfield("Packet size", "%d bytes", s->packet_size);
992                 addfield("Period   ", "%s", usec_to_text(s1, s->period_usec));
993                 addfield("AC   ", "%s", ac_to_text[s->ac]);
994                 addfield("Worst-case delay", "%s", usec_to_text(s1, s->wc_delay));
995                 addfield("Received responses", "%lld", s->received);
996         }
997         wnoutrefresh(stdscr);
998         doupdate();
999 }
1000
1001 void print_status_nogui(int seconds)
1002 {
1003         int ac;
1004         fprintf(stderr, "\r%3ds", seconds);
1005         for (ac = 0; ac < AC_NUM; ac++) {
1006                 int delta = receivers[ac].received - receivers[ac].last_received;
1007                 receivers[ac].last_received = receivers[ac].received;
1008                 fprintf(stderr, " %s %5d %4d/s", ac_to_text[ac], receivers[ac].received, delta);
1009         }
1010         fflush(stderr);
1011 }
1012
1013 #ifdef WITH_FWP
1014 int print_log_domain(ul_log_domain_t *domain, void *context)
1015 {
1016         printf("%s = %d\n", domain->name, domain->level);
1017         return 0;
1018 }
1019 #endif
1020 int main(int argc, char *argv[])
1021 {
1022         int i, rc, frames, seconds;
1023         pthread_attr_t attr;
1024         pthread_t thread;
1025         char opt;
1026
1027
1028         while ((opt = getopt(argc, argv, "B:b:C:c:Gg:I:j:l:o:qQ:s:T:")) != -1) {
1029                 switch (opt) {
1030                         case 'B':
1031                                 opt_def_bandwidth = atoi(optarg);
1032                                 break;
1033                         case 'b': {
1034                                 char *errpos;
1035                                 errpos = parse_bandwidths(optarg);
1036                                 if (errpos != NULL) {
1037                                         if (*errpos == '\0')
1038                                                 error(1, 0, "Bandwidth parse error - string to short");
1039                                         else
1040                                                 error(1, 0, "Bandwidth parse error at '%s'", errpos);
1041                                 }
1042                                 break;
1043                         }
1044                         case 'C':
1045                                 opt_comment = optarg;
1046                                 break;
1047                         case 'c':
1048                                 opt_count_sec = atoi(optarg);
1049                                 break;
1050                         case 'G':
1051                                 opt_gui = true;
1052                                 break;
1053                         case 'g':
1054                                 opt_granularity_usec = atoi(optarg);
1055                                 if (opt_granularity_usec < MIN_GRANULARITY) {
1056                                         error(1, 0, "Granulatiry too small (min %d)", MIN_GRANULARITY);
1057                                 }
1058                                 break;
1059                         case 'I':
1060                                 opt_interface = optarg;
1061                                 break;
1062                         case 'j':
1063                                 opt_jitter = atoi(optarg);
1064                                 break;
1065 #ifdef WITH_FWP
1066                         case 'l':
1067                                 if (*optarg == '?') {
1068                                         ul_logreg_for_each_domain(print_log_domain, NULL);
1069                                         exit(0);
1070                                 }
1071                                 {
1072                                         int ret;
1073                                         ret = ul_log_domain_arg2levels(optarg);
1074                                         if (ret) 
1075                                                 error(1, EINVAL, "Error parsing -l argument at char %d\n", ret);
1076                                 }
1077                                 break;
1078 #endif
1079                         case 'o':
1080                                 opt_output = optarg;
1081                                 break;
1082                         case 'Q':
1083                                 opt_send_buf_size = atoi(optarg);
1084                                 break;
1085                         case 'q':
1086                                 opt_wait_for_queue_is_full = true;
1087                                 break;
1088                         case 's':
1089                                 opt_packet_size = atoi(optarg);
1090                                 break;
1091                         case 'T':
1092                                 opt_def_period_msec = atoi(optarg);
1093                                 break;
1094                         default:
1095                                 fprintf(stderr, "Usage: %s [ options ] server_addr\n\n", argv[0]);
1096                                 fprintf(stderr, "Options:\n");
1097                                 fprintf(stderr, "    -B  default bandwidth for -b option [kbit]\n");
1098                                 fprintf(stderr, "    -b  bandwidth of streams (VO|VI|BE|BK)[:<kbit>][@<msec> or /<bytes>][,...]\n");
1099                                 fprintf(stderr, "    -C  comment (added to header)\n");
1100                                 fprintf(stderr, "    -c  count (number of seconds to run)\n");
1101                                 fprintf(stderr, "    -g  histogram granularity [usec]\n");
1102                                 fprintf(stderr, "    -G  show status in textual GUI\n");
1103                                 fprintf(stderr, "    -I  <interface> send packets from this interface\n");
1104 #ifdef WITH_FWP
1105                                 fprintf(stderr, "    -l  <loglevel> uLUt logging levels\n");
1106 #endif
1107                                 fprintf(stderr, "    -j  send jitter (0-100) [%%]\n");
1108                                 fprintf(stderr, "    -o  output filename (.dat will be appended)\n");
1109                                 fprintf(stderr, "    -q  gather statistics only after some queue becomes full\n");
1110                                 fprintf(stderr, "    -Q  <bytes> set size for socket send buffers\n");
1111                                 fprintf(stderr, "    -s  size of data payload in packets [bytes] (default: %d)\n", opt_packet_size);
1112                                 fprintf(stderr, "    -T  default period for -b option [msec]\n");
1113                                 exit(1);
1114                 }
1115         }
1116         if (opt_packet_size && opt_def_period_msec) {
1117                 error(1, 0, "Error: Nonzero -T and -s can't be used together!");
1118         }
1119
1120         if (optind < argc) {
1121                 server_addr = argv[optind];
1122         } else {
1123                 error(1, 0, "Expected server address argument");
1124         }
1125
1126         if (nr_streams == 0)
1127                 parse_bandwidths("BE");
1128                 
1129         pthread_attr_init(&attr);
1130
1131         snprintf(logfname, sizeof(logfname), "%s.dat", opt_output);
1132
1133         if ((logfd = fopen(logfname,"w+")) == NULL) {
1134                 error(1, errno ,"Can not open %s", logfname);
1135         }
1136         if (signal(SIGTERM, stopper) == SIG_ERR) {
1137                 error(1, errno, "Error in signal registration");
1138         }
1139                 
1140         if (signal(SIGINT, stopper) == SIG_ERR) {
1141                 error(1, errno, "Signal handler registration error");
1142         }
1143
1144         struct sigaction sa;
1145         sa.sa_handler = empty_handler;
1146         sa.sa_flags = 0;        /* don't restart syscalls */
1147
1148         if (sigaction(SIGUSR1, &sa, NULL) < 0) {
1149                 error(1, errno, "sigaction error");
1150         }
1151
1152         sem_init(&sem_thread_finished, 0, 0);
1153
1154         reset_statistics();
1155
1156 #ifdef WITH_FWP
1157         //ul_log_domain_arg2levels("6");
1158         rc = frsh_init();
1159         if (rc != 0) {
1160                 error(1, errno, "FWP initialization failed");
1161         }
1162 #else
1163         intptr_t ac;
1164         /* create four receivers each per AC */
1165         for (ac = AC_NUM - 1; ac >= 0; ac--) {
1166                 ac_sockfd[ac] = create_ac_socket(ac);
1167                 if (ac_sockfd[ac] < 0) {
1168                         return 1;
1169                 }
1170                 rc = pthread_create(&receivers[ac].thread, &attr, receiver, (void*) ac);
1171                 if (rc) {
1172                         error(1, rc, "Error while creating receiver");
1173                 }
1174                 receivers[ac].valid = true;
1175         }               
1176 #endif
1177
1178                         
1179         if (opt_interface) {
1180                 struct ifreq ifr;
1181
1182                 memset(&ifr, 0, sizeof(ifr));
1183                 strncpy(ifr.ifr_name, opt_interface, IFNAMSIZ-1);
1184                 if (ioctl(ac_sockfd[AC_VO], SIOCGIFINDEX, &ifr) < 0) {
1185                         error(1, 0, "unknown iface %s", opt_interface);
1186                 }
1187                 cmsg.ipi.ipi_ifindex = ifr.ifr_ifindex;
1188                 cmsg_len = sizeof(cmsg);
1189         }
1190         /* create sendpoints */
1191         for (i = 0; i < nr_streams; i++) {
1192                 struct stream *s = &streams[i];
1193                 pthread_mutex_init(&s->mutex, NULL);
1194                 calc_stream_params(s);
1195                 rc = pthread_create(&thread, &attr, sender, (void*) s);
1196                 if (rc) error(1, rc, "Error while creating sender");
1197         }
1198
1199         if (some_contract_not_accepted) {
1200                 stopper();
1201         } else {
1202                 init_gui();
1203
1204                 seconds = 1;
1205                 frames=0;
1206                 while (!exit_flag) {
1207                         if (opt_gui) {
1208                                 usleep(40000);
1209                                 frames++;
1210                                 if (frames>=25) {
1211                                         seconds++;
1212                                         frames = 0;
1213                                 }
1214                                 print_status_gui(seconds);
1215                         } else {
1216                                 sleep(1);
1217                                 seconds++;
1218                                 print_status_nogui(seconds);
1219                         }
1220
1221                         if (seconds == opt_count_sec)
1222                                 stopper();
1223                 }
1224         }
1225
1226         end_gui();
1227
1228         fprintf(stderr, "\nWaiting for threads to finish\n");
1229         wait_for_all_threads_to_finish();
1230
1231 #ifdef WITH_FWP
1232         for (i=0; i < nr_streams; i++) {
1233                 if (streams[i].vres)
1234                         frsh_contract_cancel(streams[i].vres);
1235                 if (streams[i].vres_rcv)
1236                         frsh_contract_cancel(streams[i].vres_rcv);
1237         }
1238 #endif
1239
1240         struct timespec ts;
1241         uint64_t end_timestamp, measure_length;
1242         clock_gettime(CLOCK_REALTIME,&ts);
1243         end_timestamp = ts.tv_sec*1000000000LL+ts.tv_nsec;
1244         measure_length = end_timestamp - reset_timestamp;
1245
1246         save_results(argc, argv, measure_length/1000);
1247
1248         return 0;
1249 }