QueryStateTimer.java

/*
 * 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.
 */
package com.facebook.presto.execution;

import com.google.common.base.Ticker;
import io.airlift.units.Duration;

import java.util.concurrent.atomic.AtomicReference;

import static io.airlift.units.Duration.succinctNanos;
import static java.lang.Math.max;
import static java.util.Objects.requireNonNull;
import static java.util.concurrent.TimeUnit.MILLISECONDS;
import static java.util.concurrent.TimeUnit.NANOSECONDS;

// Query time workflow chart. Left side shows query workflow. Right side shows
// associated time durations with a query.
//
//      Create                                                                                      -----------
//        |                                                                                         | waitingForPrerequisitesTime
//        |                       Semantic Analyzing      -----------                               |
//        |                               |               | semanticAnalyzingTime                   |
//        V                               V               V                                         V
//      Queued                       ACL Checking         -----------                               -----------
//        |                               |               | columnAccessPermissionCheckingTime      | queuedTime
//        V                               |               |                                         V
//    Wait for Resources                  |               V                                         -----------
//        |<------------------------------+               -----------                               | waitingForResourcesTime
//        V                                                                                         V
//    Dispatching                                                                                   -----------
//        |                                                                                         | dispatchingTime
//        V                                                                                         V
//     Planning                                                                                     ----------------------------------
//        |                                                                                         | executionTime     | planningTime
//        |      Analysis Start                                                                     |                   |        -----------
//        |         |                                                                               |                   |        | analysisTime
//        |         V                                                                               |                   |        V
//        |      Analysis End                                                                       |                   |        -----------
//        V                                                                                         |                   V
//     Starting                                                                                     |                   -----------
//        |                                                                                         |
//        V                                                                                         |
//     Running                                                                                      |
//        |                                                                                         |
//        V                                                                                         |
//    Finishing                                                                                     |                   -----------
//        |                                                                                         |                   | finishingTime
//        V                                                                                         V                   V
//       End                                                                                        ----------------------------------
public class QueryStateTimer
{
    private final Ticker ticker;

    private final long createTimeInMillis = System.currentTimeMillis();

    private final long createNanos;
    private final AtomicReference<Long> beginQueuedNanos = new AtomicReference<>();
    private final AtomicReference<Long> beginResourceWaitingNanos = new AtomicReference<>();
    private final AtomicReference<Long> beginSemanticAnalyzingNanos = new AtomicReference<>();
    private final AtomicReference<Long> beginColumnAccessPermissionCheckingNanos = new AtomicReference<>();
    private final AtomicReference<Long> beginDispatchingNanos = new AtomicReference<>();
    private final AtomicReference<Long> beginPlanningNanos = new AtomicReference<>();
    private final AtomicReference<Long> beginFinishingNanos = new AtomicReference<>();
    private final AtomicReference<Long> endNanos = new AtomicReference<>();

    private final AtomicReference<Duration> waitingForPrerequisitesTime = new AtomicReference<>();
    private final AtomicReference<Duration> queuedTime = new AtomicReference<>();
    private final AtomicReference<Duration> resourceWaitingTime = new AtomicReference<>();
    private final AtomicReference<Duration> semanticAnalyzingTime = new AtomicReference<>();
    private final AtomicReference<Duration> columnAccessPermissionCheckingTime = new AtomicReference<>();
    private final AtomicReference<Duration> dispatchingTime = new AtomicReference<>();
    private final AtomicReference<Duration> executionTime = new AtomicReference<>();
    private final AtomicReference<Duration> planningTime = new AtomicReference<>();
    private final AtomicReference<Duration> finishingTime = new AtomicReference<>();

    private final AtomicReference<Long> beginAnalysisNanos = new AtomicReference<>();
    private final AtomicReference<Duration> analysisTime = new AtomicReference<>();

    private final AtomicReference<Long> lastHeartbeatNanos;

    public QueryStateTimer(Ticker ticker)
    {
        this.ticker = requireNonNull(ticker, "ticker is null");
        this.createNanos = tickerNanos();
        this.lastHeartbeatNanos = new AtomicReference<>(createNanos);
    }

    //
    // State transitions
    //

    public void beginQueued()
    {
        beginQueued(tickerNanos());
    }

    private void beginQueued(long now)
    {
        waitingForPrerequisitesTime.compareAndSet(null, nanosSince(createNanos, now));
        beginQueuedNanos.compareAndSet(null, now);
    }

    public void beginWaitingForResources()
    {
        beginWaitingForResources(tickerNanos());
    }

    private void beginWaitingForResources(long now)
    {
        beginQueued(now);
        queuedTime.compareAndSet(null, nanosSince(beginQueuedNanos, now));
        beginResourceWaitingNanos.compareAndSet(null, now);
    }

    public void beginSemanticAnalyzing()
    {
        beginSemanticAnalyzing(tickerNanos());
    }

    private void beginSemanticAnalyzing(long now)
    {
        beginSemanticAnalyzingNanos.compareAndSet(null, now);
    }

    public void beginColumnAccessPermissionChecking()
    {
        beginColumnAccessPermissionChecking(tickerNanos());
    }

    private void beginColumnAccessPermissionChecking(long now)
    {
        beginSemanticAnalyzing(now);
        semanticAnalyzingTime.compareAndSet(null, nanosSince(beginSemanticAnalyzingNanos, now));
        beginColumnAccessPermissionCheckingNanos.compareAndSet(null, now);
    }

    public void endColumnAccessPermissionChecking()
    {
        endColumnAccessPermissionChecking(tickerNanos());
    }

    private void endColumnAccessPermissionChecking(long now)
    {
        beginColumnAccessPermissionChecking(now);
        columnAccessPermissionCheckingTime.compareAndSet(null, nanosSince(beginColumnAccessPermissionCheckingNanos, now));
    }

    public void beginDispatching()
    {
        beginDispatching(tickerNanos());
    }

    private void beginDispatching(long now)
    {
        beginWaitingForResources(now);
        resourceWaitingTime.compareAndSet(null, nanosSince(beginResourceWaitingNanos, now));
        beginDispatchingNanos.compareAndSet(null, now);
    }

    public void beginPlanning()
    {
        beginPlanning(tickerNanos());
    }

    private void beginPlanning(long now)
    {
        beginDispatching(now);
        dispatchingTime.compareAndSet(null, nanosSince(beginDispatchingNanos, now));
        beginPlanningNanos.compareAndSet(null, now);
    }

    public void beginStarting()
    {
        beginStarting(tickerNanos());
    }

    private void beginStarting(long now)
    {
        beginPlanning(now);
        planningTime.compareAndSet(null, nanosSince(beginPlanningNanos, now));
    }

    public void beginRunning()
    {
        beginRunning(tickerNanos());
    }

    private void beginRunning(long now)
    {
        beginStarting(now);
    }

    public void beginFinishing()
    {
        beginFinishing(tickerNanos());
    }

    private void beginFinishing(long now)
    {
        beginRunning(now);
        beginFinishingNanos.compareAndSet(null, now);
    }

    public void endQuery()
    {
        endQuery(tickerNanos());
    }

    private void endQuery(long now)
    {
        beginFinishing(now);
        finishingTime.compareAndSet(null, nanosSince(beginFinishingNanos, now));
        executionTime.compareAndSet(null, nanosSince(beginPlanningNanos, now));
        endNanos.compareAndSet(null, now);
    }

    //
    //  Additional timings
    //

    public void beginAnalyzing()
    {
        beginAnalysisNanos.compareAndSet(null, tickerNanos());
    }

    public void endAnalysis()
    {
        analysisTime.compareAndSet(null, nanosSince(beginAnalysisNanos, tickerNanos()));
    }

    public void recordHeartbeat()
    {
        lastHeartbeatNanos.set(tickerNanos());
    }

    //
    // Stats
    //

    public long getCreateTimeInMillis()
    {
        return createTimeInMillis;
    }

    public long getExecutionStartTimeInMillis()
    {
        return toMillis(beginPlanningNanos);
    }

    public Duration getElapsedTime()
    {
        if (endNanos.get() != null) {
            return succinctNanos(endNanos.get() - createNanos);
        }
        return nanosSince(createNanos, tickerNanos());
    }

    public Duration getWaitingForPrerequisitesTime()
    {
        Duration waitingForPrerequisitesTime = this.waitingForPrerequisitesTime.get();
        if (waitingForPrerequisitesTime != null) {
            return waitingForPrerequisitesTime;
        }

        // if prerequisite wait time is not set, the query is still waiting for prerequisites to finish
        return getElapsedTime();
    }

    public Duration getQueuedTime()
    {
        return getDuration(queuedTime, beginQueuedNanos);
    }

    public Duration getResourceWaitingTime()
    {
        return getDuration(resourceWaitingTime, beginResourceWaitingNanos);
    }

    public Duration getSemanticAnalyzingTime()
    {
        return getDuration(semanticAnalyzingTime, beginSemanticAnalyzingNanos);
    }

    public Duration getColumnAccessPermissionCheckingTime()
    {
        return getDuration(columnAccessPermissionCheckingTime, beginColumnAccessPermissionCheckingNanos);
    }

    public Duration getDispatchingTime()
    {
        return getDuration(dispatchingTime, beginDispatchingNanos);
    }

    public Duration getPlanningTime()
    {
        return getDuration(planningTime, beginPlanningNanos);
    }

    public Duration getFinishingTime()
    {
        return getDuration(finishingTime, beginFinishingNanos);
    }

    public Duration getExecutionTime()
    {
        return getDuration(executionTime, beginPlanningNanos);
    }

    public long getEndTimeInMillis()
    {
        return toMillis(endNanos);
    }

    public Duration getAnalysisTime()
    {
        return getDuration(analysisTime, beginAnalysisNanos);
    }

    public long getLastHeartbeatInMillis()
    {
        return toMillis(lastHeartbeatNanos);
    }

    //
    // Helper methods
    //

    private long tickerNanos()
    {
        return ticker.read();
    }

    private static Duration nanosSince(AtomicReference<Long> start, long end)
    {
        Long startNanos = start.get();
        if (startNanos == null) {
            throw new IllegalStateException("Start time not set");
        }
        return nanosSince(startNanos, end);
    }

    private static Duration nanosSince(long start, long now)
    {
        return succinctNanos(max(0, now - start));
    }

    private Duration getDuration(AtomicReference<Duration> finalDuration, AtomicReference<Long> start)
    {
        Duration duration = finalDuration.get();
        if (duration != null) {
            return duration;
        }
        Long startNanos = start.get();
        if (startNanos != null) {
            return nanosSince(startNanos, tickerNanos());
        }
        return new Duration(0, MILLISECONDS);
    }

    private long toMillis(AtomicReference<Long> instantNanos)
    {
        Long nanos = instantNanos.get();
        return nanos != null ? createTimeInMillis + NANOSECONDS.toMillis(nanos - createNanos) : 0L;
    }
}