diff --git a/server/src/com/cloud/api/ApiDBUtils.java b/server/src/com/cloud/api/ApiDBUtils.java index 7b441901d5e..cdafa5a2737 100755 --- a/server/src/com/cloud/api/ApiDBUtils.java +++ b/server/src/com/cloud/api/ApiDBUtils.java @@ -86,7 +86,6 @@ import com.cloud.api.query.vo.UserVmJoinVO; import com.cloud.api.query.vo.VolumeJoinVO; import com.cloud.async.AsyncJob; import com.cloud.async.AsyncJobManager; -import com.cloud.async.AsyncJobVO; import com.cloud.async.dao.AsyncJobDao; import com.cloud.capacity.CapacityVO; import com.cloud.capacity.dao.CapacityDao; @@ -661,10 +660,6 @@ public class ApiDBUtils { return _resourceLimitMgr.findCorrectResourceLimitForAccount(accountType, limit, type); } - public static AsyncJobVO findInstancePendingAsyncJob(String instanceType, long instanceId) { - return _asyncMgr.findInstancePendingAsyncJob(instanceType, instanceId); - } - public static long getResourceCount(ResourceType type, long accountId) { AccountVO account = _accountDao.findById(accountId); diff --git a/server/src/com/cloud/async/AsyncJobManager.java b/server/src/com/cloud/async/AsyncJobManager.java index 95f71576b6d..0fbb785e1fb 100644 --- a/server/src/com/cloud/async/AsyncJobManager.java +++ b/server/src/com/cloud/async/AsyncJobManager.java @@ -24,7 +24,6 @@ import com.cloud.utils.component.Manager; public interface AsyncJobManager extends Manager { public AsyncJobVO getAsyncJob(long jobId); - public AsyncJobVO findInstancePendingAsyncJob(String instanceType, long instanceId); public List findInstancePendingAsyncJobs(AsyncJob.Type instanceType, Long accountId); diff --git a/server/src/com/cloud/async/AsyncJobManagerImpl.java b/server/src/com/cloud/async/AsyncJobManagerImpl.java index d2f49122411..1406566adc6 100644 --- a/server/src/com/cloud/async/AsyncJobManagerImpl.java +++ b/server/src/com/cloud/async/AsyncJobManagerImpl.java @@ -52,7 +52,6 @@ import com.cloud.user.Account; import com.cloud.user.AccountManager; import com.cloud.user.User; import com.cloud.user.UserContext; -import com.cloud.user.dao.AccountDao; import com.cloud.utils.DateUtil; import com.cloud.utils.NumbersUtil; import com.cloud.utils.PropertiesUtil; @@ -79,7 +78,6 @@ public class AsyncJobManagerImpl extends ManagerBase implements AsyncJobManager, @Inject private SyncQueueManager _queueMgr; @Inject private ClusterManager _clusterMgr; @Inject private AccountManager _accountMgr; - @Inject private AccountDao _accountDao; @Inject private AsyncJobDao _jobDao; @Inject private ConfigurationDao _configDao; @Inject private List _jobDispatchers; @@ -105,11 +103,6 @@ public class AsyncJobManagerImpl extends ManagerBase implements AsyncJobManager, return _jobDao.findById(jobId); } - @Override - public AsyncJobVO findInstancePendingAsyncJob(String instanceType, long instanceId) { - return _jobDao.findInstancePendingAsyncJob(instanceType, instanceId); - } - @Override public List findInstancePendingAsyncJobs(AsyncJob.Type instanceType, Long accountId) { return _jobDao.findInstancePendingAsyncJobs(instanceType, accountId); diff --git a/server/src/com/cloud/async/dao/SyncQueueItemDaoImpl.java b/server/src/com/cloud/async/dao/SyncQueueItemDaoImpl.java index 829b3bb6016..29eb84165f2 100644 --- a/server/src/com/cloud/async/dao/SyncQueueItemDaoImpl.java +++ b/server/src/com/cloud/async/dao/SyncQueueItemDaoImpl.java @@ -43,7 +43,7 @@ public class SyncQueueItemDaoImpl extends GenericDaoBase private static final Logger s_logger = Logger.getLogger(SyncQueueItemDaoImpl.class); final GenericSearchBuilder queueIdSearch; - protected SyncQueueItemDaoImpl() { + public SyncQueueItemDaoImpl() { super(); queueIdSearch = createSearchBuilder(Long.class); queueIdSearch.and("contentId", queueIdSearch.entity().getContentId(), Op.EQ); diff --git a/server/test/async-job-component.xml b/server/test/async-job-component.xml deleted file mode 100644 index 46982523a23..00000000000 --- a/server/test/async-job-component.xml +++ /dev/null @@ -1,203 +0,0 @@ - - - - - - - - - - - 50 - -1 - - - - - 50 - -1 - - - 50 - -1 - - - - - - - 50 - -1 - routing - - - 5000 - 300 - - - - 50 - -1 - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - 2 - - - 2 - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - true - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - diff --git a/server/test/com/cloud/async/CleanupDelegate.java b/server/test/com/cloud/async/CleanupDelegate.java deleted file mode 100644 index 385e4cbdc12..00000000000 --- a/server/test/com/cloud/async/CleanupDelegate.java +++ /dev/null @@ -1,29 +0,0 @@ -// Licensed to the Apache Software Foundation (ASF) under one -// or more contributor license agreements. See the NOTICE file -// distributed with this work for additional information -// regarding copyright ownership. The ASF licenses this file -// to you under the Apache License, Version 2.0 (the -// "License"); you may not use this file except in compliance -// with the License. You may obtain a copy of the License at -// -// http://www.apache.org/licenses/LICENSE-2.0 -// -// Unless required by applicable law or agreed to in writing, -// software distributed under the License is distributed on an -// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY -// KIND, either express or implied. See the License for the -// specific language governing permissions and limitations -// under the License. -package com.cloud.async; - -import org.apache.log4j.Logger; - -public class CleanupDelegate implements com.cloud.utils.CleanupDelegate { - private static final Logger s_logger = Logger.getLogger(CleanupDelegate.class); - - @Override - public boolean cleanup(String param, Object managerContext) { - s_logger.info("Action called with param: " + param); - return true; - } -} diff --git a/server/test/com/cloud/async/TestAsync.java b/server/test/com/cloud/async/TestAsync.java deleted file mode 100644 index 6f67fe2227f..00000000000 --- a/server/test/com/cloud/async/TestAsync.java +++ /dev/null @@ -1,281 +0,0 @@ -// Licensed to the Apache Software Foundation (ASF) under one -// or more contributor license agreements. See the NOTICE file -// distributed with this work for additional information -// regarding copyright ownership. The ASF licenses this file -// to you under the Apache License, Version 2.0 (the -// "License"); you may not use this file except in compliance -// with the License. You may obtain a copy of the License at -// -// http://www.apache.org/licenses/LICENSE-2.0 -// -// Unless required by applicable law or agreed to in writing, -// software distributed under the License is distributed on an -// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY -// KIND, either express or implied. See the License for the -// specific language governing permissions and limitations -// under the License. -package com.cloud.async; - - -import java.util.List; - -import junit.framework.Assert; - -import org.apache.log4j.Logger; - -import com.cloud.cluster.CheckPointVO; -import com.cloud.cluster.dao.StackMaidDao; -import com.cloud.cluster.dao.StackMaidDaoImpl; -import com.cloud.utils.db.Transaction; -import com.cloud.utils.testcase.Log4jEnabledTestCase; - - -public class TestAsync extends Log4jEnabledTestCase { - private static final Logger s_logger = Logger.getLogger(TestAsync.class); - - /* - public static class SampleAsyncResult { - @Param(name="name", propName="name") - private final String _name; - - @Param - private final int count; - - public SampleAsyncResult(String name, int count) { - _name = name; - this.count = count; - } - - public String getName() { return _name; } - public int getCount() { return count; } - } - - public void testDao() { - AsyncJobDao dao = new AsyncJobDaoImpl(); - AsyncJobVO job = new AsyncJobVO(1, 1, "TestCmd", null); - job.setInstanceType("user_vm"); - job.setInstanceId(1000L); - - char[] buf = new char[1024]; - for(int i = 0; i < 1024; i++) - buf[i] = 'a'; - - job.setResult(new String(buf)); - dao.persist(job); - - AsyncJobVO jobVerify = dao.findById(job.getId()); - - Assert.assertTrue(jobVerify.getCmd().equals(job.getCmd())); - Assert.assertTrue(jobVerify.getUserId() == 1); - Assert.assertTrue(jobVerify.getAccountId() == 1); - - String result = jobVerify.getResult(); - for(int i = 0; i < 1024; i++) - Assert.assertTrue(result.charAt(i) == 'a'); - - jobVerify = dao.findInstancePendingAsyncJob("user_vm", 1000L); - Assert.assertTrue(jobVerify != null); - Assert.assertTrue(jobVerify.getCmd().equals(job.getCmd())); - Assert.assertTrue(jobVerify.getUserId() == 1); - Assert.assertTrue(jobVerify.getAccountId() == 1); - } - - public void testSerialization() { - List> l; - int value = 1; - l = SerializerHelper.toPairList(value, "result"); - Assert.assertTrue(l.size() == 1); - Assert.assertTrue(l.get(0).first().equals("result")); - Assert.assertTrue(l.get(0).second().equals("1")); - l.clear(); - - SampleAsyncResult result = new SampleAsyncResult("vmops", 1); - l = SerializerHelper.toPairList(result, "result"); - - Assert.assertTrue(l.size() == 2); - Assert.assertTrue(l.get(0).first().equals("name")); - Assert.assertTrue(l.get(0).second().equals("vmops")); - Assert.assertTrue(l.get(1).first().equals("count")); - Assert.assertTrue(l.get(1).second().equals("1")); - } - - public void testAsyncResult() { - AsyncJobResult result = new AsyncJobResult(1); - - result.setResultObject(100); - Assert.assertTrue(result.getResult().equals("java.lang.Integer/100")); - - Object obj = result.getResultObject(); - Assert.assertTrue(obj instanceof Integer); - Assert.assertTrue(((Integer)obj).intValue() == 100); - } - - public void testTransaction() { - Transaction txn = Transaction.open("testTransaction"); - try { - txn.start(); - - AsyncJobDao dao = new AsyncJobDaoImpl(); - AsyncJobVO job = new AsyncJobVO(1, 1, "TestCmd", null); - job.setInstanceType("user_vm"); - job.setInstanceId(1000L); - job.setResult(""); - dao.persist(job); - txn.rollback(); - } finally { - txn.close(); - } - } - - public void testMorevingian() { - int threadCount = 10; - final int testCount = 10; - - Thread[] threads = new Thread[threadCount]; - for(int i = 0; i < threadCount; i++) { - final int threadNum = i + 1; - threads[i] = new Thread(new Runnable() { - public void run() { - for(int i = 0; i < testCount; i++) { - Transaction txn = Transaction.open(Transaction.CLOUD_DB); - try { - AsyncJobDao dao = new AsyncJobDaoImpl(); - - s_logger.info("Thread " + threadNum + " acquiring lock"); - AsyncJobVO job = dao.acquire(1L, 30); - if(job != null) { - s_logger.info("Thread " + threadNum + " acquired lock"); - - try { - Thread.sleep(Log4jEnabledTestCase.getRandomMilliseconds(1000, 3000)); - } catch (InterruptedException e) { - } - - s_logger.info("Thread " + threadNum + " acquiring lock nestly"); - AsyncJobVO job2 = dao.acquire(1L, 30); - if(job2 != null) { - s_logger.info("Thread " + threadNum + " acquired lock nestly"); - - try { - Thread.sleep(Log4jEnabledTestCase.getRandomMilliseconds(1000, 3000)); - } catch (InterruptedException e) { - } - - s_logger.info("Thread " + threadNum + " releasing lock (nestly acquired)"); - dao.release(1L); - s_logger.info("Thread " + threadNum + " released lock (nestly acquired)"); - - } else { - s_logger.info("Thread " + threadNum + " was unable to acquire lock nestly"); - } - - s_logger.info("Thread " + threadNum + " releasing lock"); - dao.release(1L); - s_logger.info("Thread " + threadNum + " released lock"); - } else { - s_logger.info("Thread " + threadNum + " was unable to acquire lock"); - } - } finally { - txn.close(); - } - - try { - Thread.sleep(Log4jEnabledTestCase.getRandomMilliseconds(1000, 10000)); - } catch (InterruptedException e) { - } - } - } - }); - } - - for(int i = 0; i < threadCount; i++) { - threads[i].start(); - } - - for(int i = 0; i < threadCount; i++) { - try { - threads[i].join(); - } catch (InterruptedException e) { - } - } - } - */ - - public void testMaid() { - Transaction txn = Transaction.open(Transaction.CLOUD_DB); - - StackMaidDao dao = new StackMaidDaoImpl(); - dao.pushCleanupDelegate(1L, 0, "delegate1", "Hello, world"); - dao.pushCleanupDelegate(1L, 1, "delegate2", new Long(100)); - dao.pushCleanupDelegate(1L, 2, "delegate3", null); - - CheckPointVO item = dao.popCleanupDelegate(1L); - Assert.assertTrue(item.getDelegate().equals("delegate3")); - Assert.assertTrue(item.getContext() == null); - - item = dao.popCleanupDelegate(1L); - Assert.assertTrue(item.getDelegate().equals("delegate2")); - s_logger.info(item.getContext()); - - item = dao.popCleanupDelegate(1L); - Assert.assertTrue(item.getDelegate().equals("delegate1")); - s_logger.info(item.getContext()); - - txn.close(); - } - - public void testMaidClear() { - Transaction txn = Transaction.open(Transaction.CLOUD_DB); - - StackMaidDao dao = new StackMaidDaoImpl(); - dao.pushCleanupDelegate(1L, 0, "delegate1", "Hello, world"); - dao.pushCleanupDelegate(1L, 1, "delegate2", new Long(100)); - dao.pushCleanupDelegate(1L, 2, "delegate3", null); - - dao.clearStack(1L); - Assert.assertTrue(dao.popCleanupDelegate(1L) == null); - txn.close(); - } - - - public void testMaidLeftovers() { - - Thread[] threads = new Thread[3]; - for(int i = 0; i < 3; i++) { - final int threadNum = i+1; - threads[i] = new Thread(new Runnable() { - @Override - public void run() { - Transaction txn = Transaction.open(Transaction.CLOUD_DB); - - StackMaidDao dao = new StackMaidDaoImpl(); - dao.pushCleanupDelegate(1L, 0, "delegate-" + threadNum, "Hello, world"); - dao.pushCleanupDelegate(1L, 1, "delegate-" + threadNum, new Long(100)); - dao.pushCleanupDelegate(1L, 2, "delegate-" + threadNum, null); - - txn.close(); - } - }); - - threads[i].start(); - } - - for(int i = 0; i < 3; i++) { - try { - threads[i].join(); - } catch (InterruptedException e) { - } - } - - - Transaction txn = Transaction.open(Transaction.CLOUD_DB); - - StackMaidDao dao = new StackMaidDaoImpl(); - List l = dao.listLeftoversByMsid(1L); - for(CheckPointVO maid : l) { - s_logger.info("" + maid.getThreadId() + " " + maid.getDelegate() + " " + maid.getContext()); - } - - txn.close(); - } -} diff --git a/server/test/com/cloud/async/TestAsyncJobManager.java b/server/test/com/cloud/async/TestAsyncJobManager.java index e3233939bc5..a56e66f2e33 100644 --- a/server/test/com/cloud/async/TestAsyncJobManager.java +++ b/server/test/com/cloud/async/TestAsyncJobManager.java @@ -16,237 +16,44 @@ // under the License. package com.cloud.async; -import java.util.Collections; -import java.util.HashMap; -import java.util.Map; - import javax.inject.Inject; - -import junit.framework.Assert; import junit.framework.TestCase; import org.apache.log4j.Logger; +import org.junit.After; +import org.junit.Before; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.mockito.Mockito; +import org.springframework.test.context.ContextConfiguration; +import org.springframework.test.context.junit4.SpringJUnit4ClassRunner; -import com.cloud.domain.DomainVO; -import com.cloud.domain.dao.DomainDao; -import com.cloud.domain.dao.DomainDaoImpl; -import com.cloud.exception.PermissionDeniedException; -import com.cloud.host.HostVO; -import com.cloud.host.dao.HostDao; -import com.cloud.host.dao.HostDaoImpl; +import com.cloud.cluster.ClusterManager; +import com.cloud.utils.component.ComponentContext; import com.cloud.utils.db.Transaction; +@RunWith(SpringJUnit4ClassRunner.class) +@ContextConfiguration(locations="classpath:/AsyncJobTestContext.xml") public class TestAsyncJobManager extends TestCase { public static final Logger s_logger = Logger.getLogger(TestAsyncJobManager.class.getName()); - volatile long s_count = 0; - @Inject AsyncJobManager asyncMgr; + @Inject ClusterManager clusterMgr; - public void asyncCall() { -// long jobId = mgr.rebootVirtualMachineAsync(1, 1); - long jobId = 0L; - s_logger.info("Async-call job id: " + jobId); - - while(true) { - AsyncJobResult result; - try { - result = asyncMgr.queryAsyncJobResult(jobId); - - if(result.getJobStatus() != AsyncJobResult.STATUS_IN_PROGRESS) { - s_logger.info("Async-call completed, result: " + result.toString()); - break; - } - s_logger.info("Async-call is in progress, progress: " + result.toString()); - - } catch (PermissionDeniedException e1) { - } - - try { - Thread.sleep(1000); - } catch (InterruptedException e) { - } - } - } - - public void sequence() { - final HostDao hostDao = new HostDaoImpl(); - long seq = hostDao.getNextSequence(1); - s_logger.info("******* seq : " + seq + " ********"); - - HashMap hashMap = new HashMap(); - final Map map = Collections.synchronizedMap(hashMap); - - s_count = 0; - final long maxCount = 1000000; // test one million times - - Thread t1 = new Thread(new Runnable() { - @Override - public void run() { - while(s_count < maxCount) { - s_count++; - long seq = hostDao.getNextSequence(1); - Assert.assertTrue(map.put(seq, seq) == null); - } - } - }); - - Thread t2 = new Thread(new Runnable() { - @Override - public void run() { - while(s_count < maxCount) { - s_count++; - long seq = hostDao.getNextSequence(1); - Assert.assertTrue(map.put(seq, seq) == null); - } - } - }); - - t1.start(); - t2.start(); - - try { - t1.join(); - t2.join(); - } catch (InterruptedException e) { - } - } - - /* - public void ipAssignment() { - final IPAddressDao ipAddressDao = new IPAddressDaoImpl(); - - final ConcurrentHashMap map = new ConcurrentHashMap(); - //final Map map = Collections.synchronizedMap(hashMap); - - s_count = 0; - final long maxCount = 1000000; // test one million times - - Thread t1 = new Thread(new Runnable() { - public void run() { - while(s_count < maxCount) { - s_count++; - - Transaction txn = Transaction.open("Alex1"); - try { - IPAddressVO addr = ipAddressDao.assignIpAddress(1, 0, 1, false); - IPAddressVO returnStr = map.put(addr.getAddress(), addr); - if(returnStr != null) { - System.out.println("addr : " + addr.getAddress()); - } - Assert.assertTrue(returnStr == null); - } finally { - txn.close(); - } - } - } - }); - - Thread t2 = new Thread(new Runnable() { - public void run() { - while(s_count < maxCount) { - s_count++; - - Transaction txn = Transaction.open("Alex2"); - try { - IPAddressVO addr = ipAddressDao.assignIpAddress(1, 0, 1, false); - Assert.assertTrue(map.put(addr.getAddress(), addr) == null); - } finally { - txn.close(); - } - } - } - }); - - t1.start(); - t2.start(); - - try { - t1.join(); - t2.join(); - } catch (InterruptedException e) { - } - } - */ - - private long getRandomLockId() { - return 1L; - - /* - * will use in the future test cases - int i = new Random().nextInt(); - if(i % 2 == 0) - return 1L; - return 2L; - */ - } - - public void tstLocking() { - - int testThreads = 20; - Thread[] threads = new Thread[testThreads]; - - for(int i = 0; i < testThreads; i++) { - final int current = i; - threads[i] = new Thread(new Runnable() { - @Override - public void run() { - - final HostDao hostDao = new HostDaoImpl(); - while(true) { - Transaction txn = Transaction.currentTxn(); - try { - HostVO host = hostDao.acquireInLockTable(getRandomLockId(), 10); - if(host != null) { - s_logger.info("Thread " + (current + 1) + " acquired lock"); - - try { Thread.sleep(1000); } catch (InterruptedException e) {} - - s_logger.info("Thread " + (current + 1) + " released lock"); - hostDao.releaseFromLockTable(host.getId()); - - try { Thread.sleep(1000); } catch (InterruptedException e) {} - } else { - s_logger.info("Thread " + (current + 1) + " is not able to acquire lock"); - } - } finally { - txn.close(); - } - } - } - }); - threads[i].start(); - } - - try { - for(int i = 0; i < testThreads; i++) - threads[i].join(); - } catch(InterruptedException e) { - } - } - - public void testDomain() { - DomainDao domainDao = new DomainDaoImpl(); - - DomainVO domain1 = new DomainVO("d1", 2L, 1L, null, 1); - domainDao.create(domain1); - - DomainVO domain2 = new DomainVO("d2", 2L, 1L, null, 1); - domainDao.create(domain2); - - DomainVO domain3 = new DomainVO("d3", 2L, 1L, null, 1); - domainDao.create(domain3); - - DomainVO domain11 = new DomainVO("d11", 2L, domain1.getId(), null, 1); - domainDao.create(domain11); - - domainDao.remove(domain11.getId()); - - DomainVO domain12 = new DomainVO("d12", 2L, domain1.getId(), null, 1); - domainDao.create(domain12); - - domainDao.remove(domain3.getId()); - DomainVO domain4 = new DomainVO("d4", 2L, 1L, null, 1); - domainDao.create(domain4); + @Before + public void setUp() { + ComponentContext.initComponentsLifeCycle(); + Mockito.when(clusterMgr.getManagementNodeId()).thenReturn(1L); + + Transaction.open("dummy"); + } + + @After + public void tearDown() { + Transaction.currentTxn().close(); + } + + @Test + public void test() { } } diff --git a/server/test/com/cloud/async/TestSyncQueueManager.java b/server/test/com/cloud/async/TestSyncQueueManager.java index 59afb11e1c6..4c554273506 100644 --- a/server/test/com/cloud/async/TestSyncQueueManager.java +++ b/server/test/com/cloud/async/TestSyncQueueManager.java @@ -23,18 +23,40 @@ import javax.inject.Inject; import junit.framework.TestCase; import org.apache.log4j.Logger; +import org.junit.After; import org.junit.Assert; +import org.junit.Before; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.springframework.test.context.ContextConfiguration; +import org.springframework.test.context.junit4.SpringJUnit4ClassRunner; +import com.cloud.utils.component.ComponentContext; +import com.cloud.utils.db.Transaction; +@RunWith(SpringJUnit4ClassRunner.class) +@ContextConfiguration(locations="classpath:/SyncQueueTestContext.xml") public class TestSyncQueueManager extends TestCase { public static final Logger s_logger = Logger.getLogger(TestSyncQueueManager.class.getName()); private volatile int count = 0; private volatile long expectingCurrent = 1; + @Inject SyncQueueManager mgr; + @Before + public void setUp() { + ComponentContext.initComponentsLifeCycle(); + Transaction.open("dummy"); + } + + @After + public void tearDown() { + Transaction.currentTxn().close(); + } + + public void leftOverItems() { - List l = mgr.getActiveQueueItems(1L, false); if(l != null && l.size() > 0) { for(SyncQueueItemVO item : l) { @@ -72,8 +94,7 @@ public class TestSyncQueueManager extends TestCase { } } } - } - ); + }); Thread thread2 = new Thread(new Runnable() { @Override @@ -95,8 +116,7 @@ public class TestSyncQueueManager extends TestCase { } } } - } - ); + }); thread1.start(); thread2.start(); @@ -143,8 +163,7 @@ public class TestSyncQueueManager extends TestCase { } } } - } - ); + }); Thread thread2 = new Thread(new Runnable() { @Override @@ -167,8 +186,7 @@ public class TestSyncQueueManager extends TestCase { } } } - } - ); + }); thread1.start(); thread2.start(); @@ -192,6 +210,7 @@ public class TestSyncQueueManager extends TestCase { mgr.queue("vm_instance", q, "Async-job", i+1, 1); } + @Test public void testSyncQueue() { mgr.queue("vm_instance", 1, "Async-job", 1, 1); diff --git a/server/test/sync-queue-component.xml b/server/test/sync-queue-component.xml deleted file mode 100644 index 996a6949a51..00000000000 --- a/server/test/sync-queue-component.xml +++ /dev/null @@ -1,26 +0,0 @@ - - - - - - - - -