public int compare(org.drools.spi.Activation o1, org.drools.spi.Activation o2) { int result = o1.getRule().getName().compareTo(o2.getRule().getName()); if (result == 0) { LeftTuple t1 = o1.getTuple(); LeftTuple t2 = o2.getTuple(); while (result == 0 && t1 != null && t2 != null) { result = t1.getLastHandle().getId() - t2.getLastHandle().getId(); t1 = t1.getParent(); t2 = t2.getParent(); } } return result; }
public Object[] toObjectArray() { Object[] objects = new Object[this.index + 1]; LeftTuple entry = this; while (entry != null) { Object object = entry.getLastHandle().getObject(); objects[entry.index] = object; entry = entry.parent; } return objects; }
private void reaccumulateForLeftTuple( final LeftTuple leftTuple, final InternalWorkingMemory workingMemory, final AccumulateMemory memory, final AccumulateContext accctx) { this.accumulate.init(memory.workingMemoryContext, accctx.context, leftTuple, workingMemory); for (LeftTuple childMatch = getFirstMatch(leftTuple, accctx, false); childMatch != null; childMatch = childMatch.getLeftParentNext()) { InternalFactHandle childHandle = childMatch.getRightParent().getFactHandle(); LeftTuple tuple = leftTuple; if (this.unwrapRightObject) { tuple = (LeftTuple) childHandle.getObject(); childHandle = tuple.getLastHandle(); } this.accumulate.accumulate( memory.workingMemoryContext, accctx.context, tuple, childHandle, workingMemory); } }
protected String toExternalString() { StringBuilder builder = new StringBuilder(); builder.append(String.format("%08X", System.identityHashCode(this))).append(":"); int[] ids = new int[getIndex() + 1]; LeftTuple entry = this; while (entry != null) { ids[entry.getIndex()] = entry.getLastHandle().getId(); entry = entry.getParent(); } builder .append(Arrays.toString(ids)) .append(" activation=") .append(getObject() != null ? getObject() : "null") .append(" sink=") .append(getSink().getClass().getSimpleName()) .append("(") .append(getSink().getId()) .append(")"); return builder.toString(); }
public static ProtobufMessages.Activation writeActivation( MarshallerWriteContext context, AgendaItem agendaItem) { ProtobufMessages.Activation.Builder _activation = ProtobufMessages.Activation.newBuilder(); Rule rule = agendaItem.getRule(); _activation.setPackageName(rule.getPackage()); _activation.setRuleName(rule.getName()); ProtobufMessages.Tuple.Builder _tb = ProtobufMessages.Tuple.newBuilder(); for (LeftTuple entry = agendaItem.getTuple(); entry != null; entry = entry.getParent()) { InternalFactHandle handle = entry.getLastHandle(); _tb.addHandleId(handle.getId()); } _activation.setTuple(_tb.build()); _activation.setSalience(agendaItem.getSalience()); _activation.setIsActivated(agendaItem.isActivated()); if (agendaItem.getActivationGroupNode() != null) { _activation.setActivationGroup( agendaItem.getActivationGroupNode().getActivationGroup().getName()); } if (agendaItem.getFactHandle() != null) { _activation.setHandleId(agendaItem.getFactHandle().getId()); } org.drools.core.util.LinkedList list = agendaItem.getLogicalDependencies(); if (list != null && !list.isEmpty()) { for (LogicalDependency node = (LogicalDependency) list.getFirst(); node != null; node = (LogicalDependency) node.getNext()) { _activation.addLogicalDependency(((InternalFactHandle) node.getJustified()).getId()); } } return _activation.build(); }
public static void writeLeftTuple( LeftTuple leftTuple, MarshallerWriteContext context, boolean recurse) throws IOException { ObjectOutputStream stream = context.stream; InternalRuleBase ruleBase = context.ruleBase; InternalWorkingMemory wm = context.wm; LeftTupleSink sink = leftTuple.getLeftTupleSink(); switch (sink.getType()) { case NodeTypeEnums.JoinNode: { // context.out.println( "JoinNode" ); for (LeftTuple childLeftTuple = leftTuple.getFirstChild(); childLeftTuple != null; childLeftTuple = (LeftTuple) childLeftTuple.getLeftParentNext()) { stream.writeShort(PersisterEnums.RIGHT_TUPLE); int childSinkId = childLeftTuple.getLeftTupleSink().getId(); stream.writeInt(childSinkId); stream.writeInt(childLeftTuple.getRightParent().getFactHandle().getId()); // context.out.println( "RightTuple int:" + childLeftTuple.getLeftTupleSink().getId() + // " int:" + childLeftTuple.getRightParent().getFactHandle().getId() ); writeLeftTuple(childLeftTuple, context, recurse); } stream.writeShort(PersisterEnums.END); // context.out.println( "JoinNode --- END" ); break; } case NodeTypeEnums.QueryRiaFixerNode: case NodeTypeEnums.EvalConditionNode: { // context.out.println( ".... EvalConditionNode" ); for (LeftTuple childLeftTuple = leftTuple.getFirstChild(); childLeftTuple != null; childLeftTuple = (LeftTuple) childLeftTuple.getLeftParentNext()) { stream.writeShort(PersisterEnums.LEFT_TUPLE); stream.writeInt(childLeftTuple.getLeftTupleSink().getId()); writeLeftTuple(childLeftTuple, context, recurse); } stream.writeShort(PersisterEnums.END); // context.out.println( "---- EvalConditionNode --- END" ); break; } case NodeTypeEnums.NotNode: case NodeTypeEnums.ForallNotNode: { if (leftTuple.getBlocker() == null) { // is not blocked so has children stream.writeShort(PersisterEnums.LEFT_TUPLE_NOT_BLOCKED); for (LeftTuple childLeftTuple = leftTuple.getFirstChild(); childLeftTuple != null; childLeftTuple = (LeftTuple) childLeftTuple.getLeftParentNext()) { stream.writeShort(PersisterEnums.LEFT_TUPLE); stream.writeInt(childLeftTuple.getLeftTupleSink().getId()); writeLeftTuple(childLeftTuple, context, recurse); } stream.writeShort(PersisterEnums.END); } else { stream.writeShort(PersisterEnums.LEFT_TUPLE_BLOCKED); stream.writeInt(leftTuple.getBlocker().getFactHandle().getId()); } break; } case NodeTypeEnums.ExistsNode: { if (leftTuple.getBlocker() == null) { // is blocked so has children stream.writeShort(PersisterEnums.LEFT_TUPLE_NOT_BLOCKED); } else { stream.writeShort(PersisterEnums.LEFT_TUPLE_BLOCKED); stream.writeInt(leftTuple.getBlocker().getFactHandle().getId()); for (LeftTuple childLeftTuple = leftTuple.getFirstChild(); childLeftTuple != null; childLeftTuple = (LeftTuple) childLeftTuple.getLeftParentNext()) { stream.writeShort(PersisterEnums.LEFT_TUPLE); stream.writeInt(childLeftTuple.getLeftTupleSink().getId()); writeLeftTuple(childLeftTuple, context, recurse); } stream.writeShort(PersisterEnums.END); } break; } case NodeTypeEnums.AccumulateNode: { // context.out.println( ".... AccumulateNode" ); // accumulate nodes generate new facts on-demand and need special procedures when // serializing to persistent storage AccumulateMemory memory = (AccumulateMemory) context.wm.getNodeMemory((BetaNode) sink); AccumulateContext accctx = (AccumulateContext) leftTuple.getObject(); // first we serialize the generated fact handle writeFactHandle( context, stream, context.objectMarshallingStrategyStore, accctx.result.getFactHandle()); // then we serialize the associated accumulation context stream.writeObject(accctx.context); // then we serialize the boolean propagated flag stream.writeBoolean(accctx.propagated); // then we serialize all the propagated tuples for (LeftTuple childLeftTuple = leftTuple.getFirstChild(); childLeftTuple != null; childLeftTuple = (LeftTuple) childLeftTuple.getLeftParentNext()) { if (leftTuple.getLeftTupleSink().getId() == childLeftTuple.getLeftTupleSink().getId()) { // this is a matching record, so, associate the right tuples // context.out.println( "RightTuple(match) int:" + // childLeftTuple.getLeftTupleSink().getId() + " int:" + // childLeftTuple.getRightParent().getFactHandle().getId() ); stream.writeShort(PersisterEnums.RIGHT_TUPLE); stream.writeInt(childLeftTuple.getRightParent().getFactHandle().getId()); } else { // this is a propagation record // context.out.println( "RightTuple(propagation) int:" + // childLeftTuple.getLeftTupleSink().getId() + " int:" + // childLeftTuple.getRightParent().getFactHandle().getId() ); stream.writeShort(PersisterEnums.LEFT_TUPLE); int sinkId = childLeftTuple.getLeftTupleSink().getId(); stream.writeInt(sinkId); writeLeftTuple(childLeftTuple, context, recurse); } } stream.writeShort(PersisterEnums.END); // context.out.println( "---- AccumulateNode --- END" ); break; } case NodeTypeEnums.RightInputAdaterNode: { // context.out.println( ".... RightInputAdapterNode" ); // RIANs generate new fact handles on-demand to wrap tuples and need special procedures // when serializing to persistent storage ObjectHashMap memory = (ObjectHashMap) context.wm.getNodeMemory((NodeMemory) sink); InternalFactHandle ifh = (InternalFactHandle) memory.get(leftTuple); // first we serialize the generated fact handle ID // context.out.println( "FactHandle id:"+ifh.getId() ); stream.writeInt(ifh.getId()); stream.writeLong(ifh.getRecency()); writeRightTuples(ifh, context); stream.writeShort(PersisterEnums.END); // context.out.println( "---- RightInputAdapterNode --- END" ); break; } case NodeTypeEnums.FromNode: { // context.out.println( ".... FromNode" ); // FNs generate new fact handles on-demand to wrap objects and need special procedures // when serializing to persistent storage FromMemory memory = (FromMemory) context.wm.getNodeMemory((NodeMemory) sink); Map<Object, RightTuple> matches = (Map<Object, RightTuple>) leftTuple.getObject(); for (RightTuple rightTuples : matches.values()) { // first we serialize the generated fact handle ID stream.writeShort(PersisterEnums.FACT_HANDLE); writeFactHandle( context, stream, context.objectMarshallingStrategyStore, rightTuples.getFactHandle()); writeRightTuples(rightTuples.getFactHandle(), context); } stream.writeShort(PersisterEnums.END); for (LeftTuple childLeftTuple = leftTuple.getFirstChild(); childLeftTuple != null; childLeftTuple = (LeftTuple) childLeftTuple.getLeftParentNext()) { stream.writeShort(PersisterEnums.RIGHT_TUPLE); stream.writeInt(childLeftTuple.getLeftTupleSink().getId()); stream.writeInt(childLeftTuple.getRightParent().getFactHandle().getId()); // context.out.println( "RightTuple int:" + childLeftTuple.getLeftTupleSink().getId() + // " int:" + childLeftTuple.getRightParent().getFactHandle().getId() ); writeLeftTuple(childLeftTuple, context, recurse); } stream.writeShort(PersisterEnums.END); // context.out.println( "---- FromNode --- END" ); break; } case NodeTypeEnums.UnificationNode: { // context.out.println( ".... UnificationNode" ); QueryElementNode node = (QueryElementNode) sink; boolean isOpen = node.isOpenQuery(); context.writeBoolean(isOpen); if (isOpen) { InternalFactHandle factHandle = (InternalFactHandle) leftTuple.getObject(); DroolsQuery query = (DroolsQuery) factHandle.getObject(); // context.out.println( "factHandle:" + factHandle ); factHandle.setObject(null); writeFactHandle(context, stream, context.objectMarshallingStrategyStore, 0, factHandle); factHandle.setObject(query); writeLeftTuples(context, new InternalFactHandle[] {factHandle}); } else { for (LeftTuple childLeftTuple = leftTuple.getFirstChild(); childLeftTuple != null; childLeftTuple = (LeftTuple) childLeftTuple.getLeftParentNext()) { stream.writeShort(PersisterEnums.LEFT_TUPLE); stream.writeInt(childLeftTuple.getLeftTupleSink().getId()); InternalFactHandle factHandle = childLeftTuple.getLastHandle(); writeFactHandle( context, stream, context.objectMarshallingStrategyStore, 1, factHandle); writeLeftTuple(childLeftTuple, context, recurse); } stream.writeShort(PersisterEnums.END); } // context.out.println( "---- EvalConditionNode --- END" ); break; } case NodeTypeEnums.RuleTerminalNode: { // context.out.println( "RuleTerminalNode" ); int pos = context.terminalTupleMap.size(); context.terminalTupleMap.put(leftTuple, pos); break; } case NodeTypeEnums.QueryTerminalNode: { // context.out.println( ".... QueryTerminalNode" ); // LeftTuple entry = leftTuple; // // // find the DroolsQuery object // while ( entry.getParent() != null ) { // entry = entry.getParent(); // } // // // Now output all the child tuples in the caller network // DroolsQuery query = (DroolsQuery) entry.getLastHandle().getObject(); // if ( query.getQueryResultCollector() instanceof // UnificationNodeViewChangedEventListener ) { // context.writeBoolean( true ); // UnificationNodeViewChangedEventListener collector = // (UnificationNodeViewChangedEventListener) query.getQueryResultCollector(); // leftTuple = collector.getLeftTuple(); // context.writeBoolean(true); RightTuple rightTuple = (RightTuple) leftTuple.getObject(); // context.out.println( "rightTuple:" + rightTuple.getFactHandle() ); writeFactHandle( context, stream, context.objectMarshallingStrategyStore, 1, rightTuple.getFactHandle()); for (LeftTuple childLeftTuple = rightTuple.firstChild; childLeftTuple != null; childLeftTuple = (LeftTuple) childLeftTuple.getRightParentNext()) { stream.writeShort(PersisterEnums.LEFT_TUPLE); stream.writeInt(childLeftTuple.getLeftTupleSink().getId()); writeLeftTuple(childLeftTuple, context, recurse); } // for ( LeftTuple childLeftTuple = leftTuple.getFirstChild(); // childLeftTuple != null; childLeftTuple = (LeftTuple) childLeftTuple.getLeftParentNext() // ) { // stream.writeShort( PersisterEnums.LEFT_TUPLE ); // stream.writeInt( childLeftTuple.getLeftTupleSink().getId() ); // writeFactHandle( context, // stream, // context.objectMarshallingStrategyStore, // 1, // childLeftTuple.getLastHandle() ); // writeLeftTuple( childLeftTuple, // context, // recurse ); // } // } else { // context.writeBoolean( false ); // } stream.writeShort(PersisterEnums.END); // context.out.println( "---- QueryTerminalNode --- END" ); break; } } }
public static void readLeftTuple(LeftTuple parentLeftTuple, MarshallerReaderContext context) throws IOException, ClassNotFoundException { ObjectInputStream stream = context.stream; Map<Integer, BaseNode> sinks = context.sinks; LeftTupleSink sink = parentLeftTuple.getLeftTupleSink(); switch (sink.getType()) { case NodeTypeEnums.JoinNode: { BetaMemory memory = (BetaMemory) context.wm.getNodeMemory((BetaNode) sink); addToLeftMemory(parentLeftTuple, memory); while (stream.readShort() == PersisterEnums.RIGHT_TUPLE) { int childSinkId = stream.readInt(); LeftTupleSink childSink = (LeftTupleSink) sinks.get(childSinkId); int factHandleId = stream.readInt(); RightTupleKey key = new RightTupleKey(factHandleId, sink); RightTuple rightTuple = context.rightTuples.get(key); LeftTuple childLeftTuple = childSink.createLeftTuple(parentLeftTuple, rightTuple, null, null, childSink, true); readLeftTuple(childLeftTuple, context); } break; } case NodeTypeEnums.EvalConditionNode: { while (stream.readShort() == PersisterEnums.LEFT_TUPLE) { LeftTupleSink childSink = (LeftTupleSink) sinks.get(stream.readInt()); LeftTuple childLeftTuple = childSink.createLeftTuple(parentLeftTuple, childSink, true); readLeftTuple(childLeftTuple, context); } break; } case NodeTypeEnums.NotNode: case NodeTypeEnums.ForallNotNode: { BetaMemory memory = (BetaMemory) context.wm.getNodeMemory((BetaNode) sink); int type = stream.readShort(); if (type == PersisterEnums.LEFT_TUPLE_NOT_BLOCKED) { addToLeftMemory(parentLeftTuple, memory); while (stream.readShort() == PersisterEnums.LEFT_TUPLE) { LeftTupleSink childSink = (LeftTupleSink) sinks.get(stream.readInt()); LeftTuple childLeftTuple = childSink.createLeftTuple(parentLeftTuple, childSink, true); readLeftTuple(childLeftTuple, context); } } else { int factHandleId = stream.readInt(); RightTupleKey key = new RightTupleKey(factHandleId, sink); RightTuple rightTuple = context.rightTuples.get(key); parentLeftTuple.setBlocker(rightTuple); rightTuple.addBlocked(parentLeftTuple); } break; } case NodeTypeEnums.ExistsNode: { BetaMemory memory = (BetaMemory) context.wm.getNodeMemory((BetaNode) sink); int type = stream.readShort(); if (type == PersisterEnums.LEFT_TUPLE_NOT_BLOCKED) { addToLeftMemory(parentLeftTuple, memory); } else { int factHandleId = stream.readInt(); RightTupleKey key = new RightTupleKey(factHandleId, sink); RightTuple rightTuple = context.rightTuples.get(key); parentLeftTuple.setBlocker(rightTuple); rightTuple.addBlocked(parentLeftTuple); while (stream.readShort() == PersisterEnums.LEFT_TUPLE) { LeftTupleSink childSink = (LeftTupleSink) sinks.get(stream.readInt()); LeftTuple childLeftTuple = childSink.createLeftTuple(parentLeftTuple, childSink, true); readLeftTuple(childLeftTuple, context); } } break; } case NodeTypeEnums.AccumulateNode: { // accumulate nodes generate new facts on-demand and need special procedures when // de-serializing from persistent storage AccumulateMemory memory = (AccumulateMemory) context.wm.getNodeMemory((BetaNode) sink); memory.betaMemory.getLeftTupleMemory().add(parentLeftTuple); AccumulateContext accctx = new AccumulateContext(); parentLeftTuple.setObject(accctx); // first we de-serialize the generated fact handle InternalFactHandle handle = readFactHandle(context); accctx.result = new RightTuple(handle, (RightTupleSink) sink); // then we de-serialize the associated accumulation context accctx.context = (Serializable[]) stream.readObject(); // then we de-serialize the boolean propagated flag accctx.propagated = stream.readBoolean(); // then we de-serialize all the propagated tuples short head = -1; while ((head = stream.readShort()) != PersisterEnums.END) { switch (head) { case PersisterEnums.RIGHT_TUPLE: { int factHandleId = stream.readInt(); RightTupleKey key = new RightTupleKey(factHandleId, sink); RightTuple rightTuple = context.rightTuples.get(key); // just wiring up the match record sink.createLeftTuple(parentLeftTuple, rightTuple, null, null, sink, true); break; } case PersisterEnums.LEFT_TUPLE: { int sinkId = stream.readInt(); LeftTupleSink childSink = (LeftTupleSink) sinks.get(sinkId); LeftTuple childLeftTuple = new LeftTupleImpl(parentLeftTuple, accctx.result, childSink, true); readLeftTuple(childLeftTuple, context); break; } default: { throw new RuntimeDroolsException( "Marshalling error. This is a bug. Please contact the development team."); } } } break; } case NodeTypeEnums.RightInputAdaterNode: { // RIANs generate new fact handles on-demand to wrap tuples and need special procedures // when de-serializing from persistent storage ObjectHashMap memory = (ObjectHashMap) context.wm.getNodeMemory((NodeMemory) sink); // create fact handle int id = stream.readInt(); long recency = stream.readLong(); InternalFactHandle handle = new DefaultFactHandle( id, parentLeftTuple, recency, context.wm.getEntryPoints().get(EntryPoint.DEFAULT.getEntryPointId())); memory.put(parentLeftTuple, handle); readRightTuples(handle, context); stream.readShort(); // Persistence.END break; } case NodeTypeEnums.FromNode: { // context.out.println( "FromNode" ); // FNs generate new fact handles on-demand to wrap objects and need special procedures // when serializing to persistent storage FromMemory memory = (FromMemory) context.wm.getNodeMemory((NodeMemory) sink); memory.betaMemory.getLeftTupleMemory().add(parentLeftTuple); Map<Object, RightTuple> matches = new LinkedHashMap<Object, RightTuple>(); parentLeftTuple.setObject(matches); while (stream.readShort() == PersisterEnums.FACT_HANDLE) { // we de-serialize the generated fact handle ID InternalFactHandle handle = readFactHandle(context); context.handles.put(handle.getId(), handle); readRightTuples(handle, context); matches.put(handle.getObject(), handle.getFirstRightTuple()); } while (stream.readShort() == PersisterEnums.RIGHT_TUPLE) { LeftTupleSink childSink = (LeftTupleSink) sinks.get(stream.readInt()); int factHandleId = stream.readInt(); RightTupleKey key = new RightTupleKey( factHandleId, null); // created tuples in from node always use null sink RightTuple rightTuple = context.rightTuples.get(key); LeftTuple childLeftTuple = new LeftTupleImpl(parentLeftTuple, rightTuple, childSink, true); readLeftTuple(childLeftTuple, context); } // context.out.println( "FromNode --- END" ); break; } case NodeTypeEnums.UnificationNode: { boolean isOpen = context.readBoolean(); if (isOpen) { QueryElementNode node = (QueryElementNode) sink; InternalFactHandle handle = readFactHandle(context); context.handles.put(handle.getId(), handle); node.createDroolsQuery(parentLeftTuple, handle, context.wm); readLeftTuples(context); } else { while (stream.readShort() == PersisterEnums.LEFT_TUPLE) { LeftTupleSink childSink = (LeftTupleSink) sinks.get(stream.readInt()); // we de-serialize the generated fact handle ID InternalFactHandle handle = readFactHandle(context); context.handles.put(handle.getId(), handle); RightTuple rightTuple = new RightTuple(handle); // @TODO check if open query LeftTuple childLeftTuple = new LeftTupleImpl(parentLeftTuple, rightTuple, childSink, true); readLeftTuple(childLeftTuple, context); } } break; } case NodeTypeEnums.RuleTerminalNode: { int pos = context.terminalTupleMap.size(); context.terminalTupleMap.put(pos, parentLeftTuple); break; } case NodeTypeEnums.QueryTerminalNode: { boolean unificationNode = context.readBoolean(); if (unificationNode) { // we de-serialize the generated fact handle ID InternalFactHandle handle = readFactHandle(context); context.handles.put(handle.getId(), handle); RightTuple rightTuple = new RightTuple(handle); parentLeftTuple.setObject(rightTuple); LeftTuple entry = parentLeftTuple; // find the DroolsQuery object while (entry.getParent() != null) { entry = entry.getParent(); } DroolsQuery query = (DroolsQuery) entry.getLastHandle().getObject(); LeftTuple leftTuple = ((UnificationNodeViewChangedEventListener) query.getQueryResultCollector()) .getLeftTuple(); while (stream.readShort() == PersisterEnums.LEFT_TUPLE) { LeftTupleSink childSink = (LeftTupleSink) sinks.get(stream.readInt()); // @TODO check if open query!!! LeftTuple childLeftTuple = childSink.createLeftTuple(leftTuple, rightTuple, childSink); readLeftTuple(childLeftTuple, context); } } break; } } }