Merge pull request #1790 from emqx/emqx30-feng

Improve the Hooks' design
This commit is contained in:
turtleDeng 2018-09-07 21:46:30 +08:00 committed by GitHub
commit 0ec461484e
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
10 changed files with 267 additions and 208 deletions

View File

@ -1,7 +1,6 @@
# *EMQ X* - MQTT Broker # EMQ X Broker
*EMQ X* broker is a fully open source, highly scalable, highly available distributed MQTT messaging broker for IoT, M2M and Mobile applications that can handle tens of millions of concurrent clients.
*EMQ X* broker is a fully open source, highly scalable, highly available distributed message broker for IoT, M2M and Mobile applications that can handle tens of millions of concurrent clients.
Starting from 3.0 release, *EMQ X* broker fully supports MQTT V5.0 protocol specifications and backward compatible with MQTT V3.1 and V3.1.1, as well as other communication protocols such as MQTT-SN, CoAP, LwM2M, WebSocket and STOMP. The 3.0 release of the *EMQ X* broker can scaled to 10+ million concurrent MQTT connections on one cluster. Starting from 3.0 release, *EMQ X* broker fully supports MQTT V5.0 protocol specifications and backward compatible with MQTT V3.1 and V3.1.1, as well as other communication protocols such as MQTT-SN, CoAP, LwM2M, WebSocket and STOMP. The 3.0 release of the *EMQ X* broker can scaled to 10+ million concurrent MQTT connections on one cluster.

View File

@ -29,16 +29,16 @@
-export([get_subopts/2, set_subopts/3]). -export([get_subopts/2, set_subopts/3]).
%% Hooks API %% Hooks API
-export([hook/4, hook/3, unhook/2, run_hooks/2, run_hooks/3]). -export([hook/2, hook/3, hook/4, unhook/2, run_hooks/2, run_hooks/3]).
%% Shutdown and reboot %% Shutdown and reboot
-export([shutdown/0, shutdown/1, reboot/0]). -export([shutdown/0, shutdown/1, reboot/0]).
-define(APP, ?MODULE). -define(APP, ?MODULE).
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
%% Bootstrap, is_running... %% Bootstrap, is_running...
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
%% @doc Start emqx application %% @doc Start emqx application
-spec(start() -> {ok, list(atom())} | {error, term()}). -spec(start() -> {ok, list(atom())} | {error, term()}).
@ -62,9 +62,9 @@ is_running(Node) ->
Pid when is_pid(Pid) -> true Pid when is_pid(Pid) -> true
end. end.
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
%% PubSub API %% PubSub API
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
-spec(subscribe(emqx_topic:topic() | string()) -> ok). -spec(subscribe(emqx_topic:topic() | string()) -> ok).
subscribe(Topic) -> subscribe(Topic) ->
@ -97,9 +97,9 @@ unsubscribe(Topic, SubId) when is_atom(SubId); is_binary(SubId) ->
unsubscribe(Topic, SubPid) when is_pid(SubPid) -> unsubscribe(Topic, SubPid) when is_pid(SubPid) ->
emqx_broker:unsubscribe(iolist_to_binary(Topic), SubPid). emqx_broker:unsubscribe(iolist_to_binary(Topic), SubPid).
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
%% PubSub management API %% PubSub management API
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
-spec(get_subopts(emqx_topic:topic() | string(), emqx_types:subscriber()) -spec(get_subopts(emqx_topic:topic() | string(), emqx_types:subscriber())
-> emqx_types:subopts()). -> emqx_types:subopts()).
@ -128,36 +128,43 @@ subscribed(Topic, SubPid) when is_pid(SubPid) ->
subscribed(Topic, SubId) when is_atom(SubId); is_binary(SubId) -> subscribed(Topic, SubId) when is_atom(SubId); is_binary(SubId) ->
emqx_broker:subscribed(iolist_to_binary(Topic), SubId). emqx_broker:subscribed(iolist_to_binary(Topic), SubId).
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
%% Hooks API %% Hooks API
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
-spec(hook(atom(), function() | {emqx_hooks:hooktag(), function()}, list(any())) -spec(hook(emqx_hooks:hookpoint(), emqx_hooks:action()) -> ok | {error, already_exists}).
-> ok | {error, term()}). hook(HookPoint, Action) ->
hook(Hook, TagFunction, InitArgs) -> emqx_hooks:add(HookPoint, Action).
emqx_hooks:add(Hook, TagFunction, InitArgs).
-spec(hook(atom(), function() | {emqx_hooks:hooktag(), function()}, list(any()), integer()) -spec(hook(emqx_hooks:hookpoint(), emqx_hooks:action(), emqx_hooks:filter() | integer())
-> ok | {error, term()}). -> ok | {error, already_exists}).
hook(Hook, TagFunction, InitArgs, Priority) -> hook(HookPoint, Action, Priority) when is_integer(Priority) ->
emqx_hooks:add(Hook, TagFunction, InitArgs, Priority). emqx_hooks:add(HookPoint, Action, Priority);
hook(HookPoint, Action, Filter) when is_function(Filter); is_tuple(Filter) ->
emqx_hooks:add(HookPoint, Action, Filter);
hook(HookPoint, Action, InitArgs) when is_list(InitArgs) ->
emqx_hooks:add(HookPoint, Action, InitArgs).
-spec(unhook(atom(), function() | {emqx_hooks:hooktag(), function()}) -spec(hook(emqx_hooks:hookpoint(), emqx_hooks:action(), emqx_hooks:filter(), integer())
-> ok | {error, term()}). -> ok | {error, already_exists}).
unhook(Hook, TagFunction) -> hook(HookPoint, Action, Filter, Priority) ->
emqx_hooks:delete(Hook, TagFunction). emqx_hooks:add(HookPoint, Action, Filter, Priority).
-spec(run_hooks(atom(), list(any())) -> ok | stop). -spec(unhook(emqx_hooks:hookpoint(), emqx_hooks:action()) -> ok).
run_hooks(Hook, Args) -> unhook(HookPoint, Action) ->
emqx_hooks:run(Hook, Args). emqx_hooks:del(HookPoint, Action).
-spec(run_hooks(atom(), list(any()), any()) -> {ok | stop, any()}). -spec(run_hooks(emqx_hooks:hookpoint(), list(any())) -> ok | stop).
run_hooks(Hook, Args, Acc) -> run_hooks(HookPoint, Args) ->
emqx_hooks:run(Hook, Args, Acc). emqx_hooks:run(HookPoint, Args).
%%-------------------------------------------------------------------- -spec(run_hooks(emqx_hooks:hookpoint(), list(any()), any()) -> {ok | stop, any()}).
run_hooks(HookPoint, Args, Acc) ->
emqx_hooks:run(HookPoint, Args, Acc).
%%------------------------------------------------------------------------------
%% Shutdown and reboot %% Shutdown and reboot
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
shutdown() -> shutdown() ->
shutdown(normal). shutdown(normal).

View File

@ -154,7 +154,7 @@ init([]) ->
handle_call({register_mod, Type, Mod, Opts, Seq}, _From, State) -> handle_call({register_mod, Type, Mod, Opts, Seq}, _From, State) ->
Mods = lookup_mods(Type), Mods = lookup_mods(Type),
reply(case lists:keymember(Mod, 1, Mods) of reply(case lists:keymember(Mod, 1, Mods) of
true -> {error, already_existed}; true -> {error, already_exists};
false -> false ->
case catch Mod:init(Opts) of case catch Mod:init(Opts) of
{ok, ModState} -> {ok, ModState} ->
@ -183,7 +183,7 @@ handle_call(stop, _From, State) ->
handle_call(Req, _From, State) -> handle_call(Req, _From, State) ->
emqx_logger:error("[AccessControl] unexpected request: ~p", [Req]), emqx_logger:error("[AccessControl] unexpected request: ~p", [Req]),
{reply, ignore, State}. {reply, ignored, State}.
handle_cast(Msg, State) -> handle_cast(Msg, State) ->
emqx_logger:error("[AccessControl] unexpected msg: ~p", [Msg]), emqx_logger:error("[AccessControl] unexpected msg: ~p", [Msg]),

View File

@ -16,142 +16,160 @@
-behaviour(gen_server). -behaviour(gen_server).
-export([start_link/0]). -export([start_link/0, stop/0]).
%% Hooks API %% Hooks API
-export([add/3, add/4, delete/2, run/2, run/3, lookup/1]). -export([add/2, add/3, add/4, del/2, run/2, run/3, lookup/1]).
%% 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, terminate/2,
terminate/2, code_change/3]). code_change/3]).
-record(state, {}). -type(hookpoint() :: atom()).
-type(action() :: function() | mfa()).
-type(filter() :: function() | mfa()).
-type(hooktag() :: atom() | string() | binary()). -record(callback, {action :: action(),
filter :: filter(),
priority :: integer()}).
-export_type([hooktag/0]). -record(hook, {name :: hookpoint(), callbacks :: list(#callback{})}).
-record(callback, {tag :: hooktag(), -export_type([hookpoint/0, action/0, filter/0]).
function :: function(),
init_args = [] :: list(any()),
priority = 0 :: integer()}).
-record(hook, {name :: atom(), callbacks = [] :: list(#callback{})}).
-define(TAB, ?MODULE). -define(TAB, ?MODULE).
-define(SERVER, ?MODULE).
-spec(start_link() -> emqx_types:startlink_ret()).
start_link() -> start_link() ->
gen_server:start_link({local, ?MODULE}, ?MODULE, [], []). gen_server:start_link({local, ?SERVER}, ?MODULE, [], [{hibernate_after, 60000}]).
%%-------------------------------------------------------------------- -spec(stop() -> ok).
stop() ->
gen_server:stop(?SERVER, normal, infinity).
%%------------------------------------------------------------------------------
%% Hooks API %% Hooks API
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
-spec(add(atom(), function() | {hooktag(), function()}, list(any())) -> ok). %% @doc Register a callback
add(HookPoint, Function, InitArgs) when is_function(Function) -> -spec(add(hookpoint(), action() | #callback{}) -> emqx_types:ok_or_error(already_exists)).
add(HookPoint, {undefined, Function}, InitArgs, 0); add(HookPoint, Callback) when is_record(Callback, callback) ->
gen_server:call(?SERVER, {add, HookPoint, Callback}, infinity);
add(HookPoint, Action) when is_function(Action); is_tuple(Action) ->
add(HookPoint, #callback{action = Action, priority = 0}).
add(HookPoint, {Tag, Function}, InitArgs) when is_function(Function) -> -spec(add(hookpoint(), action(), filter() | integer() | list())
add(HookPoint, {Tag, Function}, InitArgs, 0). -> emqx_types:ok_or_error(already_exists)).
add(HookPoint, Action, InitArgs) when is_function(Action), is_list(InitArgs) ->
add(HookPoint, #callback{action = {Action, InitArgs}, priority = 0});
add(HookPoint, Action, Filter) when is_function(Filter); is_tuple(Filter) ->
add(HookPoint, #callback{action = Action, filter = Filter, priority = 0});
add(HookPoint, Action, Priority) when is_integer(Priority) ->
add(HookPoint, #callback{action = Action, priority = Priority}).
-spec(add(atom(), function() | {hooktag(), function()}, list(any()), integer()) -> ok). -spec(add(hookpoint(), action(), filter(), integer())
add(HookPoint, Function, InitArgs, Priority) when is_function(Function) -> -> emqx_types:ok_or_error(already_exists)).
add(HookPoint, {undefined, Function}, InitArgs, Priority); add(HookPoint, Action, Filter, Priority) ->
add(HookPoint, {Tag, Function}, InitArgs, Priority) when is_function(Function) -> add(HookPoint, #callback{action = Action, filter = Filter, priority = Priority}).
gen_server:call(?MODULE, {add, HookPoint, {Tag, Function}, InitArgs, Priority}).
-spec(delete(atom(), function() | {hooktag(), function()}) -> ok). %% @doc Unregister a callback.
delete(HookPoint, Function) when is_function(Function) -> -spec(del(hookpoint(), action()) -> ok).
delete(HookPoint, {undefined, Function}); del(HookPoint, Action) ->
delete(HookPoint, {Tag, Function}) when is_function(Function) -> gen_server:cast(?SERVER, {del, HookPoint, Action}).
gen_server:call(?MODULE, {delete, HookPoint, {Tag, Function}}).
%% @doc Run hooks without Acc. %% @doc Run hooks.
-spec(run(atom(), list(Arg :: any())) -> ok | stop). -spec(run(atom(), list(Arg :: any())) -> ok | stop).
run(HookPoint, Args) -> run(HookPoint, Args) ->
run_(lookup(HookPoint), Args). run_(lookup(HookPoint), Args).
%% @doc Run hooks with Accumulator.
-spec(run(atom(), list(Arg :: any()), any()) -> any()). -spec(run(atom(), list(Arg :: any()), any()) -> any()).
run(HookPoint, Args, Acc) -> run(HookPoint, Args, Acc) ->
run_(lookup(HookPoint), Args, Acc). run_(lookup(HookPoint), Args, Acc).
%% @private %% @private
run_([#callback{function = Fun, init_args = InitArgs} | Callbacks], Args) -> run_([#callback{action = Action, filter = Filter} | Callbacks], Args) ->
case apply(Fun, lists:append([Args, InitArgs])) of case filtered(Filter, Args) orelse execute(Action, Args) of
true -> run_(Callbacks, Args);
ok -> run_(Callbacks, Args); ok -> run_(Callbacks, Args);
stop -> stop; stop -> stop;
_Any -> run_(Callbacks, Args) _Any -> run_(Callbacks, Args)
end; end;
run_([], _Args) -> run_([], _Args) ->
ok. ok.
%% @private %% @private
run_([#callback{function = Fun, init_args = InitArgs} | Callbacks], Args, Acc) -> run_([#callback{action = Action, filter = Filter} | Callbacks], Args, Acc) ->
case apply(Fun, lists:append([Args, [Acc], InitArgs])) of Args1 = Args ++ [Acc],
case filtered(Filter, Args1) orelse execute(Action, Args1) of
true -> run_(Callbacks, Args, Acc);
ok -> run_(Callbacks, Args, Acc); ok -> run_(Callbacks, Args, Acc);
{ok, NewAcc} -> run_(Callbacks, Args, NewAcc); {ok, NewAcc} -> run_(Callbacks, Args, NewAcc);
stop -> {stop, Acc}; stop -> {stop, Acc};
{stop, NewAcc} -> {stop, NewAcc}; {stop, NewAcc} -> {stop, NewAcc};
_Any -> run_(Callbacks, Args, Acc) _Any -> run_(Callbacks, Args, Acc)
end; end;
run_([], _Args, Acc) -> run_([], _Args, Acc) ->
{ok, Acc}. {ok, Acc}.
-spec(lookup(atom()) -> [#callback{}]). filtered(undefined, _Args) ->
false;
filtered(Filter, Args) ->
execute(Filter, Args).
execute(Action, Args) when is_function(Action) ->
erlang:apply(Action, Args);
execute({Fun, InitArgs}, Args) when is_function(Fun) ->
erlang:apply(Fun, Args ++ InitArgs);
execute({M, F, A}, Args) ->
erlang:apply(M, F, Args ++ A).
%% @doc Lookup callbacks.
-spec(lookup(hookpoint()) -> [#callback{}]).
lookup(HookPoint) -> lookup(HookPoint) ->
case ets:lookup(?TAB, HookPoint) of case ets:lookup(?TAB, HookPoint) of
[#hook{callbacks = Callbacks}] -> Callbacks; [#hook{callbacks = Callbacks}] ->
Callbacks;
[] -> [] [] -> []
end. end.
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
%% gen_server callbacks %% gen_server callbacks
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
init([]) -> init([]) ->
_ = emqx_tables:new(?TAB, [set, protected, {keypos, #hook.name}, _ = emqx_tables:new(?TAB, [{keypos, #hook.name}, {read_concurrency, true}]),
{read_concurrency, true}]), {ok, #{}}.
{ok, #state{}}.
handle_call({add, HookPoint, {Tag, Function}, InitArgs, Priority}, _From, State) -> handle_call({add, HookPoint, Callback = #callback{action = Action}}, _From, State) ->
Callback = #callback{tag = Tag, function = Function, Reply = case lists:keymember(Action, 2, Callbacks = lookup(HookPoint)) of
init_args = InitArgs, priority = Priority}, true ->
{reply, {error, already_exists};
case ets:lookup(?TAB, HookPoint) of false ->
[#hook{callbacks = Callbacks}] -> insert_hook(HookPoint, add_callback(Callback, Callbacks))
case contain_(Tag, Function, Callbacks) of end,
false -> {reply, Reply, State};
insert_hook_(HookPoint, add_callback_(Callback, Callbacks));
true ->
{error, already_hooked}
end;
[] ->
insert_hook_(HookPoint, [Callback])
end, State};
handle_call({delete, HookPoint, {Tag, Function}}, _From, State) ->
{reply,
case ets:lookup(?TAB, HookPoint) of
[#hook{callbacks = Callbacks}] ->
case contain_(Tag, Function, Callbacks) of
true ->
insert_hook_(HookPoint, del_callback_(Tag, Function, Callbacks));
false ->
{error, not_found}
end;
[] ->
{error, not_found}
end, State};
handle_call(Req, _From, State) -> handle_call(Req, _From, State) ->
{reply, {error, {unexpected_request, Req}}, State}. emqx_logger:error("[Hooks] unexpected call: ~p", [Req]),
{reply, ignored, State}.
handle_cast(_Msg, State) -> handle_cast({del, HookPoint, Action}, State) ->
case del_callback(Action, lookup(HookPoint)) of
[] ->
ets:delete(?TAB, HookPoint);
Callbacks ->
insert_hook(HookPoint, Callbacks)
end,
{noreply, State};
handle_cast(Msg, State) ->
emqx_logger:error("[Hooks] unexpected msg: ~p", [Msg]),
{noreply, State}. {noreply, State}.
handle_info(_Info, State) -> handle_info(Info, State) ->
emqx_logger:error("[Hooks] unexpected info: ~p", [Info]),
{noreply, State}. {noreply, State}.
terminate(_Reason, _State) -> terminate(_Reason, _State) ->
@ -160,26 +178,35 @@ terminate(_Reason, _State) ->
code_change(_OldVsn, State, _Extra) -> code_change(_OldVsn, State, _Extra) ->
{ok, State}. {ok, State}.
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
%% Internal functions %% Internal functions
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
insert_hook_(HookPoint, Callbacks) -> insert_hook(HookPoint, Callbacks) ->
ets:insert(?TAB, #hook{name = HookPoint, callbacks = Callbacks}), ok. ets:insert(?TAB, #hook{name = HookPoint, callbacks = Callbacks}), ok.
add_callback_(Callback, Callbacks) -> add_callback(C, Callbacks) ->
lists:keymerge(#callback.priority, Callbacks, [Callback]). add_callback(C, Callbacks, []).
del_callback_(Tag, Function, Callbacks) -> add_callback(C, [], Acc) ->
lists:filter( lists:reverse([C|Acc]);
fun(#callback{tag = Tag1, function = Func1}) -> add_callback(C1 = #callback{priority = P1}, [C2 = #callback{priority = P2}|More], Acc)
not ((Tag =:= Tag1) andalso (Function =:= Func1)) when P1 =< P2 ->
end, Callbacks). add_callback(C1, More, [C2|Acc]);
add_callback(C1, More, Acc) ->
lists:append(lists:reverse(Acc), [C1 | More]).
contain_(_Tag, _Function, []) -> del_callback(Action, Callbacks) ->
false; del_callback(Action, Callbacks, []).
contain_(Tag, Function, [#callback{tag = Tag, function = Function}|_Callbacks]) ->
true; del_callback(_Action, [], Acc) ->
contain_(Tag, Function, [_Callback | Callbacks]) -> lists:reverse(Acc);
contain_(Tag, Function, Callbacks). del_callback(Action, [#callback{action = Action} | Callbacks], Acc) ->
del_callback(Action, Callbacks, Acc);
del_callback(Action = {M, F}, [#callback{action = {M, F, _A}} | Callbacks], Acc) ->
del_callback(Action, Callbacks, Acc);
del_callback(Func, [#callback{action = {Func, _A}} | Callbacks], Acc) ->
del_callback(Func, Callbacks, Acc);
del_callback(Action, [Callback | Callbacks], Acc) ->
del_callback(Action, Callbacks, [Callback | Acc]).

View File

@ -19,24 +19,24 @@
-include("emqx.hrl"). -include("emqx.hrl").
-export([load/1, unload/1]). -export([load/1, unload/1]).
-export([on_client_connected/4, on_client_disconnected/3]). -export([on_client_connected/4, on_client_disconnected/3]).
-define(ATTR_KEYS, [clean_start, proto_ver, proto_name, keepalive]).
load(Env) -> load(Env) ->
emqx_hooks:add('client.connected', fun ?MODULE:on_client_connected/4, [Env]), emqx_hooks:add('client.connected', fun ?MODULE:on_client_connected/4, [Env]),
emqx_hooks:add('client.disconnected', fun ?MODULE:on_client_disconnected/3, [Env]). emqx_hooks:add('client.disconnected', fun ?MODULE:on_client_disconnected/3, [Env]).
on_client_connected(#{client_id := ClientId, on_client_connected(#{client_id := ClientId,
username := Username, username := Username,
peername := {IpAddr, _}}, ConnAck, ConnInfo, Env) -> peername := {IpAddr, _}}, ConnAck, ConnAttrs, Env) ->
Attrs = lists:filter(fun({K, _}) -> lists:member(K, ?ATTR_KEYS) end, ConnAttrs),
case emqx_json:safe_encode([{clientid, ClientId}, case emqx_json:safe_encode([{clientid, ClientId},
{username, Username}, {username, Username},
{ipaddress, iolist_to_binary(esockd_net:ntoa(IpAddr))}, {ipaddress, iolist_to_binary(esockd_net:ntoa(IpAddr))},
{clean_start, proplists:get_value(clean_start, ConnInfo)},
{proto_ver, proplists:get_value(proto_ver, ConnInfo)},
{proto_name, proplists:get_value(proto_name, ConnInfo)},
{keepalive, proplists:get_value(keepalive, ConnInfo)},
{connack, ConnAck}, {connack, ConnAck},
{ts, os:system_time(second)}]) of {ts, os:system_time(second)} | Attrs]) of
{ok, Payload} -> {ok, Payload} ->
emqx:publish(message(qos(Env), topic(connected, ClientId), Payload)); emqx:publish(message(qos(Env), topic(connected, ClientId), Payload));
{error, Reason} -> {error, Reason} ->
@ -55,20 +55,20 @@ on_client_disconnected(#{client_id := ClientId, username := Username}, Reason, E
end. end.
unload(_Env) -> unload(_Env) ->
emqx_hooks:delete('client.connected', fun ?MODULE:on_client_connected/4), emqx_hooks:del('client.connected', fun ?MODULE:on_client_connected/4),
emqx_hooks:delete('client.disconnected', fun ?MODULE:on_client_disconnected/3). emqx_hooks:del('client.disconnected', fun ?MODULE:on_client_disconnected/3).
message(QoS, Topic, Payload) -> message(QoS, Topic, Payload) ->
Msg = emqx_message:make(?MODULE, QoS, Topic, iolist_to_binary(Payload)), emqx_message:set_flag(
emqx_message:set_flag(sys, Msg). sys, emqx_message:make(
?MODULE, QoS, Topic, iolist_to_binary(Payload))).
topic(connected, ClientId) -> topic(connected, ClientId) ->
emqx_topic:systop(iolist_to_binary(["clients/", ClientId, "/connected"])); emqx_topic:systop(iolist_to_binary(["clients/", ClientId, "/connected"]));
topic(disconnected, ClientId) -> topic(disconnected, ClientId) ->
emqx_topic:systop(iolist_to_binary(["clients/", ClientId, "/disconnected"])). emqx_topic:systop(iolist_to_binary(["clients/", ClientId, "/disconnected"])).
qos(Env) -> qos(Env) -> proplists:get_value(qos, Env, 0).
proplists:get_value(qos, Env, 0).
reason(Reason) when is_atom(Reason) -> Reason; reason(Reason) when is_atom(Reason) -> Reason;
reason({Error, _}) when is_atom(Error) -> Error; reason({Error, _}) when is_atom(Error) -> Error;

View File

@ -21,11 +21,15 @@
-export([rewrite_subscribe/3, rewrite_unsubscribe/3, rewrite_publish/2]). -export([rewrite_subscribe/3, rewrite_unsubscribe/3, rewrite_publish/2]).
load(Rules0) -> %%------------------------------------------------------------------------------
Rules = compile(Rules0), %% Load/Unload
emqx_hooks:add('client.subscribe', fun ?MODULE:rewrite_subscribe/3, [Rules]), %%------------------------------------------------------------------------------
emqx_hooks:add('client.unsubscribe',fun ?MODULE:rewrite_unsubscribe/3, [Rules]),
emqx_hooks:add('message.publish', fun ?MODULE:rewrite_publish/2, [Rules]). load(RawRules) ->
Rules = compile(RawRules),
emqx_hooks:add('client.subscribe', fun ?MODULE:rewrite_subscribe/3, [Rules]),
emqx_hooks:add('client.unsubscribe', fun ?MODULE:rewrite_unsubscribe/3, [Rules]),
emqx_hooks:add('message.publish', fun ?MODULE:rewrite_publish/2, [Rules]).
rewrite_subscribe(_Credentials, TopicTable, Rules) -> rewrite_subscribe(_Credentials, TopicTable, Rules) ->
{ok, [{match_rule(Topic, Rules), Opts} || {Topic, Opts} <- TopicTable]}. {ok, [{match_rule(Topic, Rules), Opts} || {Topic, Opts} <- TopicTable]}.
@ -37,13 +41,13 @@ rewrite_publish(Message = #message{topic = Topic}, Rules) ->
{ok, Message#message{topic = match_rule(Topic, Rules)}}. {ok, Message#message{topic = match_rule(Topic, Rules)}}.
unload(_) -> unload(_) ->
emqx_hooks:delete('client.subscribe', fun ?MODULE:rewrite_subscribe/3), emqx_hooks:del('client.subscribe', fun ?MODULE:rewrite_subscribe/3),
emqx_hooks:delete('client.unsubscribe',fun ?MODULE:rewrite_unsubscribe/3), emqx_hooks:del('client.unsubscribe', fun ?MODULE:rewrite_unsubscribe/3),
emqx_hooks:delete('message.publish', fun ?MODULE:rewrite_publish/2). emqx_hooks:del('message.publish', fun ?MODULE:rewrite_publish/2).
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
%% Internal functions %% Internal functions
%%-------------------------------------------------------------------- %%------------------------------------------------------------------------------
match_rule(Topic, []) -> match_rule(Topic, []) ->
Topic; Topic;

View File

@ -78,7 +78,7 @@ init([]) ->
handle_call({start_trace, Who, LogFile}, _From, State = #state{level = Level, traces = Traces}) -> handle_call({start_trace, Who, LogFile}, _From, State = #state{level = Level, traces = Traces}) ->
case catch lager:trace_file(LogFile, [Who], Level, ?OPTIONS) of case catch lager:trace_file(LogFile, [Who], Level, ?OPTIONS) of
{ok, exists} -> {ok, exists} ->
{reply, {error, already_existed}, State}; {reply, {error, already_exists}, State};
{ok, Trace} -> {ok, Trace} ->
{reply, ok, State#state{traces = maps:put(Who, {Trace, LogFile}, Traces)}}; {reply, ok, State#state{traces = maps:put(Who, {Trace, LogFile}, Traces)}};
{error, Reason} -> {error, Reason} ->

View File

@ -17,7 +17,7 @@
-include("emqx.hrl"). -include("emqx.hrl").
-export_type([zone/0]). -export_type([zone/0]).
-export_type([startlink_ret/0]). -export_type([startlink_ret/0, ok_or_error/1]).
-export_type([pubsub/0, topic/0, subid/0, subopts/0]). -export_type([pubsub/0, topic/0, subid/0, subopts/0]).
-export_type([client_id/0, username/0, password/0, peername/0, protocol/0]). -export_type([client_id/0, username/0, password/0, peername/0, protocol/0]).
-export_type([credentials/0, session/0]). -export_type([credentials/0, session/0]).
@ -29,6 +29,7 @@
-type(zone() :: atom()). -type(zone() :: atom()).
-type(startlink_ret() :: {ok, pid()} | ignore | {error, term()}). -type(startlink_ret() :: {ok, pid()} | ignore | {error, term()}).
-type(ok_or_error(Reason) :: ok | {error, Reason}).
-type(pubsub() :: publish | subscribe). -type(pubsub() :: publish | subscribe).
-type(topic() :: binary()). -type(topic() :: binary()).
-type(subid() :: binary() | atom()). -type(subid() :: binary() | atom()).

View File

@ -20,7 +20,6 @@
-define(APP, emqx). -define(APP, emqx).
-include_lib("eunit/include/eunit.hrl"). -include_lib("eunit/include/eunit.hrl").
-include_lib("common_test/include/ct.hrl"). -include_lib("common_test/include/ct.hrl").
-include("emqx.hrl"). -include("emqx.hrl").
@ -32,7 +31,6 @@ all() ->
{group, broker}, {group, broker},
{group, metrics}, {group, metrics},
{group, stats}, {group, stats},
{group, hook},
{group, alarms}]. {group, alarms}].
groups() -> groups() ->
@ -43,10 +41,8 @@ groups() ->
t_shared_subscribe, t_shared_subscribe,
'pubsub#', 'pubsub+']}, 'pubsub#', 'pubsub+']},
{session, [sequence], [start_session]}, {session, [sequence], [start_session]},
{broker, [sequence], [hook_unhook]},
{metrics, [sequence], [inc_dec_metric]}, {metrics, [sequence], [inc_dec_metric]},
{stats, [sequence], [set_get_stat]}, {stats, [sequence], [set_get_stat]},
{hook, [sequence], [add_delete_hook, run_hooks]},
{alarms, [sequence], [set_alarms]} {alarms, [sequence], [set_alarms]}
]. ].
@ -165,8 +161,6 @@ start_session(_) ->
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% Broker Group %% Broker Group
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
hook_unhook(_) ->
ok.
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% Metric Group %% Metric Group
@ -178,61 +172,11 @@ inc_dec_metric(_) ->
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
%% Stats Group %% Stats Group
%%-------------------------------------------------------------------- %%--------------------------------------------------------------------
set_get_stat(_) -> set_get_stat(_) ->
emqx_stats:setstat('retained/max', 99), emqx_stats:setstat('retained/max', 99),
99 = emqx_stats:getstat('retained/max'). 99 = emqx_stats:getstat('retained/max').
%%--------------------------------------------------------------------
%% Hook Test
%%--------------------------------------------------------------------
add_delete_hook(_) ->
ok = emqx:hook(test_hook, fun ?MODULE:hook_fun1/1, []),
ok = emqx:hook(test_hook, {tag, fun ?MODULE:hook_fun2/1}, []),
{error, already_hooked} = emqx:hook(test_hook, {tag, fun ?MODULE:hook_fun2/1}, []),
Callbacks = [{callback, undefined, fun ?MODULE:hook_fun1/1, [], 0},
{callback, tag, fun ?MODULE:hook_fun2/1, [], 0}],
Callbacks = emqx_hooks:lookup(test_hook),
ok = emqx:unhook(test_hook, fun ?MODULE:hook_fun1/1),
ct:print("Callbacks: ~p~n", [emqx_hooks:lookup(test_hook)]),
ok = emqx:unhook(test_hook, {tag, fun ?MODULE:hook_fun2/1}),
{error, not_found} = emqx:unhook(test_hook1, {tag, fun ?MODULE:hook_fun2/1}),
[] = emqx_hooks:lookup(test_hook),
ok = emqx:hook(emqx_hook, fun ?MODULE:hook_fun1/1, [], 9),
ok = emqx:hook(emqx_hook, {"tag", fun ?MODULE:hook_fun2/1}, [], 8),
Callbacks2 = [{callback, "tag", fun ?MODULE:hook_fun2/1, [], 8},
{callback, undefined, fun ?MODULE:hook_fun1/1, [], 9}],
Callbacks2 = emqx_hooks:lookup(emqx_hook),
ok = emqx:unhook(emqx_hook, fun ?MODULE:hook_fun1/1),
ok = emqx:unhook(emqx_hook, {"tag", fun ?MODULE:hook_fun2/1}),
[] = emqx_hooks:lookup(emqx_hook).
run_hooks(_) ->
ok = emqx:hook(foldl_hook, fun ?MODULE:hook_fun3/4, [init]),
ok = emqx:hook(foldl_hook, {tag, fun ?MODULE:hook_fun3/4}, [init]),
ok = emqx:hook(foldl_hook, fun ?MODULE:hook_fun4/4, [init]),
ok = emqx:hook(foldl_hook, fun ?MODULE:hook_fun5/4, [init]),
{stop, [r3, r2]} = emqx:run_hooks(foldl_hook, [arg1, arg2], []),
{ok, []} = emqx:run_hooks(unknown_hook, [], []),
ok = emqx:hook(foreach_hook, fun ?MODULE:hook_fun6/2, [initArg]),
ok = emqx:hook(foreach_hook, {tag, fun ?MODULE:hook_fun6/2}, [initArg]),
ok = emqx:hook(foreach_hook, fun ?MODULE:hook_fun7/2, [initArg]),
ok = emqx:hook(foreach_hook, fun ?MODULE:hook_fun8/2, [initArg]),
stop = emqx:run_hooks(foreach_hook, [arg]).
hook_fun1([]) -> ok.
hook_fun2([]) -> {ok, []}.
hook_fun3(arg1, arg2, _Acc, init) -> ok.
hook_fun4(arg1, arg2, Acc, init) -> {ok, [r2 | Acc]}.
hook_fun5(arg1, arg2, Acc, init) -> {stop, [r3 | Acc]}.
hook_fun6(arg, initArg) -> ok.
hook_fun7(arg, initArg) -> any.
hook_fun8(arg, initArg) -> stop.
set_alarms(_) -> set_alarms(_) ->
AlarmTest = #alarm{id = <<"1">>, severity = error, title="alarm title", summary="alarm summary"}, AlarmTest = #alarm{id = <<"1">>, severity = error, title="alarm title", summary="alarm summary"},
emqx_alarm_mgr:set_alarm(AlarmTest), emqx_alarm_mgr:set_alarm(AlarmTest),

77
test/emqx_hooks_SUITE.erl Normal file
View File

@ -0,0 +1,77 @@
%% Copyright (c) 2018 EMQ Technologies Co., Ltd. All Rights Reserved.
%%
%% Licensed under the Apache License, Version 2.0 (the "License");
%% you may not use this file except in compliance with the License.
%% You may obtain a copy of the License at
%%
%% http://www.apache.org/licenses/LICENSE-2.0
%%
%% Unless required by applicable law or agreed to in writing, software
%% distributed under the License is distributed on an "AS IS" BASIS,
%% WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
%% See the License for the specific language governing permissions and
%% limitations under the License.
-module(emqx_hooks_SUITE).
-compile(export_all).
-compile(nowarn_export_all).
-include_lib("eunit/include/eunit.hrl").
-include_lib("common_test/include/ct.hrl").
all() ->
[add_delete_hook, run_hooks].
add_delete_hook(_) ->
{ok, _} = emqx_hooks:start_link(),
ok = emqx:hook(test_hook, fun ?MODULE:hook_fun1/1, []),
ok = emqx:hook(test_hook, fun ?MODULE:hook_fun2/1, []),
?assertEqual({error, already_exists},
emqx:hook(test_hook, fun ?MODULE:hook_fun2/1, [])),
Callbacks = [{callback, {fun ?MODULE:hook_fun1/1, []}, undefined, 0},
{callback, {fun ?MODULE:hook_fun2/1, []}, undefined, 0}],
?assertEqual(Callbacks, emqx_hooks:lookup(test_hook)),
ok = emqx:unhook(test_hook, fun ?MODULE:hook_fun1/1),
ok = emqx:unhook(test_hook, fun ?MODULE:hook_fun2/1),
timer:sleep(1000),
?assertEqual([], emqx_hooks:lookup(test_hook)),
ok = emqx:hook(emqx_hook, {?MODULE, hook_fun2, []}, 8),
ok = emqx:hook(emqx_hook, {?MODULE, hook_fun1, []}, 9),
Callbacks2 = [{callback, {?MODULE, hook_fun1, []}, undefined, 9},
{callback, {?MODULE, hook_fun2, []}, undefined, 8}],
?assertEqual(Callbacks2, emqx_hooks:lookup(emqx_hook)),
ok = emqx:unhook(emqx_hook, {?MODULE, hook_fun1, []}),
ok = emqx:unhook(emqx_hook, {?MODULE, hook_fun2, []}),
timer:sleep(1000),
?assertEqual([], emqx_hooks:lookup(emqx_hook)),
ok = emqx_hooks:stop().
run_hooks(_) ->
{ok, _} = emqx_hooks:start_link(),
ok = emqx:hook(foldl_hook, fun ?MODULE:hook_fun3/4, [init]),
ok = emqx:hook(foldl_hook, {?MODULE, hook_fun3, [init]}),
ok = emqx:hook(foldl_hook, fun ?MODULE:hook_fun4/4, [init]),
ok = emqx:hook(foldl_hook, fun ?MODULE:hook_fun5/4, [init]),
{stop, [r3, r2]} = emqx:run_hooks(foldl_hook, [arg1, arg2], []),
{ok, []} = emqx:run_hooks(unknown_hook, [], []),
ok = emqx:hook(foreach_hook, fun ?MODULE:hook_fun6/2, [initArg]),
{error, already_exists} = emqx:hook(foreach_hook, fun ?MODULE:hook_fun6/2, [initArg]),
ok = emqx:hook(foreach_hook, fun ?MODULE:hook_fun7/2, [initArg]),
ok = emqx:hook(foreach_hook, fun ?MODULE:hook_fun8/2, [initArg]),
stop = emqx:run_hooks(foreach_hook, [arg]),
ok = emqx_hooks:stop().
hook_fun1([]) -> ok.
hook_fun2([]) -> {ok, []}.
hook_fun3(arg1, arg2, _Acc, init) -> ok.
hook_fun4(arg1, arg2, Acc, init) -> {ok, [r2 | Acc]}.
hook_fun5(arg1, arg2, Acc, init) -> {stop, [r3 | Acc]}.
hook_fun6(arg, initArg) -> ok.
hook_fun7(arg, initArg) -> any.
hook_fun8(arg, initArg) -> stop.