Phoenix.Tracker behaviour
Provides distributed Presence tracking to processes.
The Tracker
API is used as a facade for a pool of Phoenix.Tracker.Shard
s. The responsibility of which calls go to which Shard
is determined based on the topic, on which a given function is called.
Tracker shards use a heartbeat protocol and CRDT to replicate presence information across a cluster in an eventually consistent, conflict-free manner. Under this design, there is no single source of truth or global process. Each node runs a pool of Phoenix.Tracker.Shard
s and node-local changes are replicated across the cluster and handled locally as a diff of changes.
-
tracker
- The name of the tracker handler module implementing thePhoenix.Tracker
behaviour -
tracker_opts
- The list of options to pass to the tracker handler -
pool_opts
- The list of options used to construct the shard pool
Required pool_opts
:
-
:name
- The name of the server, such as:MyApp.Tracker
This will also form the common prefix for all shard names
-
:pubsub_server
- The name of the PubSub server, such as:MyApp.PubSub
Optional pool_opts
:
-
:broadcast_period
- The interval in milliseconds to send delta broadcasts across the cluster. Default1500
-
:max_silent_periods
- The max integer of broadcast periods for which no delta broadcasts have been sent. Default10
(15s heartbeat) -
:down_period
- The interval in milliseconds to flag a replica as temporarily down. Defaultbroadcast_period * max_silent_periods * 2
(30s down detection). Note: This must be at least 2x thebroadcast_period
. -
:permdown_period
- The interval in milliseconds to flag a replica as permanently down, and discard its state. Note: This must be at least greater than thedown_period
. Default1_200_000
(20 minutes) -
:clock_sample_periods
- The numbers of heartbeat windows to sample remote clocks before collapsing and requesting transfer. Default2
-
:max_delta_sizes
- The list of delta generation sizes to keep before falling back to sending entire state. Defaults[100, 1000, 10_000]
. -
:log_level
- The log level to log events, defaults:debug
and can be disabled withfalse
-
:pool_size
- The number of tracker shards to launch. Default1
Implementing a Tracker
To start a tracker, first add the tracker to your supervision tree:
children = [ # ... {MyTracker, [name: MyTracker, pubsub_server: MyApp.PubSub]} ]
Next, implement MyTracker
with support for the Phoenix.Tracker
behaviour callbacks. An example of a minimal tracker could include:
defmodule MyTracker do use Phoenix.Tracker def start_link(opts) do opts = Keyword.merge([name: __MODULE__], opts) Phoenix.Tracker.start_link(__MODULE__, opts, opts) end def init(opts) do server = Keyword.fetch!(opts, :pubsub_server) {:ok, %{pubsub_server: server, node_name: Phoenix.PubSub.node_name(server)}} end def handle_diff(diff, state) do for {topic, {joins, leaves}} <- diff do for {key, meta} <- joins do IO.puts "presence join: key \"#{key}\" with meta #{inspect meta}" msg = {:join, key, meta} Phoenix.PubSub.direct_broadcast!(state.node_name, state.pubsub_server, topic, msg) end for {key, meta} <- leaves do IO.puts "presence leave: key \"#{key}\" with meta #{inspect meta}" msg = {:leave, key, meta} Phoenix.PubSub.direct_broadcast!(state.node_name, state.pubsub_server, topic, msg) end end {:ok, state} end end
Trackers must implement start_link/1
, init/1
, and handle_diff/2
. The init/1
callback allows the tracker to manage its own state when running within the Phoenix.Tracker
server. The handle_diff
callback is invoked with a diff of presence join and leave events, grouped by topic. As replicas heartbeat and replicate data, the local tracker state is merged with the remote data, and the diff is sent to the callback. The handler can use this information to notify subscribers of events, as done above.
Special Considerations
Operations within handle_diff/2
happen in the tracker server's context. Therefore, blocking operations should be avoided when possible, and offloaded to a supervised task when required. Also, a crash in the handle_diff/2
will crash the tracker server, so operations that may crash the server should be offloaded with a Task.Supervisor
spawned process.
Summary
Types
Functions
- get_by_key(tracker_name, topic, key)
Gets presences tracked under a given topic and key pair.
- graceful_permdown(tracker_name)
Gracefully shuts down by broadcasting permdown to all replicas.
- list(tracker_name, topic)
Lists all presences tracked under a given topic.
- track(tracker_name, pid, topic, key, meta)
Tracks a presence.
- untrack(tracker_name, pid, topic, key)
Untracks a presence.
- update(tracker_name, pid, topic, key, meta)
Updates a presence's metadata.
Callbacks
Types
presence()
topic()
Functions
get_by_key(tracker_name, topic, key)
Gets presences tracked under a given topic and key pair.
-
server_name
- The registered name of the tracker server -
topic
- ThePhoenix.PubSub
topic -
key
- The key of the presence
Returns a lists of presence metadata.
Examples
iex> Phoenix.Tracker.get_by_key(MyTracker, "lobby", "user1") [{#PID<0.88.0>, %{name: "User 1"}, {#PID<0.89.0>, %{name: "User 1"}]
graceful_permdown(tracker_name)
Gracefully shuts down by broadcasting permdown to all replicas.
Examples
iex> Phoenix.Tracker.graceful_permdown(MyTracker) :ok
init(list)
list(tracker_name, topic)
Lists all presences tracked under a given topic.
-
server_name
- The registered name of the tracker server -
topic
- ThePhoenix.PubSub
topic
Returns a lists of presences in key/metadata tuple pairs.
Examples
iex> Phoenix.Tracker.list(MyTracker, "lobby") [{123, %{name: "user 123"}}, {456, %{name: "user 456"}}]
start_link(tracker, tracker_opts, pool_opts)
track(tracker_name, pid, topic, key, meta)
Tracks a presence.
-
server_name
- The registered name of the tracker server -
pid
- The Pid to track -
topic
- ThePhoenix.PubSub
topic for this presence -
key
- The key identifying this presence -
meta
- The map of metadata to attach to this presence
A process may be tracked multiple times, provided the topic and key pair are unique for any prior calls for the given process.
Examples
iex> Phoenix.Tracker.track(MyTracker, self(), "lobby", u.id, %{stat: "away"}) {:ok, "1WpAofWYIAA="} iex> Phoenix.Tracker.track(MyTracker, self(), "lobby", u.id, %{stat: "away"}) {:error, {:already_tracked, #PID<0.56.0>, "lobby", "123"}}
untrack(tracker_name, pid)
untrack(tracker_name, pid, topic, key)
Untracks a presence.
-
server_name
- The registered name of the tracker server -
pid
- The Pid to untrack -
topic
- ThePhoenix.PubSub
topic to untrack for this presence -
key
- The key identifying this presence
All presences for a given Pid can be untracked by calling the Phoenix.Tracker.untrack/2
signature of this function.
Examples
iex> Phoenix.Tracker.untrack(MyTracker, self(), "lobby", u.id) :ok iex> Phoenix.Tracker.untrack(MyTracker, self()) :ok
update(tracker_name, pid, topic, key, meta)
Updates a presence's metadata.
-
server_name
- The registered name of the tracker server -
pid
- The Pid being tracked -
topic
- ThePhoenix.PubSub
topic to update for this presence -
key
- The key identifying this presence -
meta
- Either a new map of metadata to attach to this presence, or a function. The function will receive the current metadata as input and the return value will be used as the new metadata
Examples
iex> Phoenix.Tracker.update(MyTracker, self(), "lobby", u.id, %{stat: "zzz"}) {:ok, "1WpAofWYIAA="} iex> Phoenix.Tracker.update(MyTracker, self(), "lobby", u.id, fn meta -> Map.put(meta, :away, true) end) {:ok, "1WpAofWYIAA="}
Callbacks
handle_diff(%{}, state)
init(arg1)
© 2014 Chris McCord
Licensed under the MIT License.
https://hexdocs.pm/phoenix_pubsub/Phoenix.Tracker.html