use of org.wso2.charon3.core.attributes.Attribute in project siddhi by wso2.
the class JunctionTestCase method junctionToReceiverTest.
@Test
public void junctionToReceiverTest() throws InterruptedException {
log.info("junction to receiver");
StreamDefinition streamA = StreamDefinition.id("streamA").attribute("symbol", Attribute.Type.STRING).attribute("price", Attribute.Type.INT).annotation(Annotation.annotation("parallel"));
StreamJunction streamJunctionA = new StreamJunction(streamA, executorService, 1024, siddhiAppContext);
StreamJunction.Publisher streamPublisherA = streamJunctionA.constructPublisher();
StreamCallback streamCallback = new StreamCallback() {
@Override
public void receive(Event[] streamEvents) {
count += streamEvents.length;
eventArrived = true;
}
};
streamJunctionA.subscribe(streamCallback);
streamJunctionA.startProcessing();
streamPublisherA.send(new StreamEvent(2, 2, 2));
streamPublisherA.send(new StreamEvent(2, 2, 2));
Thread.sleep(100);
AssertJUnit.assertTrue(eventArrived);
AssertJUnit.assertEquals(2, count);
streamJunctionA.stopProcessing();
}
use of org.wso2.charon3.core.attributes.Attribute in project siddhi by wso2.
the class JunctionTestCase method multiThreadedWithEventPoolTest.
@Test
public void multiThreadedWithEventPoolTest() throws InterruptedException {
log.info("multi threaded test using event pool");
final StreamEventPool streamEventPoolA1 = new StreamEventPool(2, 2, 2, 4);
final StreamEventPool streamEventPoolA2 = new StreamEventPool(2, 2, 2, 4);
final StreamEventPool streamEventPoolA3 = new StreamEventPool(2, 2, 2, 4);
final StreamEventPool streamEventPoolB1 = new StreamEventPool(2, 2, 2, 4);
final StreamEventPool streamEventPoolB2 = new StreamEventPool(2, 2, 2, 4);
StreamDefinition streamA = StreamDefinition.id("streamA").attribute("symbol", Attribute.Type.STRING).attribute("price", Attribute.Type.INT).annotation(Annotation.annotation("async"));
StreamJunction streamJunctionA = new StreamJunction(streamA, executorService, 1024, siddhiAppContext);
StreamJunction.Publisher streamPublisherA = streamJunctionA.constructPublisher();
StreamDefinition streamB = StreamDefinition.id("streamB").attribute("symbol", Attribute.Type.STRING).attribute("price", Attribute.Type.INT).annotation(Annotation.annotation("async"));
StreamJunction streamJunctionB = new StreamJunction(streamB, executorService, 1024, siddhiAppContext);
final StreamJunction.Publisher streamPublisherB1 = streamJunctionB.constructPublisher();
final StreamJunction.Publisher streamPublisherB2 = streamJunctionB.constructPublisher();
final StreamJunction.Publisher streamPublisherB3 = streamJunctionB.constructPublisher();
StreamDefinition streamC = StreamDefinition.id("streamC").attribute("symbol", Attribute.Type.STRING).attribute("price", Attribute.Type.INT).annotation(Annotation.annotation("async"));
StreamJunction streamJunctionC = new StreamJunction(streamC, executorService, 1024, siddhiAppContext);
final StreamJunction.Publisher streamPublisherC1 = streamJunctionC.constructPublisher();
final StreamJunction.Publisher streamPublisherC2 = streamJunctionC.constructPublisher();
StreamCallback streamCallbackA1 = new StreamCallback() {
@Override
public void receive(Event[] streamEvents) {
for (Event streamEvent : streamEvents) {
StreamEvent innerStreamEvent = streamEventPoolA1.borrowEvent();
innerStreamEvent.setTimestamp(streamEvent.getTimestamp());
Object[] data = new Object[] { streamEvent.getData()[0], streamEvent.getData()[1] };
data[0] = ((String) data[0]).concat("A1");
innerStreamEvent.setOutputData(data);
streamPublisherB1.send(innerStreamEvent);
}
}
};
StreamCallback streamCallbackA2 = new StreamCallback() {
@Override
public void receive(Event[] streamEvents) {
for (Event streamEvent : streamEvents) {
StreamEvent innerStreamEvent = streamEventPoolA2.borrowEvent();
innerStreamEvent.setTimestamp(streamEvent.getTimestamp());
Object[] data = new Object[] { streamEvent.getData()[0], streamEvent.getData()[1] };
data[0] = ((String) data[0]).concat("A2");
innerStreamEvent.setOutputData(data);
streamPublisherB2.send(innerStreamEvent);
}
}
};
StreamCallback streamCallbackA3 = new StreamCallback() {
@Override
public void receive(Event[] streamEvents) {
for (Event streamEvent : streamEvents) {
StreamEvent innerStreamEvent = streamEventPoolA3.borrowEvent();
innerStreamEvent.setTimestamp(streamEvent.getTimestamp());
Object[] data = new Object[] { streamEvent.getData()[0], streamEvent.getData()[1] };
data[0] = ((String) data[0]).concat("A3");
innerStreamEvent.setOutputData(data);
streamPublisherB3.send(innerStreamEvent);
}
}
};
StreamCallback streamCallbackB1 = new StreamCallback() {
@Override
public void receive(Event[] streamEvents) {
for (Event streamEvent : streamEvents) {
StreamEvent innerStreamEvent = streamEventPoolB1.borrowEvent();
innerStreamEvent.setTimestamp(streamEvent.getTimestamp());
Object[] data = new Object[] { streamEvent.getData()[0], streamEvent.getData()[1] };
data[0] = ((String) data[0]).concat("B1");
innerStreamEvent.setOutputData(data);
streamPublisherC1.send(innerStreamEvent);
}
}
};
StreamCallback streamCallbackB2 = new StreamCallback() {
@Override
public void receive(Event[] streamEvents) {
for (Event streamEvent : streamEvents) {
StreamEvent innerStreamEvent = streamEventPoolB2.borrowEvent();
innerStreamEvent.setTimestamp(streamEvent.getTimestamp());
Object[] data = new Object[] { streamEvent.getData()[0], streamEvent.getData()[1] };
data[0] = ((String) data[0]).concat("B2");
innerStreamEvent.setOutputData(data);
streamPublisherC2.send(innerStreamEvent);
}
}
};
final boolean[] eventsArrived = { false, false, false, false, false, false, false, false, false, false, false, false };
StreamCallback streamCallbackC = new StreamCallback() {
@Override
public void receive(Event[] streamEvents) {
for (Event streamEvent : streamEvents) {
count++;
eventArrived = true;
Object symbol = streamEvent.getData()[0];
if (symbol.equals("IBMA1B1")) {
eventsArrived[0] = true;
} else if (symbol.equals("IBMA1B2")) {
eventsArrived[1] = true;
} else if (symbol.equals("IBMA2B1")) {
eventsArrived[2] = true;
} else if (symbol.equals("IBMA2B2")) {
eventsArrived[3] = true;
} else if (symbol.equals("IBMA3B1")) {
eventsArrived[4] = true;
} else if (symbol.equals("IBMA3B2")) {
eventsArrived[5] = true;
}
if (symbol.equals("WSO2A1B1")) {
eventsArrived[6] = true;
} else if (symbol.equals("WSO2A1B2")) {
eventsArrived[7] = true;
} else if (symbol.equals("WSO2A2B1")) {
eventsArrived[8] = true;
} else if (symbol.equals("WSO2A2B2")) {
eventsArrived[9] = true;
} else if (symbol.equals("WSO2A3B1")) {
eventsArrived[10] = true;
} else if (symbol.equals("WSO2A3B2")) {
eventsArrived[11] = true;
}
}
}
};
streamJunctionA.subscribe(streamCallbackA1);
streamJunctionA.subscribe(streamCallbackA2);
streamJunctionA.subscribe(streamCallbackA3);
streamJunctionA.startProcessing();
streamJunctionB.subscribe(streamCallbackB1);
streamJunctionB.subscribe(streamCallbackB2);
streamJunctionB.startProcessing();
streamJunctionC.subscribe(streamCallbackC);
streamJunctionC.startProcessing();
StreamEvent streamEvent1 = new StreamEvent(2, 2, 2);
streamEvent1.setTimestamp(System.currentTimeMillis());
streamEvent1.setOutputData(new Object[] { "IBM", 12 });
StreamEvent streamEvent2 = new StreamEvent(2, 2, 2);
streamEvent2.setTimestamp(System.currentTimeMillis());
streamEvent2.setOutputData(new Object[] { "WSO2", 112 });
streamPublisherA.send(streamEvent1);
streamPublisherA.send(streamEvent2);
Thread.sleep(1000);
AssertJUnit.assertTrue(eventArrived);
AssertJUnit.assertEquals(12, count);
for (boolean arrived : eventsArrived) {
AssertJUnit.assertTrue(arrived);
}
streamJunctionA.stopProcessing();
streamJunctionB.stopProcessing();
streamJunctionC.stopProcessing();
}
use of org.wso2.charon3.core.attributes.Attribute in project siddhi by wso2.
the class EventTestCase method testQueryParser.
@Test
public void testQueryParser() {
StreamDefinition streamDefinition = StreamDefinition.id("cseEventStream").attribute("symbol", Attribute.Type.STRING).attribute("price", Attribute.Type.FLOAT).attribute("volume", Attribute.Type.INT);
StreamDefinition outStreamDefinition = StreamDefinition.id("outputStream").attribute("symbol", Attribute.Type.STRING).attribute("price", Attribute.Type.FLOAT);
Query query = new Query();
query.annotation(Annotation.annotation("info").element("name", "query1"));
query.from(InputStream.stream("cseEventStream").filter(Expression.compare(Expression.variable("volume"), Compare.Operator.NOT_EQUAL, Expression.value(50))));
query.select(Selector.selector().select("symbol", Expression.variable("symbol")).select("price", Expression.variable("price")));
query.insertInto("outputStream");
Map<String, AbstractDefinition> tableDefinitionMap = new HashMap<>();
Map<String, AbstractDefinition> windowDefinitionMap = new HashMap<>();
Map<String, AbstractDefinition> aggregationDefinitionMap = new HashMap<>();
Map<String, Table> tableMap = new HashMap<String, Table>();
Map<String, Window> eventWindowMap = new HashMap<String, Window>();
Map<String, AggregationRuntime> aggregationMap = new HashMap<String, AggregationRuntime>();
Map<String, List<Source>> eventSourceMap = new HashMap<String, List<Source>>();
Map<String, List<Sink>> eventSinkMap = new HashMap<String, List<Sink>>();
Map<String, AbstractDefinition> streamDefinitionMap = new HashMap<String, AbstractDefinition>();
LockSynchronizer lockSynchronizer = new LockSynchronizer();
streamDefinitionMap.put("cseEventStream", streamDefinition);
streamDefinitionMap.put("outputStream", outStreamDefinition);
SiddhiContext siddhicontext = new SiddhiContext();
SiddhiAppContext context = new SiddhiAppContext();
context.setSiddhiContext(siddhicontext);
context.setElementIdGenerator(new ElementIdGenerator(context.getName()));
context.setSnapshotService(new SnapshotService(context));
QueryRuntime runtime = QueryParser.parse(query, context, streamDefinitionMap, tableDefinitionMap, windowDefinitionMap, aggregationDefinitionMap, tableMap, aggregationMap, eventWindowMap, lockSynchronizer, "1");
AssertJUnit.assertNotNull(runtime);
AssertJUnit.assertTrue(runtime.getStreamRuntime() instanceof SingleStreamRuntime);
AssertJUnit.assertNotNull(runtime.getSelector());
AssertJUnit.assertTrue(runtime.getMetaComplexEvent() instanceof MetaStreamEvent);
}
use of org.wso2.charon3.core.attributes.Attribute in project siddhi by wso2.
the class EventTestCase method testConditionExpressionExecutors.
@Test
public void testConditionExpressionExecutors() {
// StreamDefinition streamDefinition = StreamDefinition.id("cseEventStream").attribute("symbol", Attribute
// .Type.STRING).attribute("price", Attribute.Type.FLOAT).attribute("volume", Attribute.Type.INT);
VariableExpressionExecutor priceVariableExpressionExecutor = new VariableExpressionExecutor(new Attribute("price", Attribute.Type.FLOAT), 0, 0);
priceVariableExpressionExecutor.setPosition(new int[] { 0, SiddhiConstants.UNKNOWN_STATE, SiddhiConstants.OUTPUT_DATA_INDEX, 1 });
VariableExpressionExecutor volumeVariableExpressionExecutor = new VariableExpressionExecutor(new Attribute("volume", Attribute.Type.INT), 0, 0);
volumeVariableExpressionExecutor.setPosition(new int[] { 0, SiddhiConstants.UNKNOWN_STATE, SiddhiConstants.OUTPUT_DATA_INDEX, 2 });
ExpressionExecutor compareLessThanExecutor = new LessThanCompareConditionExpressionExecutorFloatFloat(new ConstantExpressionExecutor(10f, Attribute.Type.FLOAT), priceVariableExpressionExecutor);
ExpressionExecutor compareGreaterThanExecutor = new GreaterThanCompareConditionExpressionExecutorIntInt(new ConstantExpressionExecutor(10, Attribute.Type.INT), volumeVariableExpressionExecutor);
ExpressionExecutor andExecutor = new AndConditionExpressionExecutor(compareLessThanExecutor, compareGreaterThanExecutor);
int count = 0;
for (int i = 0; i < 3; i++) {
StreamEvent event = new StreamEvent(0, 0, 3);
event.setOutputData(new Object[] { "WSO2", i * 11f, 5 });
if ((Boolean) andExecutor.execute(event)) {
count++;
}
}
AssertJUnit.assertEquals("Two events should pass through executor", 2, count);
}
use of org.wso2.charon3.core.attributes.Attribute in project siddhi by wso2.
the class EventTestCase method testSimpleStreamEventConverter.
@Test
public void testSimpleStreamEventConverter() {
Attribute price = new Attribute("price", Attribute.Type.DOUBLE);
Attribute symbol = new Attribute("symbol", Attribute.Type.STRING);
MetaStreamEvent metaStreamEvent = new MetaStreamEvent();
metaStreamEvent.addOutputData(symbol);
metaStreamEvent.addOutputData(price);
StreamDefinition streamDefinition = StreamDefinition.id("cseEventStream").attribute("symbol", Attribute.Type.STRING).attribute("price", Attribute.Type.DOUBLE).attribute("volume", Attribute.Type.INT);
Event event = new Event(System.currentTimeMillis(), new Object[] { "WSO2", 200, 50 });
metaStreamEvent.addInputDefinition(streamDefinition);
StreamEventConverter converter = StreamEventConverterFactory.constructEventConverter(metaStreamEvent);
StreamEventPool eventPool = new StreamEventPool(metaStreamEvent, 5);
StreamEvent borrowedEvent = eventPool.borrowEvent();
converter.convertEvent(event, borrowedEvent);
AssertJUnit.assertTrue(converter instanceof SimpleStreamEventConverter);
AssertJUnit.assertNull(borrowedEvent.getBeforeWindowData());
AssertJUnit.assertNull(borrowedEvent.getOnAfterWindowData());
AssertJUnit.assertEquals(2, borrowedEvent.getOutputData().length);
AssertJUnit.assertEquals(200, borrowedEvent.getOutputData()[1]);
AssertJUnit.assertEquals("WSO2", borrowedEvent.getOutputData()[0]);
}
Aggregations