All Downloads are FREE. Search and download functionalities are using the official Maven repository.

com.hazelcast.client.impl.statistics.ClientStatisticsService Maven / Gradle / Ivy

The newest version!
/*
 * Copyright (c) 2008-2024, Hazelcast, Inc. 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.
 */

package com.hazelcast.client.impl.statistics;

import com.hazelcast.client.config.ClientMetricsConfig;
import com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl;
import com.hazelcast.client.impl.connection.tcp.TcpClientConnection;
import com.hazelcast.client.impl.connection.tcp.TcpClientConnectionManager;
import com.hazelcast.client.impl.protocol.ClientMessage;
import com.hazelcast.client.impl.protocol.codec.ClientStatisticsCodec;
import com.hazelcast.client.impl.spi.ClientContext;
import com.hazelcast.client.impl.spi.ProxyManager;
import com.hazelcast.client.impl.spi.impl.ClientInvocation;
import com.hazelcast.instance.BuildInfoProvider;
import com.hazelcast.internal.metrics.Gauge;
import com.hazelcast.internal.metrics.MetricDescriptor;
import com.hazelcast.internal.metrics.MetricsRegistry;
import com.hazelcast.internal.metrics.collectors.MetricsCollector;
import com.hazelcast.internal.metrics.impl.CompositeMetricsCollector;
import com.hazelcast.internal.metrics.impl.MetricsCompressor;
import com.hazelcast.internal.metrics.impl.PublisherMetricsCollector;
import com.hazelcast.internal.metrics.jmx.JmxPublisher;
import com.hazelcast.internal.nio.ConnectionType;
import com.hazelcast.logging.ILogger;
import com.hazelcast.logging.Logger;
import com.hazelcast.nearcache.NearCacheStats;
import com.hazelcast.security.Credentials;

import java.util.ArrayList;
import java.util.List;

import static java.util.concurrent.TimeUnit.SECONDS;

/**
 * This class is the main entry point for collecting and sending the client
 * statistics to the cluster. If the client statistics feature is enabled,
 * it will be scheduled for periodic statistics collection and sent.
 */
public class ClientStatisticsService {

    private static final String NEAR_CACHE_CATEGORY_PREFIX = "nc.";
    private static final char STAT_SEPARATOR = ',';
    private static final char KEY_VALUE_SEPARATOR = '=';
    private static final char ESCAPE_CHAR = '\\';

    private final MetricsRegistry metricsRegistry;
    private final boolean enabled;
    private final ILogger logger = Logger.getLogger(this.getClass());

    private final HazelcastClientInstanceImpl client;

    private final boolean enterprise;
    private final ClientMetricsConfig metricsConfig;

    private PeriodicStatistics periodicStats;

    private volatile PublisherMetricsCollector publisherMetricsCollector;

    public ClientStatisticsService(final HazelcastClientInstanceImpl clientInstance) {
        this.metricsConfig = clientInstance.getClientConfig().getMetricsConfig();
        this.enabled = metricsConfig.isEnabled();
        this.client = clientInstance;
        this.enterprise = BuildInfoProvider.getBuildInfo().isEnterprise();
        this.metricsRegistry = clientInstance.getMetricsRegistry();
    }

    /**
     * Registers all client statistics and schedules periodic collection of stats.
     */
    public final void start() {
        if (!enabled) {
            return;
        }

        if (metricsConfig.getJmxConfig().isEnabled()) {
            publisherMetricsCollector = new PublisherMetricsCollector(new JmxPublisher(client.getName(), "com.hazelcast"));
        } else {
            publisherMetricsCollector = new PublisherMetricsCollector();
        }

        metricsRegistry.registerDynamicMetricsProvider(new ClusterConnectionMetricsProvider(client.getConnectionManager()));
        client.getMetricsRegistry().registerDynamicMetricsProvider(new NearCacheMetricsProvider(client.getProxyManager()));

        long periodSeconds = metricsConfig.getCollectionFrequencySeconds();

        // Note that the OperatingSystemMetricSet and RuntimeMetricSet are already registered during client start,
        // hence we do not re-register
        periodicStats = new PeriodicStatistics();

        schedulePeriodicStatisticsSendTask(metricsConfig.getCollectionFrequencySeconds());

        logger.info("Client statistics is enabled with period " + periodSeconds + " seconds.");
    }

    public void collectAndSendStatsNow() {
        if (!enabled) {
            return;
        }

        client.getTaskScheduler().schedule(this::collectAndSendStats, 0, SECONDS);
    }

    public void shutdown() {
        if (publisherMetricsCollector != null) {
            publisherMetricsCollector.shutdown();
        }
    }

    // visible for testing
    public ClientMetricsConfig getMetricsConfig() {
        return metricsConfig;
    }

    /**
     * @return the cluster listening connection to the server
     */
    private TcpClientConnection getConnection() {
        return (TcpClientConnection) client.getConnectionManager().getRandomConnection();
    }

    /**
     * @param periodSeconds the interval at which the statistics collection and send is being run
     */
    private void schedulePeriodicStatisticsSendTask(long periodSeconds) {
        client.getTaskScheduler().scheduleWithRepetition(this::collectAndSendStats, 0, periodSeconds, SECONDS);
    }

    private void collectAndSendStats() {
        try (ClientMetricCollector clientMetricCollector = new ClientMetricCollector()) {
            CompositeMetricsCollector compositeMetricsCollector = new CompositeMetricsCollector(clientMetricCollector,
                    publisherMetricsCollector);

            long collectionTimestamp = System.currentTimeMillis();
            metricsRegistry.collect(compositeMetricsCollector);
            publisherMetricsCollector.publishCollectedMetrics();

            TcpClientConnection connection = getConnection();
            if (connection == null) {
                logger.finest("Cannot send client statistics to the server. No connection found.");
                return;
            }

            final StringBuilder clientAttributes = new StringBuilder();
            periodicStats.fillMetrics(collectionTimestamp, clientAttributes, connection);
            addNearCacheStats(clientAttributes);

            byte[] metricsBlob = clientMetricCollector.getBlob();
            sendStats(collectionTimestamp, clientAttributes.toString(), metricsBlob, connection);
        }
    }

    private void addNearCacheStats(final StringBuilder stats) {
        ProxyManager proxyManager = client.getProxyManager();
        ClientContext context = proxyManager.getContext();
        if (context == null) {
            return;
        }

        context.getNearCacheManagers()
                .values()
                .stream()
                .flatMap(nearCacheManager -> nearCacheManager.listAllNearCaches().stream())
                .forEach(
                        nearCache -> {
                            String nearCacheName = nearCache.getName();
                            StringBuilder nearCacheNameWithPrefix = getNameWithPrefix(nearCacheName);

                            nearCacheNameWithPrefix.append('.');

                            NearCacheStats nearCacheStats = nearCache.getNearCacheStats();

                            String prefix = nearCacheNameWithPrefix.toString();

                            addStat(stats, prefix, "creationTime", nearCacheStats.getCreationTime());
                            addStat(stats, prefix, "evictions", nearCacheStats.getEvictions());
                            addStat(stats, prefix, "hits", nearCacheStats.getHits());
                            addStat(stats, prefix, "lastPersistenceDuration", nearCacheStats.getLastPersistenceDuration());
                            addStat(stats, prefix, "lastPersistenceKeyCount", nearCacheStats.getLastPersistenceKeyCount());
                            addStat(stats, prefix, "lastPersistenceTime", nearCacheStats.getLastPersistenceTime());
                            addStat(stats, prefix, "lastPersistenceWrittenBytes",
                                    nearCacheStats.getLastPersistenceWrittenBytes());
                            addStat(stats, prefix, "misses", nearCacheStats.getMisses());
                            addStat(stats, prefix, "ownedEntryCount", nearCacheStats.getOwnedEntryCount());
                            addStat(stats, prefix, "expirations", nearCacheStats.getExpirations());
                            addStat(stats, prefix, "invalidations", nearCacheStats.getInvalidations());
                            addStat(stats, prefix, "invalidationRequests", nearCacheStats.getInvalidationRequests());
                            addStat(stats, prefix, "ownedEntryMemoryCost", nearCacheStats.getOwnedEntryMemoryCost());
                            String persistenceFailure = nearCacheStats.getLastPersistenceFailure();
                            if (persistenceFailure != null && !persistenceFailure.isEmpty()) {
                                addStat(stats, prefix, "lastPersistenceFailure", persistenceFailure);
                            }
                        }
                );
    }

    private void addStat(final StringBuilder stats, final String name, long value) {
        addStat(stats, null, name, value);
    }

    private void addStat(final StringBuilder stats, final String keyPrefix, final String name, long value) {
        stats.append(STAT_SEPARATOR);
        if (null != keyPrefix) {
            stats.append(keyPrefix);
        }
        stats.append(name).append(KEY_VALUE_SEPARATOR).append(value);
    }

    private void addStat(StringBuilder stats, String name, String value) {
        addStat(stats, null, name, value);
    }

    private void addStat(StringBuilder stats, String keyPrefix, String name, String value) {
        stats.append(STAT_SEPARATOR);
        if (null != keyPrefix) {
            stats.append(keyPrefix);
        }
        stats.append(name).append(KEY_VALUE_SEPARATOR).append(value);
    }

    private void addStat(StringBuilder stats, String name, boolean value) {
        stats.append(STAT_SEPARATOR).append(name).append(KEY_VALUE_SEPARATOR).append(value);
    }

    private StringBuilder getNameWithPrefix(String name) {
        StringBuilder escapedName = new StringBuilder(NEAR_CACHE_CATEGORY_PREFIX);
        int prefixLen = NEAR_CACHE_CATEGORY_PREFIX.length();
        escapedName.append(name);
        if (escapedName.charAt(prefixLen) == '/') {
            escapedName.deleteCharAt(prefixLen);
        }

        escapeSpecialCharacters(escapedName, prefixLen);
        return escapedName;
    }

    /**
     * @param buffer the string for which the special characters ',', '=', '\' are escaped properly
     */
    public static void escapeSpecialCharacters(StringBuilder buffer) {
        escapeSpecialCharacters(buffer, 0);
    }

    public static void escapeSpecialCharacters(StringBuilder buffer, int start) {
        for (int i = start; i < buffer.length(); ++i) {
            char c = buffer.charAt(i);
            if (c == '=' || c == '.' || c == ',' || c == ESCAPE_CHAR) {
                buffer.insert(i, ESCAPE_CHAR);
                ++i;
            }
        }
    }

    /**
     * @param buffer the string for which the escape character '\' is removed properly
     * @return the unescaped string
     */
    public static String unescapeSpecialCharacters(String buffer) {
        return unescapeSpecialCharacters(buffer, 0);
    }

    public static String unescapeSpecialCharacters(String buffer, int start) {
        StringBuilder result = new StringBuilder(buffer);
        unescapeSpecialCharacters(result, start);
        return result.toString();
    }

    public static void unescapeSpecialCharacters(StringBuilder buffer, int start) {
        for (int i = start; i < buffer.length() - 1; ++i) {
            char c = buffer.charAt(i);
            if (c == ESCAPE_CHAR) {
                buffer.deleteCharAt(i);
            }
        }
    }

    /**
     * This method uses ',' character by default. It is for splitting into key=value tokens.
     *
     * @param statString the statistics string to be split
     * @return a list of split strings
     */
    public static List split(String statString) {
        return split(statString, 0, STAT_SEPARATOR);
    }

    /**
     * @param stat      statistics string to be split
     * @param start     the start index for splitting
     * @param splitChar A special character to be used for split, e.g. '='
     * @return a list of split strings
     */
    public static List split(String stat, int start, char splitChar) {
        int bufferLen = stat.length();
        if (bufferLen == 0) {
            return null;
        }

        List result = new ArrayList<>();
        int strStart = start;
        int index = start;
        // just initialize to a non-special character
        char previousChar = 'a';
        for (char currentChar; index < bufferLen; previousChar = currentChar, ++index) {
            currentChar = stat.charAt(index);
            if (currentChar == splitChar) {
                if (previousChar == ESCAPE_CHAR) {
                    continue;
                }

                result.add(stat.substring(strStart, index));
                strStart = index + 1;
            }
        }

        // add the last string if exists
        if (index > strStart) {
            result.add(stat.substring(strStart, index));
        }

        return result;
    }

    private void sendStats(long collectionTimestamp, String newStats, byte[] metricsBlob, TcpClientConnection ownerConnection) {
        ClientMessage request = ClientStatisticsCodec.encodeRequest(collectionTimestamp, newStats, metricsBlob);
        try {
            new ClientInvocation(client, request, null, ownerConnection).invoke();
        } catch (Exception e) {
            // suppress exception, do not print too many messages
            if (logger.isFinestEnabled()) {
                logger.finest("Could not send stats ", e);
            }
        }
    }

    class PeriodicStatistics {
        private final Gauge[] allGauges = {
                metricsRegistry.newLongGauge("os.committedVirtualMemorySize"),
                metricsRegistry.newLongGauge("os.freePhysicalMemorySize"),
                metricsRegistry.newLongGauge("os.freeSwapSpaceSize"),
                metricsRegistry.newLongGauge("os.maxFileDescriptorCount"),
                metricsRegistry.newLongGauge("os.openFileDescriptorCount"),
                metricsRegistry.newLongGauge("os.processCpuTime"),
                metricsRegistry.newDoubleGauge("os.systemLoadAverage"),
                metricsRegistry.newLongGauge("os.totalPhysicalMemorySize"),
                metricsRegistry.newLongGauge("os.totalSwapSpaceSize"),
                metricsRegistry.newLongGauge("runtime.availableProcessors"),
                metricsRegistry.newLongGauge("runtime.freeMemory"),
                metricsRegistry.newLongGauge("runtime.maxMemory"),
                metricsRegistry.newLongGauge("runtime.totalMemory"),
                metricsRegistry.newLongGauge("runtime.uptime"),
                metricsRegistry.newLongGauge("runtime.usedMemory"),
        };

        void fillMetrics(long collectionTimestamp, final StringBuilder stats, final TcpClientConnection mainConnection) {
            stats.append("lastStatisticsCollectionTime").append(KEY_VALUE_SEPARATOR).append(collectionTimestamp);
            addStat(stats, "enterprise", enterprise);
            addStat(stats, "clientType", ConnectionType.JAVA_CLIENT);
            addStat(stats, "clientVersion", BuildInfoProvider.getBuildInfo().getVersion());
            addStat(stats, "clusterConnectionTimestamp", mainConnection.getStartTime());

            stats.append(STAT_SEPARATOR).append("clientAddress").append(KEY_VALUE_SEPARATOR)
                    .append(mainConnection.getLocalSocketAddress().getAddress().getHostAddress());

            addStat(stats, "clientName", client.getName());

            TcpClientConnectionManager connectionManager = (TcpClientConnectionManager) client.getConnectionManager();
            Credentials credentials = connectionManager.getCurrentCredentials();
            if (credentials != null) {
                addStat(stats, "credentials.principal", credentials.getName());
            }

            for (Gauge gauge : allGauges) {
                stats.append(STAT_SEPARATOR).append(gauge.getName()).append(KEY_VALUE_SEPARATOR);
                gauge.render(stats);
            }
        }
    }

    private class ClientMetricCollector
            implements MetricsCollector, AutoCloseable {

        private final MetricsCompressor compressor = new MetricsCompressor();

        @Override
        public void collectLong(MetricDescriptor descriptor, long value) {
            compressor.addLong(descriptor, value);
        }

        @Override
        public void collectDouble(MetricDescriptor descriptor, double value) {
            compressor.addDouble(descriptor, value);
        }

        @Override
        public void collectException(MetricDescriptor descriptor, Exception e) {
            logger.warning("Error when collecting '" + descriptor.toString() + '\'', e);
        }

        @Override
        public void collectNoValue(MetricDescriptor descriptor) {
            // nop
        }

        private byte[] getBlob() {
            return compressor.getBlobAndClose();
        }

        @Override
        public void close() {
            compressor.close();
        }
    }
}




© 2015 - 2025 Weber Informatics LLC | Privacy Policy