Search in sources :

Example 1 with ExecutionService

use of com.hazelcast.spi.ExecutionService in project hazelcast by hazelcast.

the class TimedMemberStateFactoryHelper method registerJMXBeans.

static void registerJMXBeans(HazelcastInstanceImpl instance, MemberStateImpl memberState) {
    final EventService es = instance.node.nodeEngine.getEventService();
    final InternalOperationService os = instance.node.nodeEngine.getOperationService();
    final ConnectionManager cm = instance.node.connectionManager;
    final InternalPartitionService ps = instance.node.partitionService;
    final ProxyService proxyService = instance.node.nodeEngine.getProxyService();
    final ExecutionService executionService = instance.node.nodeEngine.getExecutionService();
    final MXBeansDTO beans = new MXBeansDTO();
    final EventServiceDTO esBean = new EventServiceDTO(es);
    beans.setEventServiceBean(esBean);
    final OperationServiceDTO osBean = new OperationServiceDTO(os);
    beans.setOperationServiceBean(osBean);
    final ConnectionManagerDTO cmBean = new ConnectionManagerDTO(cm);
    beans.setConnectionManagerBean(cmBean);
    final PartitionServiceBeanDTO psBean = new PartitionServiceBeanDTO(ps, instance);
    beans.setPartitionServiceBean(psBean);
    final ProxyServiceDTO proxyServiceBean = new ProxyServiceDTO(proxyService);
    beans.setProxyServiceBean(proxyServiceBean);
    final ManagedExecutorService systemExecutor = executionService.getExecutor(ExecutionService.SYSTEM_EXECUTOR);
    final ManagedExecutorService asyncExecutor = executionService.getExecutor(ExecutionService.ASYNC_EXECUTOR);
    final ManagedExecutorService scheduledExecutor = executionService.getExecutor(ExecutionService.SCHEDULED_EXECUTOR);
    final ManagedExecutorService clientExecutor = executionService.getExecutor(ExecutionService.CLIENT_EXECUTOR);
    final ManagedExecutorService queryExecutor = executionService.getExecutor(ExecutionService.QUERY_EXECUTOR);
    final ManagedExecutorService ioExecutor = executionService.getExecutor(ExecutionService.IO_EXECUTOR);
    final ManagedExecutorDTO systemExecutorDTO = new ManagedExecutorDTO(systemExecutor);
    final ManagedExecutorDTO asyncExecutorDTO = new ManagedExecutorDTO(asyncExecutor);
    final ManagedExecutorDTO scheduledExecutorDTO = new ManagedExecutorDTO(scheduledExecutor);
    final ManagedExecutorDTO clientExecutorDTO = new ManagedExecutorDTO(clientExecutor);
    final ManagedExecutorDTO queryExecutorDTO = new ManagedExecutorDTO(queryExecutor);
    final ManagedExecutorDTO ioExecutorDTO = new ManagedExecutorDTO(ioExecutor);
    beans.putManagedExecutor(ExecutionService.SYSTEM_EXECUTOR, systemExecutorDTO);
    beans.putManagedExecutor(ExecutionService.ASYNC_EXECUTOR, asyncExecutorDTO);
    beans.putManagedExecutor(ExecutionService.SCHEDULED_EXECUTOR, scheduledExecutorDTO);
    beans.putManagedExecutor(ExecutionService.CLIENT_EXECUTOR, clientExecutorDTO);
    beans.putManagedExecutor(ExecutionService.QUERY_EXECUTOR, queryExecutorDTO);
    beans.putManagedExecutor(ExecutionService.IO_EXECUTOR, ioExecutorDTO);
    memberState.setBeans(beans);
}
Also used : InternalPartitionService(com.hazelcast.internal.partition.InternalPartitionService) EventService(com.hazelcast.spi.EventService) InternalOperationService(com.hazelcast.spi.impl.operationservice.InternalOperationService) ExecutionService(com.hazelcast.spi.ExecutionService) EventServiceDTO(com.hazelcast.internal.management.dto.EventServiceDTO) MXBeansDTO(com.hazelcast.internal.management.dto.MXBeansDTO) ManagedExecutorDTO(com.hazelcast.internal.management.dto.ManagedExecutorDTO) ConnectionManagerDTO(com.hazelcast.internal.management.dto.ConnectionManagerDTO) ManagedExecutorService(com.hazelcast.util.executor.ManagedExecutorService) ConnectionManager(com.hazelcast.nio.ConnectionManager) ProxyService(com.hazelcast.spi.ProxyService) PartitionServiceBeanDTO(com.hazelcast.internal.management.dto.PartitionServiceBeanDTO) OperationServiceDTO(com.hazelcast.internal.management.dto.OperationServiceDTO) ProxyServiceDTO(com.hazelcast.internal.management.dto.ProxyServiceDTO)

Example 2 with ExecutionService

use of com.hazelcast.spi.ExecutionService in project hazelcast by hazelcast.

the class BatchInvalidator method startBackgroundBatchProcessor.

private void startBackgroundBatchProcessor() {
    ExecutionService executionService = nodeEngine.getExecutionService();
    executionService.scheduleWithRepetition(invalidationExecutorName, new BatchInvalidationEventSender(), batchFrequencySeconds, batchFrequencySeconds, SECONDS);
}
Also used : ExecutionService(com.hazelcast.spi.ExecutionService)

Example 3 with ExecutionService

use of com.hazelcast.spi.ExecutionService in project hazelcast by hazelcast.

the class JobSupervisor method checkFullyProcessed.

public void checkFullyProcessed(JobProcessInformation processInformation) {
    if (isOwnerNode()) {
        JobPartitionState[] partitionStates = processInformation.getPartitionStates();
        for (JobPartitionState partitionState : partitionStates) {
            if (partitionState == null || partitionState.getState() != JobPartitionState.State.PROCESSED) {
                return;
            }
        }
        final String name = configuration.getName();
        final String jobId = configuration.getJobId();
        final NodeEngine nodeEngine = configuration.getNodeEngine();
        final GetResultOperationFactory operationFactory = new GetResultOperationFactory(name, jobId);
        // Get the initial future object to eventually set the result and cleanup
        final TrackableJobFuture future = jobTracker.unregisterTrackableJob(jobId);
        if (future == null) {
            // If already handled just return
            return;
        }
        final JobSupervisor jobSupervisor = this;
        Runnable runnable = new GetResultsRunnable(nodeEngine, operationFactory, jobId, jobSupervisor, future);
        ExecutionService executionService = nodeEngine.getExecutionService();
        ManagedExecutorService executor = executionService.getExecutor(ExecutionService.ASYNC_EXECUTOR);
        executor.submit(runnable);
    }
}
Also used : NodeEngine(com.hazelcast.spi.NodeEngine) ManagedExecutorService(com.hazelcast.util.executor.ManagedExecutorService) JobPartitionState(com.hazelcast.mapreduce.JobPartitionState) GetResultOperationFactory(com.hazelcast.mapreduce.impl.operation.GetResultOperationFactory) ExecutionService(com.hazelcast.spi.ExecutionService)

Example 4 with ExecutionService

use of com.hazelcast.spi.ExecutionService in project hazelcast by hazelcast.

the class BasicCompletableFutureTest method basicCompletableFuture.

private static <V> BasicCompletableFuture<V> basicCompletableFuture(Future<V> future) {
    NodeEngine engine = mock(NodeEngine.class);
    when(engine.getLogger(BasicCompletableFuture.class)).thenReturn(mock(ILogger.class));
    ExecutionService executionService = mock(ExecutionService.class);
    when(engine.getExecutionService()).thenReturn(executionService);
    when(executionService.getExecutor(anyString())).thenReturn(new TestCurrentThreadExecutor());
    return new BasicCompletableFuture<V>(future, engine);
}
Also used : NodeEngine(com.hazelcast.spi.NodeEngine) ILogger(com.hazelcast.logging.ILogger) ExecutionService(com.hazelcast.spi.ExecutionService)

Example 5 with ExecutionService

use of com.hazelcast.spi.ExecutionService in project hazelcast by hazelcast.

the class CachedExecutorServiceDelegateTest method setup.

@Before
public void setup() {
    cachedExecutorService = new NamedThreadPoolExecutor("test", 0, Integer.MAX_VALUE, 60L, TimeUnit.SECONDS, new SynchronousQueue<Runnable>(), Executors.defaultThreadFactory());
    ExecutionService executionService = mock(ExecutionService.class);
    when(executionService.getExecutor(ExecutionService.ASYNC_EXECUTOR)).thenReturn(cachedExecutorService);
    nodeEngine = mock(NodeEngine.class);
    when(nodeEngine.getExecutionService()).thenReturn(executionService);
}
Also used : NodeEngine(com.hazelcast.spi.NodeEngine) SynchronousQueue(java.util.concurrent.SynchronousQueue) ExecutionService(com.hazelcast.spi.ExecutionService) Before(org.junit.Before)

Aggregations

ExecutionService (com.hazelcast.spi.ExecutionService)8 NodeEngine (com.hazelcast.spi.NodeEngine)3 ManagedExecutorService (com.hazelcast.util.executor.ManagedExecutorService)2 Executor (java.util.concurrent.Executor)2 ExecutionCallback (com.hazelcast.core.ExecutionCallback)1 PrefixedDistributedObject (com.hazelcast.core.PrefixedDistributedObject)1 ConnectionManagerDTO (com.hazelcast.internal.management.dto.ConnectionManagerDTO)1 EventServiceDTO (com.hazelcast.internal.management.dto.EventServiceDTO)1 MXBeansDTO (com.hazelcast.internal.management.dto.MXBeansDTO)1 ManagedExecutorDTO (com.hazelcast.internal.management.dto.ManagedExecutorDTO)1 OperationServiceDTO (com.hazelcast.internal.management.dto.OperationServiceDTO)1 PartitionServiceBeanDTO (com.hazelcast.internal.management.dto.PartitionServiceBeanDTO)1 ProxyServiceDTO (com.hazelcast.internal.management.dto.ProxyServiceDTO)1 InternalPartitionService (com.hazelcast.internal.partition.InternalPartitionService)1 ILogger (com.hazelcast.logging.ILogger)1 JobPartitionState (com.hazelcast.mapreduce.JobPartitionState)1 GetResultOperationFactory (com.hazelcast.mapreduce.impl.operation.GetResultOperationFactory)1 ConnectionManager (com.hazelcast.nio.ConnectionManager)1 AbstractDistributedObject (com.hazelcast.spi.AbstractDistributedObject)1 EventService (com.hazelcast.spi.EventService)1