Index

A B C D E F G H I K L M N O P Q R S T U V W X 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

AbstractConfigCreateNode - Class in tigase.pubsub.modules
 
AbstractConfigCreateNode() - Constructor for class tigase.pubsub.modules.AbstractConfigCreateNode
 
AbstractLoadRunner - Class in tigase.pubsub.modules.commands
 
AbstractLoadRunner(long, long) - Constructor for class tigase.pubsub.modules.commands.AbstractLoadRunner
 
AbstractNodeConfig - Class in tigase.pubsub
Common implementation of PubSub node configuration handler.
AbstractNodeConfig(String) - Constructor for class tigase.pubsub.AbstractNodeConfig
 
AbstractNodeConfig(String, AbstractNodeConfig) - Constructor for class tigase.pubsub.AbstractNodeConfig
 
AbstractPubSubModule - Class in tigase.pubsub
Base class for modules of PubSub component.
AbstractPubSubModule() - Constructor for class tigase.pubsub.AbstractPubSubModule
 
AbstractQueuingExecutor - Class in tigase.pubsub.utils.executors
Abstract class providing implementation of executor supporting task queueing and prioritization.
AbstractQueuingExecutor() - Constructor for class tigase.pubsub.utils.executors.AbstractQueuingExecutor
 
AccessModel - Enum Class in tigase.pubsub
 
Activator - Class in tigase.pubsub
 
Activator() - Constructor for class tigase.pubsub.Activator
 
add(String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet
 
add(String) - Method in interface tigase.pubsub.repository.IPubSubRepository.RootCollectionSetIfc
 
add(String, String) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
add(Field) - Method in class tigase.pubsub.AbstractNodeConfig
 
add(BareJID, JID, String) - Method in class tigase.pubsub.repository.PresenceCollectorRepository
 
add(JID, String) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.ServiceEntry
 
addAffiliation(BareJID, Affiliation) - Method in class tigase.pubsub.repository.cached.NodeAffiliations
 
addAffiliation(BareJID, Affiliation) - Method in interface tigase.pubsub.repository.IAffiliations
 
addAffiliation(BareJID, Affiliation) - Method in class tigase.pubsub.repository.NodeAffiliations
 
addFragment(Map<KEY, VALUE>) - Method in class tigase.pubsub.utils.FragmentedMap
 
addJid(BareJID, JID, String) - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
addMAMItem(BareJID, Long, String, Element, String) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
addMAMItem(BareJID, String, String, Element, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
addMAMItem(BareJID, String, String, Element, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
addMAMItem(BareJID, T, String, Element, String) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
addMAMItem(BareJID, T, String, Element, String) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
addPubSubNode(String) - Method in class tigase.pubsub.cluster.ClusterNodeMap
 
addPubSubNode(String[]) - Method in class tigase.pubsub.cluster.ClusterNodeMap
 
addSubscriberJid(BareJID, Subscription) - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
addSubscriberJid(BareJID, Subscription) - Method in class tigase.pubsub.repository.cached.NodeSubscriptions
 
addSubscriberJid(BareJID, Subscription) - Method in interface tigase.pubsub.repository.ISubscriptions
 
addSubscriberJid(BareJID, Subscription) - Method in class tigase.pubsub.repository.NodeSubscriptions
 
addToRootCollection(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
addToRootCollection(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
admins - Variable in class tigase.pubsub.PubSubConfig
 
ADMINS_KEY - Static variable in class tigase.pubsub.PubSubConfig
 
Affiliation - Enum Class in tigase.pubsub
 
affiliationsMerge() - Method in class tigase.pubsub.repository.cached.Node
 
affiliationsNeedsWriting() - Method in class tigase.pubsub.repository.cached.Node
 
affiliationsSaved() - Method in class tigase.pubsub.repository.cached.Node
 
affs - Variable in class tigase.pubsub.repository.NodeAffiliations
 
AMP_XMLNS - Static variable in class tigase.pubsub.modules.PublishItemModule
 
assign(String, String) - Method in class tigase.pubsub.cluster.ClusterNodeMap
 
asString(String...) - Static method in class tigase.pubsub.Utils
 
asStrinTable(Enum<?>[]) - Method in class tigase.pubsub.AbstractNodeConfig
 
authorize - Enum constant in enum class tigase.pubsub.AccessModel
The node owner must approve all subscription requests, and only subscribers may retrieve items from the node.

B

beforeUnregister() - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
beforeUnregister() - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
beforeUnregister() - Method in class tigase.pubsub.modules.PublishItemModule
 
beforeUnregister() - Method in class tigase.pubsub.utils.executors.AbstractQueuingExecutor
 
beforeUnregister() - Method in class tigase.pubsub.utils.executors.RateLimitingExecutor
 
belongsTo(Class<? extends BasicComponent>) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
broadcastNotification(Executor.Priority, BareJID, String, Element) - Method in class tigase.pubsub.modules.PublishItemModule
 
broadcastNotification(Executor.Priority, BareJID, String, Element) - Method in class tigase.pubsub.NotificationBroadcaster
 
BroadcastNotificationEvent(String, BareJID, String, Element) - Constructor for class tigase.pubsub.modules.PublishItemModule.BroadcastNotificationEvent
 
buddyJid - Variable in class tigase.pubsub.modules.PresenceCollectorModule.CapsChangeEvent
 
byCreationDate - Enum constant in enum class tigase.pubsub.CollectionItemsOrdering
 
byUpdateDate - Enum constant in enum class tigase.pubsub.CollectionItemsOrdering
 

C

Cache<K,V> - Interface in tigase.pubsub.utils
 
Cache.CacheException - Exception in tigase.pubsub.utils
 
Cache.CacheSupplier<V> - Interface in tigase.pubsub.utils
 
CachedPubSubRepository<T> - Class in tigase.pubsub.repository.cached
Implementation of IPubSubRepository interface providing access to the database for data storage with caching.
CachedPubSubRepository() - Constructor for class tigase.pubsub.repository.cached.CachedPubSubRepository
 
CachedPubSubRepository.NodeAffiliationProvider<T> - Interface in tigase.pubsub.repository.cached
 
CachedPubSubRepository.NodeKey - Class in tigase.pubsub.repository.cached
 
CachedPubSubRepository.RootCollectionSet - Class in tigase.pubsub.repository.cached
 
CachedPubSubRepository.RootCollectionSet.IllegalStateException - Exception in tigase.pubsub.repository.cached
 
CachedPubSubRepository.RootCollectionSet.State - Enum Class in tigase.pubsub.repository.cached
 
CachedPubSubRepository.SizedCache<V> - Class in tigase.pubsub.repository.cached
 
CacheException(Throwable) - Constructor for exception tigase.pubsub.utils.Cache.CacheException
 
calculateOffsetAndPosition(RSM, int, Integer, Integer) - Static method in class tigase.pubsub.repository.PubSubDAO
 
canHandle(Packet) - Method in class tigase.pubsub.AbstractPubSubModule
 
canHandle(Packet) - Method in class tigase.pubsub.modules.DiscoveryModule
 
canHandle(Packet) - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
canHandle(Packet) - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
CapsChangeEvent(String, BareJID, JID, String, String, Set<String>) - Constructor for class tigase.pubsub.modules.PresenceCollectorModule.CapsChangeEvent
 
CapsModule - Class in tigase.pubsub.modules
Class implements discovery of capabilities using disco#info query and CAPS.
CapsModule() - Constructor for class tigase.pubsub.modules.CapsModule
 
changeAffiliation(BareJID, Affiliation) - Method in class tigase.pubsub.repository.cached.NodeAffiliations
 
changeAffiliation(BareJID, Affiliation) - Method in interface tigase.pubsub.repository.IAffiliations
 
changeAffiliation(BareJID, Affiliation) - Method in class tigase.pubsub.repository.NodeAffiliations
 
changedAffs - Variable in class tigase.pubsub.repository.cached.NodeAffiliations
 
changedSubs - Variable in class tigase.pubsub.repository.cached.NodeSubscriptions
 
changeSubscription(UsersSubscription) - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
changeSubscription(UsersSubscription) - Method in interface tigase.pubsub.repository.cached.ISubscriptionsCached
 
changeSubscription(UsersSubscription) - Method in class tigase.pubsub.repository.cached.NodeSubscriptions
 
changeSubscription(BareJID, Subscription) - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
changeSubscription(BareJID, Subscription) - Method in class tigase.pubsub.repository.cached.NodeSubscriptions
 
changeSubscription(BareJID, Subscription) - Method in interface tigase.pubsub.repository.ISubscriptions
 
changeSubscription(BareJID, Subscription) - Method in class tigase.pubsub.repository.NodeSubscriptions
 
checkNodeConfig(AbstractNodeConfig) - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
checkNodeConfig(AbstractNodeConfig) - Method in interface tigase.pubsub.utils.PubSubLogic
 
checkPermission(BareJID, String, JID, PubSubLogic.Action) - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
checkPermission(BareJID, String, JID, PubSubLogic.Action) - Method in interface tigase.pubsub.utils.PubSubLogic
 
checkPubSubServiceJid(Packet) - Method in class tigase.pubsub.PubSubComponent
Method checks if packet is sent to pubsub@xxx and if so then it returns error as we no longer allow usage of pubsub@xxx address as pubsub service jid since we added support to use PEP and we have multiple domains support with separated nodes.
checkState(CachedPubSubRepository.RootCollectionSet.State) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet
 
childNodeAdded(String) - Method in class tigase.pubsub.repository.cached.Node
 
childNodeRemoved(String) - Method in class tigase.pubsub.repository.cached.Node
 
cleanChangingLog() - Method in class tigase.pubsub.utils.FragmentedMap
 
clear() - Method in class tigase.pubsub.utils.FragmentedMap
 
clone() - Method in class tigase.pubsub.AbstractNodeConfig
 
clone() - Method in class tigase.pubsub.repository.cached.NodeAffiliations
 
clone() - Method in class tigase.pubsub.repository.stateless.UsersAffiliation
 
clone() - Method in class tigase.pubsub.repository.stateless.UsersSubscription
 
CLOSED_NODE - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
ClusterNodeMap - Class in tigase.pubsub.cluster
 
ClusterNodeMap(Set<JID>) - Constructor for class tigase.pubsub.cluster.ClusterNodeMap
 
collection - Enum constant in enum class tigase.pubsub.NodeType
A node that contains nodes and/or other collections but no published items.
CollectionItemsOrdering - Enum Class in tigase.pubsub
 
CollectionNodeConfig - Class in tigase.pubsub
 
CollectionNodeConfig(String) - Constructor for class tigase.pubsub.CollectionNodeConfig
 
Command - Interface in tigase.pubsub.cluster
 
componentName - Variable in class tigase.pubsub.modules.commands.DefaultConfigCommand.DefaultNodeConfigurationChangedEvent
 
componentName - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LoginToNodeEvent
 
componentName - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LogoffFromNodeEvent
 
componentName - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.UpdatePresenceEvent
 
componentName - Variable in class tigase.pubsub.modules.NodeConfigModule.NodeConfigurationChangedEvent
 
componentName - Variable in class tigase.pubsub.modules.NodeCreateModule.NodeCreatedEvent
 
componentName - Variable in class tigase.pubsub.modules.NodeDeleteModule.NodeDeletedEvent
 
componentName - Variable in class tigase.pubsub.modules.PresenceCollectorModule.CapsChangeEvent
 
componentName - Variable in class tigase.pubsub.modules.PresenceCollectorModule.PresenceChangeEvent
 
componentName - Variable in class tigase.pubsub.modules.PublishItemModule.BroadcastNotificationEvent
 
componentName - Variable in class tigase.pubsub.modules.PublishItemModule.ItemPublishedEvent
 
componentName - Variable in class tigase.pubsub.modules.RetractItemModule.ItemRetractedEvent
 
computeIfAbsent(K, Cache.CacheSupplier<V>) - Method in interface tigase.pubsub.utils.Cache
 
computeIfAbsent(K, Cache.CacheSupplier<V>) - Method in class tigase.pubsub.utils.LRUCache
 
computeIfAbsent(K, Cache.CacheSupplier<V>) - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
concurrentQueuesNo() - Method in class tigase.pubsub.PepPlugin
 
config - Variable in class tigase.pubsub.AbstractPubSubModule
 
config - Variable in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
configCopyFrom(AbstractNodeConfig) - Method in class tigase.pubsub.repository.cached.Node
 
configNeedsWriting() - Method in class tigase.pubsub.repository.cached.Node
 
configSaved() - Method in class tigase.pubsub.repository.cached.Node
 
contain(String, String...) - Static method in class tigase.pubsub.Utils
 
containsCapsNode(Predicate<String>) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserResourceEntry
 
copyFrom(AbstractNodeConfig) - Method in class tigase.pubsub.AbstractNodeConfig
 
copyFromForm(Form) - Method in class tigase.pubsub.AbstractNodeConfig
 
countMAMItems(ExtendedQueryImpl, Long) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
create() - Static method in class tigase.pubsub.repository.NodeSubscriptions
 
createAffiliationNotification(JID, JID, String, Affiliation) - Static method in class tigase.pubsub.modules.ManageAffiliationsModule
 
createKey(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
createNode(BareJID, String, BareJID, AbstractNodeConfig, NodeType, Long, boolean) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
createNode(BareJID, String, BareJID, AbstractNodeConfig, NodeType, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
createNode(BareJID, String, BareJID, AbstractNodeConfig, NodeType, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
createNode(BareJID, String, BareJID, AbstractNodeConfig, NodeType, T, boolean) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
createNode(BareJID, String, BareJID, AbstractNodeConfig, NodeType, T, boolean) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
createPresenceNotificationItem(BareJID, String, JID, Packet) - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
createService(BareJID, boolean) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
createService(BareJID, boolean) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
createService(BareJID, boolean) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
createService(BareJID, boolean) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
createService(BareJID, boolean) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
createUID() - Static method in class tigase.pubsub.Utils
 
createUID(Object) - Static method in class tigase.pubsub.Utils
 
critical - Enum constant in enum class tigase.pubsub.utils.executors.RateLimitingExecutor.MemoryUsage
 
currentMemoryUsage() - Method in class tigase.pubsub.utils.executors.RateLimitingExecutor
 

D

dao - Variable in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
DEFAULT_LEAF_NODE_CONFIG_KEY - Static variable in class tigase.pubsub.PubSubComponent
 
DefaultConfigCommand - Class in tigase.pubsub.modules.commands
 
DefaultConfigCommand() - Constructor for class tigase.pubsub.modules.commands.DefaultConfigCommand
 
DefaultConfigCommand.DefaultNodeConfigurationChangedEvent - Class in tigase.pubsub.modules.commands
 
DefaultConfigModule - Class in tigase.pubsub.modules
 
DefaultConfigModule() - Constructor for class tigase.pubsub.modules.DefaultConfigModule
 
defaultNodeConfig - Variable in class tigase.pubsub.modules.AbstractConfigCreateNode
 
defaultNodeConfig - Variable in class tigase.pubsub.modules.DefaultConfigModule
 
defaultNodeConfig - Variable in class tigase.pubsub.PubSubComponent
 
DefaultNodeConfig - Class in tigase.pubsub
Created by andrzej on 10.07.2016.
DefaultNodeConfig() - Constructor for class tigase.pubsub.DefaultNodeConfig
 
DefaultNodeConfigurationChangedEvent(String) - Constructor for class tigase.pubsub.modules.commands.DefaultConfigCommand.DefaultNodeConfigurationChangedEvent
 
DefaultPacketHashCodeGenerator - Class in tigase.pubsub
 
DefaultPacketHashCodeGenerator() - Constructor for class tigase.pubsub.DefaultPacketHashCodeGenerator
 
defaultPepNodeConfig - Variable in class tigase.pubsub.modules.PublishItemModule
 
DefaultPubSubLogic - Class in tigase.pubsub.utils
Helper bean containing PubSub logic
DefaultPubSubLogic() - Constructor for class tigase.pubsub.utils.DefaultPubSubLogic
 
defragment() - Method in class tigase.pubsub.utils.FragmentedMap
 
DeleteAllNodesCommand - Class in tigase.pubsub.modules.commands
Implementation of ad-hoc commands which removes all PubSub nodes.
DeleteAllNodesCommand() - Constructor for class tigase.pubsub.modules.commands.DeleteAllNodesCommand
 
deleteItem(String) - Method in class tigase.pubsub.repository.cached.Items
 
deleteItem(String) - Method in interface tigase.pubsub.repository.IItems
 
deleteItem(BareJID, Long, String) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
deleteItem(BareJID, T, String) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
deleteItem(BareJID, T, String) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
deleteNode(BareJID, Long) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
deleteNode(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
deleteNode(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
deleteNode(BareJID, T) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
deleteNode(BareJID, T) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
deleteService(BareJID) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
deleteService(BareJID) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
deleteService(BareJID) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
deleteService(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
deleteService(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
DELIMITER - Static variable in class tigase.pubsub.repository.NodeAffiliations
 
DELIMITER - Static variable in class tigase.pubsub.repository.NodeSubscriptions
 
dependsOn() - Method in class tigase.pubsub.repository.converter.PubSubItemsConverter
 
descriptions() - Static method in enum class tigase.pubsub.CollectionItemsOrdering
 
descriptions() - Static method in enum class tigase.pubsub.SendLastPublishedItem
 
destroy() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
destroy() - Method in interface tigase.pubsub.repository.IPubSubDAO
 
destroy() - Method in interface tigase.pubsub.repository.IPubSubRepository
 
destroy() - Method in class tigase.pubsub.repository.PubSubDAO
 
destroy() - Method in class tigase.pubsub.repository.PubSubDAOPool
 
diff(String[], String[]) - Static method in class tigase.pubsub.modules.NodeConfigModule
 
DISCO_FEATURES - Static variable in class tigase.pubsub.PepPlugin
 
DISCO_INFO_XMLNS - Static variable in class tigase.pubsub.PepPlugin
 
DISCO_ITEMS_XMLNS - Static variable in class tigase.pubsub.PepPlugin
 
DiscoveryModule - Class in tigase.pubsub.modules
 
DiscoveryModule() - Constructor for class tigase.pubsub.modules.DiscoveryModule
 
doPublishItems(BareJID, String, LeafNodeConfig, String, List<Element>) - Method in class tigase.pubsub.modules.PublishItemModule
 
doWork() - Method in class tigase.pubsub.modules.commands.AbstractLoadRunner
 
doWork() - Method in class tigase.pubsub.modules.commands.LoadTestGenerator
 

E

ELEMENTS - Static variable in class tigase.pubsub.PepPlugin
 
ElementWriter - Interface in tigase.pubsub
 
engineGenerateSeed(int) - Method in class tigase.pubsub.Utils.Spi
 
engineNextBytes(byte[]) - Method in class tigase.pubsub.Utils.Spi
 
engineNextBytes(byte[], int) - Method in class tigase.pubsub.Utils.Spi
 
engineSetSeed(byte[]) - Method in class tigase.pubsub.Utils.Spi
 
ensurePepNode(BareJID, String, BareJID, Element) - Method in class tigase.pubsub.modules.PublishItemModule
 
entriesByService - Variable in class tigase.pubsub.repository.PresenceCollectorRepository
 
equals(Object) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.NodeKey
 
EVENT_XMLNS - Static variable in class tigase.pubsub.PubSubComponent
 
everyHour() - Method in class tigase.pubsub.PubSubComponent
 
everyHour() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
everyHour() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.SizedCache
 
everyHour() - Method in class tigase.pubsub.utils.LRUCache
 
everyHour() - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
everyMinute() - Method in class tigase.pubsub.PubSubComponent
 
everyMinute() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
everyMinute() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.SizedCache
 
everyMinute() - Method in class tigase.pubsub.utils.LRUCache
 
everyMinute() - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
everySecond() - Method in class tigase.pubsub.PubSubComponent
 
everySecond() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
everySecond() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.SizedCache
 
everySecond() - Method in class tigase.pubsub.utils.LRUCache
 
everySecond() - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
execute() - Method in interface tigase.pubsub.cluster.Command
 
execute() - Method in class tigase.pubsub.utils.executors.AbstractQueuingExecutor
Method called by subclass to execute a single task from the queue or wait for any task to appear.
execute(AdhHocRequest, AdHocResponse) - Method in class tigase.pubsub.cluster.ViewNodeLoadCommand
 
execute(AdhHocRequest, AdHocResponse) - Method in class tigase.pubsub.modules.commands.DefaultConfigCommand
 
execute(AdhHocRequest, AdHocResponse) - Method in class tigase.pubsub.modules.commands.DeleteAllNodesCommand
 
execute(AdhHocRequest, AdHocResponse) - Method in class tigase.pubsub.modules.commands.LoadTestCommand
 
execute(AdhHocRequest, AdHocResponse) - Method in class tigase.pubsub.modules.commands.ReadAllNodesCommand
 
execute(AdhHocRequest, AdHocResponse) - Method in class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
ExecutionQueue - Class in tigase.pubsub.utils.executors
Class implements tasks queue with priorities.
ExecutionQueue() - Constructor for class tigase.pubsub.utils.executors.ExecutionQueue
 
Executor - Interface in tigase.pubsub.utils.executors
Executor of submitted tasks with support for task priorities
Executor.Priority - Enum Class in tigase.pubsub.utils.executors
 
expiredUserResourceEntriesStream(long) - Method in class tigase.pubsub.repository.PresenceCollectorRepository
 
ExtendedQueryImpl - Class in tigase.pubsub.modules.mam
 
ExtendedQueryImpl() - Constructor for class tigase.pubsub.modules.mam.ExtendedQueryImpl
 

F

findClassForDataSource(DataSource) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
form - Variable in class tigase.pubsub.AbstractNodeConfig
List with do-not-write elements
FragmentedMap<KEY,VALUE> - Class in tigase.pubsub.utils
 
FragmentedMap(int) - Constructor for class tigase.pubsub.utils.FragmentedMap
 

G

generateItemsNotifications(BareJID, String, List<Element>, String, boolean) - Method in class tigase.pubsub.modules.PublishItemModule
 
generateNodeNotifications(BareJID, String, Element, String, boolean) - Method in class tigase.pubsub.modules.PublishItemModule
 
get() - Method in interface tigase.pubsub.repository.IPubSubRepository.RepositorySupplier
 
get() - Method in interface tigase.pubsub.utils.Cache.CacheSupplier
 
get(Object) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.SizedCache
 
get(K) - Method in interface tigase.pubsub.utils.Cache
 
get(K) - Method in class tigase.pubsub.utils.LRUCache
 
get(K) - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
get(KEY) - Method in class tigase.pubsub.utils.FragmentedMap
 
get(BareJID) - Method in class tigase.pubsub.repository.cached.NodeAffiliations
 
get(BareJID) - Method in class tigase.pubsub.repository.cached.NodeSubscriptions
 
get(BareJID) - Method in class tigase.pubsub.repository.NodeAffiliations
 
get(BareJID) - Method in class tigase.pubsub.repository.NodeSubscriptions
 
get(BareJID) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.ServiceEntry
 
getActiveSubscribers(ISubscriptions, IAffiliations) - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
getAdditionalQueriesToInitialise() - Method in class tigase.pubsub.repository.converter.PubSubItemsConverter
 
getAdditionalQueriesToInitialise() - Method in class tigase.pubsub.repository.converter.PubSubNodeConverter
 
getAdmins() - Method in interface tigase.pubsub.IPubSubConfig
 
getAdmins() - Method in class tigase.pubsub.PubSubConfig
 
getAffiliation() - Method in class tigase.pubsub.repository.stateless.UsersAffiliation
 
getAffiliations() - Method in class tigase.pubsub.repository.cached.NodeAffiliations
 
getAffiliations() - Method in interface tigase.pubsub.repository.IAffiliations
 
getAffiliations() - Method in class tigase.pubsub.repository.NodeAffiliations
 
getAffiliationsMap() - Method in class tigase.pubsub.repository.NodeAffiliations
 
getAllAvailableJids(BareJID) - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
getAllAvailableJids(BareJID, Predicate<String>) - Method in class tigase.pubsub.repository.PresenceCollectorRepository
 
getAllAvailableJidsWithFeature(BareJID, String) - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
getAllAvailableResources(BareJID, BareJID) - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
getAllAvailableResources(BareJID, BareJID) - Method in class tigase.pubsub.repository.PresenceCollectorRepository
 
getAllNodesList(BareJID) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getAllNodesList(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getAllNodesList(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getAllValues() - Method in class tigase.pubsub.utils.FragmentedMap
 
getBodyXslt() - Method in class tigase.pubsub.AbstractNodeConfig
 
getBodyXsltEmbedded() - Method in class tigase.pubsub.AbstractNodeConfig
 
getCaps() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserResourceEntry
 
getChanged() - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
getChanged() - Method in interface tigase.pubsub.repository.cached.IAffiliationsCached
 
getChanged() - Method in interface tigase.pubsub.repository.cached.ISubscriptionsCached
 
getChanged() - Method in class tigase.pubsub.repository.cached.NodeAffiliations
 
getChanged() - Method in class tigase.pubsub.repository.cached.NodeSubscriptions
 
getChangedFragmentIndexes() - Method in class tigase.pubsub.utils.FragmentedMap
 
getChildNodes() - Method in class tigase.pubsub.repository.cached.Node
 
getChildNodes(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getChildNodes(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getChildNodes(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getChildNodes(BareJID, String) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getChildNodes(BareJID, String) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getChildren() - Method in class tigase.pubsub.AbstractNodeConfig
 
getClusterNodeId(String) - Method in class tigase.pubsub.cluster.ClusterNodeMap
 
getClusterNodesLoad() - Method in class tigase.pubsub.cluster.ClusterNodeMap
 
getCode() - Method in exception tigase.pubsub.exceptions.PubSubException
 
getCollection() - Method in class tigase.pubsub.AbstractNodeConfig
 
getCollectionItemsOrdering() - Method in class tigase.pubsub.AbstractNodeConfig
 
getComparator() - Method in enum class tigase.pubsub.CollectionItemsOrdering
 
getComponentJID() - Method in interface tigase.pubsub.IPubSubConfig
 
getComponentJID() - Method in class tigase.pubsub.PubSubConfig
 
getComponentName() - Method in interface tigase.pubsub.IPubSubConfig
 
getComponentName() - Method in class tigase.pubsub.PubSubConfig
 
getComponentVersion() - Method in class tigase.pubsub.PubSubComponent
 
getCounter() - Method in class tigase.pubsub.modules.commands.AbstractLoadRunner
 
getCreationDate() - Method in class tigase.pubsub.repository.IItems.ItemMeta
 
getCreationTime() - Method in class tigase.pubsub.repository.cached.Node
 
getCreationTime() - Method in interface tigase.pubsub.repository.INodeMeta
 
getCreationTime() - Method in class tigase.pubsub.repository.stateless.NodeMeta
 
getCreator() - Method in class tigase.pubsub.repository.cached.Node
 
getCreator() - Method in interface tigase.pubsub.repository.INodeMeta
 
getCreator() - Method in class tigase.pubsub.repository.stateless.NodeMeta
 
getDefaultBeanClass() - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getDelay() - Method in class tigase.pubsub.modules.commands.AbstractLoadRunner
 
getDelayOnLowMemory() - Method in interface tigase.pubsub.IPubSubConfig
 
getDelayOnLowMemory() - Method in class tigase.pubsub.PubSubConfig
 
getDescription() - Method in class tigase.pubsub.AbstractNodeConfig
 
getDiscoCategory() - Method in class tigase.pubsub.PubSubComponent
 
getDiscoCategoryType() - Method in class tigase.pubsub.PubSubComponent
 
getDiscoDescription() - Method in class tigase.pubsub.PubSubComponent
 
getDomains() - Method in class tigase.pubsub.AbstractNodeConfig
 
getElement() - Method in class tigase.pubsub.exceptions.PubSubErrorCondition
 
getEntriesOlderThen(long) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
getErrorCondition() - Method in exception tigase.pubsub.exceptions.PubSubException
 
getEventBus() - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
getFeatures() - Method in class tigase.pubsub.modules.CapsModule
 
getFeatures() - Method in class tigase.pubsub.modules.DefaultConfigModule
 
getFeatures() - Method in class tigase.pubsub.modules.DiscoveryModule
 
getFeatures() - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
getFeatures() - Method in class tigase.pubsub.modules.ManageAffiliationsModule
 
getFeatures() - Method in class tigase.pubsub.modules.ManageSubscriptionModule
 
getFeatures() - Method in class tigase.pubsub.modules.NodeConfigModule
 
getFeatures() - Method in class tigase.pubsub.modules.NodeCreateModule
 
getFeatures() - Method in class tigase.pubsub.modules.NodeDeleteModule
 
getFeatures() - Method in class tigase.pubsub.modules.PendingSubscriptionModule
 
getFeatures() - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
getFeatures() - Method in class tigase.pubsub.modules.PublishItemModule
 
getFeatures() - Method in class tigase.pubsub.modules.PurgeItemsModule
 
getFeatures() - Method in class tigase.pubsub.modules.RetractItemModule
 
getFeatures() - Method in class tigase.pubsub.modules.RetrieveAffiliationsModule
 
getFeatures() - Method in class tigase.pubsub.modules.RetrieveItemsModule
 
getFeatures() - Method in class tigase.pubsub.modules.RetrieveSubscriptionsModule
 
getFeatures() - Method in class tigase.pubsub.modules.SubscribeNodeModule
 
getFeatures() - Method in class tigase.pubsub.modules.UnsubscribeNodeModule
 
getForm() - Method in class tigase.pubsub.AbstractNodeConfig
 
getFormElement() - Method in class tigase.pubsub.AbstractNodeConfig
 
getFragment(int) - Method in class tigase.pubsub.utils.FragmentedMap
 
getFragmentsCount() - Method in class tigase.pubsub.utils.FragmentedMap
 
getFragmentToNewData() - Method in class tigase.pubsub.utils.FragmentedMap
 
getFragmentWithKey(KEY) - Method in class tigase.pubsub.utils.FragmentedMap
 
getId() - Method in interface tigase.pubsub.repository.IItems.IItemBase
 
getId() - Method in class tigase.pubsub.repository.IItems.ItemBase
 
getId() - Method in class tigase.pubsub.repository.PubSubDAO.MAMItem
 
getIdOfJid(Connection, String) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
getInstance(String) - Method in class tigase.pubsub.AbstractNodeConfig
 
getInstance(String) - Method in class tigase.pubsub.CollectionNodeConfig
 
getInstance(String) - Method in class tigase.pubsub.LeafNodeConfig
 
getItem() - Method in exception tigase.pubsub.exceptions.PubSubException
 
getItem() - Method in interface tigase.pubsub.repository.IItems.IItem
 
getItem() - Method in class tigase.pubsub.repository.IItems.Item
 
getItem(String) - Method in class tigase.pubsub.repository.cached.Items
 
getItem(String) - Method in interface tigase.pubsub.repository.IItems
 
getItem(BareJID, Long, String) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getItem(BareJID, T, String) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getItem(BareJID, T, String) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getItems(BareJID, List<Long>, Date, Date, RSM, CollectionItemsOrdering) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getItems(BareJID, List<T>, Date, Date, RSM, CollectionItemsOrdering) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getItems(BareJID, List<T>, Date, Date, RSM, CollectionItemsOrdering) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getItemsIds(CollectionItemsOrdering) - Method in class tigase.pubsub.repository.cached.Items
 
getItemsIds(CollectionItemsOrdering) - Method in interface tigase.pubsub.repository.IItems
 
getItemsIds(BareJID, Long, CollectionItemsOrdering) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getItemsIds(BareJID, T, CollectionItemsOrdering) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getItemsIds(BareJID, T, CollectionItemsOrdering) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getItemsIdsSince(CollectionItemsOrdering, Date) - Method in class tigase.pubsub.repository.cached.Items
 
getItemsIdsSince(CollectionItemsOrdering, Date) - Method in interface tigase.pubsub.repository.IItems
 
getItemsIdsSince(BareJID, Long, CollectionItemsOrdering, Date) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getItemsIdsSince(BareJID, T, CollectionItemsOrdering, Date) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getItemsIdsSince(BareJID, T, CollectionItemsOrdering, Date) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getItemsMeta() - Method in class tigase.pubsub.repository.cached.Items
 
getItemsMeta() - Method in interface tigase.pubsub.repository.IItems
 
getItemsMeta(BareJID, Long, String) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getItemsMeta(BareJID, T, String) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getItemsMeta(BareJID, T, String) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getItemUpdateDate() - Method in class tigase.pubsub.repository.IItems.ItemMeta
 
getJid() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
getJid() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserResourceEntry
 
getJid() - Method in class tigase.pubsub.repository.stateless.UsersAffiliation
 
getJid() - Method in class tigase.pubsub.repository.stateless.UsersSubscription
 
getLastItem(CollectionItemsOrdering) - Method in class tigase.pubsub.repository.cached.Items
 
getLastItem(CollectionItemsOrdering) - Method in interface tigase.pubsub.repository.IItems
 
getLastSeen() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserResourceEntry
 
getLimit() - Method in class tigase.pubsub.utils.executors.RateLimitingExecutor
 
getMainQuery() - Method in class tigase.pubsub.repository.converter.PubSubItemsConverter
 
getMainQuery() - Method in class tigase.pubsub.repository.converter.PubSubNodeConverter
 
getMAMItem(BareJID, Long, String) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getMAMItem(BareJID, String, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getMAMItem(BareJID, String, String) - Method in interface tigase.pubsub.repository.IExtenedMAMPubSubRepository
 
getMAMItem(BareJID, T, String) - Method in interface tigase.pubsub.repository.IExtendedPubSubDAO
 
getMAMItem(BareJID, T, String) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getMAMItemPosition(ExtendedQueryImpl, Long, String) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getMap() - Method in class tigase.pubsub.utils.FragmentedMap
 
getMaxCacheSize() - Method in interface tigase.pubsub.IPubSubConfig
 
getMaxCacheSize() - Method in class tigase.pubsub.PubSubConfig
 
getMaxItems() - Method in class tigase.pubsub.LeafNodeConfig
 
getMessage() - Method in exception tigase.pubsub.exceptions.PubSubException
 
getMessage() - Method in class tigase.pubsub.repository.PubSubDAO.MAMItem
 
getModuleCriteria() - Method in class tigase.pubsub.modules.CapsModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.DefaultConfigModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
getModuleCriteria() - Method in class tigase.pubsub.modules.ManageAffiliationsModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.ManageSubscriptionModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.NodeConfigModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.NodeCreateModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.NodeDeleteModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.PendingSubscriptionModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.PublishItemModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.PurgeItemsModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.RetractItemModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.RetrieveAffiliationsModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.RetrieveItemsModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.RetrieveSubscriptionsModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.SubscribeNodeModule
 
getModuleCriteria() - Method in class tigase.pubsub.modules.UnsubscribeNodeModule
 
getName() - Method in class tigase.pubsub.cluster.ViewNodeLoadCommand
 
getName() - Method in exception tigase.pubsub.exceptions.PubSubException
 
getName() - Method in class tigase.pubsub.modules.commands.DefaultConfigCommand
 
getName() - Method in class tigase.pubsub.modules.commands.DeleteAllNodesCommand
 
getName() - Method in class tigase.pubsub.modules.commands.LoadTestCommand
 
getName() - Method in class tigase.pubsub.modules.commands.ReadAllNodesCommand
 
getName() - Method in class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
getName() - Method in class tigase.pubsub.repository.cached.Node
 
getNewOwnerOfNode(String) - Method in class tigase.pubsub.cluster.ClusterNodeMap
Stupid name, but important method.
getNode() - Method in class tigase.pubsub.cluster.ViewNodeLoadCommand
 
getNode() - Method in class tigase.pubsub.modules.commands.DefaultConfigCommand
 
getNode() - Method in class tigase.pubsub.modules.commands.DeleteAllNodesCommand
 
getNode() - Method in class tigase.pubsub.modules.commands.LoadTestCommand
 
getNode() - Method in class tigase.pubsub.modules.commands.ReadAllNodesCommand
 
getNode() - Method in class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
getNode() - Method in interface tigase.pubsub.repository.IItems.IItemBase
 
getNode() - Method in class tigase.pubsub.repository.IItems.ItemBase
 
getNode(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getNodeAccessModel() - Method in class tigase.pubsub.AbstractNodeConfig
 
getNodeAffiliations() - Method in class tigase.pubsub.repository.cached.Node
 
getNodeAffiliations(BareJID, Long) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getNodeAffiliations(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getNodeAffiliations(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getNodeAffiliations(BareJID, T) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getNodeAffiliations(BareJID, T) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getNodeAndSubnodes(BareJID, String, Predicate<Node<T>>, Predicate<Node<T>>) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getNodeConfig() - Method in class tigase.pubsub.repository.cached.Node
 
getNodeConfig() - Method in interface tigase.pubsub.repository.INodeMeta
 
getNodeConfig() - Method in class tigase.pubsub.repository.stateless.NodeMeta
 
getNodeConfig(Class<T>, String, Form) - Method in class tigase.pubsub.repository.PubSubDAO
 
getNodeConfig(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getNodeConfig(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getNodeFromCache(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getNodeId() - Method in class tigase.pubsub.repository.cached.Node
 
getNodeId() - Method in interface tigase.pubsub.repository.INodeMeta
 
getNodeId() - Method in class tigase.pubsub.repository.stateless.NodeMeta
 
getNodeItems() - Method in class tigase.pubsub.repository.cached.Node
 
getNodeItems(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getNodeItems(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getNodeItems(BareJID, String, JID, Date, Date, RSM) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getNodeItems(BareJID, String, JID, Date, Date, RSM) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getNodeMeta(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getNodeMeta(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getNodeMeta(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getNodeMeta(BareJID, String) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getNodeMeta(BareJID, String) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getNodeName() - Method in class tigase.pubsub.AbstractNodeConfig
 
getNodeOccupants(BareJID, String) - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
getNodes(BareJID, JID) - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
getNodesCount(BareJID) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getNodesCount(BareJID) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getNodesCount(BareJID) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getNodesCount(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getNodesCount(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getNodesList(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getNodesList(BareJID, String) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getNodesList(BareJID, String) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getNodeSubscriptions() - Method in class tigase.pubsub.repository.cached.Node
 
getNodeSubscriptions(BareJID, Long) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getNodeSubscriptions(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getNodeSubscriptions(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getNodeSubscriptions(BareJID, T) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getNodeSubscriptions(BareJID, T) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getNodeType() - Method in class tigase.pubsub.AbstractNodeConfig
 
getNotificationType() - Method in class tigase.pubsub.AbstractNodeConfig
 
getOrMax(int) - Method in class tigase.pubsub.utils.IntegerOrMax
 
getOrMaxGet(IntSupplier) - Method in class tigase.pubsub.utils.IntegerOrMax
 
getOrNull() - Method in class tigase.pubsub.utils.IntegerOrMax
 
getParentBean() - Method in class tigase.pubsub.repository.converter.PubSubItemsConverter
 
getParentBean() - Method in class tigase.pubsub.repository.converter.PubSubNodeConverter
 
getPermissions(long, RateLimitingExecutor.MemoryUsage) - Method in class tigase.pubsub.utils.executors.RateLimitingExecutor
 
getPoolDetails(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOPool
Deprecated.
getPresence(BareJID, String, BareJID) - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
getPresence(BareJID, String, JID) - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
getPresencePerNodeExtension() - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
getPublisherModel() - Method in class tigase.pubsub.AbstractNodeConfig
 
getPubSubConfig() - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
getPubSubDAO() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getPubSubDAO() - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getPubSubErrorCondition() - Method in exception tigase.pubsub.exceptions.PubSubException
 
getPubsubJid(XMPPResourceConnection, JID) - Method in class tigase.pubsub.PepPlugin
 
getPubsubNode() - Method in class tigase.pubsub.modules.mam.ExtendedQueryImpl
 
getPubsubNode() - Method in interface tigase.pubsub.modules.mam.PubSubQuery
 
getPubsubNode() - Method in class tigase.pubsub.modules.mam.Query
 
getRemovedFragmentIndexes() - Method in class tigase.pubsub.utils.FragmentedMap
 
getRepository() - Method in class tigase.pubsub.AbstractPubSubModule
 
getRepository() - Method in class tigase.pubsub.modules.DiscoveryModule
 
getRepository() - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
getResource() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserResourceEntry
 
getResources() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
getRootCollection(BareJID) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getRootCollection(BareJID) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getRootCollectionSet(BareJID) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getRosterGroupsAllowed() - Method in class tigase.pubsub.AbstractNodeConfig
 
getSendLastPublishedItem() - Method in class tigase.pubsub.AbstractNodeConfig
 
getServiceBareJID() - Method in interface tigase.pubsub.IPubSubConfig
 
getServiceBareJID() - Method in class tigase.pubsub.PubSubConfig
 
getServiceEntries() - Method in class tigase.pubsub.repository.PresenceCollectorRepository
 
getServiceJid() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet
 
getServiceJid() - Method in class tigase.pubsub.repository.cached.Node
 
getServiceJid() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.ServiceEntry
 
getServiceJid() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
getServiceJid() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserResourceEntry
 
getServiceProviderComponentJid() - Method in class tigase.pubsub.PepPlugin
 
getServices(BareJID, Boolean) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getServices(BareJID, Boolean) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getServices(BareJID, Boolean) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getServices(BareJID, Boolean) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getServices(BareJID, Boolean) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getSleepTime() - Method in class tigase.pubsub.utils.executors.RateLimitingExecutor
Calculate best sleep time for current limit value.
getStatistics(String, StatisticsList) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getStatistics(String, StatisticsList) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.SizedCache
 
getStatistics(String, StatisticsList) - Method in class tigase.pubsub.utils.LRUCache
 
getStatistics(String, StatisticsList) - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
getStatistics(StatisticsList) - Method in class tigase.pubsub.PubSubComponent
 
getSubid() - Method in class tigase.pubsub.repository.stateless.UsersSubscription
 
getSubscriberAffiliation(BareJID) - Method in interface tigase.pubsub.repository.IAffiliations
 
getSubscriberAffiliation(BareJID) - Method in class tigase.pubsub.repository.NodeAffiliations
 
getSubscription() - Method in class tigase.pubsub.repository.stateless.UsersSubscription
 
getSubscription(BareJID) - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
getSubscription(BareJID) - Method in interface tigase.pubsub.repository.ISubscriptions
 
getSubscription(BareJID) - Method in class tigase.pubsub.repository.NodeSubscriptions
 
getSubscriptionId(BareJID) - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
getSubscriptionId(BareJID) - Method in interface tigase.pubsub.repository.ISubscriptions
 
getSubscriptionId(BareJID) - Method in class tigase.pubsub.repository.NodeSubscriptions
 
getSubscriptions() - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
getSubscriptions() - Method in class tigase.pubsub.repository.cached.NodeSubscriptions
 
getSubscriptions() - Method in interface tigase.pubsub.repository.ISubscriptions
 
getSubscriptions() - Method in class tigase.pubsub.repository.NodeSubscriptions
 
getSubscriptionsForPublish() - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
getSubscriptionsForPublish() - Method in interface tigase.pubsub.repository.ISubscriptions
 
getSubscriptionsForPublish() - Method in class tigase.pubsub.repository.NodeSubscriptions
 
getTestEndTime() - Method in class tigase.pubsub.modules.commands.AbstractLoadRunner
 
getTestStartTime() - Method in class tigase.pubsub.modules.commands.AbstractLoadRunner
 
getTimestamp() - Method in class tigase.pubsub.repository.PubSubDAO.MAMItem
 
getTitle() - Method in class tigase.pubsub.AbstractNodeConfig
 
getType() - Method in exception tigase.pubsub.exceptions.PubSubException
 
getUserAffiliations(BareJID, BareJID) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getUserAffiliations(BareJID, BareJID) - Method in interface tigase.pubsub.repository.cached.CachedPubSubRepository.NodeAffiliationProvider
 
getUserAffiliations(BareJID, BareJID) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getUserAffiliations(BareJID, BareJID) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getUserAffiliations(BareJID, BareJID) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getUserAffiliations(BareJID, BareJID) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getUserEntries() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.ServiceEntry
 
getUserRoster(BareJID) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getUserRoster(BareJID) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getUserRoster(BareJID) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getUserRoster(BareJID) - Method in class tigase.pubsub.repository.PubSubDAO
 
getUserRoster(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getUserSubscriptions(BareJID, BareJID) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
getUserSubscriptions(BareJID, BareJID) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
getUserSubscriptions(BareJID, BareJID) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
getUserSubscriptions(BareJID, BareJID) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
getUserSubscriptions(BareJID, BareJID) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
getUUID() - Method in interface tigase.pubsub.repository.IItems.IItemBase
 
getUUID() - Method in class tigase.pubsub.repository.IItems.ItemBase
 
getValidBuddies(BareJID) - Method in class tigase.pubsub.modules.PublishItemModule
 
getValue() - Method in class tigase.pubsub.utils.IntegerOrMax
 
getVersion() - Static method in class tigase.pubsub.PubSubVersion
 
getWeight() - Method in enum class tigase.pubsub.Affiliation
 
Ghostbuster - Class in tigase.pubsub
 
Ghostbuster() - Constructor for class tigase.pubsub.Ghostbuster
 

H

hasAccessPermission(Node, JID, PubSubLogic.Action) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
hashCode() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.NodeKey
 
hashCodeForPacket(Packet) - Method in class tigase.pubsub.DefaultPacketHashCodeGenerator
 
hashCodeForPacket(Packet) - Method in class tigase.pubsub.PubSubComponent
 
hashCodeForPacket(Packet) - Method in interface tigase.pubsub.PubSubComponent.PacketHashCodeGenerator
 
hasSenderSubscription(BareJID, IAffiliations) - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
hasSenderSubscription(BareJID, IAffiliations) - Method in interface tigase.pubsub.utils.PubSubLogic
 
high - Enum constant in enum class tigase.pubsub.utils.executors.Executor.Priority
 
high - Enum constant in enum class tigase.pubsub.utils.executors.RateLimitingExecutor.MemoryUsage
 

I

IAffiliations - Interface in tigase.pubsub.repository
 
IAffiliationsCached - Interface in tigase.pubsub.repository.cached
 
id() - Method in class tigase.pubsub.PepPlugin
 
IExtendedPubSubDAO<T,S extends tigase.db.DataSource,Q extends PubSubQuery> - Interface in tigase.pubsub.repository
 
IExtenedMAMPubSubRepository - Interface in tigase.pubsub.repository
 
IItems - Interface in tigase.pubsub.repository
 
IItems.IItem - Interface in tigase.pubsub.repository
 
IItems.IItemBase - Interface in tigase.pubsub.repository
 
IItems.IListnener - Interface in tigase.pubsub.repository
 
IItems.Item - Class in tigase.pubsub.repository
 
IItems.ItemBase - Class in tigase.pubsub.repository
 
IItems.ItemMeta - Class in tigase.pubsub.repository
 
IllegalStateException(CachedPubSubRepository.RootCollectionSet.State) - Constructor for exception tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet.IllegalStateException
 
init() - Method in class tigase.pubsub.AbstractNodeConfig
 
init() - Method in class tigase.pubsub.CollectionNodeConfig
 
init() - Method in class tigase.pubsub.LeafNodeConfig
 
init() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
init() - Method in interface tigase.pubsub.repository.IPubSubRepository
 
init(Queue<UsersSubscription>) - Method in class tigase.pubsub.repository.NodeSubscriptions
 
initBindings(Bindings) - Method in class tigase.pubsub.PubSubComponent
 
initialise(Converter.ConverterProperties) - Method in class tigase.pubsub.repository.converter.PubSubItemsConverter
 
initialise(Converter.ConverterProperties) - Method in class tigase.pubsub.repository.converter.PubSubNodeConverter
 
initialize() - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
initialize() - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
initialize() - Method in class tigase.pubsub.modules.PublishItemModule
 
initialize() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
initialize() - Method in class tigase.pubsub.utils.executors.RateLimitingExecutor
 
initialized - Enum constant in enum class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet.State
 
INodeMeta<T> - Interface in tigase.pubsub.repository
Interface for classes holding metadata of PubSub node
IntegerOrMax - Class in tigase.pubsub.utils
 
IntegerOrMax(int) - Constructor for class tigase.pubsub.utils.IntegerOrMax
 
INVALID_JID - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
INVALID_SUBID - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
IPubSubConfig - Interface in tigase.pubsub
 
IPubSubDAO<T,S extends tigase.db.DataSource,Q extends PubSubQuery> - Interface in tigase.pubsub.repository
Interface of database access layer for PubSub component.
IPubSubRepository - Interface in tigase.pubsub.repository
Interface description
IPubSubRepository.IListener - Interface in tigase.pubsub.repository
 
IPubSubRepository.RepositorySupplier<T> - Interface in tigase.pubsub.repository
 
IPubSubRepository.RootCollectionSetIfc - Interface in tigase.pubsub.repository
 
isAdmin(BareJID) - Method in interface tigase.pubsub.IPubSubConfig
 
isAdmin(BareJID) - Method in class tigase.pubsub.PubSubConfig
 
isAdmin(JID) - Method in interface tigase.pubsub.IPubSubConfig
 
isAdmin(JID) - Method in class tigase.pubsub.PubSubConfig
 
isAllowedDomain(BareJID, String...) - Static method in class tigase.pubsub.Utils
 
isAllowedFor(JID) - Method in class tigase.pubsub.cluster.ViewNodeLoadCommand
 
isAllowedFor(JID) - Method in class tigase.pubsub.modules.commands.DefaultConfigCommand
 
isAllowedFor(JID) - Method in class tigase.pubsub.modules.commands.DeleteAllNodesCommand
 
isAllowedFor(JID) - Method in class tigase.pubsub.modules.commands.LoadTestCommand
 
isAllowedFor(JID) - Method in class tigase.pubsub.modules.commands.ReadAllNodesCommand
 
isAllowedFor(JID) - Method in class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
isAllowToViewSubscribers() - Method in class tigase.pubsub.AbstractNodeConfig
 
isAutoSubscribeNodeCreator() - Method in interface tigase.pubsub.IPubSubConfig
 
isAutoSubscribeNodeCreator() - Method in class tigase.pubsub.PubSubConfig
 
isAvailable(BareJID, BareJID) - Method in class tigase.pubsub.repository.PresenceCollectorRepository
 
isAvailable(BareJID, JID) - Method in class tigase.pubsub.repository.PresenceCollectorRepository
 
isAvailableLocally(JID) - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
isChanged() - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
isChanged() - Method in interface tigase.pubsub.repository.cached.IAffiliationsCached
 
isChanged() - Method in interface tigase.pubsub.repository.cached.ISubscriptionsCached
 
isChanged() - Method in class tigase.pubsub.repository.cached.NodeAffiliations
 
isChanged() - Method in class tigase.pubsub.repository.cached.NodeSubscriptions
 
isCollectionSet() - Method in class tigase.pubsub.AbstractNodeConfig
 
isConfigureNode() - Method in enum class tigase.pubsub.Affiliation
 
isDeleted() - Method in class tigase.pubsub.repository.cached.Node
 
isDeleteItem() - Method in enum class tigase.pubsub.Affiliation
 
isDeleteNode() - Method in enum class tigase.pubsub.Affiliation
 
isDeliver_payloads() - Method in class tigase.pubsub.AbstractNodeConfig
 
isDeliverPresenceBased() - Method in class tigase.pubsub.AbstractNodeConfig
 
isDiscoNonAdmin() - Method in class tigase.pubsub.PubSubComponent
 
isEmpty() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
isHighMemoryUsage() - Method in interface tigase.pubsub.IPubSubConfig
 
isHighMemoryUsage() - Method in class tigase.pubsub.PubSubConfig
 
isIn(String, String[]) - Method in class tigase.pubsub.modules.NodeConfigModule
 
isJidAvailable(BareJID, BareJID) - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
isMAMEnabled() - Method in interface tigase.pubsub.IPubSubConfig
 
isMAMEnabled() - Method in class tigase.pubsub.PubSubConfig
 
isMAMEnabled(BareJID, String) - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
isMAMEnabled(BareJID, String) - Method in interface tigase.pubsub.utils.PubSubLogic
 
isMAMEnabledForGenericService() - Method in interface tigase.pubsub.IPubSubConfig
 
isMAMEnabledForGenericService() - Method in class tigase.pubsub.PubSubConfig
 
isMax() - Method in class tigase.pubsub.utils.IntegerOrMax
 
isNotify_config() - Method in class tigase.pubsub.AbstractNodeConfig
 
isOlderThan(long) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserResourceEntry
 
isOverloaded() - Method in class tigase.pubsub.utils.executors.AbstractQueuingExecutor
 
isOverloaded() - Method in interface tigase.pubsub.utils.executors.Executor
Checks if executor is overloaded.
isOverloaded() - Method in class tigase.pubsub.utils.executors.SameThreadExecutor
 
isPEPNodeName(String) - Method in class tigase.pubsub.modules.PublishItemModule
 
isPepPeristent() - Method in interface tigase.pubsub.IPubSubConfig
 
isPepPeristent() - Method in class tigase.pubsub.PubSubConfig
 
isPepRemoveEmptyGeoloc() - Method in interface tigase.pubsub.IPubSubConfig
 
isPepRemoveEmptyGeoloc() - Method in class tigase.pubsub.PubSubConfig
 
isPersistItem() - Method in class tigase.pubsub.LeafNodeConfig
 
isPresenceExpired() - Method in class tigase.pubsub.AbstractNodeConfig
 
isPublishItem() - Method in enum class tigase.pubsub.Affiliation
 
isPurgeNode() - Method in enum class tigase.pubsub.Affiliation
 
isRetrieveItem() - Method in enum class tigase.pubsub.Affiliation
 
isSenderInRosterGroup(BareJID, AbstractNodeConfig, IAffiliations, ISubscriptions) - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
isSenderInRosterGroup(BareJID, AbstractNodeConfig, IAffiliations, ISubscriptions) - Method in interface tigase.pubsub.utils.PubSubLogic
 
isSendLastPublishedItemOnPresence() - Method in interface tigase.pubsub.IPubSubConfig
 
isSendLastPublishedItemOnPresence() - Method in class tigase.pubsub.PubSubConfig
 
isServiceAutoCreated() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
isServiceAutoCreated() - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
isServiceAutoCreated() - Method in interface tigase.pubsub.utils.PubSubLogic
 
isServiceJidPEP(BareJID) - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
isServiceJidPEP(BareJID) - Method in interface tigase.pubsub.utils.PubSubLogic
 
isSubdomain() - Method in class tigase.pubsub.PubSubComponent
 
isSubscribe() - Method in enum class tigase.pubsub.Affiliation
 
isSubscribeByPresenceFilteredNotifications() - Method in interface tigase.pubsub.IPubSubConfig
 
isSubscribeByPresenceFilteredNotifications() - Method in class tigase.pubsub.PubSubConfig
 
isTigaseNotifyChangeSubscriptionAffiliationState() - Method in class tigase.pubsub.AbstractNodeConfig
 
ISubscriptions - Interface in tigase.pubsub.repository
 
ISubscriptionsCached - Interface in tigase.pubsub.repository.cached
 
Item(String, String, String, Element) - Constructor for class tigase.pubsub.repository.IItems.Item
 
ITEM_REQUIRED - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
ItemBase(String, String, String) - Constructor for class tigase.pubsub.repository.IItems.ItemBase
 
itemDataToElement(char[]) - Method in class tigase.pubsub.repository.PubSubDAO
 
itemDataToElement(String) - Method in class tigase.pubsub.repository.PubSubDAO
 
itemDeleted(BareJID, String, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
itemDeleted(BareJID, String, String) - Method in interface tigase.pubsub.repository.IItems.IListnener
 
itemFound(Query, MAMRepository.Item) - Method in class tigase.pubsub.modules.mam.MAMItemHandler
 
ItemMeta(String, String, Date, Date, String) - Constructor for class tigase.pubsub.repository.IItems.ItemMeta
 
ItemPublishedEvent(String, BareJID, String, String, String, List<Element>) - Constructor for class tigase.pubsub.modules.PublishItemModule.ItemPublishedEvent
 
ItemRetractedEvent(String, BareJID, String, Element) - Constructor for class tigase.pubsub.modules.RetractItemModule.ItemRetractedEvent
 
Items<T> - Class in tigase.pubsub.repository.cached
 
Items(T, BareJID, String, IPubSubDAO, IItems.IListnener) - Constructor for class tigase.pubsub.repository.cached.Items
 
itemsToSend - Variable in class tigase.pubsub.modules.PublishItemModule.ItemPublishedEvent
 
itemWritten(BareJID, String, String, String, Element, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
itemWritten(BareJID, String, String, String, Element, String) - Method in interface tigase.pubsub.repository.IItems.IListnener
 

K

keySet() - Method in interface tigase.pubsub.utils.Cache
 
keySet() - Method in class tigase.pubsub.utils.LRUCache
 
keySet() - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 

L

leaf - Enum constant in enum class tigase.pubsub.NodeType
A node that contains published items only.
LeafNodeConfig - Class in tigase.pubsub
 
LeafNodeConfig(String) - Constructor for class tigase.pubsub.LeafNodeConfig
 
LeafNodeConfig(String, AbstractNodeConfig) - Constructor for class tigase.pubsub.LeafNodeConfig
 
ListCache<K,V> - Class in tigase.pubsub
 
ListCache(int, long) - Constructor for class tigase.pubsub.ListCache
 
loading - Enum constant in enum class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet.State
 
loadNode(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
loadRootCollections(CachedPubSubRepository.RootCollectionSet) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
LoadTestCommand - Class in tigase.pubsub.modules.commands
 
LoadTestCommand() - Constructor for class tigase.pubsub.modules.commands.LoadTestCommand
 
LoadTestGenerator - Class in tigase.pubsub.modules.commands
 
LoadTestGenerator(AbstractMessageReceiver, BareJID, String, BareJID, long, long, int, boolean) - Constructor for class tigase.pubsub.modules.commands.LoadTestGenerator
 
log - Static variable in class tigase.pubsub.AbstractPubSubModule
 
log - Static variable in class tigase.pubsub.cluster.ViewNodeLoadCommand
 
log - Variable in class tigase.pubsub.modules.commands.AbstractLoadRunner
 
log - Variable in class tigase.pubsub.modules.commands.DefaultConfigCommand
 
log - Variable in class tigase.pubsub.modules.commands.LoadTestCommand
 
log - Variable in class tigase.pubsub.modules.commands.LoadTestGenerator
 
log - Static variable in class tigase.pubsub.modules.commands.ReadAllNodesCommand
 
log - Static variable in class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
log - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
log - Variable in class tigase.pubsub.PubSubConfig
 
log - Static variable in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
log - Static variable in class tigase.pubsub.repository.cached.NodeSubscriptions
 
log - Static variable in class tigase.pubsub.repository.NodeSubscriptions
 
log - Static variable in class tigase.pubsub.repository.PubSubDAO
 
log - Static variable in class tigase.pubsub.Utils
 
LoginToNodeEvent(String, BareJID, String, Packet) - Constructor for class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LoginToNodeEvent
 
LogoffFromNodeEvent(String, BareJID, String, JID, Packet) - Constructor for class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LogoffFromNodeEvent
 
longToTime(long) - Static method in class tigase.pubsub.Utils
 
low - Enum constant in enum class tigase.pubsub.utils.executors.Executor.Priority
 
LRUCache<K,V> - Class in tigase.pubsub.utils
This class is implementation of Cache interface.
LRUCache() - Constructor for class tigase.pubsub.utils.LRUCache
 
LRUCache(int) - Constructor for class tigase.pubsub.utils.LRUCache
 
LRUCacheWithFuture<K,V> - Class in tigase.pubsub.utils
This class is implementation of Cache interface.
LRUCacheWithFuture() - Constructor for class tigase.pubsub.utils.LRUCacheWithFuture
 
LRUCacheWithFuture(int) - Constructor for class tigase.pubsub.utils.LRUCacheWithFuture
 

M

main(String[]) - Static method in class tigase.pubsub.modules.PublishItemModule
 
main(String[]) - Static method in class tigase.pubsub.utils.FragmentedMap
 
main(String[]) - Static method in class tigase.pubsub.Utils
 
makeArray(Packet...) - Static method in class tigase.pubsub.AbstractPubSubModule
 
makeArray(Element...) - Static method in class tigase.pubsub.AbstractPubSubModule
 
makeElement() - Method in exception tigase.pubsub.exceptions.PubSubException
 
makeElement(boolean) - Method in exception tigase.pubsub.exceptions.PubSubException
 
makeElement(Element) - Method in exception tigase.pubsub.exceptions.PubSubException
 
makeErrorElement() - Method in exception tigase.pubsub.exceptions.PubSubException
 
makeSubscription(String, BareJID, Subscription, String) - Static method in class tigase.pubsub.modules.SubscribeNodeModule
 
MAMItem(String, Date, Element) - Constructor for class tigase.pubsub.repository.PubSubDAO.MAMItem
 
MAMItemHandler - Class in tigase.pubsub.modules.mam
Created by andrzej on 25.12.2016.
MAMItemHandler() - Constructor for class tigase.pubsub.modules.mam.MAMItemHandler
 
MAMQueryModule - Class in tigase.pubsub.modules.mam
Created by andrzej on 28.12.2016.
MAMQueryModule() - Constructor for class tigase.pubsub.modules.mam.MAMQueryModule
 
MAMQueryParser - Class in tigase.pubsub.modules.mam
Created by andrzej on 22.12.2016.
MAMQueryParser() - Constructor for class tigase.pubsub.modules.mam.MAMQueryParser
 
ManageAffiliationsModule - Class in tigase.pubsub.modules
 
ManageAffiliationsModule() - Constructor for class tigase.pubsub.modules.ManageAffiliationsModule
 
manageNode - Enum constant in enum class tigase.pubsub.utils.PubSubLogic.Action
 
ManageSubscriptionModule - Class in tigase.pubsub.modules
Implementation of subscription management module for PubSub component.
ManageSubscriptionModule() - Constructor for class tigase.pubsub.modules.ManageSubscriptionModule
 
mapEntries(Function<PresenceCollectorRepository.UserResourceEntry, T>, Predicate<PresenceCollectorRepository.UserResourceEntry>) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
markAsGone(PresenceCollectorRepository.UserResourceEntry, Authorization) - Method in class tigase.pubsub.Ghostbuster
 
markAsSeen() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserResourceEntry
 
markAsSeen(PresenceCollectorRepository.UserResourceEntry) - Method in class tigase.pubsub.Ghostbuster
 
markAsSeen(PresenceCollectorRepository.UserResourceEntry) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
matches(String) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserResourceEntry
 
MAX - Static variable in class tigase.pubsub.utils.IntegerOrMax
 
MAX_CACHE_SIZE - Static variable in class tigase.pubsub.PubSubConfig
 
maxRepositoryCacheSize - Variable in class tigase.pubsub.PubSubComponent
 
member - Enum constant in enum class tigase.pubsub.Affiliation
 
merge() - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
merge() - Method in interface tigase.pubsub.repository.cached.IAffiliationsCached
 
merge() - Method in interface tigase.pubsub.repository.cached.ISubscriptionsCached
 
merge() - Method in class tigase.pubsub.repository.cached.NodeAffiliations
 
merge() - Method in class tigase.pubsub.repository.cached.NodeSubscriptions
 

N

needsWriting() - Method in class tigase.pubsub.repository.cached.Node
 
never - Enum constant in enum class tigase.pubsub.SendLastPublishedItem
Never
newCaps - Variable in class tigase.pubsub.modules.PresenceCollectorModule.CapsChangeEvent
 
newFeatures - Variable in class tigase.pubsub.modules.PresenceCollectorModule.CapsChangeEvent
 
newNodeAffiliations(BareJID, String, T, IPubSubRepository.RepositorySupplier<Map<BareJID, UsersAffiliation>>) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
newNodeAffiliations(BareJID, String, T, IPubSubRepository.RepositorySupplier<Map<BareJID, UsersAffiliation>>) - Method in interface tigase.pubsub.repository.cached.CachedPubSubRepository.NodeAffiliationProvider
 
newNodeSubscriptions(BareJID, String, T, IPubSubRepository.RepositorySupplier<Map<BareJID, UsersSubscription>>) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
newQuery() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
newQuery() - Method in interface tigase.pubsub.repository.IPubSubDAO
Deprecated.
newQuery(BareJID) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
newQuery(BareJID) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
newQuery(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
newQuery(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
node - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LoginToNodeEvent
 
node - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LogoffFromNodeEvent
 
node - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.UpdatePresenceEvent
 
node - Variable in class tigase.pubsub.modules.NodeConfigModule.NodeConfigurationChangedEvent
 
node - Variable in class tigase.pubsub.modules.NodeCreateModule.NodeCreatedEvent
 
node - Variable in class tigase.pubsub.modules.NodeDeleteModule.NodeDeletedEvent
 
node - Variable in class tigase.pubsub.modules.PublishItemModule.BroadcastNotificationEvent
 
node - Variable in class tigase.pubsub.modules.PublishItemModule.ItemPublishedEvent
 
node - Variable in class tigase.pubsub.modules.RetractItemModule.ItemRetractedEvent
 
node - Variable in class tigase.pubsub.repository.cached.CachedPubSubRepository.NodeKey
 
Node<T> - Class in tigase.pubsub.repository.cached
 
Node(T, BareJID, AbstractNodeConfig, IAffiliationsCached, ISubscriptionsCached, IItems, BareJID, Date) - Constructor for class tigase.pubsub.repository.cached.Node
 
NODE_REQUIRED - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
NodeAffiliations - Class in tigase.pubsub.repository.cached
 
NodeAffiliations - Class in tigase.pubsub.repository
 
NodeAffiliations() - Constructor for class tigase.pubsub.repository.cached.NodeAffiliations
 
NodeAffiliations() - Constructor for class tigase.pubsub.repository.NodeAffiliations
 
NodeAffiliations(Map<BareJID, UsersAffiliation>) - Constructor for class tigase.pubsub.repository.cached.NodeAffiliations
 
NodeAffiliations(Map<BareJID, UsersAffiliation>) - Constructor for class tigase.pubsub.repository.NodeAffiliations
 
nodeCollectionChanged(BareJID, String, String, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
NodeConfigModule - Class in tigase.pubsub.modules
 
NodeConfigModule() - Constructor for class tigase.pubsub.modules.NodeConfigModule
 
NodeConfigModule.NodeConfigurationChangedEvent - Class in tigase.pubsub.modules
 
NodeConfigurationChangedEvent(String, BareJID, String) - Constructor for class tigase.pubsub.modules.NodeConfigModule.NodeConfigurationChangedEvent
 
NodeCreatedEvent(String, BareJID, String) - Constructor for class tigase.pubsub.modules.NodeCreateModule.NodeCreatedEvent
 
NodeCreateModule - Class in tigase.pubsub.modules
Case 8.1.2
NodeCreateModule() - Constructor for class tigase.pubsub.modules.NodeCreateModule
 
NodeCreateModule.NodeCreatedEvent - Class in tigase.pubsub.modules
 
NodeDeletedEvent(String, BareJID, String) - Constructor for class tigase.pubsub.modules.NodeDeleteModule.NodeDeletedEvent
 
NodeDeleteModule - Class in tigase.pubsub.modules
 
NodeDeleteModule() - Constructor for class tigase.pubsub.modules.NodeDeleteModule
 
NodeDeleteModule.NodeDeletedEvent - Class in tigase.pubsub.modules
 
NODEID_REQUIRED - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
NodeKey(BareJID, String) - Constructor for class tigase.pubsub.repository.cached.CachedPubSubRepository.NodeKey
 
NodeMeta<T> - Class in tigase.pubsub.repository.stateless
Class implements INodeMeta interfaces and holds PubSub node metadata
NodeMeta(T, AbstractNodeConfig, BareJID, Date) - Constructor for class tigase.pubsub.repository.stateless.NodeMeta
 
nodes - Variable in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
nodesCount - Variable in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
NodeSubscriptions - Class in tigase.pubsub.repository.cached
 
NodeSubscriptions - Class in tigase.pubsub.repository
Implementation of PubSub node subscription handling.
NodeSubscriptions() - Constructor for class tigase.pubsub.repository.cached.NodeSubscriptions
 
NodeSubscriptions() - Constructor for class tigase.pubsub.repository.NodeSubscriptions
 
NodeSubscriptions(Map<BareJID, UsersSubscription>) - Constructor for class tigase.pubsub.repository.cached.NodeSubscriptions
 
NodeSubscriptions(Map<BareJID, UsersSubscription>) - Constructor for class tigase.pubsub.repository.NodeSubscriptions
 
NodeType - Enum Class in tigase.pubsub
 
none - Enum constant in enum class tigase.pubsub.Affiliation
 
none - Enum constant in enum class tigase.pubsub.Subscription
The node MUST NOT send event notifications or payloads to the Entity.
normal - Enum constant in enum class tigase.pubsub.utils.executors.Executor.Priority
 
normal - Enum constant in enum class tigase.pubsub.utils.executors.RateLimitingExecutor.MemoryUsage
 
NOT_IN_ROSTER_GROUP - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
NOT_SUBSCRIBED - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
notification - Variable in class tigase.pubsub.modules.RetractItemModule.ItemRetractedEvent
 
NotificationBroadcaster - Class in tigase.pubsub
 
NotificationBroadcaster() - Constructor for class tigase.pubsub.NotificationBroadcaster
 
notificationMessage - Variable in class tigase.pubsub.modules.PublishItemModule.BroadcastNotificationEvent
 

O

occupantJID - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LoginToNodeEvent
 
occupantJID - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LogoffFromNodeEvent
 
occupantJID - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.UpdatePresenceEvent
 
offer(Executor.Priority, Runnable) - Method in class tigase.pubsub.utils.executors.ExecutionQueue
 
offerDao(PubSubDAOJDBC.HashCode) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
offerDao(BareJID, IPubSubDAO) - Method in class tigase.pubsub.repository.PubSubDAOPool
Deprecated.
oldCaps - Variable in class tigase.pubsub.modules.PresenceCollectorModule.CapsChangeEvent
 
on_sub - Enum constant in enum class tigase.pubsub.SendLastPublishedItem
When a new subscription is processed
on_sub_and_presence - Enum constant in enum class tigase.pubsub.SendLastPublishedItem
When a new subscription is processed and whenever a subscriber comes online
onCapsChange(PresenceCollectorModule.CapsChangeEvent) - Method in class tigase.pubsub.modules.PublishItemModule
 
onChangeDefaultNodeConfig(DefaultConfigCommand.DefaultNodeConfigurationChangedEvent) - Method in class tigase.pubsub.PubSubComponent
 
onLoginToNode(PresencePerNodeExtension.LoginToNodeEvent) - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
onLoginToNode(BareJID, String, JID, Packet) - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
onLogoffFromNode(BareJID, String, JID, Packet) - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
onLogoffFromNodeH(PresencePerNodeExtension.LogoffFromNodeEvent) - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
onPresenceChangeEvent(PresenceCollectorModule.PresenceChangeEvent) - Method in class tigase.pubsub.modules.PublishItemModule
 
onPresenceUpdate(BareJID, String, JID, Packet) - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
onTestFinish() - Method in class tigase.pubsub.modules.commands.AbstractLoadRunner
 
onUpdatePresence(PresencePerNodeExtension.UpdatePresenceEvent) - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
onUserRemoved(UserRepository.UserRemovedEvent) - Method in class tigase.pubsub.PubSubComponent
 
open - Enum constant in enum class tigase.pubsub.AccessModel
Any entity may subscribe to the node (i.e., without the necessity for subscription approval) and any entity may retrieve items from the node (i.e., without being subscribed); this SHOULD be the default access model for generic pubsub services.
open - Enum constant in enum class tigase.pubsub.PublisherModel
 
outcast - Enum constant in enum class tigase.pubsub.Affiliation
An entity that is disallowed from subscribing or publishing to a node.
owner - Enum constant in enum class tigase.pubsub.Affiliation
The manager of a node, of which there may be more than one; often but not necessarily the node creator.

P

packet - Variable in class tigase.pubsub.modules.PresenceCollectorModule.PresenceChangeEvent
 
packetWriter - Variable in class tigase.pubsub.AbstractPubSubModule
 
parseConf(AbstractNodeConfig, Element, IPubSubConfig) - Static method in class tigase.pubsub.modules.NodeConfigModule
 
parseConfig(String, String) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
parseConfig(String, String) - Method in class tigase.pubsub.repository.PubSubDAO
 
parseConfig(String, String) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
parseConfigForm(String) - Method in class tigase.pubsub.repository.PubSubDAO
 
parseQuery(PubSubQuery, Packet) - Method in class tigase.pubsub.modules.mam.MAMQueryParser
 
parseQueryForNode(Packet) - Method in class tigase.pubsub.modules.mam.MAMQueryParser
 
pending - Enum constant in enum class tigase.pubsub.Subscription
An entity has requested to subscribe to a node and the request has not yet been approved by a node owner.
PENDING_SUBSCRIPTION - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
PendingSubscriptionModule - Class in tigase.pubsub.modules
 
PendingSubscriptionModule() - Constructor for class tigase.pubsub.modules.PendingSubscriptionModule
 
pepNodes - Variable in class tigase.pubsub.modules.PublishItemModule
 
PepPlugin - Class in tigase.pubsub
Implements PubSub support for every local user account on it's bare jid using local version of PubSub component.
PepPlugin() - Constructor for class tigase.pubsub.PepPlugin
 
ping(PresenceCollectorRepository.UserResourceEntry) - Method in class tigase.pubsub.Ghostbuster
 
PRECONDITION_NOT_MET - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
prefilterNodesWithRSM(String[], RSM) - Method in class tigase.pubsub.modules.DiscoveryModule
 
prepareDiscoInfoResponse(Packet, JID, String, JID) - Method in class tigase.pubsub.modules.DiscoveryModule
 
prepareDiscoItems(JID, String, JID, RSM) - Method in class tigase.pubsub.modules.DiscoveryModule
 
prepareNotificationMessage(JID, String, String, String, Element, String, Map<String, String>, StanzaType) - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
prepareNotificationMessage(JID, String, String, String, Element, String, Map<String, String>, StanzaType) - Method in interface tigase.pubsub.utils.PubSubLogic
 
prepareSender(BareJID, String) - Method in class tigase.pubsub.NotificationBroadcaster
 
presence - Enum constant in enum class tigase.pubsub.AccessModel
Any entity with a subscription of type "from" or "both" may subscribe to the node and retrieve items from the node; this access model applies mainly to instant messaging systems (see RFC 3921).
PRESENCE_SUBSCRIPTION_REQUIRED - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
PresenceChangeEvent(String, Packet) - Constructor for class tigase.pubsub.modules.PresenceCollectorModule.PresenceChangeEvent
 
PresenceCollectorModule - Class in tigase.pubsub.modules
 
PresenceCollectorModule() - Constructor for class tigase.pubsub.modules.PresenceCollectorModule
 
PresenceCollectorModule.CapsChangeEvent - Class in tigase.pubsub.modules
 
PresenceCollectorModule.PresenceChangeEvent - Class in tigase.pubsub.modules
 
PresenceCollectorRepository - Class in tigase.pubsub.repository
 
PresenceCollectorRepository() - Constructor for class tigase.pubsub.repository.PresenceCollectorRepository
 
PresenceCollectorRepository.ServiceEntry - Class in tigase.pubsub.repository
 
PresenceCollectorRepository.UserEntry - Class in tigase.pubsub.repository
 
PresenceCollectorRepository.UserResourceEntry - Class in tigase.pubsub.repository
 
PresenceNodeSubscriptions - Class in tigase.pubsub.modules.ext.presence
 
PresenceNodeSubscriptions(BareJID, String, ISubscriptionsCached, PresencePerNodeExtension) - Constructor for class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
PresenceNotifierModule - Class in tigase.pubsub.modules.ext.presence
 
PresenceNotifierModule() - Constructor for class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
PresencePerNodeExtension - Class in tigase.pubsub.modules.ext.presence
 
PresencePerNodeExtension() - Constructor for class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
PresencePerNodeExtension.LoginToNodeEvent - Class in tigase.pubsub.modules.ext.presence
 
PresencePerNodeExtension.LogoffFromNodeEvent - Class in tigase.pubsub.modules.ext.presence
 
PresencePerNodeExtension.UpdatePresenceEvent - Class in tigase.pubsub.modules.ext.presence
 
presenceStanza - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LoginToNodeEvent
 
presenceStanza - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LogoffFromNodeEvent
 
presenceStanza - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.UpdatePresenceEvent
 
process(Packet) - Method in class tigase.pubsub.modules.CapsModule
 
process(Packet) - Method in class tigase.pubsub.modules.DefaultConfigModule
 
process(Packet) - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
process(Packet) - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
process(Packet) - Method in class tigase.pubsub.modules.ManageAffiliationsModule
 
process(Packet) - Method in class tigase.pubsub.modules.ManageSubscriptionModule
 
process(Packet) - Method in class tigase.pubsub.modules.NodeConfigModule
 
process(Packet) - Method in class tigase.pubsub.modules.NodeCreateModule
 
process(Packet) - Method in class tigase.pubsub.modules.NodeDeleteModule
 
process(Packet) - Method in class tigase.pubsub.modules.PendingSubscriptionModule
 
process(Packet) - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
process(Packet) - Method in class tigase.pubsub.modules.PublishItemModule
 
process(Packet) - Method in class tigase.pubsub.modules.PurgeItemsModule
 
process(Packet) - Method in class tigase.pubsub.modules.RetractItemModule
 
process(Packet) - Method in class tigase.pubsub.modules.RetrieveAffiliationsModule
 
process(Packet) - Method in class tigase.pubsub.modules.RetrieveItemsModule
 
process(Packet) - Method in class tigase.pubsub.modules.RetrieveSubscriptionsModule
 
process(Packet) - Method in class tigase.pubsub.modules.SubscribeNodeModule
 
process(Packet) - Method in class tigase.pubsub.modules.UnsubscribeNodeModule
 
process(Packet, XMPPResourceConnection, NonAuthUserRepository, Queue<Packet>, Map<String, Object>) - Method in class tigase.pubsub.PepPlugin
 
processDiscoInfo(Packet, JID, String, JID) - Method in class tigase.pubsub.modules.DiscoveryModule
 
processingInThreads() - Method in class tigase.pubsub.PubSubComponent
 
processingOutThreads() - Method in class tigase.pubsub.PubSubComponent
 
processIq(Packet, XMPPResourceConnection, Queue<Packet>) - Method in class tigase.pubsub.PepPlugin
 
processJabberIqPrivateToPubSubConversion(Packet, Element, XMPPResourceConnection, Consumer<Packet>) - Method in class tigase.pubsub.PepPlugin
 
processPacket(Packet) - Method in class tigase.pubsub.PubSubComponent
 
processPresence(Packet) - Method in class tigase.pubsub.modules.CapsModule
Processes presence packet and send disco#info queries when needed
processPresence(Packet, XMPPResourceConnection, Queue<Packet>) - Method in class tigase.pubsub.PepPlugin
 
processResultSet(ResultSet) - Method in class tigase.pubsub.repository.converter.PubSubItemsConverter
 
processResultSet(ResultSet) - Method in class tigase.pubsub.repository.converter.PubSubNodeConverter
 
processScriptCommand(Packet, Queue<Packet>) - Method in class tigase.pubsub.PubSubComponent
 
publish(BareJID, String, Element) - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
publish_only - Enum constant in enum class tigase.pubsub.Affiliation
An entity that is allowed to publish items to a node.
publisher - Enum constant in enum class tigase.pubsub.Affiliation
An entity that is allowed to publish items to a node.
publisher - Variable in class tigase.pubsub.modules.PublishItemModule.ItemPublishedEvent
 
PublisherModel - Enum Class in tigase.pubsub
 
publishers - Enum constant in enum class tigase.pubsub.PublisherModel
 
PublishItemModule - Class in tigase.pubsub.modules
Implementation of the PubSub component module responsible for publication of new entries on the pubsub nodes.
PublishItemModule() - Constructor for class tigase.pubsub.modules.PublishItemModule
 
PublishItemModule.BroadcastNotificationEvent - Class in tigase.pubsub.modules
 
PublishItemModule.ItemPublishedEvent - Class in tigase.pubsub.modules
 
publishItems - Enum constant in enum class tigase.pubsub.utils.PubSubLogic.Action
 
publishItems(BareJID, String, JID, List<Element>, Element) - Method in class tigase.pubsub.modules.PublishItemModule
 
publishLastItem(BareJID, String, JID) - Method in class tigase.pubsub.modules.PublishItemModule
 
publishLastItem(BareJID, AbstractNodeConfig, JID) - Method in class tigase.pubsub.modules.PublishItemModule
 
publishToOne(BareJID, String, JID) - Method in class tigase.pubsub.modules.ext.presence.PresenceNotifierModule
 
PUBSUB - Static variable in class tigase.pubsub.AbstractNodeConfig
 
PUBSUB_FEATURE_METADATA - Static variable in class tigase.pubsub.modules.DiscoveryModule
 
PUBSUB_SCHEMA_ID - Static variable in class tigase.pubsub.repository.Schema
 
PUBSUB_SCHEMA_NAME - Static variable in class tigase.pubsub.repository.Schema
 
PUBSUB_XMLNS - Static variable in class tigase.pubsub.PepPlugin
 
PUBSUB_XMLNS_OWNER - Static variable in class tigase.pubsub.PepPlugin
 
PubSubComponent - Class in tigase.pubsub
Class description
PubSubComponent() - Constructor for class tigase.pubsub.PubSubComponent
 
PubSubComponent.PacketHashCodeGenerator - Interface in tigase.pubsub
 
PubSubConfig - Class in tigase.pubsub
Class contains basic configuration of PubSub component used by component modules.
PubSubConfig() - Constructor for class tigase.pubsub.PubSubConfig
 
PubSubDAO<T,S extends tigase.db.DataSource,Q extends PubSubQuery> - Class in tigase.pubsub.repository
 
PubSubDAO() - Constructor for class tigase.pubsub.repository.PubSubDAO
 
PubSubDAO.MAMItem - Class in tigase.pubsub.repository
 
PubSubDAOConfigBean() - Constructor for class tigase.pubsub.repository.PubSubDAOPool.PubSubDAOConfigBean
 
PubSubDAOJDBC - Class in tigase.pubsub.repository
 
PubSubDAOJDBC() - Constructor for class tigase.pubsub.repository.PubSubDAOJDBC
 
PubSubDAOPool<T,S extends tigase.db.DataSource,Q extends PubSubQuery> - Class in tigase.pubsub.repository
 
PubSubDAOPool() - Constructor for class tigase.pubsub.repository.PubSubDAOPool
 
PubSubDAOPool.PubSubDAOConfigBean - Class in tigase.pubsub.repository
 
PubSubErrorCondition - Class in tigase.pubsub.exceptions
 
PubSubErrorCondition(String) - Constructor for class tigase.pubsub.exceptions.PubSubErrorCondition
 
PubSubErrorCondition(String, String) - Constructor for class tigase.pubsub.exceptions.PubSubErrorCondition
 
PubSubException - Exception in tigase.pubsub.exceptions
Created: 2007-05-25 11:55:48
PubSubException(Element, Authorization) - Constructor for exception tigase.pubsub.exceptions.PubSubException
 
PubSubException(Element, Authorization, String) - Constructor for exception tigase.pubsub.exceptions.PubSubException
 
PubSubException(Element, Authorization, String, Exception) - Constructor for exception tigase.pubsub.exceptions.PubSubException
 
PubSubException(Element, Authorization, PubSubErrorCondition) - Constructor for exception tigase.pubsub.exceptions.PubSubException
 
PubSubException(Authorization) - Constructor for exception tigase.pubsub.exceptions.PubSubException
 
PubSubException(Authorization, String) - Constructor for exception tigase.pubsub.exceptions.PubSubException
 
PubSubException(Authorization, String, Exception) - Constructor for exception tigase.pubsub.exceptions.PubSubException
 
PubSubException(Authorization, PubSubErrorCondition) - Constructor for exception tigase.pubsub.exceptions.PubSubException
 
PubSubException(Authorization, PubSubErrorCondition, String) - Constructor for exception tigase.pubsub.exceptions.PubSubException
 
PubSubItemsConverter - Class in tigase.pubsub.repository.converter
 
PubSubItemsConverter() - Constructor for class tigase.pubsub.repository.converter.PubSubItemsConverter
 
pubsubJid - Variable in class tigase.pubsub.PepPlugin
 
pubSubLogic - Variable in class tigase.pubsub.AbstractPubSubModule
 
pubSubLogic - Variable in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
PubSubLogic - Interface in tigase.pubsub.utils
Interface of a bean which implements PubSub logic.
PubSubLogic.Action - Enum Class in tigase.pubsub.utils
 
PubSubNodeConverter - Class in tigase.pubsub.repository.converter
 
PubSubNodeConverter() - Constructor for class tigase.pubsub.repository.converter.PubSubNodeConverter
 
PubSubQuery - Interface in tigase.pubsub.modules.mam
 
PubSubVersion - Class in tigase.pubsub
 
PurgeItemsModule - Class in tigase.pubsub.modules
 
PurgeItemsModule() - Constructor for class tigase.pubsub.modules.PurgeItemsModule
 
purgeNode - Enum constant in enum class tigase.pubsub.utils.PubSubLogic.Action
 
put(KEY, VALUE) - Method in class tigase.pubsub.utils.FragmentedMap
 
put(K, V) - Method in interface tigase.pubsub.utils.Cache
 
put(K, V) - Method in class tigase.pubsub.utils.LRUCache
 
put(K, V) - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
put(Executor.Priority, Runnable) - Method in class tigase.pubsub.utils.executors.ExecutionQueue
 
putAll(Map<KEY, VALUE>) - Method in class tigase.pubsub.utils.FragmentedMap
 
putIfAbsent(K, V) - Method in interface tigase.pubsub.utils.Cache
 
putIfAbsent(K, V) - Method in class tigase.pubsub.utils.LRUCache
 
putIfAbsent(K, V) - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 

Q

Query - Class in tigase.pubsub.modules.mam
Created by andrzej on 22.12.2016.
Query() - Constructor for class tigase.pubsub.modules.mam.Query
 
queryItems(Q, T, MAMRepository.ItemHandler<Q, MAMRepository.Item>) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
queryItems(Q, T, MAMRepository.ItemHandler<Q, MAMRepository.Item>) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
queryItems(ExtendedQueryImpl, Long, MAMRepository.ItemHandler<ExtendedQueryImpl, MAMRepository.Item>) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
queryItems(PubSubQuery, MAMRepository.ItemHandler<PubSubQuery, MAMRepository.Item>) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
queue - Variable in class tigase.pubsub.utils.executors.AbstractQueuingExecutor
 

R

RateLimitingExecutor - Class in tigase.pubsub.utils.executors
Class implements an executor limiting number of executions of submitted tasks per second.
RateLimitingExecutor() - Constructor for class tigase.pubsub.utils.executors.RateLimitingExecutor
 
RateLimitingExecutor.MemoryUsage - Enum Class in tigase.pubsub.utils.executors
 
read(UserRepository, IPubSubConfig, String) - Method in class tigase.pubsub.AbstractNodeConfig
 
ReadAllNodesCommand - Class in tigase.pubsub.modules.commands
 
ReadAllNodesCommand() - Constructor for class tigase.pubsub.modules.commands.ReadAllNodesCommand
 
registerModules(Kernel) - Method in class tigase.pubsub.PubSubComponent
 
remove(String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet
 
remove(String) - Method in interface tigase.pubsub.repository.IPubSubRepository.RootCollectionSetIfc
 
remove(String) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
remove(K) - Method in interface tigase.pubsub.utils.Cache
 
remove(K) - Method in class tigase.pubsub.utils.LRUCache
 
remove(K) - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
remove(KEY) - Method in class tigase.pubsub.utils.FragmentedMap
 
remove(K, V) - Method in class tigase.pubsub.utils.LRUCache
 
remove(BareJID, JID) - Method in class tigase.pubsub.repository.PresenceCollectorRepository
 
remove(JID) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.ServiceEntry
 
removeEldestEntry(Map.Entry<CachedPubSubRepository.NodeKey, V>) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.SizedCache
 
removeFromRootCollection(BareJID, String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
removeFromRootCollection(BareJID, String) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
removeJid(BareJID, JID) - Method in class tigase.pubsub.modules.PresenceCollectorModule
 
removeMySQLNonUtf8mb3Codepoints(String) - Static method in class tigase.pubsub.Utils
 
removeNodeSubscription(BareJID, Long, BareJID) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
removeNodeSubscription(BareJID, T, BareJID) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
removeNodeSubscription(BareJID, T, BareJID) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
reset() - Method in class tigase.pubsub.AbstractNodeConfig
 
resetChangedFlag() - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
resetChangedFlag() - Method in interface tigase.pubsub.repository.cached.IAffiliationsCached
 
resetChangedFlag() - Method in interface tigase.pubsub.repository.cached.ISubscriptionsCached
 
resetChangedFlag() - Method in class tigase.pubsub.repository.cached.NodeAffiliations
 
resetChangedFlag() - Method in class tigase.pubsub.repository.cached.NodeSubscriptions
 
resetChanges() - Method in class tigase.pubsub.repository.cached.Node
 
RetractItemModule - Class in tigase.pubsub.modules
Class description
RetractItemModule() - Constructor for class tigase.pubsub.modules.RetractItemModule
 
RetractItemModule.ItemRetractedEvent - Class in tigase.pubsub.modules
 
retractItems - Enum constant in enum class tigase.pubsub.utils.PubSubLogic.Action
 
retractItems(BareJID, String, List<String>) - Method in class tigase.pubsub.modules.RetractItemModule
 
RetrieveAffiliationsModule - Class in tigase.pubsub.modules
 
RetrieveAffiliationsModule() - Constructor for class tigase.pubsub.modules.RetrieveAffiliationsModule
 
retrieveItems - Enum constant in enum class tigase.pubsub.utils.PubSubLogic.Action
 
RetrieveItemsCommand - Class in tigase.pubsub.modules.commands
 
RetrieveItemsCommand() - Constructor for class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
RetrieveItemsModule - Class in tigase.pubsub.modules
 
RetrieveItemsModule() - Constructor for class tigase.pubsub.modules.RetrieveItemsModule
 
RetrieveSubscriptionsModule - Class in tigase.pubsub.modules
Implementation of subscription retrieval module.
RetrieveSubscriptionsModule() - Constructor for class tigase.pubsub.modules.RetrieveSubscriptionsModule
 
RootCollectionSet(BareJID, CachedPubSubRepository) - Constructor for class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet
 
roster - Enum constant in enum class tigase.pubsub.AccessModel
Any entity in the specified roster group(s) may subscribe to the node and retrieve items from the node; this access model applies mainly to instant messaging systems (see RFC 3921).
run() - Method in class tigase.pubsub.Ghostbuster
 
run() - Method in class tigase.pubsub.modules.commands.AbstractLoadRunner
 
run() - Method in class tigase.pubsub.utils.executors.RateLimitingExecutor
 

S

SameThreadExecutor - Class in tigase.pubsub.utils.executors
Implementation of Executor providing no limitations and no support for priorities.
SameThreadExecutor() - Constructor for class tigase.pubsub.utils.executors.SameThreadExecutor
 
saveNode(Node<T>, int) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
Schema - Class in tigase.pubsub.repository
Created by andrzej on 07.05.2017.
Schema() - Constructor for class tigase.pubsub.repository.Schema
 
sendAuthorizationRequest(String, JID, String, BareJID, IAffiliations) - Method in class tigase.pubsub.modules.PendingSubscriptionModule
 
SendLastPublishedItem - Enum Class in tigase.pubsub
 
sendNotification(BareJID, String, Element, String, Map<String, String>, JID, StanzaType) - Method in class tigase.pubsub.modules.PublishItemModule
 
serviceBareJID - Variable in class tigase.pubsub.PubSubConfig
 
ServiceEntry(BareJID) - Constructor for class tigase.pubsub.repository.PresenceCollectorRepository.ServiceEntry
 
serviceJid - Variable in class tigase.pubsub.modules.NodeConfigModule.NodeConfigurationChangedEvent
 
serviceJid - Variable in class tigase.pubsub.modules.NodeCreateModule.NodeCreatedEvent
 
serviceJid - Variable in class tigase.pubsub.modules.NodeDeleteModule.NodeDeletedEvent
 
serviceJid - Variable in class tigase.pubsub.modules.PresenceCollectorModule.CapsChangeEvent
 
serviceJid - Variable in class tigase.pubsub.modules.PublishItemModule.BroadcastNotificationEvent
 
serviceJid - Variable in class tigase.pubsub.modules.PublishItemModule.ItemPublishedEvent
 
serviceJid - Variable in class tigase.pubsub.modules.RetractItemModule.ItemRetractedEvent
 
serviceJid - Variable in class tigase.pubsub.repository.cached.CachedPubSubRepository.NodeKey
 
serviceJID - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LoginToNodeEvent
 
serviceJID - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.LogoffFromNodeEvent
 
serviceJID - Variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.UpdatePresenceEvent
 
serviceRemoved(BareJID) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
serviceRemoved(BareJID) - Method in interface tigase.pubsub.repository.IPubSubRepository.IListener
 
setAdmins(String[]) - Method in class tigase.pubsub.PubSubConfig
 
setAffiliation(Affiliation) - Method in class tigase.pubsub.repository.stateless.UsersAffiliation
 
setBodyXsltEmbedded(String) - Method in class tigase.pubsub.AbstractNodeConfig
 
setChildNodes(List<String>) - Method in class tigase.pubsub.repository.cached.Node
 
setChildren(String[]) - Method in class tigase.pubsub.CollectionNodeConfig
 
setCollection(String) - Method in class tigase.pubsub.AbstractNodeConfig
 
setDao(IPubSubDAO<T, DataSource, PubSubQuery>) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
setDataSource(DataRepository) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
setDataSource(DataSource) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
setDeleted(boolean) - Method in class tigase.pubsub.repository.cached.Node
 
setDomains(String...) - Method in class tigase.pubsub.AbstractNodeConfig
 
setEventBus(EventBus) - Method in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
setJabberIqPrivateProcessor(JabberIqPrivate) - Method in class tigase.pubsub.PepPlugin
 
setLimit(long) - Method in class tigase.pubsub.utils.executors.RateLimitingExecutor
 
setMaxSize(int) - Method in interface tigase.pubsub.utils.Cache
 
setMaxSize(int) - Method in class tigase.pubsub.utils.LRUCache
 
setMaxSize(int) - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
setName(String) - Method in class tigase.pubsub.PubSubComponent
 
setNodeType(NodeType) - Method in class tigase.pubsub.AbstractNodeConfig
 
setProperties(Map<String, Object>) - Method in class tigase.pubsub.PubSubConfig
 
setPubsubNode(String) - Method in class tigase.pubsub.modules.mam.ExtendedQueryImpl
 
setPubsubNode(String) - Method in interface tigase.pubsub.modules.mam.PubSubQuery
 
setPubsubNode(String) - Method in class tigase.pubsub.modules.mam.Query
 
setPubsubRepository(IPubSubRepository) - Method in class tigase.pubsub.PubSubComponent
 
setStatementParamsForMAM(PreparedStatement, ExtendedQueryImpl, Long) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
setStatisticsPrefix(String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
setStatisticsPrefix(String) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.SizedCache
 
setStatisticsPrefix(String) - Method in class tigase.pubsub.utils.LRUCache
 
setStatisticsPrefix(String) - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
setSubscription(Subscription) - Method in class tigase.pubsub.repository.stateless.UsersSubscription
 
setValue(String, boolean) - Method in class tigase.pubsub.AbstractNodeConfig
 
setValue(String, Object) - Method in class tigase.pubsub.AbstractNodeConfig
 
setValues(String, String[]) - Method in class tigase.pubsub.AbstractNodeConfig
 
setVcardTempProcessor(VCardTemp) - Method in class tigase.pubsub.PepPlugin
 
sha1OfLower(String) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
shouldBroadcast(JID) - Method in class tigase.pubsub.NotificationBroadcaster
 
shouldPing(JID) - Method in class tigase.pubsub.Ghostbuster
 
simpleNodes - Variable in class tigase.pubsub.PepPlugin
 
simplePepEnabled - Variable in class tigase.pubsub.PepPlugin
 
size() - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
size() - Method in interface tigase.pubsub.repository.IAffiliations
 
size() - Method in interface tigase.pubsub.repository.ISubscriptions
 
size() - Method in class tigase.pubsub.repository.NodeAffiliations
 
size() - Method in class tigase.pubsub.repository.NodeSubscriptions
 
size() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
size() - Method in interface tigase.pubsub.utils.Cache
 
size() - Method in class tigase.pubsub.utils.LRUCache
 
size() - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
SizedCache(int) - Constructor for class tigase.pubsub.repository.cached.CachedPubSubRepository.SizedCache
 
Spi(Random) - Constructor for class tigase.pubsub.Utils.Spi
 
start() - Method in class tigase.pubsub.PubSubComponent
 
state - Variable in exception tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet.IllegalStateException
 
statisticExecutedIn(long) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.SizedCache
 
statisticExecutedIn(long) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
statisticExecutedIn(long) - Method in class tigase.pubsub.utils.LRUCache
 
statisticExecutedIn(long) - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
stop() - Method in class tigase.pubsub.PubSubComponent
 
stopped(XMPPResourceConnection, Queue<Packet>, Map<String, Object>) - Method in class tigase.pubsub.PepPlugin
 
StoredProcedures - Class in tigase.pubsub.repository.derby
 
StoredProcedures() - Constructor for class tigase.pubsub.repository.derby.StoredProcedures
 
storeEntity(PubSubItemEntity) - Method in class tigase.pubsub.repository.converter.PubSubItemsConverter
 
storeEntity(PubSubNodeEntity) - Method in class tigase.pubsub.repository.converter.PubSubNodeConverter
 
submit(Executor.Priority, Runnable) - Method in class tigase.pubsub.utils.executors.AbstractQueuingExecutor
 
submit(Executor.Priority, Runnable) - Method in interface tigase.pubsub.utils.executors.Executor
Submits a task with a priority for execution.
submit(Executor.Priority, Runnable) - Method in class tigase.pubsub.utils.executors.SameThreadExecutor
 
subs - Variable in class tigase.pubsub.repository.NodeSubscriptions
 
subscribe - Enum constant in enum class tigase.pubsub.utils.PubSubLogic.Action
 
subscribed - Enum constant in enum class tigase.pubsub.Subscription
An entity is subscribed to a node.
SubscribeNodeModule - Class in tigase.pubsub.modules
 
SubscribeNodeModule() - Constructor for class tigase.pubsub.modules.SubscribeNodeModule
 
subscribers - Enum constant in enum class tigase.pubsub.PublisherModel
 
subscribersOfNotifications(BareJID, String) - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
subscribersOfNotifications(BareJID, String) - Method in interface tigase.pubsub.utils.PubSubLogic
 
Subscription - Enum Class in tigase.pubsub
 
subscriptionsMerge() - Method in class tigase.pubsub.repository.cached.Node
 
subscriptionsNeedsWriting() - Method in class tigase.pubsub.repository.cached.Node
 
subscriptionsSaved() - Method in class tigase.pubsub.repository.cached.Node
 
supDiscoFeatures(XMPPResourceConnection) - Method in class tigase.pubsub.PepPlugin
 
supElementNamePaths() - Method in class tigase.pubsub.PepPlugin
 
supNamespaces() - Method in class tigase.pubsub.PepPlugin
 
SUPPORTED_PEP_XMLNS - Static variable in class tigase.pubsub.modules.PublishItemModule
 
supTypes() - Method in class tigase.pubsub.PepPlugin
 
synchronizeOnUserJID(BareJID, Supplier<T>) - Method in class tigase.pubsub.repository.PresenceCollectorRepository.ServiceEntry
 

T

takeDao() - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
takeDao(BareJID) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
TIGASE - Static variable in class tigase.pubsub.AbstractNodeConfig
 
TIGASE_PUBSUB_INTERNAL_KEY - Static variable in class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
TIGASE_PUBSUB_ITEMID_KEY - Static variable in class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
TIGASE_PUBSUB_NODENAME_KEY - Static variable in class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
TIGASE_PUBSUB_SERVICE_KEY - Static variable in class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
TIGASE_PUBSUB_TIMESTAMP_KEY - Static variable in class tigase.pubsub.modules.commands.RetrieveItemsCommand
 
tigase.pubsub - package tigase.pubsub
 
tigase.pubsub.cluster - package tigase.pubsub.cluster
 
tigase.pubsub.exceptions - package tigase.pubsub.exceptions
 
tigase.pubsub.modules - package tigase.pubsub.modules
 
tigase.pubsub.modules.commands - package tigase.pubsub.modules.commands
 
tigase.pubsub.modules.ext.presence - package tigase.pubsub.modules.ext.presence
 
tigase.pubsub.modules.mam - package tigase.pubsub.modules.mam
 
tigase.pubsub.repository - package tigase.pubsub.repository
 
tigase.pubsub.repository.cached - package tigase.pubsub.repository.cached
 
tigase.pubsub.repository.converter - package tigase.pubsub.repository.converter
 
tigase.pubsub.repository.derby - package tigase.pubsub.repository.derby
 
tigase.pubsub.repository.stateless - package tigase.pubsub.repository.stateless
 
tigase.pubsub.utils - package tigase.pubsub.utils
 
tigase.pubsub.utils.executors - package tigase.pubsub.utils.executors
 
tigPubSubCountNodes(String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubCreateNode(String, String, Integer, String, String, Long, Timestamp, String, Integer, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubCreateService(String, String, Integer, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubDeleteAllNodes(String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubDeleteItem(Long, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubDeleteNodeSubscription(Long, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubEnsureJid(String) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubEnsureJid(Connection, String) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubEnsureServiceJid(String, String, Integer) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubFixItem(Long, String, Timestamp, Timestamp) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubFixNode(Long, Timestamp) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetAllNodes(String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetChildNodes(String, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetItem(Long, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetNodeAffiliations(Long, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetNodeConfiguration(Long, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetNodeId(String, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetNodeItemIds(Long, Integer, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetNodeItemIdsSince(Long, Integer, Timestamp, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetNodeItemsMeta(Long, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetNodeMeta(String, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetNodeSubscriptions(Long, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetRootNodes(String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetServices(String, Integer, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetUserAffiliations(String, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubGetUserSubscriptions(String, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubMamAddItem(Long, String, Timestamp, String, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubMamQueryItem(Long, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubMamQueryItemPosition(Long, Timestamp, Timestamp, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubMamQueryItems(Long, Timestamp, Timestamp, Integer, Integer, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubMamQueryItemsCount(Long, Timestamp, Timestamp, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubMamUpdateItem(Long, String, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubQueryItemPosition(String, Timestamp, Timestamp, Integer, Long, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubQueryItems(String, Timestamp, Timestamp, Integer, Integer, Integer, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubQueryItemsCount(String, Timestamp, Timestamp, Integer, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubRemoveNode(Long, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubRemoveService(String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubSetNodeAffiliation(Long, String, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubSetNodeConfiguration(Long, String, Long, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubSetNodeSubscription(Long, String, String, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
tigPubSubWriteItem(Long, String, String, String, Timestamp, String, ResultSet[]) - Static method in class tigase.pubsub.repository.derby.StoredProcedures
 
toString() - Method in class tigase.pubsub.AbstractNodeConfig
 
toString() - Method in class tigase.pubsub.modules.ext.presence.PresenceNodeSubscriptions
 
toString() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.NodeKey
 
toString() - Method in class tigase.pubsub.repository.cached.Node
 
toString() - Method in class tigase.pubsub.repository.NodeAffiliations
 
toString() - Method in class tigase.pubsub.repository.NodeSubscriptions
 
toString() - Method in class tigase.pubsub.repository.stateless.UsersAffiliation
 
toString() - Method in class tigase.pubsub.repository.stateless.UsersSubscription
 
toString() - Method in class tigase.pubsub.utils.IntegerOrMax
 
transform(Element, AbstractNodeConfig) - Method in class tigase.pubsub.modules.XsltTool
 
trimItems(BareJID, String, Integer, CollectionItemsOrdering) - Method in class tigase.pubsub.modules.PublishItemModule
 

U

unconfigured - Enum constant in enum class tigase.pubsub.Subscription
An entity has subscribed but its subscription options have not yet been configured.
uninitialized - Enum constant in enum class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet.State
 
unsubscribe - Enum constant in enum class tigase.pubsub.utils.PubSubLogic.Action
 
UnsubscribeNodeModule - Class in tigase.pubsub.modules
 
UnsubscribeNodeModule() - Constructor for class tigase.pubsub.modules.UnsubscribeNodeModule
 
update(BareJID, String, AbstractNodeConfig) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
update(BareJID, String, AbstractNodeConfig) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
update(BareJID, String, IAffiliations) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
update(BareJID, String, IAffiliations) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
update(BareJID, String, ISubscriptions) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
update(BareJID, String, ISubscriptions) - Method in interface tigase.pubsub.repository.IPubSubRepository
 
updateMAMItem(BareJID, Long, String, Element) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
updateMAMItem(BareJID, String, String, Element) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
updateMAMItem(BareJID, String, String, Element) - Method in interface tigase.pubsub.repository.IExtenedMAMPubSubRepository
 
updateMAMItem(BareJID, T, String, Element) - Method in interface tigase.pubsub.repository.IExtendedPubSubDAO
 
updateMAMItem(BareJID, T, String, Element) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
updateNodeAffiliation(BareJID, Long, String, UsersAffiliation) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
updateNodeAffiliation(BareJID, T, String, UsersAffiliation) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
updateNodeAffiliation(BareJID, T, String, UsersAffiliation) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
updateNodeConfig(BareJID, Long, String, Long) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
updateNodeConfig(BareJID, T, String, T) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
updateNodeConfig(BareJID, T, String, T) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
updateNodeConfiguration(BareJID, String, Form) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
updateNodeSubscription(BareJID, Long, String, UsersSubscription) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
updateNodeSubscription(BareJID, T, String, UsersSubscription) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
updateNodeSubscription(BareJID, T, String, UsersSubscription) - Method in class tigase.pubsub.repository.PubSubDAOPool
 
UpdatePresenceEvent(String, BareJID, String, Packet) - Constructor for class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension.UpdatePresenceEvent
 
updateSeed(int) - Method in class tigase.pubsub.Utils.Spi
 
userEntriesStream() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.ServiceEntry
 
UserEntry(BareJID, BareJID) - Constructor for class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
userResourceEntriesStream() - Method in class tigase.pubsub.repository.PresenceCollectorRepository.UserEntry
 
UserResourceEntry(PresenceCollectorRepository.UserEntry, String, String) - Constructor for class tigase.pubsub.repository.PresenceCollectorRepository.UserResourceEntry
 
userResourceEntryStream() - Method in class tigase.pubsub.repository.PresenceCollectorRepository
 
UsersAffiliation - Class in tigase.pubsub.repository.stateless
 
UsersAffiliation(BareJID) - Constructor for class tigase.pubsub.repository.stateless.UsersAffiliation
 
UsersAffiliation(BareJID, Affiliation) - Constructor for class tigase.pubsub.repository.stateless.UsersAffiliation
 
UsersSubscription - Class in tigase.pubsub.repository.stateless
Implementation of single subscription entry.
UsersSubscription(BareJID, String, Subscription) - Constructor for class tigase.pubsub.repository.stateless.UsersSubscription
 
Utils - Class in tigase.pubsub
 
Utils() - Constructor for class tigase.pubsub.Utils
 
Utils.Spi - Class in tigase.pubsub
 
uuid - Variable in class tigase.pubsub.modules.PublishItemModule.ItemPublishedEvent
 

V

validateItem(BareJID, String, String, String, Element) - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository
 
validateItem(BareJID, String, String, String, Element) - Method in interface tigase.pubsub.repository.IItems.IListnener
 
validateItemId(BareJID, String, String) - Method in class tigase.pubsub.utils.DefaultPubSubLogic
 
validateItemId(BareJID, String, String) - Method in interface tigase.pubsub.utils.PubSubLogic
 
validateNode(BareJID, String) - Method in class tigase.pubsub.modules.mam.MAMQueryParser
 
value() - Method in enum class tigase.pubsub.CollectionItemsOrdering
 
valueof(String) - Static method in enum class tigase.pubsub.utils.executors.Executor.Priority
 
valueOf(String) - Static method in enum class tigase.pubsub.AccessModel
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tigase.pubsub.Affiliation
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tigase.pubsub.CollectionItemsOrdering
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tigase.pubsub.NodeType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tigase.pubsub.PublisherModel
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet.State
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tigase.pubsub.SendLastPublishedItem
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tigase.pubsub.Subscription
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tigase.pubsub.utils.executors.Executor.Priority
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tigase.pubsub.utils.executors.RateLimitingExecutor.MemoryUsage
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in class tigase.pubsub.utils.IntegerOrMax
 
valueOf(String) - Static method in enum class tigase.pubsub.utils.PubSubLogic.Action
Returns the enum constant of this class with the specified name.
values() - Static method in enum class tigase.pubsub.AccessModel
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tigase.pubsub.Affiliation
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tigase.pubsub.CollectionItemsOrdering
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tigase.pubsub.NodeType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tigase.pubsub.PublisherModel
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet.State
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class tigase.pubsub.repository.cached.CachedPubSubRepository.RootCollectionSet
 
values() - Method in interface tigase.pubsub.repository.IPubSubRepository.RootCollectionSetIfc
 
values() - Static method in enum class tigase.pubsub.SendLastPublishedItem
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tigase.pubsub.Subscription
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in interface tigase.pubsub.utils.Cache
 
values() - Static method in enum class tigase.pubsub.utils.executors.Executor.Priority
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tigase.pubsub.utils.executors.RateLimitingExecutor.MemoryUsage
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class tigase.pubsub.utils.LRUCache
 
values() - Method in class tigase.pubsub.utils.LRUCacheWithFuture
 
values() - Static method in enum class tigase.pubsub.utils.PubSubLogic.Action
Returns an array containing the constants of this enum class, in the order they are declared.
veryHigh - Enum constant in enum class tigase.pubsub.utils.executors.RateLimitingExecutor.MemoryUsage
 
ViewNodeLoadCommand - Class in tigase.pubsub.cluster
 
ViewNodeLoadCommand(IPubSubConfig, ClusterNodeMap) - Constructor for class tigase.pubsub.cluster.ViewNodeLoadCommand
 

W

whitelist - Enum constant in enum class tigase.pubsub.AccessModel
An entity may subscribe or retrieve items only if on a whitelist managed by the node owner.
write(Collection<Element>) - Method in interface tigase.pubsub.ElementWriter
 
write(UserRepository, IPubSubConfig, String) - Method in class tigase.pubsub.AbstractNodeConfig
 
write(Element) - Method in interface tigase.pubsub.ElementWriter
 
writeItem(String, String, Element, String) - Method in class tigase.pubsub.repository.cached.Items
 
writeItem(String, String, Element, String) - Method in interface tigase.pubsub.repository.IItems
 
writeItem(BareJID, Long, long, String, String, Element, String) - Method in class tigase.pubsub.repository.PubSubDAOJDBC
 
writeItem(BareJID, T, long, String, String, Element, String) - Method in interface tigase.pubsub.repository.IPubSubDAO
 
writeItem(BareJID, T, long, String, String, Element, String) - Method in class tigase.pubsub.repository.PubSubDAOPool
 

X

XMLNS - Static variable in class tigase.pubsub.exceptions.PubSubErrorCondition
 
XMLNS_EXTENSION - Static variable in class tigase.pubsub.modules.ext.presence.PresencePerNodeExtension
 
XMLNSS - Static variable in class tigase.pubsub.PepPlugin
 
XsltTool - Class in tigase.pubsub.modules
 
XsltTool() - Constructor for class tigase.pubsub.modules.XsltTool
 
A B C D E F G H I K L M N O P Q R S T U V W X 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form