Search in sources :

Example 1 with FilterManager

use of org.apache.qpid.server.filter.FilterManager in project qpid-broker-j by apache.

the class SendingLinkEndpoint method prepareConsumerOptionsAndFilters.

private void prepareConsumerOptionsAndFilters(final SendingDestination destination) throws AmqpErrorException {
    // TODO QPID-7952: this method might modify the source. this is not good encapsulation. furthermore if it does so then it should inform the link/linkregistry about it!
    _destination = destination;
    final Source source = getSource();
    EnumSet<ConsumerOption> options = EnumSet.noneOf(ConsumerOption.class);
    boolean noLocal = false;
    JMSSelectorFilter messageFilter = null;
    if (destination instanceof ExchangeSendingDestination) {
        options.add(ConsumerOption.ACQUIRES);
        options.add(ConsumerOption.SEES_REQUEUES);
    } else if (destination instanceof StandardSendingDestination) {
        MessageSource messageSource = _destination.getMessageSource();
        if (messageSource instanceof Queue && ((Queue<?>) messageSource).getAvailableAttributes().contains("topic")) {
            source.setDistributionMode(StdDistMode.COPY);
        }
        Map<Symbol, Filter> filters = source.getFilter();
        Map<Symbol, Filter> actualFilters = new HashMap<>();
        if (filters != null) {
            for (Map.Entry<Symbol, Filter> entry : filters.entrySet()) {
                if (entry.getValue() instanceof NoLocalFilter) {
                    actualFilters.put(entry.getKey(), entry.getValue());
                    noLocal = true;
                } else if (messageFilter == null && entry.getValue() instanceof org.apache.qpid.server.protocol.v1_0.type.messaging.JMSSelectorFilter) {
                    org.apache.qpid.server.protocol.v1_0.type.messaging.JMSSelectorFilter selectorFilter = (org.apache.qpid.server.protocol.v1_0.type.messaging.JMSSelectorFilter) entry.getValue();
                    try {
                        messageFilter = new JMSSelectorFilter(selectorFilter.getValue());
                        actualFilters.put(entry.getKey(), entry.getValue());
                    } catch (ParseException | SelectorParsingException | TokenMgrError e) {
                        Error error = new Error();
                        error.setCondition(AmqpError.INVALID_FIELD);
                        error.setDescription("Invalid JMS Selector: " + selectorFilter.getValue());
                        error.setInfo(Collections.singletonMap(Symbol.valueOf("field"), Symbol.valueOf("filter")));
                        throw new AmqpErrorException(error);
                    }
                }
            }
        }
        source.setFilter(actualFilters.isEmpty() ? null : actualFilters);
        if (source.getDistributionMode() != StdDistMode.COPY) {
            options.add(ConsumerOption.ACQUIRES);
            options.add(ConsumerOption.SEES_REQUEUES);
        }
    } else {
        throw new ConnectionScopedRuntimeException("Unknown destination type");
    }
    if (noLocal) {
        options.add(ConsumerOption.NO_LOCAL);
    }
    FilterManager filters = null;
    if (messageFilter != null) {
        filters = new FilterManager();
        filters.add(messageFilter.getName(), messageFilter);
    }
    _consumerOptions = options;
    _consumerFilters = filters;
}
Also used : ConsumerOption(org.apache.qpid.server.consumer.ConsumerOption) MessageSource(org.apache.qpid.server.message.MessageSource) BaseSource(org.apache.qpid.server.protocol.v1_0.type.BaseSource) Source(org.apache.qpid.server.protocol.v1_0.type.messaging.Source) FilterManager(org.apache.qpid.server.filter.FilterManager) SelectorParsingException(org.apache.qpid.server.filter.SelectorParsingException) ConnectionScopedRuntimeException(org.apache.qpid.server.util.ConnectionScopedRuntimeException) ConcurrentLinkedQueue(java.util.concurrent.ConcurrentLinkedQueue) Queue(org.apache.qpid.server.model.Queue) JMSSelectorFilter(org.apache.qpid.server.filter.JMSSelectorFilter) NoLocalFilter(org.apache.qpid.server.protocol.v1_0.type.messaging.NoLocalFilter) MessageSource(org.apache.qpid.server.message.MessageSource) TransactionError(org.apache.qpid.server.protocol.v1_0.type.transaction.TransactionError) TokenMgrError(org.apache.qpid.server.filter.selector.TokenMgrError) Error(org.apache.qpid.server.protocol.v1_0.type.transport.Error) AmqpError(org.apache.qpid.server.protocol.v1_0.type.transport.AmqpError) AmqpErrorException(org.apache.qpid.server.protocol.v1_0.type.AmqpErrorException) TokenMgrError(org.apache.qpid.server.filter.selector.TokenMgrError) ParseException(org.apache.qpid.server.filter.selector.ParseException) Map(java.util.Map) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) HashMap(java.util.HashMap)

Example 2 with FilterManager

use of org.apache.qpid.server.filter.FilterManager in project qpid-broker-j by apache.

the class ServerSessionDelegate method messageSubscribe.

@Override
public void messageSubscribe(ServerSession session, MessageSubscribe method) {
    /*
          TODO - work around broken Python tests
          Correct code should read like
          if not hasAcceptMode() exception ILLEGAL_ARGUMENT "Accept-mode not supplied"
          else if not method.hasAcquireMode() exception ExecutionErrorCode.ILLEGAL_ARGUMENT, "Acquire-mode not supplied"
        */
    if (!method.hasAcceptMode()) {
        method.setAcceptMode(MessageAcceptMode.EXPLICIT);
    }
    if (!method.hasAcquireMode()) {
        method.setAcquireMode(MessageAcquireMode.PRE_ACQUIRED);
    }
    if (!method.hasQueue()) {
        exception(session, method, ExecutionErrorCode.ILLEGAL_ARGUMENT, "queue not supplied");
    } else {
        String destination = method.getDestination();
        if (destination == null) {
            exception(session, method, ExecutionErrorCode.INVALID_ARGUMENT, "Subscriber must provide a destination. The protocol specification marking the destination argument as optional is considered a mistake.");
        } else if (session.getSubscription(destination) != null) {
            exception(session, method, ExecutionErrorCode.NOT_ALLOWED, "Subscription already exists with destination '" + destination + "'");
        } else {
            String queueName = method.getQueue();
            NamedAddressSpace addressSpace = getAddressSpace(session);
            final Collection<MessageSource> sources = new HashSet<>();
            final MessageSource queue = addressSpace.getAttainedMessageSource(queueName);
            if (method.getArguments() != null && method.getArguments().get("x-multiqueue") instanceof Collection) {
                for (Object object : (Collection<Object>) method.getArguments().get("x-multiqueue")) {
                    String sourceName = String.valueOf(object);
                    sourceName = sourceName.trim();
                    if (sourceName.length() != 0) {
                        MessageSource source = addressSpace.getAttainedMessageSource(sourceName);
                        if (source == null) {
                            sources.clear();
                            break;
                        } else {
                            sources.add(source);
                        }
                    }
                }
                queueName = method.getArguments().get("x-multiqueue").toString();
            } else if (queue != null) {
                sources.add(queue);
            }
            if (sources.isEmpty()) {
                exception(session, method, ExecutionErrorCode.NOT_FOUND, "Queue: " + queueName + " not found");
            } else if (!verifySessionAccess(session, sources)) {
                exception(session, method, ExecutionErrorCode.RESOURCE_LOCKED, "Exclusive Queue: " + queueName + " owned exclusively by another session");
            } else {
                ProtocolEngine protocolEngine = getServerConnection(session).getAmqpConnection();
                FlowCreditManager_0_10 creditManager = new WindowCreditManager(0L, 0L);
                FilterManager filterManager = null;
                try {
                    filterManager = FilterManagerFactory.createManager(method.getArguments());
                } catch (AMQInvalidArgumentException amqe) {
                    exception(session, method, ExecutionErrorCode.ILLEGAL_ARGUMENT, "Exception Creating FilterManager");
                    return;
                }
                if (method.hasArguments() && method.getArguments().containsKey(AMQPFilterTypes.REPLAY_PERIOD.toString())) {
                    Object value = method.getArguments().get(AMQPFilterTypes.REPLAY_PERIOD.toString());
                    final long period;
                    if (value instanceof Number) {
                        period = ((Number) value).longValue();
                    } else if (value instanceof String) {
                        try {
                            period = Long.parseLong(value.toString());
                        } catch (NumberFormatException e) {
                            exception(session, method, ExecutionErrorCode.ILLEGAL_ARGUMENT, "Cannot parse value " + value + " as a number for filter " + AMQPFilterTypes.REPLAY_PERIOD.toString());
                            return;
                        }
                    } else {
                        exception(session, method, ExecutionErrorCode.ILLEGAL_ARGUMENT, "Cannot parse value " + value + " as a number for filter " + AMQPFilterTypes.REPLAY_PERIOD.toString());
                        return;
                    }
                    final long startingFrom = System.currentTimeMillis() - (1000l * period);
                    if (filterManager == null) {
                        filterManager = new FilterManager();
                    }
                    MessageFilter filter = new ArrivalTimeFilter(startingFrom, period == 0);
                    filterManager.add(filter.getName(), filter);
                }
                boolean multiQueue = sources.size() > 1;
                ConsumerTarget_0_10 target = new ConsumerTarget_0_10(session, destination, method.getAcceptMode(), method.getAcquireMode(), MessageFlowMode.WINDOW, creditManager, method.getArguments(), multiQueue);
                Integer priority = null;
                if (method.hasArguments() && method.getArguments().containsKey("x-priority")) {
                    Object value = method.getArguments().get("x-priority");
                    if (value instanceof Number) {
                        priority = ((Number) value).intValue();
                    } else if (value instanceof String) {
                        try {
                            priority = Integer.parseInt(value.toString());
                        } catch (NumberFormatException e) {
                        }
                    }
                }
                session.register(destination, target);
                try {
                    EnumSet<ConsumerOption> options = EnumSet.noneOf(ConsumerOption.class);
                    if (method.getAcquireMode() == MessageAcquireMode.PRE_ACQUIRED) {
                        options.add(ConsumerOption.ACQUIRES);
                    }
                    if (method.getAcquireMode() != MessageAcquireMode.NOT_ACQUIRED || method.getAcceptMode() == MessageAcceptMode.EXPLICIT) {
                        options.add(ConsumerOption.SEES_REQUEUES);
                    }
                    if (method.getExclusive()) {
                        options.add(ConsumerOption.EXCLUSIVE);
                    }
                    for (MessageSource source : sources) {
                        source.addConsumer(target, filterManager, MessageTransferMessage.class, destination, options, priority);
                    }
                    target.updateNotifyWorkDesired();
                } catch (Queue.ExistingExclusiveConsumer existing) {
                    exception(session, method, ExecutionErrorCode.RESOURCE_LOCKED, "Queue has an exclusive consumer");
                } catch (Queue.ExistingConsumerPreventsExclusive exclusive) {
                    exception(session, method, ExecutionErrorCode.RESOURCE_LOCKED, "Queue has an existing consumer - can't subscribe exclusively");
                } catch (AccessControlException e) {
                    exception(session, method, ExecutionErrorCode.UNAUTHORIZED_ACCESS, e.getMessage());
                } catch (MessageSource.ConsumerAccessRefused consumerAccessRefused) {
                    exception(session, method, ExecutionErrorCode.RESOURCE_LOCKED, "Queue has an incompatible exclusivity policy");
                } catch (MessageSource.QueueDeleted queueDeleted) {
                    exception(session, method, ExecutionErrorCode.NOT_FOUND, "Queue was deleted");
                }
            }
        }
    }
}
Also used : ProtocolEngine(org.apache.qpid.server.transport.ProtocolEngine) AMQInvalidArgumentException(org.apache.qpid.server.filter.AMQInvalidArgumentException) ConsumerOption(org.apache.qpid.server.consumer.ConsumerOption) FilterManager(org.apache.qpid.server.filter.FilterManager) Queue(org.apache.qpid.server.model.Queue) ArrivalTimeFilter(org.apache.qpid.server.filter.ArrivalTimeFilter) NamedAddressSpace(org.apache.qpid.server.model.NamedAddressSpace) MessageSource(org.apache.qpid.server.message.MessageSource) AccessControlException(java.security.AccessControlException) Collection(java.util.Collection) AbstractConfiguredObject(org.apache.qpid.server.model.AbstractConfiguredObject) MessageFilter(org.apache.qpid.server.filter.MessageFilter)

Example 3 with FilterManager

use of org.apache.qpid.server.filter.FilterManager in project qpid-broker-j by apache.

the class AMQChannel method consumeFromSource.

/**
 * Subscribe to a queue. We register all subscriptions in the channel so that if the channel is closed we can clean
 * up all subscriptions, even if the client does not explicitly unsubscribe from all queues.
 *
 * @param tag       the tag chosen by the client (if null, server will generate one)
 * @param sources     the queues to subscribe to
 * @param acks      Are acks enabled for this subscriber
 * @param arguments   Filters to apply to this subscriber
 *
 * @param exclusive Flag requesting exclusive access to the queue
 * @return the consumer tag. This is returned to the subscriber and used in subsequent unsubscribe requests
 */
private AMQShortString consumeFromSource(AMQShortString tag, Collection<MessageSource> sources, boolean acks, FieldTable arguments, boolean exclusive, boolean noLocal) throws MessageSource.ExistingConsumerPreventsExclusive, MessageSource.ExistingExclusiveConsumer, AMQInvalidArgumentException, MessageSource.ConsumerAccessRefused, ConsumerTagInUseException, MessageSource.QueueDeleted {
    if (tag == null) {
        tag = new AMQShortString("sgen_" + getNextConsumerTag());
    }
    if (_tag2SubscriptionTargetMap.containsKey(tag)) {
        throw new ConsumerTagInUseException("Consumer already exists with same tag: " + tag);
    }
    ConsumerTarget_0_8 target;
    EnumSet<ConsumerOption> options = EnumSet.noneOf(ConsumerOption.class);
    final boolean multiQueue = sources.size() > 1;
    if (arguments != null && Boolean.TRUE.equals(arguments.get(AMQPFilterTypes.NO_CONSUME.getValue()))) {
        target = ConsumerTarget_0_8.createBrowserTarget(this, tag, arguments, INFINITE_CREDIT_CREDIT_MANAGER, multiQueue);
    } else if (acks) {
        target = ConsumerTarget_0_8.createAckTarget(this, tag, arguments, _creditManager, multiQueue);
        options.add(ConsumerOption.ACQUIRES);
        options.add(ConsumerOption.SEES_REQUEUES);
    } else {
        target = ConsumerTarget_0_8.createNoAckTarget(this, tag, arguments, INFINITE_CREDIT_CREDIT_MANAGER, multiQueue);
        options.add(ConsumerOption.ACQUIRES);
        options.add(ConsumerOption.SEES_REQUEUES);
    }
    if (exclusive) {
        options.add(ConsumerOption.EXCLUSIVE);
    }
    // So to keep things straight we put before the call and catch all exceptions from the register and tidy up.
    // We add before we register as the Async Delivery process may AutoClose the subscriber
    // so calling _cT2QM.remove before we have done put which was after the register succeeded.
    // So to keep things straight we put before the call and catch all exceptions from the register and tidy up.
    _tag2SubscriptionTargetMap.put(tag, target);
    try {
        FilterManager filterManager = FilterManagerFactory.createManager(FieldTable.convertToMap(arguments));
        if (noLocal) {
            if (filterManager == null) {
                filterManager = new FilterManager();
            }
            MessageFilter filter = new NoLocalFilter();
            filterManager.add(filter.getName(), filter);
        }
        if (arguments != null && arguments.containsKey(AMQPFilterTypes.REPLAY_PERIOD.toString())) {
            Object value = arguments.get(AMQPFilterTypes.REPLAY_PERIOD.toString());
            final long period;
            if (value instanceof Number) {
                period = ((Number) value).longValue();
            } else if (value instanceof String) {
                try {
                    period = Long.parseLong(value.toString());
                } catch (NumberFormatException e) {
                    throw new AMQInvalidArgumentException("Cannot parse value " + value + " as a number for filter " + AMQPFilterTypes.REPLAY_PERIOD.toString());
                }
            } else {
                throw new AMQInvalidArgumentException("Cannot parse value " + value + " as a number for filter " + AMQPFilterTypes.REPLAY_PERIOD.toString());
            }
            final long startingFrom = System.currentTimeMillis() - (1000l * period);
            if (filterManager == null) {
                filterManager = new FilterManager();
            }
            MessageFilter filter = new ArrivalTimeFilter(startingFrom, period == 0);
            filterManager.add(filter.getName(), filter);
        }
        Integer priority = null;
        if (arguments != null && arguments.containsKey("x-priority")) {
            Object value = arguments.get("x-priority");
            if (value instanceof Number) {
                priority = ((Number) value).intValue();
            } else if (value instanceof String || value instanceof AMQShortString) {
                try {
                    priority = Integer.parseInt(value.toString());
                } catch (NumberFormatException e) {
                // use default vlaue
                }
            }
        }
        for (MessageSource source : sources) {
            source.addConsumer(target, filterManager, AMQMessage.class, AMQShortString.toString(tag), options, priority);
        }
        target.updateNotifyWorkDesired();
    } catch (AccessControlException | MessageSource.ExistingExclusiveConsumer | MessageSource.ExistingConsumerPreventsExclusive | MessageSource.QueueDeleted | AMQInvalidArgumentException | MessageSource.ConsumerAccessRefused e) {
        _tag2SubscriptionTargetMap.remove(tag);
        throw e;
    }
    return tag;
}
Also used : AMQInvalidArgumentException(org.apache.qpid.server.filter.AMQInvalidArgumentException) ConsumerOption(org.apache.qpid.server.consumer.ConsumerOption) MessageSource(org.apache.qpid.server.message.MessageSource) AccessControlException(java.security.AccessControlException) FilterManager(org.apache.qpid.server.filter.FilterManager) AbstractConfiguredObject(org.apache.qpid.server.model.AbstractConfiguredObject) MessageFilter(org.apache.qpid.server.filter.MessageFilter) ArrivalTimeFilter(org.apache.qpid.server.filter.ArrivalTimeFilter)

Example 4 with FilterManager

use of org.apache.qpid.server.filter.FilterManager in project qpid-broker-j by apache.

the class AbstractQueue method addConsumerInternal.

private <T extends ConsumerTarget<T>> QueueConsumerImpl<T> addConsumerInternal(final T target, FilterManager filters, final Class<? extends ServerMessage> messageClass, final String consumerName, EnumSet<ConsumerOption> optionSet, final Integer priority) throws ExistingExclusiveConsumer, ConsumerAccessRefused, ExistingConsumerPreventsExclusive, QueueDeleted {
    if (isDeleted()) {
        throw new QueueDeleted();
    }
    if (hasExclusiveConsumer()) {
        throw new ExistingExclusiveConsumer();
    }
    Object exclusiveOwner = _exclusiveOwner;
    final AMQPSession<?, T> session = target.getSession();
    switch(_exclusive) {
        case CONNECTION:
            if (exclusiveOwner == null) {
                exclusiveOwner = session.getAMQPConnection();
                addExclusivityConstraint(session.getAMQPConnection());
            } else {
                if (exclusiveOwner != session.getAMQPConnection()) {
                    throw new ConsumerAccessRefused();
                }
            }
            break;
        case SESSION:
            if (exclusiveOwner == null) {
                exclusiveOwner = session;
                addExclusivityConstraint(session);
            } else {
                if (exclusiveOwner != session) {
                    throw new ConsumerAccessRefused();
                }
            }
            break;
        case LINK:
            if (getConsumerCount() != 0) {
                throw new ConsumerAccessRefused();
            }
            break;
        case PRINCIPAL:
            Principal currentAuthorizedPrincipal = session.getAMQPConnection().getAuthorizedPrincipal();
            if (exclusiveOwner == null) {
                exclusiveOwner = currentAuthorizedPrincipal;
            } else {
                if (!Objects.equals(((Principal) exclusiveOwner).getName(), currentAuthorizedPrincipal.getName())) {
                    throw new ConsumerAccessRefused();
                }
            }
            break;
        case CONTAINER:
            if (exclusiveOwner == null) {
                exclusiveOwner = session.getAMQPConnection().getRemoteContainerName();
            } else {
                if (!exclusiveOwner.equals(session.getAMQPConnection().getRemoteContainerName())) {
                    throw new ConsumerAccessRefused();
                }
            }
            break;
        case SHARED_SUBSCRIPTION:
            break;
        case NONE:
            break;
        default:
            throw new ServerScopedRuntimeException("Unknown exclusivity policy " + _exclusive);
    }
    boolean exclusive = optionSet.contains(ConsumerOption.EXCLUSIVE);
    boolean isTransient = optionSet.contains(ConsumerOption.TRANSIENT);
    if (_noLocal && !optionSet.contains(ConsumerOption.NO_LOCAL)) {
        optionSet = EnumSet.copyOf(optionSet);
        optionSet.add(ConsumerOption.NO_LOCAL);
    }
    if (exclusive && getConsumerCount() != 0) {
        throw new ExistingConsumerPreventsExclusive();
    }
    if (!_defaultFiltersMap.isEmpty()) {
        if (filters == null) {
            filters = new FilterManager();
        }
        for (Map.Entry<String, Callable<MessageFilter>> filter : _defaultFiltersMap.entrySet()) {
            if (!filters.hasFilter(filter.getKey())) {
                MessageFilter f;
                try {
                    f = filter.getValue().call();
                } catch (Exception e) {
                    if (e instanceof RuntimeException) {
                        throw (RuntimeException) e;
                    } else {
                        // Should never happen
                        throw new ServerScopedRuntimeException(e);
                    }
                }
                filters.add(filter.getKey(), f);
            }
        }
    }
    if (_ensureNondestructiveConsumers) {
        optionSet = EnumSet.copyOf(optionSet);
        optionSet.removeAll(EnumSet.of(ConsumerOption.SEES_REQUEUES, ConsumerOption.ACQUIRES));
    }
    QueueConsumerImpl<T> consumer = new QueueConsumerImpl<>(this, target, consumerName, filters, messageClass, optionSet, priority);
    _exclusiveOwner = exclusiveOwner;
    if (exclusive && !isTransient) {
        _exclusiveSubscriber = consumer;
    }
    QueueContext queueContext;
    if (filters == null || !filters.startAtTail()) {
        queueContext = new QueueContext(getEntries().getHead());
    } else {
        queueContext = new QueueContext(getEntries().getTail());
    }
    consumer.setQueueContext(queueContext);
    _queueConsumerManager.addConsumer(consumer);
    if (consumer.isNotifyWorkDesired()) {
        _activeSubscriberCount.incrementAndGet();
    }
    childAdded(consumer);
    consumer.addChangeListener(_deletedChildListener);
    session.incConsumerCount();
    addChangeListener(new AbstractConfigurationChangeListener() {

        @Override
        public void childRemoved(final ConfiguredObject<?> object, final ConfiguredObject<?> child) {
            if (child.equals(consumer)) {
                session.decConsumerCount();
                removeChangeListener(this);
            }
        }
    });
    return consumer;
}
Also used : Callable(java.util.concurrent.Callable) SelectorParsingException(org.apache.qpid.server.filter.SelectorParsingException) MessageDestinationIsAlternateException(org.apache.qpid.server.virtualhost.MessageDestinationIsAlternateException) ParseException(org.apache.qpid.server.filter.selector.ParseException) VirtualHostUnavailableException(org.apache.qpid.server.virtualhost.VirtualHostUnavailableException) ConnectionScopedRuntimeException(org.apache.qpid.server.util.ConnectionScopedRuntimeException) UnknownAlternateBindingException(org.apache.qpid.server.virtualhost.UnknownAlternateBindingException) MessageDeletedException(org.apache.qpid.server.message.MessageDeletedException) IOException(java.io.IOException) AccessControlException(java.security.AccessControlException) UnsupportedEncodingException(java.io.UnsupportedEncodingException) ServerScopedRuntimeException(org.apache.qpid.server.util.ServerScopedRuntimeException) IllegalConfigurationException(org.apache.qpid.server.configuration.IllegalConfigurationException) ServerScopedRuntimeException(org.apache.qpid.server.util.ServerScopedRuntimeException) FilterManager(org.apache.qpid.server.filter.FilterManager) ConnectionScopedRuntimeException(org.apache.qpid.server.util.ConnectionScopedRuntimeException) ServerScopedRuntimeException(org.apache.qpid.server.util.ServerScopedRuntimeException) MessageFilter(org.apache.qpid.server.filter.MessageFilter) Map(java.util.Map) LinkedHashMap(java.util.LinkedHashMap) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) ConcurrentMap(java.util.concurrent.ConcurrentMap) GenericPrincipal(org.apache.qpid.server.model.preferences.GenericPrincipal) SessionPrincipal(org.apache.qpid.server.connection.SessionPrincipal) Principal(java.security.Principal) AuthenticatedPrincipal(org.apache.qpid.server.security.auth.AuthenticatedPrincipal)

Example 5 with FilterManager

use of org.apache.qpid.server.filter.FilterManager in project qpid-broker-j by apache.

the class FanoutExchangeImpl method doRoute.

@Override
protected <M extends ServerMessage<? extends StorableMessageMetaData>> void doRoute(final M message, final String routingAddress, final InstanceProperties instanceProperties, final RoutingResult<M> result) {
    BindingSet bindingSet = _bindingSet;
    if (!bindingSet._unfilteredDestinations.isEmpty()) {
        for (MessageDestination destination : bindingSet._unfilteredDestinations.keySet()) {
            Set<String> replacementRoutingKeys = new HashSet<>(bindingSet._unfilteredDestinations.get(destination).values());
            replacementRoutingKeys.forEach(replacementRoutingKey -> result.add(destination.route(message, replacementRoutingKey == null ? routingAddress : replacementRoutingKey, instanceProperties)));
        }
    }
    final Map<MessageDestination, Map<BindingIdentifier, FilterManagerReplacementRoutingKeyTuple>> filteredDestinations = bindingSet._filteredDestinations;
    if (!filteredDestinations.isEmpty()) {
        for (Map.Entry<MessageDestination, Map<BindingIdentifier, FilterManagerReplacementRoutingKeyTuple>> entry : filteredDestinations.entrySet()) {
            MessageDestination destination = entry.getKey();
            final Map<BindingIdentifier, FilterManagerReplacementRoutingKeyTuple> bindingMessageFilterMap = entry.getValue();
            for (FilterManagerReplacementRoutingKeyTuple tuple : bindingMessageFilterMap.values()) {
                FilterManager filter = tuple.getFilterManager();
                if (filter.allAllow(Filterable.Factory.newInstance(message, instanceProperties))) {
                    String routingKey = tuple.getReplacementRoutingKey() == null ? routingAddress : tuple.getReplacementRoutingKey();
                    result.add(destination.route(message, routingKey, instanceProperties));
                }
            }
        }
    }
}
Also used : MessageDestination(org.apache.qpid.server.message.MessageDestination) HashMap(java.util.HashMap) Map(java.util.Map) HashSet(java.util.HashSet) FilterManager(org.apache.qpid.server.filter.FilterManager)

Aggregations

FilterManager (org.apache.qpid.server.filter.FilterManager)5 AccessControlException (java.security.AccessControlException)3 Map (java.util.Map)3 ConsumerOption (org.apache.qpid.server.consumer.ConsumerOption)3 MessageFilter (org.apache.qpid.server.filter.MessageFilter)3 MessageSource (org.apache.qpid.server.message.MessageSource)3 HashMap (java.util.HashMap)2 ConcurrentHashMap (java.util.concurrent.ConcurrentHashMap)2 AMQInvalidArgumentException (org.apache.qpid.server.filter.AMQInvalidArgumentException)2 ArrivalTimeFilter (org.apache.qpid.server.filter.ArrivalTimeFilter)2 SelectorParsingException (org.apache.qpid.server.filter.SelectorParsingException)2 ParseException (org.apache.qpid.server.filter.selector.ParseException)2 AbstractConfiguredObject (org.apache.qpid.server.model.AbstractConfiguredObject)2 Queue (org.apache.qpid.server.model.Queue)2 ConnectionScopedRuntimeException (org.apache.qpid.server.util.ConnectionScopedRuntimeException)2 IOException (java.io.IOException)1 UnsupportedEncodingException (java.io.UnsupportedEncodingException)1 Principal (java.security.Principal)1 Collection (java.util.Collection)1 HashSet (java.util.HashSet)1