Skip navigation links

Oracle Fusion Middleware Java API Reference for Oracle Event Processing for Oracle Java Embedded
11g Release 1 (11.1.1.7)

E39906-01
FRAMES    NO FRAMES

A B C D E F G H I J K L M N O P Q R S T U V W X


A

ActivatableBean - interface com.bea.wlevs.ede.api.ActivatableBean.
Interface to be implemented by beans that need to react when dynamic configuration has been set and the containing EPN is activated.
activateConfiguration(int, EventType) - Method in interface com.bea.wlevs.channel.EventPartitioner
Specifies the number of partitions that are downstream to this node, and the event type of the event channel in which this EventPartitioner is associated to.
Adapter - interface com.bea.wlevs.ede.api.Adapter.
Marker interface for Adapters.
AdapterFactory - interface com.bea.wlevs.ede.api.AdapterFactory.
Factory for creating Adapters.
AdapterMBean - interface com.bea.wlevs.management.configuration.AdapterMBean.
MBeans of this type wraps around a Adapter object which has been instantiated or configured through the spring-context file.
addDatabase(String, String) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method add a database to this processor's configuration.
addDataProvider(DataProvider) - Method in interface com.bea.wlevs.ede.api.Processor
In addition to receiving and sending events, a processor can poll data providers to be able to merge the streaming events with static data.
addDataProvider(String, DataProvider) - Method in interface com.bea.wlevs.ede.api.Processor
Deprecated. see addExternalSource
addExternalSource(ExternalSource) - Method in interface com.bea.wlevs.ede.api.Processor
In addition to receiving and sending events, a processor can poll data providers to be able to merge the streaming events with static data.
addInterface(Class) - Method in interface com.bea.wlevs.spring.support.ProxyFactory
 
addParameters(String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method binds a new set of parameter values against a parameterized query/view.
addParams(String, String) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method adds a new set of unnamed parameter values to be bound against a parameterized query.
addParams(String, String, String) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method adds a new set or replaces an existing set of named parameter values to be bound against a parameterized query.
addQuery(String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will add an CQL query to the designated CQL Processor.
addQuery(String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will add an CQL query with a name to the designated CQL Processor.
addQuery(String, String, boolean) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will add an CQL query with a name to the designated CQL Processor.
addQuery(String, String, boolean, String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method adds an CQL query and configures its ordering constraint.
addRule(String) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method will add an EPL rule to the designated EPL Processor.
addRule(String, String) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method will add an EPL rule with a name to the designated EPL Processor.
addRule(String, String, boolean) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method will add an EPL rule with a name to the designated EPL Processor.
addRules(Map) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method adds a set of EPL queries to the designated EPL Processor.
addSelectorQuery(String) - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Adds the specified query ID to the selector configuration for this channel.
addTypeAlias(String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will add a type alias to the designated CQL Processor.
addView(String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will add an CQL view to the designated CQL processor.
addView(String, List) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will add an CQL query with a name to the designated CQL Processor.
addView(String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will add an CQL query with a name to the designated CQL Processor.
addView(String, String, List) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will add an CQL query with a name to the designated CQL Processor.
addView(String, String, List, boolean) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will add an CQL view with a name to the designated CQL Processor.
addView(String, String, List, String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will add an CQL view with a name to the designated CQL Processor.
afterConfigurationActive() - Method in interface com.bea.wlevs.ede.api.ActivatableBean
Invoked by the EPN container after it has set all of the dynamic configuration.
afterConfigurationActive(BundleContext) - Method in interface com.bea.wlevs.spring.support.ConfigurationBeanPostProcessorService
The method is invoked after the configuration is activated, but before the application gets to run.
afterPropertiesSet() - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
afterPropertiesSet() - Method in interface com.bea.wlevs.ede.api.InitializingBean
Invoked by the EPN container after it has set all instance properties supplied.
afterPropertiesSet(BundleContext) - Method in interface com.bea.wlevs.spring.support.BeanPostProcessorService
Initialization callback for this context
AmbiguousFunctionException - exception com.oracle.cep.cartridge.AmbiguousFunctionException.
Exception thrown when function being referenced is ambiguous and cannot be determined by the ExternalFunctionProvider
AmbiguousFunctionException(String) - Constructor for class com.oracle.cep.cartridge.AmbiguousFunctionException
 
AmbiguousFunctionException(String, String) - Constructor for class com.oracle.cep.cartridge.AmbiguousFunctionException
 
AmbiguousFunctionException(String, String, Throwable) - Constructor for class com.oracle.cep.cartridge.AmbiguousFunctionException
 
AmbiguousFunctionException(String, Throwable) - Constructor for class com.oracle.cep.cartridge.AmbiguousFunctionException
 
APP_ID - Static variable in interface com.bea.wlevs.ede.api.FaultHandler
Use this mandatory service property to specify target application.
AppDeploymentMBean - interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean.
This MBean will manage the deployment of a deployable application in the Weblogic Event Server or in a cluster of WebLogic Event Servers.
APPLICATION_ID - Static variable in interface com.bea.wlevs.ede.api.InstanceConstants
The globally unique identity of an application
ApplicationIdentityAware - interface com.bea.wlevs.ede.api.ApplicationIdentityAware.
Interface to be implemented by beans that wish to know the application id of the containing EPN.
ApplicationMBean - interface com.bea.wlevs.management.configuration.ApplicationMBean.
This MBean represents an application instance that is deployed in the Weblogic Event Server.
ApplicationName - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters
Name of the application from which these events were recorded
ApplicationRuntimeMBean - interface com.bea.wlevs.management.runtime.ApplicationRuntimeMBean.
This MBean provides runtime information for an instance of an OEP application.
ARGUMENT_TYPES - Static variable in class com.bea.wlevs.management.configuration.CQLProcessorMBean.FunctionParameter
Function argument types.
ArithmeticExecutionException - exception com.bea.wlevs.ede.api.ArithmeticExecutionException.
Event processing exception raised if error occurs while executing an arithmetic-related expression in a CQL statement.
Asynchronous - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Property name for asynchronous.

B

BatchRelationSender - interface com.bea.wlevs.ede.api.BatchRelationSender.
A BatchRelationSender send a batch of events emitted by an RelationSource to RelationSink listeners.
BatchRelationSink - interface com.bea.wlevs.ede.api.BatchRelationSink.
Interface to be implemented by beans that want to receive a batch of events modeling a OCEP stream.
BatchSize - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Property name for batch size.
BatchSize - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Integer value with batch-size configuration paramter
BatchStreamSender - interface com.bea.wlevs.ede.api.BatchStreamSender.
A BatchStreamSender sends a batch of events emitted by an StreamSource to StreamSink listeners.
BatchStreamSink - interface com.bea.wlevs.ede.api.BatchStreamSink.
Interface to be implemented by beans that want to receive a batch of events modeling a OCEP stream.
BatchTimeout - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Integer value with batch-timeout configuration paramter
BeanPostProcessorService - interface com.bea.wlevs.spring.support.BeanPostProcessorService.
BeanPostProcessor service that allows bundles to contribute to the programming model of WLEvS.
beforeResume() - Method in interface com.bea.wlevs.ede.api.ResumableBean
Invoked by the EPN container before the bean is started or resumed.
BIGINT - Static variable in class com.bea.wlevs.ede.api.Type
 
bind(Object[]) - Method in interface com.bea.wlevs.ede.api.PreparedStatement
Binds placeholder values in the PreparedStatement with the values provided in the array in the order in which they appear.
bind(Object[], String) - Method in interface com.bea.wlevs.ede.api.PreparedStatement
Binds placeholder values in the order in which they appear in the array parameter.
bindParameters(String, String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method binds a new set of named parameter values against a parameterized query/view.
BLOCK_CALLER - Static variable in class com.bea.wlevs.channel.RejectionPolicy
Execute event handling in caller's thread, essentially blocking caller.
BOOLEAN - Static variable in class com.bea.wlevs.ede.api.Type
 
BoundStatement - interface com.bea.wlevs.ede.api.BoundStatement.
Statement created through binding placeholder values for a PreparedStatement.
BufferSize - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Property name for buffer size.
BufferWriteAttempts - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Property name for buffer write attempts.
BufferWriteTimeout - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Property name for buffer write timeout.
buildEvent(Iterator, boolean) - Method in interface com.bea.wlevs.ede.api.EventType
Creates an event object for this event type by traversing iterator for event property's key and value.
BundlePropertyAdmin - interface com.bea.wlevs.spring.support.BundlePropertyAdmin.
A lightweight equivalent to ConfigAdmin which allows the passing of properties between deployment and deployment applications.
BundlePropertyAdminMutator - interface com.bea.wlevs.spring.support.BundlePropertyAdminMutator.
 
BYTE - Static variable in class com.bea.wlevs.ede.api.Type
 

C

CACHE_MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
 
CACHE_STAGE_MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
 
CacheMBean - interface com.bea.wlevs.management.configuration.CacheMBean.
 
CacheMBeanProperties - interface com.bea.wlevs.management.configuration.CacheMBeanProperties.
 
CacheStageMBean - interface com.bea.wlevs.management.configuration.CacheStageMBean.
This MBean manages the configuration of a cache instance created as a stage in the Weblogic Event Server application as part of an EPN.
CachingSystem - interface com.bea.wlevs.cache.spi.CachingSystem.
Implementations of this interface represent a caching system that may be used by Event Server applications.
CachingSystemFactory - interface com.bea.wlevs.cache.spi.CachingSystemFactory.
 
CachingSystemMBean - interface com.bea.wlevs.management.configuration.CachingSystemMBean.
This MBean manages the configuration of a caching system instance.
CapabilityProvider - interface com.oracle.cep.cartridge.CapabilityProvider.
An ExternalConnection may implement this interface to specify the capabilities it supports, such as equals, less-than, AND, OR, etc.
CartridgeException - exception com.oracle.cep.cartridge.CartridgeException.
Root exception for Cartridges.
CartridgeException() - Constructor for class com.oracle.cep.cartridge.CartridgeException
 
CartridgeException(String) - Constructor for class com.oracle.cep.cartridge.CartridgeException
 
CartridgeException(String, Throwable) - Constructor for class com.oracle.cep.cartridge.CartridgeException
 
CartridgeException(Throwable) - Constructor for class com.oracle.cep.cartridge.CartridgeException
 
CartridgeMBean - interface com.bea.wlevs.management.configuration.CartridgeMBean.
MBean interface that must be extended by Cartridge implementations to be able to query about the extensibility mechanisms of the Cartridge.
CartridgeMBean.FunctionDescKeys - class com.bea.wlevs.management.configuration.CartridgeMBean.FunctionDescKeys.
Returns information of the specified function.
CHAR - Static variable in class com.bea.wlevs.ede.api.Type
 
clearBundleProperties(String) - Method in interface com.bea.wlevs.spring.support.BundlePropertyAdminMutator
 
close() - Method in interface com.oracle.cep.cartridge.ExternalConnection
Releases all the resources acquired by Connection without any wait.
close() - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Release this object's resources immediately without wait.
com.bea.wlevs.cache.spi - package com.bea.wlevs.cache.spi
 
com.bea.wlevs.channel - package com.bea.wlevs.channel
 
com.bea.wlevs.deployment.mbean - package com.bea.wlevs.deployment.mbean
 
com.bea.wlevs.ede.api - package com.bea.wlevs.ede.api
 
com.bea.wlevs.management - package com.bea.wlevs.management
 
com.bea.wlevs.management.configuration - package com.bea.wlevs.management.configuration
 
com.bea.wlevs.management.runtime - package com.bea.wlevs.management.runtime
 
com.bea.wlevs.spring.support - package com.bea.wlevs.spring.support
 
com.oracle.cep.cartridge - package com.oracle.cep.cartridge
 
ConfigHistoryManagerMBean - interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean.
Configuration history management MBean.
ConfigurationBeanPostProcessorService - interface com.bea.wlevs.spring.support.ConfigurationBeanPostProcessorService.
The interface defines an occurrence in the life cycle of an application.
ConfigurationException - exception com.bea.wlevs.ede.api.ConfigurationException.
Root exception for EPN configuration errors.
ConfigurationException() - Constructor for class com.bea.wlevs.ede.api.ConfigurationException
 
ConfigurationException(String) - Constructor for class com.bea.wlevs.ede.api.ConfigurationException
 
ConfigurationException(String, String) - Constructor for class com.bea.wlevs.ede.api.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for class com.bea.wlevs.ede.api.ConfigurationException
 
ConfigurationException(String, Throwable, String) - Constructor for class com.bea.wlevs.ede.api.ConfigurationException
 
ConfigurationException(Throwable) - Constructor for class com.bea.wlevs.ede.api.ConfigurationException
 
ConfigurationException(Throwable, String) - Constructor for class com.bea.wlevs.ede.api.ConfigurationException
 
ConfigurationPropertyPlaceholderConfigurer - class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer.
An implementation of PropertyPlaceholderConfigurer that understands the WLEvS configuration subsystem.
ConfigurationPropertyPlaceholderConfigurer() - Constructor for class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
configurePlayback(long, long, float, boolean) - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
configurePlaybackFilter(long, long) - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Use this to specify the record time filter for events that are to be played back.
configurePlaybackStorage(String, List, String) - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Configures the store related parameters of the events that should be played back.
configurePlaybackWithDuration(long, long, float, boolean) - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
configureQueueing(int, int) - Method in interface com.bea.wlevs.management.configuration.EventQueueMBean
This method sets both the max threads and the max size.
configureRecord(long, long) - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
configureRecordStorage(String, List, String) - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Configures the storage parameters for recording events at this stage.
configureRecordWithDuration(long, long) - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
ContextResumedEvent - class com.bea.wlevs.spring.support.ContextResumedEvent.
Event delivered when an application is resumed
ContextResumedEvent(ApplicationContext) - Constructor for class com.bea.wlevs.spring.support.ContextResumedEvent
Create a new ApplicationEvent.
ContextSuspendedEvent - class com.bea.wlevs.spring.support.ContextSuspendedEvent.
Event delivered when an application is suspended
ContextSuspendedEvent(ApplicationContext) - Constructor for class com.bea.wlevs.spring.support.ContextSuspendedEvent
Create a new ApplicationEvent.
CQLExecutionException - exception com.bea.wlevs.ede.api.CQLExecutionException.
Event processing exception raised if error occurs while executing a CQL statement.
CQLProcessorMBean - interface com.bea.wlevs.management.configuration.CQLProcessorMBean.
 
CQLProcessorMBean.FunctionParameter - class com.bea.wlevs.management.configuration.CQLProcessorMBean.FunctionParameter.
 
CQLProcessorRuntimeMBean - interface com.bea.wlevs.management.runtime.CQLProcessorRuntimeMBean.
This MBean provides runtime information for an instance of a CQL processor.
create() - Method in interface com.bea.wlevs.ede.api.StageFactory
Create a new Stage using the provided stage identifier and application identifier.
create() - Method in interface com.bea.wlevs.ede.api.Factory
 
create() - Method in interface com.bea.wlevs.cache.spi.CachingSystemFactory
 
createBuilder() - Method in interface com.bea.wlevs.ede.api.EventBuilder.Factory
 
createEvent() - Method in interface com.bea.wlevs.ede.api.EventBuilder
Instantiate an event of the type associated with this event builder.
createEvent() - Method in interface com.bea.wlevs.ede.api.EventType
Creates an event object for this event type.
createProxyFactory(Object) - Method in interface com.bea.wlevs.spring.support.ProxyFactoryService
 
createStatement(String) - Method in interface com.bea.wlevs.ede.api.Processor
Compile query using the supplied query string parameter.
createStatement(String, String) - Method in interface com.bea.wlevs.ede.api.Processor
Compile query using the supplied query string parameter and query id.

D

DataProvider - interface com.bea.wlevs.ede.api.DataProvider.
Provider of non-streaming data.
DatasetName - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
The dataset name string value
DataSetName - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters
The data set name used for this recording
DefaultAdapterMBean - interface com.bea.wlevs.management.configuration.DefaultAdapterMBean.
 
deleteAllQueries() - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This methods deletes all queries that has been configured in the CQL Processor.
deleteAllRules() - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This methods deletes all rules that has been configured in the EPL Processor.
deleteAllViews() - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This methods deletes all views that have been configured in the CQL Processor.
deleteDatabase(String) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method delete a database from this processor's configuration.
deleteParams(String) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method deletes all parameter values for the parameterized query identified by the ruleId argument.
deleteParams(String, String) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method deletes the named set of parameter values for the parameterized query identified by the ruleId argument.
deleteRule(String) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method deletes a rule from the EPL Processor with the given rule id.
deleteRules(String[]) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method deletes all rules with the given ids.
deleteTypeAlias(String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will delete a type alias to the designated CQL Processor.
deployApplication(String, byte[]) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method will deploy a serialized byte array to the Weblogic Event Server.
deployApplication(String, byte[], Map) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method will deploy a serialized byte array to the Weblogic Event Server.
deployApplication(String, File) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method will deploy the jar file in the Weblogic Event Server.
deployApplication(String, String, byte[]) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method will deploy a serialized byte array as a clustered application in a group of WebLogic Event Servers.
deployApplication(String, String, File) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method will deploy the jar file as a clustered application in a group of WebLogic Event Servers.
DeploymentNotification - class com.bea.wlevs.management.runtime.DeploymentNotification.
DeploymentNotification for deployment events.
DeploymentNotification(Object, long, long, String, String, String, String) - Constructor for class com.bea.wlevs.management.runtime.DeploymentNotification
 
DeploymentServiceMBean - interface com.bea.wlevs.deployment.mbean.DeploymentServiceMBean.
Application deployment service MBean that includes non-public methods.
deregisterEventType(String) - Method in interface com.bea.wlevs.ede.api.EventTypeRepository
Remove event type from the repository.
destroy() - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
destroy() - Method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
destroy() - Method in interface com.bea.wlevs.ede.api.Statement
Permanently destroys statement and removes its reference in the processor
destroy() - Method in interface com.bea.wlevs.ede.api.DisposableBean
Invoked by the EPN container when the containing application is stopped.
destroy(BundleContext) - Method in interface com.bea.wlevs.spring.support.BeanPostProcessorService
Destruction callback for this context
destroyStatement(String) - Method in interface com.bea.wlevs.ede.api.Processor
Deletes statement and removes it from processor.
DIRECTION_PROPERTY - Static variable in interface com.bea.wlevs.management.ManagementConstants
Attribute used to identify if it is the INBOUND (entry) or OUTBOUND (exit) point on a stage
DisposableBean - interface com.bea.wlevs.ede.api.DisposableBean.
Interface to be implemented by beans that want to release resources when the containing EPN is destroyed and the application undeployed.
DOMAIN_NAME - Static variable in interface com.bea.wlevs.management.ManagementConstants
WL EvS MBean Domain Name
DomainMBean - interface com.bea.wlevs.management.configuration.DomainMBean.
This MBean is the root of Weblogic Event Server configuration MBeans.
DomainRuntimeMBean - interface com.bea.wlevs.management.runtime.DomainRuntimeMBean.
This MBean provides runtime information for an instance of an OEP domain.
DOUBLE - Static variable in class com.bea.wlevs.ede.api.Type
 
downloadRules() - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method returns in XML format all rules and any parameter values associated with parameterized queries in the designated EPL Proessor.
DROP_OLDEST - Static variable in class com.bea.wlevs.channel.RejectionPolicy
Drop oldest event in stream, and then re-attempt to execute new new (latest) event.
DuplicateEventTypeException - exception com.bea.wlevs.ede.api.DuplicateEventTypeException.
This exception is raised when an application attempts to register an event type that already has been registered.
DuplicateEventTypeException(String) - Constructor for class com.bea.wlevs.ede.api.DuplicateEventTypeException
 

E

ELEMENT_TIME - Static variable in interface com.bea.wlevs.ede.api.EventBuilder
Should the event have an element time (see CQL documentation), it is put in Builder using this constant as the property name.
EPLProcessorMBean - interface com.bea.wlevs.management.configuration.EPLProcessorMBean.
This MBean will manage instances of epl processor whose configuration has been derived from com.bea.wlevs.configuration.application.DefaultProcessorConfig schema.
EQUALS - Static variable in interface com.oracle.cep.cartridge.ExternalConstants
External Connection capabilities
EventBean - interface com.bea.wlevs.ede.api.EventBean.
Interface needed to be implemented by beans that wish to managed by the container.
EventBeanFactory - interface com.bea.wlevs.ede.api.EventBeanFactory.
Factory for creating EventBean's.
EventBeanMBean - interface com.bea.wlevs.management.configuration.EventBeanMBean.
This MBean manages the configuration of EventBeans
EventBuilder - interface com.bea.wlevs.ede.api.EventBuilder.
Builder for creating events of a certain event type.
EventBuilder.Factory - interface com.bea.wlevs.ede.api.EventBuilder.Factory.
Factory for event builder.
EventChannel - interface com.bea.wlevs.ede.api.EventChannel.
A event channel is a conduit for events.
EventChannelFactory - interface com.bea.wlevs.ede.api.EventChannelFactory.
 
EventChannelMBean - interface com.bea.wlevs.management.configuration.EventChannelMBean.
 
EventMetadata - interface com.bea.wlevs.ede.api.EventMetadata.
All the metadata that is associated with an event instance.
EventPartitioner - interface com.bea.wlevs.channel.EventPartitioner.
An EventPartitioner provides a mechanism for end-users to configure their own custom strategy for partitioning events on a channel across its output event sinks.
EventProcessingException - exception com.bea.wlevs.ede.api.EventProcessingException.
Root runtime exception raised when an error occurs when processing events.
EventProcessingException() - Constructor for class com.bea.wlevs.ede.api.EventProcessingException
Constructor for event processing exception
EventProcessingException(String) - Constructor for class com.bea.wlevs.ede.api.EventProcessingException
Constructor for event processing exception
EventProcessingException(String, String, Collection, Collection, Collection, Throwable) - Constructor for class com.bea.wlevs.ede.api.EventProcessingException
Constructor for event processing exception
EventProcessingException(String, Throwable) - Constructor for class com.bea.wlevs.ede.api.EventProcessingException
Constructor for event processing exception
EventProcessingException(Throwable) - Constructor for class com.bea.wlevs.ede.api.EventProcessingException
Constructor for event processing exception
EventProperty - interface com.bea.wlevs.ede.api.EventProperty.
 
EventPropertyDescription - interface com.bea.wlevs.ede.api.EventPropertyDescription.
Describes a property of an event.
EventPropertyException - exception com.bea.wlevs.ede.api.EventPropertyException.
Event processing exception raised if event of a particular event-type fails to handle an event property.
EventQueue - interface com.bea.wlevs.ede.api.EventQueue.
 
EventQueueMBean - interface com.bea.wlevs.management.configuration.EventQueueMBean.
 
EventRejectedException - exception com.bea.wlevs.ede.api.EventRejectedException.
An EventRejectedException can be raised by the application developer to indicate that an EPN node is rejecting events.
EventRejectedException.Reason - class com.bea.wlevs.ede.api.EventRejectedException.Reason.
Reason for application to reject the event(s)
EventRejectedException(EventRejectedException.Reason, List, String) - Constructor for class com.bea.wlevs.ede.api.EventRejectedException
Constructor for EventRejectedException
EventRejectedException(EventRejectedException.Reason, List, String, String) - Constructor for class com.bea.wlevs.ede.api.EventRejectedException
Constructor for EventRejectedException
EventSender - interface com.bea.wlevs.ede.api.EventSender.
Deprecated. As of OCEP 10.3, replaced by StreamSender and RelationSender
EventSink - interface com.bea.wlevs.ede.api.EventSink.
Deprecated. As of OCEP 10.3, replaced by StreamSink and RelationSink.
EventSource - interface com.bea.wlevs.ede.api.EventSource.
Deprecated. As of OCEP 10.3, replaced by StreamSource and RelationSource
EventType - interface com.bea.wlevs.ede.api.EventType.
This interface provides event type metadata for events.
EventTypeList - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Comma separated list of event types as defined in the Event Type Repository
EventTypeRepository - interface com.bea.wlevs.ede.api.EventTypeRepository.
EventTypeRepository is a repository for all of the registered event types in the Event Server.
EventTypeRepositoryMBean - interface com.bea.wlevs.management.EventTypeRepositoryMBean.
 
EventTypes - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters
List of names of the event types contained in this recording.
execute(Object[], String, Map) - Method in interface com.oracle.cep.cartridge.ExternalFunction
Execute runtime function implementation for simple functions (e.g. non aggregate functions).
executeQuery() - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Executes the statement and returns an iterator over result set.
EXTERNAL - Static variable in class com.bea.wlevs.ede.api.Processor.ClockType
 
ExternalConnection - interface com.oracle.cep.cartridge.ExternalConnection.
Connection to an external data-source.
ExternalConstants - interface com.oracle.cep.cartridge.ExternalConstants.
General constants used by Cartridges
ExternalDataSource - interface com.oracle.cep.cartridge.ExternalDataSource.
An ExternalDataSource is an external source of contextual data that can be joined together with events within a CQL processor.
ExternalFunction - interface com.oracle.cep.cartridge.ExternalFunction.
ExternalFunctions are functions used within CQL queries and views that are provided by an external entity, such as an ExternalFunctionProvider.
ExternalFunctionDefinition - interface com.oracle.cep.cartridge.ExternalFunctionDefinition.
ExternalFunctionDefinitions specify the metadata for functions used within CQL queries and views that are provided by an external entity, such as an ExternalFunctionProvider.
ExternalFunctionProvider - interface com.oracle.cep.cartridge.ExternalFunctionProvider.
An ExternalFunctionProvider defines a set of functions that can be directly accessed within CQL queries and views.
ExternalPredicate - interface com.oracle.cep.cartridge.ExternalPredicate.
Represents prepared statement predicates.
ExternalPreparedStatement - interface com.oracle.cep.cartridge.ExternalPreparedStatement.
External Prepared Statement.
ExternalSource - interface com.bea.wlevs.ede.api.ExternalSource.
Externally-managed source of data that can be used to enrich the streaming events flowing from event sources.

F

Factory - interface com.bea.wlevs.ede.api.Factory.
Factory interfaces for all stages.
FaultHandler - interface com.bea.wlevs.ede.api.FaultHandler.
Service for providing custom fault handlers.
FIFO - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Specifies eviction policy of First In First Out.
FilterEndTime - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Long value with record time filter end value -1 means end time is not specified.
FilterStartTime - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Long value with record time filter start value -1 means start time is not specified.
FilterTimeDuration - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Long value with record time filter duration -1 means duration is not specified.
FLOAT - Static variable in class com.bea.wlevs.ede.api.Type
 
FULL - Static variable in class com.bea.wlevs.ede.api.EventRejectedException.Reason
 
FunctionNotFoundException - exception com.oracle.cep.cartridge.FunctionNotFoundException.
Exception thrown when function being referenced in CQL is not supported by ExternalFunctionProvider.
FunctionNotFoundException(String) - Constructor for class com.oracle.cep.cartridge.FunctionNotFoundException
 
FunctionNotFoundException(String, String) - Constructor for class com.oracle.cep.cartridge.FunctionNotFoundException
 
FunctionNotFoundException(String, String, Throwable) - Constructor for class com.oracle.cep.cartridge.FunctionNotFoundException
 
FunctionNotFoundException(String, Throwable) - Constructor for class com.oracle.cep.cartridge.FunctionNotFoundException
 

G

getAction() - Method in class com.bea.wlevs.ede.api.StatementException
 
getAction() - Method in class com.bea.wlevs.ede.api.CQLExecutionException
Returns defined action to be performed to fix error, when applicable.
getAllBoundParameterNames(String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method returns the names of the bound parameters which are bound to a rule identified by the preparedStatementId argument.
getAllBoundParameters(String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method retrieves all parameter values for a parameterized query identified by the preparedStatementId argument.
getAllFunctionsInfo() - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
Returns all user defined functions that have been associated to this processor, possibly through the wlevs:function tag in the EPN assembly configuration file.
getAllQueries() - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method fetches all the queries in this processor.
getAllQueriesInfo() - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
Returns all the queries configured for this processor along with all the information about the queries.
getAllRules() - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method fetches all the rules that has been configured in the designated EPL Proessor.
getAllRulesInfo() - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
Returns all the rules configured for this processor along with all the information about the rules.
getAllViews() - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method fetches all the views in this processor.
getAllViewsInfo() - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
Returns all the views configured for this processor along with all the information about the views.
getAmbiguousFunctionName() - Method in class com.oracle.cep.cartridge.AmbiguousFunctionException
 
getApplicationContexts(String) - Method in interface com.bea.wlevs.management.configuration.CartridgeMBean
Returns all the context names associated with the given application available for this cartridge.
getApplicationGroups() - Method in interface com.bea.wlevs.management.configuration.ApplicationMBean
Returns an array of String containing the name of all groups for which this application is a member of.
getApplicationMBeans() - Method in interface com.bea.wlevs.management.configuration.DomainMBean
Returns an array of ObjectName of the ApplicationMBeans that have been deployed in the current WebLogic Event Server instance.
getApplicationRuntimeMBeans() - Method in interface com.bea.wlevs.management.runtime.ServerRuntimeMBean
Returns an array of ObjectName of the ApplicationRuntimeMBeans that have been deployed in the current WebLogic Event Server instance.
getAttributes() - Method in interface com.oracle.cep.cartridge.ExternalPredicate
Returns list of attributes being used in predicate
getBoundParameters(String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method retrieves the set of parameter values with the given name for a parameterized query identified by the preparedStatementId argument.
getBoundStatement(String) - Method in interface com.bea.wlevs.ede.api.PreparedStatement
Returns BoundStatement identfied by bindingId
getBoundStatements() - Method in interface com.bea.wlevs.ede.api.PreparedStatement
Returns read-only Collection of all BoundStatements being managed by this PreparedStatement.
getBundleProperties(String) - Method in interface com.bea.wlevs.spring.support.BundlePropertyAdmin
Returns the set of properties registered against the application bundle represented by symbolicName.
getBundleProperty(String, String) - Method in interface com.bea.wlevs.spring.support.BundlePropertyAdmin
Returns the set of properties registered against the application bundle represented by symbolicName.
getCache(String) - Method in interface com.bea.wlevs.cache.spi.CachingSystem
Returns a named cache from the underlying caching system.
getCacheDataSource() - Method in interface com.bea.wlevs.ede.api.ExternalSource
Cache serving as a source, in the form of a map.
getCacheMBeans() - Method in interface com.bea.wlevs.management.configuration.CachingSystemMBean
Returns an array of ObjectName which contains the names of the CacheMBean
getCacheNames() - Method in interface com.bea.wlevs.cache.spi.CachingSystem
Return names of caches that are part of this caching system.
getCachingSystemMBeans() - Method in interface com.bea.wlevs.management.configuration.ApplicationMBean
Returns an array of ObjectName which is the naming of the various CachingSystemMBean
getCapabilities() - Method in interface com.oracle.cep.cartridge.CapabilityProvider
Return supported capabilities defined as functions.
getCauseMessage() - Method in class com.bea.wlevs.ede.api.StatementException
 
getCauseMessage() - Method in class com.bea.wlevs.ede.api.CQLExecutionException
Returns CQL error cause.
getChannel() - Method in interface com.bea.wlevs.management.configuration.HttpPubSubAdapterMBean
Returns the pub-sub channel
getClause() - Method in interface com.oracle.cep.cartridge.ExternalPredicate
Returns predicate clause as a String.
getClockType() - Method in interface com.bea.wlevs.ede.api.Processor
 
getColumnNumber() - Method in class com.bea.wlevs.ede.api.StatementException
Returns column number on which an error was detected.
getConcurrentConsumers() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the concurrentConsumers property.
getConfigurationVersion(String) - Method in interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean
Gets the configuration version number.
getConnection() - Method in interface com.oracle.cep.cartridge.ExternalDataSource
Attempts to get a connection to the data source
getConnectionEncryptedPassword() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the connection encryptedPassword property.
getConnectionJndiName() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the connectionJndiName property.
getConnectionPassword() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the connection password property.
getConnectionUser() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the connection user property.
getCurrentSize() - Method in interface com.bea.wlevs.management.configuration.EventQueueMBean
Returns the current (used) size of Event Queue
getCurrentSize() - Method in interface com.bea.wlevs.ede.api.EventQueue
Returns the current (used) size of channel.
getDatabases() - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method retrieve the databases configured with this processor.
getDataSource() - Method in interface com.bea.wlevs.management.configuration.TableMBean
Returns JDBC data source name associated to this table.
getDeleteEvents() - Method in class com.bea.wlevs.ede.api.EventProcessingException
Returns the delete events that caused the event processing exception, or null if not applicable.
getDeploymentName() - Method in class com.bea.wlevs.management.runtime.DeploymentNotification
Returns deployment bundle (i.e. applications, libraries) name.
getDestinationJndiName() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the destinationJndiName property.
getDestinationType() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the destinationType property.
getDurableSubscriptionName() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the durableSubscriptionName property.
getEncryptedPassword() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the encryptedPassword property.
getEndOffset() - Method in class com.bea.wlevs.ede.api.StatementException
 
getEvent() - Method in class com.bea.wlevs.management.runtime.DeploymentNotification
Returns deployment event
getEventBuilderFactory() - Method in interface com.bea.wlevs.ede.api.EventType
Deprecated. As of OCEP 11.1.1.1.0, replaced by EventType.createEvent() and buildEvent().
getEventMetadata() - Method in interface com.bea.wlevs.ede.api.MetadataEnabledEvent
 
getEventPropertyName() - Method in class com.bea.wlevs.ede.api.EventPropertyException
Returns name of offending event property that caused the exception.
getEventPropertyNamesForQuerySources(String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method returns the property names for all sources referenced by the query.
getEventPropertyNamesForViewSources(String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method returns the property names for all sources referenced by the view.
getEventType() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the eventType property.
getEventType() - Method in interface com.bea.wlevs.management.configuration.TableMBean
Returns event type associated to table's rows.
getEventType() - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Returns the event type name for this channel
getEventType() - Method in interface com.bea.wlevs.management.configuration.HttpPubSubAdapterMBean
Returns the event type of events that flow through this HTTP pub-sub channel.
getEventType() - Method in interface com.bea.wlevs.ede.api.MapEventObject
Event type for this event that contains metadata about the properties of the event.
getEventType() - Method in interface com.bea.wlevs.ede.api.EventChannel
Only events of this event type are allowed to pass through this event channel.
getEventType() - Method in interface com.bea.wlevs.ede.api.ExternalSource
Source generates data of this type.
getEventType(Object) - Method in interface com.bea.wlevs.ede.api.EventTypeRepository
Retrieve the event type for an event object.
getEventType(String) - Method in interface com.bea.wlevs.ede.api.EventTypeRepository
Retrieve a previously registered even type by name.
getEventTypeName() - Method in class com.bea.wlevs.ede.api.EventPropertyException
Returns name of target event-type.
getEventTypeRepository() - Method in interface com.bea.wlevs.ede.api.Processor
Returns repository for types defined within the application.
getEventTypes() - Method in interface com.bea.wlevs.management.EventTypeRepositoryMBean
This method returns a list of all event type names.
getEvictionPolicy() - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Gets the value of the evictionPolicy property.
getExceptions() - Method in class com.bea.wlevs.ede.api.MultiStatementException
Retrieves the list of exceptions that were detected
getExternalRowsThreshold() - Method in interface com.bea.wlevs.ede.api.ExternalSource
Returns the maximum allowed external rows to join with stream events return the threshold value
getExtLibraryState(String) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method returns a string state of the installed library extension bundle.
getFunction(String, Class[], String, Map) - Method in interface com.oracle.cep.cartridge.ExternalFunctionProvider
Return a function's metadata, including its execution call-back.
getFunctionBatch(String, String, int, int) - Method in interface com.bea.wlevs.management.configuration.CartridgeMBean
Returns the specified batch of functions for the given context id.
getFunctionCount(String, String) - Method in interface com.bea.wlevs.management.configuration.CartridgeMBean
Returns the number of functions available for the given context.
getFunctions(String, String) - Method in interface com.bea.wlevs.management.configuration.CartridgeMBean
Returns information about all the functions supported by this cartrige.
getGroupNames() - Method in interface com.bea.wlevs.management.configuration.DomainMBean
Returns an array of group names that exist in the domain.
getHeartbeatTimeout() - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Gets the heart-beat timeout for the channel if it is specified.
getHostName() - Method in interface com.bea.wlevs.management.configuration.ServerMBean
Returns the server hostname.
getId() - Method in interface com.bea.wlevs.ede.api.EventChannel
Returns the event channel identity
getId() - Method in interface com.bea.wlevs.ede.api.Statement
Retrieve the ID of the statement
getId() - Method in interface com.bea.wlevs.ede.api.ExternalSource
Returns the source identity
getId() - Method in interface com.oracle.cep.cartridge.ExternalFunctionProvider
Unique identifier for function provider (cartridge).
getIdleTime() - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Gets the value of the idleTime property.
getInsertEvents() - Method in class com.bea.wlevs.ede.api.EventProcessingException
Returns the insert events that caused the event processing exception, or null if not applicable.
getInstanceProperties() - Method in interface com.bea.wlevs.management.configuration.EventBeanMBean
Get the instance properties.
getJDBCDataSource() - Method in interface com.bea.wlevs.ede.api.ExternalSource
Name of the data-source associated to this source, should it be a table.
getJndiFactory() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the jndiFactory property.
getJndiProviderUrl() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the jndiProviderUrl property.
getKeyClass() - Method in interface com.bea.wlevs.ede.api.DataProvider
Class of primary key
getKeyClass() - Method in interface com.bea.wlevs.ede.api.ExternalSource
Returns key class for cache.
getKeyPropertyNames() - Method in interface com.bea.wlevs.ede.api.DataProvider
Property names of compound key
getKeyPropertyNames() - Method in interface com.bea.wlevs.ede.api.ExternalSource
Return the key properties for cache.
getLength() - Method in interface com.bea.wlevs.ede.api.EventPropertyDescription
Returns the length of the element if it is an array or String type.
getLibraryState(String) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method returns a string state of the installed library bundle.
getLineNumber() - Method in class com.bea.wlevs.ede.api.StatementException
Returns line number on which an error was detected.
getListeners() - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Gets the value of the listeners property.
getListenPort() - Method in interface com.bea.wlevs.management.configuration.ServerMBean
Returns the server listen port.
getMap() - Method in interface com.bea.wlevs.ede.api.DataProvider
Underlying map containing provided data
getMaxSize() - Method in interface com.bea.wlevs.management.configuration.EventQueueMBean
This method reads the size of the Channel.
getMaxSize() - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Gets the value of the maxSize property.
getMaxSize() - Method in interface com.bea.wlevs.ede.api.EventQueue
Returns maximum size of channel.
getMaxThreads() - Method in interface com.bea.wlevs.management.configuration.EventQueueMBean
This method reads the maximum number of Threads associated with the Stream's WorkManager
getMaxThreads() - Method in interface com.bea.wlevs.ede.api.EventQueue
Returns maximum number of threads that a channel should use for processing events.
getMessage() - Method in class com.bea.wlevs.ede.api.StatementException
 
getMessage() - Method in class com.bea.wlevs.ede.api.MultiStatementException
 
getMessageSelector() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the messageSelector property.
getName() - Method in interface com.bea.wlevs.management.WebLogicMBean
This method returns the name of the MBean
getName() - Method in interface com.bea.wlevs.management.configuration.CartridgeMBean
Returns the name of the cartridge.
getName() - Method in interface com.bea.wlevs.ede.api.EventPropertyDescription
Returns the name of the element
getName() - Method in interface com.bea.wlevs.cache.spi.CachingSystem
Return the name of this caching system.
getName() - Method in interface com.oracle.cep.cartridge.ExternalFunctionDefinition
Returns the name of the method
getNextException() - Method in class com.bea.wlevs.ede.api.EventProcessingException
Returns the next event processing exception on this chain of exceptions.
getNotFoundFunctionName() - Method in class com.oracle.cep.cartridge.FunctionNotFoundException
 
getNumberOfBoundParameters(String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method returns the number of bound parameters which are bound for the rule identified by the preparedStatementId argument.
getObjectName() - Method in interface com.bea.wlevs.management.WebLogicMBean
It returns the ObjectName under which the MBean is registered
getOfferTimeout() - Method in interface com.bea.wlevs.management.configuration.EventQueueMBean
Returns the timeout value used for waiting up until space becomes available in the event queue.
getOfferTimeout() - Method in interface com.bea.wlevs.ede.api.EventQueue
Returns the timeout value used for waiting up until space becomes available in the event queue.
getOperatorStats() - Method in interface com.bea.wlevs.management.runtime.CQLProcessorRuntimeMBean
Returns operator-level statistics for CQL queries.
getOrder() - Method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
getOrigin() - Method in class com.bea.wlevs.ede.api.EventProcessingException
Returns the identity of the EPN stage where the exception was first originated.
getOriginalMessage() - Method in class com.bea.wlevs.ede.api.StatementException
 
getParameterCount() - Method in interface com.bea.wlevs.ede.api.PreparedStatement
Returns the number of placeholder values which must be supplied to bind the statement (i.e. the required length of the values Object array provided to the bind method).
getParameterizedValues() - Method in interface com.bea.wlevs.ede.api.BoundStatement
Returns the array of parameterized values used to bind the Statement.
getParameterTypes() - Method in interface com.oracle.cep.cartridge.ExternalFunctionDefinition
Returns method parameter types
getParams(String) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method retrieves all parameter values for a parameterized query identified by the ruleId argument.
getParams(String, String) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method retrieves the set of parameter values with the given name for a parameterized query identified by the ruleId argument.
getParamsCount(String) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method returns the number of parameters which must be bound for the rule identified by the ruleId argument.
getPartitionOrderCapacity() - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
The capacity (i.e.number of buckets) of partition used for partition-ordered sources (e.g. relation/stream).
getPartitionOrderCapacity() - Method in interface com.bea.wlevs.ede.api.EventChannel
The capacity (i.e.number of buckets) of partition used for partition-ordered sources (e.g. relation/stream).
getPassword() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the password property.
getPlaybackConfiguration() - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Returns all the configuration values specified for playback in this stage.
getPlaybackConfiguration() - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
getPreparedStatement() - Method in interface com.bea.wlevs.ede.api.BoundStatement
Returns the PreparedStatement that created and is managing this BoundStatement.
getPrimaryKey() - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Returns primary key of relation, or an empty list for streams.
getPrimaryKey() - Method in interface com.bea.wlevs.ede.api.EventChannel
Returns primary key of relation, or an empty list for streams.
getProperties() - Method in interface com.bea.wlevs.ede.api.EventType
Returns all event properties for this event type.
getProperty(String) - Method in interface com.bea.wlevs.ede.api.EventType
Returns event property named propertyName.
getPropertyLength(String) - Method in interface com.bea.wlevs.ede.api.EventType
Returns the length of the property, if it is of array or String type and the length definition is known.
getPropertyName() - Method in class com.bea.wlevs.ede.api.UnsupportedPropertyException
Returns name of offending event property.
getPropertyNames() - Method in interface com.bea.wlevs.ede.api.EventType
Get all valid property names for the event type.
getPropertyType(String) - Method in interface com.bea.wlevs.ede.api.EventType
Get the type of an event property as returned by the "getter" method for that property.
getPropertyValue(Object, String) - Method in interface com.bea.wlevs.ede.api.EventType
Retrieves property value from an event object of this event type.
getProvider() - Method in interface com.bea.wlevs.management.configuration.EventBeanMBean
Return the name specified on the 'provider' attribute in the spring configuration for this event-bean or adapter
getProvider() - Method in interface com.bea.wlevs.management.configuration.CachingSystemMBean
Returns the provider type of this caching system.
getProvider() - Method in interface com.bea.wlevs.cache.spi.CachingSystem
Return the provider of this caching system.
getQuery() - Method in interface com.bea.wlevs.ede.api.Statement
Retrieve the query string of the statement
getQueryStats() - Method in interface com.bea.wlevs.management.runtime.CQLProcessorRuntimeMBean
Returns query-related statistics.
getReason() - Method in class com.bea.wlevs.ede.api.EventRejectedException
Retrieves the reason the EPN node rejected the event(s).
getRecordConfiguration() - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Returns all the configuration values specified for recording in this stage.
getRecordConfiguration() - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
getRecordingSessionsList(String, long) - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Returns all the recording sessions available in the server.
getRecordingStageName() - Method in interface com.bea.wlevs.ede.api.EventMetadata
Returns the name of the stage from which the event was recorded.
getRecordPlayback() - Method in interface com.bea.wlevs.management.configuration.StageMBean
Returns the ObjectName of the MBean that should be used for managing record and playback on this stage.
getRecordTime() - Method in interface com.bea.wlevs.ede.api.EventMetadata
Returns the record time for the event.
getRejectedEvents() - Method in class com.bea.wlevs.ede.api.EventRejectedException
Retrieves the collection of rejected events.
getReturnType() - Method in interface com.oracle.cep.cartridge.ExternalFunctionDefinition
Get the return type of the function
getRule(String) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method fetches a rule with the given id.
getRules(String[]) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method fetches the rules for ids that are in the array.
getSecureListenPort() - Method in interface com.bea.wlevs.management.configuration.ServerMBean
Returns the server secure listen port.
getSelectorQueries() - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Returns a list containing the IDs of the queries that route to this channel in its selector configuration.
getServerContextPath() - Method in interface com.bea.wlevs.management.configuration.HttpPubSubAdapterMBean
Return the server context path
getServerContexts() - Method in interface com.bea.wlevs.management.configuration.CartridgeMBean
Returns all the server level context names available for this cartridge.
getServerMBeans() - Method in interface com.bea.wlevs.management.configuration.DomainMBean
This method returns ObjectName for all WebLogic Event Servers available in the domain.
getServerRuntimeMBean() - Method in interface com.bea.wlevs.management.runtime.DomainRuntimeMBean
Returns object name of local server runtime.
getServerUrl() - Method in interface com.bea.wlevs.management.configuration.HttpPubSubAdapterMBean
Returns the HTTP pub-sub server URL
getServiceDependencies(BundleContext, ConfigurableListableBeanFactory) - Method in class com.bea.wlevs.spring.support.ServiceDependencyBeanFactoryPostProcessor
 
getSessionAckModeName() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the sessionAckModeName property.
getSessionManager() - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
getStage() - Method in class com.bea.wlevs.ede.api.ConfigurationException
 
getStageClassName() - Method in interface com.bea.wlevs.management.configuration.EventBeanMBean
Return the class of this event-bean or adapter as specified in the spring configuration for this event-bean or adapter
getStageMBeans() - Method in interface com.bea.wlevs.management.configuration.ApplicationMBean
Returns an array of ObjectName which is the naming of the various StageMBean
getStageRuntimeMBeans() - Method in interface com.bea.wlevs.management.runtime.ApplicationRuntimeMBean
Returns an array of ObjectName which is the naming of the various StageRuntimeMBean
getStartOffset() - Method in class com.bea.wlevs.ede.api.StatementException
 
getState() - Method in interface com.bea.wlevs.management.configuration.ApplicationMBean
Deprecated. use AppDeploymentMBean#getState()
getState() - Method in interface com.bea.wlevs.management.runtime.ServerRuntimeMBean
This method returns the state of the server
getState() - Method in interface com.bea.wlevs.management.runtime.ApplicationRuntimeMBean
Returns the application runtime state.
getState() - Method in class com.bea.wlevs.management.runtime.DeploymentNotification
Returns deployment event state.
getState(String) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method gets the deployment state of an application.
getStatement() - Method in class com.bea.wlevs.ede.api.StatementException
 
getStatement(String) - Method in interface com.bea.wlevs.ede.api.StatementManager
Retrieve compiled statement through query id
getStatementManager() - Method in interface com.bea.wlevs.ede.api.Processor
Returns statement manager for accessing compiled statements defined for this processor.
getStatements() - Method in interface com.bea.wlevs.ede.api.StatementManager
 
getStreamStats() - Method in interface com.bea.wlevs.management.runtime.CQLProcessorRuntimeMBean
Returns source-level statistics for CQL queries.
getSuperTypes() - Method in interface com.bea.wlevs.ede.api.EventType
Returns an array of event types that are super to this event type, from which this event type inherited event properties.
getSystemStats() - Method in interface com.bea.wlevs.management.runtime.CQLProcessorRuntimeMBean
Returns system-level statistics.
getTableName() - Method in interface com.bea.wlevs.management.configuration.TableMBean
Get the table name of the database table
getTableName() - Method in interface com.bea.wlevs.ede.api.ExternalSource
Table name of the database table
getTime() - Method in interface com.bea.wlevs.ede.api.Processor
 
getTimestampExpression() - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Returns expression that defines application time-stamp for event channel.
getTimestampExpression() - Method in interface com.bea.wlevs.ede.api.EventChannel
Returns expression used to calculate the application timestamp.
getTimestampProperty() - Method in class com.bea.wlevs.ede.api.IllegalTimestampPropertyException
Returns offending timestamp property.
getTimeToLive() - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Gets the value of the timeToLive property.
getType() - Method in interface com.bea.wlevs.management.WebLogicMBean
It returns the type of the MBean
getType() - Method in interface com.bea.wlevs.ede.api.EventPropertyDescription
Returns the type of the element
getTypeAliases() - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method fetches all the aliases in this processor.
getTypeName() - Method in interface com.bea.wlevs.ede.api.EventType
Returns the registered event type name associated with this EventType.
getUnderlyingType() - Method in interface com.bea.wlevs.ede.api.EventType
Get the class that represents the Java type of the event type.
getUnknownEventType() - Method in class com.bea.wlevs.ede.api.UnknownEventTypeException
 
getUnsupportedEventPropertyType() - Method in class com.bea.wlevs.ede.api.UnsupportedEventPropertyTypeException
 
getUpdateEvents() - Method in class com.bea.wlevs.ede.api.EventProcessingException
Returns the update events that caused the event processing exception, or null if not applicable.
getUser() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the user property.
getUserDefinedFunctionName() - Method in class com.bea.wlevs.ede.api.UserDefinedFunctionExecutionException
Returns the name of the offending UDF.
getUserFunctionStats() - Method in interface com.bea.wlevs.management.runtime.CQLProcessorRuntimeMBean
Returns user-defined function statistics.
getValue(Object) - Method in interface com.bea.wlevs.ede.api.EventProperty
Returns event property value.
getView(String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method fetches a view with the given id.
getViews(String[]) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method fetches a set of views with the given ids.
getWorkManager() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the workManager property.
getWorkManagerName() - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Gets the value of the workManagerName property.
getWritePolicy() - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Gets the WritePolicy that is in effect.

H

handleFault(Throwable, String[]) - Method in interface com.bea.wlevs.ede.api.FaultHandler
This method is called-back informing handler of a fault that happened while processing an event, or a batch of events, allowing client to provide custom handling of faults.
hasCustomBuilder() - Method in interface com.bea.wlevs.ede.api.JavaBeanEventType
Returns true if a user-defined (custom) event builder factory has been set for this event type.
hasLength() - Method in class com.bea.wlevs.ede.api.Type
 
hasLocation() - Method in class com.bea.wlevs.ede.api.StatementException
Indicates whether or not location information is available for this exception
hasOffsetInformation() - Method in class com.bea.wlevs.ede.api.StatementException
Indicates whether this exception has offset information.
hasServiceProperty(Class) - Method in class com.bea.wlevs.spring.support.ServiceDependencyBeanFactoryPostProcessor
 
hasServiceProperty(PropertyDescriptor) - Method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
HeartbeatAware - interface com.bea.wlevs.ede.api.HeartbeatAware.
Interface to be implemented by beans that want to receive heartbeat events.
HttpPubSubAdapterMBean - interface com.bea.wlevs.management.configuration.HttpPubSubAdapterMBean.
This MBean manages the configuration of a HttpPubSubAdapter instance

I

ID - Static variable in class com.bea.wlevs.management.configuration.CQLProcessorMBean.FunctionParameter
Function name.
ID - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters
Used to identify Id value of a rule.
IllegalAssemblyException - exception com.bea.wlevs.ede.api.IllegalAssemblyException.
This exception is raised when the EPN is assembled with an illegal configuration, such as the connection of stages that cannot be linked together.
IllegalPropertyException - exception com.bea.wlevs.ede.api.IllegalPropertyException.
Configuration exception raised when a EPN component property is configured with an illegal value.
IllegalTimestampPropertyException - exception com.bea.wlevs.ede.api.IllegalTimestampPropertyException.
This exception is raised when a timestamp property is defined on an event type that does not define this property, or if the timestamp property is not of type Long or long.
INITIALIZING - Static variable in interface com.bea.wlevs.management.configuration.ApplicationMBean
Application State:
InitializingBean - interface com.bea.wlevs.ede.api.InitializingBean.
Interface to be implemented by beans that need to react once all their properties have been set by the EPN container, for example, to perform custom initialization, or merely to check that all mandatory properties have been set.
injectServices(Object, BundleContext) - Static method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
Convenience function for injecting services.
injectServices(Object, String, BundleContext, ClassLoader) - Static method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
injectServices(Object, String, ClassLoader) - Method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
INPUT_TYPES - Static variable in class com.bea.wlevs.management.configuration.CartridgeMBean.FunctionDescKeys
This will be the input param type names of the function in an ordered List of Strings.
INSTANCE_ID - Static variable in interface com.bea.wlevs.ede.api.InstanceConstants
The application unique identity of an instance.
INSTANCE_PROVIDER - Static variable in interface com.bea.wlevs.ede.api.InstanceConstants
 
InstanceConstants - interface com.bea.wlevs.ede.api.InstanceConstants.
Predefined property names used in instance creation and advertisement
INT - Static variable in class com.bea.wlevs.ede.api.Type
 
INTERNAL - Static variable in class com.bea.wlevs.ede.api.Processor.ClockType
 
INTERVAL - Static variable in class com.bea.wlevs.ede.api.Type
 
isApplicationTimestamped() - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Returns if channel is application timestamped, that is, application is responsible for assigning a timestamp to each event.
isApplicationTimestamped() - Method in interface com.bea.wlevs.ede.api.EventChannel
Returns if channel is application timestamped, that is, application is responsible for assigning a timestamp to each event.
isBatchEvents() - Method in interface com.bea.wlevs.ede.api.EventChannel
Returns if channel is batching over timestamp
isConfigurationVersionEnabled() - Method in interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean
Gets the configuration versioning state.
isDurableSubscription() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the durableSubscription property.
isFailWhenRejected() - Method in interface com.bea.wlevs.management.configuration.EventQueueMBean
Returns true if an event processing exception should be raised when event queue is full and no space is available after offer timeout expires.
isFailWhenRejected() - Method in interface com.bea.wlevs.ede.api.EventQueue
Returns true if an event processing exception should be raised when event queue is full and no space is available after offer timeout expires.
isPlayingBack() - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Returns true if events are being played back to this stage.
isPlayingBack() - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
isProperty(String) - Method in interface com.bea.wlevs.ede.api.EventType
Check that the given property name is valid for this event type, ie. that is exists in the event type.
isRecording() - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Returns true if this stage is currently recording events flowing out of the stage.
isRecording() - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
isRelation() - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Returns if event channel is carrying relations, instead of streams.
isRelation() - Method in interface com.bea.wlevs.ede.api.EventChannel
Returns if event channel is carrying relations, instead of streams.
isRuleStarted(String) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
Use this to find out whether rule is started and is processing events.
isSessionTransacted() - Method in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
Gets the value of the sessionTransacted property.
ISSTREAM - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters
Used to identify whether it produced stream or a relation.
isSystemTimestamped() - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Returns if channel is system timestamped, that is, the system is responsible for assigning a timestamp to each event.
isSystemTimestamped() - Method in interface com.bea.wlevs.ede.api.EventChannel
Returns if channel is system timestamped, that is, the system is responsible for assigning a timestamp to each event.
isTotalOrder() - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Returns if application time published is always strictly greater than the last value used.
isTotalOrder() - Method in interface com.bea.wlevs.ede.api.EventChannel
Returns if application time published is always strictly greater than the last value used.
iterator() - Method in class com.bea.wlevs.ede.api.EventProcessingException
 

J

JavaBeanEventType - interface com.bea.wlevs.ede.api.JavaBeanEventType.
Marker interface for EventTypes that handle JavaBean-type classes.
JMSAdapterMBean - interface com.bea.wlevs.management.configuration.JMSAdapterMBean.
This MBean manages the configuration of a JMS adapter instance.

K

Key - interface com.bea.wlevs.ede.api.Key.
 

L

LARGE_BATCH - Static variable in class com.bea.wlevs.ede.api.EventRejectedException.Reason
 
LFU - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Specifies eviction policy of Least Frequently Used.
listDeployedApplications() - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method returns a java.util.Collection of application names which has been deployed in this Weblogic Event Server instance.
listDeployedExtLibraries() - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method returns a java.util.Collection of library extension bundle name which has been deployed in this Weblogic Event Server instance from library extension directory.
listDeployedLibraries() - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method returns a java.util.Collection of library bundle name which has been deployed in this Weblogic Event Server instance from library directory.
listFunctions(String, Map) - Method in interface com.oracle.cep.cartridge.ExternalFunctionProvider
Return a list of all functions supported by this provider.
loadStatements(URL) - Method in interface com.bea.wlevs.ede.api.Processor
Load queries from an XML document located at the specified URL.
lookupApplicationMBean(String) - Method in interface com.bea.wlevs.management.configuration.DomainMBean
Returns the ObjectName of the ApplicationMBean.
lookupApplicationRuntimeMBean(String) - Method in interface com.bea.wlevs.management.runtime.ServerRuntimeMBean
Returns the ObjectName of the ApplicationRuntimeMBean.
lookupApplicationsInGroup(String) - Method in interface com.bea.wlevs.management.configuration.DomainMBean
Returns an array of String containing the name of all applications that are part of the group specified by groupName
lookupCachingSystemMBean(String) - Method in interface com.bea.wlevs.management.configuration.ApplicationMBean
Returns the ObjectName of the CachingSystemMBean
lookupEventType(String) - Method in interface com.bea.wlevs.management.EventTypeRepositoryMBean
This method returns a map of event type property name and event type property type.
lookupGroupMembers(String) - Method in interface com.bea.wlevs.management.configuration.DomainMBean
Deprecated. Use lookupServersInGroup instead.
lookupPrimaryInGroup(String) - Method in interface com.bea.wlevs.management.runtime.DomainRuntimeMBean
Returns the name of the primary server of the group specified by groupName.
lookupServerMBean(String) - Method in interface com.bea.wlevs.management.configuration.DomainMBean
Returns the ObjectName for the ServerMBean.
lookupServersInGroup(String) - Method in interface com.bea.wlevs.management.configuration.DomainMBean
Returns an array of ObjectName for all servers that are part of the group specified by groupName
lookupStageMBean(String) - Method in interface com.bea.wlevs.management.configuration.ApplicationMBean
Returns the ObjectName of the StageMBean
lookupStageRuntimeMBean(String) - Method in interface com.bea.wlevs.management.runtime.ApplicationRuntimeMBean
Returns the ObjectName of the StageMBean
LRU - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Specifies eviction policy of Least Recently Used.

M

Manageable - interface com.bea.wlevs.ede.api.Manageable.
Marker interface to denote monitoring and configuration capability.
ManagementConstants - interface com.bea.wlevs.management.ManagementConstants.
Management constants to be used by client applications
ManagementRuntimeException - exception com.bea.wlevs.management.ManagementRuntimeException.
Deprecated.  
ManagementRuntimeException() - Constructor for class com.bea.wlevs.management.ManagementRuntimeException
Deprecated. Default constructor.
ManagementRuntimeException(Throwable) - Constructor for class com.bea.wlevs.management.ManagementRuntimeException
Deprecated. Constructor with a cause
MapEventObject - interface com.bea.wlevs.ede.api.MapEventObject.
An event may either be represented as a JavaBean or as a Map.
MapEventType - interface com.bea.wlevs.ede.api.MapEventType.
Marker for map-type EventTypes
MaxSize - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Integer value with max-size configuration value
MaxThreads - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Integer value with max-threads configuration value
MBEAN_NAME - Static variable in interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.EventTypeRepositoryMBean
This MBean is registered using the following MBEAN_TYPE.
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.JMSAdapterMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.StreamMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.TableMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.EventChannelMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.HttpPubSubAdapterMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.ServerMBean
This MBean is registered using the following MBEAN_TYPE.
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.CartridgeMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.ApplicationMBean
This MBean is registered using the following MBEAN_TYPE.
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.EventBeanMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.DomainMBean
This MBean is registered using the following MBEAN_TYPE.
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.DefaultAdapterMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.AdapterMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.CachingSystemMBean
 
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.runtime.ServerRuntimeMBean
This MBean is registered using the following MBEAN_TYPE.
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.runtime.ApplicationRuntimeMBean
This MBean is registered using the following MBEAN_TYPE.
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.runtime.CQLProcessorRuntimeMBean
This MBean is registered using the following MBEAN_TYPE.
MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.runtime.DomainRuntimeMBean
This MBean is registered using the following MBEAN_TYPE.
MBEAN_TYPE - Static variable in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This MBean is registered using the following MBEAN_TYPE.
MBeanOperationsException - exception com.bea.wlevs.management.MBeanOperationsException.
Deprecated.  
MBeanOperationsException(String) - Constructor for class com.bea.wlevs.management.MBeanOperationsException
Deprecated. Construct a MBeanOperationsException with a specific message
MetadataEnabledEvent - interface com.bea.wlevs.ede.api.MetadataEnabledEvent.
An event that has instance metadata associated with it.
MultiStatementException - exception com.bea.wlevs.ede.api.MultiStatementException.
Exception raised if one or more errors are detected when loading a set of statements in bulk
MultiStatementException(URL, List) - Constructor for class com.bea.wlevs.ede.api.MultiStatementException
 

N

Name - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters
User specified name for the recording
NAME - Static variable in class com.bea.wlevs.management.configuration.CartridgeMBean.FunctionDescKeys
This will be String value with the name of the function
NAME_PROPERTY - Static variable in interface com.bea.wlevs.management.ManagementConstants
Name attribute used to identify MBean
NRU - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Specifies eviction policy of Not Recently Used.

O

OBJECT - Static variable in class com.bea.wlevs.ede.api.Type
 
onDeleteEvent(Object) - Method in interface com.bea.wlevs.ede.api.RelationSink
Call-back method for receiving events of type delete.
onEvent(List) - Method in interface com.bea.wlevs.ede.api.EventSink
Deprecated. Callback method for receiving events.
onEvents(Collection, Collection, Collection) - Method in interface com.bea.wlevs.ede.api.BatchRelationSink
Call-back method for receiving a batch of events.
onHeartbeat(long) - Method in interface com.bea.wlevs.ede.api.HeartbeatAware
Callback method for receiving events of type heartbeat.
onInsertEvent(Object) - Method in interface com.bea.wlevs.ede.api.StreamSink
Call-back method for receiving events of type insert.
onInsertEvents(Collection) - Method in interface com.bea.wlevs.ede.api.BatchStreamSink
Call-back method for receiving a batch of events of type insert.
onUpdateEvent(Object) - Method in interface com.bea.wlevs.ede.api.RelationSink
Call-back method for receiving events of type update.
ORDERING_CONSTRAINT - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters
Used to specify the ordering constraint of a query or view.

P

PARTITION_EXPRESSION - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters
Used to specify the partition expression for partition ordered rules.
partition(Object) - Method in interface com.bea.wlevs.channel.EventPartitioner
Return integer representing index of listener connected to a Event Channel.
PlaybackSpeed - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Float value with playback speed parameter value
postProcessAfterInitialization(BundleContext, ConfigurableListableBeanFactory, Object, String) - Method in interface com.bea.wlevs.spring.support.BeanPostProcessorService
Apply this BeanPostProcessor to the given new bean instance after any bean initialization callbacks (like InitializingBean's afterPropertiesSet or a custom init-method).
postProcessAfterInitialization(Object, String) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
postProcessAfterInitialization(Object, String) - Method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
process FactoryBean created objects, since these will not have had services injected.
postProcessAfterInstantiation(Object, String) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
postProcessBeforeDestruction(BundleContext, ConfigurableListableBeanFactory, Object, String) - Method in interface com.bea.wlevs.spring.support.BeanPostProcessorService
Apply this BeanPostProcessor to the given bean instance before its destruction.
postProcessBeforeDestruction(Object, String) - Method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
postProcessBeforeInitialization(BundleContext, ConfigurableListableBeanFactory, Object, String) - Method in interface com.bea.wlevs.spring.support.BeanPostProcessorService
Apply this BeanPostProcessor to the given new bean instance before any bean initialization callbacks (like InitializingBean's afterPropertiesSet or a custom init-method).
postProcessBeforeInitialization(Object, String) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
postProcessBeforeInstantiation(Class, String) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
postProcessPropertyValues(PropertyValues, PropertyDescriptor[], Object, String) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
postProcessPropertyValues(PropertyValues, PropertyDescriptor[], Object, String) - Method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
PreparedStatement - interface com.bea.wlevs.ede.api.PreparedStatement.
Statement that contains placeholders for values to be bound at runtime.
prepareStatement(String, List, ExternalPredicate) - Method in interface com.oracle.cep.cartridge.ExternalConnection
Creates a ExternalPreparedStatement object for sending statements to external data-sources.
Processor - interface com.bea.wlevs.ede.api.Processor.
Processors filter, correlate, aggregate, and perform other event processing functions.
Processor.ClockType - class com.bea.wlevs.ede.api.Processor.ClockType.
 
ProcessorFactory - interface com.bea.wlevs.ede.api.ProcessorFactory.
Factory for creating Processors.
ProcessorMBean - interface com.bea.wlevs.management.configuration.ProcessorMBean.
 
ProcessorMBean.RuleConfigParameters - class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters.
Values defined here identify rule configuration parameters.
ProcessorMBean.RuleType - class com.bea.wlevs.management.configuration.ProcessorMBean.RuleType.
 
ProviderName - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters
The name of the event store provider that was used for this recording
ProviderName - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
The provider name string value
ProxyFactory - interface com.bea.wlevs.spring.support.ProxyFactory.
 
ProxyFactoryService - interface com.bea.wlevs.spring.support.ProxyFactoryService.
 
put(String, Object) - Method in interface com.bea.wlevs.ede.api.EventBuilder
Set the property of the event being created to the specified value.
putBundleProperty(String, String, Object) - Method in interface com.bea.wlevs.spring.support.BundlePropertyAdminMutator
 

Q

QUERY - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleType
 
queryChangeHistory(String, long, long) - Method in interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean
Queries the change records for the specified application.
queryChangeHistoryAsString(String, long, long) - Method in interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean
Queries the change records for the specified application.
queryConfigResourceChangeHistory(String, long, long) - Method in interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean
Queries the change records for the configuration resource within the specified application.
queryConfigResourceChangeHistoryAsString(String, long, long) - Method in interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean
Queries the change records for the configuration resource within the specified application.

R

RecordingEndTime - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters
Time at which this recording ended
RecordingStartTime - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters
Time at which this recording started
RecordPlaybackMBean - interface com.bea.wlevs.management.configuration.RecordPlaybackMBean.
 
RecordPlaybackMBean.ConfigParameters - class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters.
 
RecordPlaybackMBean.RecordSessionParameters - class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters.
 
registerEventType(String, Class) - Method in interface com.bea.wlevs.ede.api.EventTypeRepository
Registers POJO event types into repository.
registerEventType(String, Class, EventBuilder.Factory) - Method in interface com.bea.wlevs.ede.api.EventTypeRepository
Registers POJO event types into repository specifying an EventBuilder.Factory for the engine to use when instantiating events of this type.
registerEventType(String, List) - Method in interface com.bea.wlevs.ede.api.EventTypeRepository
Registers a TupleValue event type.
registerEventType(String, List, EventBuilder.Factory) - Method in interface com.bea.wlevs.ede.api.EventTypeRepository
Similar to #registerEventType(String, Map<String,Class>).
registerEventType(String, Map) - Method in interface com.bea.wlevs.ede.api.EventTypeRepository
Registers Map event types into repository.
registerEventType(String, Map, EventBuilder.Factory) - Method in interface com.bea.wlevs.ede.api.EventTypeRepository
Registers Map event types into repository specifying an EventBuilder.Factory for the engine to use when instantiating events of this type.
RejectionPolicy - class com.bea.wlevs.channel.RejectionPolicy.
Rejection policies for events when stream reaches max size.
RelationSender - interface com.bea.wlevs.ede.api.RelationSender.
A RelationSender sends events emitted by an RelationSource to RelationSink listeners.
RelationSink - interface com.bea.wlevs.ede.api.RelationSink.
Interface to be implemented by beans that want to receive events modeling a OCEP relation.
RelationSource - interface com.bea.wlevs.ede.api.RelationSource.
Interface to be implemented by beans that want to emit events modeling a OCEP relation.
removeChangeHistory(String, long, long) - Method in interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean
Removes the change records for the specified application.
removeSelectorQuery(String) - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Removes the specified query ID from the selector configuration for this channel.
Repeat - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Boolean value with playback repeat parameter value
replaceAllBoundParameters(String, String[], String[]) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method replaces all parameter values for a parameterized query identified by the ruleId argument with the parameter values provided.
replaceBoundParameters(String, String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method replaces single parameter values for a parameterized query identified by the ruleId argument.
replaceParams(String, String[]) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method replaces all parameter values for a parameterized query identified by the ruleId argument with the parameter values provided.
replaceParams(String, String[], String[]) - Method in interface com.bea.wlevs.management.configuration.EPLProcessorMBean
This method replaces all parameter values for a parameterized query identified by the ruleId argument.
replaceQuery(String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
Replaces the query string on the query with the specified id.
replaceQuery(String, String, String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
Replaces the query string on the query with the specified id.
replaceRule(String, String) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method will replace an existing EPL rule by another rule.
replaceRules(Map) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method will replace several existing EPL rules.
replaceTypeAlias(String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will replace an existing alias of the type.
replaceView(String, String, List) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will replace an existing view by another view.
replaceView(String, String, List, String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method will replace an existing view by another view.
resolvePlaceholder(String, Properties) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Resolve the placeholder in the configuration system.
ResumableBean - interface com.bea.wlevs.ede.api.ResumableBean.
Interface to be implemented by beans that need to prepare (e.g. acquire or configure resources) before resuming work.
resume(String) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method resumes a deployed application.
RETURN_TYPE - Static variable in class com.bea.wlevs.management.configuration.CQLProcessorMBean.FunctionParameter
Function return type.
RETURN_TYPE - Static variable in class com.bea.wlevs.management.configuration.CartridgeMBean.FunctionDescKeys
This will be a String containing the return paramter type name of the function.
RULE - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleType
 
RULE_TYPE - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters
Used to identify the type of a rule (query or view or rule).
RunnableBean - interface com.bea.wlevs.ede.api.RunnableBean.
Interface to be implemented by beans that want to be run in a thread.
RUNNING - Static variable in interface com.bea.wlevs.management.configuration.ApplicationMBean
 
RUNNING - Static variable in interface com.bea.wlevs.management.runtime.ServerRuntimeMBean
 

S

ScheduleEndTime - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Long value with scheduled record/playback end time
schedulePlayback(long, long, float, boolean) - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Schedules events to be played back to this stage at the specified time.
scheduleRecord(long, long) - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Configures a stage with the time range during which events from from the stage will be recorded.
ScheduleStartTime - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Long value with scheduled record/playback start time
ScheduleTimeDuration - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Long value with scheduled record/playback duration
SCHEMA - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters
Used to identify value indicating if a rule is started or not.
sendDeleteEvent(Object) - Method in interface com.bea.wlevs.ede.api.RelationSender
Send an event of type delete downstream to RelationSink listeners in the EPN.
sendEvent(List, List) - Method in interface com.bea.wlevs.ede.api.EventSender
Deprecated. Send a list of events to the downstream element in the EPN.
sendEvents(Collection, Collection, Collection) - Method in interface com.bea.wlevs.ede.api.BatchRelationSender
Send a batch of events of any type (insert, update or delete) downstream to BatchStreamSink listeners in the EPN.
sendHeartbeat(long) - Method in interface com.bea.wlevs.ede.api.StreamSender
Send an event of type heart-beat downstream to StreamSink listeners in the EPN.
sendInsertEvent(Object) - Method in interface com.bea.wlevs.ede.api.StreamSender
Send an event of type insert downstream to StreamSink listeners in the EPN.
sendInsertEvents(Collection) - Method in interface com.bea.wlevs.ede.api.BatchStreamSender
Send a batch of events of type insert downstream to BatchStreamSink listeners in the EPN.
sendUpdateEvent(Object) - Method in interface com.bea.wlevs.ede.api.RelationSender
Send an event of type update downstream to RelationSink listeners in the EPN.
SERVER_CONTEXT_LINK_ID - Static variable in interface com.oracle.cep.cartridge.ExternalConstants
Service property used to denote a ExternalFunctionProvider's link id.
ServerMBean - interface com.bea.wlevs.management.configuration.ServerMBean.
This MBean represents the configuration of an WebLogic Event Server instance.
ServerRuntimeMBean - interface com.bea.wlevs.management.runtime.ServerRuntimeMBean.
This MBean provides runtime information for an instance of an OEP server.
SERVICE_FILTER - Static variable in interface com.bea.wlevs.ede.api.EventTypeRepository
 
SERVICE_ID - Static variable in interface com.bea.wlevs.ede.api.EventTypeRepository
 
ServiceDependencyBeanFactoryPostProcessor - class com.bea.wlevs.spring.support.ServiceDependencyBeanFactoryPostProcessor.
 
ServiceDependencyBeanFactoryPostProcessor() - Constructor for class com.bea.wlevs.spring.support.ServiceDependencyBeanFactoryPostProcessor
 
ServiceInjectionBeanPostProcessor - class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor.
BeanPostProcessor that injects OSGi services.
ServiceInjectionBeanPostProcessor() - Constructor for class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
SessionName - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Name of the recording session
setApplicationIdentity(String) - Method in interface com.bea.wlevs.ede.api.ApplicationIdentityAware
Sets the application id of the containing EPN.
setBeanClassLoader(ClassLoader) - Method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
setBeanFactory(BeanFactory) - Method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
setBigDecimal(int, BigDecimal) - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Sets the designated parameter to the given Java BigDecimal value.
setBoolean(int, boolean) - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Sets the designated parameter to the given Java boolean value.
setBundleContext(BundleContext) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
setBundleContext(BundleContext) - Method in class com.bea.wlevs.spring.support.ServiceInjectionBeanPostProcessor
 
setBytes(int, byte[]) - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Sets the designated parameter to the given Java array of bytes.
setClockType(Processor.ClockType) - Method in interface com.bea.wlevs.ede.api.Processor
 
setDelegateClassLoader(ClassLoader) - Method in interface com.bea.wlevs.ede.api.Processor
Sets the ClassLoader to use to resolve user defined functions.
setDouble(int, double) - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Sets the designated parameter to the given Java double value.
setEndOffset(int) - Method in class com.bea.wlevs.ede.api.StatementException
 
setEventMetadata(EventMetadata) - Method in interface com.bea.wlevs.ede.api.MetadataEnabledEvent
 
setEventSender(EventSender) - Method in interface com.bea.wlevs.ede.api.EventSource
Deprecated. Set the EventSender for this EventSource.
setEventSender(StreamSender) - Method in interface com.bea.wlevs.ede.api.StreamSource
EPN nodes implementing this interface will be injected with an StreamSender by the framework.
setEvictionPolicy(String) - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Sets the value of the evictionPolicy property.
setFailWhenRejected(boolean) - Method in interface com.bea.wlevs.management.configuration.EventQueueMBean
Raise an EventProcessingException if the event queue is full when the offer timeout expires.
setFailWhenRejected(boolean) - Method in interface com.bea.wlevs.ede.api.EventQueue
Raise an EventProcessingException if the event queue is full when the offer timeout expires.
setFileEncoding(String) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set the encoding to use for parsing properties files.
setFloat(int, float) - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Sets the designated parameter to the given Java float value.
setFunctionBeans(Map) - Method in interface com.bea.wlevs.ede.api.Processor
Sets map of beans containing user-defined functions for this processor.
setHeartbeatTimeout(Long) - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Sets the heart-beat timeout for a channel.
setIdleTime(long) - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Sets the value of the idleTime property.
setIgnoreResourceNotFound(boolean) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set if failure to find the property resource should be ignored.
setIgnoreUnresolvablePlaceholders(boolean) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set whether to ignore unresolvable placeholders.
setInt(int, int) - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Sets the designated parameter to the given Java int value.
setListeners(Map) - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Sets the value of the listeners property.
setListeners(String, List) - Method in interface com.bea.wlevs.cache.spi.CachingSystem
sets listeners on a named cache in the underlying caching system.
setLoader(String, Object) - Method in interface com.bea.wlevs.cache.spi.CachingSystem
Sets a loader on the named cache in the underlying caching system.
setLocalOverride(boolean) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set whether local properties override properties from files.
setLocation(Resource) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set a location of a properties file to be loaded.
setLocations(Resource[]) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set locations of properties files to be loaded.
setLong(int, long) - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Sets the designated parameter to the given Java long value.
setMaxSize(int) - Method in interface com.bea.wlevs.management.configuration.EventQueueMBean
This method sets the size of the Channel.
setMaxSize(int) - Method in interface com.bea.wlevs.ede.api.EventQueue
Maximum number of events that a channel can hold at a time.
setMaxSize(long) - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Sets the value of the maxSize property.
setMaxThreads(int) - Method in interface com.bea.wlevs.management.configuration.EventQueueMBean
This method sets the maximum number of Threads associated with the Stream's WorkManager
setMaxThreads(int) - Method in interface com.bea.wlevs.ede.api.EventQueue
Maximum number of threads that a channel should use for processing events.
setNextException(EventProcessingException) - Method in class com.bea.wlevs.ede.api.EventProcessingException
Sets next exception of this chain of event processing exceptions.
setNull(int, int) - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Sets the designated parameter to Null.
setOfferTimeout(long) - Method in interface com.bea.wlevs.management.configuration.EventQueueMBean
Sets the timeout value used when the event queue is full and a pending insert (offer) is blocked.
setOfferTimeout(long) - Method in interface com.bea.wlevs.ede.api.EventQueue
Sets the timeout value used when the event queue is full and a pending insert (offer) is blocked.
setOptimize(boolean) - Method in interface com.bea.wlevs.spring.support.ProxyFactory
 
setPlaceholderPrefix(String) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set the prefix that a placeholder string starts with.
setPlaceholderSuffix(String) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set the suffix that a placeholder string ends with.
setPlaybackConfiguration(Map) - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Saves the playback configuration values specified.
setProperties(Properties) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set local properties, e.g. via the "props" tag in XML bean definitions.
setPropertiesArray(Properties[]) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set local properties, e.g. via the "props" tag in XML bean definitions, allowing for merging multiple properties sets into one.
setProxyTargetClass(boolean) - Method in interface com.bea.wlevs.spring.support.ProxyFactory
 
setRecordConfiguration(Map) - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Saves the record configuration values specified.
setRecordingStageName(String) - Method in interface com.bea.wlevs.ede.api.EventMetadata
Sets the name of the stage from which the event was recorded.
setRecordTime(long) - Method in interface com.bea.wlevs.ede.api.EventMetadata
Sets the record time for this event.
setSearchSystemEnvironment(boolean) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set whether to search for a matching system environment variable if no matching system property has been found.
setSelectorQueries(List) - Method in interface com.bea.wlevs.management.configuration.EventChannelMBean
Configures selector for this channel with the given query IDs.
setSessionManager(SessionManager) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
 
setStageIdentity(String) - Method in interface com.bea.wlevs.ede.api.StageIdentityAware
Callback through which the framework publishes the Stage identity
setStartOffset(int) - Method in class com.bea.wlevs.ede.api.StatementException
 
setStatement(String) - Method in class com.bea.wlevs.ede.api.StatementException
 
setStore(String, Object) - Method in interface com.bea.wlevs.cache.spi.CachingSystem
Sets a store on the named cache and the underlying caching system.
setString(int, String) - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Sets the designated parameter to the given Java String value.
setSystemPropertiesMode(int) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set how to check system properties: as fallback, as override, or never.
setSystemPropertiesModeName(String) - Method in class com.bea.wlevs.spring.support.ConfigurationPropertyPlaceholderConfigurer
Set the system property mode by the name of the corresponding constant, e.g.
setTime(long) - Method in interface com.bea.wlevs.ede.api.Processor
 
setTimestamp(int, Timestamp) - Method in interface com.oracle.cep.cartridge.ExternalPreparedStatement
Sets the designated parameter to the given java.sql.Timestamp value.
setTimeToLive(long) - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Sets the value of the timeToLive property.
setValue(Object, Object) - Method in interface com.bea.wlevs.ede.api.EventProperty
Sets value on this event property.
setWorkManagerName(String) - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Sets the value of the workManagerName property.
setWritePolicy(Map) - Method in interface com.bea.wlevs.management.configuration.CacheMBean
Sets the WritePolicy.
shutdown() - Method in interface com.bea.wlevs.management.runtime.ServerRuntimeMBean
This method shuts-down the server
SHUTTING_DOWN - Static variable in interface com.bea.wlevs.management.runtime.ServerRuntimeMBean
 
SQLXML - Static variable in class com.bea.wlevs.ede.api.Type
 
Stage - interface com.bea.wlevs.ede.api.Stage.
A Stage is a node of an Event Processing Network (EPN).
STAGE_APPLICATION_ID - Static variable in interface com.bea.wlevs.ede.api.StageConstants
The globally unique identity of am application
STAGE_ID - Static variable in interface com.bea.wlevs.ede.api.FaultHandler
Use this mandatory service property to specify target stage.
STAGE_ID - Static variable in interface com.bea.wlevs.ede.api.StageConstants
The application unique identity of a Stage
STAGE_MBEAN_TYPE - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
 
STAGE_PROVIDER - Static variable in interface com.bea.wlevs.ede.api.StageConstants
 
StageConstants - interface com.bea.wlevs.ede.api.StageConstants.
Predefined property names uses in Stage creation and advertisement
StageFactory - interface com.bea.wlevs.ede.api.StageFactory.
Factory interface that is implemented by all Stage creators
StageIdentityAware - interface com.bea.wlevs.ede.api.StageIdentityAware.
Interface to be implemented by Stage components that wish to be aware of their identity.
StageMBean - interface com.bea.wlevs.management.configuration.StageMBean.
 
StageName - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters
Name of the stage from which these events were recorded
StageRuntimeMBean - interface com.bea.wlevs.management.runtime.StageRuntimeMBean.
This MBean provides runtime information for an instance of a stage part of an application's EPN.
start() - Method in interface com.bea.wlevs.ede.api.Statement
Starts a statement that has previously been stopped.
startApplication(String) - Method in interface com.bea.wlevs.deployment.mbean.DeploymentServiceMBean
This method will start a deployed application which may have been stopped.
STARTED - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters
Used to identify value indicating if a rule is started or not.
STARTING - Static variable in interface com.bea.wlevs.management.runtime.ServerRuntimeMBean
 
startPlayback() - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Starts playback on a stage that is already configured with the required playback parameters.
startPlayback() - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
startPlayback(long, long, float, boolean) - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Starts playback using the specified filter and speed.
startPlaybackUsingSession(String, long, List, float, boolean) - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Starts playing back to this stage using events from the specified recording session.
startRecording() - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Starts recording on a stage that is already configured with the required record parameters.
startRecording() - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
startRule(String) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
Starts a rule and makes it ready to process events
Statement - interface com.bea.wlevs.ede.api.Statement.
Represent a single compiled query.
StatementException - exception com.bea.wlevs.ede.api.StatementException.
Exception raised when attempting to add an invalid statement
StatementException(Exception) - Constructor for class com.bea.wlevs.ede.api.StatementException
 
StatementException(String) - Constructor for class com.bea.wlevs.ede.api.StatementException
 
StatementException(String, String, String) - Constructor for class com.bea.wlevs.ede.api.StatementException
 
StatementException(String, String, String, String, Throwable, String) - Constructor for class com.bea.wlevs.ede.api.StatementException
 
StatementException(String, Throwable) - Constructor for class com.bea.wlevs.ede.api.StatementException
 
StatementException(String, Throwable, String) - Constructor for class com.bea.wlevs.ede.api.StatementException
 
StatementManager - interface com.bea.wlevs.ede.api.StatementManager.
Manages compiled and prepared statements.
stop() - Method in interface com.bea.wlevs.ede.api.Statement
Stops statement making it inactive.
stopApplication(String) - Method in interface com.bea.wlevs.deployment.mbean.DeploymentServiceMBean
This method will stop a deployed application.
stopPlayback() - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Stops playback on a stage.
stopPlayback() - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
stopRecording() - Method in interface com.bea.wlevs.management.configuration.RecordPlaybackMBean
Stops recording on a stage.
stopRecording() - Method in interface com.bea.wlevs.management.configuration.StageMBean
Deprecated. use methods on RecordPlaybackMBean whose ObjectName is returned by method getRecordPlayback
stopRule(String) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
Stops a cql query or EPL rule so that it will not process incoming events anymore.
StorePolicyParameters - Static variable in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
Store policy parameters are in the format: parameter1namebparameter1value, parameter2name=parameter2value,..
Stream - interface com.bea.wlevs.ede.api.Stream.
Deprecated. As of OCEP 10.3, replaced by EventChannel.
StreamFactory - interface com.bea.wlevs.ede.api.StreamFactory.
Factory for creating Streams.
StreamMBean - interface com.bea.wlevs.management.configuration.StreamMBean.
This MBean will manage instances of Streams whose configuration has been derived from com.bea.wlevs.configuration.application.DefaultStreamConfig schema.
StreamSender - interface com.bea.wlevs.ede.api.StreamSender.
A StreamSender sends events emitted by an StreamSource to StreamSink listeners.
StreamSink - interface com.bea.wlevs.ede.api.StreamSink.
Interface to be implemented by beans that want to receive events modeling a OCEP stream.
StreamSource - interface com.bea.wlevs.ede.api.StreamSource.
Interface to be implemented by beans that want to emit events modeling a OCEP stream.
supportsPredicate(ExternalPredicate) - Method in interface com.oracle.cep.cartridge.ExternalConnection
Return true if the connection supports the predicate.
suspend() - Method in interface com.bea.wlevs.ede.api.SuspendableBean
Invoked by the EPN container when the containing application is suspended.
suspend(String) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method suspends a deployed application.
SuspendableBean - interface com.bea.wlevs.ede.api.SuspendableBean.
Interface to be implemented by beans that want to suspend resources or stop processing events when the containing EPN is suspended.
SUSPENDED - Static variable in interface com.bea.wlevs.management.configuration.ApplicationMBean
 

T

TableMBean - interface com.bea.wlevs.management.configuration.TableMBean.
TableMBean manages tables that have been specified in an EPN using the wlevs:table tag.
TIMESTAMP - Static variable in class com.bea.wlevs.ede.api.Type
 
TimestampType - interface com.bea.wlevs.ede.api.TimestampType.
Type returned by EventType's getPropertyType method for timestamp properties.
toJavaClass() - Method in class com.bea.wlevs.ede.api.Type
Deprecated. As of OCEP 11gR1, replaced by JavaTypeSystem
toString() - Method in class com.bea.wlevs.ede.api.Type
 
TupleEventType - interface com.bea.wlevs.ede.api.TupleEventType.
Market for tuple-type EventTypes
Type - class com.bea.wlevs.ede.api.Type.
Native types for OCEP server.
TYPE_PROPERTY - Static variable in interface com.bea.wlevs.management.ManagementConstants
Type attribute used to type MBean

U

unbindAllParameters(String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method deletes or unbind all parameter values for the parameterized query identified by the ruleId argument.
unbindParameters(String, String) - Method in interface com.bea.wlevs.management.configuration.CQLProcessorMBean
This method deletes or unbind the named set of parameter values for the parameterized query identified by the ruleId argument.
undeployApplication(String) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method will undeploy an application named applicationName If application is clustered, then it will undeploy application from all servers where it has been deployed.
undo(String, String) - Method in interface com.bea.wlevs.management.configuration.ConfigHistoryManagerMBean
Undo one change to the application.
UNKNOWN - Static variable in class com.bea.wlevs.ede.api.EventRejectedException.Reason
 
UNKNOWN - Static variable in class com.bea.wlevs.ede.api.Type
 
UnknownEventTypeException - exception com.bea.wlevs.ede.api.UnknownEventTypeException.
This exception is raised when an unknown event type name is referenced.
UnknownEventTypeException(String, String) - Constructor for class com.bea.wlevs.ede.api.UnknownEventTypeException
 
UnknownEventTypeException(String, String, Throwable) - Constructor for class com.bea.wlevs.ede.api.UnknownEventTypeException
 
UnknownEventTypeException(String, Throwable) - Constructor for class com.bea.wlevs.ede.api.UnknownEventTypeException
 
UnsupportedEventPropertyTypeException - exception com.bea.wlevs.ede.api.UnsupportedEventPropertyTypeException.
This exception is raised when an event contains a property of an unsupported type.
UnsupportedEventPropertyTypeException(String, String) - Constructor for class com.bea.wlevs.ede.api.UnsupportedEventPropertyTypeException
 
UnsupportedEventPropertyTypeException(String, String, Throwable) - Constructor for class com.bea.wlevs.ede.api.UnsupportedEventPropertyTypeException
 
UnsupportedEventPropertyTypeException(String, Throwable) - Constructor for class com.bea.wlevs.ede.api.UnsupportedEventPropertyTypeException
 
UnsupportedPropertyException - exception com.bea.wlevs.ede.api.UnsupportedPropertyException.
Configuration exception raised when encountering unknown event property names.
UnsupportedPropertyException(String, String) - Constructor for class com.bea.wlevs.ede.api.UnsupportedPropertyException
Unsupported property.
UnsupportedPropertyException(String, String, Throwable) - Constructor for class com.bea.wlevs.ede.api.UnsupportedPropertyException
Unsupported property.
UntypedEventChannelException - exception com.bea.wlevs.ede.api.UntypedEventChannelException.
Configuration exception raised if channel in EPN is not typed with an event-type.
UntypedEventChannelException() - Constructor for class com.bea.wlevs.ede.api.UntypedEventChannelException
 
UntypedEventChannelException(String) - Constructor for class com.bea.wlevs.ede.api.UntypedEventChannelException
 
UntypedEventChannelException(String, Throwable) - Constructor for class com.bea.wlevs.ede.api.UntypedEventChannelException
 
UntypedEventChannelException(Throwable) - Constructor for class com.bea.wlevs.ede.api.UntypedEventChannelException
 
updateDeployedApplication(String) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method will update a deployed application in the Weblogic Event Server.
updateDeployedApplication(String, byte[]) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method will update a deployed appliction in the Weblogic Event Server.
updateDeployedApplication(String, File) - Method in interface com.bea.wlevs.deployment.mbean.AppDeploymentMBean
This method will update a deployed application in the Weblogic Event Server.
uploadRules(Map) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method uploads a collection of EPL queries to the designated EPL processor.
uploadRules(String) - Method in interface com.bea.wlevs.management.configuration.ProcessorMBean
This method uploads a collection of EPL queries and associated parameter value bindings to the designated EPL processor.
UserDefinedFunctionExecutionException - exception com.bea.wlevs.ede.api.UserDefinedFunctionExecutionException.
Event processing exception raised if error occurs while executing a user-defined function (i.e.

V

VALUE - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters
Used to identify value or rule string of a rule.
valueOf(Class) - Static method in class com.bea.wlevs.ede.api.Type
Deprecated. As of OCEP 11gR1, replaced by JavaTypeSystem
valueOf(String) - Static method in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters
 
valueOf(String) - Static method in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
 
valueOf(String) - Static method in class com.bea.wlevs.management.configuration.CQLProcessorMBean.FunctionParameter
 
valueOf(String) - Static method in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters
 
valueOf(String) - Static method in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleType
 
valueOf(String) - Static method in class com.bea.wlevs.management.configuration.CartridgeMBean.FunctionDescKeys
 
valueOf(String) - Static method in class com.bea.wlevs.ede.api.Processor.ClockType
 
valueOf(String) - Static method in class com.bea.wlevs.ede.api.EventRejectedException.Reason
 
valueOf(String) - Static method in class com.bea.wlevs.ede.api.Type
 
valueOf(String) - Static method in class com.bea.wlevs.channel.RejectionPolicy
 
values() - Static method in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.RecordSessionParameters
 
values() - Static method in class com.bea.wlevs.management.configuration.RecordPlaybackMBean.ConfigParameters
 
values() - Static method in class com.bea.wlevs.management.configuration.CQLProcessorMBean.FunctionParameter
 
values() - Static method in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleConfigParameters
 
values() - Static method in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleType
 
values() - Static method in class com.bea.wlevs.management.configuration.CartridgeMBean.FunctionDescKeys
 
values() - Static method in class com.bea.wlevs.ede.api.Processor.ClockType
 
values() - Static method in class com.bea.wlevs.ede.api.EventRejectedException.Reason
 
values() - Static method in class com.bea.wlevs.ede.api.Type
 
values() - Static method in class com.bea.wlevs.channel.RejectionPolicy
 
VIEW - Static variable in class com.bea.wlevs.management.configuration.ProcessorMBean.RuleType
 

W

WebLogicMBean - interface com.bea.wlevs.management.WebLogicMBean.
The super interface for all WebLogic Event Server MBeans.
WorkManagerName - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Property name for work manager.
WriteBehind - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Specifies write policy of Write Behind.
WriteNone - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Specifies write policy of no writes.
WritePolicy - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Property name for the write policy in the WritePolicy property map.
WriteThrough - Static variable in interface com.bea.wlevs.management.configuration.CacheMBeanProperties
Specifies write policy of Write Through.

X

XMLType - interface com.bea.wlevs.ede.api.XMLType.
Type returned by EventType's getPropertyType method for xml value properties.
XMLTYPE - Static variable in class com.bea.wlevs.ede.api.Type
 

A B C D E F G H I J K L M N O P Q R S T U V W X


Overview  Package   Class   Use   Tree  Deprecated   Index   Help 
Copyright © 2007, 2013 Oracle and/or its affiliates. All rights reserved.
 PREV   NEXT FRAMES    NO FRAMES