Search in sources :

Example 6 with GridIoManager

use of org.apache.ignite.internal.managers.communication.GridIoManager in project ignite by apache.

the class GridDiscoveryManager method createMetricsProvider.

/**
     * @return Metrics provider.
     */
private DiscoveryMetricsProvider createMetricsProvider() {
    return new DiscoveryMetricsProvider() {

        /** */
        private final long startTime = U.currentTimeMillis();

        /** {@inheritDoc} */
        @Override
        public ClusterMetrics metrics() {
            GridJobMetrics jm = ctx.jobMetric().getJobMetrics();
            ClusterMetricsSnapshot nm = new ClusterMetricsSnapshot();
            nm.setLastUpdateTime(U.currentTimeMillis());
            // Job metrics.
            nm.setMaximumActiveJobs(jm.getMaximumActiveJobs());
            nm.setCurrentActiveJobs(jm.getCurrentActiveJobs());
            nm.setAverageActiveJobs(jm.getAverageActiveJobs());
            nm.setMaximumWaitingJobs(jm.getMaximumWaitingJobs());
            nm.setCurrentWaitingJobs(jm.getCurrentWaitingJobs());
            nm.setAverageWaitingJobs(jm.getAverageWaitingJobs());
            nm.setMaximumRejectedJobs(jm.getMaximumRejectedJobs());
            nm.setCurrentRejectedJobs(jm.getCurrentRejectedJobs());
            nm.setAverageRejectedJobs(jm.getAverageRejectedJobs());
            nm.setMaximumCancelledJobs(jm.getMaximumCancelledJobs());
            nm.setCurrentCancelledJobs(jm.getCurrentCancelledJobs());
            nm.setAverageCancelledJobs(jm.getAverageCancelledJobs());
            nm.setTotalRejectedJobs(jm.getTotalRejectedJobs());
            nm.setTotalCancelledJobs(jm.getTotalCancelledJobs());
            nm.setTotalExecutedJobs(jm.getTotalExecutedJobs());
            nm.setMaximumJobWaitTime(jm.getMaximumJobWaitTime());
            nm.setCurrentJobWaitTime(jm.getCurrentJobWaitTime());
            nm.setAverageJobWaitTime(jm.getAverageJobWaitTime());
            nm.setMaximumJobExecuteTime(jm.getMaximumJobExecuteTime());
            nm.setCurrentJobExecuteTime(jm.getCurrentJobExecuteTime());
            nm.setAverageJobExecuteTime(jm.getAverageJobExecuteTime());
            nm.setCurrentIdleTime(jm.getCurrentIdleTime());
            nm.setTotalIdleTime(jm.getTotalIdleTime());
            nm.setAverageCpuLoad(jm.getAverageCpuLoad());
            // Job metrics.
            nm.setTotalExecutedTasks(ctx.task().getTotalExecutedTasks());
            // VM metrics.
            nm.setAvailableProcessors(metrics.getAvailableProcessors());
            nm.setCurrentCpuLoad(metrics.getCurrentCpuLoad());
            nm.setCurrentGcCpuLoad(metrics.getCurrentGcCpuLoad());
            nm.setHeapMemoryInitialized(metrics.getHeapMemoryInitialized());
            nm.setHeapMemoryUsed(metrics.getHeapMemoryUsed());
            nm.setHeapMemoryCommitted(metrics.getHeapMemoryCommitted());
            nm.setHeapMemoryMaximum(metrics.getHeapMemoryMaximum());
            nm.setHeapMemoryTotal(metrics.getHeapMemoryMaximum());
            nm.setNonHeapMemoryInitialized(metrics.getNonHeapMemoryInitialized());
            nonHeapMemoryUsed(nm);
            nm.setNonHeapMemoryCommitted(metrics.getNonHeapMemoryCommitted());
            nm.setNonHeapMemoryMaximum(metrics.getNonHeapMemoryMaximum());
            nm.setNonHeapMemoryTotal(metrics.getNonHeapMemoryMaximum());
            nm.setUpTime(metrics.getUptime());
            nm.setStartTime(metrics.getStartTime());
            nm.setNodeStartTime(startTime);
            nm.setCurrentThreadCount(metrics.getThreadCount());
            nm.setMaximumThreadCount(metrics.getPeakThreadCount());
            nm.setTotalStartedThreadCount(metrics.getTotalStartedThreadCount());
            nm.setCurrentDaemonThreadCount(metrics.getDaemonThreadCount());
            nm.setTotalNodes(1);
            // Data metrics.
            nm.setLastDataVersion(ctx.cache().lastDataVersion());
            GridIoManager io = ctx.io();
            // IO metrics.
            nm.setSentMessagesCount(io.getSentMessagesCount());
            nm.setSentBytesCount(io.getSentBytesCount());
            nm.setReceivedMessagesCount(io.getReceivedMessagesCount());
            nm.setReceivedBytesCount(io.getReceivedBytesCount());
            nm.setOutboundMessagesQueueSize(io.getOutboundMessagesQueueSize());
            return nm;
        }

        /**
             * @param nm Initializing metrics snapshot.
             */
        private void nonHeapMemoryUsed(ClusterMetricsSnapshot nm) {
            long nonHeapUsed = metrics.getNonHeapMemoryUsed();
            Map<Integer, CacheMetrics> nodeCacheMetrics = cacheMetrics();
            if (nodeCacheMetrics != null) {
                for (Map.Entry<Integer, CacheMetrics> entry : nodeCacheMetrics.entrySet()) {
                    CacheMetrics e = entry.getValue();
                    if (e != null)
                        nonHeapUsed += e.getOffHeapAllocatedSize();
                }
            }
            nm.setNonHeapMemoryUsed(nonHeapUsed);
        }

        /** {@inheritDoc} */
        @Override
        public Map<Integer, CacheMetrics> cacheMetrics() {
            Collection<GridCacheAdapter<?, ?>> caches = ctx.cache().internalCaches();
            if (F.isEmpty(caches))
                return Collections.emptyMap();
            Map<Integer, CacheMetrics> metrics = null;
            for (GridCacheAdapter<?, ?> cache : caches) {
                if (cache.configuration().isStatisticsEnabled() && cache.context().started() && cache.context().affinity().affinityTopologyVersion().topologyVersion() > 0) {
                    if (metrics == null)
                        metrics = U.newHashMap(caches.size());
                    metrics.put(cache.context().cacheId(), cache.localMetrics());
                }
            }
            return metrics == null ? Collections.<Integer, CacheMetrics>emptyMap() : metrics;
        }
    };
}
Also used : CacheMetrics(org.apache.ignite.cache.CacheMetrics) ClusterMetricsSnapshot(org.apache.ignite.internal.ClusterMetricsSnapshot) IgniteSystemProperties.getInteger(org.apache.ignite.IgniteSystemProperties.getInteger) GridJobMetrics(org.apache.ignite.internal.processors.jobmetrics.GridJobMetrics) GridIoManager(org.apache.ignite.internal.managers.communication.GridIoManager) GridCacheAdapter(org.apache.ignite.internal.processors.cache.GridCacheAdapter) DiscoveryMetricsProvider(org.apache.ignite.spi.discovery.DiscoveryMetricsProvider) Map(java.util.Map) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) HashMap(java.util.HashMap) ConcurrentMap(java.util.concurrent.ConcurrentMap) GridBoundedConcurrentLinkedHashMap(org.apache.ignite.internal.util.GridBoundedConcurrentLinkedHashMap)

Example 7 with GridIoManager

use of org.apache.ignite.internal.managers.communication.GridIoManager in project ignite by apache.

the class GridEventStorageManager method query.

/**
     * @param p Grid event predicate.
     * @param nodes Collection of nodes.
     * @param timeout Maximum time to wait for result, if {@code 0}, then wait until result is received.
     * @return Collection of events.
     * @throws IgniteCheckedException Thrown in case of any errors.
     */
@SuppressWarnings({ "SynchronizationOnLocalVariableOrMethodParameter", "deprecation" })
private <T extends Event> List<T> query(IgnitePredicate<T> p, Collection<? extends ClusterNode> nodes, long timeout) throws IgniteCheckedException {
    assert p != null;
    assert nodes != null;
    if (nodes.isEmpty()) {
        U.warn(log, "Failed to query events for empty nodes collection.");
        return Collections.emptyList();
    }
    GridIoManager ioMgr = ctx.io();
    final List<T> evts = new ArrayList<>();
    final AtomicReference<Throwable> err = new AtomicReference<>();
    final Set<UUID> uids = new HashSet<>();
    final Object qryMux = new Object();
    for (ClusterNode node : nodes) uids.add(node.id());
    GridLocalEventListener evtLsnr = new GridLocalEventListener() {

        @Override
        public void onEvent(Event evt) {
            assert evt instanceof DiscoveryEvent;
            synchronized (qryMux) {
                uids.remove(((DiscoveryEvent) evt).eventNode().id());
                if (uids.isEmpty())
                    qryMux.notifyAll();
            }
        }
    };
    GridMessageListener resLsnr = new GridMessageListener() {

        @SuppressWarnings("deprecation")
        @Override
        public void onMessage(UUID nodeId, Object msg) {
            assert nodeId != null;
            assert msg != null;
            if (!(msg instanceof GridEventStorageMessage)) {
                U.error(log, "Received unknown message: " + msg);
                return;
            }
            GridEventStorageMessage res = (GridEventStorageMessage) msg;
            try {
                if (res.eventsBytes() != null)
                    res.events(U.<Collection<Event>>unmarshal(marsh, res.eventsBytes(), U.resolveClassLoader(ctx.config())));
                if (res.exceptionBytes() != null)
                    res.exception(U.<Throwable>unmarshal(marsh, res.exceptionBytes(), U.resolveClassLoader(ctx.config())));
            } catch (IgniteCheckedException e) {
                U.error(log, "Failed to unmarshal events query response: " + msg, e);
                return;
            }
            synchronized (qryMux) {
                if (uids.remove(nodeId)) {
                    if (res.events() != null)
                        evts.addAll((Collection<T>) res.events());
                } else
                    U.warn(log, "Received duplicate response (ignoring) [nodeId=" + nodeId + ", msg=" + res + ']');
                if (res.exception() != null)
                    err.set(res.exception());
                if (uids.isEmpty() || err.get() != null)
                    qryMux.notifyAll();
            }
        }
    };
    Object resTopic = TOPIC_EVENT.topic(IgniteUuid.fromUuid(ctx.localNodeId()));
    try {
        addLocalEventListener(evtLsnr, new int[] { EVT_NODE_LEFT, EVT_NODE_FAILED });
        ioMgr.addMessageListener(resTopic, resLsnr);
        byte[] serFilter = U.marshal(marsh, p);
        GridDeployment dep = ctx.deploy().deploy(p.getClass(), U.detectClassLoader(p.getClass()));
        if (dep == null)
            throw new IgniteDeploymentCheckedException("Failed to deploy event filter: " + p);
        GridEventStorageMessage msg = new GridEventStorageMessage(resTopic, serFilter, p.getClass().getName(), dep.classLoaderId(), dep.deployMode(), dep.userVersion(), dep.participants());
        sendMessage(nodes, TOPIC_EVENT, msg, PUBLIC_POOL);
        if (timeout == 0)
            timeout = Long.MAX_VALUE;
        long now = U.currentTimeMillis();
        // Account for overflow of long value.
        long endTime = now + timeout <= 0 ? Long.MAX_VALUE : now + timeout;
        long delta = timeout;
        Collection<UUID> uidsCp = null;
        synchronized (qryMux) {
            try {
                while (!uids.isEmpty() && err.get() == null && delta > 0) {
                    qryMux.wait(delta);
                    delta = endTime - U.currentTimeMillis();
                }
            } catch (InterruptedException e) {
                Thread.currentThread().interrupt();
                throw new IgniteCheckedException("Got interrupted while waiting for event query responses.", e);
            }
            if (err.get() != null)
                throw new IgniteCheckedException("Failed to query events due to exception on remote node.", err.get());
            if (!uids.isEmpty())
                uidsCp = new LinkedList<>(uids);
        }
        // Outside of synchronization.
        if (uidsCp != null) {
            for (Iterator<UUID> iter = uidsCp.iterator(); iter.hasNext(); ) // Ignore nodes that have left the grid.
            if (ctx.discovery().node(iter.next()) == null)
                iter.remove();
            if (!uidsCp.isEmpty())
                throw new IgniteCheckedException("Failed to receive event query response from following nodes: " + uidsCp);
        }
    } finally {
        ioMgr.removeMessageListener(resTopic, resLsnr);
        removeLocalEventListener(evtLsnr);
    }
    return evts;
}
Also used : GridMessageListener(org.apache.ignite.internal.managers.communication.GridMessageListener) ArrayList(java.util.ArrayList) DiscoveryEvent(org.apache.ignite.events.DiscoveryEvent) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) EVT_NODE_LEFT(org.apache.ignite.events.EventType.EVT_NODE_LEFT) EVT_DISCOVERY_CUSTOM_EVT(org.apache.ignite.internal.events.DiscoveryCustomEvent.EVT_DISCOVERY_CUSTOM_EVT) LT(org.apache.ignite.internal.util.typedef.internal.LT) TOPIC_EVENT(org.apache.ignite.internal.GridTopic.TOPIC_EVENT) UUID(java.util.UUID) GridConcurrentLinkedHashSet(org.apache.ignite.internal.util.GridConcurrentLinkedHashSet) HashSet(java.util.HashSet) ClusterNode(org.apache.ignite.cluster.ClusterNode) IgniteDeploymentCheckedException(org.apache.ignite.internal.IgniteDeploymentCheckedException) AtomicReference(java.util.concurrent.atomic.AtomicReference) LinkedList(java.util.LinkedList) GridDeployment(org.apache.ignite.internal.managers.deployment.GridDeployment) GridIoManager(org.apache.ignite.internal.managers.communication.GridIoManager) Event(org.apache.ignite.events.Event) DiscoveryEvent(org.apache.ignite.events.DiscoveryEvent) Collection(java.util.Collection)

Example 8 with GridIoManager

use of org.apache.ignite.internal.managers.communication.GridIoManager in project ignite by apache.

the class GridCheckpointManager method stop.

/** {@inheritDoc} */
@Override
public void stop(boolean cancel) throws IgniteCheckedException {
    if (ctx.config().isDaemon())
        return;
    GridIoManager comm = ctx.io();
    if (comm != null)
        comm.removeMessageListener(TOPIC_CHECKPOINT, lsnr);
    stopSpi();
    if (log.isDebugEnabled())
        log.debug(stopInfo());
}
Also used : GridIoManager(org.apache.ignite.internal.managers.communication.GridIoManager)

Example 9 with GridIoManager

use of org.apache.ignite.internal.managers.communication.GridIoManager in project ignite by apache.

the class IgniteKernal method start.

/**
     * @param cfg Configuration to use.
     * @param utilityCachePool Utility cache pool.
     * @param execSvc Executor service.
     * @param sysExecSvc System executor service.
     * @param stripedExecSvc Striped executor.
     * @param p2pExecSvc P2P executor service.
     * @param mgmtExecSvc Management executor service.
     * @param igfsExecSvc IGFS executor service.
     * @param dataStreamExecSvc data stream executor service.
     * @param restExecSvc Reset executor service.
     * @param affExecSvc Affinity executor service.
     * @param idxExecSvc Indexing executor service.
     * @param callbackExecSvc Callback executor service.
     * @param qryExecSvc Query executor service.
     * @param schemaExecSvc Schema executor service.
     * @param customExecSvcs Custom named executors.
     * @param errHnd Error handler to use for notification about startup problems.
     * @throws IgniteCheckedException Thrown in case of any errors.
     */
@SuppressWarnings({ "CatchGenericClass", "unchecked" })
public void start(final IgniteConfiguration cfg, ExecutorService utilityCachePool, final ExecutorService execSvc, final ExecutorService svcExecSvc, final ExecutorService sysExecSvc, final StripedExecutor stripedExecSvc, ExecutorService p2pExecSvc, ExecutorService mgmtExecSvc, ExecutorService igfsExecSvc, ExecutorService dataStreamExecSvc, ExecutorService restExecSvc, ExecutorService affExecSvc, @Nullable ExecutorService idxExecSvc, IgniteStripedThreadPoolExecutor callbackExecSvc, ExecutorService qryExecSvc, ExecutorService schemaExecSvc, Map<String, ? extends ExecutorService> customExecSvcs, GridAbsClosure errHnd) throws IgniteCheckedException {
    gw.compareAndSet(null, new GridKernalGatewayImpl(cfg.getIgniteInstanceName()));
    GridKernalGateway gw = this.gw.get();
    gw.writeLock();
    try {
        switch(gw.getState()) {
            case STARTED:
                {
                    U.warn(log, "Grid has already been started (ignored).");
                    return;
                }
            case STARTING:
                {
                    U.warn(log, "Grid is already in process of being started (ignored).");
                    return;
                }
            case STOPPING:
                {
                    throw new IgniteCheckedException("Grid is in process of being stopped");
                }
            case STOPPED:
                {
                    break;
                }
        }
        gw.setState(STARTING);
    } finally {
        gw.writeUnlock();
    }
    assert cfg != null;
    // Make sure we got proper configuration.
    validateCommon(cfg);
    igniteInstanceName = cfg.getIgniteInstanceName();
    this.cfg = cfg;
    log = (GridLoggerProxy) cfg.getGridLogger().getLogger(getClass().getName() + (igniteInstanceName != null ? '%' + igniteInstanceName : ""));
    RuntimeMXBean rtBean = ManagementFactory.getRuntimeMXBean();
    // Ack various information.
    ackAsciiLogo();
    ackConfigUrl();
    ackDaemon();
    ackOsInfo();
    ackLanguageRuntime();
    ackRemoteManagement();
    ackVmArguments(rtBean);
    ackClassPaths(rtBean);
    ackSystemProperties();
    ackEnvironmentVariables();
    ackMemoryConfiguration();
    ackCacheConfiguration();
    ackP2pConfiguration();
    ackRebalanceConfiguration();
    // Run background network diagnostics.
    GridDiagnostic.runBackgroundCheck(igniteInstanceName, execSvc, log);
    // Ack 3-rd party licenses location.
    if (log.isInfoEnabled() && cfg.getIgniteHome() != null)
        log.info("3-rd party licenses can be found at: " + cfg.getIgniteHome() + File.separatorChar + "libs" + File.separatorChar + "licenses");
    // with internally reserved names.
    for (String name : cfg.getUserAttributes().keySet()) if (name.startsWith(ATTR_PREFIX))
        throw new IgniteCheckedException("User attribute has illegal name: '" + name + "'. Note that all names " + "starting with '" + ATTR_PREFIX + "' are reserved for internal use.");
    // Ack local node user attributes.
    logNodeUserAttributes();
    // Ack configuration.
    ackSpis();
    List<PluginProvider> plugins = U.allPluginProviders();
    final boolean activeOnStart = cfg.isActiveOnStart();
    // Spin out SPIs & managers.
    try {
        ctx = new GridKernalContextImpl(log, this, cfg, gw, utilityCachePool, execSvc, svcExecSvc, sysExecSvc, stripedExecSvc, p2pExecSvc, mgmtExecSvc, igfsExecSvc, dataStreamExecSvc, restExecSvc, affExecSvc, idxExecSvc, callbackExecSvc, qryExecSvc, schemaExecSvc, customExecSvcs, plugins);
        cfg.getMarshaller().setContext(ctx.marshallerContext());
        ClusterProcessor clusterProc = new ClusterProcessor(ctx);
        startProcessor(clusterProc);
        U.onGridStart();
        // Start and configure resource processor first as it contains resources used
        // by all other managers and processors.
        GridResourceProcessor rsrcProc = new GridResourceProcessor(ctx);
        rsrcProc.setSpringContext(rsrcCtx);
        scheduler = new IgniteSchedulerImpl(ctx);
        startProcessor(rsrcProc);
        // Inject resources into lifecycle beans.
        if (!cfg.isDaemon() && cfg.getLifecycleBeans() != null) {
            for (LifecycleBean bean : cfg.getLifecycleBeans()) {
                if (bean != null)
                    rsrcProc.inject(bean);
            }
        }
        // Lifecycle notification.
        notifyLifecycleBeans(BEFORE_NODE_START);
        // Starts lifecycle aware components.
        U.startLifecycleAware(lifecycleAwares(cfg));
        addHelper(IGFS_HELPER.create(F.isEmpty(cfg.getFileSystemConfiguration())));
        addHelper(HADOOP_HELPER.createIfInClassPath(ctx, false));
        startProcessor(new IgnitePluginProcessor(ctx, cfg, plugins));
        startProcessor(new PoolProcessor(ctx));
        // Closure processor should be started before all others
        // (except for resource processor), as many components can depend on it.
        startProcessor(new GridClosureProcessor(ctx));
        // Start some other processors (order & place is important).
        startProcessor(new GridPortProcessor(ctx));
        startProcessor(new GridJobMetricsProcessor(ctx));
        // Timeout processor needs to be started before managers,
        // as managers may depend on it.
        startProcessor(new GridTimeoutProcessor(ctx));
        // Start security processors.
        startProcessor(createComponent(GridSecurityProcessor.class, ctx));
        // Start SPI managers.
        // NOTE: that order matters as there are dependencies between managers.
        startManager(new GridIoManager(ctx));
        startManager(new GridCheckpointManager(ctx));
        startManager(new GridEventStorageManager(ctx));
        startManager(new GridDeploymentManager(ctx));
        startManager(new GridLoadBalancerManager(ctx));
        startManager(new GridFailoverManager(ctx));
        startManager(new GridCollisionManager(ctx));
        startManager(new GridIndexingManager(ctx));
        ackSecurity();
        // Assign discovery manager to context before other processors start so they
        // are able to register custom event listener.
        GridManager discoMgr = new GridDiscoveryManager(ctx);
        ctx.add(discoMgr, false);
        // be able to start receiving messages once discovery completes.
        try {
            startProcessor(createComponent(DiscoveryNodeValidationProcessor.class, ctx));
            startProcessor(new GridAffinityProcessor(ctx));
            startProcessor(createComponent(GridSegmentationProcessor.class, ctx));
            startProcessor(createComponent(IgniteCacheObjectProcessor.class, ctx));
            startProcessor(new GridCacheProcessor(ctx));
            startProcessor(new GridClusterStateProcessor(ctx));
            startProcessor(new GridQueryProcessor(ctx));
            startProcessor(new SqlListenerProcessor(ctx));
            startProcessor(new GridServiceProcessor(ctx));
            startProcessor(new GridTaskSessionProcessor(ctx));
            startProcessor(new GridJobProcessor(ctx));
            startProcessor(new GridTaskProcessor(ctx));
            startProcessor((GridProcessor) SCHEDULE.createOptional(ctx));
            startProcessor(new GridRestProcessor(ctx));
            startProcessor(new DataStreamProcessor(ctx));
            startProcessor((GridProcessor) IGFS.create(ctx, F.isEmpty(cfg.getFileSystemConfiguration())));
            startProcessor(new GridContinuousProcessor(ctx));
            startProcessor(createHadoopComponent());
            startProcessor(new DataStructuresProcessor(ctx));
            startProcessor(createComponent(PlatformProcessor.class, ctx));
            startProcessor(new GridMarshallerMappingProcessor(ctx));
            // Start plugins.
            for (PluginProvider provider : ctx.plugins().allProviders()) {
                ctx.add(new GridPluginComponent(provider));
                provider.start(ctx.plugins().pluginContextForProvider(provider));
            }
            // Start platform plugins.
            if (ctx.config().getPlatformConfiguration() != null)
                startProcessor(new PlatformPluginProcessor(ctx));
            fillNodeAttributes(clusterProc.updateNotifierEnabled());
        } catch (Throwable e) {
            U.error(log, "Exception during start processors, node will be stopped and close connections", e);
            // Stop discovery spi to close tcp socket.
            ctx.discovery().stop(true);
            throw e;
        }
        gw.writeLock();
        try {
            gw.setState(STARTED);
            // Start discovery manager last to make sure that grid is fully initialized.
            startManager(discoMgr);
        } finally {
            gw.writeUnlock();
        }
        // Check whether physical RAM is not exceeded.
        checkPhysicalRam();
        // Suggest configuration optimizations.
        suggestOptimizations(cfg);
        // Suggest JVM optimizations.
        ctx.performance().addAll(JvmConfigurationSuggestions.getSuggestions());
        // Suggest Operation System optimizations.
        ctx.performance().addAll(OsConfigurationSuggestions.getSuggestions());
        // Notify discovery manager the first to make sure that topology is discovered.
        ctx.discovery().onKernalStart(activeOnStart);
        // Notify IO manager the second so further components can send and receive messages.
        ctx.io().onKernalStart(activeOnStart);
        // Start plugins.
        for (PluginProvider provider : ctx.plugins().allProviders()) provider.onIgniteStart();
        boolean recon = false;
        // Callbacks.
        for (GridComponent comp : ctx) {
            // Skip discovery manager.
            if (comp instanceof GridDiscoveryManager)
                continue;
            // Skip IO manager.
            if (comp instanceof GridIoManager)
                continue;
            if (comp instanceof GridPluginComponent)
                continue;
            if (!skipDaemon(comp)) {
                try {
                    comp.onKernalStart(activeOnStart);
                } catch (IgniteNeedReconnectException e) {
                    assert ctx.discovery().reconnectSupported();
                    if (log.isDebugEnabled())
                        log.debug("Failed to start node components on node start, will wait for reconnect: " + e);
                    recon = true;
                }
            }
        }
        if (recon)
            reconnectState.waitFirstReconnect();
        // Register MBeans.
        registerKernalMBean();
        registerLocalNodeMBean();
        registerExecutorMBeans(execSvc, sysExecSvc, p2pExecSvc, mgmtExecSvc, restExecSvc, qryExecSvc, schemaExecSvc);
        registerStripedExecutorMBean(stripedExecSvc);
        // Lifecycle bean notifications.
        notifyLifecycleBeans(AFTER_NODE_START);
    } catch (Throwable e) {
        IgniteSpiVersionCheckException verCheckErr = X.cause(e, IgniteSpiVersionCheckException.class);
        if (verCheckErr != null)
            U.error(log, verCheckErr.getMessage());
        else if (X.hasCause(e, InterruptedException.class, IgniteInterruptedCheckedException.class))
            U.warn(log, "Grid startup routine has been interrupted (will rollback).");
        else
            U.error(log, "Got exception while starting (will rollback startup routine).", e);
        errHnd.apply();
        stop(true);
        if (e instanceof Error)
            throw e;
        else if (e instanceof IgniteCheckedException)
            throw (IgniteCheckedException) e;
        else
            throw new IgniteCheckedException(e);
    }
    // Mark start timestamp.
    startTime = U.currentTimeMillis();
    String intervalStr = IgniteSystemProperties.getString(IGNITE_STARVATION_CHECK_INTERVAL);
    // Start starvation checker if enabled.
    boolean starveCheck = !isDaemon() && !"0".equals(intervalStr);
    if (starveCheck) {
        final long interval = F.isEmpty(intervalStr) ? PERIODIC_STARVATION_CHECK_FREQ : Long.parseLong(intervalStr);
        starveTask = ctx.timeout().schedule(new Runnable() {

            /** Last completed task count. */
            private long lastCompletedCntPub;

            /** Last completed task count. */
            private long lastCompletedCntSys;

            @Override
            public void run() {
                if (execSvc instanceof ThreadPoolExecutor) {
                    ThreadPoolExecutor exec = (ThreadPoolExecutor) execSvc;
                    lastCompletedCntPub = checkPoolStarvation(exec, lastCompletedCntPub, "public");
                }
                if (sysExecSvc instanceof ThreadPoolExecutor) {
                    ThreadPoolExecutor exec = (ThreadPoolExecutor) sysExecSvc;
                    lastCompletedCntSys = checkPoolStarvation(exec, lastCompletedCntSys, "system");
                }
                if (stripedExecSvc != null)
                    stripedExecSvc.checkStarvation();
            }

            /**
                 * @param exec Thread pool executor to check.
                 * @param lastCompletedCnt Last completed tasks count.
                 * @param pool Pool name for message.
                 * @return Current completed tasks count.
                 */
            private long checkPoolStarvation(ThreadPoolExecutor exec, long lastCompletedCnt, String pool) {
                long completedCnt = exec.getCompletedTaskCount();
                // at least one waiting request, then it is possible starvation.
                if (exec.getPoolSize() == exec.getActiveCount() && completedCnt == lastCompletedCnt && !exec.getQueue().isEmpty())
                    LT.warn(log, "Possible thread pool starvation detected (no task completed in last " + interval + "ms, is " + pool + " thread pool size large enough?)");
                return completedCnt;
            }
        }, interval, interval);
    }
    long metricsLogFreq = cfg.getMetricsLogFrequency();
    if (metricsLogFreq > 0) {
        metricsLogTask = ctx.timeout().schedule(new Runnable() {

            private final DecimalFormat dblFmt = new DecimalFormat("#.##");

            @Override
            public void run() {
                if (log.isInfoEnabled()) {
                    try {
                        ClusterMetrics m = cluster().localNode().metrics();
                        double cpuLoadPct = m.getCurrentCpuLoad() * 100;
                        double avgCpuLoadPct = m.getAverageCpuLoad() * 100;
                        double gcPct = m.getCurrentGcCpuLoad() * 100;
                        //Heap params
                        long heapUsed = m.getHeapMemoryUsed();
                        long heapMax = m.getHeapMemoryMaximum();
                        long heapUsedInMBytes = heapUsed / 1024 / 1024;
                        long heapCommInMBytes = m.getHeapMemoryCommitted() / 1024 / 1024;
                        double freeHeapPct = heapMax > 0 ? ((double) ((heapMax - heapUsed) * 100)) / heapMax : -1;
                        //Non heap params
                        long nonHeapUsed = m.getNonHeapMemoryUsed();
                        long nonHeapMax = m.getNonHeapMemoryMaximum();
                        long nonHeapUsedInMBytes = nonHeapUsed / 1024 / 1024;
                        long nonHeapCommInMBytes = m.getNonHeapMemoryCommitted() / 1024 / 1024;
                        double freeNonHeapPct = nonHeapMax > 0 ? ((double) ((nonHeapMax - nonHeapUsed) * 100)) / nonHeapMax : -1;
                        int hosts = 0;
                        int nodes = 0;
                        int cpus = 0;
                        try {
                            ClusterMetrics metrics = cluster().metrics();
                            Collection<ClusterNode> nodes0 = cluster().nodes();
                            hosts = U.neighborhood(nodes0).size();
                            nodes = metrics.getTotalNodes();
                            cpus = metrics.getTotalCpus();
                        } catch (IgniteException ignore) {
                        // No-op.
                        }
                        int pubPoolActiveThreads = 0;
                        int pubPoolIdleThreads = 0;
                        int pubPoolQSize = 0;
                        if (execSvc instanceof ThreadPoolExecutor) {
                            ThreadPoolExecutor exec = (ThreadPoolExecutor) execSvc;
                            int poolSize = exec.getPoolSize();
                            pubPoolActiveThreads = Math.min(poolSize, exec.getActiveCount());
                            pubPoolIdleThreads = poolSize - pubPoolActiveThreads;
                            pubPoolQSize = exec.getQueue().size();
                        }
                        int sysPoolActiveThreads = 0;
                        int sysPoolIdleThreads = 0;
                        int sysPoolQSize = 0;
                        if (sysExecSvc instanceof ThreadPoolExecutor) {
                            ThreadPoolExecutor exec = (ThreadPoolExecutor) sysExecSvc;
                            int poolSize = exec.getPoolSize();
                            sysPoolActiveThreads = Math.min(poolSize, exec.getActiveCount());
                            sysPoolIdleThreads = poolSize - sysPoolActiveThreads;
                            sysPoolQSize = exec.getQueue().size();
                        }
                        int loadedPages = 0;
                        Collection<MemoryPolicy> policies = ctx.cache().context().database().memoryPolicies();
                        if (!F.isEmpty(policies)) {
                            for (MemoryPolicy memPlc : policies) loadedPages += memPlc.pageMemory().loadedPages();
                        }
                        String id = U.id8(localNode().id());
                        String msg = NL + "Metrics for local node (to disable set 'metricsLogFrequency' to 0)" + NL + "    ^-- Node [id=" + id + ", name=" + name() + ", uptime=" + getUpTimeFormatted() + "]" + NL + "    ^-- H/N/C [hosts=" + hosts + ", nodes=" + nodes + ", CPUs=" + cpus + "]" + NL + "    ^-- CPU [cur=" + dblFmt.format(cpuLoadPct) + "%, avg=" + dblFmt.format(avgCpuLoadPct) + "%, GC=" + dblFmt.format(gcPct) + "%]" + NL + "    ^-- PageMemory [pages=" + loadedPages + "]" + NL + "    ^-- Heap [used=" + dblFmt.format(heapUsedInMBytes) + "MB, free=" + dblFmt.format(freeHeapPct) + "%, comm=" + dblFmt.format(heapCommInMBytes) + "MB]" + NL + "    ^-- Non heap [used=" + dblFmt.format(nonHeapUsedInMBytes) + "MB, free=" + dblFmt.format(freeNonHeapPct) + "%, comm=" + dblFmt.format(nonHeapCommInMBytes) + "MB]" + NL + "    ^-- Public thread pool [active=" + pubPoolActiveThreads + ", idle=" + pubPoolIdleThreads + ", qSize=" + pubPoolQSize + "]" + NL + "    ^-- System thread pool [active=" + sysPoolActiveThreads + ", idle=" + sysPoolIdleThreads + ", qSize=" + sysPoolQSize + "]" + NL + "    ^-- Outbound messages queue [size=" + m.getOutboundMessagesQueueSize() + "]";
                        log.info(msg);
                        ctx.cache().context().database().dumpStatistics(log);
                    } catch (IgniteClientDisconnectedException ignore) {
                    // No-op.
                    }
                }
            }
        }, metricsLogFreq, metricsLogFreq);
    }
    final long longOpDumpTimeout = IgniteSystemProperties.getLong(IgniteSystemProperties.IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT, 60_000);
    if (longOpDumpTimeout > 0) {
        longOpDumpTask = ctx.timeout().schedule(new Runnable() {

            @Override
            public void run() {
                GridKernalContext ctx = IgniteKernal.this.ctx;
                if (ctx != null)
                    ctx.cache().context().exchange().dumpLongRunningOperations(longOpDumpTimeout);
            }
        }, longOpDumpTimeout, longOpDumpTimeout);
    }
    ctx.performance().add("Disable assertions (remove '-ea' from JVM options)", !U.assertionsEnabled());
    ctx.performance().logSuggestions(log, igniteInstanceName);
    U.quietAndInfo(log, "To start Console Management & Monitoring run ignitevisorcmd.{sh|bat}");
    ackStart(rtBean);
    if (!isDaemon())
        ctx.discovery().ackTopology(localNode().order());
}
Also used : SqlListenerProcessor(org.apache.ignite.internal.processors.odbc.SqlListenerProcessor) DataStructuresProcessor(org.apache.ignite.internal.processors.datastructures.DataStructuresProcessor) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) GridServiceProcessor(org.apache.ignite.internal.processors.service.GridServiceProcessor) IgniteException(org.apache.ignite.IgniteException) GridSecurityProcessor(org.apache.ignite.internal.processors.security.GridSecurityProcessor) GridCheckpointManager(org.apache.ignite.internal.managers.checkpoint.GridCheckpointManager) ClusterNode(org.apache.ignite.cluster.ClusterNode) GridIndexingManager(org.apache.ignite.internal.managers.indexing.GridIndexingManager) GridMarshallerMappingProcessor(org.apache.ignite.internal.processors.marshaller.GridMarshallerMappingProcessor) IgniteClientDisconnectedException(org.apache.ignite.IgniteClientDisconnectedException) GridTaskSessionProcessor(org.apache.ignite.internal.processors.session.GridTaskSessionProcessor) PlatformPluginProcessor(org.apache.ignite.internal.processors.platform.plugin.PlatformPluginProcessor) GridClusterStateProcessor(org.apache.ignite.internal.processors.cluster.GridClusterStateProcessor) PluginProvider(org.apache.ignite.plugin.PluginProvider) GridCacheProcessor(org.apache.ignite.internal.processors.cache.GridCacheProcessor) GridRestProcessor(org.apache.ignite.internal.processors.rest.GridRestProcessor) GridPortProcessor(org.apache.ignite.internal.processors.port.GridPortProcessor) GridDiscoveryManager(org.apache.ignite.internal.managers.discovery.GridDiscoveryManager) GridAffinityProcessor(org.apache.ignite.internal.processors.affinity.GridAffinityProcessor) MemoryPolicy(org.apache.ignite.internal.processors.cache.database.MemoryPolicy) GridJobMetricsProcessor(org.apache.ignite.internal.processors.jobmetrics.GridJobMetricsProcessor) GridQueryProcessor(org.apache.ignite.internal.processors.query.GridQueryProcessor) IgniteSpiVersionCheckException(org.apache.ignite.spi.IgniteSpiVersionCheckException) GridLoadBalancerManager(org.apache.ignite.internal.managers.loadbalancer.GridLoadBalancerManager) DataStreamProcessor(org.apache.ignite.internal.processors.datastreamer.DataStreamProcessor) GridEventStorageManager(org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager) IgnitePluginProcessor(org.apache.ignite.internal.processors.plugin.IgnitePluginProcessor) GridTimeoutProcessor(org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor) DecimalFormat(java.text.DecimalFormat) GridDeploymentManager(org.apache.ignite.internal.managers.deployment.GridDeploymentManager) GridManager(org.apache.ignite.internal.managers.GridManager) ClusterProcessor(org.apache.ignite.internal.processors.cluster.ClusterProcessor) OsDiscoveryNodeValidationProcessor(org.apache.ignite.internal.processors.nodevalidation.OsDiscoveryNodeValidationProcessor) DiscoveryNodeValidationProcessor(org.apache.ignite.internal.processors.nodevalidation.DiscoveryNodeValidationProcessor) LifecycleBean(org.apache.ignite.lifecycle.LifecycleBean) GridSegmentationProcessor(org.apache.ignite.internal.processors.segmentation.GridSegmentationProcessor) GridCollisionManager(org.apache.ignite.internal.managers.collision.GridCollisionManager) IgniteCacheObjectProcessor(org.apache.ignite.internal.processors.cacheobject.IgniteCacheObjectProcessor) GridTaskProcessor(org.apache.ignite.internal.processors.task.GridTaskProcessor) GridContinuousProcessor(org.apache.ignite.internal.processors.continuous.GridContinuousProcessor) RuntimeMXBean(java.lang.management.RuntimeMXBean) GridClosureProcessor(org.apache.ignite.internal.processors.closure.GridClosureProcessor) GridFailoverManager(org.apache.ignite.internal.managers.failover.GridFailoverManager) PlatformProcessor(org.apache.ignite.internal.processors.platform.PlatformProcessor) ClusterMetrics(org.apache.ignite.cluster.ClusterMetrics) GridIoManager(org.apache.ignite.internal.managers.communication.GridIoManager) GridResourceProcessor(org.apache.ignite.internal.processors.resource.GridResourceProcessor) PoolProcessor(org.apache.ignite.internal.processors.pool.PoolProcessor) GridJobProcessor(org.apache.ignite.internal.processors.job.GridJobProcessor) IgniteStripedThreadPoolExecutor(org.apache.ignite.thread.IgniteStripedThreadPoolExecutor) ThreadPoolExecutor(java.util.concurrent.ThreadPoolExecutor)

Example 10 with GridIoManager

use of org.apache.ignite.internal.managers.communication.GridIoManager in project ignite by apache.

the class GridIoManagerBenchmark0 method testThroughput.

/**
     * @throws Exception If failed.
     */
@SuppressWarnings("deprecation")
public void testThroughput() throws Exception {
    final IgniteKernal sndKernal = (IgniteKernal) grid(0);
    final IgniteKernal rcvKernal = (IgniteKernal) grid(1);
    final ClusterNode sndNode = sndKernal.localNode();
    final ClusterNode rcvNode = rcvKernal.localNode();
    final GridIoManager snd = sndKernal.context().io();
    final GridIoManager rcv = rcvKernal.context().io();
    info("Senders: " + THREADS);
    info("Messages: " + CONCUR_MSGS);
    final Semaphore sem = new Semaphore(CONCUR_MSGS);
    final LongAdder8 msgCntr = new LongAdder8();
    final String topic = "test-topic";
    rcv.addMessageListener(topic, new GridMessageListener() {

        @Override
        public void onMessage(UUID nodeId, Object msg) {
            try {
                rcv.sendToCustomTopic(sndNode, topic, (Message) msg, PUBLIC_POOL);
            } catch (IgniteCheckedException e) {
                error("Failed to send message.", e);
            }
        }
    });
    snd.addMessageListener(topic, new GridMessageListener() {

        @Override
        public void onMessage(UUID nodeId, Object msg) {
            msgCntr.increment();
            sem.release();
        }
    });
    Timer t = new Timer("results-reporter");
    t.schedule(new TimerTask() {

        private long ts = System.currentTimeMillis();

        @Override
        public void run() {
            long newTs = System.currentTimeMillis();
            long qrys = msgCntr.sumThenReset();
            long time = newTs - ts;
            X.println("Communication benchmark [qps=" + qrys * 1000 / time + ", executed=" + qrys + ", time=" + time + ']');
            ts = newTs;
        }
    }, 10000, 10000);
    final AtomicBoolean finish = new AtomicBoolean();
    IgniteInternalFuture<?> f = GridTestUtils.runMultiThreadedAsync(new Callable<Object>() {

        @Override
        public Object call() throws Exception {
            try {
                IgniteUuid msgId = IgniteUuid.randomUuid();
                while (!finish.get()) {
                    sem.acquire();
                    snd.sendToCustomTopic(rcvNode, topic, new GridTestMessage(msgId, (String) null), PUBLIC_POOL);
                }
            } catch (IgniteCheckedException e) {
                X.println("Message send failed", e);
            } catch (InterruptedException ignored) {
            // No-op.
            }
            return null;
        }
    }, THREADS, "send-thread");
    Thread.sleep(TEST_TIMEOUT);
    finish.set(true);
    sem.release(CONCUR_MSGS * 2);
    t.cancel();
    f.get();
}
Also used : ClusterNode(org.apache.ignite.cluster.ClusterNode) IgniteKernal(org.apache.ignite.internal.IgniteKernal) Message(org.apache.ignite.plugin.extensions.communication.Message) GridMessageListener(org.apache.ignite.internal.managers.communication.GridMessageListener) Semaphore(java.util.concurrent.Semaphore) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) Timer(java.util.Timer) TimerTask(java.util.TimerTask) GridIoManager(org.apache.ignite.internal.managers.communication.GridIoManager) IgniteUuid(org.apache.ignite.lang.IgniteUuid) UUID(java.util.UUID) LongAdder8(org.jsr166.LongAdder8)

Aggregations

GridIoManager (org.apache.ignite.internal.managers.communication.GridIoManager)16 IgniteCheckedException (org.apache.ignite.IgniteCheckedException)8 ClusterNode (org.apache.ignite.cluster.ClusterNode)8 UUID (java.util.UUID)7 GridMessageListener (org.apache.ignite.internal.managers.communication.GridMessageListener)6 CountDownLatch (java.util.concurrent.CountDownLatch)4 DiscoveryEvent (org.apache.ignite.events.DiscoveryEvent)4 Event (org.apache.ignite.events.Event)4 AtomicBoolean (java.util.concurrent.atomic.AtomicBoolean)3 IgniteKernal (org.apache.ignite.internal.IgniteKernal)3 IgniteUuid (org.apache.ignite.lang.IgniteUuid)3 Message (org.apache.ignite.plugin.extensions.communication.Message)3 TcpCommunicationSpi (org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi)3 LongAdder8 (org.jsr166.LongAdder8)3 Collection (java.util.Collection)2 HashSet (java.util.HashSet)2 Timer (java.util.Timer)2 TimerTask (java.util.TimerTask)2 Semaphore (java.util.concurrent.Semaphore)2 AtomicReference (java.util.concurrent.atomic.AtomicReference)2