Search in sources :

Example 1 with Pipeline

use of org.apache.camel.processor.Pipeline in project camel by apache.

the class ThreadsDefinition method createProcessor.

@Override
public Processor createProcessor(RouteContext routeContext) throws Exception {
    // the threads name
    String name = getThreadName() != null ? getThreadName() : "Threads";
    // prefer any explicit configured executor service
    boolean shutdownThreadPool = ProcessorDefinitionHelper.willCreateNewThreadPool(routeContext, this, true);
    ExecutorService threadPool = ProcessorDefinitionHelper.getConfiguredExecutorService(routeContext, name, this, false);
    // resolve what rejected policy to use
    ThreadPoolRejectedPolicy policy = resolveRejectedPolicy(routeContext);
    if (policy == null) {
        if (callerRunsWhenRejected == null || callerRunsWhenRejected) {
            // should use caller runs by default if not configured
            policy = ThreadPoolRejectedPolicy.CallerRuns;
        } else {
            policy = ThreadPoolRejectedPolicy.Abort;
        }
    }
    log.debug("Using ThreadPoolRejectedPolicy: {}", policy);
    // if no explicit then create from the options
    if (threadPool == null) {
        ExecutorServiceManager manager = routeContext.getCamelContext().getExecutorServiceManager();
        // create the thread pool using a builder
        ThreadPoolProfile profile = new ThreadPoolProfileBuilder(name).poolSize(getPoolSize()).maxPoolSize(getMaxPoolSize()).keepAliveTime(getKeepAliveTime(), getTimeUnit()).maxQueueSize(getMaxQueueSize()).rejectedPolicy(policy).allowCoreThreadTimeOut(getAllowCoreThreadTimeOut()).build();
        threadPool = manager.newThreadPool(this, name, profile);
        shutdownThreadPool = true;
    } else {
        if (getThreadName() != null && !getThreadName().equals("Threads")) {
            throw new IllegalArgumentException("ThreadName and executorServiceRef options cannot be used together.");
        }
        if (getPoolSize() != null) {
            throw new IllegalArgumentException("PoolSize and executorServiceRef options cannot be used together.");
        }
        if (getMaxPoolSize() != null) {
            throw new IllegalArgumentException("MaxPoolSize and executorServiceRef options cannot be used together.");
        }
        if (getKeepAliveTime() != null) {
            throw new IllegalArgumentException("KeepAliveTime and executorServiceRef options cannot be used together.");
        }
        if (getTimeUnit() != null) {
            throw new IllegalArgumentException("TimeUnit and executorServiceRef options cannot be used together.");
        }
        if (getMaxQueueSize() != null) {
            throw new IllegalArgumentException("MaxQueueSize and executorServiceRef options cannot be used together.");
        }
        if (getRejectedPolicy() != null) {
            throw new IllegalArgumentException("RejectedPolicy and executorServiceRef options cannot be used together.");
        }
        if (getAllowCoreThreadTimeOut() != null) {
            throw new IllegalArgumentException("AllowCoreThreadTimeOut and executorServiceRef options cannot be used together.");
        }
    }
    ThreadsProcessor thread = new ThreadsProcessor(routeContext.getCamelContext(), threadPool, shutdownThreadPool, policy);
    List<Processor> pipe = new ArrayList<Processor>(2);
    pipe.add(thread);
    pipe.add(createChildProcessor(routeContext, true));
    // (recipient list definition does this as well)
    return new Pipeline(routeContext.getCamelContext(), pipe) {

        @Override
        public String toString() {
            return "Threads[" + getOutputs() + "]";
        }
    };
}
Also used : ThreadPoolProfile(org.apache.camel.spi.ThreadPoolProfile) ThreadsProcessor(org.apache.camel.processor.ThreadsProcessor) ThreadsProcessor(org.apache.camel.processor.ThreadsProcessor) Processor(org.apache.camel.Processor) ThreadPoolProfileBuilder(org.apache.camel.builder.ThreadPoolProfileBuilder) ExecutorServiceManager(org.apache.camel.spi.ExecutorServiceManager) ArrayList(java.util.ArrayList) Pipeline(org.apache.camel.processor.Pipeline) ThreadPoolRejectedPolicy(org.apache.camel.ThreadPoolRejectedPolicy) ExecutorService(java.util.concurrent.ExecutorService)

Example 2 with Pipeline

use of org.apache.camel.processor.Pipeline in project camel by apache.

the class RecipientListDefinition method createProcessor.

@Override
public Processor createProcessor(RouteContext routeContext) throws Exception {
    final Expression expression = getExpression().createExpression(routeContext);
    boolean isParallelProcessing = getParallelProcessing() != null && getParallelProcessing();
    boolean isStreaming = getStreaming() != null && getStreaming();
    boolean isParallelAggregate = getParallelAggregate() != null && getParallelAggregate();
    boolean isShareUnitOfWork = getShareUnitOfWork() != null && getShareUnitOfWork();
    boolean isStopOnException = getStopOnException() != null && getStopOnException();
    boolean isIgnoreInvalidEndpoints = getIgnoreInvalidEndpoints() != null && getIgnoreInvalidEndpoints();
    boolean isStopOnAggregateException = getStopOnAggregateException() != null && getStopOnAggregateException();
    RecipientList answer;
    if (delimiter != null) {
        answer = new RecipientList(routeContext.getCamelContext(), expression, delimiter);
    } else {
        answer = new RecipientList(routeContext.getCamelContext(), expression);
    }
    answer.setAggregationStrategy(createAggregationStrategy(routeContext));
    answer.setParallelProcessing(isParallelProcessing);
    answer.setParallelAggregate(isParallelAggregate);
    answer.setStreaming(isStreaming);
    answer.setShareUnitOfWork(isShareUnitOfWork);
    answer.setStopOnException(isStopOnException);
    answer.setIgnoreInvalidEndpoints(isIgnoreInvalidEndpoints);
    answer.setStopOnAggregateException(isStopOnAggregateException);
    if (getCacheSize() != null) {
        answer.setCacheSize(getCacheSize());
    }
    if (onPrepareRef != null) {
        onPrepare = CamelContextHelper.mandatoryLookup(routeContext.getCamelContext(), onPrepareRef, Processor.class);
    }
    if (onPrepare != null) {
        answer.setOnPrepare(onPrepare);
    }
    if (getTimeout() != null) {
        answer.setTimeout(getTimeout());
    }
    boolean shutdownThreadPool = ProcessorDefinitionHelper.willCreateNewThreadPool(routeContext, this, isParallelProcessing);
    ExecutorService threadPool = ProcessorDefinitionHelper.getConfiguredExecutorService(routeContext, "RecipientList", this, isParallelProcessing);
    answer.setExecutorService(threadPool);
    answer.setShutdownExecutorService(shutdownThreadPool);
    long timeout = getTimeout() != null ? getTimeout() : 0;
    if (timeout > 0 && !isParallelProcessing) {
        throw new IllegalArgumentException("Timeout is used but ParallelProcessing has not been enabled.");
    }
    // create a pipeline with two processors
    // the first is the eval processor which evaluates the expression to use
    // the second is the recipient list
    List<Processor> pipe = new ArrayList<Processor>(2);
    // the eval processor must be wrapped in error handler, so in case there was an
    // error during evaluation, the error handler can deal with it
    // the recipient list is not in error handler, as its has its own special error handling
    // when sending to the recipients individually
    Processor evalProcessor = new EvaluateExpressionProcessor(expression);
    evalProcessor = super.wrapInErrorHandler(routeContext, evalProcessor);
    pipe.add(evalProcessor);
    pipe.add(answer);
    // (threads definition does this as well)
    return new Pipeline(routeContext.getCamelContext(), pipe) {

        @Override
        public String toString() {
            return "RecipientList[" + expression + "]";
        }
    };
}
Also used : EvaluateExpressionProcessor(org.apache.camel.processor.EvaluateExpressionProcessor) Processor(org.apache.camel.Processor) EvaluateExpressionProcessor(org.apache.camel.processor.EvaluateExpressionProcessor) Expression(org.apache.camel.Expression) ExecutorService(java.util.concurrent.ExecutorService) ArrayList(java.util.ArrayList) RecipientList(org.apache.camel.processor.RecipientList) Pipeline(org.apache.camel.processor.Pipeline)

Example 3 with Pipeline

use of org.apache.camel.processor.Pipeline in project camel by apache.

the class RouteBuilderTest method testRouteWithInterceptor.

public void testRouteWithInterceptor() throws Exception {
    List<Route> routes = buildRouteWithInterceptor();
    log.debug("Created routes: " + routes);
    assertEquals("Number routes created", 1, routes.size());
    for (Route route : routes) {
        Endpoint key = route.getEndpoint();
        assertEquals("From endpoint", "direct://a", key.getEndpointUri());
        EventDrivenConsumerRoute consumer = assertIsInstanceOf(EventDrivenConsumerRoute.class, route);
        Pipeline line = assertIsInstanceOf(Pipeline.class, unwrap(consumer.getProcessor()));
        assertEquals(3, line.getProcessors().size());
        // last should be our seda
        List<Processor> processors = new ArrayList<Processor>(line.getProcessors());
        Processor sendTo = assertIsInstanceOf(SendProcessor.class, unwrapChannel(processors.get(2)).getNextProcessor());
        assertSendTo(sendTo, "direct://d");
    }
}
Also used : DelegateProcessor(org.apache.camel.DelegateProcessor) Processor(org.apache.camel.Processor) MulticastProcessor(org.apache.camel.processor.MulticastProcessor) FilterProcessor(org.apache.camel.processor.FilterProcessor) EvaluateExpressionProcessor(org.apache.camel.processor.EvaluateExpressionProcessor) ThreadsProcessor(org.apache.camel.processor.ThreadsProcessor) SendProcessor(org.apache.camel.processor.SendProcessor) ChoiceProcessor(org.apache.camel.processor.ChoiceProcessor) Endpoint(org.apache.camel.Endpoint) ArrayList(java.util.ArrayList) EventDrivenConsumerRoute(org.apache.camel.impl.EventDrivenConsumerRoute) Route(org.apache.camel.Route) EventDrivenConsumerRoute(org.apache.camel.impl.EventDrivenConsumerRoute) Pipeline(org.apache.camel.processor.Pipeline)

Example 4 with Pipeline

use of org.apache.camel.processor.Pipeline in project camel by apache.

the class DefaultManagementObjectStrategy method getManagedObjectForProcessor.

@SuppressWarnings({ "deprecation", "unchecked" })
public Object getManagedObjectForProcessor(CamelContext context, Processor processor, ProcessorDefinition<?> definition, Route route) {
    ManagedProcessor answer = null;
    if (definition instanceof RecipientListDefinition) {
        // special for RecipientListDefinition, as the processor is wrapped in a pipeline as last
        Pipeline pipeline = (Pipeline) processor;
        Iterator<Processor> it = pipeline.getProcessors().iterator();
        while (it.hasNext()) {
            processor = it.next();
        }
    } else if (definition instanceof ThreadsDefinition) {
        // special for ThreadsDefinition, as the processor is wrapped in a pipeline as first
        Pipeline pipeline = (Pipeline) processor;
        Iterator<Processor> it = pipeline.getProcessors().iterator();
        processor = it.next();
    }
    // unwrap delegates as we want the real target processor
    Processor target = processor;
    while (target != null) {
        // skip error handlers
        if (target instanceof ErrorHandler) {
            return false;
        }
        if (target instanceof ConvertBodyProcessor) {
            answer = new ManagedConvertBody(context, (ConvertBodyProcessor) target, definition);
        } else if (target instanceof ChoiceProcessor) {
            answer = new ManagedChoice(context, (ChoiceProcessor) target, definition);
        } else if (target instanceof Delayer) {
            answer = new ManagedDelayer(context, (Delayer) target, definition);
        } else if (target instanceof Throttler) {
            answer = new ManagedThrottler(context, (Throttler) target, definition);
        } else if (target instanceof DynamicRouter) {
            answer = new ManagedDynamicRouter(context, (DynamicRouter) target, (org.apache.camel.model.DynamicRouterDefinition) definition);
        } else if (target instanceof RoutingSlip) {
            answer = new ManagedRoutingSlip(context, (RoutingSlip) target, (org.apache.camel.model.RoutingSlipDefinition) definition);
        } else if (target instanceof FilterProcessor) {
            answer = new ManagedFilter(context, (FilterProcessor) target, (ExpressionNode) definition);
        } else if (target instanceof LogProcessor) {
            answer = new ManagedLog(context, (LogProcessor) target, definition);
        } else if (target instanceof LoopProcessor) {
            answer = new ManagedLoop(context, (LoopProcessor) target, (org.apache.camel.model.LoopDefinition) definition);
        } else if (target instanceof MarshalProcessor) {
            answer = new ManagedMarshal(context, (MarshalProcessor) target, (org.apache.camel.model.MarshalDefinition) definition);
        } else if (target instanceof UnmarshalProcessor) {
            answer = new ManagedUnmarshal(context, (UnmarshalProcessor) target, (org.apache.camel.model.UnmarshalDefinition) definition);
        } else if (target instanceof CircuitBreakerLoadBalancer) {
            answer = new ManagedCircuitBreakerLoadBalancer(context, (CircuitBreakerLoadBalancer) target, (org.apache.camel.model.LoadBalanceDefinition) definition);
        } else if (target instanceof FailOverLoadBalancer) {
            answer = new ManagedFailoverLoadBalancer(context, (FailOverLoadBalancer) target, (org.apache.camel.model.LoadBalanceDefinition) definition);
        } else if (target instanceof RandomLoadBalancer) {
            answer = new ManagedRandomLoadBalancer(context, (RandomLoadBalancer) target, (org.apache.camel.model.LoadBalanceDefinition) definition);
        } else if (target instanceof RoundRobinLoadBalancer) {
            answer = new ManagedRoundRobinLoadBalancer(context, (RoundRobinLoadBalancer) target, (org.apache.camel.model.LoadBalanceDefinition) definition);
        } else if (target instanceof StickyLoadBalancer) {
            answer = new ManagedStickyLoadBalancer(context, (StickyLoadBalancer) target, (org.apache.camel.model.LoadBalanceDefinition) definition);
        } else if (target instanceof TopicLoadBalancer) {
            answer = new ManagedTopicLoadBalancer(context, (TopicLoadBalancer) target, (org.apache.camel.model.LoadBalanceDefinition) definition);
        } else if (target instanceof WeightedLoadBalancer) {
            answer = new ManagedWeightedLoadBalancer(context, (WeightedLoadBalancer) target, (org.apache.camel.model.LoadBalanceDefinition) definition);
        } else if (target instanceof RecipientList) {
            answer = new ManagedRecipientList(context, (RecipientList) target, (RecipientListDefinition) definition);
        } else if (target instanceof Splitter) {
            answer = new ManagedSplitter(context, (Splitter) target, (org.apache.camel.model.SplitDefinition) definition);
        } else if (target instanceof MulticastProcessor) {
            answer = new ManagedMulticast(context, (MulticastProcessor) target, definition);
        } else if (target instanceof SamplingThrottler) {
            answer = new ManagedSamplingThrottler(context, (SamplingThrottler) target, definition);
        } else if (target instanceof Resequencer) {
            answer = new ManagedResequencer(context, (Resequencer) target, definition);
        } else if (target instanceof RollbackProcessor) {
            answer = new ManagedRollback(context, (RollbackProcessor) target, definition);
        } else if (target instanceof StreamResequencer) {
            answer = new ManagedResequencer(context, (StreamResequencer) target, definition);
        } else if (target instanceof SetBodyProcessor) {
            answer = new ManagedSetBody(context, (SetBodyProcessor) target, (org.apache.camel.model.SetBodyDefinition) definition);
        } else if (target instanceof RemoveHeaderProcessor) {
            answer = new ManagedRemoveHeader(context, (RemoveHeaderProcessor) target, definition);
        } else if (target instanceof RemoveHeadersProcessor) {
            answer = new ManagedRemoveHeaders(context, (RemoveHeadersProcessor) target, definition);
        } else if (target instanceof SetHeaderProcessor) {
            answer = new ManagedSetHeader(context, (SetHeaderProcessor) target, (org.apache.camel.model.SetHeaderDefinition) definition);
        } else if (target instanceof RemovePropertyProcessor) {
            answer = new ManagedRemoveProperty(context, (RemovePropertyProcessor) target, definition);
        } else if (target instanceof RemovePropertiesProcessor) {
            answer = new ManagedRemoveProperties(context, (RemovePropertiesProcessor) target, definition);
        } else if (target instanceof SetPropertyProcessor) {
            answer = new ManagedSetProperty(context, (SetPropertyProcessor) target, (org.apache.camel.model.SetPropertyDefinition) definition);
        } else if (target instanceof ExchangePatternProcessor) {
            answer = new ManagedSetExchangePattern(context, (ExchangePatternProcessor) target, definition);
        } else if (target instanceof ScriptProcessor) {
            answer = new ManagedScript(context, (ScriptProcessor) target, (org.apache.camel.model.ScriptDefinition) definition);
        } else if (target instanceof StopProcessor) {
            answer = new ManagedStop(context, (StopProcessor) target, definition);
        } else if (target instanceof ThreadsProcessor) {
            answer = new ManagedThreads(context, (ThreadsProcessor) target, definition);
        } else if (target instanceof ThrowExceptionProcessor) {
            answer = new ManagedThrowException(context, (ThrowExceptionProcessor) target, definition);
        } else if (target instanceof TransformProcessor) {
            answer = new ManagedTransformer(context, (TransformProcessor) target, (org.apache.camel.model.TransformDefinition) definition);
        } else if (target instanceof PredicateValidatingProcessor) {
            answer = new ManagedValidate(context, (PredicateValidatingProcessor) target, (org.apache.camel.model.ValidateDefinition) definition);
        } else if (target instanceof WireTapProcessor) {
            answer = new ManagedWireTapProcessor(context, (WireTapProcessor) target, definition);
        } else if (target instanceof SendDynamicProcessor) {
            answer = new ManagedSendDynamicProcessor(context, (SendDynamicProcessor) target, definition);
        } else if (target instanceof SendProcessor) {
            SendProcessor sp = (SendProcessor) target;
            // special for sending to throughput logger
            if (sp.getDestination() instanceof LogEndpoint) {
                LogEndpoint le = (LogEndpoint) sp.getDestination();
                if (le.getLogger() instanceof ThroughputLogger) {
                    ThroughputLogger tl = (ThroughputLogger) le.getLogger();
                    answer = new ManagedThroughputLogger(context, tl, definition);
                }
            }
            // regular send processor
            if (answer == null) {
                answer = new ManagedSendProcessor(context, (SendProcessor) target, definition);
            }
        } else if (target instanceof BeanProcessor) {
            answer = new ManagedBeanProcessor(context, (BeanProcessor) target, definition);
        } else if (target instanceof IdempotentConsumer) {
            answer = new ManagedIdempotentConsumer(context, (IdempotentConsumer) target, (org.apache.camel.model.IdempotentConsumerDefinition) definition);
        } else if (target instanceof AggregateProcessor) {
            answer = new ManagedAggregateProcessor(context, (AggregateProcessor) target, (org.apache.camel.model.AggregateDefinition) definition);
        } else if (target instanceof Enricher) {
            answer = new ManagedEnricher(context, (Enricher) target, (org.apache.camel.model.EnrichDefinition) definition);
        } else if (target instanceof PollEnricher) {
            answer = new ManagedPollEnricher(context, (PollEnricher) target, (org.apache.camel.model.PollEnrichDefinition) definition);
        } else if (target instanceof org.apache.camel.spi.ManagementAware) {
            return ((org.apache.camel.spi.ManagementAware<Processor>) target).getManagedObject(processor);
        }
        // special for custom load balancer
        if (definition instanceof LoadBalanceDefinition) {
            LoadBalanceDefinition lb = (LoadBalanceDefinition) definition;
            if (lb.getLoadBalancerType() instanceof CustomLoadBalancerDefinition) {
                answer = new ManagedCustomLoadBalancer(context, (LoadBalancer) target, (LoadBalanceDefinition) definition);
            }
        }
        if (answer != null) {
            // break out as we found an answer
            break;
        }
        // no answer yet, so unwrap any delegates and try again
        if (target instanceof DelegateProcessor) {
            target = ((DelegateProcessor) target).getProcessor();
        } else {
            // no delegate so we dont have any target to try next
            break;
        }
    }
    if (answer == null && definition instanceof ProcessDefinition) {
        answer = new ManagedProcess(context, target, (ProcessDefinition) definition);
    } else if (answer == null) {
        // fallback to a generic processor
        answer = new ManagedProcessor(context, target, definition);
    }
    answer.setRoute(route);
    answer.init(context.getManagementStrategy());
    return answer;
}
Also used : ManagedMarshal(org.apache.camel.management.mbean.ManagedMarshal) ManagedSplitter(org.apache.camel.management.mbean.ManagedSplitter) FilterProcessor(org.apache.camel.processor.FilterProcessor) UnmarshalProcessor(org.apache.camel.processor.UnmarshalProcessor) ManagedResequencer(org.apache.camel.management.mbean.ManagedResequencer) Resequencer(org.apache.camel.processor.Resequencer) StreamResequencer(org.apache.camel.processor.StreamResequencer) ManagedSetExchangePattern(org.apache.camel.management.mbean.ManagedSetExchangePattern) ManagedWeightedLoadBalancer(org.apache.camel.management.mbean.ManagedWeightedLoadBalancer) ManagedPollEnricher(org.apache.camel.management.mbean.ManagedPollEnricher) MarshalProcessor(org.apache.camel.processor.MarshalProcessor) ManagedThrottler(org.apache.camel.management.mbean.ManagedThrottler) ManagedThroughputLogger(org.apache.camel.management.mbean.ManagedThroughputLogger) ChoiceProcessor(org.apache.camel.processor.ChoiceProcessor) ManagedThrottler(org.apache.camel.management.mbean.ManagedThrottler) SamplingThrottler(org.apache.camel.processor.SamplingThrottler) Throttler(org.apache.camel.processor.Throttler) ManagedSamplingThrottler(org.apache.camel.management.mbean.ManagedSamplingThrottler) ManagedTopicLoadBalancer(org.apache.camel.management.mbean.ManagedTopicLoadBalancer) SetHeaderProcessor(org.apache.camel.processor.SetHeaderProcessor) ManagedRemoveProperties(org.apache.camel.management.mbean.ManagedRemoveProperties) ManagedRecipientList(org.apache.camel.management.mbean.ManagedRecipientList) ManagedIdempotentConsumer(org.apache.camel.management.mbean.ManagedIdempotentConsumer) ManagedValidate(org.apache.camel.management.mbean.ManagedValidate) ConvertBodyProcessor(org.apache.camel.processor.ConvertBodyProcessor) ManagedLoop(org.apache.camel.management.mbean.ManagedLoop) MulticastProcessor(org.apache.camel.processor.MulticastProcessor) ManagedRollback(org.apache.camel.management.mbean.ManagedRollback) LogEndpoint(org.apache.camel.component.log.LogEndpoint) WireTapProcessor(org.apache.camel.processor.WireTapProcessor) ManagedWireTapProcessor(org.apache.camel.management.mbean.ManagedWireTapProcessor) ManagedScript(org.apache.camel.management.mbean.ManagedScript) ScriptProcessor(org.apache.camel.processor.ScriptProcessor) ManagedSendDynamicProcessor(org.apache.camel.management.mbean.ManagedSendDynamicProcessor) PredicateValidatingProcessor(org.apache.camel.processor.validation.PredicateValidatingProcessor) WireTapProcessor(org.apache.camel.processor.WireTapProcessor) LogProcessor(org.apache.camel.processor.LogProcessor) ManagedBeanProcessor(org.apache.camel.management.mbean.ManagedBeanProcessor) StopProcessor(org.apache.camel.processor.StopProcessor) TransformProcessor(org.apache.camel.processor.TransformProcessor) BeanProcessor(org.apache.camel.component.bean.BeanProcessor) ThrowExceptionProcessor(org.apache.camel.processor.ThrowExceptionProcessor) RemoveHeadersProcessor(org.apache.camel.processor.RemoveHeadersProcessor) SendProcessor(org.apache.camel.processor.SendProcessor) MarshalProcessor(org.apache.camel.processor.MarshalProcessor) LoopProcessor(org.apache.camel.processor.LoopProcessor) SetHeaderProcessor(org.apache.camel.processor.SetHeaderProcessor) UnmarshalProcessor(org.apache.camel.processor.UnmarshalProcessor) RemoveHeaderProcessor(org.apache.camel.processor.RemoveHeaderProcessor) RemovePropertiesProcessor(org.apache.camel.processor.RemovePropertiesProcessor) MulticastProcessor(org.apache.camel.processor.MulticastProcessor) FilterProcessor(org.apache.camel.processor.FilterProcessor) SetPropertyProcessor(org.apache.camel.processor.SetPropertyProcessor) ThreadsProcessor(org.apache.camel.processor.ThreadsProcessor) ExchangePatternProcessor(org.apache.camel.processor.ExchangePatternProcessor) SetBodyProcessor(org.apache.camel.processor.SetBodyProcessor) SendDynamicProcessor(org.apache.camel.processor.SendDynamicProcessor) ManagedProcessor(org.apache.camel.management.mbean.ManagedProcessor) ChoiceProcessor(org.apache.camel.processor.ChoiceProcessor) RollbackProcessor(org.apache.camel.processor.RollbackProcessor) DelegateProcessor(org.apache.camel.DelegateProcessor) ManagedAggregateProcessor(org.apache.camel.management.mbean.ManagedAggregateProcessor) ManagedWireTapProcessor(org.apache.camel.management.mbean.ManagedWireTapProcessor) RemovePropertyProcessor(org.apache.camel.processor.RemovePropertyProcessor) Processor(org.apache.camel.Processor) ScriptProcessor(org.apache.camel.processor.ScriptProcessor) ConvertBodyProcessor(org.apache.camel.processor.ConvertBodyProcessor) ManagedSendProcessor(org.apache.camel.management.mbean.ManagedSendProcessor) AggregateProcessor(org.apache.camel.processor.aggregate.AggregateProcessor) ThreadsProcessor(org.apache.camel.processor.ThreadsProcessor) LoopProcessor(org.apache.camel.processor.LoopProcessor) SetPropertyProcessor(org.apache.camel.processor.SetPropertyProcessor) ExchangePatternProcessor(org.apache.camel.processor.ExchangePatternProcessor) ManagedRandomLoadBalancer(org.apache.camel.management.mbean.ManagedRandomLoadBalancer) ManagedSendProcessor(org.apache.camel.management.mbean.ManagedSendProcessor) ManagedCustomLoadBalancer(org.apache.camel.management.mbean.ManagedCustomLoadBalancer) RemoveHeadersProcessor(org.apache.camel.processor.RemoveHeadersProcessor) ManagedRemoveHeaders(org.apache.camel.management.mbean.ManagedRemoveHeaders) ManagedRoutingSlip(org.apache.camel.management.mbean.ManagedRoutingSlip) RoutingSlip(org.apache.camel.processor.RoutingSlip) ManagedProcessor(org.apache.camel.management.mbean.ManagedProcessor) ThrowExceptionProcessor(org.apache.camel.processor.ThrowExceptionProcessor) ManagedFilter(org.apache.camel.management.mbean.ManagedFilter) ManagedAggregateProcessor(org.apache.camel.management.mbean.ManagedAggregateProcessor) ManagedRemoveHeader(org.apache.camel.management.mbean.ManagedRemoveHeader) CustomLoadBalancerDefinition(org.apache.camel.model.loadbalancer.CustomLoadBalancerDefinition) ManagedChoice(org.apache.camel.management.mbean.ManagedChoice) RemovePropertiesProcessor(org.apache.camel.processor.RemovePropertiesProcessor) LogProcessor(org.apache.camel.processor.LogProcessor) ManagedEnricher(org.apache.camel.management.mbean.ManagedEnricher) RemovePropertyProcessor(org.apache.camel.processor.RemovePropertyProcessor) ManagedSendDynamicProcessor(org.apache.camel.management.mbean.ManagedSendDynamicProcessor) Pipeline(org.apache.camel.processor.Pipeline) ManagedProcess(org.apache.camel.management.mbean.ManagedProcess) ManagedSetProperty(org.apache.camel.management.mbean.ManagedSetProperty) ExpressionNode(org.apache.camel.model.ExpressionNode) SamplingThrottler(org.apache.camel.processor.SamplingThrottler) ManagedSamplingThrottler(org.apache.camel.management.mbean.ManagedSamplingThrottler) RollbackProcessor(org.apache.camel.processor.RollbackProcessor) ManagedThreads(org.apache.camel.management.mbean.ManagedThreads) SendProcessor(org.apache.camel.processor.SendProcessor) ManagedSendProcessor(org.apache.camel.management.mbean.ManagedSendProcessor) ManagedIdempotentConsumer(org.apache.camel.management.mbean.ManagedIdempotentConsumer) IdempotentConsumer(org.apache.camel.processor.idempotent.IdempotentConsumer) ManagedTransformer(org.apache.camel.management.mbean.ManagedTransformer) LoadBalanceDefinition(org.apache.camel.model.LoadBalanceDefinition) SetBodyProcessor(org.apache.camel.processor.SetBodyProcessor) FailOverLoadBalancer(org.apache.camel.processor.loadbalancer.FailOverLoadBalancer) ProcessDefinition(org.apache.camel.model.ProcessDefinition) ManagedDelayer(org.apache.camel.management.mbean.ManagedDelayer) CircuitBreakerLoadBalancer(org.apache.camel.processor.loadbalancer.CircuitBreakerLoadBalancer) ManagedCircuitBreakerLoadBalancer(org.apache.camel.management.mbean.ManagedCircuitBreakerLoadBalancer) Enricher(org.apache.camel.processor.Enricher) PollEnricher(org.apache.camel.processor.PollEnricher) ManagedPollEnricher(org.apache.camel.management.mbean.ManagedPollEnricher) ManagedEnricher(org.apache.camel.management.mbean.ManagedEnricher) ManagedWireTapProcessor(org.apache.camel.management.mbean.ManagedWireTapProcessor) ManagedRoutingSlip(org.apache.camel.management.mbean.ManagedRoutingSlip) ManagedRandomLoadBalancer(org.apache.camel.management.mbean.ManagedRandomLoadBalancer) RandomLoadBalancer(org.apache.camel.processor.loadbalancer.RandomLoadBalancer) ManagedSamplingThrottler(org.apache.camel.management.mbean.ManagedSamplingThrottler) ManagedSetHeader(org.apache.camel.management.mbean.ManagedSetHeader) TransformProcessor(org.apache.camel.processor.TransformProcessor) RemoveHeaderProcessor(org.apache.camel.processor.RemoveHeaderProcessor) ErrorHandler(org.apache.camel.processor.ErrorHandler) ManagedErrorHandler(org.apache.camel.management.mbean.ManagedErrorHandler) ManagedCircuitBreakerLoadBalancer(org.apache.camel.management.mbean.ManagedCircuitBreakerLoadBalancer) ManagedTopicLoadBalancer(org.apache.camel.management.mbean.ManagedTopicLoadBalancer) ManagedWeightedLoadBalancer(org.apache.camel.management.mbean.ManagedWeightedLoadBalancer) CircuitBreakerLoadBalancer(org.apache.camel.processor.loadbalancer.CircuitBreakerLoadBalancer) StickyLoadBalancer(org.apache.camel.processor.loadbalancer.StickyLoadBalancer) WeightedLoadBalancer(org.apache.camel.processor.loadbalancer.WeightedLoadBalancer) ManagedRandomLoadBalancer(org.apache.camel.management.mbean.ManagedRandomLoadBalancer) ManagedCustomLoadBalancer(org.apache.camel.management.mbean.ManagedCustomLoadBalancer) RoundRobinLoadBalancer(org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer) TopicLoadBalancer(org.apache.camel.processor.loadbalancer.TopicLoadBalancer) ManagedFailoverLoadBalancer(org.apache.camel.management.mbean.ManagedFailoverLoadBalancer) FailOverLoadBalancer(org.apache.camel.processor.loadbalancer.FailOverLoadBalancer) LoadBalancer(org.apache.camel.processor.loadbalancer.LoadBalancer) ManagedStickyLoadBalancer(org.apache.camel.management.mbean.ManagedStickyLoadBalancer) ManagedCircuitBreakerLoadBalancer(org.apache.camel.management.mbean.ManagedCircuitBreakerLoadBalancer) RandomLoadBalancer(org.apache.camel.processor.loadbalancer.RandomLoadBalancer) ManagedRoundRobinLoadBalancer(org.apache.camel.management.mbean.ManagedRoundRobinLoadBalancer) ManagedWeightedLoadBalancer(org.apache.camel.management.mbean.ManagedWeightedLoadBalancer) WeightedLoadBalancer(org.apache.camel.processor.loadbalancer.WeightedLoadBalancer) ManagedRemoveProperty(org.apache.camel.management.mbean.ManagedRemoveProperty) ManagedAggregateProcessor(org.apache.camel.management.mbean.ManagedAggregateProcessor) AggregateProcessor(org.apache.camel.processor.aggregate.AggregateProcessor) ManagedStickyLoadBalancer(org.apache.camel.management.mbean.ManagedStickyLoadBalancer) StreamResequencer(org.apache.camel.processor.StreamResequencer) ManagedThroughputLogger(org.apache.camel.management.mbean.ManagedThroughputLogger) ThroughputLogger(org.apache.camel.processor.ThroughputLogger) PredicateValidatingProcessor(org.apache.camel.processor.validation.PredicateValidatingProcessor) ManagedResequencer(org.apache.camel.management.mbean.ManagedResequencer) ManagedLog(org.apache.camel.management.mbean.ManagedLog) RoundRobinLoadBalancer(org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer) ManagedRoundRobinLoadBalancer(org.apache.camel.management.mbean.ManagedRoundRobinLoadBalancer) ManagedRecipientList(org.apache.camel.management.mbean.ManagedRecipientList) RecipientList(org.apache.camel.processor.RecipientList) ManagedConvertBody(org.apache.camel.management.mbean.ManagedConvertBody) PollEnricher(org.apache.camel.processor.PollEnricher) ManagedPollEnricher(org.apache.camel.management.mbean.ManagedPollEnricher) Iterator(java.util.Iterator) ManagedMulticast(org.apache.camel.management.mbean.ManagedMulticast) ManagedStop(org.apache.camel.management.mbean.ManagedStop) RecipientListDefinition(org.apache.camel.model.RecipientListDefinition) ManagedSplitter(org.apache.camel.management.mbean.ManagedSplitter) Splitter(org.apache.camel.processor.Splitter) StopProcessor(org.apache.camel.processor.StopProcessor) ManagedFailoverLoadBalancer(org.apache.camel.management.mbean.ManagedFailoverLoadBalancer) ManagedBeanProcessor(org.apache.camel.management.mbean.ManagedBeanProcessor) BeanProcessor(org.apache.camel.component.bean.BeanProcessor) ThreadsDefinition(org.apache.camel.model.ThreadsDefinition) StickyLoadBalancer(org.apache.camel.processor.loadbalancer.StickyLoadBalancer) ManagedStickyLoadBalancer(org.apache.camel.management.mbean.ManagedStickyLoadBalancer) ManagedDynamicRouter(org.apache.camel.management.mbean.ManagedDynamicRouter) DynamicRouter(org.apache.camel.processor.DynamicRouter) ManagedDelayer(org.apache.camel.management.mbean.ManagedDelayer) Delayer(org.apache.camel.processor.Delayer) ManagedSendDynamicProcessor(org.apache.camel.management.mbean.ManagedSendDynamicProcessor) SendDynamicProcessor(org.apache.camel.processor.SendDynamicProcessor) ManagedBeanProcessor(org.apache.camel.management.mbean.ManagedBeanProcessor) ManagedTopicLoadBalancer(org.apache.camel.management.mbean.ManagedTopicLoadBalancer) TopicLoadBalancer(org.apache.camel.processor.loadbalancer.TopicLoadBalancer) ManagedDynamicRouter(org.apache.camel.management.mbean.ManagedDynamicRouter) ManagedUnmarshal(org.apache.camel.management.mbean.ManagedUnmarshal) DelegateProcessor(org.apache.camel.DelegateProcessor) ManagedThrowException(org.apache.camel.management.mbean.ManagedThrowException) ManagedRoundRobinLoadBalancer(org.apache.camel.management.mbean.ManagedRoundRobinLoadBalancer) ManagedSetBody(org.apache.camel.management.mbean.ManagedSetBody)

Example 5 with Pipeline

use of org.apache.camel.processor.Pipeline in project camel by apache.

the class InterceptDefinition method createProcessor.

@Override
public Processor createProcessor(final RouteContext routeContext) throws Exception {
    // create the output processor
    output = this.createChildProcessor(routeContext, true);
    // add the output as a intercept strategy to the route context so its invoked on each processing step
    routeContext.getInterceptStrategies().add(new InterceptStrategy() {

        private Processor interceptedTarget;

        public Processor wrapProcessorInInterceptors(CamelContext context, ProcessorDefinition<?> definition, Processor target, Processor nextTarget) throws Exception {
            // store the target we are intercepting
            this.interceptedTarget = target;
            // remember the target that was intercepted
            intercepted.add(interceptedTarget);
            if (interceptedTarget != null) {
                // wrap in a pipeline so we continue routing to the next
                List<Processor> list = new ArrayList<Processor>(2);
                list.add(output);
                list.add(interceptedTarget);
                return new Pipeline(context, list);
            } else {
                return output;
            }
        }

        @Override
        public String toString() {
            return "intercept[" + (interceptedTarget != null ? interceptedTarget : output) + "]";
        }
    });
    // remove me from the route so I am not invoked in a regular route path
    routeContext.getRoute().getOutputs().remove(this);
    // and return no processor to invoke next from me
    return null;
}
Also used : CamelContext(org.apache.camel.CamelContext) Processor(org.apache.camel.Processor) ArrayList(java.util.ArrayList) List(java.util.List) InterceptStrategy(org.apache.camel.spi.InterceptStrategy) Pipeline(org.apache.camel.processor.Pipeline)

Aggregations

Pipeline (org.apache.camel.processor.Pipeline)7 Processor (org.apache.camel.Processor)6 ArrayList (java.util.ArrayList)4 ThreadsProcessor (org.apache.camel.processor.ThreadsProcessor)4 DelegateProcessor (org.apache.camel.DelegateProcessor)3 Endpoint (org.apache.camel.Endpoint)3 Route (org.apache.camel.Route)3 EventDrivenConsumerRoute (org.apache.camel.impl.EventDrivenConsumerRoute)3 ChoiceProcessor (org.apache.camel.processor.ChoiceProcessor)3 EvaluateExpressionProcessor (org.apache.camel.processor.EvaluateExpressionProcessor)3 FilterProcessor (org.apache.camel.processor.FilterProcessor)3 MulticastProcessor (org.apache.camel.processor.MulticastProcessor)3 SendProcessor (org.apache.camel.processor.SendProcessor)3 ExecutorService (java.util.concurrent.ExecutorService)2 Channel (org.apache.camel.Channel)2 DeadLetterChannel (org.apache.camel.processor.DeadLetterChannel)2 RecipientList (org.apache.camel.processor.RecipientList)2 Iterator (java.util.Iterator)1 List (java.util.List)1 CamelContext (org.apache.camel.CamelContext)1