Improve the pubsub design and fix the race-condition issue

This commit is contained in:
Feng Lee 2017-11-17 20:51:51 +08:00
parent cae743803b
commit 8f00e28576
5 changed files with 321 additions and 293 deletions

View File

@ -31,8 +31,7 @@
unsubscribe/1, unsubscribe/2]). unsubscribe/1, unsubscribe/2]).
%% PubSub Management API %% PubSub Management API
-export([setqos/3, topics/0, subscriptions/1, subscribers/1, -export([setqos/3, topics/0, subscriptions/1, subscribers/1, subscribed/2]).
is_subscribed/2, subscriber_down/1]).
%% Hooks API %% Hooks API
-export([hook/4, hook/3, unhook/2, run_hooks/2, run_hooks/3]). -export([hook/4, hook/3, unhook/2, run_hooks/2, run_hooks/3]).
@ -43,14 +42,13 @@
%% Shutdown and reboot %% Shutdown and reboot
-export([shutdown/0, shutdown/1, reboot/0]). -export([shutdown/0, shutdown/1, reboot/0]).
-type(subscriber() :: pid() | binary()). -type(subid() :: binary()).
-type(subscriber() :: pid() | subid() | {subid(), pid()}).
-type(suboption() :: local | {qos, non_neg_integer()} | {share, {'$queue' | binary()}}). -type(suboption() :: local | {qos, non_neg_integer()} | {share, {'$queue' | binary()}}).
-type(pubsub_error() :: {error, {already_subscribed, binary()} -export_type([subscriber/0, suboption/0]).
| {subscription_not_found, binary()}}).
-export_type([subscriber/0, suboption/0, pubsub_error/0]).
-define(APP, ?MODULE). -define(APP, ?MODULE).
@ -59,19 +57,19 @@
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% @doc Start emqttd application. %% @doc Start emqttd application.
-spec(start() -> ok | {error, any()}). -spec(start() -> ok | {error, term()}).
start() -> application:start(?APP). start() -> application:start(?APP).
%% @doc Stop emqttd application. %% @doc Stop emqttd application.
-spec(stop() -> ok | {error, any()}). -spec(stop() -> ok | {error, term()}).
stop() -> application:stop(?APP). stop() -> application:stop(?APP).
%% @doc Environment %% @doc Environment
-spec(env(Key:: atom()) -> {ok, any()} | undefined). -spec(env(Key :: atom()) -> {ok, any()} | undefined).
env(Key) -> application:get_env(?APP, Key). env(Key) -> application:get_env(?APP, Key).
%% @doc Get environment %% @doc Get environment
-spec(env(Key:: atom(), Default:: any()) -> undefined | any()). -spec(env(Key :: atom(), Default :: any()) -> undefined | any()).
env(Key, Default) -> application:get_env(?APP, Key, Default). env(Key, Default) -> application:get_env(?APP, Key, Default).
%% @doc Is running? %% @doc Is running?
@ -88,15 +86,15 @@ is_running(Node) ->
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% @doc Subscribe %% @doc Subscribe
-spec(subscribe(iodata()) -> ok | {error, any()}). -spec(subscribe(iodata()) -> ok | {error, term()}).
subscribe(Topic) -> subscribe(Topic) ->
subscribe(Topic, self()). emqttd_server:subscribe(iolist_to_binary(Topic)).
-spec(subscribe(iodata(), subscriber()) -> ok | {error, any()}). -spec(subscribe(iodata(), subscriber()) -> ok | {error, term()}).
subscribe(Topic, Subscriber) -> subscribe(Topic, Subscriber) ->
subscribe(Topic, Subscriber, []). emqttd_server:subscribe(iolist_to_binary(Topic), Subscriber).
-spec(subscribe(iodata(), subscriber(), [suboption()]) -> ok | pubsub_error()). -spec(subscribe(iodata(), subscriber(), [suboption()]) -> ok | {error, term()}).
subscribe(Topic, Subscriber, Options) -> subscribe(Topic, Subscriber, Options) ->
emqttd_server:subscribe(iolist_to_binary(Topic), Subscriber, Options). emqttd_server:subscribe(iolist_to_binary(Topic), Subscriber, Options).
@ -106,11 +104,11 @@ publish(Msg) ->
emqttd_server:publish(Msg). emqttd_server:publish(Msg).
%% @doc Unsubscribe %% @doc Unsubscribe
-spec(unsubscribe(iodata()) -> ok | pubsub_error()). -spec(unsubscribe(iodata()) -> ok | {error, term()}).
unsubscribe(Topic) -> unsubscribe(Topic) ->
unsubscribe(Topic, self()). emqttd_server:unsubscribe(iolist_to_binary(Topic)).
-spec(unsubscribe(iodata(), subscriber()) -> ok | pubsub_error()). -spec(unsubscribe(iodata(), subscriber()) -> ok | {error, term()}).
unsubscribe(Topic, Subscriber) -> unsubscribe(Topic, Subscriber) ->
emqttd_server:unsubscribe(iolist_to_binary(Topic), Subscriber). emqttd_server:unsubscribe(iolist_to_binary(Topic), Subscriber).
@ -125,17 +123,13 @@ topics() -> emqttd_router:topics().
subscribers(Topic) -> subscribers(Topic) ->
emqttd_server:subscribers(iolist_to_binary(Topic)). emqttd_server:subscribers(iolist_to_binary(Topic)).
-spec(subscriptions(subscriber()) -> [{binary(), binary(), list(suboption())}]). -spec(subscriptions(subscriber()) -> [{emqttd:subscriber(), binary(), list(emqttd:suboption())}]).
subscriptions(Subscriber) -> subscriptions(Subscriber) ->
emqttd_server:subscriptions(Subscriber). emqttd_server:subscriptions(Subscriber).
-spec(is_subscribed(iodata(), subscriber()) -> boolean()). -spec(subscribed(iodata(), subscriber()) -> boolean()).
is_subscribed(Topic, Subscriber) -> subscribed(Topic, Subscriber) ->
emqttd_server:is_subscribed(iolist_to_binary(Topic), Subscriber). emqttd_server:subscribed(iolist_to_binary(Topic), Subscriber).
-spec(subscriber_down(subscriber()) -> ok).
subscriber_down(Subscriber) ->
emqttd_server:subscriber_down(Subscriber).
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% Hooks API %% Hooks API

View File

@ -46,7 +46,7 @@
%% Start PubSub %% Start PubSub
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
-spec(start_link(atom(), pos_integer(), list()) -> {ok, pid()} | ignore | {error, any()}). -spec(start_link(atom(), pos_integer(), list()) -> {ok, pid()} | ignore | {error, term()}).
start_link(Pool, Id, Env) -> start_link(Pool, Id, Env) ->
gen_server2:start_link({local, ?PROC_NAME(?MODULE, Id)}, ?MODULE, [Pool, Id, Env], []). gen_server2:start_link({local, ?PROC_NAME(?MODULE, Id)}, ?MODULE, [Pool, Id, Env], []).
@ -54,7 +54,7 @@ start_link(Pool, Id, Env) ->
%% PubSub API %% PubSub API
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% @doc Subscribe a Topic %% @doc Subscribe to a Topic
-spec(subscribe(binary(), emqttd:subscriber(), [emqttd:suboption()]) -> ok). -spec(subscribe(binary(), emqttd:subscriber(), [emqttd:suboption()]) -> ok).
subscribe(Topic, Subscriber, Options) -> subscribe(Topic, Subscriber, Options) ->
call(pick(Topic), {subscribe, Topic, Subscriber, Options}). call(pick(Topic), {subscribe, Topic, Subscriber, Options}).
@ -63,8 +63,8 @@ subscribe(Topic, Subscriber, Options) ->
async_subscribe(Topic, Subscriber, Options) -> async_subscribe(Topic, Subscriber, Options) ->
cast(pick(Topic), {subscribe, Topic, Subscriber, Options}). cast(pick(Topic), {subscribe, Topic, Subscriber, Options}).
%% @doc Publish MQTT Message to Topic %% @doc Publish MQTT Message to Topic.
-spec(publish(binary(), any()) -> {ok, mqtt_delivery()} | ignore). -spec(publish(binary(), mqtt_message()) -> {ok, mqtt_delivery()} | ignore).
publish(Topic, Msg) -> publish(Topic, Msg) ->
route(lists:append(emqttd_router:match(Topic), route(lists:append(emqttd_router:match(Topic),
emqttd_router:match_local(Topic)), delivery(Msg)). emqttd_router:match_local(Topic)), delivery(Msg)).
@ -72,7 +72,7 @@ publish(Topic, Msg) ->
route([], #mqtt_delivery{message = #mqtt_message{topic = Topic}}) -> route([], #mqtt_delivery{message = #mqtt_message{topic = Topic}}) ->
dropped(Topic), ignore; dropped(Topic), ignore;
%% Dispatch on the local node %% Dispatch on the local node.
route([#mqtt_route{topic = To, node = Node}], route([#mqtt_route{topic = To, node = Node}],
Delivery = #mqtt_delivery{flows = Flows}) when Node =:= node() -> Delivery = #mqtt_delivery{flows = Flows}) when Node =:= node() ->
dispatch(To, Delivery#mqtt_delivery{flows = [{route, Node, To} | Flows]}); dispatch(To, Delivery#mqtt_delivery{flows = [{route, Node, To} | Flows]});
@ -82,8 +82,8 @@ route([#mqtt_route{topic = To, node = Node}], Delivery = #mqtt_delivery{flows =
forward(Node, To, Delivery#mqtt_delivery{flows = [{route, Node, To}|Flows]}); forward(Node, To, Delivery#mqtt_delivery{flows = [{route, Node, To}|Flows]});
route(Routes, Delivery) -> route(Routes, Delivery) ->
{ok, lists:foldl(fun(Route, DelAcc) -> {ok, lists:foldl(fun(Route, Acc) ->
{ok, DelAcc1} = route([Route], DelAcc), DelAcc1 {ok, Acc1} = route([Route], Acc), Acc1
end, Delivery, Routes)}. end, Delivery, Routes)}.
delivery(Msg) -> #mqtt_delivery{sender = self(), message = Msg, flows = []}. delivery(Msg) -> #mqtt_delivery{sender = self(), message = Msg, flows = []}.
@ -92,7 +92,7 @@ delivery(Msg) -> #mqtt_delivery{sender = self(), message = Msg, flows = []}.
forward(Node, To, Delivery) -> forward(Node, To, Delivery) ->
rpc:cast(Node, ?PUBSUB, dispatch, [To, Delivery]), {ok, Delivery}. rpc:cast(Node, ?PUBSUB, dispatch, [To, Delivery]), {ok, Delivery}.
%% @doc Dispatch Message to Subscribers %% @doc Dispatch Message to Subscribers.
-spec(dispatch(binary(), mqtt_delivery()) -> mqtt_delivery()). -spec(dispatch(binary(), mqtt_delivery()) -> mqtt_delivery()).
dispatch(Topic, Delivery = #mqtt_delivery{message = Msg, flows = Flows}) -> dispatch(Topic, Delivery = #mqtt_delivery{message = Msg, flows = Flows}) ->
case subscribers(Topic) of case subscribers(Topic) of
@ -107,16 +107,16 @@ dispatch(Topic, Delivery = #mqtt_delivery{message = Msg, flows = Flows}) ->
{ok, Delivery#mqtt_delivery{flows = Flows1}} {ok, Delivery#mqtt_delivery{flows = Flows1}}
end. end.
dispatch(Pid, Topic, Msg) when is_pid(Pid) -> %%TODO: Is SubPid aliving???
Pid ! {dispatch, Topic, Msg}; dispatch(SubPid, Topic, Msg) when is_pid(SubPid) ->
dispatch(SubId, Topic, Msg) when is_binary(SubId) -> SubPid ! {dispatch, Topic, Msg};
emqttd_sm:dispatch(SubId, Topic, Msg); dispatch({SubId, SubPid}, Topic, Msg) when is_binary(SubId), is_pid(SubPid) ->
dispatch({_Share, [Sub]}, Topic, Msg) -> SubPid ! {dispatch, Topic, Msg};
dispatch({{share, _Share}, [Sub]}, Topic, Msg) ->
dispatch(Sub, Topic, Msg); dispatch(Sub, Topic, Msg);
dispatch({_Share, []}, _Topic, _Msg) -> dispatch({{share, _Share}, []}, _Topic, _Msg) ->
ok; ok;
%%TODO: round-robbin dispatch({{share, _Share}, Subs}, Topic, Msg) -> %% round-robbin?
dispatch({_Share, Subs}, Topic, Msg) ->
dispatch(lists:nth(rand:uniform(length(Subs)), Subs), Topic, Msg). dispatch(lists:nth(rand:uniform(length(Subs)), Subs), Topic, Msg).
subscribers(Topic) -> subscribers(Topic) ->
@ -126,8 +126,8 @@ group_by_share([]) -> [];
group_by_share(Subscribers) -> group_by_share(Subscribers) ->
{Subs1, Shares1} = {Subs1, Shares1} =
lists:foldl(fun({Share, Sub}, {Subs, Shares}) -> lists:foldl(fun({share, Share, Sub}, {Subs, Shares}) ->
{Subs, dict:append(Share, Sub, Shares)}; {Subs, dict:append({share, Share}, Sub, Shares)};
(Sub, {Subs, Shares}) -> (Sub, {Subs, Shares}) ->
{[Sub|Subs], Shares} {[Sub|Subs], Shares}
end, {[], dict:new()}, Subscribers), end, {[], dict:new()}, Subscribers),
@ -155,8 +155,8 @@ call(PubSub, Req) when is_pid(PubSub) ->
cast(PubSub, Msg) when is_pid(PubSub) -> cast(PubSub, Msg) when is_pid(PubSub) ->
gen_server2:cast(PubSub, Msg). gen_server2:cast(PubSub, Msg).
pick(Subscriber) -> pick(Topic) ->
gproc_pool:pick_worker(pubsub, Subscriber). gproc_pool:pick_worker(pubsub, Topic).
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% gen_server Callbacks %% gen_server Callbacks
@ -169,22 +169,22 @@ init([Pool, Id, Env]) ->
handle_call({subscribe, Topic, Subscriber, Options}, _From, State) -> handle_call({subscribe, Topic, Subscriber, Options}, _From, State) ->
add_subscriber(Topic, Subscriber, Options), add_subscriber(Topic, Subscriber, Options),
{reply, ok, setstats(State), hibernate}; reply(ok, setstats(State));
handle_call({unsubscribe, Topic, Subscriber, Options}, _From, State) -> handle_call({unsubscribe, Topic, Subscriber, Options}, _From, State) ->
del_subscriber(Topic, Subscriber, Options), del_subscriber(Topic, Subscriber, Options),
{reply, ok, setstats(State), hibernate}; reply(ok, setstats(State));
handle_call(Req, _From, State) -> handle_call(Req, _From, State) ->
?UNEXPECTED_REQ(Req, State). ?UNEXPECTED_REQ(Req, State).
handle_cast({subscribe, Topic, Subscriber, Options}, State) -> handle_cast({subscribe, Topic, Subscriber, Options}, State) ->
add_subscriber(Topic, Subscriber, Options), add_subscriber(Topic, Subscriber, Options),
{noreply, setstats(State), hibernate}; noreply(setstats(State));
handle_cast({unsubscribe, Topic, Subscriber, Options}, State) -> handle_cast({unsubscribe, Topic, Subscriber, Options}, State) ->
del_subscriber(Topic, Subscriber, Options), del_subscriber(Topic, Subscriber, Options),
{noreply, setstats(State), hibernate}; noreply(setstats(State));
handle_cast(Msg, State) -> handle_cast(Msg, State) ->
?UNEXPECTED_MSG(Msg, State). ?UNEXPECTED_MSG(Msg, State).
@ -205,39 +205,48 @@ code_change(_OldVsn, State, _Extra) ->
add_subscriber(Topic, Subscriber, Options) -> add_subscriber(Topic, Subscriber, Options) ->
Share = proplists:get_value(share, Options), Share = proplists:get_value(share, Options),
case ?is_local(Options) of case ?is_local(Options) of
false -> add_subscriber_(Share, Topic, Subscriber); false -> add_global_subscriber(Share, Topic, Subscriber);
true -> add_local_subscriber_(Share, Topic, Subscriber) true -> add_local_subscriber(Share, Topic, Subscriber)
end. end.
add_subscriber_(Share, Topic, Subscriber) -> add_global_subscriber(Share, Topic, Subscriber) ->
(not ets:member(mqtt_subscriber, Topic)) andalso emqttd_router:add_route(Topic), case ets:member(mqtt_subscriber, Topic) and emqttd_router:has_route(Topic) of
true -> ok;
false -> emqttd_router:add_route(Topic)
end,
ets:insert(mqtt_subscriber, {Topic, shared(Share, Subscriber)}). ets:insert(mqtt_subscriber, {Topic, shared(Share, Subscriber)}).
add_local_subscriber_(Share, Topic, Subscriber) -> add_local_subscriber(Share, Topic, Subscriber) ->
(not ets:member(mqtt_subscriber, {local, Topic})) andalso emqttd_router:add_local_route(Topic), (not ets:member(mqtt_subscriber, {local, Topic})) andalso emqttd_router:add_local_route(Topic),
ets:insert(mqtt_subscriber, {{local, Topic}, shared(Share, Subscriber)}). ets:insert(mqtt_subscriber, {{local, Topic}, shared(Share, Subscriber)}).
del_subscriber(Topic, Subscriber, Options) -> del_subscriber(Topic, Subscriber, Options) ->
Share = proplists:get_value(share, Options), Share = proplists:get_value(share, Options),
case ?is_local(Options) of case ?is_local(Options) of
false -> del_subscriber_(Share, Topic, Subscriber); false -> del_global_subscriber(Share, Topic, Subscriber);
true -> del_local_subscriber_(Share, Topic, Subscriber) true -> del_local_subscriber(Share, Topic, Subscriber)
end. end.
del_subscriber_(Share, Topic, Subscriber) -> del_global_subscriber(Share, Topic, Subscriber) ->
ets:delete_object(mqtt_subscriber, {Topic, shared(Share, Subscriber)}), ets:delete_object(mqtt_subscriber, {Topic, shared(Share, Subscriber)}),
(not ets:member(mqtt_subscriber, Topic)) andalso emqttd_router:del_route(Topic). (not ets:member(mqtt_subscriber, Topic)) andalso emqttd_router:del_route(Topic).
del_local_subscriber_(Share, Topic, Subscriber) -> del_local_subscriber(Share, Topic, Subscriber) ->
ets:delete_object(mqtt_subscriber, {{local, Topic}, shared(Share, Subscriber)}), ets:delete_object(mqtt_subscriber, {{local, Topic}, shared(Share, Subscriber)}),
(not ets:member(mqtt_subscriber, {local, Topic})) andalso emqttd_router:del_local_route(Topic). (not ets:member(mqtt_subscriber, {local, Topic})) andalso emqttd_router:del_local_route(Topic).
shared(undefined, Subscriber) -> shared(undefined, Subscriber) ->
Subscriber; Subscriber;
shared(Share, Subscriber) -> shared(Share, Subscriber) ->
{Share, Subscriber}. {share, Share, Subscriber}.
setstats(State) -> setstats(State) ->
emqttd_stats:setstats('subscribers/count', 'subscribers/max', ets:info(mqtt_subscriber, size)), emqttd_stats:setstats('subscribers/count', 'subscribers/max', ets:info(mqtt_subscriber, size)),
State. State.
reply(Reply, State) ->
{reply, Reply, State, hibernate}.
noreply(State) ->
{noreply, State, hibernate}.

View File

@ -28,15 +28,17 @@
-boot_mnesia({mnesia, [boot]}). -boot_mnesia({mnesia, [boot]}).
-copy_mnesia({mnesia, [copy]}). -copy_mnesia({mnesia, [copy]}).
%% Start/Stop -export([start_link/0, topics/0, local_topics/0]).
-export([start_link/0, topics/0, local_topics/0, stop/0]).
%% For eunit tests
-export([start/0, stop/0]).
%% Route APIs %% Route APIs
-export([add_route/1, add_route/2, add_routes/1, match/1, print/1, -export([add_route/1, del_route/1, match/1, print/1, has_route/1]).
del_route/1, del_route/2, del_routes/1, has_route/1]).
%% Local Route API %% Local Route API
-export([add_local_route/1, del_local_route/1, match_local/1]). -export([get_local_routes/0, add_local_route/1, match_local/1,
del_local_route/1, clean_local_routes/0]).
%% gen_server Function Exports %% gen_server Function Exports
-export([init/1, handle_call/3, handle_cast/2, handle_info/2, -export([init/1, handle_call/3, handle_cast/2, handle_info/2,
@ -55,10 +57,6 @@
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
mnesia(boot) -> mnesia(boot) ->
ok = ekka_mnesia:create_table(mqtt_topic, [
{ram_copies, [node()]},
{record_name, mqtt_topic},
{attributes, record_info(fields, mqtt_topic)}]),
ok = ekka_mnesia:create_table(mqtt_route, [ ok = ekka_mnesia:create_table(mqtt_route, [
{type, bag}, {type, bag},
{ram_copies, [node()]}, {ram_copies, [node()]},
@ -66,7 +64,6 @@ mnesia(boot) ->
{attributes, record_info(fields, mqtt_route)}]); {attributes, record_info(fields, mqtt_route)}]);
mnesia(copy) -> mnesia(copy) ->
ok = ekka_mnesia:copy_table(mqtt_topic),
ok = ekka_mnesia:copy_table(mqtt_route, ram_copies). ok = ekka_mnesia:copy_table(mqtt_route, ram_copies).
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
@ -77,19 +74,26 @@ start_link() ->
gen_server:start_link({local, ?ROUTER}, ?MODULE, [], []). gen_server:start_link({local, ?ROUTER}, ?MODULE, [], []).
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% API %% Topics
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
-spec(topics() -> list(binary())).
topics() -> topics() ->
mnesia:dirty_all_keys(mqtt_route). mnesia:dirty_all_keys(mqtt_route).
-spec(local_topics() -> list(binary())).
local_topics() -> local_topics() ->
ets:select(mqtt_local_route, [{{'$1', '_'}, [], ['$1']}]). ets:select(mqtt_local_route, [{{'$1', '_'}, [], ['$1']}]).
%%--------------------------------------------------------------------
%% Match API
%%--------------------------------------------------------------------
%% @doc Match Routes. %% @doc Match Routes.
-spec(match(Topic:: binary()) -> [mqtt_route()]). -spec(match(Topic:: binary()) -> [mqtt_route()]).
match(Topic) when is_binary(Topic) -> match(Topic) when is_binary(Topic) ->
Matched = mnesia:async_dirty(fun emqttd_trie:match/1, [Topic]), %% Optimize: ets???
Matched = mnesia:ets(fun emqttd_trie:match/1, [Topic]),
%% Optimize: route table will be replicated to all nodes. %% Optimize: route table will be replicated to all nodes.
lists:append([ets:lookup(mqtt_route, To) || To <- [Topic | Matched]]). lists:append([ets:lookup(mqtt_route, To) || To <- [Topic | Matched]]).
@ -99,93 +103,68 @@ print(Topic) ->
[io:format("~s -> ~s~n", [To, Node]) || [io:format("~s -> ~s~n", [To, Node]) ||
#mqtt_route{topic = To, node = Node} <- match(Topic)]. #mqtt_route{topic = To, node = Node} <- match(Topic)].
%% @doc Add Route %%--------------------------------------------------------------------
-spec(add_route(binary() | mqtt_route()) -> ok | {error, Reason :: any()}). %% Route Management API
%%--------------------------------------------------------------------
%% @doc Add Route.
-spec(add_route(binary() | mqtt_route()) -> ok | {error, Reason :: term()}).
add_route(Topic) when is_binary(Topic) -> add_route(Topic) when is_binary(Topic) ->
add_route(#mqtt_route{topic = Topic, node = node()}); add_route(#mqtt_route{topic = Topic, node = node()});
add_route(Route) when is_record(Route, mqtt_route) -> add_route(Route = #mqtt_route{topic = Topic}) ->
add_routes([Route]). case emqttd_topic:wildcard(Topic) of
true -> case mnesia:is_transaction() of
-spec(add_route(Topic :: binary(), Node :: node()) -> ok | {error, Reason :: any()}). true -> add_trie_route(Route);
add_route(Topic, Node) when is_binary(Topic), is_atom(Node) -> false -> trans(fun add_trie_route/1, [Route])
add_route(#mqtt_route{topic = Topic, node = Node}). end;
false -> add_direct_route(Route)
%% @doc Add Routes
-spec(add_routes([mqtt_route()]) -> ok | {error, Reason :: any()}).
add_routes(Routes) ->
AddFun = fun() -> [add_route_(Route) || Route <- Routes] end,
case mnesia:is_transaction() of
true -> AddFun();
false -> trans(AddFun)
end. end.
%% @private add_direct_route(Route) ->
add_route_(Route = #mqtt_route{topic = Topic}) -> mnesia:async_dirty(fun mnesia:write/1, [Route]).
add_trie_route(Route = #mqtt_route{topic = Topic}) ->
case mnesia:wread({mqtt_route, Topic}) of case mnesia:wread({mqtt_route, Topic}) of
[] -> [] -> emqttd_trie:insert(Topic);
case emqttd_topic:wildcard(Topic) of _ -> ok
true -> emqttd_trie:insert(Topic); end,
false -> ok mnesia:write(Route).
end,
mnesia:write(Route),
mnesia:write(#mqtt_topic{topic = Topic});
Records ->
case lists:member(Route, Records) of
true -> ok;
false -> mnesia:write(Route)
end
end.
%% @doc Delete Route %% @doc Delete Route
-spec(del_route(binary() | mqtt_route()) -> ok | {error, Reason :: any()}). -spec(del_route(binary() | mqtt_route()) -> ok | {error, Reason :: term()}).
del_route(Topic) when is_binary(Topic) -> del_route(Topic) when is_binary(Topic) ->
del_route(#mqtt_route{topic = Topic, node = node()}); del_route(#mqtt_route{topic = Topic, node = node()});
del_route(Route) when is_record(Route, mqtt_route) -> del_route(Route = #mqtt_route{topic = Topic}) ->
del_routes([Route]). case emqttd_topic:wildcard(Topic) of
true -> case mnesia:is_transaction() of
-spec(del_route(Topic :: binary(), Node :: node()) -> ok | {error, Reason :: any()}). true -> del_trie_route(Route);
del_route(Topic, Node) when is_binary(Topic), is_atom(Node) -> false -> trans(fun del_trie_route/1, [Route])
del_route(#mqtt_route{topic = Topic, node = Node}). end;
false -> del_direct_route(Route)
%% @doc Delete Routes
-spec(del_routes([mqtt_route()]) -> ok | {error, any()}).
del_routes(Routes) ->
DelFun = fun() -> [del_route_(Route) || Route <- Routes] end,
case mnesia:is_transaction() of
true -> DelFun();
false -> trans(DelFun)
end. end.
del_route_(Route = #mqtt_route{topic = Topic}) -> del_direct_route(Route) ->
mnesia:async_dirty(fun mnesia:delete_object/1, [Route]).
del_trie_route(Route = #mqtt_route{topic = Topic}) ->
case mnesia:wread({mqtt_route, Topic}) of case mnesia:wread({mqtt_route, Topic}) of
[] -> [Route] -> %% Remove route and trie
ok; mnesia:delete_object(Route),
[Route] -> emqttd_trie:delete(Topic);
%% Remove route and trie [_|_] -> %% Remove route only
mnesia:delete_object(Route), mnesia:delete_object(Route);
case emqttd_topic:wildcard(Topic) of [] -> ok
true -> emqttd_trie:delete(Topic);
false -> ok
end,
mnesia:delete({mqtt_topic, Topic});
_More ->
%% Remove route only
mnesia:delete_object(Route)
end. end.
%% @doc Has Route? %% @doc Has route?
-spec(has_route(binary()) -> boolean()). -spec(has_route(binary()) -> boolean()).
has_route(Topic) -> has_route(Topic) when is_binary(Topic) ->
Routes = case mnesia:is_transaction() of ets:member(mqtt_route, Topic).
true -> mnesia:read(mqtt_route, Topic);
false -> mnesia:dirty_read(mqtt_route, Topic)
end,
length(Routes) > 0.
%% @private %% @private
-spec(trans(function()) -> ok | {error, any()}). -spec(trans(function(), list(any())) -> ok | {error, term()}).
trans(Fun) -> trans(Fun, Args) ->
case mnesia:transaction(Fun) of case mnesia:transaction(Fun, Args) of
{atomic, _} -> ok; {atomic, _} -> ok;
{aborted, Error} -> {error, Error} {aborted, Error} -> {error, Error}
end. end.
@ -194,24 +173,44 @@ trans(Fun) ->
%% Local Route API %% Local Route API
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
-spec(get_local_routes() -> list({binary(), node()})).
get_local_routes() ->
ets:tab2list(mqtt_local_route).
-spec(add_local_route(binary()) -> ok). -spec(add_local_route(binary()) -> ok).
add_local_route(Topic) -> add_local_route(Topic) ->
gen_server:cast(?ROUTER, {add_local_route, Topic}). gen_server:call(?ROUTER, {add_local_route, Topic}).
-spec(del_local_route(binary()) -> ok). -spec(del_local_route(binary()) -> ok).
del_local_route(Topic) -> del_local_route(Topic) ->
gen_server:cast(?ROUTER, {del_local_route, Topic}). gen_server:call(?ROUTER, {del_local_route, Topic}).
-spec(match_local(binary()) -> [mqtt_route()]). -spec(match_local(binary()) -> [mqtt_route()]).
match_local(Name) -> match_local(Name) ->
[#mqtt_route{topic = {local, Filter}, node = Node} case ets:info(mqtt_local_route, size) of
|| {Filter, Node} <- ets:tab2list(mqtt_local_route), 0 -> [];
emqttd_topic:match(Name, Filter)]. _ -> ets:foldl(
fun({Filter, Node}, Matched) ->
case emqttd_topic:match(Name, Filter) of
true -> [#mqtt_route{topic = {local, Filter}, node = Node} | Matched];
false -> Matched
end
end, [], mqtt_local_route)
end.
-spec(clean_local_routes() -> ok).
clean_local_routes() ->
gen_server:call(?ROUTER, clean_local_routes).
dump() -> dump() ->
[{route, ets:tab2list(mqtt_route)}, {local_route, ets:tab2list(mqtt_local_route)}]. [{route, ets:tab2list(mqtt_route)}, {local_route, ets:tab2list(mqtt_local_route)}].
stop() -> gen_server:call(?ROUTER, stop). %% For unit test.
start() ->
gen_server:start({local, ?ROUTER}, ?MODULE, [], []).
stop() ->
gen_server:call(?ROUTER, stop).
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% gen_server Callbacks %% gen_server Callbacks
@ -223,21 +222,25 @@ init([]) ->
{ok, TRef} = timer:send_interval(timer:seconds(1), stats), {ok, TRef} = timer:send_interval(timer:seconds(1), stats),
{ok, #state{stats_timer = TRef}}. {ok, #state{stats_timer = TRef}}.
handle_call({add_local_route, Topic}, _From, State) ->
%% why node()...?
ets:insert(mqtt_local_route, {Topic, node()}),
{reply, ok, State};
handle_call({del_local_route, Topic}, _From, State) ->
ets:delete(mqtt_local_route, Topic),
{reply, ok, State};
handle_call(clean_local_routes, _From, State) ->
ets:delete_all_objects(mqtt_local_route),
{reply, ok, State};
handle_call(stop, _From, State) -> handle_call(stop, _From, State) ->
{stop, normal, ok, State}; {stop, normal, ok, State};
handle_call(_Req, _From, State) -> handle_call(_Req, _From, State) ->
{reply, ignore, State}. {reply, ignore, State}.
handle_cast({add_local_route, Topic}, State) ->
%% why node()...?
ets:insert(mqtt_local_route, {Topic, node()}),
{noreply, State};
handle_cast({del_local_route, Topic}, State) ->
ets:delete(mqtt_local_route, Topic),
{noreply, State};
handle_cast(_Msg, State) -> handle_cast(_Msg, State) ->
{noreply, State}. {noreply, State}.

View File

@ -37,8 +37,7 @@
async_unsubscribe/1, async_unsubscribe/2]). async_unsubscribe/1, async_unsubscribe/2]).
%% Management API. %% Management API.
-export([setqos/3, subscriptions/1, subscribers/1, is_subscribed/2, -export([setqos/3, subscriptions/1, subscribers/1, subscribed/2]).
subscriber_down/1]).
%% Debug API %% Debug API
-export([dump/0]). -export([dump/0]).
@ -47,10 +46,10 @@
-export([init/1, handle_call/3, handle_cast/2, handle_info/2, -export([init/1, handle_call/3, handle_cast/2, handle_info/2,
terminate/2, code_change/3]). terminate/2, code_change/3]).
-record(state, {pool, id, env, submon :: emqttd_pmon:pmon()}). -record(state, {pool, id, env, subids :: map(), submon :: emqttd_pmon:pmon()}).
%% @doc Start server %% @doc Start the server
-spec(start_link(atom(), pos_integer(), list()) -> {ok, pid()} | ignore | {error, any()}). -spec(start_link(atom(), pos_integer(), list()) -> {ok, pid()} | ignore | {error, term()}).
start_link(Pool, Id, Env) -> start_link(Pool, Id, Env) ->
gen_server2:start_link({local, ?PROC_NAME(?MODULE, Id)}, ?MODULE, [Pool, Id, Env], []). gen_server2:start_link({local, ?PROC_NAME(?MODULE, Id)}, ?MODULE, [Pool, Id, Env], []).
@ -58,21 +57,21 @@ start_link(Pool, Id, Env) ->
%% PubSub API %% PubSub API
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% @doc Subscribe a Topic %% @doc Subscribe to a Topic.
-spec(subscribe(binary()) -> ok | emqttd:pubsub_error()). -spec(subscribe(binary()) -> ok | {error, term()}).
subscribe(Topic) when is_binary(Topic) -> subscribe(Topic) when is_binary(Topic) ->
subscribe(Topic, self()). subscribe(Topic, self()).
-spec(subscribe(binary(), emqttd:subscriber()) -> ok | emqttd:pubsub_error()). -spec(subscribe(binary(), emqttd:subscriber()) -> ok | {error, term()}).
subscribe(Topic, Subscriber) when is_binary(Topic) -> subscribe(Topic, Subscriber) when is_binary(Topic) ->
subscribe(Topic, Subscriber, []). subscribe(Topic, Subscriber, []).
-spec(subscribe(binary(), emqttd:subscriber(), [emqttd:suboption()]) -> -spec(subscribe(binary(), emqttd:subscriber(), [emqttd:suboption()]) ->
ok | emqttd:pubsub_error()). ok | {error, term()}).
subscribe(Topic, Subscriber, Options) when is_binary(Topic) -> subscribe(Topic, Subscriber, Options) when is_binary(Topic) ->
call(pick(Subscriber), {subscribe, Topic, Subscriber, Options}). call(pick(Subscriber), {subscribe, Topic, with_subpid(Subscriber), Options}).
%% @doc Subscribe a Topic Asynchronously %% @doc Subscribe to a Topic asynchronously.
-spec(async_subscribe(binary()) -> ok). -spec(async_subscribe(binary()) -> ok).
async_subscribe(Topic) when is_binary(Topic) -> async_subscribe(Topic) when is_binary(Topic) ->
async_subscribe(Topic, self()). async_subscribe(Topic, self()).
@ -83,7 +82,7 @@ async_subscribe(Topic, Subscriber) when is_binary(Topic) ->
-spec(async_subscribe(binary(), emqttd:subscriber(), [emqttd:suboption()]) -> ok). -spec(async_subscribe(binary(), emqttd:subscriber(), [emqttd:suboption()]) -> ok).
async_subscribe(Topic, Subscriber, Options) when is_binary(Topic) -> async_subscribe(Topic, Subscriber, Options) when is_binary(Topic) ->
cast(pick(Subscriber), {subscribe, Topic, Subscriber, Options}). cast(pick(Subscriber), {subscribe, Topic, with_subpid(Subscriber), Options}).
%% @doc Publish message to Topic. %% @doc Publish message to Topic.
-spec(publish(mqtt_message()) -> {ok, mqtt_delivery()} | ignore). -spec(publish(mqtt_message()) -> {ok, mqtt_delivery()} | ignore).
@ -109,14 +108,14 @@ trace(publish, From, #mqtt_message{topic = Topic, payload = Payload}) ->
"~s PUBLISH to ~s: ~p", [From, Topic, Payload]). "~s PUBLISH to ~s: ~p", [From, Topic, Payload]).
%% @doc Unsubscribe %% @doc Unsubscribe
-spec(unsubscribe(binary()) -> ok | emqttd:pubsub_error()). -spec(unsubscribe(binary()) -> ok | {error, term()}).
unsubscribe(Topic) when is_binary(Topic) -> unsubscribe(Topic) when is_binary(Topic) ->
unsubscribe(Topic, self()). unsubscribe(Topic, self()).
%% @doc Unsubscribe %% @doc Unsubscribe
-spec(unsubscribe(binary(), emqttd:subscriber()) -> ok | emqttd:pubsub_error()). -spec(unsubscribe(binary(), emqttd:subscriber()) -> ok | {error, term()}).
unsubscribe(Topic, Subscriber) when is_binary(Topic) -> unsubscribe(Topic, Subscriber) when is_binary(Topic) ->
call(pick(Subscriber), {unsubscribe, Topic, Subscriber}). call(pick(Subscriber), {unsubscribe, Topic, with_subpid(Subscriber)}).
%% @doc Async Unsubscribe %% @doc Async Unsubscribe
-spec(async_unsubscribe(binary()) -> ok). -spec(async_unsubscribe(binary()) -> ok).
@ -125,32 +124,47 @@ async_unsubscribe(Topic) when is_binary(Topic) ->
-spec(async_unsubscribe(binary(), emqttd:subscriber()) -> ok). -spec(async_unsubscribe(binary(), emqttd:subscriber()) -> ok).
async_unsubscribe(Topic, Subscriber) when is_binary(Topic) -> async_unsubscribe(Topic, Subscriber) when is_binary(Topic) ->
cast(pick(Subscriber), {unsubscribe, Topic, Subscriber}). cast(pick(Subscriber), {unsubscribe, Topic, with_subpid(Subscriber)}).
-spec(setqos(binary(), emqttd:subscriber(), mqtt_qos()) -> ok).
setqos(Topic, Subscriber, Qos) when is_binary(Topic) -> setqos(Topic, Subscriber, Qos) when is_binary(Topic) ->
call(pick(Subscriber), {setqos, Topic, Subscriber, Qos}). call(pick(Subscriber), {setqos, Topic, with_subpid(Subscriber), Qos}).
-spec(subscriptions(emqttd:subscriber()) -> [{binary(), binary(), list(emqttd:suboption())}]). with_subpid(SubPid) when is_pid(SubPid) ->
subscriptions(Subscriber) -> SubPid;
lists:map(fun({_, {_Share, Topic}}) -> with_subpid(SubId) when is_binary(SubId) ->
subscription(Topic, Subscriber); {SubId, self()};
({_, Topic}) -> with_subpid({SubId, SubPid}) when is_binary(SubId), is_pid(SubPid) ->
subscription(Topic, Subscriber) {SubId, SubPid}.
end, ets:lookup(mqtt_subscription, Subscriber)).
subscription(Topic, Subscriber) -> -spec(subscriptions(emqttd:subscriber()) -> [{emqttd:subscriber(), binary(), list(emqttd:suboption())}]).
{Topic, Subscriber, ets:lookup_element(mqtt_subproperty, {Topic, Subscriber}, 2)}. subscriptions(SubPid) when is_pid(SubPid) ->
with_subproperty(ets:lookup(mqtt_subscription, SubPid));
subscribers(Topic) -> subscriptions(SubId) when is_binary(SubId) ->
with_subproperty(ets:match_object(mqtt_subscription, {{SubId, '_'}, '_'}));
subscriptions({SubId, SubPid}) when is_binary(SubId), is_pid(SubPid) ->
with_subproperty(ets:lookup(mqtt_subscription, {SubId, SubPid})).
with_subproperty({Subscriber, {share, _Share, Topic}}) ->
with_subproperty({Subscriber, Topic});
with_subproperty({Subscriber, Topic}) ->
{Subscriber, Topic, ets:lookup_element(mqtt_subproperty, {Topic, Subscriber}, 2)};
with_subproperty(Subscriptions) when is_list(Subscriptions) ->
[with_subproperty(Subscription) || Subscription <- Subscriptions].
-spec(subscribers(binary()) -> list(emqttd:subscriber())).
subscribers(Topic) when is_binary(Topic) ->
emqttd_pubsub:subscribers(Topic). emqttd_pubsub:subscribers(Topic).
-spec(is_subscribed(binary(), emqttd:subscriber()) -> boolean()). -spec(subscribed(binary(), emqttd:subscriber()) -> boolean()).
is_subscribed(Topic, Subscriber) when is_binary(Topic) -> subscribed(Topic, SubPid) when is_binary(Topic), is_pid(SubPid) ->
ets:member(mqtt_subproperty, {Topic, Subscriber}). ets:member(mqtt_subproperty, {Topic, SubPid});
subscribed(Topic, SubId) when is_binary(Topic), is_binary(SubId) ->
-spec(subscriber_down(emqttd:subscriber()) -> ok). length(ets:match_object(mqtt_subproperty, {{Topic, {SubId, '_'}}, '_'}, 1)) == 1;
subscriber_down(Subscriber) -> subscribed(Topic, {SubId, SubPid}) when is_binary(Topic), is_binary(SubId), is_pid(SubPid) ->
cast(pick(Subscriber), {subscriber_down, Subscriber}). ets:member(mqtt_subproperty, {Topic, {SubId, SubPid}}).
call(Server, Req) -> call(Server, Req) ->
gen_server2:call(Server, Req, infinity). gen_server2:call(Server, Req, infinity).
@ -158,8 +172,12 @@ call(Server, Req) ->
cast(Server, Msg) when is_pid(Server) -> cast(Server, Msg) when is_pid(Server) ->
gen_server2:cast(Server, Msg). gen_server2:cast(Server, Msg).
pick(Subscriber) -> pick(SubPid) when is_pid(SubPid) ->
gproc_pool:pick_worker(server, Subscriber). gproc_pool:pick_worker(server, SubPid);
pick(SubId) when is_binary(SubId) ->
gproc_pool:pick_worker(server, SubId);
pick({SubId, SubPid}) when is_binary(SubId), is_pid(SubPid) ->
pick(SubId).
dump() -> dump() ->
[{Tab, ets:tab2list(Tab)} || Tab <- [mqtt_subproperty, mqtt_subscription, mqtt_subscriber]]. [{Tab, ets:tab2list(Tab)} || Tab <- [mqtt_subproperty, mqtt_subscription, mqtt_subscriber]].
@ -170,18 +188,20 @@ dump() ->
init([Pool, Id, Env]) -> init([Pool, Id, Env]) ->
?GPROC_POOL(join, Pool, Id), ?GPROC_POOL(join, Pool, Id),
{ok, #state{pool = Pool, id = Id, env = Env, submon = emqttd_pmon:new()}}. State = #state{pool = Pool, id = Id, env = Env,
subids = #{}, submon = emqttd_pmon:new()},
{ok, State, hibernate, {backoff, 2000, 2000, 20000}}.
handle_call({subscribe, Topic, Subscriber, Options}, _From, State) -> handle_call({subscribe, Topic, Subscriber, Options}, _From, State) ->
case do_subscribe_(Topic, Subscriber, Options, State) of case do_subscribe(Topic, Subscriber, Options, State) of
{ok, NewState} -> {reply, ok, setstats(NewState)}; {ok, NewState} -> reply(ok, setstats(NewState));
{error, Error} -> {reply, {error, Error}, State} {error, Error} -> reply({error, Error}, State)
end; end;
handle_call({unsubscribe, Topic, Subscriber}, _From, State) -> handle_call({unsubscribe, Topic, Subscriber}, _From, State) ->
case do_unsubscribe_(Topic, Subscriber, State) of case do_unsubscribe(Topic, Subscriber, State) of
{ok, NewState} -> {reply, ok, setstats(NewState), hibernate}; {ok, NewState} -> reply(ok, setstats(NewState));
{error, Error} -> {reply, {error, Error}, State} {error, Error} -> reply({error, Error}, State)
end; end;
handle_call({setqos, Topic, Subscriber, Qos}, _From, State) -> handle_call({setqos, Topic, Subscriber, Qos}, _From, State) ->
@ -190,36 +210,37 @@ handle_call({setqos, Topic, Subscriber, Qos}, _From, State) ->
[{_, Opts}] -> [{_, Opts}] ->
Opts1 = lists:ukeymerge(1, [{qos, Qos}], Opts), Opts1 = lists:ukeymerge(1, [{qos, Qos}], Opts),
ets:insert(mqtt_subproperty, {Key, Opts1}), ets:insert(mqtt_subproperty, {Key, Opts1}),
{reply, ok, State}; reply(ok, State);
[] -> [] ->
{reply, {error, {subscription_not_found, Topic}}, State} reply({error, {subscription_not_found, Topic}}, State)
end; end;
handle_call(Req, _From, State) -> handle_call(Req, _From, State) ->
?UNEXPECTED_REQ(Req, State). ?UNEXPECTED_REQ(Req, State).
handle_cast({subscribe, Topic, Subscriber, Options}, State) -> handle_cast({subscribe, Topic, Subscriber, Options}, State) ->
case do_subscribe_(Topic, Subscriber, Options, State) of case do_subscribe(Topic, Subscriber, Options, State) of
{ok, NewState} -> {noreply, setstats(NewState)}; {ok, NewState} -> noreply(setstats(NewState));
{error, _Error} -> {noreply, State} {error, _Error} -> noreply(State)
end; end;
handle_cast({unsubscribe, Topic, Subscriber}, State) -> handle_cast({unsubscribe, Topic, Subscriber}, State) ->
case do_unsubscribe_(Topic, Subscriber, State) of case do_unsubscribe(Topic, Subscriber, State) of
{ok, NewState} -> {noreply, setstats(NewState), hibernate}; {ok, NewState} -> noreply(setstats(NewState));
{error, _Error} -> {noreply, State} {error, _Error} -> noreply(State)
end; end;
handle_cast({subscriber_down, Subscriber}, State) ->
subscriber_down_(Subscriber),
{noreply, setstats(State)};
handle_cast(Msg, State) -> handle_cast(Msg, State) ->
?UNEXPECTED_MSG(Msg, State). ?UNEXPECTED_MSG(Msg, State).
handle_info({'DOWN', _MRef, process, DownPid, _Reason}, State = #state{submon = PM}) -> handle_info({'DOWN', _MRef, process, DownPid, _Reason}, State = #state{subids = SubIds}) ->
subscriber_down_(DownPid), case maps:find(DownPid, SubIds) of
{noreply, setstats(State#state{submon = PM:erase(DownPid)}), hibernate}; {ok, SubId} ->
clean_subscriber({SubId, DownPid});
error ->
clean_subscriber(DownPid)
end,
noreply(setstats(demonitor_subscriber(DownPid, State)));
handle_info(Info, State) -> handle_info(Info, State) ->
?UNEXPECTED_INFO(Info, State). ?UNEXPECTED_INFO(Info, State).
@ -234,62 +255,54 @@ code_change(_OldVsn, State, _Extra) ->
%% Internal Functions %% Internal Functions
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
do_subscribe_(Topic, Subscriber, Options, State) -> do_subscribe(Topic, Subscriber, Options, State) ->
case ets:lookup(mqtt_subproperty, {Topic, Subscriber}) of case ets:lookup(mqtt_subproperty, {Topic, Subscriber}) of
[] -> [] ->
emqttd_pubsub:async_subscribe(Topic, Subscriber, Options), emqttd_pubsub:async_subscribe(Topic, Subscriber, Options),
Share = proplists:get_value(share, Options), Share = proplists:get_value(share, Options),
add_subscription_(Share, Subscriber, Topic), add_subscription(Share, Subscriber, Topic),
ets:insert(mqtt_subproperty, {{Topic, Subscriber}, Options}), ets:insert(mqtt_subproperty, {{Topic, Subscriber}, Options}),
{ok, monitor_subpid(Subscriber, State)}; {ok, monitor_subscriber(Subscriber, State)};
[_] -> [_] ->
{error, {already_subscribed, Topic}} {error, {already_subscribed, Topic}}
end. end.
add_subscription_(undefined, Subscriber, Topic) -> add_subscription(undefined, Subscriber, Topic) ->
ets:insert(mqtt_subscription, {Subscriber, Topic}); ets:insert(mqtt_subscription, {Subscriber, Topic});
add_subscription_(Share, Subscriber, Topic) -> add_subscription(Share, Subscriber, Topic) ->
ets:insert(mqtt_subscription, {Subscriber, {Share, Topic}}). ets:insert(mqtt_subscription, {Subscriber, {share, Share, Topic}}).
monitor_subpid(SubPid, State = #state{submon = PMon}) when is_pid(SubPid) -> monitor_subscriber(SubPid, State = #state{submon = SubMon}) when is_pid(SubPid) ->
State#state{submon = PMon:monitor(SubPid)}; State#state{submon = SubMon:monitor(SubPid)};
monitor_subpid(_SubPid, State) -> monitor_subscriber({SubId, SubPid}, State = #state{subids = SubIds, submon = SubMon}) ->
State. State#state{subids = maps:put(SubPid, SubId, SubIds), submon = SubMon:monitor(SubPid)}.
do_unsubscribe_(Topic, Subscriber, State) -> do_unsubscribe(Topic, Subscriber, State) ->
case ets:lookup(mqtt_subproperty, {Topic, Subscriber}) of case ets:lookup(mqtt_subproperty, {Topic, Subscriber}) of
[{_, Options}] -> [{_, Options}] ->
emqttd_pubsub:async_unsubscribe(Topic, Subscriber, Options), emqttd_pubsub:async_unsubscribe(Topic, Subscriber, Options),
Share = proplists:get_value(share, Options), Share = proplists:get_value(share, Options),
del_subscription_(Share, Subscriber, Topic), del_subscription(Share, Subscriber, Topic),
ets:delete(mqtt_subproperty, {Topic, Subscriber}), ets:delete(mqtt_subproperty, {Topic, Subscriber}),
{ok, case ets:member(mqtt_subscription, Subscriber) of {ok, State};
true -> State;
false -> demonitor_subpid(Subscriber, State)
end};
[] -> [] ->
{error, {subscription_not_found, Topic}} {error, {subscription_not_found, Topic}}
end. end.
del_subscription_(undefined, Subscriber, Topic) -> del_subscription(undefined, Subscriber, Topic) ->
ets:delete_object(mqtt_subscription, {Subscriber, Topic}); ets:delete_object(mqtt_subscription, {Subscriber, Topic});
del_subscription_(Share, Subscriber, Topic) -> del_subscription(Share, Subscriber, Topic) ->
ets:delete_object(mqtt_subscription, {Subscriber, {Share, Topic}}). ets:delete_object(mqtt_subscription, {Subscriber, {share, Share, Topic}}).
demonitor_subpid(SubPid, State = #state{submon = PMon}) when is_pid(SubPid) -> clean_subscriber(Subscriber) ->
State#state{submon = PMon:demonitor(SubPid)}; lists:foreach(fun({_, {share, Share, Topic}}) ->
demonitor_subpid(_SubPid, State) -> clean_subscriber(Share, Subscriber, Topic);
State.
subscriber_down_(Subscriber) ->
lists:foreach(fun({_, {Share, Topic}}) ->
subscriber_down_(Share, Subscriber, Topic);
({_, Topic}) -> ({_, Topic}) ->
subscriber_down_(undefined, Subscriber, Topic) clean_subscriber(undefined, Subscriber, Topic)
end, ets:lookup(mqtt_subscription, Subscriber)), end, ets:lookup(mqtt_subscription, Subscriber)),
ets:delete(mqtt_subscription, Subscriber). ets:delete(mqtt_subscription, Subscriber).
subscriber_down_(Share, Subscriber, Topic) -> clean_subscriber(Share, Subscriber, Topic) ->
case ets:lookup(mqtt_subproperty, {Topic, Subscriber}) of case ets:lookup(mqtt_subproperty, {Topic, Subscriber}) of
[] -> [] ->
%% TODO:....??? %% TODO:....???
@ -300,7 +313,16 @@ subscriber_down_(Share, Subscriber, Topic) ->
ets:delete(mqtt_subproperty, {Topic, Subscriber}) ets:delete(mqtt_subproperty, {Topic, Subscriber})
end. end.
demonitor_subscriber(SubPid, State = #state{subids = SubIds, submon = SubMon}) ->
State#state{subids = maps:remove(SubPid, SubIds), submon = SubMon:demonitor(SubPid)}.
setstats(State) -> setstats(State) ->
emqttd_stats:setstats('subscriptions/count', 'subscriptions/max', emqttd_stats:setstats('subscriptions/count', 'subscriptions/max',
ets:info(mqtt_subscription, size)), State. ets:info(mqtt_subscription, size)), State.
reply(Reply, State) ->
{reply, Reply, State, hibernate}.
noreply(State) ->
{noreply, State, hibernate}.

View File

@ -31,7 +31,7 @@
-copy_mnesia({mnesia, [copy]}). -copy_mnesia({mnesia, [copy]}).
%% Trie API %% Trie API
-export([insert/1, match/1, delete/1, lookup/1]). -export([insert/1, match/1, lookup/1, delete/1]).
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% Mnesia Callbacks %% Mnesia Callbacks
@ -65,22 +65,22 @@ mnesia(copy) ->
-spec(insert(Topic :: binary()) -> ok). -spec(insert(Topic :: binary()) -> ok).
insert(Topic) when is_binary(Topic) -> insert(Topic) when is_binary(Topic) ->
case mnesia:read(mqtt_trie_node, Topic) of case mnesia:read(mqtt_trie_node, Topic) of
[#trie_node{topic=Topic}] -> [#trie_node{topic = Topic}] ->
ok; ok;
[TrieNode=#trie_node{topic=undefined}] -> [TrieNode = #trie_node{topic = undefined}] ->
write_trie_node(TrieNode#trie_node{topic=Topic}); write_trie_node(TrieNode#trie_node{topic = Topic});
[] -> [] ->
% Add trie path % Add trie path
lists:foreach(fun add_path/1, emqttd_topic:triples(Topic)), lists:foreach(fun add_path/1, emqttd_topic:triples(Topic)),
% Add last node % Add last node
write_trie_node(#trie_node{node_id=Topic, topic=Topic}) write_trie_node(#trie_node{node_id = Topic, topic = Topic})
end. end.
%% @doc Find trie nodes that match topic %% @doc Find trie nodes that match topic
-spec(match(Topic :: binary()) -> list(MatchedTopic :: binary())). -spec(match(Topic :: binary()) -> list(MatchedTopic :: binary())).
match(Topic) when is_binary(Topic) -> match(Topic) when is_binary(Topic) ->
TrieNodes = match_node(root, emqttd_topic:words(Topic)), TrieNodes = match_node(root, emqttd_topic:words(Topic)),
[Name || #trie_node{topic=Name} <- TrieNodes, Name =/= undefined]. [Name || #trie_node{topic = Name} <- TrieNodes, Name =/= undefined].
%% @doc Lookup a Trie Node %% @doc Lookup a Trie Node
-spec(lookup(NodeId :: binary()) -> [#trie_node{}]). -spec(lookup(NodeId :: binary()) -> [#trie_node{}]).
@ -91,13 +91,13 @@ lookup(NodeId) ->
-spec(delete(Topic :: binary()) -> ok). -spec(delete(Topic :: binary()) -> ok).
delete(Topic) when is_binary(Topic) -> delete(Topic) when is_binary(Topic) ->
case mnesia:read(mqtt_trie_node, Topic) of case mnesia:read(mqtt_trie_node, Topic) of
[#trie_node{edge_count=0}] -> [#trie_node{edge_count = 0}] ->
mnesia:delete({mqtt_trie_node, Topic}), mnesia:delete({mqtt_trie_node, Topic}),
delete_path(lists:reverse(emqttd_topic:triples(Topic))); delete_path(lists:reverse(emqttd_topic:triples(Topic)));
[TrieNode] -> [TrieNode] ->
write_trie_node(TrieNode#trie_node{topic = undefined}); write_trie_node(TrieNode#trie_node{topic = undefined});
[] -> [] ->
ok ok
end. end.
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
@ -107,19 +107,19 @@ delete(Topic) when is_binary(Topic) ->
%% @private %% @private
%% @doc Add path to trie tree. %% @doc Add path to trie tree.
add_path({Node, Word, Child}) -> add_path({Node, Word, Child}) ->
Edge = #trie_edge{node_id=Node, word=Word}, Edge = #trie_edge{node_id = Node, word = Word},
case mnesia:read(mqtt_trie_node, Node) of case mnesia:read(mqtt_trie_node, Node) of
[TrieNode = #trie_node{edge_count=Count}] -> [TrieNode = #trie_node{edge_count = Count}] ->
case mnesia:wread({mqtt_trie, Edge}) of case mnesia:wread({mqtt_trie, Edge}) of
[] -> [] ->
write_trie_node(TrieNode#trie_node{edge_count=Count+1}), write_trie_node(TrieNode#trie_node{edge_count = Count+1}),
write_trie(#trie{edge=Edge, node_id=Child}); write_trie(#trie{edge = Edge, node_id = Child});
[_] -> [_] ->
ok ok
end; end;
[] -> [] ->
write_trie_node(#trie_node{node_id=Node, edge_count=1}), write_trie_node(#trie_node{node_id = Node, edge_count = 1}),
write_trie(#trie{edge=Edge, node_id=Child}) write_trie(#trie{edge = Edge, node_id = Child})
end. end.
%% @private %% @private
@ -135,20 +135,20 @@ match_node(NodeId, [], ResAcc) ->
match_node(NodeId, [W|Words], ResAcc) -> match_node(NodeId, [W|Words], ResAcc) ->
lists:foldl(fun(WArg, Acc) -> lists:foldl(fun(WArg, Acc) ->
case mnesia:read(mqtt_trie, #trie_edge{node_id=NodeId, word=WArg}) of case mnesia:read(mqtt_trie, #trie_edge{node_id = NodeId, word = WArg}) of
[#trie{node_id=ChildId}] -> match_node(ChildId, Words, Acc); [#trie{node_id = ChildId}] -> match_node(ChildId, Words, Acc);
[] -> Acc [] -> Acc
end end
end, 'match_#'(NodeId, ResAcc), [W, '+']). end, 'match_#'(NodeId, ResAcc), [W, '+']).
%% @private %% @private
%% @doc Match node with '#'. %% @doc Match node with '#'.
'match_#'(NodeId, ResAcc) -> 'match_#'(NodeId, ResAcc) ->
case mnesia:read(mqtt_trie, #trie_edge{node_id=NodeId, word = '#'}) of case mnesia:read(mqtt_trie, #trie_edge{node_id = NodeId, word = '#'}) of
[#trie{node_id=ChildId}] -> [#trie{node_id = ChildId}] ->
mnesia:read(mqtt_trie_node, ChildId) ++ ResAcc; mnesia:read(mqtt_trie_node, ChildId) ++ ResAcc;
[] -> [] ->
ResAcc ResAcc
end. end.
%% @private %% @private
@ -156,17 +156,17 @@ match_node(NodeId, [W|Words], ResAcc) ->
delete_path([]) -> delete_path([]) ->
ok; ok;
delete_path([{NodeId, Word, _} | RestPath]) -> delete_path([{NodeId, Word, _} | RestPath]) ->
mnesia:delete({mqtt_trie, #trie_edge{node_id=NodeId, word=Word}}), mnesia:delete({mqtt_trie, #trie_edge{node_id = NodeId, word = Word}}),
case mnesia:read(mqtt_trie_node, NodeId) of case mnesia:read(mqtt_trie_node, NodeId) of
[#trie_node{edge_count=1, topic=undefined}] -> [#trie_node{edge_count = 1, topic = undefined}] ->
mnesia:delete({mqtt_trie_node, NodeId}), mnesia:delete({mqtt_trie_node, NodeId}),
delete_path(RestPath); delete_path(RestPath);
[TrieNode=#trie_node{edge_count=1, topic=_}] -> [TrieNode = #trie_node{edge_count = 1, topic = _}] ->
write_trie_node(TrieNode#trie_node{edge_count=0}); write_trie_node(TrieNode#trie_node{edge_count = 0});
[TrieNode=#trie_node{edge_count=C}] -> [TrieNode = #trie_node{edge_count = C}] ->
write_trie_node(TrieNode#trie_node{edge_count=C-1}); write_trie_node(TrieNode#trie_node{edge_count = C-1});
[] -> [] ->
throw({notfound, NodeId}) mnesia:abort({node_not_found, NodeId})
end. end.
%% @private %% @private