361027af1de299fab960c487c32b0c09e51bbdb1
[controller.git] / opendaylight / md-sal / cds-access-client / src / main / java / org / opendaylight / controller / cluster / access / client / AbstractClientConnection.java
1 /*
2  * Copyright (c) 2016 Cisco Systems, Inc. and others.  All rights reserved.
3  *
4  * This program and the accompanying materials are made available under the
5  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
6  * and is available at http://www.eclipse.org/legal/epl-v10.html
7  */
8 package org.opendaylight.controller.cluster.access.client;
9
10 import static java.util.Objects.requireNonNull;
11
12 import akka.actor.ActorRef;
13 import com.google.common.annotations.VisibleForTesting;
14 import com.google.common.base.MoreObjects;
15 import com.google.common.base.MoreObjects.ToStringHelper;
16 import edu.umd.cs.findbugs.annotations.SuppressFBWarnings;
17 import java.util.Collection;
18 import java.util.Optional;
19 import java.util.concurrent.TimeUnit;
20 import java.util.concurrent.TimeoutException;
21 import java.util.concurrent.locks.Lock;
22 import java.util.concurrent.locks.ReentrantLock;
23 import java.util.function.Consumer;
24 import org.checkerframework.checker.lock.qual.GuardedBy;
25 import org.checkerframework.checker.lock.qual.Holding;
26 import org.eclipse.jdt.annotation.NonNull;
27 import org.opendaylight.controller.cluster.access.concepts.Request;
28 import org.opendaylight.controller.cluster.access.concepts.RequestException;
29 import org.opendaylight.controller.cluster.access.concepts.Response;
30 import org.opendaylight.controller.cluster.access.concepts.ResponseEnvelope;
31 import org.opendaylight.controller.cluster.access.concepts.RuntimeRequestException;
32 import org.slf4j.Logger;
33 import org.slf4j.LoggerFactory;
34 import scala.concurrent.duration.FiniteDuration;
35
36 /**
37  * Base class for a connection to the backend. Responsible to queueing and dispatch of requests toward the backend.
38  * Can be in three conceptual states: Connecting, Connected and Reconnecting, which are represented by public final
39  * classes exposed from this package. This class NOT thread-safe, not are its subclasses expected to be thread-safe.
40  *
41  * @author Robert Varga
42  */
43 public abstract class AbstractClientConnection<T extends BackendInfo> {
44     private static final Logger LOG = LoggerFactory.getLogger(AbstractClientConnection.class);
45
46     /*
47      * Timers involved in communication with the backend. There are three tiers which are spaced out to allow for
48      * recovery at each tier. Keep these constants in nanoseconds, as that prevents unnecessary conversions in the fast
49      * path.
50      */
51     /**
52      * Backend aliveness timer. This is reset whenever we receive a response from the backend and kept armed whenever
53      * we have an outstanding request. If when this time expires, we tear down this connection and attempt to reconnect
54      * it.
55      */
56     public static final long DEFAULT_BACKEND_ALIVE_TIMEOUT_NANOS = TimeUnit.SECONDS.toNanos(30);
57
58     /**
59      * Request timeout. If the request fails to complete within this time since it was originally enqueued, we time
60      * the request out.
61      */
62     public static final long DEFAULT_REQUEST_TIMEOUT_NANOS = TimeUnit.MINUTES.toNanos(2);
63
64     /**
65      * No progress timeout. A client fails to make any forward progress in this time, it will terminate itself.
66      */
67     public static final long DEFAULT_NO_PROGRESS_TIMEOUT_NANOS = TimeUnit.MINUTES.toNanos(15);
68
69     // Emit a debug entry if we sleep for more that this amount
70     private static final long DEBUG_DELAY_NANOS = TimeUnit.MILLISECONDS.toNanos(100);
71
72     // Upper bound on the time a thread is forced to sleep to keep queue size under control
73     private static final long MAX_DELAY_SECONDS = 5;
74     private static final long MAX_DELAY_NANOS = TimeUnit.SECONDS.toNanos(MAX_DELAY_SECONDS);
75
76     private final Lock lock = new ReentrantLock();
77     private final ClientActorContext context;
78     @GuardedBy("lock")
79     private final TransmitQueue queue;
80     private final @NonNull Long cookie;
81     private final String backendName;
82
83     @GuardedBy("lock")
84     private boolean haveTimer;
85
86     /**
87      * Time reference when we saw any activity from the backend.
88      */
89     private long lastReceivedTicks;
90
91     private volatile RequestException poisoned;
92
93     // Private constructor to avoid code duplication.
94     private AbstractClientConnection(final AbstractClientConnection<T> oldConn, final TransmitQueue newQueue,
95             final String backendName) {
96         this.context = requireNonNull(oldConn.context);
97         this.cookie = requireNonNull(oldConn.cookie);
98         this.backendName = requireNonNull(backendName);
99         this.queue = requireNonNull(newQueue);
100         // Will be updated in finishReplay if needed.
101         this.lastReceivedTicks = oldConn.lastReceivedTicks;
102     }
103
104     // This constructor is only to be called by ConnectingClientConnection constructor.
105     // Do not allow subclassing outside of this package
106     AbstractClientConnection(final ClientActorContext context, final Long cookie, final String backendName,
107             final int queueDepth) {
108         this.context = requireNonNull(context);
109         this.cookie = requireNonNull(cookie);
110         this.backendName = requireNonNull(backendName);
111         this.queue = new TransmitQueue.Halted(queueDepth);
112         this.lastReceivedTicks = currentTime();
113     }
114
115     // This constructor is only to be called (indirectly) by ReconnectingClientConnection constructor.
116     // Do not allow subclassing outside of this package
117     AbstractClientConnection(final AbstractClientConnection<T> oldConn) {
118         this(oldConn, new TransmitQueue.Halted(oldConn.queue, oldConn.currentTime()), oldConn.backendName);
119     }
120
121     // This constructor is only to be called (indirectly) by ConnectedClientConnection constructor.
122     // Do not allow subclassing outside of this package
123     AbstractClientConnection(final AbstractClientConnection<T> oldConn, final T newBackend,
124             final int queueDepth) {
125         this(oldConn, new TransmitQueue.Transmitting(oldConn.queue, queueDepth, newBackend, oldConn.currentTime(),
126             requireNonNull(oldConn.context).messageSlicer()), newBackend.getName());
127     }
128
129     public final ClientActorContext context() {
130         return context;
131     }
132
133     public final @NonNull Long cookie() {
134         return cookie;
135     }
136
137     public final ActorRef localActor() {
138         return context.self();
139     }
140
141     public final long currentTime() {
142         return context.ticker().read();
143     }
144
145     /**
146      * Send a request to the backend and invoke a specified callback when it finishes. This method is safe to invoke
147      * from any thread.
148      *
149      * <p>This method may put the caller thread to sleep in order to throttle the request rate.
150      * The callback may be called before the sleep finishes.
151      *
152      * @param request Request to send
153      * @param callback Callback to invoke
154      */
155     public final void sendRequest(final Request<?, ?> request, final Consumer<Response<?, ?>> callback) {
156         final long now = currentTime();
157         sendEntry(new ConnectionEntry(request, callback, now), now);
158     }
159
160     /**
161      * Send a request to the backend and invoke a specified callback when it finishes. This method is safe to invoke
162      * from any thread.
163      *
164      * <p>
165      * Note that unlike {@link #sendRequest(Request, Consumer)}, this method does not exert backpressure, hence it
166      * should never be called from an application thread.
167      *
168      * @param request Request to send
169      * @param callback Callback to invoke
170      * @param enqueuedTicks Time (according to {@link #currentTime()} of request enqueue
171      */
172     public final void enqueueRequest(final Request<?, ?> request, final Consumer<Response<?, ?>> callback,
173             final long enqueuedTicks) {
174         enqueueEntry(new ConnectionEntry(request, callback, enqueuedTicks), currentTime());
175     }
176
177     private long enqueueOrForward(final ConnectionEntry entry, final long now) {
178         lock.lock();
179         try {
180             commonEnqueue(entry, now);
181             return queue.enqueueOrForward(entry, now);
182         } finally {
183             lock.unlock();
184         }
185     }
186
187     /**
188      * Enqueue an entry, possibly also transmitting it.
189      */
190     public final void enqueueEntry(final ConnectionEntry entry, final long now) {
191         lock.lock();
192         try {
193             commonEnqueue(entry, now);
194             queue.enqueueOrReplay(entry, now);
195         } finally {
196             lock.unlock();
197         }
198     }
199
200     @Holding("lock")
201     private void commonEnqueue(final ConnectionEntry entry, final long now) {
202         final RequestException maybePoison = poisoned;
203         if (maybePoison != null) {
204             throw new IllegalStateException("Connection " + this + " has been poisoned", maybePoison);
205         }
206
207         if (queue.isEmpty()) {
208             // The queue is becoming non-empty, schedule a timer.
209             scheduleTimer(entry.getEnqueuedTicks() + context.config().getRequestTimeout() - now);
210         }
211     }
212
213     // To be called from ClientActorBehavior on ConnectedClientConnection after entries are replayed.
214     final void cancelDebt() {
215         queue.cancelDebt(currentTime());
216     }
217
218     public abstract Optional<T> getBackendInfo();
219
220     final Collection<ConnectionEntry> startReplay() {
221         lock.lock();
222         return queue.drain();
223     }
224
225     @Holding("lock")
226     final void finishReplay(final ReconnectForwarder forwarder) {
227         setForwarder(forwarder);
228
229         /*
230          * The process of replaying all messages may have taken a significant chunk of time, depending on type
231          * of messages, queue depth and available processing power. In extreme situations this may have already
232          * exceeded BACKEND_ALIVE_TIMEOUT_NANOS, in which case we are running the risk of not making reasonable forward
233          * progress before we start a reconnect cycle.
234          *
235          * Note that the timer is armed after we have sent the first message, hence we should be seeing a response
236          * from the backend before we see a timeout, simply due to how the mailbox operates.
237          *
238          * At any rate, reset the timestamp once we complete reconnection (which an atomic transition from the
239          * perspective of outside world), as that makes it a bit easier to reason about timing of events.
240          */
241         lastReceivedTicks = currentTime();
242         lock.unlock();
243     }
244
245     @Holding("lock")
246     final void setForwarder(final ReconnectForwarder forwarder) {
247         queue.setForwarder(forwarder, currentTime());
248     }
249
250     @Holding("lock")
251     abstract ClientActorBehavior<T> lockedReconnect(ClientActorBehavior<T> current,
252             RequestException runtimeRequestException);
253
254     final void sendEntry(final ConnectionEntry entry, final long now) {
255         long delay = enqueueOrForward(entry, now);
256         try {
257             if (delay >= DEBUG_DELAY_NANOS) {
258                 if (delay > MAX_DELAY_NANOS) {
259                     LOG.info("Capping {} throttle delay from {} to {} seconds", this,
260                         TimeUnit.NANOSECONDS.toSeconds(delay), MAX_DELAY_SECONDS, new Throwable());
261                     delay = MAX_DELAY_NANOS;
262                 }
263                 if (LOG.isDebugEnabled()) {
264                     LOG.debug("{}: Sleeping for {}ms on connection {}", context.persistenceId(),
265                         TimeUnit.NANOSECONDS.toMillis(delay), this);
266                 }
267             }
268             TimeUnit.NANOSECONDS.sleep(delay);
269         } catch (InterruptedException e) {
270             Thread.currentThread().interrupt();
271             LOG.debug("Interrupted after sleeping {}ns", currentTime() - now, e);
272         }
273     }
274
275     final ClientActorBehavior<T> reconnect(final ClientActorBehavior<T> current, final RequestException cause) {
276         lock.lock();
277         try {
278             return lockedReconnect(current, cause);
279         } finally {
280             lock.unlock();
281         }
282     }
283
284     /**
285      * Schedule a timer to fire on the actor thread after a delay.
286      *
287      * @param delay Delay, in nanoseconds
288      */
289     @Holding("lock")
290     private void scheduleTimer(final long delay) {
291         if (haveTimer) {
292             LOG.debug("{}: timer already scheduled on {}", context.persistenceId(), this);
293             return;
294         }
295         if (queue.hasSuccessor()) {
296             LOG.debug("{}: connection {} has a successor, not scheduling timer", context.persistenceId(), this);
297             return;
298         }
299
300         // If the delay is negative, we need to schedule an action immediately. While the caller could have checked
301         // for that condition and take appropriate action, but this is more convenient and less error-prone.
302         final long normalized =  delay <= 0 ? 0 : Math.min(delay, context.config().getBackendAlivenessTimerInterval());
303
304         final FiniteDuration dur = FiniteDuration.fromNanos(normalized);
305         LOG.debug("{}: connection {} scheduling timeout in {}", context.persistenceId(), this, dur);
306         context.executeInActor(this::runTimer, dur);
307         haveTimer = true;
308     }
309
310     /**
311      * Check this queue for timeout and initiate reconnection if that happened. If the queue has not made progress
312      * in {@link #DEFAULT_NO_PROGRESS_TIMEOUT_NANOS} nanoseconds, it will be aborted.
313      *
314      * @param current Current behavior
315      * @return Next behavior to use
316      */
317     @VisibleForTesting
318     final ClientActorBehavior<T> runTimer(final ClientActorBehavior<T> current) {
319         final Optional<Long> delay;
320
321         lock.lock();
322         try {
323             haveTimer = false;
324             final long now = currentTime();
325
326             LOG.debug("{}: running timer on {}", context.persistenceId(), this);
327
328             // The following line is only reliable when queue is not forwarding, but such state should not last long.
329             // FIXME: BUG-8422: this may not be accurate w.r.t. replayed entries
330             final long ticksSinceProgress = queue.ticksStalling(now);
331             if (ticksSinceProgress >= context.config().getNoProgressTimeout()) {
332                 LOG.error("Queue {} has not seen progress in {} seconds, failing all requests", this,
333                     TimeUnit.NANOSECONDS.toSeconds(ticksSinceProgress));
334
335                 lockedPoison(new NoProgressException(ticksSinceProgress));
336                 current.removeConnection(this);
337                 return current;
338             }
339
340             // Requests are always scheduled in sequence, hence checking for timeout is relatively straightforward.
341             // Note we use also inquire about the delay, so we can re-schedule if needed, hence the unusual tri-state
342             // return convention.
343             delay = lockedCheckTimeout(now);
344             if (delay == null) {
345                 // We have timed out. There is no point in scheduling a timer
346                 LOG.debug("{}: connection {} timed out", context.persistenceId(), this);
347                 return lockedReconnect(current, new RuntimeRequestException("Backend connection timed out",
348                     new TimeoutException()));
349             }
350
351             if (delay.isPresent()) {
352                 // If there is new delay, schedule a timer
353                 scheduleTimer(delay.get());
354             } else {
355                 LOG.debug("{}: not scheduling timeout on {}", context.persistenceId(), this);
356             }
357         } finally {
358             lock.unlock();
359         }
360
361         return current;
362     }
363
364     @VisibleForTesting
365     final Optional<Long> checkTimeout(final long now) {
366         lock.lock();
367         try {
368             return lockedCheckTimeout(now);
369         } finally {
370             lock.unlock();
371         }
372     }
373
374     long backendSilentTicks(final long now) {
375         return now - lastReceivedTicks;
376     }
377
378     /*
379      * We are using tri-state return here to indicate one of three conditions:
380      * - if there is no timeout to schedule, return Optional.empty()
381      * - if there is a timeout to schedule, return a non-empty optional
382      * - if this connections has timed out, return null
383      */
384     @SuppressFBWarnings(value = "NP_OPTIONAL_RETURN_NULL",
385             justification = "Returning null Optional is documented in the API contract.")
386     @GuardedBy("lock")
387     private Optional<Long> lockedCheckTimeout(final long now) {
388         if (queue.isEmpty()) {
389             LOG.debug("{}: connection {} is empty", context.persistenceId(), this);
390             return Optional.empty();
391         }
392
393         final long backendSilentTicks = backendSilentTicks(now);
394         if (backendSilentTicks >= context.config().getBackendAlivenessTimerInterval()) {
395             LOG.debug("{}: Connection {} has not seen activity from backend for {} nanoseconds, timing out",
396                 context.persistenceId(), this, backendSilentTicks);
397             return null;
398         }
399
400         int tasksTimedOut = 0;
401         for (ConnectionEntry head = queue.peek(); head != null; head = queue.peek()) {
402             final long beenOpen = now - head.getEnqueuedTicks();
403             final long requestTimeout = context.config().getRequestTimeout();
404             if (beenOpen < requestTimeout) {
405                 return Optional.of(requestTimeout - beenOpen);
406             }
407
408             tasksTimedOut++;
409             queue.remove(now);
410             LOG.debug("{}: Connection {} timed out entry {}", context.persistenceId(), this, head);
411
412             timeoutEntry(head, beenOpen);
413         }
414
415         LOG.debug("Connection {} timed out {} tasks", this, tasksTimedOut);
416         if (tasksTimedOut != 0) {
417             queue.tryTransmit(now);
418         }
419
420         return Optional.empty();
421     }
422
423     private void timeoutEntry(final ConnectionEntry entry, final long beenOpen) {
424         // Timeouts needs to be re-scheduled on actor thread because we are holding the lock on the current queue,
425         // which may be the tail of a successor chain. This is a problem if the callback attempts to send a request
426         // because that will attempt to lock the chain from the start, potentially causing a deadlock if there is
427         // a concurrent attempt to transmit.
428         context.executeInActor(current -> {
429             final double time = beenOpen * 1.0 / 1_000_000_000;
430             entry.complete(entry.getRequest().toRequestFailure(
431                 new RequestTimeoutException(entry.getRequest() + " timed out after " + time
432                         + " seconds. The backend for " + backendName + " is not available.")));
433             return current;
434         });
435     }
436
437     final void poison(final RequestException cause) {
438         lock.lock();
439         try {
440             lockedPoison(cause);
441         } finally {
442             lock.unlock();
443         }
444     }
445
446     @Holding("lock")
447     private void lockedPoison(final RequestException cause) {
448         poisoned = enrichPoison(cause);
449         queue.poison(cause);
450     }
451
452     RequestException enrichPoison(final RequestException ex) {
453         return ex;
454     }
455
456     @VisibleForTesting
457     final RequestException poisoned() {
458         return poisoned;
459     }
460
461     void receiveResponse(final ResponseEnvelope<?> envelope) {
462         final long now = currentTime();
463         lastReceivedTicks = now;
464
465         final Optional<TransmittedConnectionEntry> maybeEntry;
466         lock.lock();
467         try {
468             maybeEntry = queue.complete(envelope, now);
469         } finally {
470             lock.unlock();
471         }
472
473         if (maybeEntry.isPresent()) {
474             final TransmittedConnectionEntry entry = maybeEntry.get();
475             LOG.debug("Completing {} with {}", entry, envelope);
476             entry.complete(envelope.getMessage());
477         }
478     }
479
480     @Override
481     public final String toString() {
482         return addToStringAttributes(MoreObjects.toStringHelper(this).omitNullValues()).toString();
483     }
484
485     ToStringHelper addToStringAttributes(final ToStringHelper toStringHelper) {
486         return toStringHelper.add("client", context.getIdentifier()).add("cookie", cookie).add("poisoned", poisoned);
487     }
488 }