use of com.palantir.atlasdb.keyvalue.api.RowColumnRangeIterator in project atlasdb by palantir.
the class KvsGetRowsColumnRangeBenchmarks method getAllColumnsUnaligned.
@Benchmark
@Threads(1)
@Warmup(time = 16, timeUnit = TimeUnit.SECONDS)
@Measurement(time = 160, timeUnit = TimeUnit.SECONDS)
public Object getAllColumnsUnaligned(WideRowsTable table) {
List<byte[]> rows = IntStream.rangeClosed(0, WideRowsTable.NUM_ROWS - 1).mapToObj(WideRowsTable::getRow).collect(Collectors.toList());
RowColumnRangeIterator rowsColumnRange = table.getKvs().getRowsColumnRange(table.getTableRef(), rows, new ColumnRangeSelection(null, null), 10017, Long.MAX_VALUE);
int expectedNumCells = WideRowsTable.NUM_ROWS * WideRowsTable.NUM_COLS_PER_ROW;
List<Map.Entry<Cell, Value>> loadedCells = new ArrayList<>(expectedNumCells);
while (rowsColumnRange.hasNext()) {
loadedCells.add(rowsColumnRange.next());
}
Preconditions.checkState(loadedCells.size() == expectedNumCells, "Should be %s cells, but were: %s", expectedNumCells, loadedCells.size());
return loadedCells;
}
use of com.palantir.atlasdb.keyvalue.api.RowColumnRangeIterator in project atlasdb by palantir.
the class CassandraKeyValueServiceImpl method getRowsColumnRangeIteratorForSingleHost.
private Map<byte[], RowColumnRangeIterator> getRowsColumnRangeIteratorForSingleHost(InetSocketAddress host, TableReference tableRef, List<byte[]> rows, BatchColumnRangeSelection batchColumnRangeSelection, long startTs) {
try {
RowColumnRangeExtractor.RowColumnRangeResult firstPage = getRowsColumnRangeForSingleHost(host, tableRef, rows, batchColumnRangeSelection, startTs);
Map<byte[], LinkedHashMap<Cell, Value>> results = firstPage.getResults();
Map<byte[], Column> rowsToLastCompositeColumns = firstPage.getRowsToLastCompositeColumns();
Map<byte[], byte[]> incompleteRowsToNextColumns = Maps.newHashMap();
for (Entry<byte[], Column> e : rowsToLastCompositeColumns.entrySet()) {
byte[] row = e.getKey();
byte[] col = CassandraKeyValueServices.decomposeName(e.getValue()).getLhSide();
// If we read a version of the cell before our start timestamp, it will be the most recent version
// readable to us and we can continue to the next column. Otherwise we have to continue reading
// this column.
Map<Cell, Value> rowResult = results.get(row);
boolean completedCell = (rowResult != null) && rowResult.containsKey(Cell.create(row, col));
boolean endOfRange = isEndOfColumnRange(completedCell, col, firstPage.getRowsToRawColumnCount().get(row), batchColumnRangeSelection);
if (!endOfRange) {
byte[] nextCol = getNextColumnRangeColumn(completedCell, col);
incompleteRowsToNextColumns.put(row, nextCol);
}
}
Map<byte[], RowColumnRangeIterator> ret = Maps.newHashMapWithExpectedSize(rows.size());
for (byte[] row : rowsToLastCompositeColumns.keySet()) {
Iterator<Entry<Cell, Value>> resultIterator;
Map<Cell, Value> result = results.get(row);
if (result != null) {
resultIterator = result.entrySet().iterator();
} else {
resultIterator = Collections.emptyIterator();
}
byte[] nextCol = incompleteRowsToNextColumns.get(row);
if (nextCol == null) {
ret.put(row, new LocalRowColumnRangeIterator(resultIterator));
} else {
BatchColumnRangeSelection newColumnRange = BatchColumnRangeSelection.create(nextCol, batchColumnRangeSelection.getEndCol(), batchColumnRangeSelection.getBatchHint());
ret.put(row, new LocalRowColumnRangeIterator(Iterators.concat(resultIterator, getRowColumnRange(host, tableRef, row, newColumnRange, startTs))));
}
}
// We saw no Cassandra results at all for these rows, so the entire column range is empty for these rows.
for (byte[] row : firstPage.getEmptyRows()) {
ret.put(row, new LocalRowColumnRangeIterator(Collections.emptyIterator()));
}
return ret;
} catch (Exception e) {
throw QosAwareThrowables.unwrapAndThrowRateLimitExceededOrAtlasDbDependencyException(e);
}
}
use of com.palantir.atlasdb.keyvalue.api.RowColumnRangeIterator in project atlasdb by palantir.
the class SnapshotTransaction method partitionByRow.
/**
* Partitions a {@link RowColumnRangeIterator} into contiguous blocks that share the same row name.
* {@link KeyValueService#getRowsColumnRange(TableReference, Iterable, ColumnRangeSelection, int, long)} guarantees
* that all columns for a single row are adjacent, so this method will return an {@link Iterator} with exactly one
* entry per non-empty row.
*/
private Iterator<Map.Entry<byte[], RowColumnRangeIterator>> partitionByRow(RowColumnRangeIterator rawResults) {
PeekingIterator<Map.Entry<Cell, Value>> peekableRawResults = Iterators.peekingIterator(rawResults);
return new AbstractIterator<Map.Entry<byte[], RowColumnRangeIterator>>() {
byte[] prevRowName;
@Override
protected Map.Entry<byte[], RowColumnRangeIterator> computeNext() {
finishConsumingPreviousRow(peekableRawResults);
if (!peekableRawResults.hasNext()) {
return endOfData();
}
byte[] nextRowName = peekableRawResults.peek().getKey().getRowName();
Iterator<Map.Entry<Cell, Value>> columnsIterator = new AbstractIterator<Map.Entry<Cell, Value>>() {
@Override
protected Map.Entry<Cell, Value> computeNext() {
if (!peekableRawResults.hasNext() || !Arrays.equals(peekableRawResults.peek().getKey().getRowName(), nextRowName)) {
return endOfData();
}
return peekableRawResults.next();
}
};
prevRowName = nextRowName;
return Maps.immutableEntry(nextRowName, new LocalRowColumnRangeIterator(columnsIterator));
}
private void finishConsumingPreviousRow(PeekingIterator<Map.Entry<Cell, Value>> iter) {
int numConsumed = 0;
while (iter.hasNext() && Arrays.equals(iter.peek().getKey().getRowName(), prevRowName)) {
iter.next();
numConsumed++;
}
if (numConsumed > 0) {
log.warn("Not all columns for row {} were read. {} columns were discarded.", UnsafeArg.of("row", Arrays.toString(prevRowName)), SafeArg.of("numColumnsDiscarded", numConsumed));
}
}
};
}
use of com.palantir.atlasdb.keyvalue.api.RowColumnRangeIterator in project atlasdb by palantir.
the class SnapshotTransaction method getRowsColumnRange.
@Override
public Map<byte[], BatchingVisitable<Map.Entry<Cell, byte[]>>> getRowsColumnRange(TableReference tableRef, Iterable<byte[]> rows, BatchColumnRangeSelection columnRangeSelection) {
checkGetPreconditions(tableRef);
if (Iterables.isEmpty(rows)) {
return ImmutableMap.of();
}
hasReads = true;
Map<byte[], RowColumnRangeIterator> rawResults = keyValueService.getRowsColumnRange(tableRef, rows, columnRangeSelection, getStartTimestamp());
Map<byte[], BatchingVisitable<Map.Entry<Cell, byte[]>>> postFilteredResults = Maps.newHashMapWithExpectedSize(rawResults.size());
for (Entry<byte[], RowColumnRangeIterator> e : rawResults.entrySet()) {
byte[] row = e.getKey();
RowColumnRangeIterator rawIterator = e.getValue();
Iterator<Map.Entry<Cell, byte[]>> postFilteredIterator = getPostFilteredColumns(tableRef, columnRangeSelection, row, rawIterator);
postFilteredResults.put(row, BatchingVisitableFromIterable.create(postFilteredIterator));
}
return postFilteredResults;
}
use of com.palantir.atlasdb.keyvalue.api.RowColumnRangeIterator in project atlasdb by palantir.
the class TracingKeyValueServiceTest method getRowsColumnRangeBatch.
@Test
public void getRowsColumnRangeBatch() throws Exception {
RowColumnRangeIterator rowColumnIterator = mock(RowColumnRangeIterator.class);
List<byte[]> rows = ImmutableList.of(ROW_NAME);
Map<byte[], RowColumnRangeIterator> expectedResult = ImmutableMap.of(ROW_NAME, rowColumnIterator);
BatchColumnRangeSelection range = BatchColumnRangeSelection.create(COL_NAME, COL_NAME, 2);
when(delegate.getRowsColumnRange(TABLE_REF, rows, range, TIMESTAMP)).thenReturn(expectedResult);
Map<byte[], RowColumnRangeIterator> result = kvs.getRowsColumnRange(TABLE_REF, rows, range, TIMESTAMP);
assertThat(result, equalTo(expectedResult));
checkSpan("atlasdb-kvs.getRowsColumnRange({table}, 1 rows, ts 1)");
verify(delegate).getRowsColumnRange(TABLE_REF, rows, range, TIMESTAMP);
verifyNoMoreInteractions(delegate);
}
Aggregations