Exemplo n.º 1
0
		internal QCandidates(LocalTransaction a_trans, ClassMetadata a_classMetadata, QField
			 a_field)
		{
			// Transaction necessary as reference to stream
			// root of the QCandidate tree
			// collection of all constraints
			// possible class information
			// possible field information
			// current executing constraint, only set where needed
			i_trans = a_trans;
			i_classMetadata = a_classMetadata;
			_field = a_field;
			if (a_field == null || a_field._fieldMetadata == null || !(a_field._fieldMetadata
				.GetHandler() is StandardReferenceTypeHandler))
			{
				return;
			}
			ClassMetadata yc = ((StandardReferenceTypeHandler)a_field._fieldMetadata.GetHandler
				()).ClassMetadata();
			if (i_classMetadata == null)
			{
				i_classMetadata = yc;
			}
			else
			{
				yc = i_classMetadata.GetHigherOrCommonHierarchy(yc);
				if (yc != null)
				{
					i_classMetadata = yc;
				}
			}
		}
Exemplo n.º 2
0
 public _ICallbackInfoCollector_297(LocalTransaction _enclosing, Collection4 added
                                    , Collection4 updated)
 {
     this._enclosing = _enclosing;
     this.added      = added;
     this.updated    = updated;
 }
Exemplo n.º 3
0
		internal QCandidates(LocalTransaction a_trans, ClassMetadata a_classMetadata, QField
			 a_field, bool isTopLevel)
		{
			// Transaction necessary as reference to stream
			// collection of all constraints
			// possible class information
			// possible field information
			// current executing constraint, only set where needed
			_result = new QueryResultCandidates(this);
			_isTopLevel = isTopLevel;
			i_trans = a_trans;
			_classMetadata = a_classMetadata;
			_field = a_field;
			if (a_field == null || a_field._fieldMetadata == null || !(a_field._fieldMetadata
				.GetHandler() is StandardReferenceTypeHandler))
			{
				return;
			}
			ClassMetadata yc = ((StandardReferenceTypeHandler)a_field._fieldMetadata.GetHandler
				()).ClassMetadata();
			if (_classMetadata == null)
			{
				_classMetadata = yc;
			}
			else
			{
				yc = _classMetadata.GetHigherOrCommonHierarchy(yc);
				if (yc != null)
				{
					_classMetadata = yc;
				}
			}
		}
Exemplo n.º 4
0
 public WriteUpdateProcessor(LocalTransaction transaction, int id, ClassMetadata clazz
                             , ArrayType typeInfo)
 {
     _transaction = transaction;
     _id          = id;
     _clazz       = clazz;
     _typeInfo    = typeInfo;
 }
Exemplo n.º 5
0
		public WriteUpdateProcessor(LocalTransaction transaction, int id, ClassMetadata clazz
			, ArrayType typeInfo)
		{
			_transaction = transaction;
			_id = id;
			_clazz = clazz;
			_typeInfo = typeInfo;
		}
		public virtual void ReadIdentity(LocalTransaction trans)
		{
			LocalObjectContainer file = trans.LocalContainer();
			Db4oDatabase identity = Debug4.staticIdentity ? Db4oDatabase.StaticIdentity : (Db4oDatabase
				)file.GetByID(trans, SystemData().IdentityId());
			if (null != identity)
			{
				file.Activate(trans, identity, new FixedActivationDepth(2));
				SystemData().Identity(identity);
			}
		}
Exemplo n.º 7
0
		private void AddCommittedInfoMsg(CallbackObjectInfoCollections committedInfo, LocalTransaction
			 serverTransaction)
		{
			lock (ContainerLock())
			{
				Msg.CommittedInfo.SetTransaction(serverTransaction);
				MCommittedInfo message = Msg.CommittedInfo.Encode(committedInfo, ServerMessageDispatcher
					().DispatcherID());
				message.SetMessageDispatcher(ServerMessageDispatcher());
				ServerMessageDispatcher().Server().AddCommittedInfoMsg(message);
			}
		}
Exemplo n.º 8
0
            public void OnEvent(object sender, Db4objects.Db4o.Events.CommitEventArgs args)
            {
                LocalTransaction trans = (LocalTransaction)((CommitEventArgs)args).Transaction();
                long             transactionTimestamp = trans.Timestamp();
                long             commitTimestamp      = (transactionTimestamp > 0) ? transactionTimestamp : this._enclosing
                                                        ._container.GenerateTimeStampId();
                Transaction sysTrans = trans.SystemTransaction();

                this.AddTimestamp(sysTrans, ((CommitEventArgs)args).Added.GetEnumerator(), commitTimestamp
                                  );
                this.AddTimestamp(sysTrans, ((CommitEventArgs)args).Updated.GetEnumerator(), commitTimestamp
                                  );
                this.AddTimestamp(sysTrans, ((CommitEventArgs)args).Deleted.GetEnumerator(), 0);
            }
Exemplo n.º 9
0
        public void DropIndex(LocalTransaction systemTrans)
        {
            if (_index == null)
            {
                return;
            }
            ObjectContainerBase stream = systemTrans.Container();

            if (stream.ConfigImpl.MessageLevel() > Const4.None)
            {
                stream.Message("dropping index " + ToString());
            }
            _index.Free(systemTrans);
            stream.SetDirtyInSystemTransaction(ContainingClass());
            _index = null;
        }
		public virtual ByteArrayBuffer Marshall(LocalTransaction transaction, IIntIterator4
			 ids, int count)
		{
			ByteArrayBuffer buffer = new ByteArrayBuffer(Const4.IntLength + count * Const4.IntLength
				);
			int sizeOffset = buffer.Offset();
			buffer.WriteInt(0);
			int written = 0;
			while (count > 0 && ids.MoveNext())
			{
				buffer.WriteInt(ids.CurrentInt());
				++written;
				--count;
			}
			buffer.Seek(sizeOffset);
			buffer.WriteInt(written);
			return buffer;
		}
Exemplo n.º 11
0
        /// <exception cref="Db4objects.Db4o.Internal.FieldIndexException"></exception>
        public override void AddFieldIndex(ObjectIdContextImpl context)
        {
            LocalTransaction     transaction    = (LocalTransaction)context.Transaction();
            LocalObjectContainer localContainer = (LocalObjectContainer)transaction.Container
                                                      ();
            Slot oldSlot                = transaction.IdSystem().CommittedSlot(context.ObjectId());
            int  savedOffset            = context.Offset();
            int  db4oDatabaseIdentityID = context.ReadInt();
            long uuid = context.ReadLong();

            context.Seek(savedOffset);
            bool isnew = (oldSlot.IsNull());

            if ((uuid == 0 || db4oDatabaseIdentityID == 0) && context.ObjectId() > 0 && !isnew)
            {
                UUIDFieldMetadata.DatabaseIdentityIDAndUUID identityAndUUID = ReadDatabaseIdentityIDAndUUID
                                                                                  (localContainer, context.ClassMetadata(), oldSlot, false);
                db4oDatabaseIdentityID = identityAndUUID.databaseIdentityID;
                uuid = identityAndUUID.uuid;
            }
            if (db4oDatabaseIdentityID == 0)
            {
                db4oDatabaseIdentityID = localContainer.Identity().GetID(transaction);
            }
            if (uuid == 0)
            {
                uuid = localContainer.GenerateTimeStampId();
            }
            StatefulBuffer writer = (StatefulBuffer)context.Buffer();

            writer.WriteInt(db4oDatabaseIdentityID);
            writer.WriteLong(uuid);
            if (isnew)
            {
                AddIndexEntry(writer, uuid);
            }
        }
Exemplo n.º 12
0
		public override void Free(LocalTransaction systemTrans)
		{
			_disposed = true;
			FreeAllNodeIds(systemTrans, AllNodeIds(systemTrans));
			base.Free((LocalTransaction)systemTrans);
		}
Exemplo n.º 13
0
		public override void Free(LocalTransaction trans)
		{
			_dead = true;
			if (!IsRoot())
			{
				Db4objects.Db4o.Internal.Btree.BTreeNode parent = _btree.ProduceNode(_parentID);
				parent.RemoveChild(trans, this);
			}
			PointPreviousTo(trans, _nextID);
			PointNextTo(trans, _previousID);
			base.Free((LocalTransaction)trans);
			_btree.RemoveNode(this);
			_btree.NotifyDeleted(trans, this);
		}
		public virtual ByteArrayBuffer Marshall(LocalTransaction transaction, IIntIterator4
			 ids, int maxCount)
		{
			return new EagerObjectWriter(_config, transaction).Write(ids, maxCount);
		}
Exemplo n.º 15
0
		/// <exception cref="System.Exception"></exception>
		public static void AssertAllSlotsFreed(LocalTransaction trans, BTree bTree, ICodeBlock
			 block)
		{
			LocalObjectContainer container = (LocalObjectContainer)trans.Container();
			ITransactionalIdSystem idSystem = trans.IdSystem();
			IEnumerator allSlotIDs = bTree.AllNodeIds(trans.SystemTransaction());
			Collection4 allSlots = new Collection4();
			while (allSlotIDs.MoveNext())
			{
				int slotID = ((int)allSlotIDs.Current);
				Slot slot = idSystem.CurrentSlot(slotID);
				allSlots.Add(slot);
			}
			Slot bTreeSlot = idSystem.CurrentSlot(bTree.GetID());
			allSlots.Add(bTreeSlot);
			Collection4 freedSlots = new Collection4();
			IFreespaceManager freespaceManager = container.FreespaceManager();
			container.InstallDebugFreespaceManager(new FreespaceManagerForDebug(new _ISlotListener_99
				(freedSlots)));
			block.Run();
			container.InstallDebugFreespaceManager(freespaceManager);
			Assert.IsTrue(freedSlots.ContainsAll(allSlots.GetEnumerator()));
		}
Exemplo n.º 16
0
		public StandardSlotAccessor(LocalTransaction transaction)
		{
			_transaction = transaction;
		}
Exemplo n.º 17
0
 public virtual void Free(LocalTransaction trans)
 {
     IdSystem(trans.SystemTransaction()).NotifySlotDeleted(GetID(), SlotChangeFactory(
                                                               ));
 }
Exemplo n.º 18
0
 public _IVisitor4_224(LocalTransaction _enclosing)
 {
     this._enclosing = _enclosing;
 }
Exemplo n.º 19
0
 public _ICommittedCallbackDispatcher_39(LocalTransaction _enclosing)
 {
     this._enclosing = _enclosing;
 }
		public SodaQueryComparator(LocalObjectContainer container, ClassMetadata extent, 
			SodaQueryComparator.Ordering[] orderings)
		{
			_container = container;
			_transaction = ((LocalTransaction)_container.Transaction);
			_extentType = extent;
			_orderings = orderings;
			ResolveFieldPaths(orderings);
		}
Exemplo n.º 21
0
 public _ICallbackInfoCollector_274(LocalTransaction _enclosing, Collection4 deleted
                                    )
 {
     this._enclosing = _enclosing;
     this.deleted    = deleted;
 }
Exemplo n.º 22
0
		private void FreeAllNodeIds(LocalTransaction systemTrans, IEnumerator allNodeIDs)
		{
			ITransactionalIdSystem idSystem = IdSystem(systemTrans);
			while (allNodeIDs.MoveNext())
			{
				int id = ((int)allNodeIDs.Current);
				idSystem.NotifySlotDeleted(id, SlotChangeFactory());
			}
		}
Exemplo n.º 23
0
			public _IVisitor4_336(DefragmentServicesImpl _enclosing, CommitTimestampSupport target
				, LocalTransaction targetTransaction)
			{
				this._enclosing = _enclosing;
				this.target = target;
				this.targetTransaction = targetTransaction;
			}
		public EagerObjectWriter(ObjectExchangeConfiguration config, LocalTransaction transaction
			)
		{
			_config = config;
			_transaction = transaction;
		}
Exemplo n.º 25
0
		public void DropIndex(LocalTransaction systemTrans)
		{
			if (_index == null)
			{
				return;
			}
			ObjectContainerBase stream = systemTrans.Container();
			if (stream.ConfigImpl.MessageLevel() > Const4.None)
			{
				stream.Message("dropping index " + ToString());
			}
			_index.Free(systemTrans);
			stream.SetDirtyInSystemTransaction(ContainingClass());
			_index = null;
		}
Exemplo n.º 26
0
 public _ICallbackInfoCollector_320(LocalTransaction _enclosing, Collection4 added
     , Collection4 updated, Collection4 deleted)
 {
     this._enclosing = _enclosing;
     this.added = added;
     this.updated = updated;
     this.deleted = deleted;
 }
Exemplo n.º 27
0
 public _IVisitor4_224(LocalTransaction _enclosing)
 {
     this._enclosing = _enclosing;
 }
Exemplo n.º 28
0
		public virtual void Free(LocalTransaction trans)
		{
			IdSystem(trans.SystemTransaction()).NotifySlotDeleted(GetID(), SlotChangeFactory(
				));
		}
Exemplo n.º 29
0
 public _ICallbackInfoCollector_274(LocalTransaction _enclosing, Collection4 deleted
     )
 {
     this._enclosing = _enclosing;
     this.deleted = deleted;
 }
Exemplo n.º 30
0
 public _ICommittedCallbackDispatcher_39(LocalTransaction _enclosing)
 {
     this._enclosing = _enclosing;
 }