Package org.apache.cassandra.db

Examples of org.apache.cassandra.db.OnDiskAtom


            file.seek(positionToSeek);
            FileMark mark = file.mark();
            // TODO only completely deserialize columns we are interested in
            while (file.bytesPastMark(mark) < indexInfo.width)
            {
                OnDiskAtom column = atomSerializer.deserializeFromSSTable(file, sstable.descriptor.version);
                // we check vs the original Set, not the filtered List, for efficiency
                if (!(column instanceof IColumn) || columnNames.contains(column.name()))
                    result.add(column);
            }
        }
    }
View Full Code Here


    protected void serializeColumns(Subscriber<? super AtomWritable> subscriber, byte[] rowKey, long deletedAt, int count,
            DataInput columns) throws IOException {
        for (int i = 0; i < count; i++) {
            // serialize columns
            OnDiskAtom atom = serializer.deserializeFromSSTable(columns, version);
            subscriber.onNext(new AtomWritable(rowKey, deletedAt, atom));
        }
    }
View Full Code Here

  }

  public void serializeColumns(StringBuilder sb, int count, DataInput columns) throws IOException {
    for (int i = 0; i < count; i++) {
      // serialize columns
      OnDiskAtom atom = serializer.deserializeFromSSTable(columns, version);
      if (atom instanceof IColumn) {
        IColumn column = (IColumn) atom;
        String cn = convertColumnName(column.name());
        sb.append("[\"");
        sb.append(cn);
View Full Code Here

            // we will duplicate this behavior. If the etl needs this data at some
            // point we can change, but it is only available assuming
            // cassandra hasn't discarded it.
            Iterator<OnDiskAtom> columnIterator = columns.iterator();
            while (columnIterator.hasNext()) {
                OnDiskAtom atom = columnIterator.next();
                if (atom instanceof RangeTombstone) {
                    columnIterator.remove();
                } else if (atom instanceof Column && ((Column) atom).timestamp() <= this.deletedAt) {
                    columnIterator.remove();
                }
View Full Code Here

                if (indexedColumnsInRow != null)
                    indexedColumnsInRow.clear();

                while (row.hasNext())
                {
                    OnDiskAtom column = row.next();

                    if (column instanceof Cell && cfs.indexManager.indexes((Cell) column))
                    {
                        if (indexedColumnsInRow == null)
                            indexedColumnsInRow = new ArrayList<>();
View Full Code Here

TOP

Related Classes of org.apache.cassandra.db.OnDiskAtom

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.