use of org.apache.ignite.internal.processors.cache.persistence.PageStoreWriter in project ignite by apache.
the class IgnitePageMemReplaceDelayedWriteUnitTest method testBackwardCompatibilityMode.
/**
* Test delayed eviction causes locking in page reads
* @throws IgniteCheckedException if failed.
*/
@Test
public void testBackwardCompatibilityMode() throws IgniteCheckedException {
IgniteConfiguration cfg = getConfiguration(16 * MB);
AtomicInteger totalEvicted = new AtomicInteger();
PageStoreWriter pageWriter = (FullPageId fullPageId, ByteBuffer byteBuf, int tag) -> {
log.info("Evicting " + fullPageId);
assert getSegment(fullPageId).writeLock().isHeldByCurrentThread();
totalEvicted.incrementAndGet();
};
System.setProperty(IgniteSystemProperties.IGNITE_DELAYED_REPLACED_PAGE_WRITE, "false");
int pageSize = 4096;
PageMemoryImpl memory;
try {
memory = createPageMemory(cfg, pageWriter, pageSize);
} finally {
System.clearProperty(IgniteSystemProperties.IGNITE_DELAYED_REPLACED_PAGE_WRITE);
}
this.pageMemory = memory;
long pagesTotal = cfg.getDataStorageConfiguration().getDefaultDataRegionConfiguration().getMaxSize() / pageSize;
long markDirty = pagesTotal * 2 / 3;
for (int i = 0; i < markDirty; i++) {
long pageId = memory.allocatePage(1, 1, PageIdAllocator.FLAG_DATA);
long ptr = memory.acquirePage(1, pageId);
memory.releasePage(1, pageId, ptr);
}
GridMultiCollectionWrapper<FullPageId> ids = memory.beginCheckpoint(new GridFinishedFuture());
int cpPages = ids.size();
log.info("Started CP with [" + cpPages + "] pages in it, created [" + markDirty + "] pages");
for (int i = 0; i < cpPages; i++) {
long pageId = memory.allocatePage(1, 1, PageIdAllocator.FLAG_DATA);
long ptr = memory.acquirePage(1, pageId);
memory.releasePage(1, pageId, ptr);
}
assert totalEvicted.get() > 0;
memory.stop(true);
}
use of org.apache.ignite.internal.processors.cache.persistence.PageStoreWriter in project ignite by apache.
the class CheckpointPagesWriter method writePages.
/**
* @param writePageIds Collections of pages to write.
* @return pagesToRetry Pages which should be retried.
*/
private GridConcurrentMultiPairQueue<PageMemoryEx, FullPageId> writePages(GridConcurrentMultiPairQueue<PageMemoryEx, FullPageId> writePageIds) throws IgniteCheckedException {
Map<PageMemoryEx, List<FullPageId>> pagesToRetry = new HashMap<>();
CheckpointMetricsTracker tracker = persStoreMetrics.metricsEnabled() ? this.tracker : null;
Map<PageMemoryEx, PageStoreWriter> pageStoreWriters = new HashMap<>();
ByteBuffer tmpWriteBuf = threadBuf.get();
boolean throttlingEnabled = throttlingPolicy != PageMemoryImpl.ThrottlingPolicy.DISABLED;
GridConcurrentMultiPairQueue.Result<PageMemoryEx, FullPageId> res = new GridConcurrentMultiPairQueue.Result<>();
while (writePageIds.next(res)) {
if (shutdownNow.getAsBoolean())
break;
beforePageWrite.run();
FullPageId fullId = res.getValue();
PageMemoryEx pageMem = res.getKey();
snapshotMgr.beforePageWrite(fullId);
tmpWriteBuf.rewind();
PageStoreWriter pageStoreWriter = pageStoreWriters.computeIfAbsent(pageMem, pageMemEx -> createPageStoreWriter(pageMemEx, pagesToRetry));
pageMem.checkpointWritePage(fullId, tmpWriteBuf, pageStoreWriter, tracker);
if (throttlingEnabled) {
while (pageMem.isCpBufferOverflowThresholdExceeded()) {
FullPageId cpPageId = pageMem.pullPageFromCpBuffer();
if (cpPageId.equals(FullPageId.NULL_PAGE))
break;
snapshotMgr.beforePageWrite(cpPageId);
tmpWriteBuf.rewind();
pageMem.checkpointWritePage(cpPageId, tmpWriteBuf, pageStoreWriter, tracker);
}
}
}
return pagesToRetry.isEmpty() ? GridConcurrentMultiPairQueue.EMPTY : new GridConcurrentMultiPairQueue<>(pagesToRetry);
}
use of org.apache.ignite.internal.processors.cache.persistence.PageStoreWriter in project ignite by apache.
the class CheckpointPagesWriter method createPageStoreWriter.
/**
* Factory method for create {@link PageStoreWriter}.
*
* @param pageMemEx
* @param pagesToRetry List pages for retry.
* @return Checkpoint page write context.
*/
private PageStoreWriter createPageStoreWriter(PageMemoryEx pageMemEx, Map<PageMemoryEx, List<FullPageId>> pagesToRetry) {
return new PageStoreWriter() {
/**
* {@inheritDoc}
*/
@Override
public void writePage(FullPageId fullPageId, ByteBuffer buf, int tag) throws IgniteCheckedException {
if (tag == PageMemoryImpl.TRY_AGAIN_TAG) {
pagesToRetry.computeIfAbsent(pageMemEx, k -> new ArrayList<>()).add(fullPageId);
return;
}
int groupId = fullPageId.groupId();
long pageId = fullPageId.pageId();
assert getType(buf) != 0 : "Invalid state. Type is 0! pageId = " + hexLong(pageId);
assert getVersion(buf) != 0 : "Invalid state. Version is 0! pageId = " + hexLong(pageId);
if (persStoreMetrics.metricsEnabled()) {
int pageType = getType(buf);
if (PageIO.isDataPageType(pageType))
tracker.onDataPageWritten();
}
curCpProgress.updateWrittenPages(1);
PageStore store = pageWriter.write(pageMemEx, fullPageId, buf, tag);
updStores.computeIfAbsent(store, k -> new LongAdder()).increment();
}
};
}
use of org.apache.ignite.internal.processors.cache.persistence.PageStoreWriter in project ignite by apache.
the class PageMemoryImplTest method doCheckpoint.
/**
* @param cpPages Checkpoint pages acuiqred by {@code beginCheckpoint()}.
* @param memory Page memory.
* @param pageStoreMgr Test page store manager.
* @throws Exception If failed.
*/
private void doCheckpoint(GridMultiCollectionWrapper<FullPageId> cpPages, PageMemoryImpl memory, TestPageStoreManager pageStoreMgr) throws Exception {
PageStoreWriter pageStoreWriter = (fullPageId, buf, tag) -> {
assertNotNull(tag);
pageStoreMgr.write(fullPageId.groupId(), fullPageId.pageId(), buf, 1, false);
};
for (FullPageId cpPage : cpPages) {
byte[] data = new byte[PAGE_SIZE];
ByteBuffer buf = ByteBuffer.wrap(data);
memory.checkpointWritePage(cpPage, buf, pageStoreWriter, null);
while (memory.isCpBufferOverflowThresholdExceeded()) {
FullPageId cpPageId = memory.pullPageFromCpBuffer();
if (cpPageId.equals(FullPageId.NULL_PAGE))
break;
ByteBuffer tmpWriteBuf = ByteBuffer.allocateDirect(memory.pageSize());
tmpWriteBuf.order(ByteOrder.nativeOrder());
tmpWriteBuf.rewind();
memory.checkpointWritePage(cpPageId, tmpWriteBuf, pageStoreWriter, null);
}
}
memory.finishCheckpoint();
}
use of org.apache.ignite.internal.processors.cache.persistence.PageStoreWriter in project ignite by apache.
the class IgnitePdsCheckpointSimulationWithRealCpDisabledTest method runCheckpointing.
/**
* @param mem Memory to use.
* @param storeMgr Store manager.
* @param cacheId Cache ID.
* @return Result map of random operations.
* @throws Exception If failure occurred.
*/
private IgniteBiTuple<Map<FullPageId, Integer>, WALPointer> runCheckpointing(final IgniteEx ig, final PageMemoryImpl mem, final IgnitePageStoreManager storeMgr, final IgniteWriteAheadLogManager wal, final int cacheId) throws Exception {
final ConcurrentMap<FullPageId, Integer> resMap = new ConcurrentHashMap<>();
final FullPageId[] pages = new FullPageId[TOTAL_PAGES];
Set<FullPageId> allocated = new HashSet<>();
IgniteCacheDatabaseSharedManager db = ig.context().cache().context().database();
PageIO pageIO = new DummyPageIO();
for (int i = 0; i < TOTAL_PAGES; i++) {
FullPageId fullId;
db.checkpointReadLock();
try {
fullId = new FullPageId(mem.allocatePage(cacheId, 0, PageIdAllocator.FLAG_DATA), cacheId);
initPage(mem, pageIO, fullId);
} finally {
db.checkpointReadUnlock();
}
resMap.put(fullId, -1);
pages[i] = fullId;
allocated.add(fullId);
}
final AtomicBoolean run = new AtomicBoolean(true);
// Simulate transaction lock.
final ReadWriteLock updLock = new ReentrantReadWriteLock();
// Mark the start position.
CheckpointRecord cpRec = new CheckpointRecord(null);
WALPointer start = wal.log(cpRec);
wal.flush(start, false);
IgniteInternalFuture<Long> updFut = GridTestUtils.runMultiThreadedAsync(new Callable<Object>() {
@Override
public Object call() throws Exception {
while (true) {
FullPageId fullId = pages[ThreadLocalRandom.current().nextInt(TOTAL_PAGES)];
updLock.readLock().lock();
try {
if (!run.get())
return null;
ig.context().cache().context().database().checkpointReadLock();
try {
long page = mem.acquirePage(fullId.groupId(), fullId.pageId());
try {
long pageAddr = mem.writeLock(fullId.groupId(), fullId.pageId(), page);
PageIO.setPageId(pageAddr, fullId.pageId());
try {
int state = resMap.get(fullId);
if (state != -1) {
if (VERBOSE)
info("Verify page [fullId=" + fullId + ", state=" + state + ", buf=" + pageAddr + ", bhc=" + U.hexLong(System.identityHashCode(pageAddr)) + ", page=" + U.hexLong(System.identityHashCode(page)) + ']');
for (int i = PageIO.COMMON_HEADER_END; i < mem.realPageSize(fullId.groupId()); i++) {
assertEquals("Verify page failed [fullId=" + fullId + ", i=" + i + ", state=" + state + ", buf=" + pageAddr + ", bhc=" + U.hexLong(System.identityHashCode(pageAddr)) + ", page=" + U.hexLong(System.identityHashCode(page)) + ']', state & 0xFF, PageUtils.getByte(pageAddr, i) & 0xFF);
}
}
state = (state + 1) & 0xFF;
if (VERBOSE)
info("Write page [fullId=" + fullId + ", state=" + state + ", buf=" + pageAddr + ", bhc=" + U.hexLong(System.identityHashCode(pageAddr)) + ", page=" + U.hexLong(System.identityHashCode(page)) + ']');
for (int i = PageIO.COMMON_HEADER_END; i < mem.realPageSize(fullId.groupId()); i++) PageUtils.putByte(pageAddr, i, (byte) state);
resMap.put(fullId, state);
} finally {
mem.writeUnlock(fullId.groupId(), fullId.pageId(), page, null, true);
}
} finally {
mem.releasePage(fullId.groupId(), fullId.pageId(), page);
}
} finally {
ig.context().cache().context().database().checkpointReadUnlock();
}
} finally {
updLock.readLock().unlock();
}
}
}
}, 8, "update-thread");
int checkpoints = 20;
while (checkpoints > 0) {
Map<FullPageId, Integer> snapshot = null;
Collection<FullPageId> pageIds;
updLock.writeLock().lock();
try {
snapshot = new HashMap<>(resMap);
pageIds = mem.beginCheckpoint(new GridFinishedFuture());
checkpoints--;
if (checkpoints == 0)
// No more writes should be done at this point.
run.set(false);
info("Acquired pages for checkpoint: " + pageIds.size());
} finally {
updLock.writeLock().unlock();
}
boolean ok = false;
try {
ByteBuffer tmpBuf = ByteBuffer.allocate(mem.pageSize());
tmpBuf.order(ByteOrder.nativeOrder());
long begin = System.currentTimeMillis();
long cp = 0;
long write = 0;
for (FullPageId fullId : pageIds) {
long cpStart = System.nanoTime();
Integer tag;
AtomicReference<Integer> tag0 = new AtomicReference<>();
PageStoreWriter pageStoreWriter = (fullPageId, buf, tagx) -> {
tag0.set(tagx);
};
while (true) {
mem.checkpointWritePage(fullId, tmpBuf, pageStoreWriter, null);
tag = tag0.get();
if (tag != null && tag == PageMemoryImpl.TRY_AGAIN_TAG)
continue;
break;
}
if (tag == null)
continue;
long cpEnd = System.nanoTime();
cp += cpEnd - cpStart;
Integer state = snapshot.get(fullId);
if (allocated.contains(fullId) && state != -1) {
tmpBuf.rewind();
Integer first = null;
for (int i = PageIO.COMMON_HEADER_END; i < mem.realPageSize(fullId.groupId()); i++) {
int val = tmpBuf.get(i) & 0xFF;
if (first == null)
first = val;
// Avoid string concat.
if (first != val)
assertEquals("Corrupted buffer at position [pageId=" + fullId + ", pos=" + i + ']', (int) first, val);
// Avoid string concat.
if (state != val)
assertEquals("Invalid value at position [pageId=" + fullId + ", pos=" + i + ']', (int) state, val);
}
}
tmpBuf.rewind();
long writeStart = System.nanoTime();
storeMgr.write(cacheId, fullId.pageId(), tmpBuf, tag, true);
long writeEnd = System.nanoTime();
write += writeEnd - writeStart;
tmpBuf.rewind();
}
long syncStart = System.currentTimeMillis();
storeMgr.sync(cacheId, 0);
long end = System.currentTimeMillis();
info("Written pages in " + (end - begin) + "ms, copy took " + (cp / 1_000_000) + "ms, " + "write took " + (write / 1_000_000) + "ms, sync took " + (end - syncStart) + "ms");
ok = true;
} finally {
info("Finishing checkpoint...");
mem.finishCheckpoint();
info("Finished checkpoint");
if (!ok) {
info("Cancelling updates...");
run.set(false);
updFut.get();
}
}
if (checkpoints != 0)
Thread.sleep(2_000);
}
info("checkpoints=" + checkpoints + ", done=" + updFut.isDone());
updFut.get();
assertEquals(0, mem.activePagesCount());
for (FullPageId fullId : pages) {
long page = mem.acquirePage(fullId.groupId(), fullId.pageId());
try {
assertFalse("Page has a temp heap copy after the last checkpoint: [cacheId=" + fullId.groupId() + ", pageId=" + fullId.pageId() + "]", mem.hasTempCopy(page));
assertFalse("Page is dirty after the last checkpoint: [cacheId=" + fullId.groupId() + ", pageId=" + fullId.pageId() + "]", mem.isDirty(fullId.groupId(), fullId.pageId(), page));
} finally {
mem.releasePage(fullId.groupId(), fullId.pageId(), page);
}
}
return F.t((Map<FullPageId, Integer>) resMap, start);
}
Aggregations