Spawning
We are going to shift gears and start working on the Redis server.
First, move the client SET/GET code from the previous section to an example
file. This way, we can run it against our server.
$ mkdir -p examples
$ mv src/main.rs examples/hello-redis.rs
Then create a new, empty src/main.rs and continue.
Accepting sockets
The first thing our Redis server needs to do is to accept inbound TCP sockets.
This is done by binding tokio::net::TcpListener to port 6379.
Many of Tokio's types are named the same as their synchronous equivalent in the Rust standard library. When it makes sense, Tokio exposes the same APIs as
stdbut usingasync fn.
Then the sockets are accepted in a loop. Each socket is processed then closed. For now, we will read the command, print it to stdout and respond with an error.
src/main.rs
use tokio::net::{TcpListener, TcpStream};
use mini_redis::{Connection, Frame};
#[tokio::main]
async fn main() {
    // Bind the listener to the address
    let listener = TcpListener::bind("127.0.0.1:6379").await.unwrap();
    loop {
        // The second item contains the IP and port of the new connection.
        let (socket, _) = listener.accept().await.unwrap();
        process(socket).await;
    }
}
async fn process(socket: TcpStream) {
    // The `Connection` lets us read/write redis **frames** instead of
    // byte streams. The `Connection` type is defined by mini-redis.
    let mut connection = Connection::new(socket);
    if let Some(frame) = connection.read_frame().await.unwrap() {
        println!("GOT: {:?}", frame);
        // Respond with an error
        let response = Frame::Error("unimplemented".to_string());
        connection.write_frame(&response).await.unwrap();
    }
}
Now, run this accept loop:
$ cargo run
In a separate terminal window, run the hello-redis example (the SET/GET
command from the previous section):
$ cargo run --example hello-redis
The output should be:
Error: "unimplemented"
In the server terminal, the output is:
GOT: Array([Bulk(b"set"), Bulk(b"hello"), Bulk(b"world")])
Concurrency
Our server has a slight problem (besides only responding with errors). It processes inbound requests one at a time. When a connection is accepted, the server stays inside the accept loop block until the response is fully written to the socket.
We want our Redis server to process many concurrent requests. To do this, we need to add some concurrency.
Concurrency and parallelism are not the same thing. If you alternate between two tasks, then you are working on both tasks concurrently, but not in parallel. For it to qualify as parallel, you would need two people, one dedicated to each task.
One of the advantages of using Tokio is that asynchronous code allows you to work on many tasks concurrently, without having to work on them in parallel using ordinary threads. In fact, Tokio can run many tasks concurrently on a single thread!
To process connections concurrently, a new task is spawned for each inbound connection. The connection is processed on this task.
The accept loop becomes:
use tokio::net::TcpListener;
#[tokio::main]
async fn main() {
    let listener = TcpListener::bind("127.0.0.1:6379").await.unwrap();
    loop {
        let (socket, _) = listener.accept().await.unwrap();
        // A new task is spawned for each inbound socket. The socket is
        // moved to the new task and processed there.
        tokio::spawn(async move {
            process(socket).await;
        });
    }
}
Tasks
A Tokio task is an asynchronous green thread. They are created by passing an
async block to tokio::spawn. The tokio::spawn function returns a
JoinHandle, which the caller may use to interact with the spawned task. The
async block may have a return value. The caller may obtain the return value
using .await on the JoinHandle.
For example:
#[tokio::main]
async fn main() {
    let handle = tokio::spawn(async {
        // Do some async work
        "return value"
    });
    // Do some other work
    let out = handle.await.unwrap();
    println!("GOT {}", out);
}
Awaiting on JoinHandle returns a Result. When a task encounters an error
during execution, the JoinHandle will return an Err. This happens when the
task either panics, or if the task is forcefully cancelled by the runtime
shutting down.
Tasks are the unit of execution managed by the scheduler. Spawning the task submits it to the Tokio scheduler, which then ensures that the task executes when it has work to do. The spawned task may be executed on the same thread as where it was spawned, or it may execute on a different runtime thread. The task can also be moved between threads after being spawned.
Tasks in Tokio are very lightweight. Under the hood, they require only a single allocation and 64 bytes of memory. Applications should feel free to spawn thousands, if not millions of tasks.
'static bound
When you spawn a task on the Tokio runtime, its type's lifetime must be 'static. This
means that the spawned task must not contain any references to data owned
outside the task.
It is a common misconception that
'staticalways means "lives forever", but this is not the case. Just because a value is'staticdoes not mean that you have a memory leak. You can read more in Common Rust Lifetime Misconceptions.
For example, the following will not compile:
use tokio::task;
#[tokio::main]
async fn main() {
    let v = vec![1, 2, 3];
    task::spawn(async {
        println!("Here's a vec: {:?}", v);
    });
}
Attempting to compile this results in the following error:
error[E0373]: async block may outlive the current function, but
              it borrows `v`, which is owned by the current function
 --> src/main.rs:7:23
  |
7 |       task::spawn(async {
  |  _______________________^
8 | |         println!("Here's a vec: {:?}", v);
  | |                                        - `v` is borrowed here
9 | |     });
  | |_____^ may outlive borrowed value `v`
  |
note: function requires argument type to outlive `'static`
 --> src/main.rs:7:17
  |
7 |       task::spawn(async {
  |  _________________^
8 | |         println!("Here's a vector: {:?}", v);
9 | |     });
  | |_____^
help: to force the async block to take ownership of `v` (and any other
      referenced variables), use the `move` keyword
  |
7 |     task::spawn(async move {
8 |         println!("Here's a vec: {:?}", v);
9 |     });
  |
This happens because, by default, variables are not moved into async blocks.
The v vector remains owned by the main function. The println! line borrows
v. The rust compiler helpfully explains this to us and even suggests the fix!
Changing line 7 to task::spawn(async move { will instruct the compiler to
move v into the spawned task. Now, the task owns all of its data, making
it 'static.
If a single piece of data must be accessible from more than one task
concurrently, then it must be shared using synchronization primitives such as
Arc.
Note that the error message talks about the argument type outliving the
'static lifetime. This terminology can be rather confusing because the
'static lifetime lasts until the end of the program, so if it outlives it,
don't you have a memory leak? The explanation is that it is the type, not the
value that must outlive the 'static lifetime, and the value may be destroyed
before its type is no longer valid.
When we say that a value is 'static, all that means is that it would not be
incorrect to keep that value around forever. This is important because the
compiler is unable to reason about how long a newly spawned task stays around.
We have to make sure that the task is allowed to live forever, so that Tokio
can make the task run as long as it needs to.
The article that the info-box earlier links to uses the terminology "bounded by
'static" rather than "its type outlives 'static" or "the value is 'static"
to refer to T: 'static. These all mean the same thing, but are different from
"annotated with 'static" as in &'static T.
Send bound
Tasks spawned by tokio::spawn must implement Send. This allows the Tokio
runtime to move the tasks between threads while they are suspended at an
.await.
Tasks are Send when all data that is held across .await calls is
Send. This is a bit subtle. When .await is called, the task yields back to
the scheduler. The next time the task is executed, it resumes from the point it
last yielded. To make this work, all state that is used after .await must
be saved by the task. If this state is Send, i.e. can be moved across threads,
then the task itself can be moved across threads. Conversely, if the state is not
Send, then neither is the task.
For example, this works:
use tokio::task::yield_now;
use std::rc::Rc;
#[tokio::main]
async fn main() {
    tokio::spawn(async {
        // The scope forces `rc` to drop before `.await`.
        {
            let rc = Rc::new("hello");
            println!("{}", rc);
        }
        // `rc` is no longer used. It is **not** persisted when
        // the task yields to the scheduler
        yield_now().await;
    });
}
This does not:
use tokio::task::yield_now;
use std::rc::Rc;
#[tokio::main]
async fn main() {
    tokio::spawn(async {
        let rc = Rc::new("hello");
        // `rc` is used after `.await`. It must be persisted to
        // the task's state.
        yield_now().await;
        println!("{}", rc);
    });
}
Attempting to compile the snippet results in:
error: future cannot be sent between threads safely
   --> src/main.rs:6:5
    |
6   |     tokio::spawn(async {
    |     ^^^^^^^^^^^^ future created by async block is not `Send`
    | 
   ::: [..]spawn.rs:127:21
    |
127 |         T: Future + Send + 'static,
    |                     ---- required by this bound in
    |                          `tokio::task::spawn::spawn`
    |
    = help: within `impl std::future::Future`, the trait
    |       `std::marker::Send` is not  implemented for
    |       `std::rc::Rc<&str>`
note: future is not `Send` as this value is used across an await
   --> src/main.rs:10:9
    |
7   |         let rc = Rc::new("hello");
    |             -- has type `std::rc::Rc<&str>` which is not `Send`
...
10  |         yield_now().await;
    |         ^^^^^^^^^^^^^^^^^ await occurs here, with `rc` maybe
    |                           used later
11  |         println!("{}", rc);
12  |     });
    |     - `rc` is later dropped here
We will discuss a special case of this error in more depth in the next chapter.
Store values
We will now implement the process function to handle incoming commands. We
will use a HashMap to store values. SET commands will insert into the
HashMap and GET values will load them. Additionally, we will use a loop to
accept more than one command per connection.
use tokio::net::TcpStream;
use mini_redis::{Connection, Frame};
async fn process(socket: TcpStream) {
    use mini_redis::Command::{self, Get, Set};
    use std::collections::HashMap;
    // A hashmap is used to store data
    let mut db = HashMap::new();
    // Connection, provided by `mini-redis`, handles parsing frames from
    // the socket
    let mut connection = Connection::new(socket);
    // Use `read_frame` to receive a command from the connection.
    while let Some(frame) = connection.read_frame().await.unwrap() {
        let response = match Command::from_frame(frame).unwrap() {
            Set(cmd) => {
                // The value is stored as `Vec<u8>`
                db.insert(cmd.key().to_string(), cmd.value().to_vec());
                Frame::Simple("OK".to_string())
            }
            Get(cmd) => {
                if let Some(value) = db.get(cmd.key()) {
                    // `Frame::Bulk` expects data to be of type `Bytes`. This
                    // type will be covered later in the tutorial. For now,
                    // `&Vec<u8>` is converted to `Bytes` using `into()`.
                    Frame::Bulk(value.clone().into())
                } else {
                    Frame::Null
                }
            }
            cmd => panic!("unimplemented {:?}", cmd),
        };
        // Write the response to the client
        connection.write_frame(&response).await.unwrap();
    }
}
Now, start the server:
$ cargo run
and in a separate terminal window, run the hello-redis example:
$ cargo run --example hello-redis
Now, the output will be:
got value from the server; result=Some(b"world")
We can now get and set values, but there is a problem: The values are not
shared between connections. If another socket connects and tries to GET
the hello key, it will not find anything.
You can find the full code here.
In the next section, we will implement persisting data for all sockets.