Example usage for org.springframework.context ApplicationEventPublisherAware interface-usage

List of usage examples for org.springframework.context ApplicationEventPublisherAware interface-usage

Introduction

In this page you can find the example usage for org.springframework.context ApplicationEventPublisherAware interface-usage.

Usage

From source file org.springframework.integration.config.AbstractSimpleMessageHandlerFactoryBean.java

/**
 * Factory bean to create and configure a {@link MessageHandler}.
 *
 * @author Dave Syer
 * @author Oleg Zhurakousky
 * @author Gary Russell

From source file org.springframework.integration.etcd.leader.LeaderInitiator.java

/**
 * Bootstrap leadership {@link Candidate candidates} with etcd. Upon construction, {@link #start}
 * must be invoked to register the candidate for leadership election.
 *
 * @author Venil Noronha
 * @author Patrick Peralta

From source file org.springframework.integration.hazelcast.leader.LeaderInitiator.java

/**
 * Bootstrap leadership {@link org.springframework.integration.leader.Candidate candidates}
 * with Hazelcast. Upon construction, {@link #start} must be invoked to
 * register the candidate for leadership election.
 *
 * @author Patrick Peralta

From source file org.springframework.integration.stomp.AbstractStompSessionManager.java

/**
 * Base {@link StompSessionManager} implementation to manage a single {@link StompSession}
 * over its {@link ListenableFuture} from the target implementation of this class.
 * <p>
 * The connection to the {@link StompSession} is made during {@link #start()}.
 * <p>

From source file org.springframework.integration.support.leader.LockRegistryLeaderInitiator.java

/**
 * Component that initiates leader election based on holding a lock. If the lock has the
 * right properties (global with expiry), there will never be more than one leader, but
 * there may occasionally be no leader for short periods. If the lock has stronger
 * guarantees, and it interrupts the holder's thread when it expires or is stolen, then
 * you can adjust the parameters to reduce the leaderless period to be limited only by

From source file org.springframework.kafka.listener.AbstractMessageListenerContainer.java

/**
 * The base implementation for the {@link MessageListenerContainer}.
 *
 * @param <K> the key type.
 * @param <V> the value type.
 *

From source file org.springframework.messaging.simp.broker.AbstractBrokerMessageHandler.java

/**
 * Abstract base class for a {@link MessageHandler} that broker messages to
 * registered subscribers.
 *
 * @author Rossen Stoyanchev
 * @since 4.0

From source file org.springframework.messaging.simp.handler.AbstractBrokerMessageHandler.java

/**
 *
 * @author Rossen Stoyanchev
 * @since 4.0
 */
public abstract class AbstractBrokerMessageHandler

From source file org.springframework.osgi.service.importer.support.internal.aop.ServiceDynamicInterceptor.java

/**
 * Interceptor adding dynamic behaviour for unary service (..1 cardinality). It will look for a service using the given
 * filter, retrying if the service is down or unavailable. Will dynamically rebound a new service, if one is available
 * with a higher service ranking and the interceptor is non sticky.
 * 
 * <p/> In case no service is available, it will throw an exception.

From source file org.springframework.osgi.service.importer.support.OsgiServiceProxyFactoryBean.java

/**
 * OSGi (single) service importer. This implementation creates a managed OSGi service proxy that handles the OSGi
 * service dynamics. The returned proxy will select only the best matching OSGi service for the configuration criteria.
 * If the select service goes away (at any point in time), the proxy will automatically search for a replacement without
 * the user intervention.
 *