Пример #1
0
int main(int argc, char **argv) {

	BIO *acc, *client;
	THREAD_TYPE tid;
	
	init_OpenSSL();
	
	acc = BIO_new_accept(SERV_PORT);
	if(!acc) {
		int_error("Error creating server socket.\n");
	}

	if(BIO_do_accept(acc) <= 0) {
		int_error("Error binding server socket.\n");
	}

	for(;;) {

		if(BIO_do_accept(acc) <= 0) {
			int_error("Error accepting connection from client.\n");
		}
		
		client = BIO_pop(acc);
		THREAD_CREATE(tid, server_thread, client);
	}

	BIO_free(acc);
	return 0;
}
Пример #2
0
int main(int argc, char *argv[])
{
	BIO *acc, *client;
	pthread_t pid;

	init_OpenSSL();
	acc = BIO_new_accept(PORT);
	if(!acc)
		int_error("Error creating server socket");

	if(BIO_do_accept(acc)<=0)
		int_error("Error binding server socket");

	for(;;)
	{
		if(BIO_do_accept(acc)<=0)
			int_error("Error accepting connection");

		client=BIO_pop(acc);
		pthread_create(&pid, NULL, server_thread, client);
	}

	BIO_free(acc);
	return 0;
}
Пример #3
0
//=========================================
// Constructor
//-----------------------------------------
SSLClient::SSLClient ( QObject* parent ) : SSLCommon ( parent ) {
	BIO *sbio = NULL;
	printf ("Initialize openssl\n");
	init_OpenSSL ();
	seed_prng ();
	printf ("Setup client context\n");
	setupClientCTX ();
	printf ("Connecting TCP socket\n");
	connectTCP ();

	printf ("Creating new SSL object\n");
	ssl = SSL_new (ctx);
	printf ("Creating new SSL BIO socket: %d\n",mSocket);
	sbio= BIO_new_socket (mSocket,BIO_NOCLOSE);
	printf ("Setup SSL BIO socket\n");
	SSL_set_bio (ssl,sbio,sbio);
	printf ("Connecting SSL socket\n");
	if (SSL_connect(ssl) <=0) {
		qerror ("Error creating connection BIO");
	}
	int ofcmode = fcntl (mSocket,F_GETFL,0);
	if (fcntl (mSocket,F_SETFL,ofcmode | O_NDELAY)) {
		qerror ("Couldn't make socket nonblocking");
	}
	FD_ZERO (&readFDs);
	printf ("SSL Connection created\n");
}
Пример #4
0
int main(int argc, char *argv[])
{

	BIO *server, *client;
	SSL *ssl;
	SSL_CTX *ctx;
	pthread_t tid;

	init_OpenSSL();

	/*
	 *	It creates a new accept BIO with port host_port
	 */
	server = BIO_new_accept("9104");

	if (!server)
		error("Error creating server socket");

	/*
	 *	BIO_do_accept() serves two functions. When it is first called, after the accept
	 *	BIO has been setup, it will attempt to create the accept socket and bind an 
	 *	address to it. Second and subsequent calls to BIO_do_accept() will await an
	 *	incoming connection,or request a retry in non blocking mode
	 */
	if (BIO_do_accept(server) <= 0)
		error("Setup BIO in Accepting Mode\n");
	for (;;)
	{
		if (BIO_do_accept(server) <= 0)
			error("Error Accepting Connection\n");
		/*
		 * When a connection is established a new socket BIO is created for the 
		 * connection and appended to the chain.
		 * BIO_pop removes the BIO b from a chain and returns the next BIO in the
		 * chain.
		 */
		client = BIO_pop(server);
		/*
		 *Now client here is containing a BIO for the recently established connection
		 *and server will now be a single BIO again which can be used to await further
		 *incoming connections
		 */
		pthread_create(&tid, NULL, (void *)server_thread, client);
	}
	/*
	 *	Close the connection
	 */
	BIO_free(server);
	return 0;
}
Пример #5
0
int main(int argc, char *argv[])
{
     init_OpenSSL(  );
     seed_prng(  );

     if(argc < 4) 
     {
	  fprintf(stderr, "usage: ./client start-session host port\n");
	  exit(1);
     }
     if(0 == strcmp(argv[1], "start-session"))
	  start_session(argv[2], argv[3]);

     return 0;
}
Пример #6
0
int main_ssl(int argc, char **argv)
{
	BIO *conn;
	SSL *ssl;
	SSL_CTX *ctx;
	long err;

	init_OpenSSL();
	seed_prng();

	ctx = setup_client_ctx();

	fprintf(stderr, "SERVER= %s:%s\n", SERVER, PORT);
	conn = BIO_new_connect(SERVER ":" PORT);
	if (!conn)
		int_error("Error creating connection BIO");

	if (BIO_do_connect(conn) <= 0)
		int_error("Error connecting to remote machine");

	ssl = SSL_new(ctx);
	SSL_set_bio(ssl, conn, conn);
	if (SSL_connect(ssl) <= 0)
		int_error("Error connecting SSL object");
	if ((err = post_connection_check(ssl, SERVER)) != X509_V_OK) {
		fprintf(stderr, "-Error: peer certificate: %s\n",
			X509_verify_cert_error_string(err));
		int_error("Error checking SSL object after connection");
	}
	fprintf(stderr, "SSL Connection opened\n");
	if (do_client_loop(ssl))
		SSL_shutdown(ssl);
	else
		SSL_clear(ssl);
	fprintf(stderr, "SSL Connection closed\n");

	SSL_free(ssl);
	SSL_CTX_free(ctx);
	return 0;
}
Пример #7
0
SSL *
connect_client (int port, const char *addr, int addr_family)
{
  int sd;
  int err;
  int result = -1;
  /* SSL preliminaries */
  SSL_CTX* ctx;
  SSL*     ssl;
  init_OpenSSL ();			  
  seed_prng ();
  
  sd = crv_client_create(port, addr, addr_family);
  /* We keep the certificate and key with the context. */
  ctx = setup_client_ctx ();

  /* TCP connection is ready. Do server side SSL. */
  ssl = SSL_new (ctx);
  if ((ssl)==NULL) {
	fprintf ( stderr, "%s\n", "Create new ssl failed");
  }
		
  /* connect the SSL object with a file descriptor */
  err = SSL_set_fd (ssl, sd);
  if ((err)==0) {
	fprintf ( stderr, "%s\n", "Put SSL on socket failed \n");
	close(sd);
  }

  result = SSL_connect (ssl);
  if (result == 0)	{
	SSL_get_error(ssl, result);
	return (NULL);
  } else
  if (result == -1) {
	fprintf( stderr, "%s\n", "client_(): Err[003] SSL_connect() failed");
	return (NULL);
  }
  return (ssl);
}
Пример #8
0
int main(int argc, char * argv[]) {
    BIO * acc, * client;
    THREAD_TYPE tid;
    SSL * ssl;
    SSL_CTX * ctx;

    init_OpenSSL();
    seed_prng();

    ctx = setup_server_ctx();
    
    acc = BIO_new_accept(PORT);
    if (!acc)
        int_error("Error creating server socket");
    if (BIO_do_accept(acc) <= 0)
        int_error("Error binding server socket");
    // BIO_do_accept() will block and wait for a remote connection.
    while (1) {
        if (BIO_do_accept(acc) <= 0)
            int_error("Error accepting connection");
        // get the client BIO
        client = BIO_pop(acc);
        if (!(ssl = SSL_new(ctx)))
            int_error("Error creating SSL context");
        SSL_set_accept_state(ssl);
        SSL_set_bio(ssl, client, client);
        // create a new thread to handle the new connection,
        // The thread will call do_server_loop with the client BIO.
        // THREAD_CREATE(tid, entry, arg);
        // tid is the id of the new thread.
        // server_thread is the function defined above, which will call
        // do_server_loop() with the client BIO.
        THREAD_CREATE(tid, server_thread, ssl);
    }
    SSL_CTX_free(ctx);
    BIO_free(acc);
    return 0;
}
Пример #9
0
int main(int argc, char *argv[])
{
    BIO     *acc, *client;
    SSL     *ssl;
    SSL_CTX *ctx;
    THREAD_TYPE tid;

    init_OpenSSL(  );
    seed_prng();

 
    ctx = setup_server_ctx(  );
 
    acc = BIO_new_accept(PORT);
    if (!acc)
        int_error("Error creating server socket");
 
    if (BIO_do_accept(acc) <= 0)
        int_error("Error binding server socket");
 
    while(1)
    {
        if (BIO_do_accept(acc) <= 0)
            int_error("Error accepting connection");
 
        client = BIO_pop(acc);
        if (!(ssl = SSL_new(ctx)))
        int_error("Error creating SSL context");
        SSL_set_accept_state(ssl);
        SSL_set_bio(ssl, client, client);
        THREAD_CREATE(tid, (void *)server_thread, ssl);
    }
 
    SSL_CTX_free(ctx);
    BIO_free(acc);
    return 0;
}
Пример #10
0
int main(int argc, char *argv[])
{
	BIO *acc, *client;
	SSL *ssl;
	SSL_CTX *ctx;
	THREAD_TYPE tid;
	void* (*func)(void*) = &server_thread;


	std::cout << "before init\n";
	init_OpenSSL();
	//seed_prng();
	std::cout << "after init\n";

	ctx = setup_server_ctx();

	acc = BIO_new_accept(PORT);
	if(!acc)
		int_error("Error creating socket");
	if(BIO_do_accept(acc) <= 0)
		int_error("Error binding socket");

	for(;;)
	{
		if(BIO_do_accept(acc) <= 0)
			int_error("Error accepting connection");

		client = BIO_pop(acc);
		if(!(ssl = SSL_new(ctx)))
			int_error("Error creating ssl object");
		SSL_set_bio(ssl,client,client);
		THREAD_CREATE(tid,func,ssl);
	}
	BIO_free(acc);
	SSL_CTX_free(ctx);
	return 0;
}
Пример #11
0
int main(int argc, char *argv[])
{
    int lsfd;
    int ret, n, i;
    struct epoll_event event;
    struct epoll_event *events = NULL;
    connection_t *conn;
    connections_head_t *head = NULL;

    if (argc != 2) {
        fprintf(stdout, "Usage: %s [port]\n", argv[0]);
        exit(EXIT_FAILURE);
    }

    /* init connections cache */
    head = init_connections(MAX_CONNECTIONS);
    if (NULL == head) {
        ERROR_MSG("init_connections\n");
        goto error;
    }

    /* init SSL data */
    ret = init_OpenSSL();
    if (ret != 0) {
        ERROR_MSG("init_OpenSSL\n");
        goto error;
    }

    head->ctx = init_ssl_ctx(SRV_CERTFILE, SRV_PRIKEY, SRV_CAFILE);
    if (NULL == head->ctx) {
        ERROR_MSG("init_ssl_ctx error\n");
        goto error;
    }

    /* init epoll's data */
    head->epfd = epoll_create(MAX_CONNECTIONS);
    if (-1 == head->epfd) {
        ERROR_MSG("epoll_create\n");
        goto error;
    }

    events = calloc(MAX_EVENTS, sizeof(struct epoll_event));
    if (NULL == events) {
        ERROR_MSG("calloc\n");
        goto error;
    }

    /* listen's data */
    lsfd = start_listen(argv[1]);
    if (lsfd < 0) {
        ERROR_MSG("start_listen\n");
        goto error;
    }

    /* add the lsfd to events */
    conn = get_connection(head);
    if (NULL == conn) {
        ERROR_MSG("get_connection\n");
        goto error;
    }

    conn->fd = lsfd;
    conn->handler = accept_handler;

    event.data.ptr = conn;
    event.events = EPOLLIN | EPOLLET;
    ret = epoll_ctl(head->epfd, EPOLL_CTL_ADD, lsfd, &event);
    if (-1 == ret) {
        ERROR_MSG("epoll_ctl\n");
        goto error;
    }

    /* The event loop */
    while (1)
    {
        n = epoll_wait(head->epfd, events, MAX_EVENTS, -1);
        for (i = 0; i < n; ++i)
        {
            conn = events[i].data.ptr;

            if ((events[i].events & EPOLLERR)
                || (events[i].events & EPOLLHUP)
                || !(events[i].events & EPOLLIN))
            {
                /* it will delete the event from events at the same time 
                 * due to invoked close
                 */
                free_connection(head, conn);
            } else {
                if (conn->handler) {
                    conn->handler(head, conn);
                }
            }
        }
    }

error:
    if (events) free(events);
    destroy_connections(head);
    return EXIT_SUCCESS;
}
Пример #12
0
static void 
receive_sync_file (void *arg)
{
  int sd;
  int code = 0;
  int port;
  int i;
  long lval;
  char command[SIZE];
  char *sync_arg = arg;
  char buf[4096];
  char *ep = NULL;
  char host_port[SIZE];
  char **c = NULL;
  FILE *fd = NULL;
  SSL_CTX* ctx;
  SSL*     ssl;


  c = crv_cut (sync_arg, ":");
  lval = strtol(c[1], &ep, 10);
  if (c[0][0] == '\0' || *ep != '\0') {
    fprintf(stderr, "%s\n", "Sync(): Err[002] Check port on serveur_liste");
    return ;
  }
  if (lval > 65535 || lval < 0) {
    fprintf(stderr, "%s\n", "Sync(): Err[003] Check port on serveur_liste");
    return ;
  }
  port = lval;

  crv_strncpy (host_port, "./listing/", sizeof(host_port));
  crv_strncat (host_port, c[0], sizeof(host_port));	/* put server name in host_port */
  crv_strncat (host_port, ".db", sizeof(host_port));	/* add : behind server name */
  fprintf (stdout, "%s", "Listing reception on ");
  fflush(stdout);

#ifndef WIN32
      couleur ("33;31");
#else
      couleur (12, 0);
#endif
      fprintf (stdout, "'%s'", c[0]);
	  fflush(stdout);
#ifndef WIN32
      couleur ("0");
#else
      couleur (15, 0);
#endif
      fprintf (stdout, "%s\n", " is running ...");

  /* SSL preliminaries */
  init_OpenSSL ();			  
  seed_prng ();
  
  sd = crv_client_create(port, c[0], options.address_family);
	if (sd == -1) {
		close(sd);
		pthread_exit(NULL);
	}

  /* We keep the certificate and key with the context. */
  ctx = setup_client_ctx ();

  /* TCP connection is ready. Do server side SSL. */
  ssl = SSL_new (ctx);
  if ((ssl)==NULL) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "receive_sync_file() Err[001] Create new ssl failed");
	pthread_exit(NULL);
  }
		
  /* connect the SSL object with a file descriptor */
  code = SSL_set_fd (ssl, sd);
  if ( code == 0) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "receive_sync_file() Err[002] Put SSL on socket failed \n");
	pthread_exit(NULL);
  }

  code = SSL_connect (ssl);
  if (code == 0)	{
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf( stderr, "%s\n", "receive_sync_file(): Err[003] SSL_connect() failed");
	pthread_exit (NULL);
  } else
  if (code == -1) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf( stderr, "%s\n", "receive_sync_file(): Err[004] SSL_connect() failed");
	pthread_exit (NULL);
  }
 
  
  #ifndef WIN32
  /* 
  code = post_connection_check (ssl, c[0]);
  if (code != X509_V_OK)
  {
	fprintf (stderr, "-Error: peer certificate: %s\n", X509_verify_cert_error_string (code));
	  close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf( stderr, "%s\n", "receive_sync_file(): Err[004'] post_connection_check() failed");
	  pthread_exit (NULL);
  }
  */
  #endif
  for (i = 0; c[i]; i++)
	crv_free(c[i]); 

  fd = crv_fopen(host_port, "w");
  if (fd == NULL) {
	fclose(fd); close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "receive_sync_file(): Err[005] crv_fopen() failed");
	pthread_exit (NULL);
  }
  
  /* Build command -> SYNC#version */
  (void)crv_strncpy(command, "SYNC#", sizeof(command));
  (void)crv_strncat(command, CREUVUX_VERSION, sizeof(command));
  
  code = SSL_write (ssl, command, (int)strlen(command));
  if ( code <= 0) {
	fclose(fd); close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "receive_sync_file(): Err[006] SSL_write() failed.");
	pthread_exit(NULL);
  }

  code = SSL_read (ssl, buf, sizeof(buf) - 1);
  buf[code] = '\0';
  if(!strncmp (buf, "SYNC_ACK", strlen("SYNC_ACK")))
  {
	for (;;)
	{
		code = SSL_read (ssl, buf, sizeof (buf));
		switch (SSL_get_error (ssl, code))
        {
		  case SSL_ERROR_NONE:
		  case SSL_ERROR_ZERO_RETURN:
		  case SSL_ERROR_WANT_READ:
		  case SSL_ERROR_WANT_WRITE:
			break;
		  default:
			fclose(fd); close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
			fprintf(stderr, "0)Can't receive LISTING\n");
			pthread_exit (NULL);
		}

	  if (!strncmp (buf, "SYNC_END", strlen("SYNC_END"))) {
	    break;
	  }
	  code = fwrite (&buf, (size_t) code, 1, fd);
	  if (code <= 0) {
		fclose(fd); close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	    fprintf(stderr, "1)Can't write LISTING file\n");
		pthread_exit (NULL);
	  }
	}
  }

  fclose(fd);
  close (sd);
  SSL_free (ssl);
  SSL_CTX_free (ctx);

  pthread_exit (NULL);
}
Пример #13
0
int Gtk_Put(const char *filename, const char *file_descrip, const char *server, const char *Sha1)
{
  SSL_CTX* ctx = NULL;
  SSL*     ssl = NULL;
  int sd = -1;
  int port = -1;
  char *ep;
  long lval;
  int code = -1;
  off_t size = 0;
  char command[SIZE];
  char buf[SIZE];
  char size_c [SIZE];
  char *dscr = NULL;
	char *sha1 = NULL;
	char **a = NULL;
	int descr_fd = 0;
  errno = 0;

  /* ETA */
  struct timeval tv1, tv2;
  int sec1;
  
  
  init_OpenSSL ();			  
  seed_prng ();
	
  size = crv_du (filename);
  if (size == -1) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf( stderr, "%s\n", "Put(): Err[007] crv_du() can't get size");
		return(-1);
  }
  snprintf(size_c, sizeof(size), "%lld", size);

  a = crv_cut(server, ":");
  
	lval = strtol(a[1], &ep, 10);
  if (a[1][0] == '\0' || *ep != '\0') {
		fprintf(stderr, "%s\n", "Put(): Err[001] port is not a number");
		return (-1);
  }

  if ((errno == ERANGE && (lval == LONG_MAX
	  || lval == LONG_MIN)) ||
	  (lval > 65535 || lval < 0))
  {
		fprintf(stderr, "%s\n", "Put(): Err[002] port is out of range");
		return (-1);
  }
  port = lval;
  sd = crv_client_create( port, a[0], options.address_family);
  
  /* We keep the certificate and key with the context. */
  ctx = setup_client_ctx ();

  /* TCP connection is ready. Do server side SSL. */
  ssl = SSL_new (ctx);
  if ((ssl)==NULL) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "Put() Err[003] Create new ssl failed");
		return(-1);
  }

  /* connect the SSL object with a file descriptor */
  code = SSL_set_fd (ssl, sd);
  if ( code == 0) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "Put() Err[004] Put SSL on socket failed \n");
		return(-1);
  }

  code = SSL_connect (ssl);
  if (code == 0)	{
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf( stderr, "%s\n", "Put(): Err[005] SSL_connect() failed");
		return(-1);
  } else
  if (code == -1) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf( stderr, "%s\n", "Put(): Err[006] SSL_connect() failed");
		return(-1);
  }

  /* Build command -> GET#version#sha1#begin#end */
  (void)crv_strncpy(command, "PUT#", sizeof(command));
  (void)crv_strncat(command, CREUVUX_VERSION, sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, Sha1, sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, "0", sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, size_c, sizeof(command));
  
  /* Time initialisation */
  gettimeofday (&tv1, NULL);

  code = SSL_write (ssl, command, (int)strlen(command));
  if ( code <= 0) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "receive_get_file(): Err[011] SSL_write() failed.");
	return(-1);
  }

  code = SSL_read (ssl, buf, sizeof(buf) - 1);
  buf[code] = '\0';

  if(!crv_strncmp (buf, "PUT_ACK"))
  {
		fprintf(stdout, "\n\n");
		code = SSL_sendfile(ssl, Sha1, filename, (off_t)0, size);	
		if (code == -1) {
			close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
			fprintf(stderr, "%s\n", "Put() Err[012] SSL_sendfile() failed");
			return(-1);
		}
  }
  
  code = SSL_write (ssl, "PUT_END", (int)strlen("PUT_END"));
  if ( code <= 0) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "receive_get_file(): Err[013] SSL_write() failed.");
		return(-1);
  }


  gettimeofday (&tv2, NULL);
  /* compute difference */
  sec1 = tv2.tv_sec - tv1.tv_sec;
  int min;
  float average;
  average = ((float) size / (float) sec1) / 1024;
  min = sec1 / 60;
  sec1 = sec1 - min * 60;
  fprintf (stdout,
	     "\n\nFile download in %d min  %d sec \nSpeed average -> %.f KBps\n\n",
	     min, sec1, average);

  close(sd); SSL_free (ssl); SSL_CTX_free (ctx);


  /* Send file's decription */
  init_OpenSSL ();			  
  seed_prng ();
  sd = crv_client_create( port, a[0], options.address_family);
  
  /* We keep the certificate and key with the context. */
  ctx = setup_client_ctx ();

  /* TCP connection is ready. Do server side SSL. */
  ssl = SSL_new (ctx);
  if ((ssl)==NULL) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "Put() Err[003] Create new ssl failed");
	return(-1);
  }

  /* connect the SSL object with a file descriptor */
  code = SSL_set_fd (ssl, sd);
  if ( code == 0) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "Put() Err[004] Put SSL on socket failed \n");
	return(-1);
  }

  code = SSL_connect (ssl);
  if (code == 0)	{
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf( stderr, "%s\n", "Put(): Err[005] SSL_connect() failed");
	return(-1);
  } else
  if (code == -1) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf( stderr, "%s\n", "Put(): Err[006] SSL_connect() failed");
	return(-1);
  }

	fprintf(stderr, "File: '%s'\n", file_descrip);
	size = -1;
	size = crv_du (file_descrip);
	fprintf(stderr, "Size: '%lld'\n", size);
  if (size == -1) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf( stderr, "%s\n", "Put(): Err[007] crv_du() can't get size");
		return(-1);
  }
  memset(size_c, 0, sizeof(size_c));
  snprintf(size_c, sizeof(size), "%lld", size);

	sha1 = crv_sha1(file_descrip);
  
  /* Build command -> GET#version#sha1#begin#end */
  (void)crv_strncpy(command, "COMMENT#", sizeof(command));
  (void)crv_strncat(command, CREUVUX_VERSION, sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, sha1, sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, "0", sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, size_c, sizeof(command));
	fprintf(stderr, "CMD:'%s'\n", command);
  
  code = SSL_write (ssl, command, (int)strlen(command));
  if ( code <= 0) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "receive_get_file(): Err[011] SSL_write() failed.");
	return(-1);
  }

  code = SSL_read (ssl, buf, sizeof(buf) - 1);
  buf[code] = '\0';

  if(!strncmp (buf, "PUT_ACK", strlen("PUT_ACK")))
  {
		code = SSL_sendfile(ssl, sha1, file_descrip, (off_t)0, size);	
		if (code == -1) {
			close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
			fprintf(stderr, "%s\n", "Put() Err[012] SSL_sendfile() failed");
			return(-1);
		}
  }
  
  code = SSL_write (ssl, "PUT_END", (int)strlen("PUT_END"));
  if ( code <= 0) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "receive_get_file(): Err[013] SSL_write() failed.");
		return(-1);
  }


	fprintf(stdout, "%s", "Information about file is uploaded\n"); 

	code = unlink((const char *)file_descrip);
  if (code == -1) {
		fprintf(stderr, "%s%s\n", 
			"Put(): Err[010] unlink() failed with error -> ",
			strerror(errno));
		return (-1);
  }

  close(sd); SSL_free (ssl); SSL_CTX_free (ctx);crv_free(sha1);
  return (0);

}
Пример #14
0
int Msg(const char *id)
{
	FILE *fd = NULL;
	char buf[SIZE];
	char command[SIZE];
	int result = -1;
	off_t size;
	char size_c[SIZE];
	SSL_CTX* ctx = NULL;
  SSL*     ssl = NULL;
  int sd = -1;
	
	errno = 0;
	sha1 = NULL;  /* Sha1 for wanted ID */
	server = NULL;/* server for wanted ID */
	port = 0;			/* port for Wanted ID*/


	/* Get info about file */
	get_server_info(id);
	get_sha1(id);



	fd = crv_fopen(sha1, "w");
  if (fd == NULL) {
		fprintf( stderr, "%s\n", "Msg(): Err[001] crv_fopen() failed");
		return (-1);
	}
	fprintf(fd, "<?xml version=\"1.0\" encoding=\"ISO-8859-1\"?>\n");
	fprintf(fd, "<comment><![CDATA[");
	fprintf(stdout, "%s", "\nEntrez votre reponse(':wq' pour quitter)\n");
	fprintf(stdout, "%s", ">");
	while (fgets(buf, sizeof(buf), stdin) != NULL) {
		buf[strcspn(buf, "\n")] = '\0';
		if (!crv_strncmp(buf, ":wq"))
			break;
		fprintf(fd, "%s\n", buf);
		fprintf(stdout, "%s", ">");
	}
	fprintf(fd, "]]></comment>\n");
	fclose(fd);
	

	/*
	 * Build command -> GET#version#sha1#begin#end 
	 */
	size = crv_du (sha1);
  if (size == -1) {
		fprintf( stderr, "%s\n", "Put(): Err[002] crv_du() can't get size");
		return(-1);
  }
  snprintf(size_c, sizeof(size), "%lld", size);

  (void)crv_strncpy(command, "MSG_REPLY#", sizeof(command));
  (void)crv_strncat(command, CREUVUX_VERSION, sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, sha1, sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, "0", sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, size_c, sizeof(command));
	/*
	 * Connection.
	 */
	init_OpenSSL ();			  
  seed_prng ();
	sd = crv_client_create( port, server, options.address_family);

  /* We keep the certificate and key with the context. */
  ctx = setup_client_ctx ();

  /* TCP connection is ready. Do server side SSL. */
  ssl = SSL_new (ctx);
  if ((ssl)==NULL) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "Msg() Err[003] Create new ssl failed");
		return(-1);
  }

  /* connect the SSL object with a file descriptor */
  result = SSL_set_fd (ssl, sd);
  if ( result == 0) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "Msg() Err[004] Put SSL on socket failed \n");
		return(-1);
  }

  result = SSL_connect (ssl);
  if (result == 0)	{
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf( stderr, "%s\n", "Msg(): Err[005] SSL_connect() failed");
		return(-1);
  } else
  if (result == -1) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf( stderr, "%s\n", "Msg(): Err[006] SSL_connect() failed");
		return(-1);
  }

	result = SSL_write (ssl, command, (int)strlen(command));
  if ( result <= 0) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "receive_get_file(): Err[011] SSL_write() failed.");
		return(-1);
  }

  result = SSL_read (ssl, buf, sizeof(buf) - 1);
  buf[result] = '\0';

  if(!strncmp (buf, "PUT_ACK", strlen("PUT_ACK")))
  {
		fprintf(stdout, "\n\n");
		result = SSL_sendfile(ssl, NULL, sha1, (off_t)0, size);	
		if (result == -1) {
			close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
			fprintf(stderr, "%s\n", "Put() Err[012] SSL_sendfile() failed");
			return(-1);
		}
  }
  
  result = SSL_write (ssl, "PUT_END", (int)strlen("PUT_END"));
  if ( result <= 0) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "receive_get_file(): Err[013] SSL_write() failed.");
		return(-1);
  }

	result = unlink((const char *)sha1);
  if (result == -1) {
		fprintf(stderr, "%s%s\n", 
					"Msg(): Err[007] unlink() failed with error -> ",
					strerror(errno));
		return (-1);
  }
	
	return (0);
}
Пример #15
0
static int Put(sqlite3 *db, const char *filename, const char *server, const char *grp, const char *username, const char *genre)
{
  SSL_CTX* ctx = NULL;
  SSL*     ssl = NULL;
	FILE *fd = NULL;
  int sd = -1;
  int port = -1;
  char *ep;
  long lval;
  int code = -1;
  off_t size = 0;
  char command[SIZE];
  char buf[SIZE];
  char size_c [SIZE];
  char *dscr = NULL;
  char *sha1 = NULL;
  char **a = NULL;
  char *blob = NULL;
  char dbname[SIZE];
  char msg[4096];
  int descr_fd = 0;
  errno = 0;

  /* ETA */
  struct timeval tv1, tv2;
  int sec1;
 
	/* On ouvre le fichier pour voir si il existe */
  if ((fd = fopen (filename, "rb")) == NULL)
    {
      fprintf (stderr, "Le fichier '%s' peut pas etre ouvert\n", filename);
      fprintf (stderr, "Verifiez les droits et son emplacements\n");
      exit (EXIT_FAILURE);
    }
	fclose (fd);
	
	char *real_name = NULL;
	real_name = basename((const char *)filename);
	if (real_name == NULL)
		return (NULL);
  
  size = crv_du (filename);
  if (size == -1) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf( stderr, "%s\n", "Put(): Err[007] crv_du() can't get size");
		return(-1);
  }
  snprintf(size_c, sizeof(size), "%lld", size);

	fprintf(stdout, "%s\n", "Determination de la signature numerique du fichier en cours ...");
	sha1 = crv_sha1(filename);

  /* Create info's file */
  (void)crv_strncpy (dbname, sha1, sizeof(dbname));
  (void)crv_strncat (dbname, ".db",  sizeof (dbname));

	if (many_files != 1) {
		int rep;
		fprintf (stdout, "Voulez-vous mettre des informations ? (o/n) :"); fflush(stdout);
		rep = fgetc (stdin);
		rep = toupper (rep);
		if (rep == 'O')
		{
			(void)crv_strncpy(msg, "", sizeof(msg));
			fprintf(stdout, "%s", "\nEntrez les informations du fichier (':wq' pour quitter)\n");
			fprintf(stdout, "%s", ">");
			memset(buf, 0, sizeof(buf));
			while (fgets(buf, sizeof(buf), stdin) != NULL) {
				if (!crv_strncmp(buf, ":wq\n"))
					break;
				(void)crv_strncat(msg, buf, sizeof(msg));
				fprintf(stdout, "%s", ">");
			}
		}
	}

	{
		int rep1;
		rep1 = -1;
		fprintf (stdout, "Voulez-vous mettre un Thumbnail ? (o/n) :"); fflush(stdout);
		rep1 = fgetc (stdin);
		rep1 = toupper (rep1);
		if (rep1 == 'O')
		{
			fprintf(stdout, "%s", "\nEntrez le chemin du fichier ('Enter' pour valider)\n");
			fprintf(stdout, "%s", ">");
			memset(buf, 0, sizeof(buf));
			while (fgets(buf, sizeof(buf), stdin) != NULL) {
				buf[strcspn(buf, "\n")] = '\0';
				if (strlen(buf) > 1)
					break;
			}
			blob = crv_strdup(buf);
		}

	}

	size = crv_du (filename);
  if (size == -1) {
		fprintf( stderr, "%s\n", "Put(): Err[007] crv_du() can't get size");
		return(-1);
  }
  memset(size_c, 0, sizeof(size_c));
  snprintf(size_c, sizeof(size_c), "%lld", size);
	/*
	fprintf (stdout, "DEBUG: DB Name='%s'\n", dbname);
	fprintf (stdout, "DEBUG: Sha1='%s'\n", sha1); 
  	fprintf (stdout, "DEBUG: Titre='%s'\n", real_name);
	fprintf (stdout, "DEBUG: Size='%s'\n", size_c);
	fprintf (stdout, "DEBUG: Pseudo='%s'\n", username);
	fprintf (stdout, "DEBUG: Message=\n`-> %s\n", msg);
	*/
	/*
	 * Database for file creation
	 */
	char *zErrMsg = 0;
	int rc = -1;
	char *req = NULL;
	sqlite3 *db_put;
	/* Open MAIN Database */
	rc = sqlite3_open( dbname, &db_put);
	if( rc ){
		fprintf(stderr, "Can't open database: %s", sqlite3_errmsg(db_put));
		sqlite3_close(db_put);
		return (-1);
	}
	
	/* Create Tables */
	if (create_db (db_put) == -1) {
		fprintf(stderr, "%s\n", "Put(): Database creation Failed");
		return (-1);
	}

	/* Fill Files tables*/
	/* CREATE TABLE Files (Sha1 TEXT NOT NULL, Name TEXT NOT NULL, Size NUMERIC NOT NULL); */
	req = sqlite3_mprintf("INSERT into Files (Sha1, Name, Size) values ('%q', '%q', '%q')", sha1, real_name, size_c);
	rc = sqlite3_exec(db_put, req, NULL, 0, &zErrMsg);
	if( rc!=SQLITE_OK ){
		fprintf(stderr, "SQL error: %s\n", zErrMsg);
		sqlite3_free(zErrMsg);
	}

	/* CREATE TABLE Categories (Sha1 TEXT NOT NULL, Cat TEXT NOT NULL); */
	req = sqlite3_mprintf("INSERT into Categories (Sha1, Cat) values ('%q', '%q')", sha1, genre);
	rc = sqlite3_exec(db_put, req, NULL, 0, &zErrMsg);
	if( rc!=SQLITE_OK ){
		fprintf(stderr, "SQL error: %s\n", zErrMsg);
		sqlite3_free(zErrMsg);
	}

	/* CREATE TABLE Descr (Sha1 TEXT NOT NULL, Descr LONGTEXT NOT NULL); */
	if (strlen(msg) > 0) {
		req = sqlite3_mprintf("INSERT into Descr (Sha1, Descr) values ('%q', '%q')", sha1, msg);
	} else
		req = sqlite3_mprintf("INSERT into Descr (Sha1, Descr) values ('%q', '')", sha1);
	rc = sqlite3_exec(db_put, req, NULL, 0, &zErrMsg);
	if( rc!=SQLITE_OK ){
		fprintf(stderr, "SQL error: %s\n", zErrMsg);
		sqlite3_free(zErrMsg);
	}

	/* CREATE TABLE Grp_Sha1 (groupname TEXT NOT NULL, sha1 TEXT NOT NULL); */
	req = sqlite3_mprintf("INSERT into Grp_Sha1 (groupname, sha1) values ('%q', '%q')", grp, sha1);
	rc = sqlite3_exec(db_put, req, NULL, 0, &zErrMsg);
	if( rc!=SQLITE_OK ){
		fprintf(stderr, "SQL error: %s\n", zErrMsg);
		sqlite3_free(zErrMsg);
	}

	/* CREATE TABLE Grp_User (groupname TEXT NOT NULL, username TEXT NOT NULL); */
	if (username != NULL) {
		req = sqlite3_mprintf("INSERT into Grp_User (groupname, username) values ('%q', '%q')", grp, username);
		rc = sqlite3_exec(db_put, req, NULL, 0, &zErrMsg);
		if( rc!=SQLITE_OK ){
			fprintf(stderr, "SQL error: %s\n", zErrMsg);
			sqlite3_free(zErrMsg);
		}
	}

	/* CREATE TABLE Blob_Data (blob_title varchar(80), b blob); */
	/* insert into blobtest (des,b) values ('A test file: test.png',?); */
	if (blob != NULL) {
		int fd, n, i;
		long buflen = 0, totread = 0;
		char *bbuf = NULL, *pbuf = NULL;
		sqlite3_stmt *plineInfo = 0;

		if ((fd = open( blob, O_RDWR | O_CREAT, 0600)) == -1) {
			fprintf(stderr, "Can't open Blob: %s\n", strerror(errno));
			return 1;
		}
		while (buflen - totread - 1 < 1024)
		buflen = addmem(&bbuf, buflen);
		pbuf = bbuf;
		totread = 0;
		while ((n = read(fd, pbuf, 1024)) > 0) {
			totread += n;
			pbuf[n] = '\0';	// This is for printing test
			while (buflen - totread - 1 < 1024)
				buflen = addmem(&bbuf, buflen);
			pbuf = &bbuf[totread];
		}
		close(fd);
		req = sqlite3_mprintf("INSERT into Blob_Data (blob_title, b) values ('%q', ?)", "blob");
		rc = sqlite3_prepare(db_put, req, -1, &plineInfo, 0);
		if (rc == SQLITE_OK && plineInfo != NULL) {
			//fprintf(stderr, "SQLITE_OK\n");
			sqlite3_bind_blob(plineInfo, 1, bbuf, totread, free);
			sqlite3_step(plineInfo);
			rc = sqlite3_finalize(plineInfo);
		}	
		
	}
	sqlite3_close(db_put);

	/* Network zone */
	init_OpenSSL ();			  
  seed_prng ();
	a = crv_cut(server, ":");
  
	lval = strtol(a[1], &ep, 10);
  if (a[1][0] == '\0' || *ep != '\0') {
		fprintf(stderr, "%s\n", "Put(): Err[001] port is not a number");
		return (-1);
  }

  if ((errno == ERANGE && (lval == LONG_MAX
	  || lval == LONG_MIN)) ||
	  (lval > 65535 || lval < 0))
  {
		fprintf(stderr, "%s\n", "Put(): Err[002] port is out of range");
		return (-1);
  }
  port = lval;
  sd = crv_client_create( port, a[0], options.address_family);
  
  /* We keep the certificate and key with the context. */
  ctx = setup_client_ctx ();

  /* TCP connection is ready. Do server side SSL. */
  ssl = SSL_new (ctx);
  if ((ssl)==NULL) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "Put() Err[003] Create new ssl failed");
		return(-1);
  }

  /* connect the SSL object with a file descriptor */
  code = SSL_set_fd (ssl, sd);
  if ( code == 0) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "Put() Err[004] Put SSL on socket failed \n");
		return(-1);
  }

  code = SSL_connect (ssl);
  if (code == 0)	{
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf( stderr, "%s\n", "Put(): Err[005] SSL_connect() failed");
		return(-1);
  } else
  if (code == -1) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf( stderr, "%s\n", "Put(): Err[006] SSL_connect() failed");
		return(-1);
  }

  /* Build command -> GET#version#sha1#begin#end */
  (void)crv_strncpy(command, "PUT#", sizeof(command));
  (void)crv_strncat(command, CREUVUX_VERSION, sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, sha1, sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, "0", sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, size_c, sizeof(command));
  
  /* Time initialisation */
  gettimeofday (&tv1, NULL);

  code = SSL_write (ssl, command, (int)strlen(command));
  if ( code <= 0) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "receive_get_file(): Err[011] SSL_write() failed.");
	return(-1);
  }

  code = SSL_read (ssl, buf, sizeof(buf) - 1);
  buf[code] = '\0';

  if(!crv_strncmp (buf, "PUT_ACK"))
  {
		fprintf(stdout, "\n\n");
		code = SSL_sendfile(ssl, sha1, filename, (off_t)0, size);	
		if (code == -1) {
			close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
			fprintf(stderr, "%s\n", "Put() Err[012] SSL_sendfile() failed");
			return(-1);
		}
  }
  
  code = SSL_write (ssl, "PUT_END", (int)strlen("PUT_END"));
  if ( code <= 0) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "receive_get_file(): Err[013] SSL_write() failed.");
		return(-1);
  }


  gettimeofday (&tv2, NULL);
  /* compute difference */
  sec1 = tv2.tv_sec - tv1.tv_sec;
  int min;
  float average;
  average = ((float) size / (float) sec1) / 1024;
  min = sec1 / 60;
  sec1 = sec1 - min * 60;
  fprintf (stdout,
	     "\n\nFile download in %d min  %d sec \nSpeed average -> %.f KBps\n\n",
	     min, sec1, average);

  close(sd); SSL_free (ssl); SSL_CTX_free (ctx);crv_free(sha1);


  /* Send file's decription */
  init_OpenSSL ();			  
  seed_prng ();
  sd = crv_client_create( port, a[0], options.address_family);
  
  /* We keep the certificate and key with the context. */
  ctx = setup_client_ctx ();

  /* TCP connection is ready. Do server side SSL. */
  ssl = SSL_new (ctx);
  if ((ssl)==NULL) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "Put() Err[003] Create new ssl failed");
	return(-1);
  }

  /* connect the SSL object with a file descriptor */
  code = SSL_set_fd (ssl, sd);
  if ( code == 0) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "Put() Err[004] Put SSL on socket failed \n");
	return(-1);
  }

  code = SSL_connect (ssl);
  if (code == 0)	{
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf( stderr, "%s\n", "Put(): Err[005] SSL_connect() failed");
	return(-1);
  } else
  if (code == -1) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf( stderr, "%s\n", "Put(): Err[006] SSL_connect() failed");
	return(-1);
  }

	size = crv_du (dbname);
  if (size == -1) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf( stderr, "%s\n", "Put(): Err[007] crv_du() can't get size");
	return(-1);
  }
  memset(size_c, 0, sizeof(size_c));
  snprintf(size_c, sizeof(size), "%lld", size);

	sha1 = crv_sha1(dbname);
  
  /* Build command -> GET#version#sha1#begin#end */
  (void)crv_strncpy(command, "COMMENT#", sizeof(command));
  (void)crv_strncat(command, CREUVUX_VERSION, sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, sha1, sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, "0", sizeof(command));
  (void)crv_strncat(command, "#", sizeof(command));
  (void)crv_strncat(command, size_c, sizeof(command));
  
  code = SSL_write (ssl, command, (int)strlen(command));
  if ( code <= 0) {
	close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
	fprintf(stderr, "%s\n", "receive_get_file(): Err[011] SSL_write() failed.");
	return(-1);
  }

  code = SSL_read (ssl, buf, sizeof(buf) - 1);
  buf[code] = '\0';

  if(!strncmp (buf, "PUT_ACK", strlen("PUT_ACK")))
  {
		code = SSL_sendfile(ssl, sha1, dbname, (off_t)0, size);	
		if (code == -1) {
			close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
			fprintf(stderr, "%s\n", "Put() Err[012] SSL_sendfile() failed");
			return(-1);
		}
  }
  
  code = SSL_write (ssl, "PUT_END", (int)strlen("PUT_END"));
  if ( code <= 0) {
		close(sd); SSL_free (ssl); SSL_CTX_free (ctx);
		fprintf(stderr, "%s\n", "receive_get_file(): Err[013] SSL_write() failed.");
		return(-1);
  }


	fprintf(stdout, "%s", "Information about file is uploaded\n"); 

  /* Delete DB Meta Data */
  
  code = unlink((const char *)dbname);
  if (code == -1) {
		fprintf(stderr, "%s%s\n", 
			"Put(): Err[010] unlink() failed with error -> ",
			strerror(errno));
		return (-1);
  }
  

  close(sd); SSL_free (ssl); SSL_CTX_free (ctx);crv_free(sha1);
  return (0);

}
Пример #16
0
/*
 * The main TCP accpet loop
 */
void
server_accept_loop()
{
  fd_set *fdset;
  int maxfd, i, ret, err;
  int newsock;
  struct sockaddr_in from;
  socklen_t fromlen;
  int handcheck = -1;
  int sock;
  char **addr = NULL;
	int pfd[2];

	fdset = NULL;
	maxfd = 0;
	
	signal(SIGPIPE, SIG_IGN);
	signal(SIGTERM, ctr_c);
	signal(SIGQUIT, ctr_c);
	signal(SIGINT, ctr_c);

  /* SSL preliminaries */
  SSL_CTX* ctx;
  SSL*     ssl;
  init_OpenSSL ();			  
  seed_prng ();	

  /* We keep the certificate and key with the context. */
  ctx = setup_server_ctx ();
  
  addr = crv_cut(options.listen_addrs, " ");
  for (i = 0; addr[i]; i++)
  {
		/* Prepare TCP socket for receiving connections (change user for ROOT if port < 1024  )*/
		sock = crv_server_listen(options.num_ports, 5, addr[i], options.address_family, 1);
		if (sock == -1) {
			fprintf( stderr, "%s\n", "main(): server_listent() failed");
			exit (EXIT_FAILURE);
		}
		/* Add comment (listening on several adress )*/
		listen_socks[num_listen_socks] = sock;
		num_listen_socks++;
  }

  for( i = 0; addr[i]; i++)
		crv_free(addr[i]);
  crv_free(addr);

  for (i = 0; i < num_listen_socks; i++)
		if (listen_socks[i] > maxfd)
			maxfd = listen_socks[i];
 
  /* loop */
  for(;;)
  {
		newsock = -1;
		int pid;
		handcheck = -1;

		if (fdset != NULL)
			free(fdset);
	
		fdset = (fd_set *) calloc(howmany(maxfd + 1, NFDBITS), sizeof(fd_mask));

		for ( i = 0; i < num_listen_socks; i++)
			FD_SET(listen_socks[i], fdset);


		/* wait in select until there is a connection. */
		ret = select(maxfd+1, fdset, NULL, NULL, NULL);
		if (ret < 0 && errno != EINTR)  
			Log ( "WARNING", 0, "select: %.100s", strerror(errno));
	
		for ( i = 0; i < num_listen_socks; i++)
			if ( FD_ISSET(listen_socks[i], fdset)) {
				fromlen = sizeof(from);
				newsock = accept(listen_socks[i], (struct sockaddr *)&from, &fromlen);
				if (newsock < 0) {
					if (errno != EINTR && errno != EWOULDBLOCK )
						Log ( "WARNING", 0, "accept: %.100s", strerror(errno));
					continue;
				}

				if (received_sigterm) {
					fprintf( stderr, "Received signal %d; terminating.\n",
						(int) received_sigterm);
					close_listen_socks();
					unlink(options.pid);
					return;
				}
		
				if (crv_unset_nonblock(newsock) == -1) {
					Log ( "CRASH", 0, "Unset nonblock failed");
					continue;
				}
		
				/* TCP connection is ready. Do server side SSL. */
				ssl = SSL_new (ctx);
				if ((ssl)==NULL) {
					Log ( "CRASH", 0, "Create new ssl failed");
					continue;
				}
		
				/* connect the SSL object with a file descriptor */
				err = SSL_set_fd (ssl, newsock);
				if ((err)==0) {
					Log ( "CRASH", 0, "Put SSL on socket failed \n");
					close(newsock);
					continue;
				}

				/* TCP connection is ready. Do server side SSL. */
				err = SSL_accept (ssl);
				if ((err) <= 0) {
					Log ("HACK", 0, "%s handcheck failed", inet_ntoa(from.sin_addr));
					/* Free the allocated SSL structure */
					SSL_free (ssl);
					continue;
				} 
				else {
					handcheck = 0;
				}

				if ( handcheck != -1 )
				{
					/* Pipe creation */
					if (pipe(pfd) == -1)
					{
						fprintf( stderr, "%s\n", "server_accept_loop(): pipe() failed");
						return;
					}

					switch((pid = fork()))
					{
						/* fork() Error */
						case -1:
							Log ("CRASH", 0, "%s%s\n", "Error on fork() -> ", strerror(errno));
							exit (EXIT_FAILURE);
				
						/* First child process */
						case 0:
							/* Close socket that has been created in create_tcp_socket() */
							close_listen_socks();
							int result = 0;
							
							/* Chroot process */
							if (result != -1) 
								result = crv_drop_priv_perm_and_chroot (options.user , options.chroot_directory );

							initialize_command_opt(&command);
							command.addr = crv_strdup((const char *)inet_ntoa (from.sin_addr));
					
							if (options.sec == 1) {
								result = post_connection_check (ssl, command.addr);
								if (result != X509_V_OK) {
									Log ( "HACK", 0, 
									"-Error: peer certificate: %s\n",
									X509_verify_cert_error_string (result));
									result = -1;
								}
							}

							/* Time initialisation */
							gettimeofday (&tv1, NULL);

							/* Get client name*/
							char buff[SIZE];
							command.user = recup_pseudo (ssl);
							command.mail = recup_email (ssl);

							/* Send client pseudo to father */
							write(pfd[1], command.user, strlen(command.user)+1);
							close(pfd[1]); /* close write side */

							sleep(1);
							memset(buff, 0, sizeof(buff));
							
							/* Read repond from father */
							(void)read(pfd[0], buff, SIZE);
							close(pfd[0]);
							
							/* Get father respond about client pseudo */
							/* Les pipes sont à enlever car, la liste des utilisateurs autorisés
							 * sont contenue sur la base de données distante
							if (!crv_strncmp(buff, "no_register")) {
								Log ("WARNING", 0, "Username '%s' is not registered", command.user);
								result = -1;
							}
							*/
							printf("buff:%s\n", buff);
						
							/* Get CMD info (comd name, sha1 file, begin, end) */
							if (result != -1)
								result = pre_authcon( ssl, (const char *)buff);

							if ( result == -1)
								Log ("WARNING", 0, "Can't set command options");
				
							/* exec command give by client */
							if (result != -1)
								traitement_conec ( ssl);
					
							/* Free command structure */
							Free_cmd_struct();
					
							/* Close Socket , tube */
							shutdown (newsock, 2);
							close (newsock);
					
							/* Free the allocated SSL structure */
							SSL_free (ssl);
					
							/* Free the allocated SSL CONTEXT object */
							SSL_CTX_free (ctx);

							/* EXIT */
							exit (EXIT_SUCCESS);
			
						/* Father process */
						default:
							{	
								char *xpath = NULL;
								char Buffer[SIZE];

								/* Read client pseudo from son */
								(void)read(pfd[0], Buffer, SIZE);
								//xpath = get_grp_list(Buffer);
								close(pfd[0]); /* close read side */
								
								if (xpath == NULL)
									xpath = crv_strdup("no_register");
							
								(void)crv_strncpy(Buffer, xpath, sizeof(Buffer));
								(void)write(pfd[1], Buffer, strlen(Buffer)+1);
								close(pfd[1]);
								if (xpath != NULL)
									crv_free(xpath);

								SSL_free (ssl);
								close(newsock);
							}
					} /* End of fork() */

				} /* if handcheck is 0 */

			} /* FD_ISSET */

		} /* End of for() loop */
}