123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957 |
- // Libraries
- import { cloneDeep, isEmpty, map as lodashMap } from 'lodash';
- import Prism from 'prismjs';
- import { lastValueFrom, merge, Observable, of, throwError } from 'rxjs';
- import { catchError, map, switchMap } from 'rxjs/operators';
- // Types
- import {
- AnnotationEvent,
- AnnotationQueryRequest,
- CoreApp,
- DataFrame,
- DataFrameView,
- DataQueryError,
- DataQueryRequest,
- DataQueryResponse,
- DataSourceInstanceSettings,
- DataSourceWithLogsContextSupport,
- DataSourceWithLogsVolumeSupport,
- DataSourceWithQueryExportSupport,
- DataSourceWithQueryImportSupport,
- dateMath,
- DateTime,
- FieldCache,
- AbstractQuery,
- FieldType,
- getLogLevelFromKey,
- Labels,
- LoadingState,
- LogLevel,
- LogRowModel,
- QueryResultMeta,
- ScopedVars,
- TimeRange,
- rangeUtil,
- toUtc,
- } from '@grafana/data';
- import { BackendSrvRequest, FetchError, getBackendSrv, config, DataSourceWithBackend } from '@grafana/runtime';
- import { RowContextOptions } from '@grafana/ui/src/components/Logs/LogRowContextProvider';
- import { queryLogsVolume } from 'app/core/logs_model';
- import { convertToWebSocketUrl } from 'app/core/utils/explore';
- import { getTimeSrv, TimeSrv } from 'app/features/dashboard/services/TimeSrv';
- import { getTemplateSrv, TemplateSrv } from 'app/features/templating/template_srv';
- import { serializeParams } from '../../../core/utils/fetch';
- import { renderLegendFormat } from '../prometheus/legend';
- import { addLabelToQuery } from './add_label_to_query';
- import { transformBackendResult } from './backendResultTransformer';
- import { DEFAULT_RESOLUTION } from './components/LokiOptionFields';
- import LanguageProvider from './language_provider';
- import { escapeLabelValueInSelector } from './language_utils';
- import { LiveStreams, LokiLiveTarget } from './live_streams';
- import { addParsedLabelToQuery, getNormalizedLokiQuery, queryHasPipeParser } from './query_utils';
- import { lokiResultsToTableModel, lokiStreamsToDataFrames, processRangeQueryResponse } from './result_transformer';
- import { sortDataFrameByTime } from './sortDataFrame';
- import { doLokiChannelStream } from './streaming';
- import syntax from './syntax';
- import {
- LokiOptions,
- LokiQuery,
- LokiQueryDirection,
- LokiQueryType,
- LokiRangeQueryRequest,
- LokiResultType,
- LokiStreamResponse,
- } from './types';
- export type RangeQueryOptions = DataQueryRequest<LokiQuery> | AnnotationQueryRequest<LokiQuery>;
- export const DEFAULT_MAX_LINES = 1000;
- export const LOKI_ENDPOINT = '/loki/api/v1';
- const NS_IN_MS = 1000000;
- const RANGE_QUERY_ENDPOINT = `${LOKI_ENDPOINT}/query_range`;
- const INSTANT_QUERY_ENDPOINT = `${LOKI_ENDPOINT}/query`;
- const DEFAULT_QUERY_PARAMS: Partial<LokiRangeQueryRequest> = {
- limit: DEFAULT_MAX_LINES,
- query: '',
- };
- function makeRequest(query: LokiQuery, range: TimeRange, app: CoreApp, requestId: string): DataQueryRequest<LokiQuery> {
- const intervalInfo = rangeUtil.calculateInterval(range, 1);
- return {
- targets: [query],
- requestId,
- interval: intervalInfo.interval,
- intervalMs: intervalInfo.intervalMs,
- range: range,
- scopedVars: {},
- timezone: 'UTC',
- app,
- startTime: Date.now(),
- };
- }
- export class LokiDatasource
- extends DataSourceWithBackend<LokiQuery, LokiOptions>
- implements
- DataSourceWithLogsContextSupport,
- DataSourceWithLogsVolumeSupport<LokiQuery>,
- DataSourceWithQueryImportSupport<LokiQuery>,
- DataSourceWithQueryExportSupport<LokiQuery>
- {
- private streams = new LiveStreams();
- languageProvider: LanguageProvider;
- maxLines: number;
- useBackendMode: boolean;
- constructor(
- private instanceSettings: DataSourceInstanceSettings<LokiOptions>,
- private readonly templateSrv: TemplateSrv = getTemplateSrv(),
- private readonly timeSrv: TimeSrv = getTimeSrv()
- ) {
- super(instanceSettings);
- this.languageProvider = new LanguageProvider(this);
- const settingsData = instanceSettings.jsonData || {};
- this.maxLines = parseInt(settingsData.maxLines ?? '0', 10) || DEFAULT_MAX_LINES;
- const keepCookiesUsed = (settingsData.keepCookies ?? []).length > 0;
- // only use backend-mode when keep-cookies is not used
- this.useBackendMode = !keepCookiesUsed && (config.featureToggles.lokiBackendMode ?? false);
- }
- _request(apiUrl: string, data?: any, options?: Partial<BackendSrvRequest>): Observable<Record<string, any>> {
- const baseUrl = this.instanceSettings.url;
- const params = data ? serializeParams(data) : '';
- const url = `${baseUrl}${apiUrl}${params.length ? `?${params}` : ''}`;
- if (this.instanceSettings.withCredentials || this.instanceSettings.basicAuth) {
- options = { ...options, withCredentials: true };
- if (this.instanceSettings.basicAuth) {
- options.headers = { ...options.headers, Authorization: this.instanceSettings.basicAuth };
- }
- }
- const req = {
- ...options,
- url,
- };
- return getBackendSrv().fetch<Record<string, any>>(req);
- }
- getLogsVolumeDataProvider(request: DataQueryRequest<LokiQuery>): Observable<DataQueryResponse> | undefined {
- const isQuerySuitable = (query: LokiQuery) => {
- const normalized = getNormalizedLokiQuery(query);
- const { expr } = normalized;
- // it has to be a logs-producing range-query
- return expr && !isMetricsQuery(expr) && normalized.queryType === LokiQueryType.Range;
- };
- const isLogsVolumeAvailable = request.targets.some(isQuerySuitable);
- if (!isLogsVolumeAvailable) {
- return undefined;
- }
- const logsVolumeRequest = cloneDeep(request);
- logsVolumeRequest.targets = logsVolumeRequest.targets.filter(isQuerySuitable).map((target) => {
- return {
- ...target,
- instant: false,
- volumeQuery: true,
- expr: `sum by (level) (count_over_time(${target.expr}[$__interval]))`,
- };
- });
- return queryLogsVolume(this, logsVolumeRequest, {
- extractLevel,
- range: request.range,
- targets: request.targets,
- });
- }
- query(request: DataQueryRequest<LokiQuery>): Observable<DataQueryResponse> {
- const subQueries: Array<Observable<DataQueryResponse>> = [];
- const scopedVars = {
- ...request.scopedVars,
- ...this.getRangeScopedVars(request.range),
- };
- if (this.useBackendMode) {
- const queries = request.targets
- .map(getNormalizedLokiQuery) // "fix" the `.queryType` prop
- .map((q) => ({ ...q, maxLines: q.maxLines || this.maxLines })); // set maxLines if not set
- const fixedRequest = {
- ...request,
- targets: queries,
- };
- const streamQueries = fixedRequest.targets.filter((q) => q.queryType === LokiQueryType.Stream);
- if (config.featureToggles.lokiLive && streamQueries.length > 0 && fixedRequest.rangeRaw?.to === 'now') {
- // this is still an in-development feature,
- // we do not support mixing stream-queries with normal-queries for now.
- const streamRequest = {
- ...fixedRequest,
- targets: streamQueries,
- };
- return merge(...streamQueries.map((q) => doLokiChannelStream(q, this, streamRequest)));
- }
- if (fixedRequest.liveStreaming) {
- return this.runLiveQueryThroughBackend(fixedRequest);
- } else {
- return super
- .query(fixedRequest)
- .pipe(
- map((response) =>
- transformBackendResult(response, fixedRequest.targets, this.instanceSettings.jsonData.derivedFields ?? [])
- )
- );
- }
- }
- const filteredTargets = request.targets
- .filter((target) => target.expr && !target.hide)
- .map((target) => {
- const expr = this.addAdHocFilters(target.expr);
- return {
- ...target,
- expr: this.templateSrv.replace(expr, scopedVars, this.interpolateQueryExpr),
- };
- });
- for (const target of filteredTargets) {
- if (target.instant || target.queryType === LokiQueryType.Instant) {
- subQueries.push(this.runInstantQuery(target, request, filteredTargets.length));
- } else if (
- config.featureToggles.lokiLive &&
- target.queryType === LokiQueryType.Stream &&
- request.rangeRaw?.to === 'now'
- ) {
- subQueries.push(doLokiChannelStream(target, this, request));
- } else {
- subQueries.push(this.runRangeQuery(target, request));
- }
- }
- // No valid targets, return the empty result to save a round trip.
- if (isEmpty(subQueries)) {
- return of({
- data: [],
- state: LoadingState.Done,
- });
- }
- return merge(...subQueries);
- }
- runLiveQueryThroughBackend(request: DataQueryRequest<LokiQuery>): Observable<DataQueryResponse> {
- // this only works in explore-mode, so variables don't need to be handled,
- // and only for logs-queries, not metric queries
- const logsQueries = request.targets.filter((query) => query.expr !== '' && !isMetricsQuery(query.expr));
- if (logsQueries.length === 0) {
- return of({
- data: [],
- state: LoadingState.Done,
- });
- }
- const subQueries = logsQueries.map((query) => {
- const maxDataPoints = query.maxLines || this.maxLines;
- // FIXME: currently we are running it through the frontend still.
- return this.runLiveQuery(query, maxDataPoints);
- });
- return merge(...subQueries);
- }
- runInstantQuery = (
- target: LokiQuery,
- options: DataQueryRequest<LokiQuery>,
- responseListLength = 1
- ): Observable<DataQueryResponse> => {
- const timeNs = this.getTime(options.range.to, true);
- const queryLimit = isMetricsQuery(target.expr) ? options.maxDataPoints : target.maxLines;
- const query = {
- query: target.expr,
- time: `${timeNs + (1e9 - (timeNs % 1e9))}`,
- limit: Math.min(queryLimit || Infinity, this.maxLines),
- direction: target.direction === LokiQueryDirection.Forward ? 'FORWARD' : 'BACKWARD',
- };
- /** Used only for results of metrics instant queries */
- const meta: QueryResultMeta = {
- preferredVisualisationType: 'table',
- };
- return this._request(INSTANT_QUERY_ENDPOINT, query).pipe(
- map((response) => {
- if (response.data.data.resultType === LokiResultType.Stream) {
- return {
- data: response.data
- ? lokiStreamsToDataFrames(
- response.data as LokiStreamResponse,
- target,
- query.limit,
- this.instanceSettings.jsonData
- )
- : [],
- key: `${target.refId}_instant`,
- };
- }
- return {
- data: [lokiResultsToTableModel(response.data.data.result, responseListLength, target.refId, meta)],
- key: `${target.refId}_instant`,
- };
- }),
- catchError((err) => throwError(() => this.processError(err, target)))
- );
- };
- createRangeQuery(target: LokiQuery, options: RangeQueryOptions, limit: number): LokiRangeQueryRequest {
- const query = target.expr;
- let range: { start?: number; end?: number; step?: number } = {};
- if (options.range) {
- const startNs = this.getTime(options.range.from, false);
- const endNs = this.getTime(options.range.to, true);
- const rangeMs = Math.ceil((endNs - startNs) / 1e6);
- const resolution = target.resolution || (DEFAULT_RESOLUTION.value as number);
- const adjustedInterval =
- this.adjustInterval((options as DataQueryRequest<LokiQuery>).intervalMs || 1000, resolution, rangeMs) / 1000;
- // We want to ceil to 3 decimal places
- const step = Math.ceil(adjustedInterval * 1000) / 1000;
- range = {
- start: startNs,
- end: endNs,
- step,
- };
- }
- return {
- ...DEFAULT_QUERY_PARAMS,
- ...range,
- query,
- limit,
- direction: target.direction === LokiQueryDirection.Forward ? 'FORWARD' : 'BACKWARD',
- };
- }
- /**
- * Attempts to send a query to /loki/api/v1/query_range
- */
- runRangeQuery = (target: LokiQuery, options: RangeQueryOptions): Observable<DataQueryResponse> => {
- // For metric query we use maxDataPoints from the request options which should be something like width of the
- // visualisation in pixels. In case of logs request we either use lines limit defined in the query target or
- // global limit defined for the data source which ever is lower.
- let maxDataPoints = isMetricsQuery(target.expr)
- ? // We fallback to maxLines here because maxDataPoints is defined as possibly undefined. Not sure that can
- // actually happen both Dashboards and Explore should send some value here. If not maxLines does not make that
- // much sense but nor any other arbitrary value.
- (options as DataQueryRequest<LokiQuery>).maxDataPoints || this.maxLines
- : // If user wants maxLines 0 we still fallback to data source limit. I think that makes sense as why would anyone
- // want to do a query and not see any results?
- target.maxLines || this.maxLines;
- if ((options as DataQueryRequest<LokiQuery>).liveStreaming) {
- return this.runLiveQuery(target, maxDataPoints);
- }
- const query = this.createRangeQuery(target, options, maxDataPoints);
- const headers = target.volumeQuery ? { 'X-Query-Tags': 'Source=logvolhist' } : undefined;
- return this._request(RANGE_QUERY_ENDPOINT, query, { headers }).pipe(
- catchError((err) => throwError(() => this.processError(err, target))),
- switchMap((response) =>
- processRangeQueryResponse(
- response.data,
- target,
- query,
- maxDataPoints,
- this.instanceSettings.jsonData,
- (options as DataQueryRequest<LokiQuery>).scopedVars
- )
- )
- );
- };
- createLiveTarget(target: LokiQuery, maxDataPoints: number): LokiLiveTarget {
- const query = target.expr;
- const baseUrl = this.instanceSettings.url;
- const params = serializeParams({ query });
- return {
- query,
- url: convertToWebSocketUrl(`${baseUrl}/loki/api/v1/tail?${params}`),
- refId: target.refId,
- size: maxDataPoints,
- };
- }
- /**
- * Runs live queries which in this case means creating a websocket and listening on it for new logs.
- * This returns a bit different dataFrame than runQueries as it returns single dataframe even if there are multiple
- * Loki streams, sets only common labels on dataframe.labels and has additional dataframe.fields.labels for unique
- * labels per row.
- */
- runLiveQuery = (target: LokiQuery, maxDataPoints: number): Observable<DataQueryResponse> => {
- const liveTarget = this.createLiveTarget(target, maxDataPoints);
- return this.streams.getStream(liveTarget).pipe(
- map((data) => ({
- data: data || [],
- key: `loki-${liveTarget.refId}`,
- state: LoadingState.Streaming,
- })),
- catchError((err: any) => {
- return throwError(() => `Live tailing was stopped due to following error: ${err.reason}`);
- })
- );
- };
- getRangeScopedVars(range: TimeRange = this.timeSrv.timeRange()) {
- const msRange = range.to.diff(range.from);
- const sRange = Math.round(msRange / 1000);
- return {
- __range_ms: { text: msRange, value: msRange },
- __range_s: { text: sRange, value: sRange },
- __range: { text: sRange + 's', value: sRange + 's' },
- };
- }
- interpolateVariablesInQueries(queries: LokiQuery[], scopedVars: ScopedVars): LokiQuery[] {
- let expandedQueries = queries;
- if (queries && queries.length) {
- expandedQueries = queries.map((query) => ({
- ...query,
- datasource: this.getRef(),
- expr: this.templateSrv.replace(query.expr, scopedVars, this.interpolateQueryExpr),
- }));
- }
- return expandedQueries;
- }
- getQueryDisplayText(query: LokiQuery) {
- return query.expr;
- }
- getTimeRangeParams() {
- const timeRange = this.timeSrv.timeRange();
- return { start: timeRange.from.valueOf() * NS_IN_MS, end: timeRange.to.valueOf() * NS_IN_MS };
- }
- async importFromAbstractQueries(abstractQueries: AbstractQuery[]): Promise<LokiQuery[]> {
- await this.languageProvider.start();
- const existingKeys = this.languageProvider.labelKeys;
- if (existingKeys && existingKeys.length) {
- abstractQueries = abstractQueries.map((abstractQuery) => {
- abstractQuery.labelMatchers = abstractQuery.labelMatchers.filter((labelMatcher) => {
- return existingKeys.includes(labelMatcher.name);
- });
- return abstractQuery;
- });
- }
- return abstractQueries.map((abstractQuery) => this.languageProvider.importFromAbstractQuery(abstractQuery));
- }
- async exportToAbstractQueries(queries: LokiQuery[]): Promise<AbstractQuery[]> {
- return queries.map((query) => this.languageProvider.exportToAbstractQuery(query));
- }
- async metadataRequest(url: string, params?: Record<string, string | number>) {
- // url must not start with a `/`, otherwise the AJAX-request
- // going from the browser will contain `//`, which can cause problems.
- if (url.startsWith('/')) {
- throw new Error(`invalid metadata request url: ${url}`);
- }
- if (this.useBackendMode) {
- const res = await this.getResource(url, params);
- return res.data || [];
- } else {
- const lokiURL = `${LOKI_ENDPOINT}/${url}`;
- const res = await lastValueFrom(this._request(lokiURL, params, { hideFromInspector: true }));
- return res.data.data || [];
- }
- }
- async metricFindQuery(query: string) {
- if (!query) {
- return Promise.resolve([]);
- }
- const interpolated = this.templateSrv.replace(query, {}, this.interpolateQueryExpr);
- return await this.processMetricFindQuery(interpolated);
- }
- async processMetricFindQuery(query: string) {
- const labelNamesRegex = /^label_names\(\)\s*$/;
- const labelValuesRegex = /^label_values\((?:(.+),\s*)?([a-zA-Z_][a-zA-Z0-9_]*)\)\s*$/;
- const labelNames = query.match(labelNamesRegex);
- if (labelNames) {
- return await this.labelNamesQuery();
- }
- const labelValues = query.match(labelValuesRegex);
- if (labelValues) {
- // If we have query expr, use /series endpoint
- if (labelValues[1]) {
- return await this.labelValuesSeriesQuery(labelValues[1], labelValues[2]);
- }
- return await this.labelValuesQuery(labelValues[2]);
- }
- return Promise.resolve([]);
- }
- async labelNamesQuery() {
- const url = 'labels';
- const params = this.getTimeRangeParams();
- const result = await this.metadataRequest(url, params);
- return result.map((value: string) => ({ text: value }));
- }
- async labelValuesQuery(label: string) {
- const params = this.getTimeRangeParams();
- const url = `label/${label}/values`;
- const result = await this.metadataRequest(url, params);
- return result.map((value: string) => ({ text: value }));
- }
- async labelValuesSeriesQuery(expr: string, label: string) {
- const timeParams = this.getTimeRangeParams();
- const params = {
- ...timeParams,
- 'match[]': expr,
- };
- const url = 'series';
- const streams = new Set();
- const result = await this.metadataRequest(url, params);
- result.forEach((stream: { [key: string]: string }) => {
- if (stream[label]) {
- streams.add({ text: stream[label] });
- }
- });
- return Array.from(streams);
- }
- // By implementing getTagKeys and getTagValues we add ad-hoc filtters functionality
- async getTagKeys() {
- return await this.labelNamesQuery();
- }
- async getTagValues(options: any = {}) {
- return await this.labelValuesQuery(options.key);
- }
- interpolateQueryExpr(value: any, variable: any) {
- // if no multi or include all do not regexEscape
- if (!variable.multi && !variable.includeAll) {
- return lokiRegularEscape(value);
- }
- if (typeof value === 'string') {
- return lokiSpecialRegexEscape(value);
- }
- const escapedValues = lodashMap(value, lokiSpecialRegexEscape);
- return escapedValues.join('|');
- }
- modifyQuery(query: LokiQuery, action: any): LokiQuery {
- let expression = query.expr ?? '';
- switch (action.type) {
- case 'ADD_FILTER': {
- expression = this.addLabelToQuery(expression, action.key, action.value, '=');
- break;
- }
- case 'ADD_FILTER_OUT': {
- expression = this.addLabelToQuery(expression, action.key, action.value, '!=');
- break;
- }
- default:
- break;
- }
- return { ...query, expr: expression };
- }
- getTime(date: string | DateTime, roundUp: boolean) {
- if (typeof date === 'string') {
- date = dateMath.parse(date, roundUp)!;
- }
- return Math.ceil(date.valueOf() * 1e6);
- }
- getLogRowContext = (row: LogRowModel, options?: RowContextOptions): Promise<{ data: DataFrame[] }> => {
- const direction = (options && options.direction) || 'BACKWARD';
- const limit = (options && options.limit) || 10;
- const { query, range } = this.prepareLogRowContextQueryTarget(row, limit, direction);
- const processDataFrame = (frame: DataFrame): DataFrame => {
- // log-row-context requires specific field-names to work, so we set them here: "ts", "line", "id"
- const cache = new FieldCache(frame);
- const timestampField = cache.getFirstFieldOfType(FieldType.time);
- const lineField = cache.getFirstFieldOfType(FieldType.string);
- const idField = cache.getFieldByName('id');
- if (timestampField === undefined || lineField === undefined || idField === undefined) {
- // this should never really happen, but i want to keep typescript happy
- return { ...frame, fields: [] };
- }
- return {
- ...frame,
- fields: [
- {
- ...timestampField,
- name: 'ts',
- },
- {
- ...lineField,
- name: 'line',
- },
- {
- ...idField,
- name: 'id',
- },
- ],
- };
- };
- const processResults = (result: DataQueryResponse): DataQueryResponse => {
- const frames: DataFrame[] = result.data;
- const processedFrames = frames
- .map((frame) => sortDataFrameByTime(frame, 'DESCENDING'))
- .map((frame) => processDataFrame(frame)); // rename fields if needed
- return {
- ...result,
- data: processedFrames,
- };
- };
- // this can only be called from explore currently
- const app = CoreApp.Explore;
- return lastValueFrom(
- this.query(makeRequest(query, range, app, `log-row-context-query-${direction}`)).pipe(
- catchError((err) => {
- const error: DataQueryError = {
- message: 'Error during context query. Please check JS console logs.',
- status: err.status,
- statusText: err.statusText,
- };
- throw error;
- }),
- switchMap((res) => of(processResults(res)))
- )
- );
- };
- prepareLogRowContextQueryTarget = (
- row: LogRowModel,
- limit: number,
- direction: 'BACKWARD' | 'FORWARD'
- ): { query: LokiQuery; range: TimeRange } => {
- const labels = this.languageProvider.getLabelKeys();
- const expr = Object.keys(row.labels)
- .map((label: string) => {
- if (labels.includes(label)) {
- // escape backslashes in label as users can't escape them by themselves
- return `${label}="${row.labels[label].replace(/\\/g, '\\\\')}"`;
- }
- return '';
- })
- // Filter empty strings
- .filter((label) => !!label)
- .join(',');
- const contextTimeBuffer = 2 * 60 * 60 * 1000; // 2h buffer
- const queryDirection = direction === 'FORWARD' ? LokiQueryDirection.Forward : LokiQueryDirection.Backward;
- const query: LokiQuery = {
- expr: `{${expr}}`,
- queryType: LokiQueryType.Range,
- refId: '',
- maxLines: limit,
- direction: queryDirection,
- };
- const fieldCache = new FieldCache(row.dataFrame);
- const tsField = fieldCache.getFirstFieldOfType(FieldType.time);
- if (tsField === undefined) {
- throw new Error('loki: dataframe missing time-field, should never happen');
- }
- const tsValue = tsField.values.get(row.rowIndex);
- const timestamp = toUtc(tsValue);
- const range =
- queryDirection === LokiQueryDirection.Forward
- ? {
- // start param in Loki API is inclusive so we'll have to filter out the row that this request is based from
- // and any other that were logged in the same ns but before the row. Right now these rows will be lost
- // because the are before but came it he response that should return only rows after.
- from: timestamp,
- // convert to ns, we loose some precision here but it is not that important at the far points of the context
- to: toUtc(row.timeEpochMs + contextTimeBuffer),
- }
- : {
- // convert to ns, we loose some precision here but it is not that important at the far points of the context
- from: toUtc(row.timeEpochMs - contextTimeBuffer),
- to: timestamp,
- };
- return {
- query,
- range: {
- from: range.from,
- to: range.to,
- raw: range,
- },
- };
- };
- testDatasource(): Promise<{ status: string; message: string }> {
- // Consider only last 10 minutes otherwise request takes too long
- const nowMs = Date.now();
- const params = {
- start: (nowMs - 10 * 60 * 1000) * NS_IN_MS,
- end: nowMs * NS_IN_MS,
- };
- return this.metadataRequest('labels', params).then(
- (values) => {
- return values.length > 0
- ? { status: 'success', message: 'Data source connected and labels found.' }
- : {
- status: 'error',
- message:
- 'Data source connected, but no labels received. Verify that Loki and Promtail is configured properly.',
- };
- },
- (err) => {
- // we did a resource-call that failed.
- // the only info we have, if exists, is err.data.message
- // (when in development-mode, err.data.error exists too, but not in production-mode)
- // things like err.status & err.statusText does not help,
- // because those will only describe how the request between browser<>server failed
- const info: string = err?.data?.message ?? '';
- const infoInParentheses = info !== '' ? ` (${info})` : '';
- const message = `Unable to fetch labels from Loki${infoInParentheses}, please check the server logs for more details`;
- return { status: 'error', message: message };
- }
- );
- }
- async annotationQuery(options: any): Promise<AnnotationEvent[]> {
- const { expr, maxLines, instant, tagKeys = '', titleFormat = '', textFormat = '' } = options.annotation;
- if (!expr) {
- return [];
- }
- const id = `annotation-${options.annotation.name}`;
- const query: LokiQuery = {
- refId: id,
- expr,
- maxLines,
- instant,
- queryType: instant ? LokiQueryType.Instant : LokiQueryType.Range,
- };
- const request = makeRequest(query, options.range, CoreApp.Dashboard, id);
- const { data } = await lastValueFrom(this.query(request));
- const annotations: AnnotationEvent[] = [];
- const splitKeys: string[] = tagKeys.split(',').filter((v: string) => v !== '');
- for (const frame of data) {
- const view = new DataFrameView<{ Time: string; Line: string; labels: Labels }>(frame);
- view.forEach((row) => {
- const { labels } = row;
- const maybeDuplicatedTags = Object.entries(labels)
- .map(([key, val]) => [key, val.trim()]) // trim all label-values
- .filter(([key, val]) => {
- if (val === '') {
- // remove empty
- return false;
- }
- // if tags are specified, remove label if does not match tags
- if (splitKeys.length && !splitKeys.includes(key)) {
- return false;
- }
- return true;
- })
- .map(([key, val]) => val); // keep only the label-value
- // remove duplicates
- const tags = Array.from(new Set(maybeDuplicatedTags));
- annotations.push({
- time: new Date(row.Time).valueOf(),
- title: renderLegendFormat(titleFormat, labels),
- text: renderLegendFormat(textFormat, labels) || row.Line,
- tags,
- });
- });
- }
- return annotations;
- }
- showContextToggle(row?: LogRowModel): boolean {
- return (row && row.searchWords && row.searchWords.length > 0) === true;
- }
- processError(err: FetchError, target: LokiQuery) {
- let error: DataQueryError = cloneDeep(err);
- error.refId = target.refId;
- if (error.data && err.data.message.includes('escape') && target.expr.includes('\\')) {
- error.data.message = `Error: ${err.data.message}. Make sure that all special characters are escaped with \\. For more information on escaping of special characters visit LogQL documentation at https://grafana.com/docs/loki/latest/logql/.`;
- }
- return error;
- }
- adjustInterval(dynamicInterval: number, resolution: number, range: number) {
- // Loki will drop queries that might return more than 11000 data points.
- // Calibrate interval if it is too small.
- let safeInterval = range / 11000;
- if (safeInterval > 1) {
- safeInterval = Math.ceil(safeInterval);
- }
- let adjustedInterval = Math.max(resolution * dynamicInterval, safeInterval);
- return adjustedInterval;
- }
- addAdHocFilters(queryExpr: string) {
- const adhocFilters = this.templateSrv.getAdhocFilters(this.name);
- let expr = queryExpr;
- expr = adhocFilters.reduce((acc: string, filter: { key?: any; operator?: any; value?: any }) => {
- const { key, operator } = filter;
- let { value } = filter;
- return this.addLabelToQuery(acc, key, value, operator, true);
- }, expr);
- return expr;
- }
- addLabelToQuery(
- queryExpr: string,
- key: string,
- value: string | number,
- operator: string,
- // Override to make sure that we use label as actual label and not parsed label
- notParsedLabelOverride?: boolean
- ) {
- let escapedValue = escapeLabelValueInSelector(value.toString(), operator);
- if (queryHasPipeParser(queryExpr) && !isMetricsQuery(queryExpr) && !notParsedLabelOverride) {
- // If query has parser, we treat all labels as parsed and use | key="value" syntax
- return addParsedLabelToQuery(queryExpr, key, escapedValue, operator);
- } else {
- return addLabelToQuery(queryExpr, key, escapedValue, operator, true);
- }
- }
- // Used when running queries through backend
- filterQuery(query: LokiQuery): boolean {
- if (query.hide || query.expr === '') {
- return false;
- }
- return true;
- }
- // Used when running queries through backend
- applyTemplateVariables(target: LokiQuery, scopedVars: ScopedVars): LokiQuery {
- // We want to interpolate these variables on backend
- const { __interval, __interval_ms, ...rest } = scopedVars;
- const exprWithAdHoc = this.addAdHocFilters(target.expr);
- return {
- ...target,
- legendFormat: this.templateSrv.replace(target.legendFormat, rest),
- expr: this.templateSrv.replace(exprWithAdHoc, rest, this.interpolateQueryExpr),
- };
- }
- interpolateString(string: string) {
- return this.templateSrv.replace(string, undefined, this.interpolateQueryExpr);
- }
- getVariables(): string[] {
- return this.templateSrv.getVariables().map((v) => `$${v.name}`);
- }
- }
- export function lokiRegularEscape(value: any) {
- if (typeof value === 'string') {
- return value.replace(/'/g, "\\\\'");
- }
- return value;
- }
- export function lokiSpecialRegexEscape(value: any) {
- if (typeof value === 'string') {
- return lokiRegularEscape(value.replace(/\\/g, '\\\\\\\\').replace(/[$^*{}\[\]+?.()|]/g, '\\\\$&'));
- }
- return value;
- }
- /**
- * Checks if the query expression uses function and so should return a time series instead of logs.
- * Sometimes important to know that before we actually do the query.
- */
- export function isMetricsQuery(query: string): boolean {
- if (!query) {
- return false;
- }
- const tokens = Prism.tokenize(query, syntax);
- return tokens.some((t) => {
- // Not sure in which cases it can be string maybe if nothing matched which means it should not be a function
- return typeof t !== 'string' && t.type === 'function';
- });
- }
- function extractLevel(dataFrame: DataFrame): LogLevel {
- let valueField;
- try {
- valueField = new FieldCache(dataFrame).getFirstFieldOfType(FieldType.number);
- } catch {}
- return valueField?.labels ? getLogLevelFromLabels(valueField.labels) : LogLevel.unknown;
- }
- function getLogLevelFromLabels(labels: Labels): LogLevel {
- const labelNames = ['level', 'lvl', 'loglevel'];
- let levelLabel;
- for (let labelName of labelNames) {
- if (labelName in labels) {
- levelLabel = labelName;
- break;
- }
- }
- return levelLabel ? getLogLevelFromKey(labels[levelLabel]) : LogLevel.unknown;
- }
|