aboutsummaryrefslogtreecommitdiffstats
diff options
context:
space:
mode:
authorLoïc Hoguin <[email protected]>2012-04-12 23:22:52 +0200
committerLoïc Hoguin <[email protected]>2012-04-14 17:52:47 +0200
commit4156fa3ebb978a21b52abf94202bb3d7676f4c03 (patch)
treee05c4cac592afeace0f1722bd2111d0d88eb94d0
parentf971ec1ced3758834d6e98ab3c7fafddd8bf9da6 (diff)
downloadranch-4156fa3ebb978a21b52abf94202bb3d7676f4c03.tar.gz
ranch-4156fa3ebb978a21b52abf94202bb3d7676f4c03.tar.bz2
ranch-4156fa3ebb978a21b52abf94202bb3d7676f4c03.zip
Import the acceptor code from Cowboy
Modules were renamed. The 'cowboy_' prefix became 'ranch_'. At the same time, ranch_ssl_transport became ranch_ssl, and ranch_tcp_transport became ranch_tcp, because appending '_transport' felt a bit redundant considering SSL and TCP clearly are transports. One test has been added to make sure everything is working.
-rw-r--r--.gitignore10
-rw-r--r--AUTHORS11
-rw-r--r--LICENSE13
-rw-r--r--Makefile50
-rw-r--r--README.md90
-rw-r--r--ROADMAP.md45
-rw-r--r--cover.spec1
-rw-r--r--doc/overview.edoc4
-rw-r--r--rebar.config6
-rw-r--r--rebar.tests.config4
-rw-r--r--src/ranch.app.src26
-rw-r--r--src/ranch.erl114
-rw-r--r--src/ranch_acceptor.erl57
-rw-r--r--src/ranch_acceptors_sup.erl48
-rw-r--r--src/ranch_app.erl53
-rw-r--r--src/ranch_conns_sup.erl44
-rw-r--r--src/ranch_listener.erl224
-rw-r--r--src/ranch_listener_sup.erl46
-rw-r--r--src/ranch_ssl.erl170
-rw-r--r--src/ranch_sup.erl40
-rw-r--r--src/ranch_tcp.erl113
-rw-r--r--test/acceptor_SUITE.erl52
-rw-r--r--test/echo_protocol.erl19
23 files changed, 1238 insertions, 2 deletions
diff --git a/.gitignore b/.gitignore
new file mode 100644
index 0000000..1570b33
--- /dev/null
+++ b/.gitignore
@@ -0,0 +1,10 @@
+.ranch.plt
+.eunit
+deps
+doc/*.css
+doc/*.html
+doc/*.png
+doc/edoc-info
+ebin
+logs
+test/*.beam
diff --git a/AUTHORS b/AUTHORS
new file mode 100644
index 0000000..36d4b75
--- /dev/null
+++ b/AUTHORS
@@ -0,0 +1,11 @@
+Ranch is available thanks to the work of:
+
+Loïc Hoguin
+Ali Sabil
+Andrew Thompson
+DeadZen
+Hunter Morris
+Jesper Louis Andersen
+Paul Oliver
+Roberto Ostinelli
+Steven Gravell
diff --git a/LICENSE b/LICENSE
new file mode 100644
index 0000000..f79b460
--- /dev/null
+++ b/LICENSE
@@ -0,0 +1,13 @@
+Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+
+Permission to use, copy, modify, and/or distribute this software for any
+purpose with or without fee is hereby granted, provided that the above
+copyright notice and this permission notice appear in all copies.
+
+THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
diff --git a/Makefile b/Makefile
new file mode 100644
index 0000000..fd627e2
--- /dev/null
+++ b/Makefile
@@ -0,0 +1,50 @@
+# See LICENSE for licensing information.
+
+PROJECT = ranch
+
+DIALYZER = dialyzer
+REBAR = rebar
+
+all: app
+
+# Application.
+
+deps:
+ @$(REBAR) get-deps
+
+app: deps
+ @$(REBAR) compile
+
+clean:
+ @$(REBAR) clean
+ rm -f test/*.beam
+ rm -f erl_crash.dump
+
+docs: clean-docs
+ @$(REBAR) doc skip_deps=true
+
+clean-docs:
+ rm -f doc/*.css
+ rm -f doc/*.html
+ rm -f doc/*.png
+ rm -f doc/edoc-info
+
+# Tests.
+
+tests: clean app eunit ct
+
+eunit:
+ @$(REBAR) -C rebar.tests.config eunit skip_deps=true
+
+ct:
+ @$(REBAR) -C rebar.tests.config ct skip_deps=true
+
+# Dialyzer.
+
+build-plt:
+ @$(DIALYZER) --build_plt --output_plt .$(PROJECT).plt \
+ --apps kernel stdlib sasl tools inets crypto public_key ssl
+
+dialyze:
+ @$(DIALYZER) --src src --plt .$(PROJECT).plt \
+ -Werror_handling -Wrace_conditions -Wunmatched_returns # -Wunderspecs
diff --git a/README.md b/README.md
index 551c502..2fbe9cd 100644
--- a/README.md
+++ b/README.md
@@ -1,5 +1,91 @@
Ranch
=====
-Ranch is a socket acceptor pool, able to accept connections for any kind
-of TCP protocol.
+Ranch is a socket acceptor pool for TCP protocols.
+
+Goals
+-----
+
+Ranch aims to provide everything you need to accept TCP connections with
+a **small** code base and **low latency** while being easy to use directly
+as an application or to **embed** into your own.
+
+Ranch provides a **modular** design, letting you choose which transport
+and protocol are going to be used for a particular listener. Listeners
+accept and manage connections on one port, and include facilities to
+limit the number of **concurrent** connections. Connections are sorted
+into **pools**, each pool having a different configurable limit.
+
+Ranch also allows you to **upgrade** the acceptor pool without having
+to close any of the currently opened sockets.
+
+The project is currently in early development. Comments and suggestions are
+more than welcome. To contribute, either open bug reports, or fork the project
+and send us pull requests with new or improved functionality. You should
+discuss your plans with us before doing any serious work, though, to avoid
+duplicating efforts.
+
+Quick start
+-----------
+
+* Add Ranch as a rebar or agner dependency to your application.
+* Start Ranch and add one or more listeners.
+* Write protocol handlers for your application.
+
+Getting Started
+---------------
+
+Ranch accepts connections received on a given port and using a given
+transport, like TCP or SSL, and forward them to a given protocol
+handler. Acceptors and protocol handler processes are of course
+supervised automatically.
+
+Ranch does nothing by default. You need to explicitly request Ranch
+to listen on a port with your chosen transport and protocol handlers.
+To do so, you must start a listener.
+
+A listener is a special kind of supervisor that manages both the
+acceptor pool and the protocol processes. It is named and can thus be
+started and stopped at will.
+
+An acceptor pool is a pool of processes whose only role is to accept
+new connections. It's good practice to have many of these processes
+as they are very cheap and allow much quicker response when you get
+many connections. Of course, as with everything else, you should
+**benchmark** before you decide what's best for you.
+
+Ranch includes both TCP and SSL transport handlers, abstracted through
+a single common interface.
+
+You can start and stop listeners by calling `ranch:start_listener/6` and
+`ranch:stop_listener/1` respectively.
+
+The following example demonstrates the startup of a very simple listener.
+
+``` erlang
+application:start(ranch),
+%% Name, NbAcceptors, Transport, TransOpts, Protocol, ProtoOpts
+ranch:start_listener(my_echo_listener, 100,
+ ranch_tcp, [{port, 1234}],
+ my_echo_protocol, [{log, "echo.log"}]
+).
+```
+
+Writing a protocol handler
+--------------------------
+
+The only exported function a protocol handler needs is the start_link/4
+function, with arguments ListenerPid, Socket, Transport and Opts. ListenerPid
+is the pid to the listener's gen_server, managing the connections. Socket is of
+course the client socket; Transport is the module name of the chosen transport
+handler and Opts is protocol options defined when starting the listener.
+
+After initializing your protocol, it is recommended to call the
+function ranch:accept_ack/1 with the ListenerPid as argument,
+as it will ensure Ranch has been able to fully initialize the socket.
+Anything you do past this point is up to you!
+
+If you need to change some socket options, like enabling raw mode for example,
+you can call the <em>Transport:setopts/2</em> function. It is the protocol's
+responsability to manage the socket usage, there should be no need for an user
+to specify that kind of options while starting a listener.
diff --git a/ROADMAP.md b/ROADMAP.md
new file mode 100644
index 0000000..2c756b8
--- /dev/null
+++ b/ROADMAP.md
@@ -0,0 +1,45 @@
+ROADMAP
+=======
+
+This document explains in as much details as possible the
+list of planned changes and work to be done on the Ranch
+project. It is non-exhaustive and subject to change. Items
+are not ordered.
+
+* Write examples.
+
+ Ideally we would have one complete example per folder.
+
+ Examples should be commented. They may or may not be
+ used for writing the user guides.
+
+* Write user guides.
+
+ We currently have good API documentation, but no step
+ by step user guides.
+
+* Continuous performance testing.
+
+ Initially dubbed the Horse project, Ranch could benefit
+ from a continuous performance testing tool that would
+ allow us to easily compare the impact of the changes we
+ are introducing, similar to what the Phoronix test suite
+ allows.
+
+* Transport upgrades.
+
+ Some protocols allow an upgrade from TCP to SSL without
+ closing the connection. This is currently not possible
+ through the Ranch API.
+
+* Resizing the acceptor pool.
+
+ We should be able to add more acceptors to a pool but also
+ to remove some of them as needed.
+
+* Add Transport:secure/0.
+
+ Currently Cowboy checks if a connection is secure by
+ checking if its name is 'ssl'. This isn't a very modular
+ solution, adding an API function that returns whether
+ a connection is secure would fix that issue.
diff --git a/cover.spec b/cover.spec
new file mode 100644
index 0000000..13c52ba
--- /dev/null
+++ b/cover.spec
@@ -0,0 +1 @@
+{incl_app, ranch, details}.
diff --git a/doc/overview.edoc b/doc/overview.edoc
new file mode 100644
index 0000000..baf4939
--- /dev/null
+++ b/doc/overview.edoc
@@ -0,0 +1,4 @@
+@author Lo�c Hoguin <[email protected]>
+@copyright 2011-2012 Lo�c Hoguin
+@version HEAD
+@title Socket acceptor pool for TCP protocols.
diff --git a/rebar.config b/rebar.config
new file mode 100644
index 0000000..4d66319
--- /dev/null
+++ b/rebar.config
@@ -0,0 +1,6 @@
+{erl_opts, [
+%% bin_opt_info,
+ warn_missing_spec,
+ warnings_as_errors,
+ warn_export_all
+]}.
diff --git a/rebar.tests.config b/rebar.tests.config
new file mode 100644
index 0000000..9fbc6af
--- /dev/null
+++ b/rebar.tests.config
@@ -0,0 +1,4 @@
+{cover_enabled, true}.
+{deps, []}.
+{eunit_opts, [verbose, {report, {eunit_surefire, [{dir, "."}]}}]}.
+{erl_opts, []}.
diff --git a/src/ranch.app.src b/src/ranch.app.src
new file mode 100644
index 0000000..becbe4c
--- /dev/null
+++ b/src/ranch.app.src
@@ -0,0 +1,26 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+{application, ranch, [
+ {description, "Socket acceptor pool for TCP protocols."},
+ {vsn, "0.1.0"},
+ {modules, []},
+ {registered, [ranch_sup]},
+ {applications, [
+ kernel,
+ stdlib
+ ]},
+ {mod, {ranch_app, []}},
+ {env, []}
+]}.
diff --git a/src/ranch.erl b/src/ranch.erl
new file mode 100644
index 0000000..ab9d767
--- /dev/null
+++ b/src/ranch.erl
@@ -0,0 +1,114 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+%% @doc Ranch API to start and stop listeners.
+-module(ranch).
+
+-export([start_listener/6, stop_listener/1, child_spec/6, accept_ack/1,
+ get_protocol_options/1, set_protocol_options/2]).
+
+%% @doc Start a listener for the given transport and protocol.
+%%
+%% A listener is effectively a pool of <em>NbAcceptors</em> acceptors.
+%% Acceptors accept connections on the given <em>Transport</em> and forward
+%% connections to the given <em>Protocol</em> handler. Both transport and
+%% protocol modules can be given options through the <em>TransOpts</em> and
+%% the <em>ProtoOpts</em> arguments. Available options are documented in the
+%% <em>listen</em> transport function and in the protocol module of your choice.
+%%
+%% All acceptor and connection processes are supervised by the listener.
+%%
+%% It is recommended to set a large enough number of acceptors to improve
+%% performance. The exact number depends of course on your hardware, on the
+%% protocol used and on the number of expected simultaneous connections.
+%%
+%% The <em>Transport</em> option <em>max_connections</em> allows you to define
+%% the maximum number of simultaneous connections for this listener. It defaults
+%% to 1024. See <em>ranch_listener</em> for more details on limiting the number
+%% of connections.
+%%
+%% <em>Ref</em> can be used to stop the listener later on.
+-spec start_listener(any(), non_neg_integer(), module(), any(), module(), any())
+ -> {ok, pid()}.
+start_listener(Ref, NbAcceptors, Transport, TransOpts, Protocol, ProtoOpts)
+ when is_integer(NbAcceptors) andalso is_atom(Transport)
+ andalso is_atom(Protocol) ->
+ supervisor:start_child(ranch_sup, child_spec(Ref, NbAcceptors,
+ Transport, TransOpts, Protocol, ProtoOpts)).
+
+%% @doc Stop a listener identified by <em>Ref</em>.
+%%
+%% Note that stopping the listener will close all currently running
+%% connections abruptly.
+-spec stop_listener(any()) -> ok | {error, not_found}.
+stop_listener(Ref) ->
+ case supervisor:terminate_child(ranch_sup, {ranch_listener_sup, Ref}) of
+ ok ->
+ supervisor:delete_child(ranch_sup, {ranch_listener_sup, Ref});
+ {error, Reason} ->
+ {error, Reason}
+ end.
+
+%% @doc Return a child spec suitable for embedding.
+%%
+%% When you want to embed Ranch in another application, you can use this
+%% function to create a <em>ChildSpec</em> suitable for use in a supervisor.
+%% The parameters are the same as in <em>start_listener/6</em> but rather
+%% than hooking the listener to the Ranch internal supervisor, it just returns
+%% the spec.
+-spec child_spec(any(), non_neg_integer(), module(), any(), module(), any())
+ -> supervisor:child_spec().
+child_spec(Ref, NbAcceptors, Transport, TransOpts, Protocol, ProtoOpts)
+ when is_integer(NbAcceptors) andalso is_atom(Transport)
+ andalso is_atom(Protocol) ->
+ {{ranch_listener_sup, Ref}, {ranch_listener_sup, start_link, [
+ NbAcceptors, Transport, TransOpts, Protocol, ProtoOpts
+ ]}, permanent, 5000, supervisor, [ranch_listener_sup]}.
+
+%% @doc Acknowledge the accepted connection.
+%%
+%% Effectively used to make sure the socket control has been given to
+%% the protocol process before starting to use it.
+-spec accept_ack(pid()) -> ok.
+accept_ack(ListenerPid) ->
+ receive {shoot, ListenerPid} -> ok end.
+
+%% @doc Return the current protocol options for the given listener.
+-spec get_protocol_options(any()) -> any().
+get_protocol_options(Ref) ->
+ ListenerPid = ref_to_listener_pid(Ref),
+ {ok, ProtoOpts} = ranch_listener:get_protocol_options(ListenerPid),
+ ProtoOpts.
+
+%% @doc Upgrade the protocol options for the given listener.
+%%
+%% The upgrade takes place at the acceptor level, meaning that only the
+%% newly accepted connections receive the new protocol options. This has
+%% no effect on the currently opened connections.
+-spec set_protocol_options(any(), any()) -> ok.
+set_protocol_options(Ref, ProtoOpts) ->
+ ListenerPid = ref_to_listener_pid(Ref),
+ ok = ranch_listener:set_protocol_options(ListenerPid, ProtoOpts).
+
+%% Internal.
+
+-spec ref_to_listener_pid(any()) -> pid().
+ref_to_listener_pid(Ref) ->
+ Children = supervisor:which_children(ranch_sup),
+ {_, ListenerSupPid, _, _} = lists:keyfind(
+ {ranch_listener_sup, Ref}, 1, Children),
+ ListenerSupChildren = supervisor:which_children(ListenerSupPid),
+ {_, ListenerPid, _, _} = lists:keyfind(
+ ranch_listener, 1, ListenerSupChildren),
+ ListenerPid.
diff --git a/src/ranch_acceptor.erl b/src/ranch_acceptor.erl
new file mode 100644
index 0000000..f35b025
--- /dev/null
+++ b/src/ranch_acceptor.erl
@@ -0,0 +1,57 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+%% @private
+-module(ranch_acceptor).
+
+-export([start_link/6]). %% API.
+-export([acceptor/7]). %% Internal.
+
+%% API.
+
+-spec start_link(inet:socket(), module(), module(), any(),
+ pid(), pid()) -> {ok, pid()}.
+start_link(LSocket, Transport, Protocol, Opts,
+ ListenerPid, ConnsSup) ->
+ Pid = spawn_link(?MODULE, acceptor,
+ [LSocket, Transport, Protocol, Opts, 1, ListenerPid, ConnsSup]),
+ {ok, Pid}.
+
+%% Internal.
+
+-spec acceptor(inet:socket(), module(), module(), any(),
+ non_neg_integer(), pid(), pid()) -> no_return().
+acceptor(LSocket, Transport, Protocol, Opts, OptsVsn, ListenerPid, ConnsSup) ->
+ Res = case Transport:accept(LSocket, 2000) of
+ {ok, CSocket} ->
+ {ok, Pid} = supervisor:start_child(ConnsSup,
+ [ListenerPid, CSocket, Transport, Protocol, Opts]),
+ Transport:controlling_process(CSocket, Pid),
+ ranch_listener:add_connection(ListenerPid,
+ default, Pid, OptsVsn);
+ {error, timeout} ->
+ ranch_listener:check_upgrades(ListenerPid, OptsVsn);
+ {error, _Reason} ->
+ %% @todo Probably do something here. If the socket was closed,
+ %% we may want to try and listen again on the port?
+ ok
+ end,
+ case Res of
+ ok ->
+ ?MODULE:acceptor(LSocket, Transport, Protocol,
+ Opts, OptsVsn, ListenerPid, ConnsSup);
+ {upgrade, Opts2, OptsVsn2} ->
+ ?MODULE:acceptor(LSocket, Transport, Protocol,
+ Opts2, OptsVsn2, ListenerPid, ConnsSup)
+ end.
diff --git a/src/ranch_acceptors_sup.erl b/src/ranch_acceptors_sup.erl
new file mode 100644
index 0000000..3b32668
--- /dev/null
+++ b/src/ranch_acceptors_sup.erl
@@ -0,0 +1,48 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+%% @private
+-module(ranch_acceptors_sup).
+-behaviour(supervisor).
+
+-export([start_link/7]). %% API.
+-export([init/1]). %% supervisor.
+
+%% API.
+
+-spec start_link(non_neg_integer(), module(), any(),
+ module(), any(), pid(), pid()) -> {ok, pid()}.
+start_link(NbAcceptors, Transport, TransOpts,
+ Protocol, ProtoOpts, ListenerPid, ConnsPid) ->
+ supervisor:start_link(?MODULE, [NbAcceptors, Transport, TransOpts,
+ Protocol, ProtoOpts, ListenerPid, ConnsPid]).
+
+%% supervisor.
+
+-spec init([any()]) -> {'ok', {{'one_for_one', 10, 10}, [{
+ any(), {atom() | tuple(), atom(), 'undefined' | [any()]},
+ 'permanent' | 'temporary' | 'transient',
+ 'brutal_kill' | 'infinity' | non_neg_integer(),
+ 'supervisor' | 'worker',
+ 'dynamic' | [atom() | tuple()]}]
+}}.
+init([NbAcceptors, Transport, TransOpts,
+ Protocol, ProtoOpts, ListenerPid, ConnsPid]) ->
+ {ok, LSocket} = Transport:listen(TransOpts),
+ Procs = [{{acceptor, self(), N}, {ranch_acceptor, start_link, [
+ LSocket, Transport, Protocol, ProtoOpts,
+ ListenerPid, ConnsPid
+ ]}, permanent, brutal_kill, worker, []}
+ || N <- lists:seq(1, NbAcceptors)],
+ {ok, {{one_for_one, 10, 10}, Procs}}.
diff --git a/src/ranch_app.erl b/src/ranch_app.erl
new file mode 100644
index 0000000..0dc687c
--- /dev/null
+++ b/src/ranch_app.erl
@@ -0,0 +1,53 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+%% @private
+-module(ranch_app).
+-behaviour(application).
+
+-export([start/2, stop/1, profile_output/0]). %% API.
+
+-type application_start_type() :: normal
+ | {takeover, node()} | {failover, node()}.
+
+%% API.
+
+-spec start(application_start_type(), any()) -> {ok, pid()}.
+start(_Type, _Args) ->
+ consider_profiling(),
+ ranch_sup:start_link().
+
+-spec stop(any()) -> ok.
+stop(_State) ->
+ ok.
+
+-spec profile_output() -> ok.
+profile_output() ->
+ eprof:stop_profiling(),
+ eprof:log("procs.profile"),
+ eprof:analyze(procs),
+ eprof:log("total.profile"),
+ eprof:analyze(total).
+
+%% Internal.
+
+-spec consider_profiling() -> profiling | not_profiling.
+consider_profiling() ->
+ case application:get_env(profile) of
+ {ok, true} ->
+ {ok, _Pid} = eprof:start(),
+ eprof:start_profiling([self()]);
+ _ ->
+ not_profiling
+ end.
diff --git a/src/ranch_conns_sup.erl b/src/ranch_conns_sup.erl
new file mode 100644
index 0000000..41c1919
--- /dev/null
+++ b/src/ranch_conns_sup.erl
@@ -0,0 +1,44 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+%% @private
+-module(ranch_conns_sup).
+-behaviour(supervisor).
+
+-export([start_link/0, start_protocol/5]). %% API.
+-export([init/1]). %% supervisor.
+
+%% API.
+
+-spec start_link() -> {ok, pid()}.
+start_link() ->
+ supervisor:start_link(?MODULE, []).
+
+-spec start_protocol(pid(), inet:socket(), module(), module(), any())
+ -> {ok, pid()}.
+start_protocol(ListenerPid, Socket, Transport, Protocol, Opts) ->
+ Protocol:start_link(ListenerPid, Socket, Transport, Opts).
+
+%% supervisor.
+
+-spec init([]) -> {'ok', {{'simple_one_for_one', 0, 1}, [{
+ any(), {atom() | tuple(), atom(), 'undefined' | [any()]},
+ 'permanent' | 'temporary' | 'transient',
+ 'brutal_kill' | 'infinity' | non_neg_integer(),
+ 'supervisor' | 'worker',
+ 'dynamic' | [atom() | tuple()]}]
+}}.
+init([]) ->
+ {ok, {{simple_one_for_one, 0, 1}, [{?MODULE, {?MODULE, start_protocol, []},
+ temporary, brutal_kill, worker, [?MODULE]}]}}.
diff --git a/src/ranch_listener.erl b/src/ranch_listener.erl
new file mode 100644
index 0000000..fbcb87a
--- /dev/null
+++ b/src/ranch_listener.erl
@@ -0,0 +1,224 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+%% @doc Public API for managing listeners.
+-module(ranch_listener).
+-behaviour(gen_server).
+
+-export([start_link/2, stop/1,
+ add_connection/4, move_connection/3, remove_connection/2, check_upgrades/2,
+ get_protocol_options/1, set_protocol_options/2]). %% API.
+-export([init/1, handle_call/3, handle_cast/2,
+ handle_info/2, terminate/2, code_change/3]). %% gen_server.
+
+-type pools() :: [{atom(), non_neg_integer()}].
+
+-record(state, {
+ conn_pools = [] :: pools(),
+ conns_table :: ets:tid(),
+ queue = undefined :: queue(),
+ max_conns = undefined :: non_neg_integer(),
+ proto_opts :: any(),
+ proto_opts_vsn = 1 :: non_neg_integer()
+}).
+
+%% API.
+
+%% @private
+%%
+%% We set the process priority to high because ranch_listener is the central
+%% gen_server in Ranch and is used to manage all the incoming connections.
+%% Setting the process priority to high ensures the connection-related code
+%% will always be executed when a connection needs it, allowing Ranch to
+%% scale far beyond what it would with a normal priority.
+-spec start_link(non_neg_integer(), any()) -> {ok, pid()}.
+start_link(MaxConns, ProtoOpts) ->
+ gen_server:start_link(?MODULE, [MaxConns, ProtoOpts],
+ [{spawn_opt, [{priority, high}]}]).
+
+%% @private
+-spec stop(pid()) -> stopped.
+stop(ServerPid) ->
+ gen_server:call(ServerPid, stop).
+
+%% @doc Add a connection to the given pool in the listener.
+%%
+%% Pools of connections are used to restrict the maximum number of connections
+%% depending on their type. By default, Ranch add all connections to the
+%% pool <em>default</em>. It also checks for the maximum number of connections
+%% in that pool before accepting again. This function only returns when there
+%% is free space in the pool.
+%%
+%% When a process managing a connection dies, the process is removed from the
+%% pool. If the socket has been sent to another process, it is up to the
+%% protocol code to inform the listener of the new <em>ConnPid</em> by removing
+%% the previous and adding the new one.
+%%
+%% This function also returns whether the protocol options have been modified.
+%% If so, then an {upgrade, ProtoOpts, OptsVsn} will be returned instead of
+%% the atom 'ok'. The acceptor can then continue with the new protocol options.
+-spec add_connection(pid(), atom(), pid(), non_neg_integer())
+ -> ok | {upgrade, any(), non_neg_integer()}.
+add_connection(ServerPid, Pool, ConnPid, OptsVsn) ->
+ gen_server:call(ServerPid, {add_connection, Pool, ConnPid, OptsVsn},
+ infinity).
+
+%% @doc Move a connection from one pool to another.
+-spec move_connection(pid(), atom(), pid()) -> ok.
+move_connection(ServerPid, DestPool, ConnPid) ->
+ gen_server:cast(ServerPid, {move_connection, DestPool, ConnPid}).
+
+%% @doc Remove the given connection from its pool.
+-spec remove_connection(pid(), pid()) -> ok.
+remove_connection(ServerPid, ConnPid) ->
+ gen_server:cast(ServerPid, {remove_connection, ConnPid}).
+
+%% @doc Return whether a protocol upgrade is required.
+-spec check_upgrades(pid(), non_neg_integer())
+ -> ok | {upgrade, any(), non_neg_integer()}.
+check_upgrades(ServerPid, OptsVsn) ->
+ gen_server:call(ServerPid, {check_upgrades, OptsVsn}).
+
+%% @doc Return the current protocol options.
+-spec get_protocol_options(pid()) -> {ok, any()}.
+get_protocol_options(ServerPid) ->
+ gen_server:call(ServerPid, get_protocol_options).
+
+%% @doc Upgrade the protocol options.
+-spec set_protocol_options(pid(), any()) -> ok.
+set_protocol_options(ServerPid, ProtoOpts) ->
+ gen_server:call(ServerPid, {set_protocol_options, ProtoOpts}).
+
+%% gen_server.
+
+%% @private
+-spec init(list()) -> {ok, #state{}}.
+init([MaxConns, ProtoOpts]) ->
+ ConnsTable = ets:new(connections_table, [set, private]),
+ Queue = queue:new(),
+ {ok, #state{conns_table=ConnsTable, max_conns=MaxConns,
+ proto_opts=ProtoOpts, queue=Queue}}.
+
+%% @private
+-spec handle_call(_, _, State)
+ -> {reply, ignored, State} | {stop, normal, stopped, State}.
+handle_call({add_connection, Pool, ConnPid, AccOptsVsn}, From, State=#state{
+ conn_pools=Pools, conns_table=ConnsTable,
+ queue=Queue, max_conns=MaxConns,
+ proto_opts=ProtoOpts, proto_opts_vsn=LisOptsVsn}) ->
+ {NbConns, Pools2} = add_pid(ConnPid, Pool, Pools, ConnsTable),
+ State2 = State#state{conn_pools=Pools2},
+ if AccOptsVsn =/= LisOptsVsn ->
+ {reply, {upgrade, ProtoOpts, LisOptsVsn}, State2};
+ NbConns > MaxConns ->
+ Queue2 = queue:in(From, Queue),
+ {noreply, State2#state{queue=Queue2}};
+ true ->
+ {reply, ok, State2}
+ end;
+handle_call({check_upgrades, AccOptsVsn}, _From, State=#state{
+ proto_opts=ProtoOpts, proto_opts_vsn=LisOptsVsn}) ->
+ if AccOptsVsn =/= LisOptsVsn ->
+ {reply, {upgrade, ProtoOpts, LisOptsVsn}, State};
+ true ->
+ {reply, ok, State}
+ end;
+handle_call(get_protocol_options, _From, State=#state{proto_opts=ProtoOpts}) ->
+ {reply, {ok, ProtoOpts}, State};
+handle_call({set_protocol_options, ProtoOpts}, _From,
+ State=#state{proto_opts_vsn=OptsVsn}) ->
+ {reply, ok, State#state{proto_opts=ProtoOpts, proto_opts_vsn=OptsVsn + 1}};
+handle_call(stop, _From, State) ->
+ {stop, normal, stopped, State};
+handle_call(_, _From, State) ->
+ {reply, ignored, State}.
+
+%% @private
+-spec handle_cast(_, State) -> {noreply, State}.
+handle_cast({move_connection, DestPool, ConnPid}, State=#state{
+ conn_pools=Pools, conns_table=ConnsTable}) ->
+ Pools2 = move_pid(ConnPid, DestPool, Pools, ConnsTable),
+ {noreply, State#state{conn_pools=Pools2}};
+handle_cast({remove_connection, ConnPid}, State=#state{
+ conn_pools=Pools, conns_table=ConnsTable, queue=Queue}) ->
+ {Pools2, Queue2} = remove_pid(ConnPid, Pools, ConnsTable, Queue),
+ {noreply, State#state{conn_pools=Pools2, queue=Queue2}};
+handle_cast(_Msg, State) ->
+ {noreply, State}.
+
+%% @private
+-spec handle_info(_, State) -> {noreply, State}.
+handle_info({'DOWN', _Ref, process, Pid, _Info}, State=#state{
+ conn_pools=Pools, conns_table=ConnsTable, queue=Queue}) ->
+ {Pools2, Queue2} = remove_pid(Pid, Pools, ConnsTable, Queue),
+ {noreply, State#state{conn_pools=Pools2, queue=Queue2}};
+handle_info(_Info, State) ->
+ {noreply, State}.
+
+%% @private
+-spec terminate(_, _) -> ok.
+terminate(_Reason, _State) ->
+ ok.
+
+%% @private
+-spec code_change(_, State, _) -> {ok, State}.
+code_change(_OldVsn, State, _Extra) ->
+ {ok, State}.
+
+%% Internal.
+
+%% @private
+-spec add_pid(pid(), atom(), pools(), ets:tid())
+ -> {non_neg_integer(), pools()}.
+add_pid(ConnPid, Pool, Pools, ConnsTable) ->
+ MonitorRef = erlang:monitor(process, ConnPid),
+ ConnPid ! {shoot, self()},
+ {NbConnsRet, Pools2} = case lists:keyfind(Pool, 1, Pools) of
+ false ->
+ {1, [{Pool, 1}|Pools]};
+ {Pool, NbConns} ->
+ NbConns2 = NbConns + 1,
+ {NbConns2, [{Pool, NbConns2}|lists:keydelete(Pool, 1, Pools)]}
+ end,
+ ets:insert(ConnsTable, {ConnPid, {MonitorRef, Pool}}),
+ {NbConnsRet, Pools2}.
+
+%% @private
+-spec move_pid(pid(), atom(), pools(), ets:tid()) -> pools().
+move_pid(ConnPid, DestPool, Pools, ConnsTable) ->
+ {MonitorRef, SrcPool} = ets:lookup_element(ConnsTable, ConnPid, 2),
+ ets:insert(ConnsTable, {ConnPid, {MonitorRef, DestPool}}),
+ {SrcPool, SrcNbConns} = lists:keyfind(SrcPool, 1, Pools),
+ DestNbConns = case lists:keyfind(DestPool, 1, Pools) of
+ false -> 1;
+ {DestPool, NbConns} -> NbConns + 1
+ end,
+ Pools2 = lists:keydelete(SrcPool, 1, lists:keydelete(DestPool, 1, Pools)),
+ [{SrcPool, SrcNbConns - 1}, {DestPool, DestNbConns}|Pools2].
+
+%% @private
+-spec remove_pid(pid(), pools(), ets:tid(), queue()) -> {pools(), queue()}.
+remove_pid(Pid, Pools, ConnsTable, Queue) ->
+ {MonitorRef, Pool} = ets:lookup_element(ConnsTable, Pid, 2),
+ erlang:demonitor(MonitorRef, [flush]),
+ {Pool, NbConns} = lists:keyfind(Pool, 1, Pools),
+ Pools2 = [{Pool, NbConns - 1}|lists:keydelete(Pool, 1, Pools)],
+ ets:delete(ConnsTable, Pid),
+ case queue:out(Queue) of
+ {{value, Client}, Queue2} ->
+ gen_server:reply(Client, ok),
+ {Pools2, Queue2};
+ _ ->
+ {Pools2, Queue}
+ end.
diff --git a/src/ranch_listener_sup.erl b/src/ranch_listener_sup.erl
new file mode 100644
index 0000000..c33194f
--- /dev/null
+++ b/src/ranch_listener_sup.erl
@@ -0,0 +1,46 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+%% @private
+-module(ranch_listener_sup).
+-behaviour(supervisor).
+
+-export([start_link/5]). %% API.
+-export([init/1]). %% supervisor.
+
+%% API.
+
+-spec start_link(non_neg_integer(), module(), any(), module(), any())
+ -> {ok, pid()}.
+start_link(NbAcceptors, Transport, TransOpts, Protocol, ProtoOpts) ->
+ MaxConns = proplists:get_value(max_connections, TransOpts, 1024),
+ {ok, SupPid} = supervisor:start_link(?MODULE, []),
+ {ok, ListenerPid} = supervisor:start_child(SupPid,
+ {ranch_listener, {ranch_listener, start_link, [MaxConns, ProtoOpts]},
+ permanent, 5000, worker, [ranch_listener]}),
+ {ok, ConnsPid} = supervisor:start_child(SupPid,
+ {ranch_conns_sup, {ranch_conns_sup, start_link, []},
+ permanent, 5000, supervisor, [ranch_conns_sup]}),
+ {ok, _PoolPid} = supervisor:start_child(SupPid,
+ {ranch_acceptors_sup, {ranch_acceptors_sup, start_link, [
+ NbAcceptors, Transport, TransOpts,
+ Protocol, ProtoOpts, ListenerPid, ConnsPid
+ ]}, permanent, 5000, supervisor, [ranch_acceptors_sup]}),
+ {ok, SupPid}.
+
+%% supervisor.
+
+-spec init([]) -> {ok, {{one_for_all, 10, 10}, []}}.
+init([]) ->
+ {ok, {{one_for_all, 10, 10}, []}}.
diff --git a/src/ranch_ssl.erl b/src/ranch_ssl.erl
new file mode 100644
index 0000000..10cba53
--- /dev/null
+++ b/src/ranch_ssl.erl
@@ -0,0 +1,170 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+%% @doc SSL transport API.
+%%
+%% Wrapper around <em>ssl</em> implementing the Ranch transport API.
+%%
+%% This transport requires the <em>crypto</em>, <em>public_key</em>
+%% and <em>ssl</em> applications to be started. If they aren't started,
+%% it will try to start them itself before opening a port to listen.
+%% Applications aren't stopped when the listening socket is closed, though.
+%%
+%% @see ssl
+-module(ranch_ssl).
+-export([name/0, messages/0, listen/1, accept/2, recv/3, send/2, setopts/2,
+ controlling_process/2, peername/1, close/1, sockname/1]).
+
+%% @doc Name of this transport API, <em>ssl</em>.
+-spec name() -> ssl.
+name() -> ssl.
+
+%% @doc Atoms used in the process messages sent by this API.
+%%
+%% They identify incoming data, closed connection and errors when receiving
+%% data in active mode.
+-spec messages() -> {ssl, ssl_closed, ssl_error}.
+messages() -> {ssl, ssl_closed, ssl_error}.
+
+%% @doc Setup a socket to listen on the given port on the local host.
+%%
+%% The available options are:
+%% <dl>
+%% <dt>port</dt><dd>Mandatory. TCP port number to open.</dd>
+%% <dt>backlog</dt><dd>Maximum length of the pending connections queue.
+%% Defaults to 1024.</dd>
+%% <dt>ip</dt><dd>Interface to listen on. Listen on all interfaces
+%% by default.</dd>
+%% <dt>certfile</dt><dd>Mandatory. Path to a file containing the user's
+%% certificate.</dd>
+%% <dt>keyfile</dt><dd>Optional. Path to the file containing the user's
+%% private PEM encoded key.</dd>
+%% <dt>cacertfile</dt><dd>Optional. Path to file containing PEM encoded
+%% CA certificates (trusted certificates used for verifying a peer
+%% certificate).</dd>
+%% <dt>password</dt><dd>Optional. String containing the user's password.
+%% All private keyfiles must be password protected currently.</dd>
+%% <dt>ciphers</dt><dd>Optional. The cipher suites that should be supported.
+%% The function ssl:cipher_suites/0 can be used to find all available
+%% ciphers.</dd>
+%% </dl>
+%%
+%% @see ssl:listen/2
+-spec listen([{port, inet:port_number()} | {certfile, string()}
+ | {keyfile, string()} | {password, string()}
+ | {cacertfile, string()} | {ip, inet:ip_address()}])
+ -> {ok, ssl:sslsocket()} | {error, atom()}.
+listen(Opts) ->
+ require([crypto, public_key, ssl]),
+ {port, Port} = lists:keyfind(port, 1, Opts),
+ Backlog = proplists:get_value(backlog, Opts, 1024),
+ {certfile, CertFile} = lists:keyfind(certfile, 1, Opts),
+
+ ListenOpts0 = [binary, {active, false},
+ {backlog, Backlog}, {packet, raw}, {reuseaddr, true},
+ {certfile, CertFile}],
+ ListenOpts = lists:foldl(fun
+ ({ip, _} = Ip, Acc) -> [Ip | Acc];
+ ({keyfile, _} = KeyFile, Acc) -> [KeyFile | Acc];
+ ({cacertfile, _} = CACertFile, Acc) -> [CACertFile | Acc];
+ ({password, _} = Password, Acc) -> [Password | Acc];
+ ({ciphers, _} = Ciphers, Acc) -> [Ciphers | Acc];
+ (_, Acc) -> Acc
+ end, ListenOpts0, Opts),
+ ssl:listen(Port, ListenOpts).
+
+%% @doc Accept an incoming connection on a listen socket.
+%%
+%% Note that this function does both the transport accept and
+%% the SSL handshake.
+%%
+%% @see ssl:transport_accept/2
+%% @see ssl:ssl_accept/2
+-spec accept(ssl:sslsocket(), timeout())
+ -> {ok, ssl:sslsocket()} | {error, closed | timeout | atom()}.
+accept(LSocket, Timeout) ->
+ case ssl:transport_accept(LSocket, Timeout) of
+ {ok, CSocket} ->
+ ssl_accept(CSocket, Timeout);
+ {error, Reason} ->
+ {error, Reason}
+ end.
+
+%% @doc Receive a packet from a socket in passive mode.
+%% @see ssl:recv/3
+-spec recv(ssl:sslsocket(), non_neg_integer(), timeout())
+ -> {ok, any()} | {error, closed | atom()}.
+recv(Socket, Length, Timeout) ->
+ ssl:recv(Socket, Length, Timeout).
+
+%% @doc Send a packet on a socket.
+%% @see ssl:send/2
+-spec send(ssl:sslsocket(), iolist()) -> ok | {error, atom()}.
+send(Socket, Packet) ->
+ ssl:send(Socket, Packet).
+
+%% @doc Set one or more options for a socket.
+%% @see ssl:setopts/2
+-spec setopts(ssl:sslsocket(), list()) -> ok | {error, atom()}.
+setopts(Socket, Opts) ->
+ ssl:setopts(Socket, Opts).
+
+%% @doc Assign a new controlling process <em>Pid</em> to <em>Socket</em>.
+%% @see ssl:controlling_process/2
+-spec controlling_process(ssl:sslsocket(), pid())
+ -> ok | {error, closed | not_owner | atom()}.
+controlling_process(Socket, Pid) ->
+ ssl:controlling_process(Socket, Pid).
+
+%% @doc Return the address and port for the other end of a connection.
+%% @see ssl:peername/1
+-spec peername(ssl:sslsocket())
+ -> {ok, {inet:ip_address(), inet:port_number()}} | {error, atom()}.
+peername(Socket) ->
+ ssl:peername(Socket).
+
+%% @doc Close a TCP socket.
+%% @see ssl:close/1
+-spec close(ssl:sslsocket()) -> ok.
+close(Socket) ->
+ ssl:close(Socket).
+
+%% @doc Get the local address and port of a socket
+%% @see ssl:sockname/1
+-spec sockname(ssl:sslsocket())
+ -> {ok, {inet:ip_address(), inet:port_number()}} | {error, atom()}.
+sockname(Socket) ->
+ ssl:sockname(Socket).
+
+%% Internal.
+
+-spec require(list(module())) -> ok.
+require([]) ->
+ ok;
+require([App|Tail]) ->
+ case application:start(App) of
+ ok -> ok;
+ {error, {already_started, App}} -> ok
+ end,
+ require(Tail).
+
+-spec ssl_accept(ssl:sslsocket(), timeout())
+ -> {ok, ssl:sslsocket()} | {error, closed | timeout | atom()}.
+ssl_accept(Socket, Timeout) ->
+ case ssl:ssl_accept(Socket, Timeout) of
+ ok ->
+ {ok, Socket};
+ {error, Reason} ->
+ {error, Reason}
+ end.
diff --git a/src/ranch_sup.erl b/src/ranch_sup.erl
new file mode 100644
index 0000000..942522d
--- /dev/null
+++ b/src/ranch_sup.erl
@@ -0,0 +1,40 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+%% @private
+-module(ranch_sup).
+-behaviour(supervisor).
+
+-export([start_link/0]). %% API.
+-export([init/1]). %% supervisor.
+
+-define(SUPERVISOR, ?MODULE).
+
+%% API.
+
+-spec start_link() -> {ok, pid()}.
+start_link() ->
+ supervisor:start_link({local, ?SUPERVISOR}, ?MODULE, []).
+
+%% supervisor.
+
+-spec init([]) -> {'ok', {{'one_for_one', 10, 10}, [{
+ any(), {atom() | tuple(), atom(), 'undefined' | [any()]},
+ 'permanent' | 'temporary' | 'transient',
+ 'brutal_kill' | 'infinity' | non_neg_integer(),
+ 'supervisor' | 'worker',
+ 'dynamic' | [atom() | tuple()]}]
+}}.
+init([]) ->
+ {ok, {{one_for_one, 10, 10}, []}}.
diff --git a/src/ranch_tcp.erl b/src/ranch_tcp.erl
new file mode 100644
index 0000000..5c2a61d
--- /dev/null
+++ b/src/ranch_tcp.erl
@@ -0,0 +1,113 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+%% @doc TCP transport API.
+%%
+%% Wrapper around <em>gen_tcp</em> implementing the Ranch transport API.
+%%
+%% @see gen_tcp
+-module(ranch_tcp).
+
+-export([name/0, messages/0, listen/1, accept/2, recv/3, send/2, setopts/2,
+ controlling_process/2, peername/1, close/1, sockname/1]).
+
+%% @doc Name of this transport API, <em>tcp</em>.
+-spec name() -> tcp.
+name() -> tcp.
+
+%% @doc Atoms used in the process messages sent by this API.
+%%
+%% They identify incoming data, closed connection and errors when receiving
+%% data in active mode.
+-spec messages() -> {tcp, tcp_closed, tcp_error}.
+messages() -> {tcp, tcp_closed, tcp_error}.
+
+%% @doc Setup a socket to listen on the given port on the local host.
+%%
+%% The available options are:
+%% <dl>
+%% <dt>port</dt><dd>Mandatory. TCP port number to open.</dd>
+%% <dt>backlog</dt><dd>Maximum length of the pending connections queue.
+%% Defaults to 1024.</dd>
+%% <dt>ip</dt><dd>Interface to listen on. Listen on all interfaces
+%% by default.</dd>
+%% </dl>
+%%
+%% @see gen_tcp:listen/2
+-spec listen([{port, inet:port_number()} | {ip, inet:ip_address()}])
+ -> {ok, inet:socket()} | {error, atom()}.
+listen(Opts) ->
+ {port, Port} = lists:keyfind(port, 1, Opts),
+ Backlog = proplists:get_value(backlog, Opts, 1024),
+ ListenOpts0 = [binary, {active, false},
+ {backlog, Backlog}, {packet, raw}, {reuseaddr, true}],
+ ListenOpts =
+ case lists:keyfind(ip, 1, Opts) of
+ false -> ListenOpts0;
+ Ip -> [Ip|ListenOpts0]
+ end,
+ gen_tcp:listen(Port, ListenOpts).
+
+%% @doc Accept an incoming connection on a listen socket.
+%% @see gen_tcp:accept/2
+-spec accept(inet:socket(), timeout())
+ -> {ok, inet:socket()} | {error, closed | timeout | atom()}.
+accept(LSocket, Timeout) ->
+ gen_tcp:accept(LSocket, Timeout).
+
+%% @doc Receive a packet from a socket in passive mode.
+%% @see gen_tcp:recv/3
+-spec recv(inet:socket(), non_neg_integer(), timeout())
+ -> {ok, any()} | {error, closed | atom()}.
+recv(Socket, Length, Timeout) ->
+ gen_tcp:recv(Socket, Length, Timeout).
+
+%% @doc Send a packet on a socket.
+%% @see gen_tcp:send/2
+-spec send(inet:socket(), iolist()) -> ok | {error, atom()}.
+send(Socket, Packet) ->
+ gen_tcp:send(Socket, Packet).
+
+%% @doc Set one or more options for a socket.
+%% @see inet:setopts/2
+-spec setopts(inet:socket(), list()) -> ok | {error, atom()}.
+setopts(Socket, Opts) ->
+ inet:setopts(Socket, Opts).
+
+%% @doc Assign a new controlling process <em>Pid</em> to <em>Socket</em>.
+%% @see gen_tcp:controlling_process/2
+-spec controlling_process(inet:socket(), pid())
+ -> ok | {error, closed | not_owner | atom()}.
+controlling_process(Socket, Pid) ->
+ gen_tcp:controlling_process(Socket, Pid).
+
+%% @doc Return the address and port for the other end of a connection.
+%% @see inet:peername/1
+-spec peername(inet:socket())
+ -> {ok, {inet:ip_address(), inet:port_number()}} | {error, atom()}.
+peername(Socket) ->
+ inet:peername(Socket).
+
+%% @doc Close a TCP socket.
+%% @see gen_tcp:close/1
+-spec close(inet:socket()) -> ok.
+close(Socket) ->
+ gen_tcp:close(Socket).
+
+%% @doc Get the local address and port of a socket
+%% @see inet:sockname/1
+-spec sockname(inet:socket())
+ -> {ok, {inet:ip_address(), inet:port_number()}} | {error, atom()}.
+sockname(Socket) ->
+ inet:sockname(Socket).
diff --git a/test/acceptor_SUITE.erl b/test/acceptor_SUITE.erl
new file mode 100644
index 0000000..cfb5cd8
--- /dev/null
+++ b/test/acceptor_SUITE.erl
@@ -0,0 +1,52 @@
+%% Copyright (c) 2011-2012, Loïc Hoguin <[email protected]>
+%%
+%% Permission to use, copy, modify, and/or distribute this software for any
+%% purpose with or without fee is hereby granted, provided that the above
+%% copyright notice and this permission notice appear in all copies.
+%%
+%% THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
+%% WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+%% MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
+%% ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+%% WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+%% ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
+%% OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
+
+-module(acceptor_SUITE).
+
+-include_lib("common_test/include/ct.hrl").
+
+-export([all/0, groups/0, init_per_suite/1, end_per_suite/1]). %% ct.
+-export([tcp_echo/1]). %% tcp.
+
+%% ct.
+
+all() ->
+ [{group, tcp}].
+
+groups() ->
+ Tests = [tcp_echo],
+ [{tcp, Tests}].
+
+init_per_suite(Config) ->
+ application:start(ranch),
+ Config.
+
+end_per_suite(_) ->
+ application:stop(ranch),
+ ok.
+
+%% tcp.
+
+tcp_echo(_) ->
+ %% @todo Don't use a fixed port. start_listener should return the port used?
+ {ok, _} = ranch:start_listener(tcp_echo, 1,
+ ranch_tcp, [{port, 33333}],
+ echo_protocol, []),
+ {ok, Socket} = gen_tcp:connect("localhost", 33333,
+ [binary, {active, false}, {packet, raw}]),
+ ok = gen_tcp:send(Socket, <<"Ranch is working!">>),
+ {ok, <<"Ranch is working!">>} = gen_tcp:recv(Socket, 0, 1000),
+ ok = ranch:stop_listener(tcp_echo),
+ {error, closed} = gen_tcp:recv(Socket, 0, 1000),
+ ok.
diff --git a/test/echo_protocol.erl b/test/echo_protocol.erl
new file mode 100644
index 0000000..950cb06
--- /dev/null
+++ b/test/echo_protocol.erl
@@ -0,0 +1,19 @@
+-module(echo_protocol).
+-export([start_link/4, init/4]).
+
+start_link(ListenerPid, Socket, Transport, Opts) ->
+ Pid = spawn_link(?MODULE, init, [ListenerPid, Socket, Transport, Opts]),
+ {ok, Pid}.
+
+init(ListenerPid, Socket, Transport, _Opts = []) ->
+ ok = ranch:accept_ack(ListenerPid),
+ loop(Socket, Transport).
+
+loop(Socket, Transport) ->
+ case Transport:recv(Socket, 0, 5000) of
+ {ok, Data} ->
+ Transport:send(Socket, Data),
+ loop(Socket, Transport);
+ _ ->
+ ok = Transport:close(Socket)
+ end.