use of com.google.cloud.spanner.SessionPool.SessionConsumerImpl in project java-spanner by googleapis.
the class SessionPoolTest method testSessionNotFoundWriteAtLeastOnce.
@Test
public void testSessionNotFoundWriteAtLeastOnce() {
SpannerException sessionNotFound = SpannerExceptionFactoryTest.newSessionNotFoundException(sessionName);
List<Mutation> mutations = Collections.singletonList(Mutation.newInsertBuilder("FOO").build());
final SessionImpl closedSession = mockSession();
when(closedSession.writeAtLeastOnceWithOptions(mutations)).thenThrow(sessionNotFound);
final SessionImpl openSession = mockSession();
com.google.cloud.spanner.CommitResponse response = mock(com.google.cloud.spanner.CommitResponse.class);
when(response.getCommitTimestamp()).thenReturn(Timestamp.now());
when(openSession.writeAtLeastOnceWithOptions(mutations)).thenReturn(response);
doAnswer(invocation -> {
executor.submit(() -> {
SessionConsumerImpl consumer = invocation.getArgument(2, SessionConsumerImpl.class);
consumer.onSessionReady(closedSession);
});
return null;
}).doAnswer(invocation -> {
executor.submit(() -> {
SessionConsumerImpl consumer = invocation.getArgument(2, SessionConsumerImpl.class);
consumer.onSessionReady(openSession);
});
return null;
}).when(sessionClient).asyncBatchCreateSessions(Mockito.eq(1), Mockito.anyBoolean(), any(SessionConsumer.class));
FakeClock clock = new FakeClock();
clock.currentTimeMillis = System.currentTimeMillis();
pool = createPool(clock);
DatabaseClientImpl impl = new DatabaseClientImpl(pool);
assertThat(impl.writeAtLeastOnce(mutations)).isNotNull();
}
use of com.google.cloud.spanner.SessionPool.SessionConsumerImpl in project java-spanner by googleapis.
the class SessionPoolTest method poolClosureFailsPendingReadWaiters.
@Test
public void poolClosureFailsPendingReadWaiters() throws Exception {
final CountDownLatch insideCreation = new CountDownLatch(1);
final CountDownLatch releaseCreation = new CountDownLatch(1);
final SessionImpl session1 = mockSession();
final SessionImpl session2 = mockSession();
doAnswer(invocation -> {
executor.submit(() -> {
SessionConsumerImpl consumer = invocation.getArgument(2, SessionConsumerImpl.class);
consumer.onSessionReady(session1);
});
return null;
}).doAnswer(invocation -> {
executor.submit(() -> {
insideCreation.countDown();
releaseCreation.await();
SessionConsumerImpl consumer = invocation.getArgument(2, SessionConsumerImpl.class);
consumer.onSessionReady(session2);
return null;
});
return null;
}).when(sessionClient).asyncBatchCreateSessions(Mockito.eq(1), Mockito.anyBoolean(), any(SessionConsumer.class));
pool = createPool();
PooledSessionFuture leakedSession = pool.getSession();
// Suppress expected leakedSession warning.
leakedSession.clearLeakedException();
AtomicBoolean failed = new AtomicBoolean(false);
CountDownLatch latch = new CountDownLatch(1);
getSessionAsync(latch, failed);
insideCreation.await();
pool.closeAsync(new SpannerImpl.ClosedException());
releaseCreation.countDown();
latch.await(5L, TimeUnit.SECONDS);
assertThat(failed.get()).isTrue();
}
use of com.google.cloud.spanner.SessionPool.SessionConsumerImpl in project java-spanner by googleapis.
the class SessionPoolTest method idleSessionCleanup.
@Test
public void idleSessionCleanup() throws Exception {
options = SessionPoolOptions.newBuilder().setMinSessions(1).setMaxSessions(3).setIncStep(1).setMaxIdleSessions(0).build();
SessionImpl session1 = mockSession();
SessionImpl session2 = mockSession();
SessionImpl session3 = mockSession();
final LinkedList<SessionImpl> sessions = new LinkedList<>(Arrays.asList(session1, session2, session3));
doAnswer(invocation -> {
executor.submit(() -> {
SessionConsumerImpl consumer = invocation.getArgument(2, SessionConsumerImpl.class);
consumer.onSessionReady(sessions.pop());
});
return null;
}).when(sessionClient).asyncBatchCreateSessions(Mockito.eq(1), Mockito.anyBoolean(), any(SessionConsumer.class));
for (SessionImpl session : sessions) {
mockKeepAlive(session);
}
FakeClock clock = new FakeClock();
clock.currentTimeMillis = System.currentTimeMillis();
pool = createPool(clock);
// Make sure pool has been initialized
pool.getSession().close();
runMaintenanceLoop(clock, pool, pool.poolMaintainer.numClosureCycles);
assertThat(pool.numIdleSessionsRemoved()).isEqualTo(0L);
PooledSessionFuture readSession1 = pool.getSession();
PooledSessionFuture readSession2 = pool.getSession();
PooledSessionFuture readSession3 = pool.getSession();
// Wait until the sessions have actually been gotten in order to make sure they are in use in
// parallel.
readSession1.get();
readSession2.get();
readSession3.get();
readSession1.close();
readSession2.close();
readSession3.close();
// Now there are 3 sessions in the pool but since none of them has timed out, they will all be
// kept in the pool.
runMaintenanceLoop(clock, pool, pool.poolMaintainer.numClosureCycles);
assertThat(pool.numIdleSessionsRemoved()).isEqualTo(0L);
// Counters have now been reset
// Use all 3 sessions sequentially
pool.getSession().close();
pool.getSession().close();
pool.getSession().close();
// Advance the time by running the maintainer. This should cause
// one session to be kept alive and two sessions to be removed.
long cycles = options.getRemoveInactiveSessionAfter().toMillis() / pool.poolMaintainer.loopFrequency;
runMaintenanceLoop(clock, pool, cycles);
// We will still close 2 sessions since at any point in time only 1 session was in use.
assertThat(pool.numIdleSessionsRemoved()).isEqualTo(2L);
pool.closeAsync(new SpannerImpl.ClosedException()).get(5L, TimeUnit.SECONDS);
}
use of com.google.cloud.spanner.SessionPool.SessionConsumerImpl in project java-spanner by googleapis.
the class SessionPoolTest method testSessionNotFoundReadWriteTransaction.
@SuppressWarnings("unchecked")
@Test
public void testSessionNotFoundReadWriteTransaction() {
final Statement queryStatement = Statement.of("SELECT 1");
final Statement updateStatement = Statement.of("UPDATE FOO SET BAR=1 WHERE ID=2");
final SpannerException sessionNotFound = SpannerExceptionFactoryTest.newSessionNotFoundException(sessionName);
for (ReadWriteTransactionTestStatementType statementType : ReadWriteTransactionTestStatementType.values()) {
final ReadWriteTransactionTestStatementType executeStatementType = statementType;
SpannerRpc.StreamingCall closedStreamingCall = mock(SpannerRpc.StreamingCall.class);
doThrow(sessionNotFound).when(closedStreamingCall).request(Mockito.anyInt());
SpannerRpc rpc = mock(SpannerRpc.class);
when(rpc.asyncDeleteSession(Mockito.anyString(), Mockito.anyMap())).thenReturn(ApiFutures.immediateFuture(Empty.getDefaultInstance()));
when(rpc.executeQuery(any(ExecuteSqlRequest.class), any(ResultStreamConsumer.class), any(Map.class))).thenReturn(closedStreamingCall);
when(rpc.executeQuery(any(ExecuteSqlRequest.class), any(Map.class))).thenThrow(sessionNotFound);
when(rpc.executeBatchDml(any(ExecuteBatchDmlRequest.class), any(Map.class))).thenThrow(sessionNotFound);
when(rpc.commitAsync(any(CommitRequest.class), any(Map.class))).thenReturn(ApiFutures.<CommitResponse>immediateFailedFuture(sessionNotFound));
when(rpc.rollbackAsync(any(RollbackRequest.class), any(Map.class))).thenReturn(ApiFutures.<Empty>immediateFailedFuture(sessionNotFound));
final SessionImpl closedSession = mock(SessionImpl.class);
when(closedSession.getName()).thenReturn("projects/dummy/instances/dummy/database/dummy/sessions/session-closed");
final TransactionContextImpl closedTransactionContext = TransactionContextImpl.newBuilder().setSession(closedSession).setOptions(Options.fromTransactionOptions()).setRpc(rpc).build();
when(closedSession.asyncClose()).thenReturn(ApiFutures.immediateFuture(Empty.getDefaultInstance()));
when(closedSession.newTransaction(Options.fromTransactionOptions())).thenReturn(closedTransactionContext);
when(closedSession.beginTransactionAsync()).thenThrow(sessionNotFound);
TransactionRunnerImpl closedTransactionRunner = new TransactionRunnerImpl(closedSession);
closedTransactionRunner.setSpan(mock(Span.class));
when(closedSession.readWriteTransaction()).thenReturn(closedTransactionRunner);
final SessionImpl openSession = mock(SessionImpl.class);
when(openSession.asyncClose()).thenReturn(ApiFutures.immediateFuture(Empty.getDefaultInstance()));
when(openSession.getName()).thenReturn("projects/dummy/instances/dummy/database/dummy/sessions/session-open");
final TransactionContextImpl openTransactionContext = mock(TransactionContextImpl.class);
when(openSession.newTransaction(Options.fromTransactionOptions())).thenReturn(openTransactionContext);
when(openSession.beginTransactionAsync()).thenReturn(ApiFutures.immediateFuture(ByteString.copyFromUtf8("open-txn")));
TransactionRunnerImpl openTransactionRunner = new TransactionRunnerImpl(openSession);
openTransactionRunner.setSpan(mock(Span.class));
when(openSession.readWriteTransaction()).thenReturn(openTransactionRunner);
ResultSet openResultSet = mock(ResultSet.class);
when(openResultSet.next()).thenReturn(true, false);
ResultSet planResultSet = mock(ResultSet.class);
when(planResultSet.getStats()).thenReturn(ResultSetStats.getDefaultInstance());
when(openTransactionContext.executeQuery(queryStatement)).thenReturn(openResultSet);
when(openTransactionContext.analyzeQuery(queryStatement, QueryAnalyzeMode.PLAN)).thenReturn(planResultSet);
when(openTransactionContext.executeUpdate(updateStatement)).thenReturn(1L);
when(openTransactionContext.batchUpdate(Arrays.asList(updateStatement, updateStatement))).thenReturn(new long[] { 1L, 1L });
SpannerImpl spanner = mock(SpannerImpl.class);
SessionClient sessionClient = mock(SessionClient.class);
when(spanner.getSessionClient(db)).thenReturn(sessionClient);
doAnswer(invocation -> {
executor.submit(() -> {
SessionConsumerImpl consumer = invocation.getArgument(2, SessionConsumerImpl.class);
consumer.onSessionReady(closedSession);
});
return null;
}).doAnswer(invocation -> {
executor.submit(() -> {
SessionConsumerImpl consumer = invocation.getArgument(2, SessionConsumerImpl.class);
consumer.onSessionReady(openSession);
});
return null;
}).when(sessionClient).asyncBatchCreateSessions(Mockito.eq(1), Mockito.anyBoolean(), any(SessionConsumer.class));
SessionPoolOptions options = SessionPoolOptions.newBuilder().setMinSessions(// The pool should not auto-create any sessions
0).setMaxSessions(2).setIncStep(1).setBlockIfPoolExhausted().build();
SpannerOptions spannerOptions = mock(SpannerOptions.class);
when(spannerOptions.getSessionPoolOptions()).thenReturn(options);
when(spannerOptions.getNumChannels()).thenReturn(4);
when(spanner.getOptions()).thenReturn(spannerOptions);
SessionPool pool = SessionPool.createPool(options, new TestExecutorFactory(), spanner.getSessionClient(db));
try (PooledSessionFuture readWriteSession = pool.getSession()) {
TransactionRunner runner = readWriteSession.readWriteTransaction();
try {
runner.run(new TransactionCallable<Integer>() {
private int callNumber = 0;
@Override
public Integer run(TransactionContext transaction) {
callNumber++;
if (callNumber == 1) {
assertThat(transaction).isEqualTo(closedTransactionContext);
} else {
assertThat(transaction).isEqualTo(openTransactionContext);
}
switch(executeStatementType) {
case QUERY:
ResultSet resultSet = transaction.executeQuery(queryStatement);
assertThat(resultSet.next()).isTrue();
break;
case ANALYZE:
ResultSet planResultSet = transaction.analyzeQuery(queryStatement, QueryAnalyzeMode.PLAN);
assertThat(planResultSet.next()).isFalse();
assertThat(planResultSet.getStats()).isNotNull();
break;
case UPDATE:
long updateCount = transaction.executeUpdate(updateStatement);
assertThat(updateCount).isEqualTo(1L);
break;
case BATCH_UPDATE:
long[] updateCounts = transaction.batchUpdate(Arrays.asList(updateStatement, updateStatement));
assertThat(updateCounts).isEqualTo(new long[] { 1L, 1L });
break;
case WRITE:
transaction.buffer(Mutation.delete("FOO", Key.of(1L)));
break;
case EXCEPTION:
throw new RuntimeException("rollback at call " + callNumber);
default:
fail("Unknown statement type: " + executeStatementType);
}
return callNumber;
}
});
} catch (Exception e) {
// The rollback will also cause a SessionNotFoundException, but this is caught, logged
// and further ignored by the library, meaning that the session will not be re-created
// for retry. Hence rollback at call 1.
assertThat(executeStatementType).isEqualTo(ReadWriteTransactionTestStatementType.EXCEPTION);
assertThat(e.getMessage()).contains("rollback at call 1");
}
}
pool.closeAsync(new SpannerImpl.ClosedException());
}
}
use of com.google.cloud.spanner.SessionPool.SessionConsumerImpl in project java-spanner by googleapis.
the class SessionPoolTest method setupMockSessionCreation.
private void setupMockSessionCreation() {
doAnswer(invocation -> {
executor.submit(() -> {
int sessionCount = invocation.getArgument(0, Integer.class);
SessionConsumerImpl consumer = invocation.getArgument(2, SessionConsumerImpl.class);
for (int i = 0; i < sessionCount; i++) {
consumer.onSessionReady(mockSession());
}
});
return null;
}).when(sessionClient).asyncBatchCreateSessions(Mockito.anyInt(), Mockito.anyBoolean(), any(SessionConsumer.class));
}
Aggregations