query
stringlengths 7
33.1k
| document
stringlengths 7
335k
| metadata
dict | negatives
listlengths 3
101
| negative_scores
listlengths 3
101
| document_score
stringlengths 3
10
| document_rank
stringclasses 102
values |
---|---|---|---|---|---|---|
MBean for retrieving some statistics about the connection pool | public interface DBPoolViewMBean {
/**
* Number of active connections
*
* @return <code>int</code> Number of active connections
*/
public int getNumActive();
/**
* Number of idle connections
*
* @return <code>int</code> Number of idle connections
*/
public int getNumIdle();
/**
* Data source name
*
* @return <code>String</code> data source name
*/
public String getName();
/**
* Connection information as a string
*
* @return <code>String</code> representing connection information
*/
public Map getConnectionUsage();
/**
* reset statistics
*/
public void reset();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Map getConnectionUsage();",
"final ConcurrentMap<Object, ManagedConnectionPool> getManagedConnectionPools()\n {\n return mcpPools;\n }",
"public interface DeviceGatewayMonitorJMXMBean {\n\t/**\n\t * @return current tunnel connection count\n\t */\n\tint getTunnelConnectionCount();\n\n\t/**\n\t * @return heartbeat request times in last second\n\t */\n\tlong getHeartbeatCount();\n\n\t/**\n\t * @return list message request times in last second\n\t */\n\tlong getListRequestCount();\n\n\t/**\n\t * @return list message request successful times in last second\n\t */\n\tlong getListSuccessCount();\n\n\t/**\n\t * @return list message service unavailable times in last second\n\t */\n\tlong getListServiceUnavailableCount();\n\n\t/**\n\t * @return register request times in last second\n\t */\n\tlong getRegisterRequestCount();\n\n\t/**\n\t * @return register request successful times in last second\n\t */\n\tlong getRegisterSuccessCount();\n\n\t/**\n\t * @return register service unavailable times in last second\n\t */\n\tlong getRegisterServiceUnavailableCount();\n\n\t/**\n\t * @return auth request times in last second\n\t */\n\tlong getAuthRequestCount();\n\n\t/**\n\t * @return auth request successful times in last second\n\t */\n\tlong getAuthSuccessCount();\n\n\t/**\n\t * @return auth service unavailable times in last second\n\t */\n\tlong getAuthServiceUnavailableCount();\n\n\t/**\n\t * @return count request times in last second\n\t */\n\tlong getCountRequestCount();\n\n\t/**\n\t * @return count request successful times in last second\n\t */\n\tlong getCountSuccessCount();\n\n\t/**\n\t * @return Count service unavailable times in last second\n\t */\n\tlong getCountServiceUnavailableCount();\n\n\t/**\n\t * @return update request times in last second\n\t */\n\tlong getUpdateRequestCount();\n\n\t/**\n\t * @return update request successful times in last second\n\t */\n\tlong getUpdateSuccessCount();\n\n\t/**\n\t * @return update service unavailable times in last second\n\t */\n\tlong getUpdateServiceUnavailableCount();\n\n\t/**\n\t * @return bind request times in last second\n\t */\n\tlong getBindRequestCount();\n\n\t/**\n\t * @return bind request successful times in last second\n\t */\n\tlong getBindSuccessCount();\n\n\t/**\n\t * @return bind service unavailable times in last second\n\t */\n\tlong getBindServiceUnavailableCount();\n\n\t/**\n\t * @return unbind request times in last second\n\t */\n\tlong getUnbindRequestCount();\n\n\t/**\n\t * @return unbind request successful times in last second\n\t */\n\tlong getUnbindSuccessCount();\n\n\t/**\n\t * @return unbind service unavailable times in last second\n\t */\n\tlong getUnbindServiceUnavailableCount();\n\n\t/**\n\t * @return list message request times in last second\n\t */\n\tlong getAckListRequestCount();\n\n\t/**\n\t * @return list message request successful times in last second\n\t */\n\tlong getAckListSuccessCount();\n\n\t/**\n\t * @return list message service unavailable times in last second\n\t */\n\tlong getAckListServiceUnavailableCount();\n}",
"@SneakyThrows\n @Test\n @Disabled\n public void test() {\n JMXServiceURL url = new JMXServiceURL(\"service:jmx:rmi:///jndi/rmi://localhost:9840/jmxrmi\");\n\n JMXConnector jmxc = JMXConnectorFactory.connect(url, null);\n MBeanServerConnection mbsc = jmxc.getMBeanServerConnection();\n Set<ObjectName> names =\n new TreeSet<>(mbsc.queryNames(null, null));\n for (ObjectName name : names) {\n log.debug(\"ObjectName = \" + name);\n }\n\n ObjectName mbeanName = new ObjectName(\"org.apache.commons.dbcp2:name=dataSource,type=BasicDataSource\");\n GenericObjectPoolMXBean mxBean = JMX.newMBeanProxy(mbsc, mbeanName, GenericObjectPoolMXBean.class, true);\n log.debug(\"numActive:{}\", mxBean.getNumActive());\n }",
"OMMPool getPool();",
"public interface GeocodeWsStatisticsMBean {\n\n long getTotalGoodRequests();\n\n long getTotalBadRequests();\n\n long getTotalServedFromCache();\n\n long getTotalServedFromDatabase();\n\n long getTotalPoliticalHits();\n\n long getTotalEezHits();\n\n long getTotalNoResults();\n\n long getWithing5KmHits();\n\n double getAverageResultSize();\n\n void resetStats();\n}",
"public interface ServerMonitorMXBean extends Statistic {\n\n String getHostName();\n\n int getPort();\n\n String getStartupAt();\n\n /**\n * The block IPs\n */\n Set<String> getBlackList();\n}",
"public List<TPStatsInfo> getTPStats() {\n List<TPStatsInfo> tpstats = new ArrayList<>();\n Iterator<Map.Entry<String, JMXEnabledThreadPoolExecutorMBean>> threads = nodeProbe.getThreadPoolMBeanProxies();\n while (threads.hasNext()) {\n Map.Entry<String, JMXEnabledThreadPoolExecutorMBean> thread = threads.next();\n JMXEnabledThreadPoolExecutorMBean threadPoolProxy = thread.getValue();\n tpstats.add(new TPStatsInfo(thread.getKey(), threadPoolProxy.getActiveCount(),\n threadPoolProxy.getPendingTasks(), threadPoolProxy.getCompletedTasks(),\n threadPoolProxy.getCurrentlyBlockedTasks(), threadPoolProxy.getTotalBlockedTasks()));\n }\n return tpstats;\n }",
"public String poolName();",
"@ProviderType\npublic interface ThreadPoolMBean {\n\n /**\n * Retrieve the block policy of the thread pool.\n * \n * @return the block policy\n */\n String getBlockPolicy();\n\n /**\n * Retrieve the active count from the pool's Executor.\n * \n * @return the active count or -1 if the thread pool does not have an Executor\n */\n int getExecutorActiveCount();\n\n /**\n * Retrieve the completed task count from the pool's Executor.\n * \n * @return the completed task count or -1 if the thread pool does not have an Executor\n */\n long getExecutorCompletedTaskCount();\n\n /**\n * Retrieve the core pool size from the pool's Executor.\n * \n * @return the core pool size or -1 if the thread pool does not have an Executor\n */\n int getExecutorCorePoolSize();\n\n /**\n * Retrieve the largest pool size from the pool's Executor.\n * \n * @return the largest pool size or -1 if the thread pool does not have an Executor\n */\n int getExecutorLargestPoolSize();\n\n /**\n * Retrieve the maximum pool size from the pool's Executor.\n * \n * @return the maximum pool size or -1 if the thread pool does not have an Executor\n */\n int getExecutorMaximumPoolSize();\n\n\n /**\n * Retrieve the pool size from the pool's Executor.\n * \n * @return the pool size or -1 if the thread pool does not have an Executor\n */\n int getExecutorPoolSize();\n\n\n /**\n * Retrieve the task count from the pool's Executor. This is the total number of tasks, which\n * have ever been scheduled to this threadpool. They might have been processed yet or not.\n * \n * @return the task count or -1 if the thread pool does not have an Executor\n */\n long getExecutorTaskCount();\n \n \n /**\n * Retrieve the number of tasks in the work queue of the pool's Executor. These are the\n * tasks which have been already submitted to the threadpool, but which are not yet executed.\n * @return the number of tasks in the work queue -1 if the thread pool does not have an Executor\n */\n long getExcutorTasksInWorkQueueCount();\n\n /**\n * Return the configured max thread age.\n *\n * @return The configured max thread age.\n * @deprecated Since version 1.1.1 always returns -1 as threads are no longer retired\n * but instead the thread locals are cleaned up (<a href=\"https://issues.apache.org/jira/browse/SLING-6261\">SLING-6261</a>)\n */\n @Deprecated\n long getMaxThreadAge();\n\n /**\n * Return the configured keep alive time.\n * \n * @return The configured keep alive time.\n */\n long getKeepAliveTime();\n\n /**\n * Return the configured maximum pool size.\n * \n * @return The configured maximum pool size.\n */\n int getMaxPoolSize();\n\n /**\n * Return the minimum pool size.\n * \n * @return The minimum pool size.\n */\n int getMinPoolSize();\n\n /**\n * Return the name of the thread pool\n * \n * @return the name\n */\n String getName();\n\n /**\n * Return the configuration pid of the thread pool.\n * \n * @return the pid\n */\n String getPid();\n\n /**\n * Return the configured priority of the thread pool.\n * \n * @return the priority\n */\n String getPriority();\n\n /**\n * Return the configured queue size.\n * \n * @return The configured queue size.\n */\n int getQueueSize();\n\n /**\n * Return the configured shutdown wait time in milliseconds.\n * \n * @return The configured shutdown wait time.\n */\n int getShutdownWaitTimeMs();\n\n /**\n * Return whether or not the thread pool creates daemon threads.\n * \n * @return The daemon configuration.\n */\n boolean isDaemon();\n\n /**\n * Return whether or not the thread pool is configured to shutdown gracefully.\n * \n * @return The graceful shutdown configuration.\n */\n boolean isShutdownGraceful();\n\n /**\n * Return whether or not the thread pool is in use.\n * \n * @return The used state of the pool.\n */\n boolean isUsed();\n\n}",
"int getTotalCreatedConnections();",
"public MBeanInfo getMBeanInfo() {\n buildDynamicMBeanInfo();\n return dMBeanInfo;\n }",
"java.util.List<io.netifi.proteus.admin.om.Connection> \n getConnectionsList();",
"public TomcatWebConnectorStatsImpl() {\n requestTime = new TimeStatisticImpl(\"Request Time\", StatisticImpl.UNIT_TIME_MILLISECOND,\n \"The time to process all requests\");\n activeRequestCount = new CountStatisticImpl(\"Active Request Count\", StatisticImpl.UNIT_COUNT,\n \"currently active requests \", 0);\n errorCount = new CountStatisticImpl(\"Error Count\", StatisticImpl.UNIT_COUNT,\n \"The numbet of Errors during the observed period\", 0);\n bytesSentCount = new CountStatisticImpl(\"Bytes Sent\", StatisticImpl.UNIT_COUNT,\n \"The number of bytes sent during the observerd period\", 0);\n bytesReceivedCount = new CountStatisticImpl(\"Bytes Received\", StatisticImpl.UNIT_COUNT,\n \"The number of bytes received during the observerd period\", 0);\n openConnectionCount = new RangeStatisticImpl(\"\" + \"Open Connections\", StatisticImpl.UNIT_COUNT,\n \"Range for connections opened during the observed period\", 0); // all 0's\n busyThreads = new BoundedRangeStatisticImpl(\"Busy Threads\", StatisticImpl.UNIT_COUNT,\n \"BoundedRange for Threads currently busy serving requests\", 0, 0, 0);\n addStat(\"RequestTime\", requestTime); // better name\n addStat(\"activeRequestCount\", activeRequestCount);\n addStat(\"errorCount\", errorCount);\n addStat(\"bytesSent\", bytesSentCount);\n addStat(\"bytesReceived\", bytesReceivedCount);\n addStat(\"openConnectionCount\", openConnectionCount);\n addStat(\"busyThreads\", busyThreads);\n }",
"public Connections getConnections();",
"public static ConcurrentHashMap<String,QueryStats> getPoolStats(String poolname) {\n return perPoolStats.get(poolname);\n }",
"int getConnectionCount();",
"java.util.List<io.netifi.proteus.admin.om.Connection> \n getConnectionList();",
"public int getActivePoolSize(){return activePoolSize;}",
"int getConnectionsCount();",
"public long getConnectionCount() {\n return connectionCount.getCount();\n }",
"Map getConnectionManagerMap();",
"Collection<TcpIpConnection> getActiveConnections();",
"List<storage_server_connections> getAllForStoragePool(Guid pool);",
"public String getDatabaseConnectionPoolMinNumberConnections(){\n \t\treturn getProperty(\"org.sagebionetworks.pool.min.number.connections\");\n \t}",
"private ConnectionPool() {\r\n\t\tResourceManagerDB resourceManager = ResourceManagerDB.getInstance();\r\n\t\tthis.driver = resourceManager.getValue(ParameterDB.DRIVER_DB);\r\n\t\tthis.url = resourceManager.getValue(ParameterDB.URL_DB);\r\n\t\tthis.user = resourceManager.getValue(ParameterDB.USER_DB);\r\n\t\tthis.password = resourceManager.getValue(ParameterDB.PASSWORD_DB);\r\n\t\tthis.poolsize = Integer.parseInt(resourceManager.getValue(ParameterDB.POOLSIZE_DB));\r\n\t}",
"public ConnInfo[] getConnections() {\n return connInfo;\n }",
"protected void reloadMBeanNames()\n {\n try\n {\n GraphDatabaseService genericDb = NeoServer.INSTANCE.database();\n\n if ( genericDb instanceof EmbeddedGraphDatabase )\n {\n EmbeddedGraphDatabase db = (EmbeddedGraphDatabase) genericDb;\n\n // Grab relevant jmx management beans\n ObjectName neoQuery = db.getManagementBean( Kernel.class ).getMBeanQuery();\n String instance = neoQuery.getKeyProperty( \"instance\" );\n String baseName = neoQuery.getDomain() + \":instance=\"\n + instance + \",name=\";\n\n primitivesName = new ObjectName( baseName\n + JMX_NEO4J_PRIMITIVE_COUNT );\n storeSizesName = new ObjectName( baseName\n + JMX_NEO4J_STORE_FILE_SIZES );\n transactionsName = new ObjectName( baseName\n + JMX_NEO4J_TRANSACTIONS );\n memoryMappingName = new ObjectName( baseName\n + JMX_NEO4J_MEMORY_MAPPING );\n kernelName = new ObjectName( baseName + JMX_NEO4J_KERNEL );\n lockingName = new ObjectName( baseName + JMX_NEO4J_LOCKING );\n cacheName = new ObjectName( baseName + JMX_NEO4J_CACHE );\n configurationName = new ObjectName( baseName\n + JMX_NEO4J_CONFIGURATION );\n xaResourcesName = new ObjectName( baseName\n + JMX_NEO4J_XA_RESOURCES );\n }\n\n }\n catch ( MalformedObjectNameException e )\n {\n // TODO Auto-generated catch block\n e.printStackTrace();\n }\n catch ( NullPointerException e )\n {\n // TODO Auto-generated catch block\n e.printStackTrace();\n }\n catch ( org.neo4j.webadmin.domain.DatabaseBlockedException e )\n {\n e.printStackTrace();\n }\n }",
"public CommandResult getStats() {\n return getDB().executeCommand(new BsonDocument(\"collStats\", new BsonString(getName())), getReadPreference());\n }",
"public static long getConnections() {\n return connections;\n }",
"public String getDatabaseConnectionPoolMaxNumberConnections(){\n \t\treturn getProperty(\"org.sagebionetworks.pool.max.number.connections\");\n \t}",
"public int connectionCount()\n {\n return _connectionCount;\n }",
"public int getConnectionStatus()\r\n { return connectionStatus; }",
"public String toString() {\n return poolName + \" [\" + getUsedCount() + \"/\" + (objects == null ? 0 : objects.size()) + \"/\" + (maxSize == 0 ? \"Unlimited\" : Integer.toString(maxSize)) + \"]\";\n }",
"public Connections getConnections() {\r\n return connections;\r\n }",
"public void refreshConnectionStatistics() {\n\t\tIPSECconnections = 0;\n\t\tPPTPconnections = 0;\n\t\tHTTPSconnections = 0;\n\t\tSSHconnections = 0;\n\t\tOthersconnections = 0;\n\t\tTotalconnections = 0;\n\n\t\tIterator listIterator = vpn.trafficPanel.VPNPairList.listIterator();\n\t\twhile (listIterator.hasNext()) {\n\t\t\tPair aPair = (Pair) listIterator.next();\n\t\t\tif (aPair.type == Traffic.IPSEC) {\n\t\t\t\tIPSECconnections++;\n\t\t\t} else if (aPair.type == Traffic.PPTP) {\n\t\t\t\tPPTPconnections++;\n\t\t\t} else if (aPair.type == Traffic.HTTPS) {\n\t\t\t\tHTTPSconnections++;\n\t\t\t} else if (aPair.type == Traffic.SSH) {\n\t\t\t\tSSHconnections++;\n\t\t\t} else {\n\t\t\t\tOthersconnections++;\n\t\t\t}\n\t\t\tTotalconnections++;\n\t\t}\n\n\t\tint ctotal =\n\t\t\tIPSECconnections\n\t\t\t\t+ PPTPconnections\n\t\t\t\t+ HTTPSconnections\n\t\t\t\t+ SSHconnections\n\t\t\t\t+ Othersconnections;\n\t\tif (ctotal == 0)\n\t\t\tctotal = 1;\n\t\tIPSECconnectionLabel.setText(\n\t\t\t\"IPSEC Connections: \"\n\t\t\t\t+ IPSECconnections\n\t\t\t\t+ \" ( \"\n\t\t\t\t+ (IPSECconnections * 100 / ctotal)\n\t\t\t\t+ \" % )\");\n\t\tPPTPconnectionLabel.setText(\n\t\t\t\"PPTP Connections: \"\n\t\t\t\t+ PPTPconnections\n\t\t\t\t+ \" ( \"\n\t\t\t\t+ (PPTPconnections * 100 / ctotal)\n\t\t\t\t+ \" % )\");\n\t\tHTTPSconnectionLabel.setText(\n\t\t\t\"HTTPS Connections: \"\n\t\t\t\t+ HTTPSconnections\n\t\t\t\t+ \" ( \"\n\t\t\t\t+ (HTTPSconnections * 100 / ctotal)\n\t\t\t\t+ \" % )\");\n\t\tSSHconnectionLabel.setText(\n\t\t\t\"SSH Connections: \"\n\t\t\t\t+ SSHconnections\n\t\t\t\t+ \" ( \"\n\t\t\t\t+ (SSHconnections * 100 / ctotal)\n\t\t\t\t+ \" % )\");\n\t\tOthersconnectionLabel.setText(\n\t\t\t\"Other Connections: \"\n\t\t\t\t+ Othersconnections\n\t\t\t\t+ \" ( \"\n\t\t\t\t+ (Othersconnections * 100 / ctotal)\n\t\t\t\t+ \" % )\");\n\t\tTotalconnectionLabel.setText(\n\t\t\t\"Total Connections: \"\n\t\t\t\t+ Totalconnections\n\t\t\t\t+ \" ( \"\n\t\t\t\t+ (Totalconnections * 100 / ctotal)\n\t\t\t\t+ \" % )\");\n\t}",
"public String getInfoPool() {\n StringBuilder info = new StringBuilder();\n \n if (pool == null) {\n info.append(\"El pool no está creado\");\n } else {\n\n int conexiones_libres = pool.getTotalFree();\n int conexiones_creadas_totales = pool.getTotalCreatedConnections();\n int conexiones_liberadas_totales = pool.getTotalLeased();\n \n BoneCPConfig config = pool.getConfig();\n \n info.append(\"Pool \" + config.getPoolName() + \": \");\n info.append(\"Libres: \" + conexiones_libres + \" / \");\n info.append(\"Tot. creadas: \" + conexiones_creadas_totales + \" / \");\n info.append(\"Tot. liberadas: \" + conexiones_liberadas_totales + Comun.NL);\n }\n \n info.append(Comun.NL);\n \n return info.toString();\n }",
"public void registerJMX() {\n Hashtable<String, String> tb = new Hashtable<String, String>();\n tb.put(\"type\", \"statistics\");\n tb.put(\"sessionFactory\", \"HibernateSessionFactory\");\n try {\n ObjectName on = new ObjectName(\"hibernate\", tb);\n MBeanServer mbs = ManagementFactory.getPlatformMBeanServer();\n if (!mbs.isRegistered(on)) {\n StatisticsService stats = new StatisticsService();\n stats.setSessionFactory(getSessionFactory());\n mbs.registerMBean(stats, on);\n ManagementService.registerMBeans(CacheManager.getInstance(),\n mbs, true, true, true, true);\n }\n } catch (Exception e) {\n logger.warn(\"Unable to register Hibernate and EHCache with JMX\");\n }\n\n }",
"List<CacheHealth> getCacheHealth();",
"public interface SessionMXBean /*extends SessionManagementListener*/ {\n\n void close();\n\n void closeImmediately();\n\n ObjectName getObjectName();\n\n long getId();\n\n long getReadBytes();\n\n double getReadBytesThroughput();\n\n long getWrittenBytes();\n\n double getWrittenBytesThroughput();\n\n String getPrincipals();\n\n long getCreateTime();\n\n String getRemoteAddress();\n\n String getSessionTypeName();\n\n String getSessionDirection();\n\n long getLastRoundTripLatency();\n\n long getLastRoundTripLatencyTimestamp();\n}",
"Integer getConnectorCount();",
"@Override\n public MBeanInfo getMBeanInfo() {\n mBeanInfo = super.getMBeanInfo();\n return mBeanInfo;\n }",
"int getPoolSize();",
"Collection<TcpIpConnection> getConnections();",
"io.netifi.proteus.admin.om.Connection getConnections(int index);",
"io.netifi.proteus.admin.om.Metrics getMetrics();",
"ConnectionProfile connectionProfile();",
"public int getPoolSize() {\n return poolSize;\n }",
"public ArrayList<Connection> getConnections(){\n\t\treturn manager.getConnectionsWith(this);\n\t}",
"public void testGenerateBrokerVirtualhostAndConnectionStatistics() throws Exception\n {\n sendUsing(_test, 5, 200);\n Thread.sleep(1000);\n \n for (ManagedConnection mc : _jmxUtils.getManagedConnections(\"test\"))\n {\n assertEquals(\"Incorrect connection total\", 5, mc.getTotalMessagesReceived());\n assertEquals(\"Incorrect connection data\", 1000, mc.getTotalDataReceived());\n\t assertTrue(\"Connection statistics should be enabled\", mc.isStatisticsEnabled());\n }\n \n ManagedBroker vhost = _jmxUtils.getManagedBroker(\"test\");\n assertEquals(\"Incorrect vhost data\", 5, vhost.getTotalMessagesReceived());\n assertEquals(\"Incorrect vhost data\", 1000, vhost.getTotalDataReceived());\n assertTrue(\"Vhost statistics should be enabled\", vhost.isStatisticsEnabled());\n\n assertEquals(\"Incorrect server total messages\", 5, _jmxUtils.getServerInformation().getTotalMessagesReceived());\n assertEquals(\"Incorrect server total data\", 1000, _jmxUtils.getServerInformation().getTotalDataReceived());\n assertTrue(\"Server statistics should be enabled\", _jmxUtils.getServerInformation().isStatisticsEnabled());\n }",
"Map<String, Object> getStats();",
"public Map<String, String> getConnectionDetails() {\n\t\treturn connectionDetails;\n\t}",
"public String toString()\n {\n return \"DBPoolImpl[\" + _name + \"]\";\n }",
"public int getMaxConnections()\n {\n return _maxConnections;\n }",
"public interface ServerSocketMXBean {\r\n\r\n /**\r\n * Returns all live server-socket IDs. Some server-socket included in the\r\n * returned array may have been terminated when this method returns.\r\n * \r\n * @return an array of <tt>long</tt>, each is a server-socket ID.\r\n * @throws java.lang.SecurityException if a security manager exists and the\r\n * caller does not have ManagementPermission(\"monitor\").\r\n */\r\n long[] getAllServerSocketIds();\r\n\r\n /**\r\n * Returns the total number of server-sockets opened since the Java virtual\r\n * machine started.\r\n * \r\n * @return the total number of server-sockets opened.\r\n */\r\n long getTotalServerSocketsCount();\r\n\r\n /**\r\n * Returns the peak open server-socket count since the Java virtual machine\r\n * started or the peak was reset.\r\n * \r\n * @return the peak live server-socket count.\r\n */\r\n int getPeakServerSocketCount();\r\n\r\n /**\r\n * Returns the current number of open server-sockets.\r\n * \r\n * @return the current number of open server-sockets.\r\n */\r\n int getServerSocketCount();\r\n\r\n /**\r\n * Returns the total number of sockets accepted by all server-sockets since\r\n * the Java virtual machine started.\r\n * \r\n * @return the total number of server-sockets opened.\r\n */\r\n long getTotalAcceptCount();\r\n\r\n /**\r\n * Returns the total number of sockets accepted by a server-socket with the\r\n * specified <tt>id</tt>.\r\n * \r\n * @param id the ID of the server-socket. Must be positive.\r\n * @return the total number of server-sockets opened.\r\n */\r\n long getTotalAcceptCount(long id);\r\n\r\n /**\r\n * Returns the server-socket info for a server-socket of the specified\r\n * <tt>id</tt>.\r\n * <p>\r\n * This method returns a <tt>ServerSocketInfo</tt> object representing the\r\n * server-socket information for the server-socket of the specified ID. If a\r\n * server-socket of the given ID is not open or does not exist, this method\r\n * will return <tt>null</tt>.\r\n * <p>\r\n * <b>MBeanServer access </b>: <br>\r\n * The mapped type of <tt>ServerSocketInfo</tt> is <tt>CompositeData</tt>\r\n * with attributes as specified in\r\n * {@link ServerSocketInfo#from ServerSocketInfo}.\r\n * \r\n * @param id the ID of the server-socket. Must be positive.\r\n * @return a {@link ServerSocketInfo}object for the server-socket of the\r\n * given ID; <tt>null</tt> if the server-socket of the given ID is\r\n * not open or it does not exist.\r\n * @throws IllegalArgumentException if <tt>id <= 0</tt>.\r\n * @throws java.lang.SecurityException if a security manager exists and the\r\n * caller does not have ManagementPermission(\"monitor\").\r\n */\r\n ServerSocketInfo getServerSocketInfo(long id);\r\n\r\n /**\r\n * Returns the server-socket info for each server-socket whose ID is in the\r\n * input array <tt>ids</tt>.\r\n * <p>\r\n * This method returns an array of the <tt>ServerSocketInfo</tt> objects.\r\n * If a server-socket of a given ID is not open or does not exist, the\r\n * corresponding element in the returned array will contain <tt>null</tt>.\r\n * <p>\r\n * <b>MBeanServer access </b>: <br>\r\n * The mapped type of <tt>ServerSocketInfo</tt> is <tt>CompositeData</tt>\r\n * with attributes as specified in\r\n * {@link ServerSocketInfo#from ServerSocketInfo}.\r\n * \r\n * @param ids an array of server-socket IDs\r\n * @return an array of the {@link ServerSocketInfo}objects, each containing\r\n * information about a server-socket whose ID is in the\r\n * corresponding element of the input array of IDs.\r\n * @throws IllegalArgumentException if any element in the input array\r\n * <tt>ids</tt> is <tt><= 0</tt>.\r\n * @throws java.lang.SecurityException if a security manager exists and the\r\n * caller does not have ManagementPermission(\"monitor\").\r\n */\r\n ServerSocketInfo[] getServerSocketInfo(long[] ids);\r\n\r\n /**\r\n * Resets the peak server-socket count to the current number of open\r\n * server-sockets.\r\n * \r\n * @throws java.lang.SecurityException if a security manager exists and the\r\n * caller does not have ManagementPermission(\"control\").\r\n * @see #getPeakServerSocketCount\r\n * @see #getServerSocketCount\r\n */\r\n void resetPeakServerSocketCount();\r\n}",
"public interface OdlOpenFlowStats2MBean {\n\n /**\n * Getter for the \"OdlOpenflowFlowstats2\" variable.\n */\n public String getOdlOpenflowFlowstats2() throws SnmpStatusException;\n\n /**\n * Setter for the \"OdlOpenflowFlowstats2\" variable.\n */\n public void setOdlOpenflowFlowstats2(String x) throws SnmpStatusException;\n\n /**\n * Checker for the \"OdlOpenflowFlowstats2\" variable.\n */\n public void checkOdlOpenflowFlowstats2(String x) throws SnmpStatusException;\n\n /**\n * Getter for the \"OdlOpenflowStatus2\" variable.\n */\n public String getOdlOpenflowStatus2() throws SnmpStatusException;\n\n /**\n * Setter for the \"OdlOpenflowStatus2\" variable.\n */\n public void setOdlOpenflowStatus2(String x) throws SnmpStatusException;\n\n /**\n * Checker for the \"OdlOpenflowStatus2\" variable.\n */\n public void checkOdlOpenflowStatus2(String x) throws SnmpStatusException;\n\n /**\n * Getter for the \"OdlOpenflowManufacturer2\" variable.\n */\n public String getOdlOpenflowManufacturer2() throws SnmpStatusException;\n\n /**\n * Setter for the \"OdlOpenflowManufacturer2\" variable.\n */\n public void setOdlOpenflowManufacturer2(String x) throws SnmpStatusException;\n\n /**\n * Checker for the \"OdlOpenflowManufacturer2\" variable.\n */\n public void checkOdlOpenflowManufacturer2(String x) throws SnmpStatusException;\n\n /**\n * Getter for the \"OdlOpenflowMacAddress2\" variable.\n */\n public String getOdlOpenflowMacAddress2() throws SnmpStatusException;\n\n /**\n * Setter for the \"OdlOpenflowMacAddress2\" variable.\n */\n public void setOdlOpenflowMacAddress2(String x) throws SnmpStatusException;\n\n /**\n * Checker for the \"OdlOpenflowMacAddress2\" variable.\n */\n public void checkOdlOpenflowMacAddress2(String x) throws SnmpStatusException;\n\n /**\n * Getter for the \"OdlOpenflowInterface2\" variable.\n */\n public String getOdlOpenflowInterface2() throws SnmpStatusException;\n\n /**\n * Setter for the \"OdlOpenflowInterface2\" variable.\n */\n public void setOdlOpenflowInterface2(String x) throws SnmpStatusException;\n\n /**\n * Checker for the \"OdlOpenflowInterface2\" variable.\n */\n public void checkOdlOpenflowInterface2(String x) throws SnmpStatusException;\n\n /**\n * Getter for the \"OdlOpenflowNode2\" variable.\n */\n public String getOdlOpenflowNode2() throws SnmpStatusException;\n\n /**\n * Setter for the \"OdlOpenflowNode2\" variable.\n */\n public void setOdlOpenflowNode2(String x) throws SnmpStatusException;\n\n /**\n * Checker for the \"OdlOpenflowNode2\" variable.\n */\n public void checkOdlOpenflowNode2(String x) throws SnmpStatusException;\n\n /**\n * Getter for the \"OdlOpenflowMeterstats2\" variable.\n */\n public String getOdlOpenflowMeterstats2() throws SnmpStatusException;\n\n /**\n * Setter for the \"OdlOpenflowMeterstats2\" variable.\n */\n public void setOdlOpenflowMeterstats2(String x) throws SnmpStatusException;\n\n /**\n * Checker for the \"OdlOpenflowMeterstats2\" variable.\n */\n public void checkOdlOpenflowMeterstats2(String x) throws SnmpStatusException;\n\n}",
"PolicyStatsManager getStats();",
"public String getConcurrentPool() {\n return getPropertyAsString(CONCURRENT_POOL, CONCURRENT_POOL_DEFAULT);\n }",
"public ConcurrentHashMap<String, SocketManager> getActiveConnections() {\n return threadListen.getActiveConnexion();\n }",
"@Override\n\tpublic Map<InetSocketAddress, Map<String, String>> getStats()\n\t\t\tthrows MemcachedException, InterruptedException, TimeoutException {\n\t\treturn null;\n\t}",
"int getPoolNumber();",
"public int getTotalConnections()\n {\n // return _connections.size();\n return 0;\n }",
"public static int getConnectionCount()\r\n {\r\n return count_; \r\n }",
"interface ClientMetrics {\n void incrementReadRequest();\n\n void incrementWriteRequest();\n\n String getHostName();\n\n long getReadRequestsCount();\n\n long getWriteRequestsCount();\n\n void incrementFilteredReadRequests();\n\n long getFilteredReadRequests();\n }",
"public static Collection<Access.AccessStatsEntry> getStatistics() {\n accessorQueueLen.count = accessorQueue.size();\n\n return stats;\n }",
"javax.management.ObjectName getMessageCache();",
"public ObjectPoolStatus[] getObjectPoolStatuses() throws MediaAlbumException;",
"public String getConnectionDetails() {\n return getName();\n }",
"public Statistics getStatistics()\n throws IOException,IllegalArgumentException\n {\n Mocket.Statistics statistics = new Mocket.Statistics();\n return getStatisticsNative (statistics);\n }",
"public interface PaxosMBeanInfo {\n /**\n * @return a string identifying the MBean \n */\n public String getName();\n /**\n * If isHidden returns true, the MBean won't be registered with MBean server,\n * and thus won't be available for management tools. Used for grouping MBeans.\n * @return true if the MBean is hidden.\n */\n public boolean isHidden();\n}",
"public String getConnectionName() {\n return connectionName;\r\n }",
"public ArrayList<Integer> getConnections() {\n\t\treturn connections;\n\t}",
"public Connection getCachedConnection (CConnection connection);",
"public Connection getCachedConnection (CConnection connection);",
"private static BufferPoolMXBean createBufferPoolMXBean(BufferPool paramBufferPool)\n/* */ {\n/* 227 */ new BufferPoolMXBean() {\n/* */ private volatile ObjectName objname;\n/* */ \n/* */ public ObjectName getObjectName() {\n/* 231 */ ObjectName localObjectName = this.objname;\n/* 232 */ if (localObjectName == null) {\n/* 233 */ synchronized (this) {\n/* 234 */ localObjectName = this.objname;\n/* 235 */ if (localObjectName == null) {\n/* 236 */ localObjectName = Util.newObjectName(\"java.nio:type=BufferPool,name=\" + this.val$pool\n/* 237 */ .getName());\n/* 238 */ this.objname = localObjectName;\n/* */ }\n/* */ }\n/* */ }\n/* 242 */ return localObjectName;\n/* */ }\n/* */ \n/* */ public String getName() {\n/* 246 */ return this.val$pool.getName();\n/* */ }\n/* */ \n/* */ public long getCount() {\n/* 250 */ return this.val$pool.getCount();\n/* */ }\n/* */ \n/* */ public long getTotalCapacity() {\n/* 254 */ return this.val$pool.getTotalCapacity();\n/* */ }\n/* */ \n/* */ public long getMemoryUsed() {\n/* 258 */ return this.val$pool.getMemoryUsed();\n/* */ }\n/* */ };\n/* */ }",
"public int numConnections(){\n return connections.size();\n }",
"public BoneCP getPool() {\n return pool;\n }",
"private void initJMX() throws Exception{\n\t\tMap env = new HashMap<String, Object>();\r\n\t\tenv.put(Context.INITIAL_CONTEXT_FACTORY,\"com.sun.jndi.rmi.registry.RegistryContextFactory\");\r\n\t\tenv.put(RMIConnectorServer.JNDI_REBIND_ATTRIBUTE, \"true\");\r\n\t\tJMXServiceURL url = new JMXServiceURL(\"service:jmx:rmi:///jndi/rmi://127.0.0.1:1099/server\");\r\n\t\tObjectName objectName=ObjectName.getInstance(\"test:name=test\");\r\n\t\tManagementFactory.getPlatformMBeanServer().registerMBean(MBeanHandler.createJMXMBean(new AdminAgent(),objectName), objectName);\r\n\t\t\r\n\t\tRegion region=CacheFactory.getAnyInstance().getRegion(\"/CHECK\");\t\r\n\t\tObjectName regionObjectName=ObjectName.getInstance(\"region:name=region\");\r\n\t\tManagementFactory.getPlatformMBeanServer().registerMBean(MBeanHandler.createJMXMBean(new RegionAgent(region),regionObjectName), regionObjectName);\r\n\t\tJMXConnectorServer connectorServer = JMXConnectorServerFactory\r\n\t\t.newJMXConnectorServer(url, env, ManagementFactory.getPlatformMBeanServer());\r\n connectorServer.start();\r\n\t\t\r\n//\t\tMBeanHandler.createJMXMBean(new AdminAgent(), ObjectNameFactory.resolveFromClass(AdminAgent.class));\r\n//\t\tjmxserver.registerMBean(new AdminAgent(), ObjectNameFactory.resolveFromClass(AdminAgent.class));\r\n\t\tSystem.out.println(\"JMX connection is established on: service:jmx:rmi:///jndi/rmi://127.0.0.1:1099/server\");\r\n\t\t\r\n\t}",
"private String getJmxDomain() {\n return \"metrics.session.\" + configuration.getNamespace();\n }",
"public ConnectionPoolDataSource createPoolDataSource(CConnection connection);",
"public ConnectionPoolDataSource createPoolDataSource(CConnection connection);",
"public interface Pool {\n public PooledConnection getConnection();\n\n public void createConnection(int ocunt);\n}",
"void closeConnectionsPool();",
"public static synchronized HotspotMemoryMBean getHotspotMemoryMBean()\n/* */ {\n/* 312 */ if (hsMemoryMBean == null) {\n/* 313 */ hsMemoryMBean = new HotspotMemory(jvm);\n/* */ }\n/* 315 */ return hsMemoryMBean;\n/* */ }",
"void startStatisticsMonitor();",
"@Override\n public StatsViewer getStatsViewer() {\n return sessionPool.getStatsViewer();\n }",
"public Connection getConn() {return conn;}",
"@Override\r\n\t\tpublic void close() throws SQLException {\n\t\t\t\r\n\t\t\tJdbcPool.list.add(this.conn);\r\n\t\t\tSystem.out.println(\"�и�connection�ͷ���,�ص����ӳ�����list��!��ǰ���ӳ���connection������\" + list.size());\r\n\t\t}",
"public StatisticsCollector(Configuration conf, NetworkLayer net) {\n\t\tthis.net = net;\n\t\tstatsEnabled = conf.getBoolean(Consts.STATS_ENABLED, true);\n\t\tmyId = net.getMyPartition();\n\t}",
"@Override\n public DataSource getDataSource() {\n\n // PostgreSQL does not provide connection pool (as of version 42.1.3) so make one using Apache Commons DBCP \n ds = new BasicDataSource();\n\n // max number of active connections\n Integer maxTotal = AtsSystemProperties.getPropertyAsNumber(\"dbcp.maxTotal\");\n if (maxTotal == null) {\n maxTotal = 8;\n } else {\n log.info(\"Max number of active connections is \"\n + maxTotal);\n }\n ds.setMaxTotal(maxTotal);\n\n // wait time for new connection\n Integer maxWaitMillis = AtsSystemProperties.getPropertyAsNumber(\"dbcp.maxWaitMillis\");\n if (maxWaitMillis == null) {\n maxWaitMillis = 60 * 1000;\n } else {\n log.info(\"Connection creation wait is \"\n + maxWaitMillis\n + \" msec\");\n }\n ds.setMaxWaitMillis(maxWaitMillis);\n\n String logAbandoned = System.getProperty(\"dbcp.logAbandoned\");\n if (logAbandoned != null && (\"true\".equalsIgnoreCase(logAbandoned))\n || \"1\".equalsIgnoreCase(logAbandoned)) {\n String removeAbandonedTimeoutString = System.getProperty(\"dbcp.removeAbandonedTimeout\");\n int removeAbandonedTimeout = (int) ds.getMaxWaitMillis() / (2 * 1000);\n if (!StringUtils.isNullOrEmpty(removeAbandonedTimeoutString)) {\n removeAbandonedTimeout = Integer.parseInt(removeAbandonedTimeoutString);\n }\n log.info(\n \"Will log and remove abandoned connections if not cleaned in \"\n + removeAbandonedTimeout\n + \" sec\");\n // log not closed connections\n ds.setLogAbandoned(true); // issue stack trace of not closed connection\n ds.setAbandonedUsageTracking(true);\n ds.setLogExpiredConnections(true);\n ds.setRemoveAbandonedTimeout(removeAbandonedTimeout);\n ds.setRemoveAbandonedOnBorrow(true);\n ds.setRemoveAbandonedOnMaintenance(true);\n ds.setAbandonedLogWriter(new PrintWriter(System.err));\n }\n ds.setValidationQuery(\"SELECT 1\");\n ds.setDriverClassName(getDriverClass().getName());\n ds.setUsername(user);\n ds.setPassword(password);\n ds.setUrl(getURL());\n return ds;\n }",
"int getChannelStatisticsCount();",
"@Test\n @ConnectionConfiguration(user = \"stranger\", password = \"1234567\")\n public void testQueryBean() throws MalformedObjectNameException, IOException {\n MBeanServerConnection con = connectionRule.getMBeanServerConnection();\n Set<ObjectInstance> objects =\n con.queryMBeans(ObjectName.getInstance(ResourceConstants.OBJECT_NAME_ACCESSCONTROL), null);\n assertThat(objects.size()).isEqualTo(0); // no AccessControlMBean in the query result\n\n objects = con.queryMBeans(ObjectName.getInstance(\"GemFire:service=CacheServer,*\"), null);\n assertThat(objects.size()).isEqualTo(1);\n }",
"public String describe() throws NotBoundException, RemoteException {\n\t\tRegistry registry = LocateRegistry.getRegistry(registryHost,\n\t\t\t\tregistryPort);\n\t\tJobTracker jobTracker = (JobTracker) registry.lookup(\"JobTracker\");\n\t\treturn jobTracker.describeJobs();\n\t}",
"public BasicServerMetricsListener() {\n myServerMetrics = new ConcurrentHashMap<String, BasicServerMetrics>();\n }",
"CohortConnectionStatus getCohortConnectionStatus()\n {\n return cohortConnectionStatus;\n }",
"public SharedMemory infos();",
"@Override\n public CompactionSettingsInfo getCompactionSettingsInfo() {\n return new CompactionSettingsInfo(nodeProbe.getCompactionThroughput(),\n nodeProbe.getCompactionManagerProxy().getCoreCompactorThreads(),\n nodeProbe.getCompactionManagerProxy().getMaximumCompactorThreads(),\n nodeProbe.getCompactionManagerProxy().getCoreValidationThreads(),\n nodeProbe.getCompactionManagerProxy().getMaximumValidatorThreads());\n\n }",
"public String getConnection();",
"int getMinPoolSize();",
"public MBeanInfo getInfo() throws InstanceNotFoundException,\r\n\t\t\tIntrospectionException, ReflectionException, IOException {\r\n\t\treturn home.getInfo(objectName);\r\n\t}"
]
| [
"0.691478",
"0.6544413",
"0.65228903",
"0.625763",
"0.61660045",
"0.6163195",
"0.6138785",
"0.6137472",
"0.612583",
"0.6107291",
"0.60410905",
"0.59830284",
"0.5922929",
"0.5921547",
"0.59114504",
"0.5894359",
"0.58258235",
"0.5802433",
"0.57724303",
"0.5770441",
"0.575144",
"0.5675896",
"0.5660925",
"0.5640555",
"0.5624459",
"0.56229705",
"0.5611788",
"0.559632",
"0.5577521",
"0.55387866",
"0.55353117",
"0.55304",
"0.5525122",
"0.5524244",
"0.54931027",
"0.5475897",
"0.54674697",
"0.54426235",
"0.54270977",
"0.5424069",
"0.54190946",
"0.5414323",
"0.54027903",
"0.5393232",
"0.5388072",
"0.5387036",
"0.5375214",
"0.53681666",
"0.5366332",
"0.5360645",
"0.5340231",
"0.53355736",
"0.53322047",
"0.5327732",
"0.53259265",
"0.5325117",
"0.5324016",
"0.5320544",
"0.53196317",
"0.53031224",
"0.53000456",
"0.5297877",
"0.52969193",
"0.5290424",
"0.52840054",
"0.5280611",
"0.52558625",
"0.5251614",
"0.52362466",
"0.52357745",
"0.52281225",
"0.52276236",
"0.52220565",
"0.52220565",
"0.521522",
"0.5212359",
"0.5209339",
"0.52051437",
"0.5192183",
"0.5186098",
"0.5186098",
"0.5178758",
"0.5169972",
"0.5168314",
"0.5166454",
"0.5165419",
"0.51607996",
"0.5156018",
"0.51503474",
"0.51401305",
"0.51397634",
"0.5138248",
"0.51371884",
"0.5135575",
"0.5130954",
"0.5124811",
"0.5124131",
"0.5117144",
"0.51131463",
"0.5105174"
]
| 0.813234 | 0 |
Number of active connections | public int getNumActive(); | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"int getConnectionsCount();",
"public int numConnections(){\n return connections.size();\n }",
"public int getNumOfConnections() {\r\n\t\treturn numOfConnections;\r\n\t}",
"public static int getConnectionCount()\r\n {\r\n return count_; \r\n }",
"int getConnectionCount();",
"public int connectionCount()\n {\n return _connectionCount;\n }",
"public static long getNumberOfOpenConnections() {\n return openConnections.size();\n }",
"int getTotalCreatedConnections();",
"public int getTotalConnections()\n {\n // return _connections.size();\n return 0;\n }",
"@Override\n public int getNumConnections()\n {\n return connections.size();\n }",
"public long getConnectionCount() {\n return connectionCount.getCount();\n }",
"public int getNumConnects() {\n\t\treturn numConnects;\n\t}",
"@Override\r\n\tpublic int getConnectionsCount() {\r\n\t\treturn currentConnections.get();\r\n\t}",
"public int numofConnections() {\n\t\tint numberofconnection = 0;\n\t\tString node;\n\t\tfor (String key : Nodeswithconnect.keySet()) {\n\t\t\tfor (int i = 0; i < Nodeswithconnect.get(key).length; i++) {\n\t\t\t\tnode = Nodeswithconnect.get(key)[i];\n\t\t\t\tif (!node.equals(\"null\")) {\n\t\t\t\t\tnumberofconnection++;\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn numberofconnection;\n\t}",
"public int getUseCount() {\n\t\tint useCount=0;\n\t\tsynchronized(connStatus) {\n\t\t\tfor(int i=0; i < currConnections; i++) {\n\t\t\t\tif(connStatus[i] > 0) { // In use\n\t\t\t\t\tuseCount++;\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn useCount;\n\t}",
"public int getConnectionCount() {\n int i;\n synchronized (this.bindings) {\n i = 0;\n for (IntentBindRecord intentBindRecord : this.bindings) {\n i += intentBindRecord.connections.size();\n }\n }\n return i;\n }",
"public static long getConnections() {\n return connections;\n }",
"public int manyConnections() {\n\t\tint ammound = 0;\n\t\tfor (int i = 0; i < this.size(); i++) {\n\t\t\tif(this.get(i).clientAlive) {\n\t\t\t\tammound++;\n\t\t\t}\n\t\t\tSystem.out.println(\"Ist Client Nr. \" + i + \" frei? \" + !this.get(i).isAlive());\n\t\t}\n\t\treturn ammound;\n\t\t\n\t}",
"private void incrConnectionCount() {\n connectionCount.inc();\n }",
"Integer getConnectorCount();",
"int getServerSocketCount();",
"public int getMaxConnections()\n {\n return _maxConnections;\n }",
"public int getSize() {\n\t\treturn currConnections;\n\t}",
"@Override\n public int getNumOpenConnections() {\n return allChannels.size() - 1;\n }",
"long getTotalServerSocketsCount();",
"public int getMaxConnections() {\n return maxConnections;\n }",
"int getPeersCount();",
"private void countConnectingSocket() {\n \t\tcurrentlyConnectingSockets.incrementAndGet();\n \t}",
"private void updateNumberOfConnections(int delta)\n\t{\n\t\tint count = numberOfConnections.addAndGet(delta);\t\t\n\t\tLOG.debug(\"Active connections count = {}\", count);\n\t}",
"private synchronized static void incrementNumberOfOpenSockets() {\r\n\r\n\t\tnumberOfOpenSockets++;\r\n\t}",
"public static int getCurrentSessionCount() {\n\t\treturn (currentSessionCount);\n\t}",
"public void setNumConnections(int connections) {\n\t\tnumConnects = connections;\n\t}",
"int getRequestsCount();",
"int getRequestsCount();",
"public static Integer numValidClients() {\n return getLoggedInUserConnections().size() + anonClients.size();\n }",
"private int visitedNetworksCount() {\n final HashSet<String> visitedNetworksSet = new HashSet<>(mVisitedNetworks);\n return visitedNetworksSet.size();\n }",
"public int numberOfOpenSites() {\n return (openCount);\n }",
"public int numberOfOpenSites() {\n return count;\n }",
"public int getNumOfThreads() {\n return numOfThreads;\n }",
"public int size() {\r\n\t\tint size = 0;\r\n\t\tfor (Integer key : connectionLists.keySet()) {\r\n\t\t\tsize += connectionLists.get(key).size();\r\n\t\t}\r\n\t\treturn size;\r\n\t}",
"public int getNumberOfConnectors() { return numberOfConnectors; }",
"public int getMaxIdleConns() {\n return maxIdleConns;\n }",
"public int getNumberOfActivitiesOfConnections(Identity ownerIdentity);",
"long getRequestsCount();",
"public int getRunningDevicesCount();",
"public int getRequestsCount() {\n return instance.getRequestsCount();\n }",
"int getPeerCount();",
"public int numberOfOpenSites() {\n\t\treturn openCount;\n\t}",
"public Integer serverCount() {\n return this.serverCount;\n }",
"public int getConnectedDeviceCount() {\n return getConnectedDevices().size();\n }",
"public static int countNodes() {\n\t\treturn count_nodes;\n\t}",
"@Override\n public int getNumIdle() {\n return _pool.size();\n }",
"public int getAvailableCount();",
"int getSessionCount();",
"public int getMaxOverflowConnections()\n {\n return _maxOverflowConnections;\n }",
"public int getNumAlive() {\n return numAlive;\n }",
"public abstract int getNumSessions();",
"public int numberOfOpenSites() {\n return NOpen;\r\n }",
"protected int numPeers() {\n\t\treturn peers.size();\n\t}",
"public int numberOfOpenSites() {\n \treturn num;\r\n }",
"public void incrementNumConnects() {\n this.numConnects.incrementAndGet();\n }",
"public int getNumThreads() {\n return numThreads;\n }",
"public int clientsCount(){\n return clientsList.size();\n }",
"public static synchronized long getConnectionAttemptsGlobalCounter() {\n return connectionAttemptsGlobalCounter;\n }",
"public int getMinConnections() {\n return minConnections;\n }",
"public int getActiveCount() {\n return activeCount;\n }",
"int getPeakServerSocketCount();",
"public void setNumOfConnections(int num) {\r\n\t\tnumOfConnections = num;\r\n\t}",
"public synchronized void increaseUsersConn() {\r\n\t\tusersConn++;\r\n\t}",
"public String getDatabaseConnectionPoolMaxNumberConnections(){\n \t\treturn getProperty(\"org.sagebionetworks.pool.max.number.connections\");\n \t}",
"public int getNumOfServers() {\n return numOfServers;\n }",
"public int numberOfOpenSites(){\n\t\treturn numOpen;\n\t}",
"public int numberOfOpenSites() {\n return openSitesCount;\n }",
"public int numberOfOpenSites() {\n return openSitesCount;\n }",
"public int numberOfOpenSites() {\n \treturn size;\n }",
"int getExecutorActiveCount();",
"public int getActiveSessions();",
"public int numberOfOpenSites() {\n return numOpen;\n }",
"public int numberOfOpenSites() {\n return openSites;\n }",
"public int numberOfOpenSites() {\n return openSites;\n }",
"public int numberOfOpenSites() {\n return openSites;\n }",
"public int numberOfOpenSites() {\n return openSites;\n }",
"public int numberOfOpenSites() {\n return openSites;\n }",
"public int getNbClients() {\n\t\t\treturn nbClients;\r\n\t\t}",
"public int getRequestsCount() {\n return requests_.size();\n }",
"public int getNumberOfThreads(){\n return numberOfThreads;\n }",
"public ConnectionCount(int counter) {\nthis.counter = counter;\n}",
"public int numberOfOpenSites() {\n return openNum;\n }",
"public int getNumberOfThreads() { return numberOfThreads; }",
"public int getNumIdle();",
"public String getDatabaseConnectionPoolMinNumberConnections(){\n \t\treturn getProperty(\"org.sagebionetworks.pool.min.number.connections\");\n \t}",
"public int numberOfOpenSites() {\n return mOpenSites;\n }",
"public int numberOfOpenSites() {\n return this.numOfOpenSites;\n }",
"public int numberOfOpenSites() {\n return numOpen;\n }",
"public int numberOfOpenSites(){\n return numOpenSites;\n }",
"public int getCount() {\n\t\treturn channelCountMapper.getCount();\n\t}",
"public int numberOfOpenSites() {\n return numberOfOpenSites;\n }",
"public int getRequestsCount() {\n return requests_.size();\n }",
"int getReplicationCount();",
"public Object getNumberOfConnectedComponents() {\r\n\t\tConnectivityInspector<Country, DefaultEdge> inspector=new ConnectivityInspector<Country, DefaultEdge>(graph);\r\n\t\treturn inspector.connectedSets().size();\r\n\t}",
"long getListenerCount();"
]
| [
"0.8779871",
"0.8741027",
"0.8544166",
"0.85064816",
"0.8416054",
"0.8382249",
"0.82864016",
"0.8235743",
"0.8202746",
"0.8197641",
"0.8189306",
"0.8081173",
"0.80686665",
"0.80374706",
"0.7943861",
"0.78956497",
"0.7833374",
"0.78265697",
"0.7769329",
"0.77639145",
"0.7496571",
"0.74673355",
"0.745967",
"0.74001634",
"0.73882383",
"0.7222713",
"0.7209841",
"0.7198735",
"0.71913743",
"0.71485037",
"0.71249795",
"0.70795256",
"0.7042815",
"0.7042815",
"0.7014922",
"0.6979448",
"0.6975575",
"0.69638777",
"0.6944548",
"0.6927569",
"0.69274914",
"0.6926535",
"0.69264865",
"0.6922406",
"0.6907033",
"0.6906572",
"0.6904319",
"0.69031864",
"0.69011617",
"0.6898672",
"0.6889698",
"0.68857557",
"0.68847704",
"0.6859296",
"0.6855618",
"0.68552816",
"0.6849007",
"0.68482226",
"0.6831589",
"0.6818821",
"0.6811357",
"0.6804673",
"0.68001187",
"0.6798733",
"0.67856324",
"0.6772995",
"0.67683935",
"0.67660767",
"0.67615855",
"0.6755633",
"0.67453605",
"0.6738474",
"0.6724717",
"0.6724717",
"0.6723683",
"0.67066467",
"0.6692622",
"0.6683016",
"0.6668174",
"0.6668174",
"0.6668174",
"0.6668174",
"0.6668174",
"0.66672504",
"0.6660901",
"0.6659083",
"0.66432667",
"0.6636845",
"0.6632482",
"0.662894",
"0.66255534",
"0.66250646",
"0.6625024",
"0.6621119",
"0.6618685",
"0.66088116",
"0.65929526",
"0.657627",
"0.65695137",
"0.6566669",
"0.65602034"
]
| 0.0 | -1 |
Number of idle connections | public int getNumIdle(); | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\n public int getNumIdle() {\n return _pool.size();\n }",
"public static long getNumberOfOpenConnections() {\n return openConnections.size();\n }",
"int getConnectionsCount();",
"int getTotalCreatedConnections();",
"public int numConnections(){\n return connections.size();\n }",
"public int getMaxIdleConns() {\n return maxIdleConns;\n }",
"public int connectionCount()\n {\n return _connectionCount;\n }",
"public static int getConnectionCount()\r\n {\r\n return count_; \r\n }",
"int getConnectionCount();",
"public int getNumOfConnections() {\r\n\t\treturn numOfConnections;\r\n\t}",
"public long getConnectionCount() {\n return connectionCount.getCount();\n }",
"public int getTotalConnections()\n {\n // return _connections.size();\n return 0;\n }",
"public static long getConnections() {\n return connections;\n }",
"private void incrConnectionCount() {\n connectionCount.inc();\n }",
"public int getUseCount() {\n\t\tint useCount=0;\n\t\tsynchronized(connStatus) {\n\t\t\tfor(int i=0; i < currConnections; i++) {\n\t\t\t\tif(connStatus[i] > 0) { // In use\n\t\t\t\t\tuseCount++;\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn useCount;\n\t}",
"public int manyConnections() {\n\t\tint ammound = 0;\n\t\tfor (int i = 0; i < this.size(); i++) {\n\t\t\tif(this.get(i).clientAlive) {\n\t\t\t\tammound++;\n\t\t\t}\n\t\t\tSystem.out.println(\"Ist Client Nr. \" + i + \" frei? \" + !this.get(i).isAlive());\n\t\t}\n\t\treturn ammound;\n\t\t\n\t}",
"@Override\n public int getNumConnections()\n {\n return connections.size();\n }",
"private synchronized static void incrementNumberOfOpenSockets() {\r\n\r\n\t\tnumberOfOpenSockets++;\r\n\t}",
"@Override\r\n\tpublic int getConnectionsCount() {\r\n\t\treturn currentConnections.get();\r\n\t}",
"public int getMaxConnections()\n {\n return _maxConnections;\n }",
"public static synchronized long getConnectionAttemptsGlobalCounter() {\n return connectionAttemptsGlobalCounter;\n }",
"public int getNumConnects() {\n\t\treturn numConnects;\n\t}",
"@Override\n public int getNumOpenConnections() {\n return allChannels.size() - 1;\n }",
"public int numofConnections() {\n\t\tint numberofconnection = 0;\n\t\tString node;\n\t\tfor (String key : Nodeswithconnect.keySet()) {\n\t\t\tfor (int i = 0; i < Nodeswithconnect.get(key).length; i++) {\n\t\t\t\tnode = Nodeswithconnect.get(key)[i];\n\t\t\t\tif (!node.equals(\"null\")) {\n\t\t\t\t\tnumberofconnection++;\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn numberofconnection;\n\t}",
"long getTotalServerSocketsCount();",
"public int getMaxOverflowConnections()\n {\n return _maxOverflowConnections;\n }",
"private void countConnectingSocket() {\n \t\tcurrentlyConnectingSockets.incrementAndGet();\n \t}",
"int getServerSocketCount();",
"protected static synchronized long getNextConnectionAttemptGlobalCounter() {\n connectionAttemptsGlobalCounter++;\n if (connectionAttemptsGlobalCounter < 0) {\n connectionAttemptsGlobalCounter = 1;\n }\n return connectionAttemptsGlobalCounter;\n }",
"public static int getCurrentSessionCount() {\n\t\treturn (currentSessionCount);\n\t}",
"public int getMaxConnections() {\n return maxConnections;\n }",
"int getPeakServerSocketCount();",
"public static long getIdleTimeouts() {\n return idleTimeouts;\n }",
"public int getConnectionCount() {\n int i;\n synchronized (this.bindings) {\n i = 0;\n for (IntentBindRecord intentBindRecord : this.bindings) {\n i += intentBindRecord.connections.size();\n }\n }\n return i;\n }",
"public void setMaxIdleConns(int value) {\n this.maxIdleConns = value;\n }",
"public synchronized void increaseUsersConn() {\r\n\t\tusersConn++;\r\n\t}",
"long getRequestsCount();",
"int getRequestsCount();",
"int getRequestsCount();",
"public int numberOfOpenSites() {\n return (openCount);\n }",
"public int getNumAlive() {\n return numAlive;\n }",
"private void updateNumberOfConnections(int delta)\n\t{\n\t\tint count = numberOfConnections.addAndGet(delta);\t\t\n\t\tLOG.debug(\"Active connections count = {}\", count);\n\t}",
"Integer getConnectorCount();",
"public int numberOfOpenSites() {\n return NOpen;\r\n }",
"public int getSize() {\n\t\treturn currConnections;\n\t}",
"int getSessionCount();",
"public int numberOfOpenSites() {\n\t\treturn openCount;\n\t}",
"public abstract int getNumSessions();",
"public int getSessionMaxAliveTime();",
"public int numberOfOpenSites() {\n return count;\n }",
"public int getActiveSessions();",
"private synchronized static void decrementNumberOfOpenSockets() {\r\n\r\n\t\tnumberOfOpenSockets--;\r\n\t}",
"public int getAvailableCount();",
"public int numberOfOpenSites(){\n\t\treturn numOpen;\n\t}",
"@Test(timeout = 4000)\n public void test049() throws Throwable {\n int int0 = DBUtil.getOpenConnectionCount();\n assertEquals(0, int0);\n }",
"public int getRequestsCount() {\n return instance.getRequestsCount();\n }",
"long getListenerCount();",
"int getActiveSessions();",
"private void countSocketClose() {\n \t\tcurrentlyOpenSockets.decrementAndGet();\n \t\tsynchronized (this) {\n \t\t\tthis.notifyAll();\n \t\t}\n \n \t}",
"public long getReconnects() {\n return reconnects.get();\n }",
"public void setNumConnections(int connections) {\n\t\tnumConnects = connections;\n\t}",
"public int numberOfOpenSites() {\n \treturn num;\r\n }",
"@Override\n public int getMaxConnections() throws ResourceException {\n return Integer.MAX_VALUE;\n }",
"public int numberOfOpenSites() {\n return numOpen;\n }",
"public static Integer numValidClients() {\n return getLoggedInUserConnections().size() + anonClients.size();\n }",
"public int numberOfOpenSites() {\n return openSitesCount;\n }",
"public int numberOfOpenSites() {\n return openSitesCount;\n }",
"public long getSessionCounter();",
"public String getDatabaseConnectionPoolMaxNumberConnections(){\n \t\treturn getProperty(\"org.sagebionetworks.pool.max.number.connections\");\n \t}",
"int getExecutorActiveCount();",
"public int numberOfOpenSites() {\n return numOpen;\n }",
"public static void resetConnectionCounts() {\n CREATED_TCP_CONNECTIONS.set(0);\n CREATED_UDP_CONNECTIONS.set(0);\n }",
"public int numberOfOpenSites() {\n return openNum;\n }",
"public int numberOfOpenSites() {\n return openSites;\n }",
"public int numberOfOpenSites() {\n return openSites;\n }",
"public int numberOfOpenSites() {\n return openSites;\n }",
"public int numberOfOpenSites() {\n return openSites;\n }",
"public int numberOfOpenSites() {\n return openSites;\n }",
"public int numberOfOpenSites() {\n return mOpenSites;\n }",
"public int getRunningDevicesCount();",
"public Long getMaxConcurrentConnection() {\n return this.MaxConcurrentConnection;\n }",
"public int numberOfOpenSites() {\n return this.numOfOpenSites;\n }",
"public int numberOfOpenSites(){\n return numOpenSites;\n }",
"private void decrConnectionCount() {\n connectionCount.dec();\n }",
"public int numberOfOpenSites() {\n \treturn size;\n }",
"public long getIdle() { return idle; }",
"public IdleConnectionHandler() {\n/* 61 */ this.connectionToTimes = new HashMap<HttpConnection, TimeValues>();\n/* */ }",
"public void incrementNumConnects() {\n this.numConnects.incrementAndGet();\n }",
"public int numberOfOpenSites() {\n return numberOfOpenSites;\n }",
"public ConnectionCount(int counter) {\nthis.counter = counter;\n}",
"public static int getNumberCreated() {\n return numberOfPools;\n }",
"public int getInactiveCount() {\n return inactiveCount;\n }",
"public int getConnectTimeouts() {\n return connectTimeouts.get();\n }",
"public int getNumberOfActivitiesOfConnections(Identity ownerIdentity);",
"public int numberOfOpenSites() {\n return 0;\n }",
"public int getMinConnections() {\n return minConnections;\n }",
"public Integer serverCount() {\n return this.serverCount;\n }",
"public int numberOfOpenSites() {\n return open_blocks;\n }",
"public void closeIdleConnections()\n {\n \n }",
"public int getRequestsCount() {\n return requests_.size();\n }"
]
| [
"0.7802752",
"0.77686685",
"0.7691691",
"0.7681597",
"0.75935644",
"0.755688",
"0.7522926",
"0.7516185",
"0.7483932",
"0.73354995",
"0.73258775",
"0.7293534",
"0.72698677",
"0.72369546",
"0.72081524",
"0.71651703",
"0.71007276",
"0.7096714",
"0.70588493",
"0.70296466",
"0.69916594",
"0.6985734",
"0.69627756",
"0.6942274",
"0.68589914",
"0.683562",
"0.680478",
"0.6790716",
"0.6765043",
"0.6756897",
"0.6745532",
"0.6698235",
"0.66980183",
"0.6681284",
"0.6654579",
"0.6652663",
"0.66183215",
"0.6614838",
"0.6614838",
"0.65965873",
"0.659171",
"0.6566439",
"0.6547051",
"0.6543397",
"0.6515283",
"0.65091604",
"0.65008605",
"0.6474056",
"0.6464916",
"0.6464787",
"0.6435024",
"0.64114136",
"0.63745445",
"0.63538307",
"0.63507044",
"0.6346603",
"0.6346419",
"0.63380367",
"0.6333033",
"0.6328476",
"0.6327128",
"0.63214797",
"0.63064057",
"0.6293129",
"0.6274744",
"0.6270948",
"0.6270948",
"0.6249239",
"0.624867",
"0.6242867",
"0.62408954",
"0.62350076",
"0.62324274",
"0.62260467",
"0.62260467",
"0.62260467",
"0.62260467",
"0.62260467",
"0.6220983",
"0.6215019",
"0.62108177",
"0.6196409",
"0.6193892",
"0.61910915",
"0.6181932",
"0.61798877",
"0.61712956",
"0.6167353",
"0.6165316",
"0.61650145",
"0.6159068",
"0.6154328",
"0.61526185",
"0.6143803",
"0.6135423",
"0.61237085",
"0.61153394",
"0.6109557",
"0.6108352",
"0.6095826"
]
| 0.78459173 | 0 |
Connection information as a string | public Map getConnectionUsage(); | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private String connectionToString(URLConnection con) throws IOException {\n\t\tStringWriter writer = new StringWriter();\n\t\tIOUtils.copy(con.getInputStream(), writer, \"UTF-8\");\n\t\treturn writer.toString();\n\t}",
"@Override\n public String toString() {\n return (name + \", IP=\" + ipAddress + \":\" + portNumber + \", DBNAME=\" + dbName\n + \", User=\" + userLogin + \", Password=********\"\n + \", DriverName=\" + driverName + \", DriverClass=\" + driverClass\n + \", ConnectionURL=\" + connectionURL\n + \", [INFORMIXSERVER=\" + informixServer + \"]\");\n }",
"@Override\n public String toString() {\n StringBuilder sb = new StringBuilder();\n sb.append(\"{\");\n if (getConnectionId() != null)\n sb.append(\"ConnectionId: \").append(getConnectionId()).append(\",\");\n if (getConnectionName() != null)\n sb.append(\"ConnectionName: \").append(getConnectionName()).append(\",\");\n if (getEncryptionMode() != null)\n sb.append(\"EncryptionMode: \").append(getEncryptionMode());\n sb.append(\"}\");\n return sb.toString();\n }",
"public String getConnectionDetails() {\n return getName();\n }",
"@Override\n public String toString() {\n return getClass().getSimpleName() + \"{\" +\n \"connectionType=\" + connectionType + \", \" +\n \"hostKey=\" + hostKey + \", \" +\n \"hostName=\" + hostName + \", \" +\n \"port=\" + port + \", \" +\n \"userName=\" + userName + \", \" +\n \"password=\" + password + \", \" +\n \"method=\" + method + \", \" +\n \"becomeMethod=\" + becomeMethod + \", \" +\n \"becomePassword=\" + becomePassword + \", \" +\n \"createHomeDirectory=\" + createHomeDirectory + \", \" +\n \"deleteHomeDirectory=\" + deleteHomeDirectory + \", \" +\n \"homeDirectoryPermissions=\" + homeDirectoryPermissions +\n \"}\";\n }",
"public String toString()\n\t{\n\t\treturn \"connection type \" + connType + \" length \" + length + \" data \"\n\t\t\t\t+ (opt.length == 0 ? \"-\" : DataUnitBuilder.toHex(opt, \" \"));\n\t}",
"String getConnection();",
"String getConnection();",
"String getConnection();",
"String getConnection();",
"public String[] getConnessionDetails() {\r\n\t\treturn new String[]{server.getText(),port.getText(),database.getText(),user.getText(),password.getText()};\r\n\t}",
"public String getConnection() {\n Object ref = connection_;\n if (!(ref instanceof String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n connection_ = s;\n return s;\n } else {\n return (String) ref;\n }\n }",
"public String getConnection() {\n Object ref = connection_;\n if (!(ref instanceof String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n connection_ = s;\n return s;\n } else {\n return (String) ref;\n }\n }",
"public String getConnection() {\n Object ref = connection_;\n if (!(ref instanceof String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n connection_ = s;\n return s;\n } else {\n return (String) ref;\n }\n }",
"public String getConnection() {\n Object ref = connection_;\n if (!(ref instanceof String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n connection_ = s;\n return s;\n } else {\n return (String) ref;\n }\n }",
"public String toString() {\n StringBuffer sb = new StringBuffer();\n\n // Print the connection ID\n sb.append(\"id=\" + connId + \", \");\n\n // Print the thread information\n if (threadName != null) {\n sb.append(\"thread=\" + threadName + \" (\" + threadId + \")\");\n } else {\n sb.append(\"thread=\" + threadId);\n }\n\n return sb.toString();\n }",
"@Override\n public String getConnection() {\n Object ref = connection_;\n if (ref instanceof String) {\n return (String) ref;\n } else {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n connection_ = s;\n return s;\n }\n }",
"@Override\n public String getConnection() {\n Object ref = connection_;\n if (ref instanceof String) {\n return (String) ref;\n } else {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n connection_ = s;\n return s;\n }\n }",
"@Override\n public String getConnection() {\n Object ref = connection_;\n if (ref instanceof String) {\n return (String) ref;\n } else {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n connection_ = s;\n return s;\n }\n }",
"@Override\n public String getConnection() {\n Object ref = connection_;\n if (ref instanceof String) {\n return (String) ref;\n } else {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n connection_ = s;\n return s;\n }\n }",
"public String toString() {\n\t\tif (_error)\n\t\t\treturn \"An error occured -- Could not fetch database metadata.\";\n\t\treturn _buffer.toString();\n\t}",
"@Override\n public String toString() {\n StringBuilder sb = new StringBuilder();\n sb.append(\"{\");\n if (getDatabaseHost() != null)\n sb.append(\"DatabaseHost: \").append(getDatabaseHost()).append(\",\");\n if (getDatabasePort() != null)\n sb.append(\"DatabasePort: \").append(getDatabasePort()).append(\",\");\n if (getDatabaseName() != null)\n sb.append(\"DatabaseName: \").append(getDatabaseName()).append(\",\");\n if (getTableName() != null)\n sb.append(\"TableName: \").append(getTableName()).append(\",\");\n if (getSecretArn() != null)\n sb.append(\"SecretArn: \").append(getSecretArn());\n sb.append(\"}\");\n return sb.toString();\n }",
"public String getConnection();",
"public String toString() {\n String msg = \"\\nList of current server connections\\n\";\n for (Object i : connections.keySet().toArray()) {\n msg += connections.get(i).toString();\n }\n return msg;\n }",
"public String getConnection()\n {\n return this.connection;\n }",
"public String getDetailString()\n {\n String msg = \"{0}, database: {1}, schema: {2}\";\n String unspec = \"<not specified>\";\n String db = StringUtils.isBlank(m_database) ? unspec : m_database;\n String orig = StringUtils.isBlank(m_origin) ? unspec : m_origin;\n return MessageFormat.format(msg, m_jdbcUrl, db, orig);\n }",
"public String getConnectionDescription()\n {\n return endpoint.getEndpointURI().toString();\n }",
"public String createConnection() {\r\n // Use DRIVER and DBURL to create a connection\r\n // Recommend connection pool implementation/usage\r\n return \"Connect to Cloudscape > \" + DRIVER + \"::\" + DBURL + \"\\n\";\r\n }",
"private String getConnectionLine(boolean bPersistentConnection) {\n String sConnection = \"Connection: \";\n String sConnectionStatus = (bPersistentConnection ? \"keep-alive\" : \"close\");\n return sConnection + sConnectionStatus;\n }",
"public Map<String, String> getConnectionDetails() {\n\t\treturn connectionDetails;\n\t}",
"@Override\n public String toString() {\n return getDbName() + \", \" + getDbHost();\n }",
"@Override\n public com.google.protobuf.ByteString\n getConnectionBytes() {\n Object ref = connection_;\n if (ref instanceof String) {\n com.google.protobuf.ByteString b =\n com.google.protobuf.ByteString.copyFromUtf8(\n (String) ref);\n connection_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }",
"@Override\n public com.google.protobuf.ByteString\n getConnectionBytes() {\n Object ref = connection_;\n if (ref instanceof String) {\n com.google.protobuf.ByteString b =\n com.google.protobuf.ByteString.copyFromUtf8(\n (String) ref);\n connection_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }",
"@Override\n public com.google.protobuf.ByteString\n getConnectionBytes() {\n Object ref = connection_;\n if (ref instanceof String) {\n com.google.protobuf.ByteString b =\n com.google.protobuf.ByteString.copyFromUtf8(\n (String) ref);\n connection_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }",
"@Override\n public com.google.protobuf.ByteString\n getConnectionBytes() {\n Object ref = connection_;\n if (ref instanceof String) {\n com.google.protobuf.ByteString b =\n com.google.protobuf.ByteString.copyFromUtf8(\n (String) ref);\n connection_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }",
"@Override\n public String toString() {\n SimpleDateFormat formatter = new SimpleDateFormat(\"yyyy-MM-dd'@'HH:mm:ss\");\n String userInformation = new String();\n Date date = new Date();\n userInformation = \"[\" + username + \" - \" +\n socket.getInetAddress().getHostAddress() +\n \":\" + socket.getPort() + \" - \" + formatter.format(date)\n + \"]: \";\n return userInformation;\n }",
"@Override\n public String getConnectionInfo() {\n return null;\n }",
"@Override\n public String toString() {\n StringBuilder builder = new StringBuilder();\n builder.append(\"socket://\");\n builder.append(addr.getHostString());\n builder.append(\":\");\n builder.append(addr.getPort());\n return builder.toString();\n }",
"@Override\r\n\tpublic String toString() {\r\n\t\treturn \"DatabaseConnectionTest: \";\r\n\t}",
"@Override\r\n\tpublic String toString() {\r\n\t\treturn \"DatabaseConnectionTest: \";\r\n\t}",
"public com.google.protobuf.ByteString\n getConnectionBytes() {\n Object ref = connection_;\n if (ref instanceof String) {\n com.google.protobuf.ByteString b =\n com.google.protobuf.ByteString.copyFromUtf8(\n (String) ref);\n connection_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }",
"public com.google.protobuf.ByteString\n getConnectionBytes() {\n Object ref = connection_;\n if (ref instanceof String) {\n com.google.protobuf.ByteString b =\n com.google.protobuf.ByteString.copyFromUtf8(\n (String) ref);\n connection_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }",
"public com.google.protobuf.ByteString\n getConnectionBytes() {\n Object ref = connection_;\n if (ref instanceof String) {\n com.google.protobuf.ByteString b =\n com.google.protobuf.ByteString.copyFromUtf8(\n (String) ref);\n connection_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }",
"public com.google.protobuf.ByteString\n getConnectionBytes() {\n Object ref = connection_;\n if (ref instanceof String) {\n com.google.protobuf.ByteString b =\n com.google.protobuf.ByteString.copyFromUtf8(\n (String) ref);\n connection_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }",
"public String getInfoPool() {\n StringBuilder info = new StringBuilder();\n \n if (pool == null) {\n info.append(\"El pool no está creado\");\n } else {\n\n int conexiones_libres = pool.getTotalFree();\n int conexiones_creadas_totales = pool.getTotalCreatedConnections();\n int conexiones_liberadas_totales = pool.getTotalLeased();\n \n BoneCPConfig config = pool.getConfig();\n \n info.append(\"Pool \" + config.getPoolName() + \": \");\n info.append(\"Libres: \" + conexiones_libres + \" / \");\n info.append(\"Tot. creadas: \" + conexiones_creadas_totales + \" / \");\n info.append(\"Tot. liberadas: \" + conexiones_liberadas_totales + Comun.NL);\n }\n \n info.append(Comun.NL);\n \n return info.toString();\n }",
"@Override\n public String toString() {\n \treturn this.getUsername()+\"\\t\\t\"+this.getTel()+\"\\t\\t\"+this.getPassword()+\"\\t\"+this.getMembertypeid()+\"\\t\\t\"+this.getIntegral()+\"\\t\\t\"+this.getAddress();\n }",
"PeerConnectionInformation peerConnectionInformation();",
"public String toString()\n {\n return serverAddress == null?\"null\":serverAddress.toString();\n }",
"public String getConnectionStatus() {\n\t\treturn this.connectionStatus;\n\t}",
"com.google.protobuf.ByteString\n getConnectionBytes();",
"com.google.protobuf.ByteString\n getConnectionBytes();",
"com.google.protobuf.ByteString\n getConnectionBytes();",
"com.google.protobuf.ByteString\n getConnectionBytes();",
"public String getConnectionName() {\n return connectionName;\r\n }",
"public static String getConnectivityStatusString(Context context) {\r\n int conn = NetworkUtil.getConnectivityStatus(context);\r\n String status = null;\r\n if (conn == 1) {\r\n status = \"Connected\";\r\n } else if (conn == 2) {\r\n status = \"Connected\";\r\n } else if (conn == 0) {\r\n status = \"Not-Connected\";\r\n }\r\n return status;\r\n }",
"public String getConnectionString()\n\t{\n\t\treturn connectionString;\n\t}",
"private static String getResponseAsString(HttpURLConnection connection) throws Exception {\n InputStream in = connection.getInputStream();\n ByteArrayOutputStream out = new ByteArrayOutputStream();\n int b;\n while ((b = in.read()) != -1) {\n out.write(b);\n }\n return out.toString();\n }",
"public String getInformation() {\n\t\tStringBuilder sb = new StringBuilder();\n\n\t\tencodingTable.forEach((c, s) -> {\n\t\t\tsb.append(c);\n\t\t\tsb.append(\" -> \");\n\t\t\tsb.append(s);\n\t\t\tsb.append('\\n');\n\t\t});\n\n\t\treturn sb.toString();\n\t}",
"public String getConnectionString() {\n return this.connectionString;\n }",
"public String getConnectionName() {\n return this.connectionName;\n }",
"public String toString()\r\n\t{\r\n\t\treturn this.mac+\",\"+this.ssid+\",\"+this.channel+\",\"+this.signal+\",\";\r\n\t\t\r\n\t}",
"protected String stringConnectionsMatrix() {\n String ret = \"Connection Matrix\";\n for (G good : this.goods) {\n ret += \"\\n\";\n for (B bidder : this.bidders) {\n if (bidder.demandsGood(good)) {\n ret += \"\\t yes\";\n } else {\n ret += \"\\t no\";\n }\n }\n }\n return ret + \"\\n\";\n }",
"public String toString(){\n return \"MAVLINK_MSG_ID_GIMBAL_DEVICE_INFORMATION - sysid:\"+sysid+\" compid:\"+compid+\" time_boot_ms:\"+time_boot_ms+\" firmware_version:\"+firmware_version+\" tilt_max:\"+tilt_max+\" tilt_min:\"+tilt_min+\" tilt_rate_max:\"+tilt_rate_max+\" pan_max:\"+pan_max+\" pan_min:\"+pan_min+\" pan_rate_max:\"+pan_rate_max+\" cap_flags:\"+cap_flags+\" vendor_name:\"+vendor_name+\" model_name:\"+model_name+\"\";\n }",
"java.lang.String getConnectionId();",
"java.lang.String getConnectionId();",
"java.lang.String getConnectionId();",
"public String getInfoString();",
"public String toString() {\n\t\t\tswitch(this) {\n\t\t\tcase INSERT_BSI_RESOURCES_BASE:{\n\t\t\t\treturn \"INSERT INTO lry.aut_bsi_prc_cfg_resources(CFG_ID, RSC_NAME, RSC_DESCRIPTION, RSC_LOCATION_INPUT, RSC_LOCATION_OUTPUT, RSC_ITEM, RSC_ITEM_KEY) VALUES(?,?,?,?,?,?,?);\";\n\t\t\t}\n\t\t\tcase SELECT_ALL_BSI_RESOURCES_BASE:{\n\t\t\t\treturn \"SELECT RSC_ID FROM lry.aut_bsi_prc_cfg_resources;\";\n\t\t\t}\n\t\t\tcase SELECT_BSI_RESOURCES_BASE_BY_CFG_BASE_ID:{\n\t\t\t\treturn \"SELECT RSC_ID FROM lry.aut_bsi_prc_cfg_resources WHERE CFG_ID=?;\";\n\t\t\t}\n\t\t\tdefault:{\n\t\t\t\treturn this.name();\n\t\t\t}\n\t\t\t}\n\t\t}",
"public interface JDBCConnectionInfo {\n\tstatic final String CONNECTIONINFO = \"jdbc:mysql://sql9.freemysqlhosting.net:3306/sql9378764?useSSL=false\";\n\tstatic final String LOGIN = \"sql9378764\";\n\tstatic final String PASSWORD = \"rrXgstV3nB\";\n\n\tstatic final String MOVIETABLE = \"MOVIE\";\n\tstatic final String REGISTEREDUSERTABLE = \"REGISTEREDUSER\";\n\tstatic final String SHOWTIMETABLE = \"SHOWTIME\";\n\tstatic final String TICKETTABLE = \"TICKET\";\n\tstatic final String VOUCHERTABLE = \"VOUCHER\";\n\tstatic final String THEATRETABLE = \"THEATRE\";\n}",
"public String toString() {\n return \"appName=\" + _appName\n + \", readTimeout=\" + _readTimeout + \", poolSize=\" + _poolSize\n + \", numberOfOperations=\" + numOfOps + \", shutdown=\" + _shutdown;\n }",
"public String toString() {\n String ret = null;\n ContentIOSession session = getIOSession();\n try {\n ret = \"{\" + session.getId() + \", \" + session.getType() + \"}\";\n } finally {\n session.close();\n }\n return ret;\n\n }",
"org.apache.calcite.avatica.proto.Common.ConnectionProperties getConnProps();",
"public String toString() {\n/* 235 */ return \"Status = \" + this.status + \" HandshakeStatus = \" + this.handshakeStatus + \"\\nbytesConsumed = \" + this.bytesConsumed + \" bytesProduced = \" + this.bytesProduced;\n/* */ }",
"@Override\n public String toString() {\n StringBuilder sb = new StringBuilder();\n sb.append(\"{\");\n if (getGlobalTableName() != null)\n sb.append(\"GlobalTableName: \").append(getGlobalTableName()).append(\",\");\n if (getReplicaSettings() != null)\n sb.append(\"ReplicaSettings: \").append(getReplicaSettings());\n sb.append(\"}\");\n return sb.toString();\n }",
"public String toString() {\r\n\t\tString host;\r\n\t\tint port;\r\n\t\tString tmpStr = \"\";\r\n\t\ttmpStr += \"Server(s):\\n\";\r\n\t\ttmpStr += \"----------\";\r\n\t\tfor(int i=0; i<listHostPort.size(); i++) {\r\n\t\t\thost = ((DNSHostPort)listHostPort.get(i)).getHost();\r\n\t\t\tport = ((DNSHostPort)listHostPort.get(i)).getPort();\r\n\t\t\ttmpStr += \" \" + host + \":\" + port + \"\\n\";\r\n\t\t}\r\n\t\treturn tmpStr;\r\n\t}",
"private String getServerDetails() {\n String sServerLine = \"Server: Ramon's Killer \";\n String sSocketType = (bIsSecure ? \"(SECURE)\" : \"(unsecure)\");\n sServerLine = sServerLine + sSocketType + \" Server\";\n return sServerLine;\n }",
"public java.lang.String getConnectionId() {\n java.lang.Object ref = connectionId_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n connectionId_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }",
"public java.lang.String getConnectionId() {\n java.lang.Object ref = connectionId_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n connectionId_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }",
"public java.lang.String getConnectionId() {\n java.lang.Object ref = connectionId_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n connectionId_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }",
"public String toString() {\r\n\treturn \"interfaceID = \" + interfaceID + \"; versionInfoID = \" + versionInfoID + \"; blender = \" + blender;\r\n }",
"public String toString() {\n\t\treturn(\"\\nComputer Info:\" +\n\t\t\t \"\\nBrand: \" + brand +\n\t\t\t \"\\nModel: \" + model +\n\t\t\t \"\\nSN: \" + SN +\n\t\t\t \"\\nPrice: \" + price);\n\t}",
"public String toString() {\n String result = \"VersionDownload: \";\n result += \", serverType: \";\n result += serverType;\n result += \", userName: \";\n result += userName;\n result += \", userPass: \";\n result += userPass;\n result += \", versionPath: \";\n result += versionPath;\n result += \", serverPort: \";\n result += serverPort;\n result = result.replaceFirst(\", \", \"\");\n\n return result;\n }",
"public org.apache.calcite.avatica.proto.Common.ConnectionProperties getConnProps() {\n if (connPropsBuilder_ == null) {\n return connProps_ == null ? org.apache.calcite.avatica.proto.Common.ConnectionProperties.getDefaultInstance() : connProps_;\n } else {\n return connPropsBuilder_.getMessage();\n }\n }",
"ConnectionProfile connectionProfile();",
"@Override\n public String toString() {\n return info();\n }",
"public String toString() {\n \t\tStringBuffer retval = new StringBuffer();\r\n \t\tretval.append(address.toString());\r\n \t\tif ( parameters.size() != 0 ) retval.append(\";\").append(parameters.toString());\r\n \t\treturn retval.toString();\r\n \t}",
"public String getConnectionId() {\n return this.connectionId;\n }",
"@Override\n public String getConnectionAlias() {\n Object ref = connectionAlias_;\n if (ref instanceof String) {\n return (String) ref;\n } else {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n connectionAlias_ = s;\n return s;\n }\n }",
"@Override\n public String getConnectionAlias() {\n Object ref = connectionAlias_;\n if (ref instanceof String) {\n return (String) ref;\n } else {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n connectionAlias_ = s;\n return s;\n }\n }",
"public String toString() {\n\t\tStringBuffer sb;\n\t\tsb = new StringBuffer(\"\\nlogin : \" + login);\n\t\tsb.append(\"\\npass : \" + passwd);\n\t\tif (admin) sb.append(\"admin\");\n\t\tif (pcreator) sb.append(\"pcreator\");\n\t\treturn sb.toString();\n\t}",
"public String toString()\n {\n /**\n * Set the format as [timestamp] account number : command\n */\n String transaction = \"[\" + timestamp + \"] \" + accountInfo.getAccountNumber() + \" : \" + command.name(); \n \n /**\n * Return the string.\n */\n return transaction;\n }",
"public void getNetworkConnection() {\n System.out.println(((AndroidDriver) getDriver()).getConnection());\n }",
"public String toString() {\r\n StringBuilder sb = new StringBuilder();\r\n sb.append(this.getClass().getName());\r\n sb.append(\"(\");\r\n\r\n sb.append(\", \").append(\"username=\").append(username);\r\n\r\n sb.append(\", \").append(\"email=\").append(email);\r\n\r\n sb.append(\", \").append(\"ragione_sociale=\").append(ragione_sociale);\r\n\r\n sb.append(\", \").append(\"nome=\").append(nome);\r\n\r\n sb.append(\", \").append(\"cognome=\").append(cognome);\r\n\r\n sb.append(\", \").append(\"immagine=\").append(immagine);\r\n\r\n sb.append(\", \").append(\"data_ultima_modifica=\").append(data_ultima_modifica);\r\n\r\n sb.append(\", \").append(\"oggetti=\").append(oggetti);\r\n\r\n sb.append(\", \").append(\"prestiti=\").append(prestiti);\r\n\r\n sb.append(\")\");\r\n return sb.toString();\r\n }",
"public String getInfo() {\n Object ref = info_;\n if (!(ref instanceof String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n info_ = s;\n return s;\n } else {\n return (String) ref;\n }\n }",
"public String getDbconnstr() {\n return dbconnstr;\n }",
"public String toString()\n { \n \treturn (\"Door of ID: \" + id + \" connects to Room ID: \" + room.getName() + \", Locked: \" + isLocked +\n \t\t\t\", Unlocking key: \" + keyID);\n }",
"public String toString() {\r\n\t\tif (!error)\r\n\t\t\treturn \"Username: \" + userName + \"\\nID: \" + id + \"\\nAuthToken: \" + authToken;\r\n\t\telse\r\n\t\t\treturn \"Error: \" + message; \r\n\t}",
"public String toString() {\n\t\treturn \"[\" + clientId + \"] \" + messageCount + \" messages sent - Connected = \" + String.valueOf(isConnected());\n\t}",
"private String readToString(URLConnection connection) throws IOException {\n\tBufferedReader reader = null;\n\ttry {\n\t\tInputStream inStream = connection.getInputStream();\n\t\tif (connection instanceof java.net.HttpURLConnection) {\n\t\t\tHttpURLConnection httpConnection = (HttpURLConnection) connection;\n\t\t\tif (httpConnection.getResponseCode() == 403) {\n\t\t\t\tthrow new IOException(\"Service does not accept the authentication credentials: \"\n\t\t\t\t\t+ httpConnection.getResponseCode() + httpConnection.getResponseMessage());\n\t\t\t} else if (httpConnection.getResponseCode() >= 400) {\n\t\t\t\tthrow new IOException(\"Service responded with a failure code: \"\n\t\t\t\t\t+ httpConnection.getResponseCode() + httpConnection.getResponseMessage());\n\t\t\t}\n\t\t} else {\n\t\t\tthrow new IOException(\"Unexpected URI type encountered\");\n\t\t}\n\t\treader = new BufferedReader(new InputStreamReader(inStream));\n\t\tString str;\n\t\tStringBuilder buffer = new StringBuilder();\n\t\twhile ((str = reader.readLine()) != null) {\n\t\t\tbuffer.append(str);\n\t\t}\n\t\treturn buffer.toString();\n\t } finally {\n\t \tif (reader != null) {\n\t \t\treader.close();\n\t \t}\n\t}\n }",
"public java.lang.String getConnectionId() {\n java.lang.Object ref = connectionId_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n connectionId_ = s;\n return s;\n }\n }",
"public java.lang.String getConnectionId() {\n java.lang.Object ref = connectionId_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n connectionId_ = s;\n return s;\n }\n }"
]
| [
"0.7514957",
"0.7255365",
"0.725387",
"0.7048909",
"0.69239515",
"0.68940336",
"0.68655837",
"0.68655837",
"0.68655837",
"0.68655837",
"0.68297195",
"0.6781957",
"0.6781957",
"0.6781957",
"0.6781957",
"0.6771722",
"0.665216",
"0.665216",
"0.665216",
"0.665216",
"0.66172236",
"0.66085005",
"0.6583608",
"0.65428734",
"0.6483097",
"0.64802486",
"0.6477974",
"0.64418745",
"0.64149266",
"0.64015335",
"0.63318896",
"0.6304991",
"0.6304991",
"0.6304991",
"0.6304991",
"0.6282007",
"0.62105834",
"0.6186595",
"0.61666775",
"0.61666775",
"0.6134683",
"0.6134683",
"0.6134683",
"0.6134683",
"0.6091514",
"0.60779625",
"0.60773295",
"0.60648924",
"0.6057287",
"0.60546726",
"0.60546726",
"0.60546726",
"0.60546726",
"0.60407925",
"0.59882116",
"0.59730196",
"0.59640545",
"0.5945268",
"0.59249556",
"0.5919161",
"0.59164965",
"0.5909143",
"0.59071755",
"0.5894396",
"0.5894396",
"0.5894396",
"0.588194",
"0.58788556",
"0.58777833",
"0.5876435",
"0.58668476",
"0.5848086",
"0.5831073",
"0.58287746",
"0.5816552",
"0.5795687",
"0.57948285",
"0.57948285",
"0.57948285",
"0.5786947",
"0.57845926",
"0.5783991",
"0.5781474",
"0.5775581",
"0.57736474",
"0.57621515",
"0.5759311",
"0.57565314",
"0.57565314",
"0.57421464",
"0.5741811",
"0.572978",
"0.57271457",
"0.5726343",
"0.5722789",
"0.57133245",
"0.571149",
"0.5697837",
"0.5696261",
"0.5695777",
"0.5695777"
]
| 0.0 | -1 |
Sets up this panel with some buttons to show how flow layout affects their position. | public FlowPanel(){
setLayout(new FlowLayout());
setBackground(Color.green);
JButton b1 = new JButton("Button 1");
JButton b2 = new JButton("Button 2");
JButton b3 = new JButton("Button 3");
JButton b4 = new JButton("Button 4");
JButton b5 = new JButton("Button 5");
add(b1);
add(b2);
add(b3);
add(b4);
add(b5);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void setupPanel()\n\t{\n\t\tthis.setLayout(baseLayout);\n\t\tthis.add(firstButton);\n\t\tthis.add(firstField);\n\t}",
"@Override\n\tpublic void doLayout() {\n\t\tthis.transitionsPanel.setBounds(0, 0, this.getWidth(), this.getHeight());\n\t\t//this.timersButton.setBounds(this.getWidth()-2*50, 0, 50, 50);\n\t\t//this.countersButton.setBounds(this.getWidth()-50, 0, 50, 50);\n\t\t//this.salirButton.setBounds(this.getWidth()-40,0,40, 40);\n\t\tsuper.doLayout();\n\t}",
"private void setupLayout() {\r\n\t\tgetContentPane().add(panel);\r\n\t}",
"private void setUpPanel() {\n\n this.add(nameLabel);\n this.add(showMetadataButton);\n this.add(compressFilesButton);\n this.add(decompressFilesButton);\n this.add(compressionResultLabel);\n this.add(messageShorteningButton);\n this.add(messageShorteningResultLabel);\n }",
"private void setupLayout()\n\t{\n\t\tbaseLayout.putConstraint(SpringLayout.NORTH, queryButton, 70, SpringLayout.NORTH, this);\n\t\tbaseLayout.putConstraint(SpringLayout.WEST, queryButton, 49, SpringLayout.WEST, this);\n\t}",
"private void setupPanel()\n\t{\n\t\tthis.setLayout(baseLayout);\n\t\tqueryButton = new JButton(\"query\");\n\t\tthis.add(queryButton);\n\t\tthis.add(displayPane);\n\t\tdisplayArea = new JTextArea(10,30);\n\t\tadd(displayArea);\n\t\t\n\t\t\n\t}",
"private void setupLayout()\n\t{\n\t\tbaseLayout.putConstraint(SpringLayout.WEST,firstButton,107,SpringLayout.WEST, this);\n\t\tbaseLayout.putConstraint(SpringLayout.SOUTH, firstButton, -32, SpringLayout.SOUTH, this);\n\t\tbaseLayout.putConstraint(SpringLayout.WEST, firstField, 37, SpringLayout.WEST, this);\n\t\tbaseLayout.putConstraint(SpringLayout.SOUTH, firstField, -24, SpringLayout.SOUTH, this);\n\t}",
"private void setUpLayout() {\n\n this.setLayout(new GridLayout(7, 1, 40, 37));\n this.setBackground(new Color(72, 0, 0));\n this.setBorder(BorderFactory.createEmptyBorder(8, 150, 8, 150));\n }",
"private void setUp() {\r\n add(myNextPiece, BorderLayout.NORTH);\r\n add(myScorePanel, BorderLayout.CENTER);\r\n add(myControl, BorderLayout.SOUTH);\r\n }",
"private void initializePanels() {\n queueInfoPanel.setBackground(new Color(236, 125, 51));\n queueButtonsPanel.setBackground(new Color(93, 118, 161));\n createLabelForPanel(queueInfoPanel);\n createButtonsForPanel(queueButtonsPanel);\n }",
"public JButtonsPanel() {\r\n setBorder(BorderFactory.createEtchedBorder(Color.GREEN, new Color(148, 145, 140)));\r\n\r\n jOpen.setText(BTN_OPEN);\r\n jOpen.setToolTipText(MSG_OPEN);\r\n jOpen.setBounds(new Rectangle(BTN_LEFT, BTN_VSPACE, BTN_WIDTH, BTN_HEIGHT));\r\n add(jOpen);\r\n\r\n jCheckHealth.setText(BTN_CHECK_HEALTH);\r\n jCheckHealth.setToolTipText(MSG_CHECK_HEALTH);\r\n jCheckHealth.setBounds(new Rectangle(BTN_LEFT, (int) (jOpen.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jCheckHealth);\r\n\r\n jClose.setText(BTN_CLOSE);\r\n jClose.setToolTipText(MSG_CLOSE);\r\n jClose.setBounds(new Rectangle(BTN_LEFT, (int) (jCheckHealth.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jClose);\r\n\r\n jClaim.setText(BTN_CLAIM);\r\n jClaim.setToolTipText(MSG_CLAIM);\r\n jClaim.setBounds(new Rectangle(BTN_LEFT, (int) (jClose.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jClaim);\r\n\r\n jRelease.setText(BTN_RELEASE);\r\n jRelease.setToolTipText(MSG_RELEASE);\r\n jRelease.setBounds(new Rectangle(BTN_LEFT, (int) (jClaim.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jRelease);\r\n\r\n jDeviceEnable.setText(BTN_DEVICE_ENABLE);\r\n jDeviceEnable.setToolTipText(MSG_DEVICE_ENABLE);\r\n jDeviceEnable.setBounds(new Rectangle(BTN_LEFT, (int) (jRelease.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jDeviceEnable);\r\n\r\n jDeviceDisable.setText(BTN_DEVICE_DISABLE);\r\n jDeviceDisable.setToolTipText(MSG_DEVICE_DISABLE);\r\n jDeviceDisable.setBounds(new Rectangle(BTN_LEFT, (int) (jDeviceEnable.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jDeviceDisable);\r\n\r\n jClearData.setText(BTN_CLEAR_DATA);\r\n jClearData.setToolTipText(MSG_CLEAR_DATA);\r\n jClearData.setBounds(new Rectangle(BTN_LEFT, (int) (jDeviceDisable.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jClearData);\r\n\r\n jBeginEnrollCapture.setText(BTN_BEGIN_ENROLL_CAPTURE);\r\n jBeginEnrollCapture.setToolTipText(MSG_BEGIN_ENROLL_CAPTURE);\r\n jBeginEnrollCapture.setBounds(new Rectangle(BTN_LEFT, (int) (jClearData.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jBeginEnrollCapture);\r\n\r\n jEndCapture.setText(BTN_END_CAPTURE);\r\n jEndCapture.setToolTipText(MSG_END_CAPTURE);\r\n jEndCapture.setBounds(new Rectangle(BTN_LEFT, (int) (jBeginEnrollCapture.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jEndCapture);\r\n\r\n jBeginVerifyCapture.setText(BTN_BEGIN_VERIFY_CAPTURE);\r\n jBeginVerifyCapture.setToolTipText(MSG_BEGIN_VERIFY_CAPTURE);\r\n jBeginVerifyCapture.setBounds(new Rectangle(BTN_LEFT, (int) (jEndCapture.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jBeginVerifyCapture);\r\n\r\n jIdentifyMatch.setText(BTN_IDENTIFY_MATCH);\r\n jIdentifyMatch.setToolTipText(MSG_IDENTIFY_MATCH);\r\n jIdentifyMatch.setBounds(new Rectangle(BTN_LEFT, (int) (jBeginVerifyCapture.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jIdentifyMatch);\r\n\r\n jVerifyMatch.setText(BTN_VERIFY_MATCH);\r\n jVerifyMatch.setToolTipText(MSG_VERIFY_MATCH);\r\n jVerifyMatch.setBounds(new Rectangle(BTN_LEFT, (int) (jIdentifyMatch.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jVerifyMatch);\r\n\r\n jIdentify.setText(BTN_IDENTIFY);\r\n jIdentify.setToolTipText(MSG_IDENTIFY);\r\n jIdentify.setBounds(new Rectangle(BTN_LEFT, (int) (jVerifyMatch.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jIdentify);\r\n\r\n jVerify.setText(BTN_VERIFY);\r\n jVerify.setToolTipText(MSG_VERIFY);\r\n jVerify.setBounds(new Rectangle(BTN_LEFT, (int) (jIdentify.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jVerify);\r\n }",
"private void setup() {\r\n setDefaultCloseOperation(DISPOSE_ON_CLOSE);\r\n\r\n // list\r\n listPanel = new JPanel();\r\n listPanel.setLayout(new BoxLayout(listPanel, BoxLayout.PAGE_AXIS));\r\n\r\n JScrollPane scrollPane = new JScrollPane(listPanel);\r\n\r\n // button\r\n JPanel buttonPanel = new JPanel(new FlowLayout(FlowLayout.RIGHT));\r\n buttonPanel.setBorder(BorderFactory.createEmptyBorder(4, 4, 4, 4));\r\n\r\n JButton button = new JButton(\"Close\");\r\n button.addActionListener(this);\r\n buttonPanel.add(button);\r\n\r\n // container\r\n Container contentPane = getContentPane();\r\n contentPane.setLayout(new BorderLayout());\r\n\r\n contentPane.add(scrollPane, BorderLayout.CENTER);\r\n contentPane.add(buttonPanel, BorderLayout.PAGE_END);\r\n }",
"private void $$$setupUI$$$() {\n contentPane = new JPanel();\n contentPane.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(3, 1, new Insets(10, 10, 10, 10), -1, -1));\n btnPanel = new JPanel();\n btnPanel.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(btnPanel, new com.intellij.uiDesigner.core.GridConstraints(2, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, 1, null, null, null, 0, false));\n final com.intellij.uiDesigner.core.Spacer spacer1 = new com.intellij.uiDesigner.core.Spacer();\n btnPanel.add(spacer1, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n btnPanel2 = new JPanel();\n btnPanel2.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n btnPanel.add(btnPanel2, new com.intellij.uiDesigner.core.GridConstraints(0, 1, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n buttonOK = new JButton();\n buttonOK.setText(\"OK\");\n btnPanel2.add(buttonOK, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n contentPanel = new JPanel();\n contentPanel.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(contentPanel, new com.intellij.uiDesigner.core.GridConstraints(1, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n content = new JTextArea();\n content.setBackground(new Color(-1118482));\n content.setEditable(false);\n contentPanel.add(content, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, null, new Dimension(150, 50), null, 0, false));\n title = new JLabel();\n Font titleFont = this.$$$getFont$$$(null, -1, 20, title.getFont());\n if (titleFont != null) title.setFont(titleFont);\n title.setText(\"Invalid Number of Players\");\n contentPane.add(title, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_NONE, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n }",
"private void $$$setupUI$$$() {\n myContentPanel = new JPanel();\n myContentPanel.setLayout(new GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(4, 1, new Insets(0, 0, 0, 0), -1, -1));\n myContentPanel.add(panel1, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n myAcceptYoursButton = new JButton();\n myAcceptYoursButton.setEnabled(false);\n myAcceptYoursButton.setText(\"Accept Yours\");\n myAcceptYoursButton.setMnemonic('Y');\n myAcceptYoursButton.setDisplayedMnemonicIndex(7);\n panel1.add(myAcceptYoursButton, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final Spacer spacer1 = new Spacer();\n panel1.add(spacer1, new GridConstraints(3, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_VERTICAL, 1, GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n myAcceptTheirsButton = new JButton();\n myAcceptTheirsButton.setEnabled(false);\n myAcceptTheirsButton.setText(\"Accept Theirs\");\n myAcceptTheirsButton.setMnemonic('T');\n myAcceptTheirsButton.setDisplayedMnemonicIndex(7);\n panel1.add(myAcceptTheirsButton, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n myMergeButton = new JButton();\n myMergeButton.setEnabled(false);\n myMergeButton.setText(\"Merge\");\n myMergeButton.setMnemonic('M');\n myMergeButton.setDisplayedMnemonicIndex(0);\n panel1.add(myMergeButton, new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JBScrollPane jBScrollPane1 = new JBScrollPane();\n myContentPanel.add(jBScrollPane1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n myItemsTable = new JBTable();\n myItemsTable.putClientProperty(\"Table.isFileList\", Boolean.FALSE);\n jBScrollPane1.setViewportView(myItemsTable);\n }",
"public void setupLayout() {\n // left empty for subclass to override\n }",
"private void setButtonPanelComponents(){\n\t\tJPanel buttonPane = new JPanel();\n\t\tbuttonPane.setPreferredSize(new Dimension(-1,32));\n\t\tbuttonPane.setBackground(Constant.DIALOG_BOX_COLOR_BG);\n\t\tbuttonPane.setLayout(new FlowLayout(FlowLayout.RIGHT));\n\t\tgetContentPane().add(buttonPane, BorderLayout.SOUTH);\n\t\t\n\t\tsaveButton = Utilities.getInstance().initializeNewButton(\n\t\t\t-1, -1, -1, -1,\n\t\t\tImages.getInstance().saveBtnDialogImg,\n\t\t\tImages.getInstance().saveBtnDialogImgHover\n\t\t);\n\t\tbuttonPane.add(saveButton);\n\t\n\n\t\n\t}",
"private void initButton() {\r\n\t\tthis.panelButton = new JPanel();\r\n\t\tthis.panelButton.setLayout(new BoxLayout(this.panelButton,\r\n\t\t\t\tBoxLayout.LINE_AXIS));\r\n\t\tthis.modifyButton = new JButton(\"Modify\");\r\n\t\tthis.buttonSize(this.modifyButton);\r\n\t\tthis.deleteButton = new JButton(\"Delete\");\r\n\t\tthis.buttonSize(this.deleteButton);\r\n\t\tthis.cancelButton = new JButton(\"Cancel\");\r\n\t\tthis.buttonSize(this.cancelButton);\r\n\r\n\t\tthis.modifyButton.addActionListener(this.editWeaponControl);\r\n\t\tthis.deleteButton.addActionListener(this.editWeaponControl);\r\n\t\tthis.cancelButton.addActionListener(this.editWeaponControl);\r\n\r\n\t\tthis.panelButton.add(this.modifyButton);\r\n\t\tthis.panelButton.add(Box.createRigidArea(new Dimension(15, 0)));\r\n\t\tthis.panelButton.add(this.deleteButton);\r\n\t\tthis.panelButton.add(Box.createRigidArea(new Dimension(15, 0)));\r\n\t\tthis.panelButton.add(this.cancelButton);\r\n\t}",
"public void addComponentsToPanel() {\n\t\tpanel.add(backBtn);\n\t\tpanel.add(forgotPassword);\n\t\tpanel.add(txtPass);\n\t\tpanel.add(txtSendEmail);\n\t\tpanel.add(remindMeBtn);\n\n\t\tpanel.add(backgroundLabel);\n\t}",
"private void $$$setupUI$$$()\n {\n panel = new JPanel();\n panel.setLayout(new GridLayoutManager(6, 1, new Insets(20, 20, 20, 20), -1, -1));\n panel.setAutoscrolls(true);\n buttonSettings = new JButton();\n buttonSettings.setEnabled(true);\n buttonSettings.setText(\"Open Application Settings\");\n panel.add(buttonSettings,\n new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL,\n GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW,\n GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n buttonStartGit = new JButton();\n buttonStartGit.setEnabled(true);\n buttonStartGit.setText(\"Start Git Management\");\n panel.add(buttonStartGit,\n new GridConstraints(3, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL,\n GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW,\n GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JScrollPane scrollPane1 = new JScrollPane();\n panel.add(scrollPane1, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH,\n GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW,\n GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW,\n null, new Dimension(500, 500), null, 0, false));\n textPaneConsole = new JTextPane();\n textPaneConsole.setEditable(false);\n scrollPane1.setViewportView(textPaneConsole);\n buttonOpenBenchmarkDialog = new JButton();\n buttonOpenBenchmarkDialog.setText(\"Open YCSB Benchmark Dialog\");\n panel.add(buttonOpenBenchmarkDialog,\n new GridConstraints(5, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL,\n GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW,\n GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n buttonShowGitSettings = new JButton();\n buttonShowGitSettings.setEnabled(true);\n buttonShowGitSettings.setText(\"Open Git Management\");\n panel.add(buttonShowGitSettings,\n new GridConstraints(4, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL,\n GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW,\n GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JLabel label1 = new JLabel();\n label1.setText(\"Console Output\");\n panel.add(label1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE,\n GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null,\n null, null, 0, false));\n }",
"private void $$$setupUI$$$() {\n topPanel = new JPanel();\n topPanel.setLayout(new GridLayoutManager(4, 1, new Insets(0, 0, 0, 0), -1, -1));\n headerLabel = new JLabel();\n headerLabel.setText(\"Header\");\n topPanel.add(headerLabel, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n contentPanel = new JPanel();\n contentPanel.setLayout(new BorderLayout(0, 0));\n topPanel.add(contentPanel, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(1, 4, new Insets(0, 0, 0, 0), -1, -1));\n topPanel.add(panel1, new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final Spacer spacer1 = new Spacer();\n panel1.add(spacer1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n buttonBack = new JButton();\n buttonBack.setText(\"Back\");\n panel1.add(buttonBack, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n buttonNext = new JButton();\n buttonNext.setText(\"Next\");\n panel1.add(buttonNext, new GridConstraints(0, 2, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n buttonCancel = new JButton();\n buttonCancel.setText(\"Cancel\");\n panel1.add(buttonCancel, new GridConstraints(0, 3, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JPanel panel2 = new JPanel();\n panel2.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n topPanel.add(panel2, new GridConstraints(3, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n statusLabel = new JLabel();\n statusLabel.setText(\"Status\");\n panel2.add(statusLabel, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n }",
"public void setupPanel() {\n\t\tpanel = new JPanel();\n\t\tpanel.setLayout(new ModifiedFlowLayout(FlowLayout.LEFT));\n\t\tpanel.setBackground(Color.BLACK);\n\t\tpanel.setOpaque(true);\n\t}",
"private void setUp() {\n\t\tthis.setLayout(new BorderLayout());\n\t\tsetupMessagePanel();\n\t\tsetupHomeButtonPanel();\n\t}",
"private void $$$setupUI$$$() {\n contentPane = new JPanel();\n contentPane.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(4, 2, new Insets(10, 10, 10, 10), -1, -1));\n contentPane.setBackground(new Color(-16316665));\n contentPane.setMinimumSize(new Dimension(450, 500));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(1, 5, new Insets(0, 0, 0, 0), 0, 0));\n panel1.setAlignmentY(0.0f);\n panel1.setAutoscrolls(true);\n panel1.setBackground(new Color(-16316665));\n contentPane.add(panel1, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 4, 2, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_NORTH, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n stopButton = new JButton();\n stopButton.setBackground(new Color(-16316665));\n stopButton.setForeground(new Color(-1041));\n stopButton.setText(\"Stop\");\n panel1.add(stopButton, new com.intellij.uiDesigner.core.GridConstraints(0, 4, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n pauseButton = new JButton();\n pauseButton.setBackground(new Color(-16316665));\n pauseButton.setForeground(new Color(-1041));\n pauseButton.setText(\"Pause\");\n panel1.add(pauseButton, new com.intellij.uiDesigner.core.GridConstraints(0, 1, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n startButton = new JButton();\n startButton.setBackground(new Color(-16316665));\n startButton.setForeground(new Color(-1041));\n startButton.setText(\"Start\");\n panel1.add(startButton, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n textArea1 = new JTextArea();\n textArea1.setBackground(new Color(-16316665));\n textArea1.setDisabledTextColor(new Color(-1041));\n textArea1.setEditable(false);\n textArea1.setForeground(new Color(-1041));\n panel1.add(textArea1, new com.intellij.uiDesigner.core.GridConstraints(0, 2, 1, 2, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n board = new JPanel();\n board.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n board.setBackground(new Color(-16316665));\n contentPane.add(board, new com.intellij.uiDesigner.core.GridConstraints(3, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n board.setBorder(BorderFactory.createTitledBorder(BorderFactory.createLineBorder(new Color(-1041)), null, TitledBorder.DEFAULT_JUSTIFICATION, TitledBorder.DEFAULT_POSITION, null, new Color(-16777216)));\n textArea2 = new JTextArea();\n textArea2.setBackground(new Color(-16316665));\n textArea2.setFont(new Font(textArea2.getFont().getName(), textArea2.getFont().getStyle(), 22));\n board.add(textArea2, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, null, new Dimension(150, 50), null, 0, false));\n }",
"private void $$$setupUI$$$() {\n contentPane = new JPanel();\n contentPane.setLayout(new GridLayoutManager(2, 1, new Insets(10, 10, 10, 10), -1, -1));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(panel1, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, 1, new Dimension(100, 20), new Dimension(100, 20), new Dimension(100, 20), 0, false));\n final Spacer spacer1 = new Spacer();\n panel1.add(spacer1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n final JPanel panel2 = new JPanel();\n panel2.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n panel1.add(panel2, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n buttonClose = new JButton();\n buttonClose.setText(\"Close\");\n panel2.add(buttonClose, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JPanel panel3 = new JPanel();\n panel3.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(panel3, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n messageLabel = new JLabel();\n messageLabel.setText(\"\");\n panel3.add(messageLabel, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n }",
"private void initPanelButtons() {\r\n\t\tthis.panelButtons = new JPanel(new GridBagLayout());\r\n\t\tthis.panelButtons.setBorder(BorderFactory.createEmptyBorder(10, 5, 0, 5));\r\n\t\tthis.panelButtons.setOpaque(false);\r\n\t\tGridBagConstraints gbc = new GridBagConstraints();\r\n\r\n\t\tgbc.gridx = 0;\r\n\t\tgbc.gridy = 0;\r\n\t\tgbc.gridwidth = 1;\r\n\t\tgbc.gridheight = 1;\r\n\t\tgbc.weightx = 1;\r\n\t\tgbc.weighty = 1;\r\n\t\tthis.returnButton.setBackground(ConstantView.COLOR_BUTTON_LOGIN);\r\n\t\tthis.returnButton.setForeground(Color.WHITE);\r\n\t\tthis.returnButton.setFocusable(false);\r\n\t\tthis.returnButton.setCursor(new Cursor(Cursor.HAND_CURSOR));\r\n\t\tthis.returnButton.setFont(ConstantView.FONT_PRINCIPAL_LABELS);\r\n\t\tthis.panelButtons.add(returnButton, gbc);\r\n\r\n\t\tgbc.gridx = 7;\r\n\t\tthis.okButton.setBackground(ConstantView.COLOR_BUTTON_LOGIN);\r\n\t\tthis.okButton.setForeground(Color.WHITE);\r\n\t\tthis.okButton.setFocusable(false);\r\n\t\tthis.okButton.setCursor(new Cursor(Cursor.HAND_CURSOR));\r\n\t\tthis.okButton.setFont(ConstantView.FONT_PRINCIPAL_LABELS);\r\n\t\tthis.okButton.addActionListener(ControlClient.getInstance());\r\n\t\tthis.okButton.setActionCommand(ClientCommands.OK_SIGN_IN.toString());\r\n\t\tthis.panelButtons.add(okButton, gbc);\r\n\t}",
"private void setupToolBar() {\n\t\tJPanel buttons = new JPanel(new GridBagLayout());\n\t\tGridBagConstraints c = new GridBagConstraints();\n\t\tc.fill = GridBagConstraints.HORIZONTAL;\n\t\ttoolBar = new JToolBar(\"Buttons\");\n\t\ttoolBar.setFloatable(false);\n\t\ttoolBar.setOrientation(SwingConstants.VERTICAL);\n\t\tbuttons.add(toolBar, c);\n\t\tadd(buttons, BorderLayout.EAST);\n\t}",
"private void init() {\n setBackground(LIGHT_GRAY);\n Box layout = new Box(BoxLayout.Y_AXIS);\n\n jump = createButton(\"Jump\", null);\n exit = createButton(\"Exit!\", null);\n fly = createButton(\"Fly\", null);\n Jfloat = createButton(\"Float\", null);\n layout.add(Box.createRigidArea(new Dimension(0, 150)));\n layout.add(jump);\n layout.add(Box.createRigidArea(new Dimension(0, 25)));\n layout.add(Jfloat);\n layout.add(Box.createRigidArea(new Dimension(0, 25)));\n layout.add(fly);\n layout.add(Box.createRigidArea(new Dimension(0, 25)));\n layout.add(exit);\n add(layout);\n }",
"private void $$$setupUI$$$() {\n adminSelectFunctionPanel = new JPanel();\n adminSelectFunctionPanel.setLayout(new GridLayoutManager(4, 3, new Insets(30, 30, 30, 30), 10, 30, true, false));\n adminSelectFunctionPanel.setBackground(new Color(-1));\n adminSelectFunctionPanel.setForeground(new Color(-1));\n adminSelectFunctionPanel.setMinimumSize(new Dimension(800, 600));\n adminSelectFunctionPanel.setPreferredSize(new Dimension(800, 600));\n changeATMBalanceButton = new JButton();\n changeATMBalanceButton.setBackground(new Color(-10592674));\n Font changeATMBalanceButtonFont = this.$$$getFont$$$(null, -1, 20, changeATMBalanceButton.getFont());\n if (changeATMBalanceButtonFont != null) changeATMBalanceButton.setFont(changeATMBalanceButtonFont);\n changeATMBalanceButton.setForeground(new Color(-1));\n changeATMBalanceButton.setText(\"Change ATM Balance\");\n adminSelectFunctionPanel.add(changeATMBalanceButton, new GridConstraints(2, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, null, new Dimension(150, 100), null, 0, false));\n changeLocaleButton = new JButton();\n changeLocaleButton.setBackground(new Color(-10592674));\n Font changeLocaleButtonFont = this.$$$getFont$$$(null, -1, 20, changeLocaleButton.getFont());\n if (changeLocaleButtonFont != null) changeLocaleButton.setFont(changeLocaleButtonFont);\n changeLocaleButton.setForeground(new Color(-1));\n changeLocaleButton.setText(\"Change Locale\");\n adminSelectFunctionPanel.add(changeLocaleButton, new GridConstraints(2, 2, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, null, new Dimension(150, 100), null, 0, false));\n addAdminButton = new JButton();\n addAdminButton.setBackground(new Color(-10592674));\n Font addAdminButtonFont = this.$$$getFont$$$(null, -1, 20, addAdminButton.getFont());\n if (addAdminButtonFont != null) addAdminButton.setFont(addAdminButtonFont);\n addAdminButton.setForeground(new Color(-1));\n addAdminButton.setText(\"Add Admin\");\n adminSelectFunctionPanel.add(addAdminButton, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_WANT_GROW, null, new Dimension(150, 100), null, 0, false));\n atmStateLabel = new JLabel();\n atmStateLabel.setBackground(new Color(-15024996));\n Font atmStateLabelFont = this.$$$getFont$$$(null, -1, 24, atmStateLabel.getFont());\n if (atmStateLabelFont != null) atmStateLabel.setFont(atmStateLabelFont);\n atmStateLabel.setForeground(new Color(-1));\n atmStateLabel.setHorizontalAlignment(0);\n atmStateLabel.setHorizontalTextPosition(0);\n atmStateLabel.setOpaque(true);\n atmStateLabel.setText(\"\");\n adminSelectFunctionPanel.add(atmStateLabel, new GridConstraints(0, 2, 1, 1, GridConstraints.ANCHOR_EAST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, new Dimension(100, -1), null, 0, false));\n removeAdminButton = new JButton();\n removeAdminButton.setBackground(new Color(-10592674));\n Font removeAdminButtonFont = this.$$$getFont$$$(null, -1, 20, removeAdminButton.getFont());\n if (removeAdminButtonFont != null) removeAdminButton.setFont(removeAdminButtonFont);\n removeAdminButton.setForeground(new Color(-1));\n removeAdminButton.setText(\"Remove Admin\");\n adminSelectFunctionPanel.add(removeAdminButton, new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, null, new Dimension(150, 100), null, 0, false));\n queryATMBalanceButton = new JButton();\n queryATMBalanceButton.setBackground(new Color(-10592674));\n Font queryATMBalanceButtonFont = this.$$$getFont$$$(null, -1, 20, queryATMBalanceButton.getFont());\n if (queryATMBalanceButtonFont != null) queryATMBalanceButton.setFont(queryATMBalanceButtonFont);\n queryATMBalanceButton.setForeground(new Color(-1));\n queryATMBalanceButton.setText(\"Query ATM Balance\");\n adminSelectFunctionPanel.add(queryATMBalanceButton, new GridConstraints(1, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, null, new Dimension(150, 100), null, 0, false));\n toggleStateButton = new JButton();\n toggleStateButton.setBackground(new Color(-10592674));\n Font toggleStateButtonFont = this.$$$getFont$$$(null, -1, 20, toggleStateButton.getFont());\n if (toggleStateButtonFont != null) toggleStateButton.setFont(toggleStateButtonFont);\n toggleStateButton.setForeground(new Color(-1));\n toggleStateButton.setText(\"Toggle State\");\n adminSelectFunctionPanel.add(toggleStateButton, new GridConstraints(1, 2, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, null, new Dimension(150, 100), null, 0, false));\n logoutButton = new JButton();\n logoutButton.setBackground(new Color(-10592674));\n Font logoutButtonFont = this.$$$getFont$$$(null, -1, 20, logoutButton.getFont());\n if (logoutButtonFont != null) logoutButton.setFont(logoutButtonFont);\n logoutButton.setForeground(new Color(-1));\n logoutButton.setText(\"Logout\");\n adminSelectFunctionPanel.add(logoutButton, new GridConstraints(3, 2, 1, 1, GridConstraints.ANCHOR_EAST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, new Dimension(150, 50), null, 0, false));\n }",
"private void setupUI() {\n\t\tpanel1 = new JPanel();\n\t\tpanel1.setLayout(new BorderLayout(0, 0));\n\t\tfinal JPanel panel2 = new JPanel();\n\t\tpanel2.setLayout(new FlowLayout(FlowLayout.LEFT, 2, 2));\n\t\tpanel2.setBackground(Color.BLACK);\n\t\tpanel2.setPreferredSize(new Dimension(800, 34));\n\t\tpanel1.add(panel2, BorderLayout.SOUTH);\n\t\tstopButton = new JButton();\n\t\tstopButton.setText(\"STOP\");\n\t\tstopButton.setPreferredSize(new Dimension(82, 30));\n\t\tpanel2.add(stopButton);\n\t\tclsButton = new JButton();\n\t\tclsButton.setPreferredSize(new Dimension(82, 30));\n\t\tclsButton.setText(\"CLS\");\n\t\tpanel2.add(clsButton);\n\t\trunButton = new JButton();\n\t\trunButton.setPreferredSize(new Dimension(82, 30));\n\t\trunButton.setText(\"RUN\");\n\t\tpanel2.add(runButton);\n\t\tcaretLabel = new JLabel();\n\t\tcaretLabel.setPreferredSize(new Dimension(82, 30));\n\t\tcaretLabel.setForeground(Color.pink);\n\t\tpanel2.add(caretLabel);\n\t\tmainTextArea = new ShellTextComponent(this);\n\t\tmainTextArea.setCaretColor(new Color(Colors.COLORS[14]));\n\t\tfinal JScrollPane scrollPane1 = new JScrollPane(mainTextArea);\n\n\t\tpanel1.add(scrollPane1, BorderLayout.CENTER);\n\t\tpanel1.setPreferredSize(new Dimension(800, 600));\n\t}",
"ButtonPanel() {\n setLayout(new GridLayout(0,3));\n setPreferredSize(new Dimension(1000,100));\n setVisible(true);\n setMaximumSize(new Dimension(1000,250));\n reservationButton = new JButton(\"Reservation View\");\n bookingButton = new JButton(\"Booking View\");\n searchButton = new JButton(\"Search View\");\n add(reservationButton);\n add(bookingButton);\n add(searchButton);\n \n }",
"private void setupPanels() {\n\t\tsplitPanel.addEast(east, Window.getClientWidth() / 5);\n\t\tsplitPanel.add(battleMatCanvasPanel);\n\t\tpanelsSetup = true;\n\t}",
"private JPanel setWestPanel() {\n westPanel = new JPanel();\n westPanel.setAlignmentX(Component.CENTER_ALIGNMENT);\n\n today = new JButton(\"Today\");\n newEvent = new JButton(\"New Event\");\n\n //creating another panel with default flow layout to have the \"<\" and \">\" buttons next to each other\n prevNextPanel = new JPanel();\n\n left = new JButton();\n right = new JButton();\n prevNextPanel.add(left);\n prevNextPanel.add(right);\n prevNextPanel.setMaximumSize(new Dimension(300, 50));\n prevNextPanel.setAlignmentX(CENTER_ALIGNMENT);\n prevNextPanel.setBackground(Color.WHITE);\n\n //attempt to \"beautify\" buttons with icons\n beautifyButtons();\n\n westPanel.setLayout(new BoxLayout(westPanel, Y_AXIS));\n westPanel.setBackground(Color.WHITE);\n\n //dont know of a better way to create empty space between the title of panel and next container\n westPanel.add(Box.createRigidArea(new Dimension(WEST_WIDTH, 20)));\n westPanel.add(today);\n westPanel.add(prevNextPanel);\n westPanel.add(newEvent);\n westPanel.add(Box.createRigidArea(new Dimension(WEST_WIDTH, 20)));\n westPanel.add(addEventTypeMap());\n\n //adding action listened to \"Today\" to update the main display\n today.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n statusLabel.setText(String.format(status, today.getText()));\n date = dayViewComponent.setCurrentDate(LocalDate.now());\n updateDateDisplay();\n }\n });\n\n //adding action listened to \"<\" to update the main display\n left.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n statusLabel.setText(String.format(status, \"Left\"));\n date = dayViewComponent.updateDate(isDayViewSelected(), false);\n updateDateDisplay();\n }\n });\n\n //adding action listened to \">\" to update the main display\n right.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n statusLabel.setText(String.format(status, \"Right\"));\n date = dayViewComponent.updateDate(isDayViewSelected(), true);\n updateDateDisplay();\n }\n });\n\n //adding action listened to \"New event\" to update the main display\n newEvent.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n statusLabel.setText(String.format(status, newEvent.getText()));\n new NewEventDialogue(dayViewComponent);\n }\n });\n\n\n return westPanel;\n }",
"private void init(){\r\n\t\tsetLayout(new FlowLayout());\r\n\t\tsetPreferredSize(new Dimension(40,40));\r\n\t\tsetVisible(true);\r\n\t}",
"public void initComponents()\n {\n \n \n \n button1.setPreferredSize(new Dimension(100,100));\n button2.setPreferredSize(button2.getPreferredSize());\n \n panel1.setComponentOrientation(ComponentOrientation.LEFT_TO_RIGHT);\n panel1.add(button1);\n panel1.add(button2);\n panel1.add(button3);\n panel1.add(button4);\n this.getContentPane().add(panel1, BorderLayout.PAGE_START);\n \n }",
"private void setupPanel()\n\t{\n\t\tsetLayout(numberLayout);\n\t\tsetBorder(new EtchedBorder(EtchedBorder.RAISED, Color.GRAY, Color.DARK_GRAY));\n\t\tsetBackground(Color.LIGHT_GRAY);\n\t\tadd(ans);\n\t\tadd(clear);\n\t\tadd(backspace);\n\t\tadd(divide);\n\t\tadd(seven);\n\t\tadd(eight);\n\t\tadd(nine);\n\t\tadd(multiply);\n\t\tadd(four);\n\t\tadd(five);\n\t\tadd(six);\n\t\tadd(subtract);\n\t\tadd(one);\n\t\tadd(two);\n\t\tadd(three);\n\t\tadd(add);\n\t\tadd(negative);\n\t\tadd(zero);\n\t\tadd(point);\n\t\tadd(equals);\n\t}",
"private void setPanel()\r\n\t{\r\n\t\tpanel = new JPanel();\r\n\t\tpanel.setLayout(new GridLayout(5, 2));\r\n\t\t\r\n\t\tpanel.add(bubbleL);\r\n\t\tpanel.add(bubblePB);\r\n\t\t\r\n\t\tpanel.add(insertionL);\r\n\t\tpanel.add(insertionPB);\r\n\t\t\r\n\t\tpanel.add(mergeL);\r\n\t\tpanel.add(mergePB);\r\n\t\t\r\n\t\tpanel.add(quickL);\r\n\t\tpanel.add(quickPB);\r\n\t\t\r\n\t\tpanel.add(radixL);\r\n\t\tpanel.add(radixPB);\r\n\t}",
"public ActionButtonPanel() {\n\t\tthis.setBackground(new Color(33, 162, 246));\n\t\tthis.setLayout(new FlowLayout());\n\t\t\n\t\tmoveShepherdButton = new ActionButton(new ImageIcon(Default.moveShepherdButtonUrl));\n\t\tmoveSheepButton = new ActionButton(new ImageIcon(Default.moveSheepButtonUrl));\n\t\tcoupleButton = new ActionButton(new ImageIcon(Default.coupleButtonUrl));\n\t\tcoupleSheepsButton = new ActionButton(new ImageIcon(Default.coupleSheepsButtonUrl));\n\t\tkillButton = new ActionButton(new ImageIcon(Default.killButtonUrl));\n\t\tbuyCardButton = new ActionButton(new ImageIcon(Default.buyCardButtonUrl));\n\t\t\n\t\tthis.add(moveShepherdButton);\n\t\tthis.add(moveSheepButton);\n\t\tthis.add(coupleButton);\n\t\tthis.add(coupleSheepsButton);\n\t\tthis.add(killButton);\n\t\tthis.add(buyCardButton);\n\t\t\n\t\tmoveShepherdButton.setEnabled(false);\n\t\tmoveSheepButton.setEnabled(false);\n\t\tcoupleButton.setEnabled(false);\n\t\tcoupleSheepsButton.setEnabled(false);\n\t\tkillButton.setEnabled(false);\n\t\tbuyCardButton.setEnabled(false);\n\t}",
"private void initUI() {\n\t\tthis.horizontalLayout = new XdevHorizontalLayout();\n\t\tthis.gridLayout = new XdevGridLayout();\n\t\tthis.button = new XdevButton();\n\t\tthis.button2 = new XdevButton();\n\t\tthis.label = new XdevLabel();\n\n\t\tthis.button.setCaption(\"go to HashdemoView\");\n\t\tthis.button2.setCaption(\"go to CommonView\");\n\t\tthis.label.setValue(\"Go into code tab to view comments\");\n\n\t\tthis.gridLayout.setColumns(2);\n\t\tthis.gridLayout.setRows(2);\n\t\tthis.button.setWidth(200, Unit.PIXELS);\n\t\tthis.button.setHeight(-1, Unit.PIXELS);\n\t\tthis.gridLayout.addComponent(this.button, 0, 0);\n\t\tthis.button2.setWidth(200, Unit.PIXELS);\n\t\tthis.button2.setHeight(-1, Unit.PIXELS);\n\t\tthis.gridLayout.addComponent(this.button2, 1, 0);\n\t\tthis.label.setWidth(100, Unit.PERCENTAGE);\n\t\tthis.label.setHeight(-1, Unit.PIXELS);\n\t\tthis.gridLayout.addComponent(this.label, 0, 1, 1, 1);\n\t\tthis.gridLayout.setComponentAlignment(this.label, Alignment.TOP_CENTER);\n\t\tthis.gridLayout.setSizeUndefined();\n\t\tthis.horizontalLayout.addComponent(this.gridLayout);\n\t\tthis.horizontalLayout.setComponentAlignment(this.gridLayout, Alignment.MIDDLE_CENTER);\n\t\tthis.horizontalLayout.setExpandRatio(this.gridLayout, 10.0F);\n\t\tthis.horizontalLayout.setSizeFull();\n\t\tthis.setContent(this.horizontalLayout);\n\t\tthis.setSizeFull();\n\n\t\tthis.button.addClickListener(event -> this.button_buttonClick(event));\n\t\tthis.button2.addClickListener(event -> this.button2_buttonClick(event));\n\t}",
"private void setupSettings() {\n add(announcementBtn).expandX().width(ChessGame.MENU_WIDTH);\n row();\n add(currentGamesBtn).expandX().width(ChessGame.MENU_WIDTH);\n row();\n add(chatRoomBtn).expandX().width(ChessGame.MENU_WIDTH);\n row();\n add(friendsListBtn).expandX().width(ChessGame.MENU_WIDTH);\n row();\n add(leaderboardBtn).expandX().width(ChessGame.MENU_WIDTH);\n row();\n }",
"private void $$$setupUI$$$() {\n createUIComponents();\n contentPane = new JPanel();\n contentPane.setLayout(new GridLayoutManager(2, 1, new Insets(10, 10, 10, 10), -1, -1));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(panel1, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, 1, null, null, null, 0, false));\n final Spacer spacer1 = new Spacer();\n panel1.add(spacer1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n final JPanel panel2 = new JPanel();\n panel2.setLayout(new GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1, true, false));\n panel1.add(panel2, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n buttonOK = new JButton();\n buttonOK.setText(\"OK\");\n panel2.add(buttonOK, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n buttonCancel = new JButton();\n buttonCancel.setText(\"Cancel\");\n panel2.add(buttonCancel, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JPanel panel3 = new JPanel();\n panel3.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(panel3, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n pan1 = new JPanel();\n pan1.setLayout(new GridLayoutManager(4, 3, new Insets(0, 0, 0, 0), -1, -1));\n panel3.add(pan1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n final JLabel label1 = new JLabel();\n label1.setText(\"Название номера\");\n pan1.add(label1, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JLabel label2 = new JLabel();\n label2.setText(\"Дата регистрации\");\n pan1.add(label2, new GridConstraints(1, 1, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JLabel label3 = new JLabel();\n label3.setText(\"Дата истечения\");\n pan1.add(label3, new GridConstraints(2, 1, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_VERTICAL, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final Spacer spacer2 = new Spacer();\n pan1.add(spacer2, new GridConstraints(3, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_VERTICAL, 1, GridConstraints.SIZEPOLICY_WANT_GROW, new Dimension(0, 25), new Dimension(0, 25), new Dimension(0, 25), 0, false));\n number = new JTextField();\n pan1.add(number, new GridConstraints(0, 2, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_FIXED, null, new Dimension(150, -1), null, 0, false));\n pan1.add(creationDatePanel, new GridConstraints(1, 2, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n pan1.add(expirationDatePanel, new GridConstraints(2, 2, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n }",
"private DisplayPanel(){\r\n\t\t\t\tControlActionListenter cal = new ControlActionListenter();\r\n\t\t\t\tsetLayout(new BorderLayout());\r\n\t\t\t\tfinal JButton btn1 = new JButton(\"First\");\r\n\t\t\t\tbtn1.setFocusable(false);\r\n \t \tbtn1.addActionListener(cal);\r\n \t\t\tfinal JButton btn2 = new JButton(\"Next\");\r\n \t\t\tbtn2.addActionListener(cal);\r\n \t\t\t\tfinal JButton btn3 = new JButton(\"Previous\");\r\n \t\t \tbtn3.addActionListener(cal);\r\n \t\t final JButton btn4 = new JButton(\"Last\");\r\n \t\tbtn4.addActionListener(cal);\r\n \t\tbtn2.setFocusable(false);\r\n \t\tbtn3.setFocusable(false);\r\n \t\tbtn4.setFocusable(false);\r\n \t\t \tJPanel controlButtons = new JPanel(new GridLayout(2,2,5,5));\r\n \t\t \tcontrolButtons.add(btn3);\r\n \t\t \tcontrolButtons.add(btn2);\r\n \t\t \tcontrolButtons.add(btn1);\r\n \t\tcontrolButtons.add(btn4);\r\n \t\tcontrolButtons.setBorder(BorderFactory.createEmptyBorder(10, 10, 10, 10));\r\n \t\tadd(controlButtons, BorderLayout.PAGE_END);\r\n\t\t\t}",
"private void setUpPanel() { \n this.setPreferredSize(new Dimension(myWidth, myHeight)); \n // Set this panel as a grid panel with 1 column, 6 rows. \n this.setLayout(new GridLayout(NUM_ROWS, 1)); \n // Create the next piece panel.\n this.myNextPiece = new TetrisNextPiecePanel();\n this.add(myNextPiece); \n // Add another panel which will show game instruction.\n final HowToPlayPanel instructionsPanel = new HowToPlayPanel();\n this.add(instructionsPanel);\n // add the last panel which will show the scores, level, game state etc.\n this.setUpLastPanel();\n }",
"private void $$$setupUI$$$() {\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n }",
"private void $$$setupUI$$$() {\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n }",
"private void init() {\n setLayout(new BorderLayout());\n setBackground(ProgramPresets.COLOR_BACKGROUND);\n add(getTitlePanel(), BorderLayout.NORTH);\n add(getTextPanel(), BorderLayout.CENTER);\n add(getLinkPanel(), BorderLayout.SOUTH);\n }",
"public ButtonBar() {\n scrollPane = new JScrollPane();\n scrollPane.setBorder(null);\n scrollPane.setHorizontalScrollBarPolicy(ScrollPaneConstants\n .HORIZONTAL_SCROLLBAR_NEVER);\n scrollPane.setVerticalScrollBarPolicy(ScrollPaneConstants\n .VERTICAL_SCROLLBAR_AS_NEEDED);\n scrollPane.setMinimumSize(new Dimension(0,buttonHeight\n + ((int) PlatformDefaults.getUnitValueX(\"related\").getValue()) * 2));\n \n buttons = Collections.synchronizedMap(new TreeMap<FrameContainer<?>,\n JToggleButton>(new FrameContainerComparator()));\n position = FramemanagerPosition.getPosition(\n IdentityManager.getGlobalConfig().getOption(\"ui\",\n \"framemanagerPosition\"));\n \n if (position.isHorizontal()) {\n buttonPanel = new ButtonPanel(new MigLayout(\"ins rel, fill, flowx\"),\n this);\n } else {\n buttonPanel = new ButtonPanel(new MigLayout(\"ins rel, fill, flowy\"),\n this);\n }\n scrollPane.getViewport().add(buttonPanel);\n }",
"public RepalyPanel() {\n\t\t\ttry {\n//\t\t\t\tthis.addMouseListener(new MouseAdapter() {\n//\t\t\t\t\t@Override\n//\t\t\t\t\tpublic void mouseClicked(MouseEvent e) {\n//\t\t\t\t\t\tSystem.out.println(e.getX() + \" \" + e.getY());\n//\t\t\t\t\t}\n//\t\t\t\t});\n\n\t\t\t\tsetLayout(null);\n\n\t\t\t\t// 退出按键\n\t\t\t\tjbRestart = MyButton.makeButton(restart, restart_down,\n\t\t\t\t\t\trestart_hover);\n\t\t\t\tadd(jbRestart);\n\t\t\t\tjbRestart.setBounds(540, 355, 140, 56);\n\t\t\t\tjbRestart.addActionListener(this);\n\n\t\t\t\t// 确认退出按键\n\t\t\t\tjbContinue = MyButton.makeButton(continue_pic, continue_down,\n\t\t\t\t\t\tcontinue_hover);\n\t\t\t\tadd(jbContinue);\n\t\t\t\tjbContinue.setBounds(345, 355, 140, 56);\n\t\t\t\tjbContinue.addActionListener(this);\n\t\t\t} catch (IOException e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t}",
"private void setupToDoPanel() {\n\t\tpnlToDo = new JPanel(new GridBagLayout());\n\t\tgc.fill = GridBagConstraints.HORIZONTAL;\n\t\tgc.anchor = GridBagConstraints.CENTER;\n\t\tgc.insets = new Insets(10, 10, 10, 10);\n\t\tgc.gridx = 0;\n\t\tfor (int i = 0; i < txtTodo.size(); i++) {\n\t\t\tgc.gridy = i;\n\t\t\tpnlToDo.add(txtTodo.get(i), gc);\n\t\t}\n\t\tgc.gridx = 1;\n\t\tfor (int i = 0; i < check.size(); i++) {\n\t\t\tgc.gridy = i;\n\t\t\tpnlToDo.add(check.get(i), gc);\n\t\t}\n\t\tscroll = new JScrollPane(pnlToDo);\n\n\t\tpnlButton = new JPanel();\n\t\tpnlButton.setLayout(new BoxLayout(pnlButton, BoxLayout.X_AXIS));\n\t\tpnlButton.add(Box.createHorizontalGlue());\n\t\tpnlButton.add(btnAddTask);\n\t\tpnlButton.add(Box.createRigidArea(new Dimension(5, 0)));\n\t\tpnlButton.add(btnSave);\n\t\tpnlButton.add(Box.createHorizontalGlue());\n\t}",
"public void initPanel()\n\t{\n\t\tthis.setVisible(false);\n\t\t//this.setLayout(new BorderLayout());\n \n\t\t//*Layout setup\n\t\t\n\t\tGroupLayout layout = new GroupLayout(this);\n\t\t//this.setLayout(layout);\n\n\t\tlayout.setAutoCreateGaps(true);\n\t\tlayout.setAutoCreateContainerGaps(true);\t\t\n\t\t\t\t\n\t\t//frame = new JFrame();\n offscreenImage = new BufferedImage(width, height, BufferedImage.TYPE_INT_ARGB);\n onscreenImage = new BufferedImage(width, height, BufferedImage.TYPE_INT_ARGB);\n offscreen = offscreenImage.createGraphics();\n onscreen = onscreenImage.createGraphics();\n setXscale();\n setXscale();\n offscreen.setColor(DEFAULT_CLEAR_COLOR);\n offscreen.fillRect(0, 0, width, height);\n setPenColor();\n setPenRadius();\n setFont();\n clear();\n\n // add antialiasing\n RenderingHints hints = new RenderingHints(RenderingHints.KEY_ANTIALIASING,\n RenderingHints.VALUE_ANTIALIAS_ON);\n hints.put(RenderingHints.KEY_RENDERING, RenderingHints.VALUE_RENDER_QUALITY);\n offscreen.addRenderingHints(hints);\n\n \n // frame stuff\n ImageIcon icon = new ImageIcon(onscreenImage);\n drawLabel = new JLabel(icon);\n\n drawLabel.addMouseListener(this);\n drawLabel.addMouseMotionListener(this);\n \n //Create buttons\n resetButton = new JButton();\n undoButton = new JButton();\n \n undoButton.setVisible(true);\n undoButton.setEnabled(true);\n undoButton.setName(\"Undo\");\n undoButton.setText(\"Undo\");\n undoButton.setSize(75, 30);\n undoButton.setPreferredSize(new Dimension(75,30));\n \n resetButton.setVisible(true);\n resetButton.setEnabled(true);\n resetButton.setName(\"Reset\");\n resetButton.setText(\"Reset\");\n \tresetButton.setSize(75, 30);\n \tresetButton.setPreferredSize(new Dimension(75,30));\n \t\n //this.add(resetButton, BorderLayout.NORTH);\n //this.add(undoButton, BorderLayout.NORTH);\n \n // JPanel mainPanel = new JPanel(new BorderLayout());\n\n // JPanel northPanel = new JPanel();\n // northPanel.add(resetButton);\n // northPanel.add(undoButton);\n // mainPanel.add(northPanel, BorderLayout.NORTH);\n // mainPanel.add(drawLabel, BorderLayout.CENTER);\n \n\n // generalColorValue = getColorParameter(Skin.GENERAL_TEXT_COLOR); \n //controlColorValue = getColorParameter(Skin.CONTROL_BACKGROUND_COLOR); \n \n\t\t//trimColorValue = getColorParameter(Skin.TRIM_COLOR); \n\t \n\t\tinitComboBox();\n\t\t//this.setContentPane(drawLabel); <---------------------------\n this.add(drawLabel, BorderLayout.CENTER);\n \n this.addKeyListener(this); // JLabel cannot get keyboard focus\n this.setResizable(true);\n this.setDefaultCloseOperation(JFrame.EXIT_ON_CLOSE); // closes all windows\n //this.setDefaultCloseOperation(JFrame.DISPOSE_ON_CLOSE); // closes only current window\n this.setTitle(name);\n // frame.setJMenuBar(createMenuBar());\n this.pack();\n this.requestFocusInWindow();\n this.setVisible(true);\n \n\t}",
"private void $$$setupUI$$$() {\n contentPane = new JPanel();\n contentPane.setLayout(new GridLayoutManager(2, 1, new Insets(10, 10, 10, 10), -1, -1));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(panel1, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, 1, null, null, null, 0, false));\n final JPanel panel2 = new JPanel();\n panel2.setLayout(new GridLayoutManager(3, 1, new Insets(0, 0, 0, 0), -1, -1));\n panel1.add(panel2, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n memberImportTagButton = new JButton();\n Font memberImportTagButtonFont = this.$$$getFont$$$(null, Font.PLAIN, -1, memberImportTagButton.getFont());\n if (memberImportTagButtonFont != null) memberImportTagButton.setFont(memberImportTagButtonFont);\n memberImportTagButton.setText(\"导入选择的标签分组-取并集\");\n panel2.add(memberImportTagButton, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n memberImportTagRetainButton = new JButton();\n Font memberImportTagRetainButtonFont = this.$$$getFont$$$(null, Font.PLAIN, -1, memberImportTagRetainButton.getFont());\n if (memberImportTagRetainButtonFont != null)\n memberImportTagRetainButton.setFont(memberImportTagRetainButtonFont);\n memberImportTagRetainButton.setText(\"导入选择的标签分组-取交集\");\n panel2.add(memberImportTagRetainButton, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n memberImportAllButton = new JButton();\n Font memberImportAllButtonFont = this.$$$getFont$$$(null, Font.PLAIN, -1, memberImportAllButton.getFont());\n if (memberImportAllButtonFont != null) memberImportAllButton.setFont(memberImportAllButtonFont);\n memberImportAllButton.setText(\"导入所有关注公众号的用户\");\n panel2.add(memberImportAllButton, new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n final JPanel panel3 = new JPanel();\n panel3.setLayout(new GridLayoutManager(2, 3, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(panel3, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n importOptionPanel = new JPanel();\n importOptionPanel.setLayout(new GridLayoutManager(1, 5, new Insets(0, 0, 0, 0), -1, -1));\n panel3.add(importOptionPanel, new GridConstraints(1, 0, 1, 3, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n importOptionOpenIdCheckBox = new JCheckBox();\n importOptionOpenIdCheckBox.setEnabled(false);\n importOptionOpenIdCheckBox.setSelected(true);\n importOptionOpenIdCheckBox.setText(\"openId\");\n importOptionPanel.add(importOptionOpenIdCheckBox, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final Spacer spacer1 = new Spacer();\n importOptionPanel.add(spacer1, new GridConstraints(0, 4, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n importOptionBasicInfoCheckBox = new JCheckBox();\n importOptionBasicInfoCheckBox.setText(\"昵称、性别等基本信息\");\n importOptionBasicInfoCheckBox.setToolTipText(\"每获取一条信息会花费一次每日接口调用量\");\n importOptionPanel.add(importOptionBasicInfoCheckBox, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n importOptionAvatarCheckBox = new JCheckBox();\n importOptionAvatarCheckBox.setText(\"头像\");\n importOptionAvatarCheckBox.setToolTipText(\"勾选会导致左侧列表甚至WePush变卡哦\");\n importOptionPanel.add(importOptionAvatarCheckBox, new GridConstraints(0, 2, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n clearDbCacheButton = new JButton();\n clearDbCacheButton.setText(\"清空本地缓存\");\n importOptionPanel.add(clearDbCacheButton, new GridConstraints(0, 3, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n memberImportTagComboBox = new JComboBox();\n final DefaultComboBoxModel defaultComboBoxModel1 = new DefaultComboBoxModel();\n memberImportTagComboBox.setModel(defaultComboBoxModel1);\n panel3.add(memberImportTagComboBox, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n memberImportTagFreshButton = new JButton();\n Font memberImportTagFreshButtonFont = this.$$$getFont$$$(null, Font.PLAIN, -1, memberImportTagFreshButton.getFont());\n if (memberImportTagFreshButtonFont != null) memberImportTagFreshButton.setFont(memberImportTagFreshButtonFont);\n memberImportTagFreshButton.setText(\"刷新\");\n panel3.add(memberImportTagFreshButton, new GridConstraints(0, 2, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, 1, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JLabel label1 = new JLabel();\n label1.setText(\"标签分组\");\n panel3.add(label1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n }",
"private void $$$setupUI$$$() {\n createUIComponents();\n panel = new JPanel();\n panel.setLayout(new GridLayoutManager(2, 1, new Insets(10, 10, 10, 10), -1, -1));\n final JScrollPane scrollPane1 = new JScrollPane();\n panel.add(scrollPane1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n scrollPane1.setViewportView(table);\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(1, 3, new Insets(0, 0, 0, 0), -1, -1));\n panel.add(panel1, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n buttonRegister = new JButton();\n buttonRegister.setText(\"Track\");\n panel1.add(buttonRegister, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n buttonMenu = new JButton();\n buttonMenu.setText(\"Menu\");\n panel1.add(buttonMenu, new GridConstraints(0, 2, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final Spacer spacer1 = new Spacer();\n panel1.add(spacer1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n }",
"public void initializeButtons() {\n\t\tif(null!=itemPanel)\n\t\t\tremove(itemPanel);\n\t\t\n\t\titemPanel = new JPanel();\n\t\titemPanel.setLayout(new FlowLayout());\n\t\tList<Item> allItems = itemDao.readAll();\n\t\t\n\t\t//Sort list of items based on item code.\n\t\tCollections.sort(allItems, new Comparator<Item>() {\n\t\t\t@Override\n\t\t\tpublic int compare(Item o1, Item o2) {\n\t\t\t\tCharacter c1 = o1.getCode();\n\t\t\t\tCharacter c2 = o2.getCode();\n\t\t\t\treturn c1.compareTo(c2);\n\t\t\t}\n\t\t});\n\t\t\n\t\tfor(final Item item : allItems){\n\t\t\tJButton addButton = new JButton(item.getName());\n\t\t\tDeal deal = item.getDeal();\n\t\t\tString dealName = deal == null ? \"\" : \"<br>\" + deal.getName();\n\t\t\t//Set tool tip as description and deal if available\n\t\t\taddButton.setToolTipText(\"<html>\"+item.getDescription()+\"<br>Price: $\"+item.getPrice()\n\t\t\t\t\t+ dealName+\"</html>\");\n\t\t\t//Add item to cart when pressed, also update cartLabel.\n\t\t\taddButton.addActionListener(new ActionListener() {\n\t\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\t\tcart.addItem(item.getCode());\n\t\t\t\t\tcartLabel.setText(cart.size()+ \" items in your cart\");\n\t\t\t\t}\n\t\t\t});\n\t\t\t//addButton.setBounds(10, frameHeight, 75, 20);\n\t\t\taddButton.setSize(new Dimension(75, 20));\n\t\t\titemPanel.add(addButton);\n\t\t}\n\t\t\n\t\titemPanel.setBounds(10, 30, 280, 150);\n\t\tadd(itemPanel);\n\t\tMain.getFrame().setVisible(true);;\n\t}",
"private void $$$setupUI$$$() {\n mainPanel = new JPanel();\n mainPanel.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(5, 1, new Insets(0, 0, 0, 0), -1, -1));\n mainPanel.add(panel1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n servicesButton = new JButton();\n servicesButton.setText(\"Services management\");\n panel1.add(servicesButton, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n surveysManagementButton = new JButton();\n surveysManagementButton.setText(\"Surveys management\");\n panel1.add(surveysManagementButton, new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n connectingAndResultsButton = new JButton();\n connectingAndResultsButton.setText(\"Conecting surveys to services\");\n panel1.add(connectingAndResultsButton, new GridConstraints(3, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JLabel label1 = new JLabel();\n label1.setText(\"Choose option below\");\n panel1.add(label1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n results = new JButton();\n results.setText(\"Browse the results\");\n panel1.add(results, new GridConstraints(4, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n }",
"private void $$$setupUI$$$() {\n contentPane = new JPanel();\n contentPane.setLayout(new GridLayoutManager(2, 1, new Insets(10, 10, 10, 10), -1, -1));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(panel1, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, 1, null, null, null, 0, false));\n final Spacer spacer1 = new Spacer();\n panel1.add(spacer1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n final JPanel panel2 = new JPanel();\n panel2.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n panel1.add(panel2, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n buttonOK = new JButton();\n buttonOK.setText(\"OK\");\n panel2.add(buttonOK, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n content = new JPanel();\n content.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(content, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n tabbedPane1 = new JTabbedPane();\n content.add(tabbedPane1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, new Dimension(200, 200), null, 0, false));\n Gesture = new JPanel();\n Gesture.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n tabbedPane1.addTab(\"Gesture\", Gesture);\n final JLabel label1 = new JLabel();\n label1.setIcon(new ImageIcon(getClass().getResource(\"/reference/by_gesture.png\")));\n label1.setText(\"\");\n Gesture.add(label1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n }",
"private void setupLayout()\n {\n Container contentPane;\n\n setSize(300, 300); \n\n contentPane = getContentPane();\n\n // Layout this PINPadWindow\n }",
"@Override\n public void setupPanel()\n {\n\n }",
"private void initUI() {\n\t\tPanel p = new Panel();\n\t\tp.setLayout(new BorderLayout());\n\t\t\n\t\tPanel flowLayoutPanel = new Panel();\n\t\tflowLayoutPanel.setLayout(new FlowLayout());\n\t\t\n\t\ttextArea = new JTextArea();\n\t\t\n\t\tMyCloseButton exitButton = new MyCloseButton(\"Exit\");\n\t\t/*\n\t\texit.addActionListener(new ActionListener(){\n\n\t\t\t@Override\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tSystem.exit(0);\n\t\t\t}\n\t\t\t\t\t\n\t\t});\n\t\t*/\n\t\tMyOpenButton saveButton = new MyOpenButton(\"Open\");\n\t\t/*\n\t\tsaveButton.addActionListener(new ActionListener(){\n\n\t\t\t@Override\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tSystem.exit(0);\n\t\t\t}\n\t\t\n\t\t});\n\t\t*/\n\t\tMySaveButton mySaveButton =new MySaveButton(\"Save\");\n\t\t//setVisible(mb);\n\t\tp.add(flowLayoutPanel, BorderLayout.SOUTH);\n\t\tflowLayoutPanel.add(exitButton);\n\t\tflowLayoutPanel.add(saveButton);\n\t\tflowLayoutPanel.add(mySaveButton);\n\t\tp.add(textArea, BorderLayout.CENTER); \n\t\tadd(p);\n\t\t\n\t\tcreateMenu();\n\t\t\n\t\tsetTitle(\"Text Editor\");\n\t\tsetSize(600, 600);\n\t\tsetLocationRelativeTo(null);\n\t\tsetDefaultCloseOperation(EXIT_ON_CLOSE);\n\t\t\n\t}",
"private void init() {\r\n\t\tthis.setBackground(Color.decode(\"#c5dfed\"));\r\n\r\n\t\tthis.initPanelButtons();\r\n\r\n\t\tUtilityClass.addBorder(this, 20, 20, 20, 20);\r\n\t\t\r\n\t\tthis.title.setFont(ConstantView.FONT_TITLE_CRUD);\r\n\t\tthis.title.setHorizontalAlignment(JLabel.CENTER);\r\n\t\tthis.add(title, BorderLayout.NORTH);\r\n\t\t\r\n\t\tthis.add(panelButtons, BorderLayout.SOUTH);\r\n\t\tthis.jPanelFormClient.setOpaque(false);\r\n\t\tthis.add(jPanelFormClient, BorderLayout.CENTER);\r\n\t}",
"private void $$$setupUI$$$() {\n createUIComponents();\n contentPane = new JPanel();\n contentPane.setLayout(new GridLayoutManager(2, 1, new Insets(10, 10, 10, 10), -1, -1));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(panel1, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, 1, null, null, null, 0, false));\n final Spacer spacer1 = new Spacer();\n panel1.add(spacer1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n final JPanel panel2 = new JPanel();\n panel2.setLayout(new GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1));\n panel1.add(panel2, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n buttonOK = new JButton();\n buttonOK.setText(\"OK\");\n panel2.add(buttonOK, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n buttonCancel = new JButton();\n this.$$$loadButtonText$$$(buttonCancel, ResourceBundle.getBundle(\"strings\").getString(\"cancel\"));\n panel2.add(buttonCancel, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JPanel panel3 = new JPanel();\n panel3.setLayout(new GridLayoutManager(2, 2, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(panel3, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n final JLabel label1 = new JLabel();\n this.$$$loadLabelText$$$(label1, ResourceBundle.getBundle(\"strings\").getString(\"resource-name\"));\n panel3.add(label1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n nameField = new JTextField();\n panel3.add(nameField, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_FIXED, null, new Dimension(150, -1), null, 0, false));\n final JLabel label2 = new JLabel();\n this.$$$loadLabelText$$$(label2, ResourceBundle.getBundle(\"strings\").getString(\"resource-availability\"));\n panel3.add(label2, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JScrollPane scrollPane1 = new JScrollPane();\n panel3.add(scrollPane1, new GridConstraints(1, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n scrollPane1.setViewportView(availabilitiesList);\n label1.setLabelFor(nameField);\n }",
"public void layoutTop() {\n\t\tJPanel top = new JPanel();\n\t\tcloseButton = new JButton(\"Save and Exit\");\n\t\tcloseButton.addActionListener(this);\n\t\ttop.add(closeButton);\n\t\tattendanceButton = new JButton(\"View Attendances\");\n\t\tattendanceButton.addActionListener(this);\n\t\ttop.add(attendanceButton);\n\t\tadd(top, BorderLayout.NORTH);\n\t}",
"private void setLayout() {\n\tHorizontalLayout main = new HorizontalLayout();\n\tmain.setMargin(true);\n\tmain.setSpacing(true);\n\n\t// vertically divide the right area\n\tVerticalLayout left = new VerticalLayout();\n\tleft.setSpacing(true);\n\tmain.addComponent(left);\n\n\tleft.addComponent(openProdManager);\n\topenProdManager.addListener(new Button.ClickListener() {\n\t public void buttonClick(ClickEvent event) {\n\t\tCustomerWindow productManagerWin = new CustomerWindow(CollectorManagerApplication.this);\n\t\tproductManagerWin.addListener(new Window.CloseListener() {\n\t\t public void windowClose(CloseEvent e) {\n\t\t\topenProdManager.setEnabled(true);\n\t\t }\n\t\t});\n\n\t\tCollectorManagerApplication.this.getMainWindow().addWindow(productManagerWin);\n\t\topenProdManager.setEnabled(false);\n\t }\n\t});\n\n\t\n\tsetMainWindow(new Window(\"Sistema de Cobranzas\", main));\n\n }",
"private void initUI() {\r\n\t\t//Äußeres Panel\r\n\t\tContainer pane = getContentPane();\r\n\t\tGroupLayout gl = new GroupLayout(pane);\r\n\t\tpane.setLayout(gl);\r\n\t\t//Abstende von den Containern und dem äußeren Rand\r\n\t\tgl.setAutoCreateContainerGaps(true);\r\n\t\tgl.setAutoCreateGaps(true);\r\n\t\t//TextFeld für die Ausgabe\r\n\t\tJTextField output = view.getTextField();\r\n\t\t//Die jeweiligen Panels für die jeweiigen Buttons\r\n\t\tJPanel brackets = view.getBracketPanel();\r\n\t\tJPanel remove = view.getTop2Panel();\r\n\t\tJPanel numbers = view.getNumbersPanel();\r\n\t\tJPanel last = view.getBottomPanel();\r\n\t\t//Anordnung der jeweiligen Panels durch den Layout Manager\r\n\t\tgl.setHorizontalGroup(gl.createParallelGroup().addComponent(output).addComponent(brackets).addComponent(remove).addComponent(numbers).addComponent(last));\r\n\t\tgl.setVerticalGroup(gl.createSequentialGroup().addComponent(output).addComponent(brackets).addComponent(remove).addComponent(numbers).addComponent(last));\r\n\t\tpack();\r\n\t\tsetTitle(\"Basic - Taschenrechner\");\r\n\t\tsetDefaultCloseOperation(EXIT_ON_CLOSE);\r\n\t\tsetResizable(false);\r\n\t}",
"private void createButtonsPanel() {\r\n Composite buttonsPanel = new Composite(this, SWT.NONE);\r\n buttonsPanel.setLayoutData(new GridData(SWT.FILL, SWT.FILL, true, false));\r\n buttonsPanel.setLayout(new GridLayout(4, true));\r\n\r\n getButtonFromAction(buttonsPanel, \"New\", new NewAction(_window));\r\n getButtonFromAction(buttonsPanel, \"Save\", new SaveAction());\r\n getButtonFromAction(buttonsPanel, \"Delete\", new DeleteAction(_window));\r\n getButtonFromAction(buttonsPanel, \"Cancel\", new CancelAction());\r\n }",
"private void setUpAllButtons() {\n\t\t\n\t\tGridLayout leftSideGridLayout = new GridLayout(9,1);\n\t\tleftSideGridLayout.setVgap(20);\n\t\t\n\t\tleftSideOfGUI.setLayout(leftSideGridLayout);\n\t\t\n\t\t/*\n\t\t * JRadioButtons\n\t\t */\n\t\t\n\t\taddVertex = new JRadioButton(\"Add a vertex\");\n\t\taddVertex.addActionListener(radioButtonListener);\n\t\t\n\t\taddEdge = new JRadioButton(\"Add an edge\");\n\t\taddEdge.addActionListener(radioButtonListener);\n\t\t\n\t\tmoveVertex = new JRadioButton(\"Move a vertex\");\n\t\tmoveVertex.addActionListener(radioButtonListener);\n\t\t\n\t\tshortestPath = new JRadioButton(\"Shortest Path\");\n\t\tshortestPath.addActionListener(radioButtonListener);\n\t\t\n\t\t//Weight Sections consists of JRadioButton and JTextArea\n\t\tweightSection = new JPanel();\n\t\tweightSection.setLayout(new GridLayout(1,2));\n\t\t\n\t\tchangeWeight = new JRadioButton(\"Change weight to :\");\n\t\tchangeWeight.addActionListener(radioButtonListener);\n\t\t\n\t\tweightInputText = new JTextField();\n\t\tweightInputText.setPreferredSize(new Dimension(20,20));\n\t\t\n\t\t//Adding JRadioButtons to left JPanel\n\t\tleftSideOfGUI.add(addVertex);\n\t\tleftSideOfGUI.add(addEdge);\n\t\tleftSideOfGUI.add(moveVertex);\n\t\tleftSideOfGUI.add(shortestPath);\n\t\t\n\t\t//Adding specific JPanel to the left side, consists of two components\n\t\tweightSection.add(changeWeight);\n\t\tweightSection.add(weightInputText);\n\t\t\n\t\tleftSideOfGUI.add(weightSection);\n\t\t\n\t\t\n\t\t/*\n\t\t * Buttons\n\t\t */\n\t\t\n\t\taddEdgesButton = new JButton(\"Add All Edges\");\n\t\taddEdgesButton.setPreferredSize(new Dimension(50, 50));\n\t\taddEdgesButton.addActionListener(buttonListener);\n\t\t\n\t\trandomWeightsButton = new JButton(\"Random Weights\");\n\t\trandomWeightsButton.setPreferredSize(new Dimension(50, 50));\n\t\trandomWeightsButton.addActionListener(buttonListener);\n\t\t\n\t\tminimalSpanningTreeButton = new JButton(\"Minimal Tree Spanning\");\n\t\tminimalSpanningTreeButton.setPreferredSize(new Dimension(50, 50));\n\t\tminimalSpanningTreeButton.addActionListener(buttonListener);\n\t\t\n\t\thelpButton = new JButton(\"Help\");\n\t\thelpButton.setPreferredSize(new Dimension(50, 50));\n\t\thelpButton.addActionListener(buttonListener);\n\t\t\n\t\t//Adding Buttons to left side of GUI\n\t\tleftSideOfGUI.add(addEdgesButton);\n\t\tleftSideOfGUI.add(randomWeightsButton);\n\t\tleftSideOfGUI.add(minimalSpanningTreeButton);\n\t\tleftSideOfGUI.add(helpButton);\n\t\t\n\t}",
"private void $$$setupUI$$$ ()\n {\n contentPane = new JPanel();\n contentPane.setLayout(new BorderLayout(0, 0));\n contentPane.setBackground(new Color(-16777216));\n contentPane.setPreferredSize(new Dimension(300, 100));\n contentPane.setRequestFocusEnabled(false);\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new FlowLayout(FlowLayout.CENTER, 5, 5));\n panel1.setBackground(new Color(-16777216));\n panel1.setPreferredSize(new Dimension(200, 50));\n contentPane.add(panel1, BorderLayout.SOUTH);\n buttonOK = new JButton();\n buttonOK.setPreferredSize(new Dimension(100, 31));\n buttonOK.setText(\"OK\");\n panel1.add(buttonOK);\n final JLabel label1 = new JLabel();\n label1.setPreferredSize(new Dimension(30, 10));\n label1.setText(\"\");\n panel1.add(label1);\n buttonCancel = new JButton();\n buttonCancel.setPreferredSize(new Dimension(100, 31));\n buttonCancel.setText(\"Cancel\");\n panel1.add(buttonCancel);\n textField1 = new JTextField();\n textField1.setBackground(new Color(-15987184));\n Font textField1Font = Tools.getFont(\"Arial\", -1, 20, textField1.getFont());\n if (textField1Font != null)\n {\n textField1.setFont(textField1Font);\n }\n textField1.setForeground(new Color(-1));\n textField1.setHorizontalAlignment(0);\n textField1.setOpaque(false);\n textField1.setPreferredSize(new Dimension(300, 50));\n contentPane.add(textField1, BorderLayout.CENTER);\n final JLabel label2 = new JLabel();\n label2.setPreferredSize(new Dimension(11, 11));\n label2.setText(\" \");\n contentPane.add(label2, BorderLayout.WEST);\n final JLabel label3 = new JLabel();\n label3.setPreferredSize(new Dimension(11, 11));\n label3.setText(\" \");\n contentPane.add(label3, BorderLayout.EAST);\n final JLabel label4 = new JLabel();\n label4.setPreferredSize(new Dimension(11, 11));\n label4.setText(\"\");\n contentPane.add(label4, BorderLayout.NORTH);\n }",
"private void doTheLayout(){\n\n\t JPanel top = new JPanel();\n\t JPanel center = new JPanel();\n\t JPanel bottom = new JPanel();\n\n\t top.setLayout( new FlowLayout());\n\t top.add(label1);\n\t top.add(field1);\n\n\t center.setLayout( new FlowLayout());\n\t center.add(label2);\n\t center.add(field2);\n\n\t bottom.setLayout( new FlowLayout());\n\t bottom.add(SortButton);\n\t bottom.add(CloseButton);\n\n\t setLayout( new BorderLayout());\n\t add(top, \"North\");\n\t add(center, \"Center\");\n\t add(bottom, \"South\");\n\n\t }",
"private void setViewLayout() {\n\t\tthis.setBorder(new EmptyBorder(15, 15, 15, 15));\n\t\tthis.setLayout(new GridLayout(2, 2, 15, 15));\n\t}",
"private void init() {\r\n\t\tthis.panel.setLayout(new BoxLayout(this.panel, BoxLayout.PAGE_AXIS));\r\n\t\tthis.labelTitle = new JLabel(\"Edit your weapons\");\r\n\t\tthis.labelTitle.setAlignmentX(Component.CENTER_ALIGNMENT);\r\n\t\tthis.initFilter();\r\n\t\tthis.initList();\r\n\t\tthis.list.setSelectedIndex(0);\r\n\t\tthis.initInfo();\r\n\t\tthis.initButton();\r\n\r\n\t\tJPanel panelWest = new JPanel();\r\n\t\tpanelWest.setLayout(new BoxLayout(panelWest, BoxLayout.PAGE_AXIS));\r\n\t\tJPanel panelCenter = new JPanel();\r\n\t\tpanelCenter.setLayout(new BoxLayout(panelCenter, BoxLayout.LINE_AXIS));\r\n\r\n\t\tpanelWest.add(this.panelFilter);\r\n\t\tpanelWest.add(Box.createRigidArea(new Dimension(0, 5)));\r\n\t\tpanelWest.add(this.panelInfo);\r\n\t\tpanelCenter.add(panelWest);\r\n\t\tpanelCenter.add(Box.createRigidArea(new Dimension(10, 0)));\r\n\t\tthis.panelList.setPreferredSize(new Dimension(300, 150));\r\n\t\tpanelCenter.add(this.panelList);\r\n\r\n\t\tthis.panel.add(this.labelTitle);\r\n\t\tthis.panel.add(Box.createRigidArea(new Dimension(0, 10)));\r\n\t\tthis.panel.add(panelCenter);\r\n\t\tthis.panel.add(Box.createRigidArea(new Dimension(0, 10)));\r\n\t\tthis.panel.add(this.panelButton);\r\n\r\n\t}",
"private void makeButtonPanel()\n {\n \n this.buttonPanel.setLayout(new GridLayout(10, 2, 30, 10));\n \n \n this.buttonPanel.add(this.fLabel);\n this.fName.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.fName);\n\n this.buttonPanel.add(this.lLabel);\n this.lName.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.lName);\n\n this.buttonPanel.add(this.idLabel);\n this.iD.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.iD);\n\n this.buttonPanel.add(this.courseLabel);\n this.course.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.course);\n\n this.buttonPanel.add(this.instructorLabel);\n this.instructor.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.instructor);\n\n this.buttonPanel.add(this.tutorLabel);\n this.tutor.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.tutor);\n \n this.buttonPanel.add(this.commentsLable);\n this.comments.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.comments);\n //Removed for appointment tabel\n //this.buttonPanel.add(this.appointmentLable);\n //this.buttonPanel.add(this.appointment);\n this.buttonPanel.add(this.sessionLenLabel);\n this.sessionLength.setColumns(COL_WIDTH);\n this.sessionLength.setText(\"30\");\n this.buttonPanel.add(this.sessionLength);\n\n this.ADD_BUTTON.addActionListener(new AddButtonListener());\n //buttonPanel.add(ADD_BUTTON);\n \n \n this.addSessionPlaceHolder.add(this.buttonPanel);\n }",
"public void initLayouts() {\n\t\tJPanel p_header = (JPanel) getComponentByName(\"p_header\");\n\t\tJPanel p_container = (JPanel) getComponentByName(\"p_container\");\n\t\tJPanel p_tree = (JPanel) getComponentByName(\"p_tree\");\n\t\tJPanel p_commands = (JPanel) getComponentByName(\"p_commands\");\n\t\tJPanel p_execute = (JPanel) getComponentByName(\"p_execute\");\n\t\tJPanel p_buttons = (JPanel) getComponentByName(\"p_buttons\");\n\t\tJPanel p_view = (JPanel) getComponentByName(\"p_view\");\n\t\tJPanel p_info = (JPanel) getComponentByName(\"p_info\");\n\t\tJPanel p_chooseFile = (JPanel) getComponentByName(\"p_chooseFile\");\n\t\tJButton bt_apply = (JButton) getComponentByName(\"bt_apply\");\n\t\tJButton bt_revert = (JButton) getComponentByName(\"bt_revert\");\n\t\tJTextArea ta_header = (JTextArea) getComponentByName(\"ta_header\");\n\t\tJLabel lb_icon = (JLabel) getComponentByName(\"lb_icon\");\n\t\tJLabel lb_name = (JLabel) getComponentByName(\"lb_name\");\n\t\tJTextField tf_name = (JTextField) getComponentByName(\"tf_name\");\n\n\t\tBorder etched = BorderFactory.createEtchedBorder(EtchedBorder.LOWERED);\n\n\t\tp_header.setBorder(etched);\n\t\tp_container.setBorder(etched);\n\t\tp_commands.setBorder(etched);\n\t\t// p_execute.setBorder(etched);\n\t\t// p_view.setBorder(etched);\n\t\t// p_buttons.setBorder(etched);\n\n\t\tp_buttons.setLayout(new FlowLayout(FlowLayout.LEFT, 25, 2));\n\t\tp_chooseFile.setLayout(new FlowLayout(FlowLayout.LEFT, 6, 1));\n\t\tp_view.setLayout(new BorderLayout(0, 0));\n\t\tp_info.setLayout(null);\n\n\t\t// GroupLayout for main JFrame\n\t\t// If you want to change this, use something like netbeans or read more\n\t\t// into group layouts\n\t\tGroupLayout groupLayout = new GroupLayout(getContentPane());\n\t\tgroupLayout\n\t\t\t\t.setHorizontalGroup(groupLayout\n\t\t\t\t\t\t.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\tgroupLayout\n\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t.addContainerGap()\n\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\tgroupLayout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tgroupLayout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tp_commands,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t225,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tgroupLayout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tp_execute,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t957,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tp_container,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t957,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE)))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tp_header,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t1188,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE))\n\t\t\t\t\t\t\t\t\t\t.addContainerGap()));\n\t\tgroupLayout\n\t\t\t\t.setVerticalGroup(groupLayout\n\t\t\t\t\t\t.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\tgroupLayout\n\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t.addContainerGap()\n\t\t\t\t\t\t\t\t\t\t.addComponent(p_header,\n\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE, 57,\n\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t.addPreferredGap(\n\t\t\t\t\t\t\t\t\t\t\t\tComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\tgroupLayout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tp_commands,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t603,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tgroupLayout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tp_container,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t549,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tp_execute,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t48,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE)))\n\t\t\t\t\t\t\t\t\t\t.addContainerGap()));\n\n\t\tGroupLayout gl_p_container = new GroupLayout(p_container);\n\t\tgl_p_container\n\t\t\t\t.setHorizontalGroup(gl_p_container\n\t\t\t\t\t\t.createParallelGroup(Alignment.TRAILING)\n\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\tgl_p_container\n\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t.addContainerGap()\n\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\tgl_p_container\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tp_view,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t955,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.TRAILING,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tgl_p_container\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tbt_apply)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tbt_revert))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tgl_p_container\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tlb_name)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\ttf_name,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t893,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE)))\n\t\t\t\t\t\t\t\t\t\t.addContainerGap()));\n\t\tgl_p_container\n\t\t\t\t.setVerticalGroup(gl_p_container\n\t\t\t\t\t\t.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\tgl_p_container\n\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t.addContainerGap()\n\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\tgl_p_container\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.BASELINE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\ttf_name,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(lb_name))\n\t\t\t\t\t\t\t\t\t\t.addPreferredGap(\n\t\t\t\t\t\t\t\t\t\t\t\tComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t.addComponent(p_view,\n\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t466, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t.addPreferredGap(\n\t\t\t\t\t\t\t\t\t\t\t\tComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\tgl_p_container\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.BASELINE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(bt_revert)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(bt_apply))\n\t\t\t\t\t\t\t\t\t\t.addContainerGap(\n\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE)));\n\t\tp_container.setLayout(gl_p_container);\n\n\t\t// GroupLayout for p_header\n\n\t\tGroupLayout gl_p_header = new GroupLayout(p_header);\n\t\tgl_p_header.setHorizontalGroup(gl_p_header.createParallelGroup(\n\t\t\t\tAlignment.LEADING).addGroup(\n\t\t\t\tAlignment.TRAILING,\n\t\t\t\tgl_p_header\n\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t.addContainerGap()\n\t\t\t\t\t\t.addComponent(ta_header, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t1069, Short.MAX_VALUE).addGap(18)\n\t\t\t\t\t\t.addComponent(lb_icon).addGap(4)));\n\t\tgl_p_header\n\t\t\t\t.setVerticalGroup(gl_p_header\n\t\t\t\t\t\t.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\tgl_p_header\n\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t.addGap(6)\n\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\tgl_p_header\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.BASELINE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tta_header,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t44,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(lb_icon))\n\t\t\t\t\t\t\t\t\t\t.addContainerGap()));\n\t\tp_header.setLayout(gl_p_header);\n\n\t\tGroupLayout gl_p_commands = new GroupLayout(p_commands);\n\t\tgl_p_commands\n\t\t\t\t.setHorizontalGroup(gl_p_commands\n\t\t\t\t\t\t.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\tgl_p_commands\n\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t.addContainerGap()\n\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\tgl_p_commands\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tp_tree,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t211,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tp_buttons,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE))\n\t\t\t\t\t\t\t\t\t\t.addContainerGap()));\n\t\tgl_p_commands.setVerticalGroup(gl_p_commands.createParallelGroup(\n\t\t\t\tAlignment.LEADING).addGroup(\n\t\t\t\tgl_p_commands\n\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t.addContainerGap()\n\t\t\t\t\t\t.addComponent(p_buttons, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t.addComponent(p_tree, GroupLayout.DEFAULT_SIZE, 558,\n\t\t\t\t\t\t\t\tShort.MAX_VALUE).addContainerGap()));\n\t\tp_commands.setLayout(gl_p_commands);\n\n\t\tgetContentPane().setLayout(groupLayout);\n\t}",
"private void setupButtons() {\n\t\tsetupCreateCourse();\n\t\tsetupRemoveCourse();\n\t\tsetupCreateOffering();\n\t\tsetupRemoveOffering();\n\t\tsetupAddPreReq();\n\t\tsetupRemovePreReq();\n\t\tsetupBack();\n\t}",
"private void layoutControls()\n {\n getChildren().addAll(\n new Label(\"Abfahrt\"),\n departureTimeField,\n new Label(\"Bahnhof\"),\n destinationField\n );\n }",
"private void buildTopPanel() {\n \t\tJPanel panel = new JPanel();\n \t\tpanel.setLayout(new BorderLayout(10, 10));\n \t\t\n \t\t// this does not need to be referenced else where, only for layout\n \t\tJPanel paneButtons = new JPanel();\n \t\tGridLayout bl = new GridLayout(2, 1);\n \t\tpaneButtons.setLayout(bl);\n \t\t\n \t\tpaneButtons.add(bCastOff);\n \t\tpaneButtons.add(bSavePlayer);\n \t\t\n \t\t// add all components on top:\n \t\tpanel.add(imgDisplay, BorderLayout.LINE_START);\n \t\tpanel.add(paneEditFields, BorderLayout.CENTER);\n \t\tpanel.add(paneButtons, BorderLayout.LINE_END);\n \t\t\n \t\tadd(panel, BorderLayout.PAGE_START);\n \t}",
"private void $$$setupUI$$$() {\r\n panel1 = new BackGroundPanel();\r\n panel1.setOpaque(false);\r\n panel1.setLayout(new GridLayoutManager(4, 2, new Insets(0, 0, 0, 0), -1, -1));\r\n final Spacer spacer1 = new Spacer();\r\n panel1.add(spacer1, new GridConstraints(1, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_VERTICAL, 1, GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\r\n textPane1 = new JTextArea();\r\n textPane1.setFont(new Font(\"HGMinchoL\", textPane1.getFont().getStyle(), 22));\r\n textPane1.setText(\"\");\r\n textPane1.setEditable(false);\r\n textPane1.setOpaque(false);\r\n panel1.add(textPane1, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_WANT_GROW, null, new Dimension(150, 50), null, 0, false));\r\n final JLabel label1 = new JLabel();\r\n label1.setText(\"Answer:\");\r\n panel1.add(label1, new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\r\n textField1 = new JTextField();\r\n panel1.add(textField1, new GridConstraints(3, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_FIXED, null, new Dimension(150, -1), null, 0, false));\r\n SWINGButton = createButton(\"bat\", \"SWING!\");\r\n //SWINGButton.setText(\"SWING\");\r\n panel1.add(SWINGButton, new GridConstraints(3, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\r\n formattedTextField1 = new JFormattedTextField();\r\n formattedTextField1.setEditable(false);\r\n formattedTextField1.setFont(new Font(\"HGMinchol\", formattedTextField1.getFont().getStyle(), 22));\r\n panel1.add(formattedTextField1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_FIXED, null, new Dimension(150, -1), null, 0, false));\r\n }",
"private void setupLayout() {\n this.setLayout(new BorderLayout());\n\t\tthis.setupConstraints();\n\n\t\tJPanel titleAuthorFields = new JPanel(new GridBagLayout());\n\t\ttitleAuthorFields.add(Pirex.inputField(titleLabel, titleTextField, null), cTitleField);\n\t\ttitleAuthorFields.add(Pirex.inputField(authorLabel, authorTextField, null), cAuthorField);\n\n\t\tJPanel inputFields = new JPanel(new GridLayout(3, 0));\n\t\tinputFields.add(Pirex.inputField(fileLabel, fileTextField, fileBrowseButton));\n\t\tinputFields.add(Pirex.inputField(fileTypeLabel, fileTypeComboBox, null));\n\t\tinputFields.add(titleAuthorFields);\n\t\tinputFields = Pirex.borderLayoutWrap(null, null, inputFields, null, separator);\n\n\t\tJPanel leftAlignedProcessButton = Pirex.leftAlign(processButton);\n\t\tJPanel processPanel = Pirex.borderLayoutWrap(leftAlignedProcessButton, null, summaryScrollPanel, null, null);\n\t\tJPanel loadTabPanel = Pirex.borderLayoutWrap(inputFields, null, processPanel, null, null);\n\n\t\tthis.add(Pirex.withBorder(loadTabPanel), BorderLayout.CENTER);\n\n }",
"public FlowLayout1() {\r\n super( \"Demostracion de FlowLayout\" );\r\n esquema = new FlowLayout(); // crea objeto FlowLayout1\r\n contenedor = getContentPane(); // obtiene contenedor para esquema\r\n setLayout( esquema ); // establece el esquema del marco\r\n\r\n // establece botonJButtonIzquierda y registra componente de escucha\r\n botonJButtonIzquierda = new JButton( \"Izquierda\" ); // crea botón Izquierda\r\n add( botonJButtonIzquierda ); // agrega botón Izquierda al marco\r\n botonJButtonIzquierda.addActionListener(new ActionListener() // clase interna anónima\r\n {\r\n // procesa evento de botonJButtonIzquierda \r\n public void actionPerformed( ActionEvent evento ) {\r\n esquema.setAlignment( FlowLayout.LEFT );\r\n \r\n // realinea los componentes adjuntos\r\n esquema.layoutContainer( contenedor );\r\n } // fin del método actionPerformed\r\n } // fin de la clase interna anónima\r\n ); // fin de la llamada a addActionListener\r\n\r\n // establece botonJButtonCentro y registra componente de escucha\r\n botonJButtonCentro = new JButton( \"Centro\" ); // crea botón Centro\r\n add( botonJButtonCentro ); // agrega botón Centro al marco\r\n botonJButtonCentro.addActionListener(new ActionListener() // clase interna anónima}\r\n {\r\n // procesa evento de botonJButtonCentro \r\n public void actionPerformed( ActionEvent evento ) {\r\n esquema.setAlignment( FlowLayout.CENTER );\r\n \r\n // realinea los componentes adjuntos\r\n esquema.layoutContainer( contenedor );\r\n } // fin del método actionPerformed\r\n } // fin de la clase interna anónima\r\n ); // fin de la llamada a addActionListener\r\n \r\n // establece botonJButtonDerecha y registra componente de escucha\r\n botonJButtonDerecha = new JButton( \"Derecha\" ); // crea botón Derecha\r\n add( botonJButtonDerecha ); // agrega botón Derecha al marco\r\n botonJButtonDerecha.addActionListener(new ActionListener() // clase interna anónima\r\n {\r\n // procesa evento de botonJButtonDerecha \r\n public void actionPerformed( ActionEvent evento ) {\r\n esquema.setAlignment( FlowLayout.RIGHT );\r\n \r\n // realinea los componentes adjuntos\r\n esquema.layoutContainer( contenedor );\r\n } // fin del método actionPerformed\r\n } // fin de la clase interna anónima\r\n ); // fin de la llamada a addActionListener\r\n }",
"public void setLayout() {\n\t\tpersonenListe.getItems().addAll(deck.getPersonenOrdered());\n\t\tpersonenListe.setValue(\"Täter\");\n\t\twaffenListe.getItems().addAll(deck.getWaffenOrdered());\n\t\twaffenListe.setValue(\"Waffe\");\n\t\t// zimmerListe.getItems().addAll(deck.getZimmerOrdered());\n\t\tzimmerListe.setValue(\"Raum\");\n\n\t\tanklage.setMinSize(80, 120);\n\t\tanklage.setMaxSize(80, 120);\n\t\tanklage.setTextFill(Color.BLACK);\n\t\tanklage.setStyle(\"-fx-background-color: #787878;\");\n\n\t\twurfel.setMinSize(80, 120);\n\t\twurfel.setMaxSize(80, 120);\n\t\twurfel.setTextFill(Color.BLACK);\n\t\twurfel.setStyle(\"-fx-background-color: #787878;\");\n\n\t\tgang.setMinSize(80, 120);\n\t\tgang.setMaxSize(80, 120);\n\t\tgang.setTextFill(Color.BLACK);\n\t\tgang.setStyle(\"-fx-background-color: #787878;\");\n\n\t\ttop = new HBox();\n\t\ttop.setSpacing(1);\n\t\ttop.setAlignment(Pos.CENTER);\n\n\t\tbuttons = new HBox();\n\t\tbuttons.setSpacing(20);\n\t\tbuttons.setAlignment(Pos.CENTER);\n\t\tbuttons.getChildren().addAll(anklage, wurfel, gang);\n\n\t\tbottom = new HBox();\n\t\tbottom.setSpacing(150);\n\t\tbottom.setAlignment(Pos.CENTER);\n\t\tbottom.getChildren().addAll(close);\n\n\t\tfenster = new BorderPane();\n\t\tfenster.setStyle(\"-fx-background-image: url('media/ZugFensterResized.png');\");\n\t\tfenster.setTop(top);\n\t\tfenster.setCenter(buttons);\n\t\tfenster.setBottom(bottom);\n\t}",
"protected void masterLayout() {\r\n gbc.anchor = GridBagConstraints.CENTER;\r\n gbc.insets = new Insets(5, 5, 5, 5);\r\n gbc.fill = GridBagConstraints.NONE;\r\n gbc.weighty = 0.0;\r\n gbc.gridx = 0;\r\n gbc.gridy = 0;\r\n int jbHeight = applyButton.getPreferredSize().height;\r\n int jbWidth = applyButton.getPreferredSize().width;\r\n int mpHeight = mainPanel.getPanel().getPreferredSize().height;\r\n int mpWidth = mainPanel.getPanel().getPreferredSize().width;\r\n\r\n gbc.gridheight = (int) Math.ceil((double) mpHeight / jbHeight);\r\n gbc.gridwidth = (int) Math.ceil((double) mpWidth / jbWidth);\r\n\r\n this.add(mainPanel.getPanel(), gbc);\r\n\r\n gbc.gridy += gbc.gridheight;\r\n gbc.weighty = 1.0;\r\n gbc.fill = GridBagConstraints.VERTICAL;\r\n gbc.anchor = GridBagConstraints.CENTER;\r\n this.add(Box.createVerticalGlue(), gbc);\r\n\r\n gbc.gridx += gbc.gridwidth - 1;\r\n gbc.gridy += 1;\r\n gbc.weighty = 0.0;\r\n gbc.fill = GridBagConstraints.NONE;\r\n gbc.anchor = GridBagConstraints.EAST;\r\n gbc.insets = new Insets(10, 10, 10, 10);\r\n gbc.gridheight = 1;\r\n gbc.gridwidth = 1;\r\n\r\n applyButton.setVisible(true);\r\n\r\n this.add(applyButton, gbc);\r\n }",
"private void generateButtonPanel() {\n buttonsPanel = new JPanel();\n playPauseButton = addButton(\"Play/Pause\");\n restartButton = addButton(\"Restart\");\n speedUpButton = addButton(\"Speed Up\");\n slowDownButton = addButton(\"Slow Down\");\n loopbackButton = addButton(\"Loopback\");\n keyCommandsButton = addButton(\"Key Commands\");\n textViewButton = addButton(\"Animation Text\");\n\n addShapeButton = addButton(\"Add Shape\");\n removeShapeButton = addButton(\"Remove Shape\");\n addKeyframeButton = addButton(\"Add Keyframe\");\n removeKeyframeButton = addButton(\"Remove Keyframe\");\n editKeyframeButton = addButton(\"Edit Keyframe\");\n clearAnimationButton = addButton(\"Clear Animation\");\n clearShapeButton = addButton(\"Clear Shape\");\n buttonsPanel.setLayout(new FlowLayout());\n\n mainPanel.add(buttonsPanel);\n }",
"private void $$$setupUI$$$() {\n mainPanel = new JPanel();\n mainPanel.setLayout(new GridLayoutManager(3, 3, new Insets(0, 0, 0, 0), -1, -1));\n toolBarPanel = new JPanel();\n toolBarPanel.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n mainPanel.add(toolBarPanel, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n containerPanel = new JPanel();\n containerPanel.setLayout(new BorderLayout(0, 0));\n mainPanel.add(containerPanel, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n errorPanel = new JPanel();\n errorPanel.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n mainPanel.add(errorPanel, new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n valuePanel = new JPanel();\n valuePanel.setLayout(new BorderLayout(0, 0));\n mainPanel.add(valuePanel, new GridConstraints(1, 1, 1, 2, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n final JLabel label1 = new JLabel();\n label1.setText(\"view as\");\n mainPanel.add(label1, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n comboBox1 = new JComboBox();\n final DefaultComboBoxModel defaultComboBoxModel1 = new DefaultComboBoxModel();\n defaultComboBoxModel1.addElement(\"UTF-8String\");\n comboBox1.setModel(defaultComboBoxModel1);\n mainPanel.add(comboBox1, new GridConstraints(0, 2, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n }",
"private void initComponents() {\n\n jSeparator1 = new javax.swing.JToolBar.Separator();\n buttonGroup1 = new javax.swing.ButtonGroup();\n btnPin = new javax.swing.JToggleButton();\n toolbar = new javax.swing.JToolBar();\n toolbar2 = new javax.swing.JToolBar();\n\n btnPin.setIcon(new javax.swing.ImageIcon(getClass().getResource(\"/org/piraso/ui/api/icons/pin_small.png\"))); // NOI18N\n org.openide.awt.Mnemonics.setLocalizedText(btnPin, org.openide.util.NbBundle.getMessage(BaseEntryViewTopComponent.class, \"BaseEntryViewTopComponent.btnPin.text\")); // NOI18N\n btnPin.setToolTipText(org.openide.util.NbBundle.getMessage(BaseEntryViewTopComponent.class, \"BaseEntryViewTopComponent.btnPin.toolTipText\")); // NOI18N\n btnPin.setFocusable(false);\n btnPin.setHorizontalTextPosition(javax.swing.SwingConstants.CENTER);\n btnPin.setVerticalTextPosition(javax.swing.SwingConstants.BOTTOM);\n btnPin.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n btnPinActionPerformed(evt);\n }\n });\n\n setLayout(new java.awt.BorderLayout());\n\n toolbar.setBackground(new java.awt.Color(226, 226, 226));\n toolbar.setFloatable(false);\n toolbar.setRollover(true);\n add(toolbar, java.awt.BorderLayout.NORTH);\n\n toolbar2.setBackground(new java.awt.Color(226, 226, 226));\n toolbar2.setFloatable(false);\n toolbar2.setOrientation(1);\n toolbar2.setRollover(true);\n toolbar2.setVisible(false);\n add(toolbar2, java.awt.BorderLayout.WEST);\n }",
"private void buttonPanel() {\n totalButton = new JButton(\"Calculate Total\");\r\n totalButton.setPreferredSize(new Dimension(150, 60));\r\n\r\n //add an action listener to the total.\r\n totalButton.addActionListener(new TotalButtonListener());\r\n\r\n //create a button to Submit Order.\r\n orderButton = new JButton(\"Submit Order\");\r\n orderButton.setPreferredSize(new Dimension(150, 60));\r\n orderButton.setEnabled(false);\r\n\r\n //add an action listener to the button.\r\n orderButton.addActionListener(new OrderButtonListener());\r\n\r\n //create a button to reset the checkboxes.\r\n resetButton = new JButton(\"Reset\");\r\n resetButton.setPreferredSize(new Dimension(150, 60));\r\n\r\n //add an action listener to the button.\r\n resetButton.addActionListener(new ResetButtonListener());\r\n\r\n //create a button to exit the application.\r\n exitButton = new JButton(\"Exit\");\r\n exitButton.setPreferredSize(new Dimension(150, 60));\r\n\r\n //add an action listener to the button.\r\n exitButton.addActionListener(new ExitButtonListener());\r\n\r\n //put the buttons in their own panel.\r\n buttonPanel = new JPanel();\r\n buttonPanel.setLayout(new GridLayout(1, 4));\r\n buttonPanel.add(totalButton);\r\n buttonPanel.add(orderButton);\r\n buttonPanel.add(resetButton);\r\n buttonPanel.add(exitButton);\r\n }",
"public void addPanelControls() {\n\t\tlist_sort = new JComboBox<>(new String[] { \"MSSV\", \"HoTen\", \"NTNS\" });\r\n\t\tbtn_sapxep = new JButton(\"Sap xep\");\r\n\t\tbtn_them = new JButton(\"Them\");\r\n\t\tbtn_xoa = new JButton(\"Xoa\");\r\n\t\tbtn_save = new JButton(\"Save\");\r\n\t\tbtn_load = new JButton(\"Load\");\r\n\r\n\t\tJPanel mControlPanel = new JPanel(new GridLayout(5, 1));\r\n\t\tmControlPanel.add(btn_them);\r\n\t\tmControlPanel.add(btn_xoa);\r\n\t\tJPanel sapxepPanel = new JPanel();\r\n\t\tsapxepPanel.add(list_sort);\r\n\t\tsapxepPanel.add(btn_sapxep);\r\n\t\tmControlPanel.add(sapxepPanel);\r\n\t\tmControlPanel.add(btn_save);\r\n\t\tmControlPanel.add(btn_load);\r\n\r\n\t\tmControlPanel.setPreferredSize(new Dimension(380, 200));\r\n\t\tmControlPanel.setBorder(new TitledBorder(\"Controls\"));\r\n\t\tc.fill = GridBagConstraints.HORIZONTAL;\r\n\t\tc.weightx = 0.5;\r\n\t\tc.gridx = 1;\r\n\t\tc.gridy = 0;\r\n\t\tpanel.add(mControlPanel,c);\r\n\t}",
"private void setUpPanel() {\n this.panel = new JPanel();\n functions = new JPanel();\n panel.setPreferredSize(new Dimension(Screen.screenWidth, Screen.screenHeight));\n\n int borderBottom = Screen.screenHeight / 8;\n if (Screen.screenHeight > 1400) {\n borderBottom = Screen.screenHeight / 7;\n }\n\n panel.setBorder(BorderFactory.createEmptyBorder(80, Screen.border, borderBottom, Screen.border));\n panel.setLayout(new BoxLayout(panel, BoxLayout.Y_AXIS));\n functions.setPreferredSize(new Dimension(600, 500));\n functions.setLayout(cardLayout);\n }",
"private void $$$setupUI$$$() {\n contentPane = new JPanel();\n contentPane.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(2, 1, new Insets(10, 10, 10, 10), -1, -1));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1));\n contentPane.add(panel1, new com.intellij.uiDesigner.core.GridConstraints(1, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, 1, null, null, null, 0, false));\n final com.intellij.uiDesigner.core.Spacer spacer1 = new com.intellij.uiDesigner.core.Spacer();\n panel1.add(spacer1, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n final JPanel panel2 = new JPanel();\n panel2.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1, true, false));\n panel1.add(panel2, new com.intellij.uiDesigner.core.GridConstraints(0, 1, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n buttonOK = new JButton();\n buttonOK.setText(\"OK\");\n panel2.add(buttonOK, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n buttonCancel = new JButton();\n buttonCancel.setText(\"Cancel\");\n panel2.add(buttonCancel, new com.intellij.uiDesigner.core.GridConstraints(0, 1, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JScrollPane scrollPane1 = new JScrollPane();\n contentPane.add(scrollPane1, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n final JPanel panel3 = new JPanel();\n panel3.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(3, 4, new Insets(0, 0, 0, 0), 5, 5));\n scrollPane1.setViewportView(panel3);\n final JLabel label1 = new JLabel();\n label1.setFont(new Font(label1.getFont().getName(), Font.BOLD, label1.getFont().getSize()));\n label1.setText(\"mlocarna:\");\n panel3.add(label1, new com.intellij.uiDesigner.core.GridConstraints(1, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_WEST, com.intellij.uiDesigner.core.GridConstraints.FILL_NONE, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final com.intellij.uiDesigner.core.Spacer spacer2 = new com.intellij.uiDesigner.core.Spacer();\n panel3.add(spacer2, new com.intellij.uiDesigner.core.GridConstraints(2, 0, 1, 4, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_VERTICAL, 1, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n final JLabel label2 = new JLabel();\n label2.setBackground(new Color(-65485));\n label2.setFont(new Font(label2.getFont().getName(), Font.BOLD, label2.getFont().getSize()));\n label2.setOpaque(false);\n label2.setText(\"RNAsubopt:\");\n panel3.add(label2, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_WEST, com.intellij.uiDesigner.core.GridConstraints.FILL_NONE, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n random_sample = new JComboBox();\n final DefaultComboBoxModel defaultComboBoxModel1 = new DefaultComboBoxModel();\n defaultComboBoxModel1.addElement(\"5\");\n defaultComboBoxModel1.addElement(\"10\");\n defaultComboBoxModel1.addElement(\"15\");\n defaultComboBoxModel1.addElement(\"20\");\n random_sample.setModel(defaultComboBoxModel1);\n panel3.add(random_sample, new com.intellij.uiDesigner.core.GridConstraints(0, 1, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_EAST, com.intellij.uiDesigner.core.GridConstraints.FILL_NONE, 1, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n useMlocarna = new JCheckBox();\n useMlocarna.setSelected(true);\n useMlocarna.setText(\"\");\n panel3.add(useMlocarna, new com.intellij.uiDesigner.core.GridConstraints(1, 1, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_EAST, com.intellij.uiDesigner.core.GridConstraints.FILL_NONE, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JLabel label3 = new JLabel();\n label3.setText(\"suboptimal structures computed\");\n panel3.add(label3, new com.intellij.uiDesigner.core.GridConstraints(0, 2, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_WEST, com.intellij.uiDesigner.core.GridConstraints.FILL_NONE, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JLabel label4 = new JLabel();\n label4.setText(\"use to compute the folding landscape \");\n panel3.add(label4, new com.intellij.uiDesigner.core.GridConstraints(1, 2, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_WEST, com.intellij.uiDesigner.core.GridConstraints.FILL_NONE, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final com.intellij.uiDesigner.core.Spacer spacer3 = new com.intellij.uiDesigner.core.Spacer();\n panel3.add(spacer3, new com.intellij.uiDesigner.core.GridConstraints(0, 3, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n final com.intellij.uiDesigner.core.Spacer spacer4 = new com.intellij.uiDesigner.core.Spacer();\n panel3.add(spacer4, new com.intellij.uiDesigner.core.GridConstraints(1, 3, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, 1, null, null, null, 0, false));\n }",
"private void initComponents() {\r\n\t\tsetLayout(new java.awt.BorderLayout(10, 10));\r\n\r\n\t\tjavax.swing.JPanel centerPanel = new javax.swing.JPanel(new java.awt.BorderLayout(5, 5));\r\n\t\tjavax.swing.JPanel ticketsAndActivityPanel = new javax.swing.JPanel(new java.awt.BorderLayout(10, 10));\r\n\r\n\t\tTitledBorder titledBorder = BorderFactory.createTitledBorder(null, POSConstants.OPEN_TICKETS_AND_ACTIVITY, TitledBorder.CENTER, TitledBorder.DEFAULT_POSITION);\r\n\t\tticketsAndActivityPanel.setBorder(new CompoundBorder(titledBorder, new EmptyBorder(2, 2, 2, 2)));\r\n\r\n\t\torderFiltersPanel = createOrderFilters();\r\n\t\tticketsAndActivityPanel.add(orderFiltersPanel, BorderLayout.NORTH);\r\n\t\tticketsAndActivityPanel.add(openTicketList, java.awt.BorderLayout.CENTER);\r\n\r\n\t\tJPanel activityPanel = createActivityPanel();\r\n\r\n\t\tticketsAndActivityPanel.add(activityPanel, java.awt.BorderLayout.SOUTH);\r\n\r\n\t\tbtnAssignDriver.addActionListener(new ActionListener() {\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tdoAssignDriver();\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tbtnCloseOrder.addActionListener(new ActionListener() {\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tdoCloseOrder();\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tcenterPanel.add(ticketsAndActivityPanel, java.awt.BorderLayout.CENTER);\r\n\r\n\t\tJPanel rightPanel = new JPanel(new BorderLayout(20, 20));\r\n\t\tTitledBorder titledBorder2 = BorderFactory.createTitledBorder(null, \"-\", TitledBorder.CENTER, TitledBorder.DEFAULT_POSITION);\r\n\t\trightPanel.setBorder(new CompoundBorder(titledBorder2, new EmptyBorder(2, 2, 6, 2)));\r\n\r\n\t\tJPanel orderPanel = new JPanel(new MigLayout(\"ins 2 2 0 2, fill, hidemode 3, flowy\", \"fill, grow\", \"\"));\r\n\t\torderPanel.add(btnDineIn, \"grow\");\r\n\t\torderPanel.add(btnTakeout, \"grow\");\r\n\t\torderPanel.add(btnPickup, \"grow\");\r\n\t\torderPanel.add(btnHomeDelivery, \"grow\");\r\n\t\torderPanel.add(btnDriveThrough, \"grow\");\r\n\t\torderPanel.add(btnBarTab, \"grow\");\r\n\r\n\t\tsetupOrderTypes();\r\n\r\n\t\trightPanel.add(orderPanel);\r\n\r\n\t\tPosButton btnOthers = new PosButton(\"OTHER FUNCTIONS\");\r\n\t\tbtnOthers.addActionListener(new ActionListener() {\r\n\t\t\t@Override\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tSwitchboardOtherFunctionsDialog dialog = new SwitchboardOtherFunctionsDialog(SwitchboardView.this);\r\n\t\t\t\tdialog.open();\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tPosButton btnBackOffice = new PosButton(POSConstants.BACK_OFFICE_BUTTON_TEXT);\r\n\t\tbtnBackOffice.addActionListener(new ActionListener() {\r\n\t\t\t@Override\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tBackOfficeWindow window = BackOfficeWindow.getInstance();\r\n\t\t\t\tif (window == null) {\r\n\t\t\t\t\twindow = new BackOfficeWindow();\r\n\t\t\t\t\tApplication.getInstance().setBackOfficeWindow(window);\r\n\t\t\t\t}\r\n\t\t\t\twindow.setVisible(true);\r\n\t\t\t\twindow.toFront();\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\trightPanel.add(btnBackOffice, BorderLayout.SOUTH);\r\n\r\n\t\tcenterPanel.add(rightPanel, java.awt.BorderLayout.EAST);\r\n\r\n\t\tadd(centerPanel, java.awt.BorderLayout.CENTER);\r\n\t}",
"private void preparePanel()\r\n\t{\r\n\t\t\r\n\t\tSystem.out.println(\"[INFO] <RADIOBUTTON_PANEL> Running preparePanel\"); // Debug\r\n\t\t\r\n\t\tthis.setLayout(new GridLayout(0,2)); // Infinite rows 2 columns\r\n\t\t\r\n\t\t// Create a button group for the radio buttons\r\n\t\tgroup = new ButtonGroup();\r\n\t\t\r\n\t\tfor (JRadioButton button : buttons) // Add each button to the array\r\n\t\t{\r\n\t\t\tthis.add(button);\r\n\t\t\tgroup.add(button); // Add the buttons to the button group\r\n\t\t}\r\n\t\t\r\n\t\t// Calculate the number of rows\r\n\t\tint numberOfRows = (buttons.length + 1)/2;\r\n\t\t\r\n\t\t// Make the panel the correct size, 40px per row\r\n\t\tthis.setPreferredSize(new Dimension(700,40*numberOfRows));\r\n\t\tthis.setMaximumSize(new Dimension(700,50*numberOfRows));\r\n\t}",
"private void $$$setupUI$$$() {\n rootPanel = new JPanel();\n rootPanel.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(11, 3, new Insets(0, 0, 0, 0), -1, -1));\n bKillSession = new JButton();\n bKillSession.setText(\"Убить сессии\");\n rootPanel.add(bKillSession, new com.intellij.uiDesigner.core.GridConstraints(0, 2, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n bGetAll = new JButton();\n bGetAll.setText(\"Получить график\");\n rootPanel.add(bGetAll, new com.intellij.uiDesigner.core.GridConstraints(1, 2, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n bStartBS = new JButton();\n bStartBS.setText(\"Старт БС\");\n rootPanel.add(bStartBS, new com.intellij.uiDesigner.core.GridConstraints(1, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n bSetFreq = new JButton();\n bSetFreq.setText(\"Установить частоту\");\n rootPanel.add(bSetFreq, new com.intellij.uiDesigner.core.GridConstraints(2, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n tfFreq = new JTextField();\n rootPanel.add(tfFreq, new com.intellij.uiDesigner.core.GridConstraints(2, 2, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_WEST, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, new Dimension(150, -1), null, 0, false));\n cbDefaultBS = new JCheckBox();\n cbDefaultBS.setSelected(true);\n cbDefaultBS.setText(\"Использовать БС из конфига\");\n rootPanel.add(cbDefaultBS, new com.intellij.uiDesigner.core.GridConstraints(4, 0, 1, 3, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_WEST, com.intellij.uiDesigner.core.GridConstraints.FILL_NONE, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final com.intellij.uiDesigner.core.Spacer spacer1 = new com.intellij.uiDesigner.core.Spacer();\n rootPanel.add(spacer1, new com.intellij.uiDesigner.core.GridConstraints(7, 2, 4, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_VERTICAL, 1, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n cbListMethods = new JComboBox();\n rootPanel.add(cbListMethods, new com.intellij.uiDesigner.core.GridConstraints(5, 2, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_WEST, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JLabel label1 = new JLabel();\n label1.setText(\"Запускаемый метод:\");\n rootPanel.add(label1, new com.intellij.uiDesigner.core.GridConstraints(5, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_WEST, com.intellij.uiDesigner.core.GridConstraints.FILL_NONE, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final com.intellij.uiDesigner.core.Spacer spacer2 = new com.intellij.uiDesigner.core.Spacer();\n rootPanel.add(spacer2, new com.intellij.uiDesigner.core.GridConstraints(7, 0, 4, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_VERTICAL, 1, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n lblParams = new JLabel();\n lblParams.setText(\"Label\");\n rootPanel.add(lblParams, new com.intellij.uiDesigner.core.GridConstraints(6, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_WEST, com.intellij.uiDesigner.core.GridConstraints.FILL_NONE, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new com.intellij.uiDesigner.core.GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1));\n rootPanel.add(panel1, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n bPause = new JButton();\n bPause.setText(\"Пауза\");\n panel1.add(bPause, new com.intellij.uiDesigner.core.GridConstraints(0, 1, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n bStart = new JButton();\n bStart.setText(\"Старт\");\n panel1.add(bStart, new com.intellij.uiDesigner.core.GridConstraints(0, 0, 1, 1, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_HORIZONTAL, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_SHRINK | com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_CAN_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JSeparator separator1 = new JSeparator();\n rootPanel.add(separator1, new com.intellij.uiDesigner.core.GridConstraints(3, 0, 1, 3, com.intellij.uiDesigner.core.GridConstraints.ANCHOR_CENTER, com.intellij.uiDesigner.core.GridConstraints.FILL_BOTH, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, com.intellij.uiDesigner.core.GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n }",
"private void createpanel4() {\r\n\t\tpanels[3].setLayout(new FlowLayout(FlowLayout.CENTER, 20, 0));\r\n\r\n\t\texecute = new JButton(\"Login\") {\r\n\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic void paint(Graphics g) {\r\n\t\t\t\tg.drawImage(ImageLoader.getImage(\"black_0.4\"), 0, 0, null);\r\n\t\t\t\tsuper.paint(g);\r\n\t\t\t}\r\n\t\t};\r\n\t\texecute.setOpaque(false);\r\n\t\tif (System.getProperty(\"os.name\").startsWith(\"Windows\"))\r\n\t\t\texecute.setForeground(Color.WHITE);\r\n\t\telse\r\n\t\t\texecute.setForeground(Color.BLACK);\r\n\t\texecute.setBorderPainted(true);\r\n\t\texecute.setContentAreaFilled(false);\r\n\t\texecute.setFont(customFont.deriveFont(15f));\r\n\r\n\t\tcancel = new JButton(\"Cancel\") {\r\n\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic void paint(Graphics g) {\r\n\t\t\t\tg.drawImage(ImageLoader.getImage(\"black_0.4\"), 0, 0, null);\r\n\t\t\t\tsuper.paint(g);\r\n\t\t\t}\r\n\t\t};\r\n\t\tcancel.setOpaque(false);\r\n\t\tif (System.getProperty(\"os.name\").startsWith(\"Windows\"))\r\n\t\t\tcancel.setForeground(Color.WHITE);\r\n\t\telse\r\n\t\t\tcancel.setForeground(Color.BLACK);\r\n\t\tcancel.setBorderPainted(true);\r\n\t\tcancel.setContentAreaFilled(false);\r\n\t\tcancel.setFont(customFont.deriveFont(15f));\r\n\r\n\t\tcreateAccount = new JButton(\"New Account\") {\r\n\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic void paint(Graphics g) {\r\n\t\t\t\tg.drawImage(ImageLoader.getImage(\"black_0.4\"), 0, 0, null);\r\n\t\t\t\tsuper.paint(g);\r\n\t\t\t}\r\n\t\t};\r\n\t\tcreateAccount.setOpaque(false);\r\n\t\tif (System.getProperty(\"os.name\").startsWith(\"Windows\"))\r\n\t\t\tcreateAccount.setForeground(Color.WHITE);\r\n\t\telse\r\n\t\t\tcreateAccount.setForeground(Color.BLACK);\r\n\t\tcreateAccount.setBorderPainted(true);\r\n\t\tcreateAccount.setContentAreaFilled(false);\r\n\t\tcreateAccount.setFont(customFont.deriveFont(10f));\r\n\r\n\t\tcancel.setPreferredSize(new Dimension(120, 30));\r\n\t\tcreateAccount.setPreferredSize(new Dimension(120, 30));\r\n\t\texecute.setPreferredSize(new Dimension(120, 30));\r\n\r\n\t\tpanels[3].add(execute);\r\n\t\tpanels[3].add(createAccount);\r\n\t\tpanels[3].add(cancel);\r\n\t\tpanels[3].setOpaque(false);\r\n\t\tallComponents.add(panels[3]);\r\n\t\tthis.backPanel.add(allComponents);\r\n\t\tthis.getContentPane().add(backPanel);\r\n\t\tpanels[3].revalidate();\r\n\r\n\t\tcreateAccount.addMouseListener(\r\n\t\t\t\tnew LoginListener(createAccount, userinfo, passwordbox, guicontroller, cancel, createAccount));\r\n\t\tcancel.addMouseListener(new LoginListener(cancel, userinfo, passwordbox, guicontroller, cancel, createAccount));\r\n\t\texecute.addMouseListener(\r\n\t\t\t\tnew LoginListener(execute, userinfo, passwordbox, guicontroller, cancel, createAccount));\r\n\t}",
"public ButtonPanel(GameFrame gf) {\n gameFrame = gf;\n JPanel buttonPanel = new JPanel();\n setFocusable(false);\n setBackground(new Color(0x696969));\n setLayout(new FlowLayout(FlowLayout.CENTER, 100, 70));\n add(startButton());\n add(saveButton());\n add(loadButton());\n add(resetButton());\n add(exitButton());\n addListeners();\n }",
"private void setDisplay() {\n\t\tDimension d = new Dimension(160,40);\n\t\tsetPreferredSize(d);\n\t\tsetMaximumSize(d);\n\t\tsetMinimumSize(d);\n\t\tsetLayout(new BorderLayout());\n\t\tsetBorder(new EmptyBorder(3,0,3,0));\n\t\tbtnUser = new RoundedButton(new Color(0xEEEEEE), new Color(0xCCCCCC));\n\t\tJPanel pnlInner = new JPanel(new FlowLayout(FlowLayout.LEFT));\n\t\t\n\t\tpnlIcon = new JPanel(new BorderLayout());\n\t\tpnlIcon.add(lblUserListIcon, BorderLayout.CENTER);\n//\t\tpnlIcon.setBackground(new Color(0xEEEEEE));\n\t\tpnlIcon.setOpaque(false);\n\t\t\n\t\tpnlIcon.setBorder(new EmptyBorder(0,5, 0, 5));\n\t\t\n\t\tpnlName = new JPanel(new BorderLayout());\n\t\tpnlName.add(lblUserListName, BorderLayout.CENTER);\n//\t\tpnlName.setBackground(new Color(0xEEEEEE));\n\t\tpnlName.setOpaque(false);\n\t\t\n\t\tpnlInner.add(pnlIcon);\n\t\tpnlInner.add(pnlName);\n\t\t\n\t\tsetOpaque(true);\n\t\tsetBackground(Color.WHITE);\n\t\t\n\t\tbtnUser.add(pnlIcon, BorderLayout.WEST);\n\t\tbtnUser.add(pnlName, BorderLayout.CENTER);\n\t\tadd(btnUser, BorderLayout.CENTER);\n\t}",
"private void initComponents() {\r\n\r\n setLayout(new java.awt.BorderLayout());\r\n }",
"public void init()\n {\n Container screen = getContentPane();\n buttonPanel.setLayout(new BoxLayout(buttonPanel, BoxLayout.Y_AXIS));\n buttonPanel.add(attackButton);\n attackButton.setBackground(Color.WHITE);\n buttonPanel.add(defendButton);\n buttonPanel.add(fireButton);\n buttonPanel.add(iceButton);\n buttonPanel.add(hPotionButton);\n buttonPanel.add(mPotionButton);\n attackButton.addActionListener(this);\n defendButton.addActionListener(this);\n hPotionButton.addActionListener(this);\n mPotionButton.addActionListener(this);\n fireButton.addActionListener(this);\n iceButton.addActionListener(this);\n offScreen = new BufferedImage(500,500, BufferedImage.TYPE_INT_RGB);\n add(buttonPanel, BorderLayout.EAST);\n }",
"private void controllersUI() {\n\t\tc.setLayout(null);\n\t\tc.setBackground(whiteColor);\n\t\t\n\t\tlbPullTitle.setHorizontalAlignment(SwingConstants.CENTER);\n\t\tlbPullTitle.setOpaque(true);\n\t\tlbPullTitle.setFont(new Font(\"Helvetica Neue\", Font.PLAIN, 18));\n\t\tlbPullTitle.setBounds(0, 0, 320, 52);\n\t\t\n\t\ttxtPulls.setFont(new Font(\"Helvetica Neue\", Font.PLAIN, 12));\n\t\ttxtPulls.setBounds(0, 52, 320, 420);\n\t\t\n\t\ttxtMsg.setBounds(10, 480, 230, 35);\n\t\tbtnMsg.setBounds(250, 476, 60, 40);\n\t\t\n\t\tc.add(txtPulls);\n\t\tc.add(lbPullTitle);\n\t\tc.add(btnMsg);\n\t\tc.add(txtMsg);\n\t\t\n\t\tbtnMsg.addActionListener(this);\n\t}",
"public MyPanel2() {\n\t\t//layout설정,버튼 생성,버튼에 객체 연결,버튼 레이아웃 지정\n\t\tJButton button = new JButton(\"Traffic light turn on\");\n\t\tbutton.addActionListener(this);\n\t\t\n\t\tthis.setLayout(new BorderLayout());\n\t\tthis.add(\"South\",button);\n\t\t\n\t}",
"public void initPanel(){\r\n\t \r\n\t\t//Titre\r\n\t\tlabel.setFont(new Font(\"Verdana\",1,40));\r\n\t label.setForeground(Color.black);\r\n\t label.setBorder(BorderFactory.createLineBorder(Color.BLACK, 2));\r\n\t label.setBounds(110,0,575,50);\r\n\t\tthis.panel.setLayout(null);\t \r\n\t this.panel.add(label);\r\n\t \r\n\t //dc\r\n\t this.panel.add(label1, BorderLayout.CENTER);\r\n\t label1.setFont(new Font(\"Verdana\",1,40));\r\n\t label1.setForeground(Color.black);\r\n\t label1.setBorder(BorderFactory.createLineBorder(Color.BLACK, 2));\r\n\t label1.setBounds(150,500,100,50);\r\n\t //ab\r\n\t this.panel.add(label2);\r\n\t label2.setFont(new Font(\"Verdana\",1,40));\r\n\t label2.setForeground(Color.black);\r\n\t label2.setBorder(BorderFactory.createLineBorder(Color.BLACK, 2));\r\n\t label2.setBounds(550,500,100,50);\r\n\t //Button dc\r\n\t\tdc.setBounds(50,200,300,250);\r\n\t\tthis.panel.add(dc);\r\n\t\tdc.addActionListener(this);\r\n\t\t//Button ab\r\n\t\tab.setBounds(450,200,300,250);\r\n\t\tthis.panel.add(ab);\r\n\t\tab.addActionListener(this);\r\n\t\t\r\n\t\tthis.panel.add(label3);\r\n\t label3.setFont(new Font(\"Verdana\",1,20));\r\n\t label3.setForeground(Color.black);\r\n\t label3.setBorder(BorderFactory.createLineBorder(Color.BLACK, 2));\r\n\t label3.setBounds(90,575,220,30);\r\n\t \r\n\t this.panel.add(label4);\r\n\t label4.setFont(new Font(\"Verdana\",1,20));\r\n\t label4.setForeground(Color.black);\r\n\t label4.setBorder(BorderFactory.createLineBorder(Color.BLACK, 2));\r\n\t label4.setBounds(490,575,220,30);\r\n\t}",
"private void addPanels() {\n\t\tthis.add(dicePanel, BorderLayout.WEST);\n\t\tthis.add(inputPanel, BorderLayout.CENTER);\n\t\tthis.add(infoPanel, BorderLayout.SOUTH);\n\t}",
"private void initComponents() {\n\n setLayout(new java.awt.BorderLayout());\n }",
"public void setPanels() {\n\t\tframe.setPreferredSize(new Dimension(3000, 2000));\n\n\t\tcontainer.setBackground(lightGray);\n\t\tcontainer.setPreferredSize(new Dimension(2300, 120));\n\t\tcontainer.setBorder(BorderFactory.createLineBorder(black));\n\n\t\tagePanel.setBackground(lightGray);\n\t\tagePanel.setPreferredSize(new Dimension(2400, 120));\n\t\tagePanel.setBorder(BorderFactory.createLineBorder(black));\n\n\t\theightPanel.setBackground(lightGray);\n\t\theightPanel.setPreferredSize(new Dimension(1200, 120));\n\t\theightPanel.setBorder(BorderFactory.createLineBorder(black));\n\n\t\tweightPanel.setBackground(lightGray);\n\t\tweightPanel.setPreferredSize(new Dimension(850, 120));\n\t\tweightPanel.setBorder(BorderFactory.createLineBorder(black));\n\n\t\thairPanel.setBackground(lightGray);\n\t\thairPanel.setPreferredSize(new Dimension(900, 120));\n\t\thairPanel.setBorder(BorderFactory.createLineBorder(black));\n\n\t\teyePanel.setBackground(lightGray);\n\t\teyePanel.setPreferredSize(new Dimension(900, 120));\n\t\teyePanel.setBorder(BorderFactory.createLineBorder(black));\n\n\t\tabilitySelectionPanel.setBackground(lightGray);\n\t\tabilitySelectionPanel.setPreferredSize(new Dimension(2400, 120));\n\t\tabilitySelectionPanel.setBorder(BorderFactory.createLineBorder(black));\n\n\t\tphysicalAbilityPanel.setBackground(lightGray);\n\t\tphysicalAbilityPanel.setPreferredSize(new Dimension(2400, 400));\n\t\tphysicalAbilityPanel.setBorder(BorderFactory.createLineBorder(black));\n\n\t\tmentalAbilityPanel.setBackground(lightGray);\n\t\tmentalAbilityPanel.setPreferredSize(new Dimension(2400, 400));\n\t\tmentalAbilityPanel.setBorder(BorderFactory.createLineBorder(black));\n\t}",
"private void setupButtonPanel() {\n\n Dimension btnSize = new Dimension(100, 50);\n\n exitButton = new JButton(\"Exit\");\n playAgainButton = new JButton(\"Play Again\");\n\n exitButton.setPreferredSize(btnSize);\n playAgainButton.setPreferredSize(btnSize);\n\n buttonPanel.add(playAgainButton);\n buttonPanel.add(exitButton);\n fullPanel.add(buttonPanel, BorderLayout.SOUTH);\n\n playAgainButton.addActionListener(actionEvent -> {\n GameOver.this.dispose();\n new MainScreen();\n });\n exitButton.addActionListener(actionEvent -> System.exit(0));\n }"
]
| [
"0.7657153",
"0.746164",
"0.7240827",
"0.72160566",
"0.7182723",
"0.7170811",
"0.7116723",
"0.7114378",
"0.70389956",
"0.70268565",
"0.6982423",
"0.69733006",
"0.69506747",
"0.6946019",
"0.6931121",
"0.6916385",
"0.68668747",
"0.6835703",
"0.68349063",
"0.68265384",
"0.6821222",
"0.6816299",
"0.6811235",
"0.6803411",
"0.6795499",
"0.67911035",
"0.67730427",
"0.6769571",
"0.6766195",
"0.6740166",
"0.6736635",
"0.67340505",
"0.6723623",
"0.67182547",
"0.6703087",
"0.6699954",
"0.66926694",
"0.6682769",
"0.66819036",
"0.6675286",
"0.66738504",
"0.6673587",
"0.6669908",
"0.66674024",
"0.66665226",
"0.66650593",
"0.6652425",
"0.6649825",
"0.66422653",
"0.6638287",
"0.6628906",
"0.6627989",
"0.66251767",
"0.6618156",
"0.66162276",
"0.6614751",
"0.66008884",
"0.65938365",
"0.6590086",
"0.65868086",
"0.6581902",
"0.6568291",
"0.6562684",
"0.6559969",
"0.6555139",
"0.65547407",
"0.65542364",
"0.6545555",
"0.6541055",
"0.6537066",
"0.65311396",
"0.6530619",
"0.651291",
"0.651044",
"0.6501715",
"0.6500931",
"0.64942",
"0.64930636",
"0.64918506",
"0.64906317",
"0.6490088",
"0.6488587",
"0.64819086",
"0.64742607",
"0.6468893",
"0.64647675",
"0.64559436",
"0.6450981",
"0.6443651",
"0.6440645",
"0.64375913",
"0.6427742",
"0.6424925",
"0.6422117",
"0.64202034",
"0.6418538",
"0.640297",
"0.63984454",
"0.63973874",
"0.6390858"
]
| 0.70714027 | 8 |
Sets up this panel with a button in each area of a border layout to show how it affects their position, shape, and size. | public BorderPanel(){
setLayout(new BorderLayout());
setBackground(Color.green);
JButton b1 = new JButton("Button 1");
JButton b2 = new JButton("Button 2");
JButton b3 = new JButton("Button 3");
JButton b4 = new JButton("Button 4");
JButton b5 = new JButton("Button 5");
add(b1, BorderLayout.CENTER);
add(b2, BorderLayout.NORTH);
add(b3, BorderLayout.SOUTH);
add(b4, BorderLayout.EAST);
add(b5, BorderLayout.WEST);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void initButton() {\r\n\t\tthis.panelButton = new JPanel();\r\n\t\tthis.panelButton.setLayout(new BoxLayout(this.panelButton,\r\n\t\t\t\tBoxLayout.LINE_AXIS));\r\n\t\tthis.modifyButton = new JButton(\"Modify\");\r\n\t\tthis.buttonSize(this.modifyButton);\r\n\t\tthis.deleteButton = new JButton(\"Delete\");\r\n\t\tthis.buttonSize(this.deleteButton);\r\n\t\tthis.cancelButton = new JButton(\"Cancel\");\r\n\t\tthis.buttonSize(this.cancelButton);\r\n\r\n\t\tthis.modifyButton.addActionListener(this.editWeaponControl);\r\n\t\tthis.deleteButton.addActionListener(this.editWeaponControl);\r\n\t\tthis.cancelButton.addActionListener(this.editWeaponControl);\r\n\r\n\t\tthis.panelButton.add(this.modifyButton);\r\n\t\tthis.panelButton.add(Box.createRigidArea(new Dimension(15, 0)));\r\n\t\tthis.panelButton.add(this.deleteButton);\r\n\t\tthis.panelButton.add(Box.createRigidArea(new Dimension(15, 0)));\r\n\t\tthis.panelButton.add(this.cancelButton);\r\n\t}",
"public JButtonsPanel() {\r\n setBorder(BorderFactory.createEtchedBorder(Color.GREEN, new Color(148, 145, 140)));\r\n\r\n jOpen.setText(BTN_OPEN);\r\n jOpen.setToolTipText(MSG_OPEN);\r\n jOpen.setBounds(new Rectangle(BTN_LEFT, BTN_VSPACE, BTN_WIDTH, BTN_HEIGHT));\r\n add(jOpen);\r\n\r\n jCheckHealth.setText(BTN_CHECK_HEALTH);\r\n jCheckHealth.setToolTipText(MSG_CHECK_HEALTH);\r\n jCheckHealth.setBounds(new Rectangle(BTN_LEFT, (int) (jOpen.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jCheckHealth);\r\n\r\n jClose.setText(BTN_CLOSE);\r\n jClose.setToolTipText(MSG_CLOSE);\r\n jClose.setBounds(new Rectangle(BTN_LEFT, (int) (jCheckHealth.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jClose);\r\n\r\n jClaim.setText(BTN_CLAIM);\r\n jClaim.setToolTipText(MSG_CLAIM);\r\n jClaim.setBounds(new Rectangle(BTN_LEFT, (int) (jClose.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jClaim);\r\n\r\n jRelease.setText(BTN_RELEASE);\r\n jRelease.setToolTipText(MSG_RELEASE);\r\n jRelease.setBounds(new Rectangle(BTN_LEFT, (int) (jClaim.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jRelease);\r\n\r\n jDeviceEnable.setText(BTN_DEVICE_ENABLE);\r\n jDeviceEnable.setToolTipText(MSG_DEVICE_ENABLE);\r\n jDeviceEnable.setBounds(new Rectangle(BTN_LEFT, (int) (jRelease.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jDeviceEnable);\r\n\r\n jDeviceDisable.setText(BTN_DEVICE_DISABLE);\r\n jDeviceDisable.setToolTipText(MSG_DEVICE_DISABLE);\r\n jDeviceDisable.setBounds(new Rectangle(BTN_LEFT, (int) (jDeviceEnable.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jDeviceDisable);\r\n\r\n jClearData.setText(BTN_CLEAR_DATA);\r\n jClearData.setToolTipText(MSG_CLEAR_DATA);\r\n jClearData.setBounds(new Rectangle(BTN_LEFT, (int) (jDeviceDisable.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jClearData);\r\n\r\n jBeginEnrollCapture.setText(BTN_BEGIN_ENROLL_CAPTURE);\r\n jBeginEnrollCapture.setToolTipText(MSG_BEGIN_ENROLL_CAPTURE);\r\n jBeginEnrollCapture.setBounds(new Rectangle(BTN_LEFT, (int) (jClearData.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jBeginEnrollCapture);\r\n\r\n jEndCapture.setText(BTN_END_CAPTURE);\r\n jEndCapture.setToolTipText(MSG_END_CAPTURE);\r\n jEndCapture.setBounds(new Rectangle(BTN_LEFT, (int) (jBeginEnrollCapture.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jEndCapture);\r\n\r\n jBeginVerifyCapture.setText(BTN_BEGIN_VERIFY_CAPTURE);\r\n jBeginVerifyCapture.setToolTipText(MSG_BEGIN_VERIFY_CAPTURE);\r\n jBeginVerifyCapture.setBounds(new Rectangle(BTN_LEFT, (int) (jEndCapture.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jBeginVerifyCapture);\r\n\r\n jIdentifyMatch.setText(BTN_IDENTIFY_MATCH);\r\n jIdentifyMatch.setToolTipText(MSG_IDENTIFY_MATCH);\r\n jIdentifyMatch.setBounds(new Rectangle(BTN_LEFT, (int) (jBeginVerifyCapture.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jIdentifyMatch);\r\n\r\n jVerifyMatch.setText(BTN_VERIFY_MATCH);\r\n jVerifyMatch.setToolTipText(MSG_VERIFY_MATCH);\r\n jVerifyMatch.setBounds(new Rectangle(BTN_LEFT, (int) (jIdentifyMatch.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jVerifyMatch);\r\n\r\n jIdentify.setText(BTN_IDENTIFY);\r\n jIdentify.setToolTipText(MSG_IDENTIFY);\r\n jIdentify.setBounds(new Rectangle(BTN_LEFT, (int) (jVerifyMatch.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jIdentify);\r\n\r\n jVerify.setText(BTN_VERIFY);\r\n jVerify.setToolTipText(MSG_VERIFY);\r\n jVerify.setBounds(new Rectangle(BTN_LEFT, (int) (jIdentify.getBounds().getMaxY() + BTN_VSPACE), BTN_WIDTH, BTN_HEIGHT));\r\n add(jVerify);\r\n }",
"ButtonPanel() {\n setLayout(new GridLayout(0,3));\n setPreferredSize(new Dimension(1000,100));\n setVisible(true);\n setMaximumSize(new Dimension(1000,250));\n reservationButton = new JButton(\"Reservation View\");\n bookingButton = new JButton(\"Booking View\");\n searchButton = new JButton(\"Search View\");\n add(reservationButton);\n add(bookingButton);\n add(searchButton);\n \n }",
"private ButtonJPanel(){\n GridLayout layout = new GridLayout(0, 1);//creates a grid layout with 1 column and unlimited rows, for the buttons\n setLayout(layout);//sets the JPanel layout\n layout.setVgap(5);//sets the vertical gap between the buttons\n setBackground(Color.WHITE);//sets the color of the panel to WHITE\n \n fillrecimg = new ImageIcon(\"src/fillrec.png\");//assigns a png image to the ImageIcon\n fillovalimg = new ImageIcon(\"src/filloval.png\");\n emptyrecimg = new ImageIcon(\"src/emptyrec.png\");\n emptyovalimg = new ImageIcon(\"src/emptyoval.png\");\n linedrawimg = new ImageIcon(\"src/linedraw.png\");\n \n clear = new JButton(\"Clear\");//initializes the buttons, either with text or an icon\n (fillrec = new JButton(fillrecimg)).setActionCommand(\"Filled Rectangle\");//icon buttons are assigned a string ActionCommand\n (filloval = new JButton(fillovalimg)).setActionCommand(\"Filled Oval\");\n (emptyrec = new JButton(emptyrecimg)).setActionCommand(\"Empty Rectangle\");\n (emptyoval = new JButton(emptyovalimg)).setActionCommand(\"Empty Oval\");\n (linedraw = new JButton(linedrawimg)).setActionCommand(\"Line Drawing\");\n opencolor = new JButton(\"Color Chooser\");\n \n JButton[] buttons = {clear, fillrec, filloval, emptyrec, emptyoval, linedraw, opencolor};//an array of all the buttons\n \n for(JButton button : buttons){//for each button...\n button.addActionListener(this);//add a listener\n add(button);//add the button to the panel\n button.setOpaque(true);//make the color visable\n button.setBackground(Color.BLACK);//set background to black\n button.setFont(new Font(Font.DIALOG, Font.PLAIN, 13));//sets the font, style, and size\n }\n }",
"private void geometry()\n\t\t{\n\t\t// JComponent : Instanciation\n\t\tbutton1 = new JButton(\"1\");\n\t\tbutton2 = new JButton(\"2\");\n\n\t\t// Layout : Specification\n\t\t\t{\n\t\t\tFlowLayout flowlayout = new FlowLayout(FlowLayout.CENTER);\n\t\t\tsetLayout(flowlayout);\n\n\t\t\tflowlayout.setHgap(20);\n\t\t\t}\n\n\t\t// JComponent : add\n\t\tadd(button1);\n\t\tadd(button2);\n\t\t}",
"public Box getButtonPanel() {\n\t\tBox buttonsPanel = new Box(BoxLayout.Y_AXIS);\n\t\tbuttonsPanel.setAlignmentX(Component.CENTER_ALIGNMENT);\n\n\t\tBox treeBox = new Box(BoxLayout.Y_AXIS);\n\t\ttreeBox.setBorder(new TitledBorder(\"Schema\"));\n\n\t\tBox associationBox = new Box(BoxLayout.Y_AXIS);\n\t\tassociationBox.setBorder(new TitledBorder(\"Association\"));\n\n\t\tBox outputBox = new Box(BoxLayout.Y_AXIS);\n\t\toutputBox.setBorder(new TitledBorder(\"Output\"));\n\n\t\tBox numerotationBox = new Box(BoxLayout.X_AXIS);\n\t\tnumerotationBox.setBorder(new TitledBorder(\"Numerotation\"));\n\t\t/* add a button for loading a XML Schema */\n\t\tJButton loadFileb = new JButton(\"Open schema\");\n\t\tUtils.setDefaultSize(loadFileb);\n\t\tloadFileb.addActionListener(new LoadSchemaListener());\n\n\t\t/*\n\t\t * add a button for associating the content of a node to a line in the\n\t\t * flat file\n\t\t */\n\t\tJButton selectLineNodeb = new JButton(\"Main node\");\n\t\tUtils.setDefaultSize(selectLineNodeb);\n\t\tselectLineNodeb.addActionListener(new SelectLineNodeListener());\n\n\t\tJButton selectNodeb = new JButton(\"Select\");\n\t\tUtils.setDefaultSize(selectNodeb);\n\t\tselectNodeb.addActionListener(new SelectNodeListener());\n\n\t\tJButton unselectNodeb = new JButton(\"Unselect\");\n\t\tUtils.setDefaultSize(unselectNodeb);\n\t\tunselectNodeb.addActionListener(new UnselectNodeListener());\n\n\t\tJButton nameb = new JButton(\"Name\");\n\t\tUtils.setDefaultSize(nameb);\n\t\tnameb.addActionListener(new associateNameListener());\n\n\t\tJButton filterb = new JButton(\"Filter\");\n\t\tUtils.setDefaultSize(filterb);\n\t\tfilterb.addActionListener(new AssociateFilterListener());\n\n\t\tJButton infosb = new JButton(\"About\");\n\t\tUtils.setDefaultSize(infosb);\n\t\tinfosb.addActionListener(new InfosListener());\n\n\t\tassociationBox.add(selectNodeb);\n\t\tassociationBox.add(unselectNodeb);\n\t\tassociationBox.add(nameb);\n\t\tassociationBox.add(filterb);\n\t\tfilter = new JLabel(\"no filter\");\n\t\tassociationBox.add(filter);\n\n\t\ttreeBox.add(loadFileb);\n\n\t\tassociationBox.add(infosb);\n\n\t\tJButton loadXmlFileb = new JButton(\"Open document (XML)\");\n\t\tUtils.setDefaultSize(loadXmlFileb);\n\t\tloadXmlFileb.addActionListener(new LoadDocumentListener());\n\n\t\tJButton setSeparatorb = new JButton(\"Separator\");\n\t\tUtils.setDefaultSize(setSeparatorb);\n\t\tsetSeparatorb.addActionListener(new SetSeparatorListener());\n\n\t\tJButton printTabFileb = new JButton(\"Print\");\n\t\tUtils.setDefaultSize(printTabFileb);\n\t\tprintTabFileb.addActionListener(new PrintFlatFileListener());\n\n\t\ttreeBox.add(loadXmlFileb);\n\t\ttreeBox.add(selectLineNodeb);\n\n\t\toutputBox.add(setSeparatorb);\n\t\toutputBox.add(printTabFileb);\n\n\t\tnumerotationButtons = new ButtonGroup();\n\n\t\tnumericb = new JRadioButton(\"1\");\n\t\thighAlphabeticb = new JRadioButton(\"A\");\n\t\tlowAlphabeticb = new JRadioButton(\"a\");\n\t\tnoneb = new JRadioButton(\"none\");\n\n\t\tnumericb.addActionListener(new NumerotationListener());\n\t\thighAlphabeticb.addActionListener(new NumerotationListener());\n\t\tlowAlphabeticb.addActionListener(new NumerotationListener());\n\t\tnumerotationBox.setAlignmentX(Component.LEFT_ALIGNMENT);\n\t\tnumerotationButtons.add(numericb);\n\t\tnumerotationButtons.add(highAlphabeticb);\n\t\tnumerotationButtons.add(lowAlphabeticb);\n\t\tnumerotationButtons.add(noneb);\n\n\t\tswitch (((XsdTreeStructImpl) xsdTree).numerotation_type) {\n\t\tcase XsdTreeStructImpl.HIGH_ALPHABETIC_NUMEROTATION:\n\t\t\thighAlphabeticb.setSelected(true);\n\t\t\tbreak;\n\t\tcase XsdTreeStructImpl.LOW_ALPHABETIC_NUMEROTATION:\n\t\t\tlowAlphabeticb.setSelected(true);\n\t\t\tbreak;\n\t\tcase XsdTreeStructImpl.NUMERIC_NUMEROTATION:\n\t\t\tnumericb.setSelected(true);\n\t\t\tbreak;\n\t\tdefault:\n\t\t\tnoneb.setSelected(true);\n\t\t\tbreak;\n\t\t}\n\n\t\tnumerotationBox.add(numericb);\n\t\tnumerotationBox.add(highAlphabeticb);\n\t\tnumerotationBox.add(lowAlphabeticb);\n\t\tnumerotationBox.add(noneb);\n\n\t\tbuttonsPanel.add(treeBox);\n\t\tbuttonsPanel.add(associationBox);\n\t\tbuttonsPanel.add(outputBox);\n\t\tbuttonsPanel.add(numerotationBox);\n\n\t\tdisplayExample = new JCheckBox(\"preview\");\n\t\tbuttonsPanel.add(displayExample);\n\t\tdisplayExample.addActionListener(new PreviewListener());\n\t\t\n\t\treturn buttonsPanel;\n\t}",
"private void setUpLayout() {\n\n this.setLayout(new GridLayout(7, 1, 40, 37));\n this.setBackground(new Color(72, 0, 0));\n this.setBorder(BorderFactory.createEmptyBorder(8, 150, 8, 150));\n }",
"private void createButtonsPanel() {\r\n Composite buttonsPanel = new Composite(this, SWT.NONE);\r\n buttonsPanel.setLayoutData(new GridData(SWT.FILL, SWT.FILL, true, false));\r\n buttonsPanel.setLayout(new GridLayout(4, true));\r\n\r\n getButtonFromAction(buttonsPanel, \"New\", new NewAction(_window));\r\n getButtonFromAction(buttonsPanel, \"Save\", new SaveAction());\r\n getButtonFromAction(buttonsPanel, \"Delete\", new DeleteAction(_window));\r\n getButtonFromAction(buttonsPanel, \"Cancel\", new CancelAction());\r\n }",
"@Override\n\tpublic void doLayout() {\n\t\tthis.transitionsPanel.setBounds(0, 0, this.getWidth(), this.getHeight());\n\t\t//this.timersButton.setBounds(this.getWidth()-2*50, 0, 50, 50);\n\t\t//this.countersButton.setBounds(this.getWidth()-50, 0, 50, 50);\n\t\t//this.salirButton.setBounds(this.getWidth()-40,0,40, 40);\n\t\tsuper.doLayout();\n\t}",
"private void initPanelButtons() {\r\n\t\tthis.panelButtons = new JPanel(new GridBagLayout());\r\n\t\tthis.panelButtons.setBorder(BorderFactory.createEmptyBorder(10, 5, 0, 5));\r\n\t\tthis.panelButtons.setOpaque(false);\r\n\t\tGridBagConstraints gbc = new GridBagConstraints();\r\n\r\n\t\tgbc.gridx = 0;\r\n\t\tgbc.gridy = 0;\r\n\t\tgbc.gridwidth = 1;\r\n\t\tgbc.gridheight = 1;\r\n\t\tgbc.weightx = 1;\r\n\t\tgbc.weighty = 1;\r\n\t\tthis.returnButton.setBackground(ConstantView.COLOR_BUTTON_LOGIN);\r\n\t\tthis.returnButton.setForeground(Color.WHITE);\r\n\t\tthis.returnButton.setFocusable(false);\r\n\t\tthis.returnButton.setCursor(new Cursor(Cursor.HAND_CURSOR));\r\n\t\tthis.returnButton.setFont(ConstantView.FONT_PRINCIPAL_LABELS);\r\n\t\tthis.panelButtons.add(returnButton, gbc);\r\n\r\n\t\tgbc.gridx = 7;\r\n\t\tthis.okButton.setBackground(ConstantView.COLOR_BUTTON_LOGIN);\r\n\t\tthis.okButton.setForeground(Color.WHITE);\r\n\t\tthis.okButton.setFocusable(false);\r\n\t\tthis.okButton.setCursor(new Cursor(Cursor.HAND_CURSOR));\r\n\t\tthis.okButton.setFont(ConstantView.FONT_PRINCIPAL_LABELS);\r\n\t\tthis.okButton.addActionListener(ControlClient.getInstance());\r\n\t\tthis.okButton.setActionCommand(ClientCommands.OK_SIGN_IN.toString());\r\n\t\tthis.panelButtons.add(okButton, gbc);\r\n\t}",
"private void setButtonPanelComponents(){\n\t\tJPanel buttonPane = new JPanel();\n\t\tbuttonPane.setPreferredSize(new Dimension(-1,32));\n\t\tbuttonPane.setBackground(Constant.DIALOG_BOX_COLOR_BG);\n\t\tbuttonPane.setLayout(new FlowLayout(FlowLayout.RIGHT));\n\t\tgetContentPane().add(buttonPane, BorderLayout.SOUTH);\n\t\t\n\t\tsaveButton = Utilities.getInstance().initializeNewButton(\n\t\t\t-1, -1, -1, -1,\n\t\t\tImages.getInstance().saveBtnDialogImg,\n\t\t\tImages.getInstance().saveBtnDialogImgHover\n\t\t);\n\t\tbuttonPane.add(saveButton);\n\t\n\n\t\n\t}",
"private void makeButtonPanel()\n {\n \n this.buttonPanel.setLayout(new GridLayout(10, 2, 30, 10));\n \n \n this.buttonPanel.add(this.fLabel);\n this.fName.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.fName);\n\n this.buttonPanel.add(this.lLabel);\n this.lName.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.lName);\n\n this.buttonPanel.add(this.idLabel);\n this.iD.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.iD);\n\n this.buttonPanel.add(this.courseLabel);\n this.course.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.course);\n\n this.buttonPanel.add(this.instructorLabel);\n this.instructor.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.instructor);\n\n this.buttonPanel.add(this.tutorLabel);\n this.tutor.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.tutor);\n \n this.buttonPanel.add(this.commentsLable);\n this.comments.setColumns(COL_WIDTH);\n this.buttonPanel.add(this.comments);\n //Removed for appointment tabel\n //this.buttonPanel.add(this.appointmentLable);\n //this.buttonPanel.add(this.appointment);\n this.buttonPanel.add(this.sessionLenLabel);\n this.sessionLength.setColumns(COL_WIDTH);\n this.sessionLength.setText(\"30\");\n this.buttonPanel.add(this.sessionLength);\n\n this.ADD_BUTTON.addActionListener(new AddButtonListener());\n //buttonPanel.add(ADD_BUTTON);\n \n \n this.addSessionPlaceHolder.add(this.buttonPanel);\n }",
"private void buttonPanel() {\n totalButton = new JButton(\"Calculate Total\");\r\n totalButton.setPreferredSize(new Dimension(150, 60));\r\n\r\n //add an action listener to the total.\r\n totalButton.addActionListener(new TotalButtonListener());\r\n\r\n //create a button to Submit Order.\r\n orderButton = new JButton(\"Submit Order\");\r\n orderButton.setPreferredSize(new Dimension(150, 60));\r\n orderButton.setEnabled(false);\r\n\r\n //add an action listener to the button.\r\n orderButton.addActionListener(new OrderButtonListener());\r\n\r\n //create a button to reset the checkboxes.\r\n resetButton = new JButton(\"Reset\");\r\n resetButton.setPreferredSize(new Dimension(150, 60));\r\n\r\n //add an action listener to the button.\r\n resetButton.addActionListener(new ResetButtonListener());\r\n\r\n //create a button to exit the application.\r\n exitButton = new JButton(\"Exit\");\r\n exitButton.setPreferredSize(new Dimension(150, 60));\r\n\r\n //add an action listener to the button.\r\n exitButton.addActionListener(new ExitButtonListener());\r\n\r\n //put the buttons in their own panel.\r\n buttonPanel = new JPanel();\r\n buttonPanel.setLayout(new GridLayout(1, 4));\r\n buttonPanel.add(totalButton);\r\n buttonPanel.add(orderButton);\r\n buttonPanel.add(resetButton);\r\n buttonPanel.add(exitButton);\r\n }",
"private void buttonInit(){\n for(int i=0; i < 3; i++){\n choice[i] = new JButton();\n\n }\n choice[0].setText(\"10x10 / 8 bombs\");\n choice[0].setBackground(new Color(86, 160, 189));\n\n\n choice[0].addActionListener(l-> makeGamePanel(10, 8));\n\n choice[1].setText(\"15x15 / 30 bombs\");\n choice[1].setBackground(new Color(238, 160, 160));\n\n\n choice[1].addActionListener(l-> makeGamePanel(15,30));\n\n choice[2].setText(\"24x24 / 70 bombs\");\n choice[2].setBackground(new Color(253, 230, 122));\n choice[2].setFont(new Font(Font.MONOSPACED, Font.BOLD, 30));\n choice[2].setForeground(new Color(45, 68, 73));\n\n choice[2].addActionListener(l-> makeGamePanel(24,70));\n\n this.add(choice[0], BorderLayout.LINE_START); this.add(choice[1], BorderLayout.LINE_END); this.add(choice[2], BorderLayout.CENTER);\n }",
"public ButtonBar() {\n scrollPane = new JScrollPane();\n scrollPane.setBorder(null);\n scrollPane.setHorizontalScrollBarPolicy(ScrollPaneConstants\n .HORIZONTAL_SCROLLBAR_NEVER);\n scrollPane.setVerticalScrollBarPolicy(ScrollPaneConstants\n .VERTICAL_SCROLLBAR_AS_NEEDED);\n scrollPane.setMinimumSize(new Dimension(0,buttonHeight\n + ((int) PlatformDefaults.getUnitValueX(\"related\").getValue()) * 2));\n \n buttons = Collections.synchronizedMap(new TreeMap<FrameContainer<?>,\n JToggleButton>(new FrameContainerComparator()));\n position = FramemanagerPosition.getPosition(\n IdentityManager.getGlobalConfig().getOption(\"ui\",\n \"framemanagerPosition\"));\n \n if (position.isHorizontal()) {\n buttonPanel = new ButtonPanel(new MigLayout(\"ins rel, fill, flowx\"),\n this);\n } else {\n buttonPanel = new ButtonPanel(new MigLayout(\"ins rel, fill, flowy\"),\n this);\n }\n scrollPane.getViewport().add(buttonPanel);\n }",
"private void addButtonsToPanel() {\n\t\tselectionPanel.add(rock, BorderLayout.WEST);\n\t\tselectionPanel.add(paper, BorderLayout.CENTER);\n\t\tselectionPanel.add(scissors, BorderLayout.EAST);\n\n\t\t// Adds a border with given text\n\t\tselectionPanel.setBorder(BorderFactory\n\t\t\t\t.createTitledBorder(\"Choose wisely. . .\"));\n\t}",
"private void setupButtonPanel() {\n\n Dimension btnSize = new Dimension(100, 50);\n\n exitButton = new JButton(\"Exit\");\n playAgainButton = new JButton(\"Play Again\");\n\n exitButton.setPreferredSize(btnSize);\n playAgainButton.setPreferredSize(btnSize);\n\n buttonPanel.add(playAgainButton);\n buttonPanel.add(exitButton);\n fullPanel.add(buttonPanel, BorderLayout.SOUTH);\n\n playAgainButton.addActionListener(actionEvent -> {\n GameOver.this.dispose();\n new MainScreen();\n });\n exitButton.addActionListener(actionEvent -> System.exit(0));\n }",
"private void generateButtonPanel() {\n buttonsPanel = new JPanel();\n playPauseButton = addButton(\"Play/Pause\");\n restartButton = addButton(\"Restart\");\n speedUpButton = addButton(\"Speed Up\");\n slowDownButton = addButton(\"Slow Down\");\n loopbackButton = addButton(\"Loopback\");\n keyCommandsButton = addButton(\"Key Commands\");\n textViewButton = addButton(\"Animation Text\");\n\n addShapeButton = addButton(\"Add Shape\");\n removeShapeButton = addButton(\"Remove Shape\");\n addKeyframeButton = addButton(\"Add Keyframe\");\n removeKeyframeButton = addButton(\"Remove Keyframe\");\n editKeyframeButton = addButton(\"Edit Keyframe\");\n clearAnimationButton = addButton(\"Clear Animation\");\n clearShapeButton = addButton(\"Clear Shape\");\n buttonsPanel.setLayout(new FlowLayout());\n\n mainPanel.add(buttonsPanel);\n }",
"public void buttonPressed(){\r\n\t\tsetBorder(new BevelBorder(10));\r\n\t}",
"private void setUpAllButtons() {\n\t\t\n\t\tGridLayout leftSideGridLayout = new GridLayout(9,1);\n\t\tleftSideGridLayout.setVgap(20);\n\t\t\n\t\tleftSideOfGUI.setLayout(leftSideGridLayout);\n\t\t\n\t\t/*\n\t\t * JRadioButtons\n\t\t */\n\t\t\n\t\taddVertex = new JRadioButton(\"Add a vertex\");\n\t\taddVertex.addActionListener(radioButtonListener);\n\t\t\n\t\taddEdge = new JRadioButton(\"Add an edge\");\n\t\taddEdge.addActionListener(radioButtonListener);\n\t\t\n\t\tmoveVertex = new JRadioButton(\"Move a vertex\");\n\t\tmoveVertex.addActionListener(radioButtonListener);\n\t\t\n\t\tshortestPath = new JRadioButton(\"Shortest Path\");\n\t\tshortestPath.addActionListener(radioButtonListener);\n\t\t\n\t\t//Weight Sections consists of JRadioButton and JTextArea\n\t\tweightSection = new JPanel();\n\t\tweightSection.setLayout(new GridLayout(1,2));\n\t\t\n\t\tchangeWeight = new JRadioButton(\"Change weight to :\");\n\t\tchangeWeight.addActionListener(radioButtonListener);\n\t\t\n\t\tweightInputText = new JTextField();\n\t\tweightInputText.setPreferredSize(new Dimension(20,20));\n\t\t\n\t\t//Adding JRadioButtons to left JPanel\n\t\tleftSideOfGUI.add(addVertex);\n\t\tleftSideOfGUI.add(addEdge);\n\t\tleftSideOfGUI.add(moveVertex);\n\t\tleftSideOfGUI.add(shortestPath);\n\t\t\n\t\t//Adding specific JPanel to the left side, consists of two components\n\t\tweightSection.add(changeWeight);\n\t\tweightSection.add(weightInputText);\n\t\t\n\t\tleftSideOfGUI.add(weightSection);\n\t\t\n\t\t\n\t\t/*\n\t\t * Buttons\n\t\t */\n\t\t\n\t\taddEdgesButton = new JButton(\"Add All Edges\");\n\t\taddEdgesButton.setPreferredSize(new Dimension(50, 50));\n\t\taddEdgesButton.addActionListener(buttonListener);\n\t\t\n\t\trandomWeightsButton = new JButton(\"Random Weights\");\n\t\trandomWeightsButton.setPreferredSize(new Dimension(50, 50));\n\t\trandomWeightsButton.addActionListener(buttonListener);\n\t\t\n\t\tminimalSpanningTreeButton = new JButton(\"Minimal Tree Spanning\");\n\t\tminimalSpanningTreeButton.setPreferredSize(new Dimension(50, 50));\n\t\tminimalSpanningTreeButton.addActionListener(buttonListener);\n\t\t\n\t\thelpButton = new JButton(\"Help\");\n\t\thelpButton.setPreferredSize(new Dimension(50, 50));\n\t\thelpButton.addActionListener(buttonListener);\n\t\t\n\t\t//Adding Buttons to left side of GUI\n\t\tleftSideOfGUI.add(addEdgesButton);\n\t\tleftSideOfGUI.add(randomWeightsButton);\n\t\tleftSideOfGUI.add(minimalSpanningTreeButton);\n\t\tleftSideOfGUI.add(helpButton);\n\t\t\n\t}",
"private void geometry()\n\t\t{\n\t\t\t// JComponent : Instanciation\n\t\tthis.jPanelAction = new JPanelAction();\n\t\tthis.jPanelCommande = new JPanelCommande(jPanelAction);\n\n\t\t\t// Layout : Specification\n\t\t\t{\n\t\t\tBorderLayout borderLayout = new BorderLayout();\n\t\t\tsetLayout(borderLayout);\n\n\t\t\t// flowlayout.setHgap(20);\n\t\t\t// flowlayout.setVgap(20);\n\t\t\t}\n\n\t\t// JComponent : add\n\t\tthis.add(this.jPanelAction, BorderLayout.CENTER);\n\t\tthis.add(this.jPanelCommande, BorderLayout.SOUTH);\n\t\t}",
"private void setupPanel()\n\t{\n\t\tthis.setLayout(baseLayout);\n\t\tthis.add(firstButton);\n\t\tthis.add(firstField);\n\t}",
"private void buttonsPanel(JPanel panel_buttons) {\n\t\t//BUTTON COMPONENETS\n\t\tJButton btnDraw = new JButton(\"DRAW\");\n\t\tbtnDraw.setMinimumSize(new Dimension(81, 34));\n\t\tbtnDraw.setMaximumSize(new Dimension(81, 34));\n\t\tbtnDraw.setOpaque(true);\n\t\tbtnDraw.setBorderPainted(false);\n\t\tbtnDraw.setHideActionText(true);\n\t\tbtnDraw.setCursor(Cursor.getPredefinedCursor(Cursor.DEFAULT_CURSOR));\n\t\tbtnDraw.setSelected(true);\n\t\tbtnDraw.setRequestFocusEnabled(false);\n\t\tbtnDraw.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t}\n\t\t});\n\t\tbtnDraw.setFont(UIManager.getFont(\"ColorChooser.font.green\"));\n\t\tbtnDraw.setBackground(Color.BLACK);\n\t\tbtnDraw.setForeground(Color.GREEN);\n\t\tbtnDraw.setFont(UIManager.getFont(\"ColorChooser.font.green\"));\n\t\t\n\t\tJButton btnReset = new JButton(\"RESET\");\n\t\tbtnReset.setForeground(Color.RED);\n\t\tbtnReset.setFont(UIManager.getFont(\"Button.font\"));\n\t\tbtnReset.setBorder(null);\n\t\tbtnReset.setOpaque(true);\n\t\tbtnReset.setBackground(Color.BLACK);\n\t\tbtnReset.setName(\"\");\n\t\t\n\t\tJButton btnQuit = new JButton(\"QUIT\");\n\t\tbtnQuit.setMaximumSize(new Dimension(81, 29));\n\t\tbtnQuit.setMinimumSize(new Dimension(81, 29));\n\t\tbtnQuit.setOpaque(true);\n\t\tbtnQuit.setBackground(Color.BLACK);\n\t\tbtnQuit.setBorderPainted(false);\n\t\tbtnQuit.setForeground(Color.WHITE);\n\t\tbtnQuit.setFont(UIManager.getFont(\"ColorChooser.font\"));\n\t\tbtnQuit.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t}\n\t\t});\n\t\t\n\t\t\n\t\t//PANEL LAYOUT FOR BUTTONS\n\t\tGroupLayout gl_panel_Buttons = new GroupLayout(panel_buttons);\n\t\tgl_panel_Buttons.setHorizontalGroup(\n\t\t\tgl_panel_Buttons.createParallelGroup(Alignment.TRAILING)\n\t\t\t\t.addComponent(btnReset, Alignment.LEADING, GroupLayout.DEFAULT_SIZE, 106, Short.MAX_VALUE)\n\t\t\t\t.addComponent(btnQuit, Alignment.LEADING, GroupLayout.DEFAULT_SIZE, 106, Short.MAX_VALUE)\n\t\t\t\t.addComponent(btnDraw, Alignment.LEADING, GroupLayout.DEFAULT_SIZE, 106, Short.MAX_VALUE)\n\t\t);\n\t\tgl_panel_Buttons.setVerticalGroup(\n\t\t\tgl_panel_Buttons.createParallelGroup(Alignment.LEADING)\n\t\t\t\t.addGroup(gl_panel_Buttons.createSequentialGroup()\n\t\t\t\t\t.addComponent(btnDraw, GroupLayout.PREFERRED_SIZE, 78, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t.addComponent(btnReset, GroupLayout.DEFAULT_SIZE, 81, Short.MAX_VALUE)\n\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t.addComponent(btnQuit, GroupLayout.PREFERRED_SIZE, 80, GroupLayout.PREFERRED_SIZE))\n\t\t);\n\t\tpanel_buttons.setLayout(gl_panel_Buttons);\n\t}",
"public Tests () {\r\n\t // Set up display panel\r\n\t Panel panelDisplay = new Panel(new FlowLayout());\r\n\t tfDisplay = new TextField(\"0\", 10);\r\n\t text = new Label(\"Questionnaire CLAN\");\r\n\t panelDisplay.add(text);\r\n\t Color c = new Color(51, 165, 156);\r\n\t Dimension d = new Dimension(180,180);\r\n\t //GraphicsEnvironment ge = GraphicsEnvironment.getLocalGraphicsEnvironment();\r\n\t //ge.getAllFonts();\r\n\t Font myFont = new Font(\"Arial\", Font.BOLD, 15);\r\n\t \r\n\t addWindowListener(new WindowAdapter(){ \r\n\t public void windowClosing(WindowEvent e) { \r\n\t dispose(); \r\n\t } \r\n\t }); \r\n\t \r\n\t // Set up button panel\r\n\t Panel panelButtons = new Panel(new GridLayout(2, 2, 20, 20));\r\n\t btns = new Button[4]; // Construct an array of 10 numeric Buttons\r\n\t btns[0] = new Button(\"Create a Test\"); // Construct Button \"1\"\r\n\t panelButtons.add(btns[0]); // The Panel adds this Button\r\n\t btns[1] = new Button(\"Create a Survey\");\r\n\t panelButtons.add(btns[1]);\r\n\t btns[2] = new Button(\"Take a Test/Survey\");\r\n\t panelButtons.add(btns[2]);\r\n\t btns[3] = new Button(\"View my Tests/Surveys\");\r\n\t panelButtons.add(btns[3]);\r\n\t \r\n\t for(int i=0; i<btns.length; i++){\r\n\t \t btns[i].setPreferredSize(d);\r\n\t\t btns[i].setBackground(c);\r\n\t\t btns[i].setFont(myFont);\r\n\t }\t \r\n\t \r\n\t setLayout(new BorderLayout()); // \"super\" Frame sets to BorderLayout\r\n\t add(panelDisplay, BorderLayout.NORTH);\r\n\t add(panelButtons, BorderLayout.SOUTH);\r\n\t \r\n\t setTitle(\"BorderLayout Demo\"); // \"super\" Frame sets title\r\n\t //setSize(500, 500); // \"super\" Frame sets initial size\r\n\t pack();\r\n\t setVisible(true); // \"super\" Frame shows\r\n\t }",
"private void createButton(JButton button, Component rightOf, Component below, int width, int height,\n JPanel panel) {\n int x = rightOf == null ? 315 : rightOf.getX() + rightOf.getWidth() + 5;\n // rightOf.getX() + rightOf.getWidth() + stdMargin()\n int y = below == null ? 10 : below.getY() + below.getHeight() + 10;\n // below.getY()+ below.getHeight() + stdMargin\n // int width = 250;\n // int height = 30;\n // textField.setOpaque(true);\n // textField.setBackground(Color.CYAN);\n\n button.setBounds(x, y, width, height);\n\n panel.add(button);\n }",
"private void init() {\n setBackground(LIGHT_GRAY);\n Box layout = new Box(BoxLayout.Y_AXIS);\n\n jump = createButton(\"Jump\", null);\n exit = createButton(\"Exit!\", null);\n fly = createButton(\"Fly\", null);\n Jfloat = createButton(\"Float\", null);\n layout.add(Box.createRigidArea(new Dimension(0, 150)));\n layout.add(jump);\n layout.add(Box.createRigidArea(new Dimension(0, 25)));\n layout.add(Jfloat);\n layout.add(Box.createRigidArea(new Dimension(0, 25)));\n layout.add(fly);\n layout.add(Box.createRigidArea(new Dimension(0, 25)));\n layout.add(exit);\n add(layout);\n }",
"public JPanel createDeclarationButtonBar() {\n\tJPanel buttonBar = new JPanel();\n\tBoxLayout boxlay=new BoxLayout(buttonBar,BoxLayout.Y_AXIS); //i think this does setLayout\n\tbuttonBar.setLayout(boxlay);\n\tbuttonBar.setBorder(new BevelBorder(BevelBorder.RAISED));\n\n\t//alignment = left\n\tFlowLayout flowlay1=new FlowLayout(FlowLayout.LEFT); //left justified\n\tFlowLayout flowlay2=new FlowLayout(FlowLayout.LEFT); //left justified\n\tJPanel buttonTopBar = new JPanel(flowlay1); //left justified\n\tJPanel buttonLowerBar = new JPanel(flowlay2);\n\n\t//JButton addVarTopButton=new JButton(\"Add Top Var\"); \n\tJButton addInputPortButton=new JButton(\"Add InputPort\"); \n\tJButton addOutputPortButton=new JButton(\"Add OutputPort\"); \n\tJButton addSubModuleButton=new JButton(\"Add SubModule\"); \n\tJButton addVarBottomButton=new JButton(\"Add Other Variable\"); \n\n\t//buttonTopBar.add(addVarTopButton);\n\tbuttonTopBar.add(addInputPortButton);\n\tbuttonTopBar.add(addOutputPortButton);\n\tbuttonTopBar.add(addSubModuleButton);\n\tbuttonTopBar.add(addVarBottomButton);\n\n\t//addVarTopButton.addActionListener(this);\n\taddInputPortButton.addActionListener(this);\n\taddOutputPortButton.addActionListener(this);\n\taddSubModuleButton.addActionListener(this);\n\taddVarBottomButton.addActionListener(this);\n\n //lower bar\n\n\tJButton changeButton=new JButton(\"Change\"); \n\tchangeButton.addActionListener(this);\n\tbuttonLowerBar.add(changeButton);\n\n\tJButton changeNameButton=new JButton(\"Change Name\"); \n\tchangeNameButton.addActionListener(this);\n\tbuttonLowerBar.add(changeNameButton);\n\n\tJButton copyButton=new JButton(\"Copy\"); \n\tcopyButton.addActionListener(this);\n\tbuttonLowerBar.add(copyButton);\n\n\tJButton deleteButton=new JButton(\"Delete\"); \n\tdeleteButton.addActionListener(this);\n\tbuttonLowerBar.add(deleteButton);\n\n\tJButton upButton=new JButton(\"Up\"); \n\tupButton.addActionListener(this);\n\tbuttonLowerBar.add(upButton);\n\n\tJButton downButton=new JButton(\"Down\"); \n\tdownButton.addActionListener(this);\n\tbuttonLowerBar.add(downButton);\n\n\tJButton topButton=new JButton(\"Top\"); \n\ttopButton.addActionListener(this);\n\tbuttonLowerBar.add(topButton);\n\n\tJButton bottomButton=new JButton(\"Bottom\"); \n\tbottomButton.addActionListener(this);\n\tbuttonLowerBar.add(bottomButton);\n\n buttonBar.add(buttonTopBar);\n buttonBar.add(buttonLowerBar);\n\treturn(buttonBar);\n }",
"public TicTacToePanel()\n {\n //Construct a JPanel\n super();\n \n GridLayout layout;\n \n //Make a 3x3 View\n layout = new GridLayout(3,3);\n layout.setHgap(0);\n layout.setVgap(0);\n \n //Initialize the button array\n ticTacToeButtons = new JButton[9];\n \n //Put everything together\n this.setLayout(layout);\n \n for(int i = 0; i < ticTacToeButtons.length; i++)\n {\n //Initialize Button\n ticTacToeButtons[i] = new JButton();\n \n //Now the loop can work like a for-each\n JButton myButton = ticTacToeButtons[i];\n \n //Setup the button\n myButton.setContentAreaFilled(false);\n this.add(myButton);\n }\n \n validate();\n repaint();\n }",
"protected void createButtons(Panel panel) {\n panel.add(new Filler(24,20));\n\n Choice drawingChoice = new Choice();\n drawingChoice.addItem(fgUntitled);\n\n\t String param = getParameter(\"DRAWINGS\");\n\t if (param == null)\n\t param = \"\";\n \tStringTokenizer st = new StringTokenizer(param);\n while (st.hasMoreTokens())\n drawingChoice.addItem(st.nextToken());\n // offer choice only if more than one\n if (drawingChoice.getItemCount() > 1)\n panel.add(drawingChoice);\n else\n panel.add(new Label(fgUntitled));\n\n\t\tdrawingChoice.addItemListener(\n\t\t new ItemListener() {\n\t\t public void itemStateChanged(ItemEvent e) {\n\t\t if (e.getStateChange() == ItemEvent.SELECTED) {\n\t\t loadDrawing((String)e.getItem());\n\t\t }\n\t\t }\n\t\t }\n\t\t);\n\n panel.add(new Filler(6,20));\n\n Button button;\n button = new CommandButton(new DeleteCommand(\"Delete\", fView));\n panel.add(button);\n\n button = new CommandButton(new DuplicateCommand(\"Duplicate\", fView));\n panel.add(button);\n\n button = new CommandButton(new GroupCommand(\"Group\", fView));\n panel.add(button);\n\n button = new CommandButton(new UngroupCommand(\"Ungroup\", fView));\n panel.add(button);\n\n button = new Button(\"Help\");\n\t\tbutton.addActionListener(\n\t\t new ActionListener() {\n\t\t public void actionPerformed(ActionEvent event) {\n\t\t showHelp();\n\t\t }\n\t\t }\n\t\t);\n panel.add(button);\n\n fUpdateButton = new Button(\"Simple Update\");\n\t\tfUpdateButton.addActionListener(\n\t\t new ActionListener() {\n\t\t public void actionPerformed(ActionEvent event) {\n if (fSimpleUpdate)\n setBufferedDisplayUpdate();\n else\n setSimpleDisplayUpdate();\n\t\t }\n\t\t }\n\t\t);\n\n // panel.add(fUpdateButton); // not shown currently\n }",
"private void $$$setupUI$$$() {\r\n panel1 = new BackGroundPanel();\r\n panel1.setOpaque(false);\r\n panel1.setLayout(new GridLayoutManager(4, 2, new Insets(0, 0, 0, 0), -1, -1));\r\n final Spacer spacer1 = new Spacer();\r\n panel1.add(spacer1, new GridConstraints(1, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_VERTICAL, 1, GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\r\n textPane1 = new JTextArea();\r\n textPane1.setFont(new Font(\"HGMinchoL\", textPane1.getFont().getStyle(), 22));\r\n textPane1.setText(\"\");\r\n textPane1.setEditable(false);\r\n textPane1.setOpaque(false);\r\n panel1.add(textPane1, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_WANT_GROW, null, new Dimension(150, 50), null, 0, false));\r\n final JLabel label1 = new JLabel();\r\n label1.setText(\"Answer:\");\r\n panel1.add(label1, new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\r\n textField1 = new JTextField();\r\n panel1.add(textField1, new GridConstraints(3, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_FIXED, null, new Dimension(150, -1), null, 0, false));\r\n SWINGButton = createButton(\"bat\", \"SWING!\");\r\n //SWINGButton.setText(\"SWING\");\r\n panel1.add(SWINGButton, new GridConstraints(3, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\r\n formattedTextField1 = new JFormattedTextField();\r\n formattedTextField1.setEditable(false);\r\n formattedTextField1.setFont(new Font(\"HGMinchol\", formattedTextField1.getFont().getStyle(), 22));\r\n panel1.add(formattedTextField1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_WEST, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_FIXED, null, new Dimension(150, -1), null, 0, false));\r\n }",
"public FlowPanel(){\r\n setLayout(new FlowLayout());\r\n setBackground(Color.green);\r\n JButton b1 = new JButton(\"Button 1\");\r\n JButton b2 = new JButton(\"Button 2\");\r\n JButton b3 = new JButton(\"Button 3\");\r\n JButton b4 = new JButton(\"Button 4\");\r\n JButton b5 = new JButton(\"Button 5\");\r\n add(b1);\r\n add(b2);\r\n add(b3);\r\n add(b4);\r\n add(b5);\r\n }",
"private void makeFrontGUIButtons(){\n Dimension preferred = getPreferredSize();\n\n optionsButton = new JButton();\n makeFrontButton(optionsButton, \"optionsIcon\", \"showOptions\", new Rectangle((int) preferred.getWidth() - 60, (int) preferred.getHeight() - (int) (preferred.getHeight() * 0.98), 39, 37));\n makeSearchButton();\n\n zoomInButton = new JButton();\n makeFrontButton(zoomInButton, \"plusIcon\", \"zoomIn\", new Rectangle((int) preferred.getWidth() - 60, (int) preferred.getHeight() - (int) preferred.getHeight() / 3 * 2, 39, 37));\n\n zoomOutButton = new JButton();\n makeFrontButton(zoomOutButton, \"minusIcon\", \"zoomOut\", new Rectangle((int) preferred.getWidth() - 60, (int) preferred.getHeight() - (int) (preferred.getHeight() / 3 * 2 + 45), 39, 37));\n\n makeShowRoutePanelButton();\n\n fullscreenButton = new JButton();\n makeFrontButton(fullscreenButton, \"fullscreenIcon\", \"fullscreen\", new Rectangle((int) preferred.getWidth() - 60, (int) (preferred.getHeight() - preferred.getHeight() / 3 * 2 + 100), 39, 37));\n\n mapTypeButton = new JButton();\n makeFrontButton(mapTypeButton, \"layerIcon\", \"mapType\", new Rectangle((int) preferred.getWidth() - 49, (int) (preferred.getHeight() - preferred.getHeight() / 3 * 2 - 45), 39, 37));\n makeCloseDirectionListPanel();\n }",
"protected Panel createButtonPanel() {\n Panel panel = new Panel();\n panel.setLayout(new PaletteLayout(2, new Point(2,2), false));\n return panel;\n }",
"private void setLayout(BorderLayout borderLayout) {\n\t\t\n\t}",
"public ButtonPanel(GameFrame gf) {\n gameFrame = gf;\n JPanel buttonPanel = new JPanel();\n setFocusable(false);\n setBackground(new Color(0x696969));\n setLayout(new FlowLayout(FlowLayout.CENTER, 100, 70));\n add(startButton());\n add(saveButton());\n add(loadButton());\n add(resetButton());\n add(exitButton());\n addListeners();\n }",
"private void createButton(){\n addButton();\n addStartButton();\n }",
"public void initButtons() {\n for (int i = 0; i < 5; i++) {\n for (int j = 0; j < 5; j++) {\n bt[i][j].setOnMouseEntered(e -> {\n Button button;\n button = (Button) e.getSource();\n button.setStyle(\"-fx-border-color:yellow\");\n });\n bt[i][j].setOnMouseExited(e -> {\n Button button;\n button = (Button) e.getSource();\n button.setStyle(\"-fx-border-color:trasparent\");\n });\n\n }\n }\n }",
"@Override\n protected void createButtonsForButtonBar(final Composite parent) {\n\n GridLayout layout = (GridLayout) parent.getLayout();\n layout.marginHeight = 0;\n }",
"public Button(){\n id=1+nbrButton++;\n setBounds(((id-1)*getDimX())/(Data.getNbrLevelAviable()+1),((id-1)*getDimY())/(Data.getNbrLevelAviable()+1),getDimX()/(2*Data.getNbrLevelAviable()),getDimY()/(2*Data.getNbrLevelAviable()));\n setText(id+\"\");\n setFont(Data.getFont());\n addMouseListener(this);\n setVisible(true);\n }",
"public ZeePanel(Spel spel) {\n this.spel = spel;\n buttons = new JButton[16][16];\n setLayout(new GridLayout(16,16,5,5));\n for (int rij=0;rij<16;rij++)\n {\n for (int kolom=0;kolom<16;kolom++)\n {\n buttons[rij][kolom] = new JButton();\n buttons[rij][kolom].setBackground(Color.CYAN);\n add(buttons[rij][kolom]);\n buttons[rij][kolom].addActionListener(this);\n buttons[rij][kolom].setActionCommand(rij + \",\" + kolom);\n }\n }\n }",
"private void setupLayout()\n\t{\n\t\tbaseLayout.putConstraint(SpringLayout.NORTH, queryButton, 70, SpringLayout.NORTH, this);\n\t\tbaseLayout.putConstraint(SpringLayout.WEST, queryButton, 49, SpringLayout.WEST, this);\n\t}",
"public void createButtonGrid() {\n\t\tbuttonPanel.setOpaque(false);\n\t\t\n\t\t// designs array of buttons\n\t\tfor (int counter = 1; counter <= 20; counter++) {\n\t\t\tbuttonArray[counter] = new JButton();\n\t\t\tbuttonArray[counter].setOpaque(false);\n\t\t\tbuttonArray[counter].setVisible(true);\n\t\t\tbuttonArray[counter].setBorderPainted(false);\n\t\t\tbuttonArray[counter].setHorizontalTextPosition(JButton.CENTER);\n\t\t\tbuttonArray[counter].setVerticalTextPosition(SwingConstants.CENTER);\n\t\t\tbuttonArray[counter].setFont(new Font(\"Courier\", Font.PLAIN, 15));\n\t\t\tbuttonArray[counter].setText(\"<html><font color = white>\" + Integer.toString(counter) + \"</font></html>\");\n\t\t\t// add action listener to each button\n\t\t\tbuttonArray[counter].addActionListener(eventsMain);\n\t\t\t// add each button to the container\n\t\t\tbuttonPanel.add(buttonArray[counter]);\n\t\t}\n\t\t\n\t\t// set colour for ach row of buttons\n\t\tfor (int counter = 1; counter <= 20; counter++) {\n\t\t\tif (counter >= 1 && counter < 6) {\n\t\t\t\tbuttonArray[counter].setIcon(btnBlue);\n\t\t\t} else if (counter > 5 && counter < 11) {\n\t\t\t\tbuttonArray[counter].setIcon(btnGreen);\n\t\t\t} else if (counter > 10 && counter < 16) {\n\t\t\t\tbuttonArray[counter].setIcon(btnRed);\n\t\t\t} else if (counter > 15 && counter < 21) {\n\t\t\t\tbuttonArray[counter].setIcon(btnGray);\n\t\t\t}\n\t\t}\n\t}",
"private void init() {\n\t\t\n\t\t// Buttons\n\t\tendButton = new JButton(\"Spiel beenden\");\n\t\tendButton.setBackground(Color.white);\n\t\tendButton.setForeground(Color.black);\n\t\tendButton.setFont(endButton.getFont().deriveFont(20.0f));\n\t\tendButton.setBorder(BorderFactory.createStrokeBorder(new BasicStroke(1.5f), Color.black));\n\t\t\n\t\tanleitungButton = new JButton(\"Anleitung\");\n\t\tanleitungButton.setBackground(endButton.getBackground());\n\t\tanleitungButton.setForeground(endButton.getForeground());\n\t\tanleitungButton.setFont(endButton.getFont());\n\t\tanleitungButton.setBorder(endButton.getBorder());\n\t\t\n\t\tbackButton = new JButton(\"zurück\");\n\t\tbackButton.setBackground(endButton.getBackground());\n\t\tbackButton.setForeground(endButton.getForeground());\n\t\tbackButton.setFont(endButton.getFont());\n\t\tbackButton.setBorder(endButton.getBorder());\n\t\t\n\t\tbuttonPanel = new JPanel(new GridLayout(3, 1, 0, 50));\n\t\tbuttonPanel.add(endButton);\n\t\tbuttonPanel.add(anleitungButton);\n\t\tbuttonPanel.add(backButton);\n\t\tbuttonPanel.setBackground(Color.red.darker());\n\t\t\n\t\tgetContentPane().setLayout(new BorderLayout(40, 40));\n\t\tgetContentPane().add(buttonPanel, BorderLayout.CENTER);\n\t\tgetContentPane().add(new JLabel(), BorderLayout.NORTH);\n\t\tgetContentPane().add(new JLabel(), BorderLayout.SOUTH);\n\t\tgetContentPane().add(new JLabel(), BorderLayout.WEST);\n\t\tgetContentPane().add(new JLabel(), BorderLayout.EAST);\n\t\tgetContentPane().setBackground(buttonPanel.getBackground());\n\t\t\n\t\t// ACTIONLISTENER\n\t\tendButton.addActionListener(new ActionListener() {\n\t\t\t\n\t\t\t@Override\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tdispose();\n\t\t\t\tSystem.exit(0);\n\t\t\t\tcancelGameandGoBackToHome(e);\t\t\t\n\t\t\t}\n\t\t});\n\t\t\n\t\tanleitungButton.addActionListener(new ActionListener() {\n\t\t\t\n\t\t\t@Override\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tdispose();\n\t\t\t\topenAnleitung(e);\n\t\t\t}\n\t\t});\n\t\t\n\t\tbackButton.addActionListener(new ActionListener() {\n\t\t\t\n\t\t\t@Override\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tdispose();\n\t\t\t\tbackToGame(e);\t\t\t\t\t\n\t\t\t}\n\t\t});\n\t}",
"private void setupLayout()\n\t{\n\t\tbaseLayout.putConstraint(SpringLayout.WEST,firstButton,107,SpringLayout.WEST, this);\n\t\tbaseLayout.putConstraint(SpringLayout.SOUTH, firstButton, -32, SpringLayout.SOUTH, this);\n\t\tbaseLayout.putConstraint(SpringLayout.WEST, firstField, 37, SpringLayout.WEST, this);\n\t\tbaseLayout.putConstraint(SpringLayout.SOUTH, firstField, -24, SpringLayout.SOUTH, this);\n\t}",
"public void initializeButtons() {\n\t\tif(null!=itemPanel)\n\t\t\tremove(itemPanel);\n\t\t\n\t\titemPanel = new JPanel();\n\t\titemPanel.setLayout(new FlowLayout());\n\t\tList<Item> allItems = itemDao.readAll();\n\t\t\n\t\t//Sort list of items based on item code.\n\t\tCollections.sort(allItems, new Comparator<Item>() {\n\t\t\t@Override\n\t\t\tpublic int compare(Item o1, Item o2) {\n\t\t\t\tCharacter c1 = o1.getCode();\n\t\t\t\tCharacter c2 = o2.getCode();\n\t\t\t\treturn c1.compareTo(c2);\n\t\t\t}\n\t\t});\n\t\t\n\t\tfor(final Item item : allItems){\n\t\t\tJButton addButton = new JButton(item.getName());\n\t\t\tDeal deal = item.getDeal();\n\t\t\tString dealName = deal == null ? \"\" : \"<br>\" + deal.getName();\n\t\t\t//Set tool tip as description and deal if available\n\t\t\taddButton.setToolTipText(\"<html>\"+item.getDescription()+\"<br>Price: $\"+item.getPrice()\n\t\t\t\t\t+ dealName+\"</html>\");\n\t\t\t//Add item to cart when pressed, also update cartLabel.\n\t\t\taddButton.addActionListener(new ActionListener() {\n\t\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\t\tcart.addItem(item.getCode());\n\t\t\t\t\tcartLabel.setText(cart.size()+ \" items in your cart\");\n\t\t\t\t}\n\t\t\t});\n\t\t\t//addButton.setBounds(10, frameHeight, 75, 20);\n\t\t\taddButton.setSize(new Dimension(75, 20));\n\t\t\titemPanel.add(addButton);\n\t\t}\n\t\t\n\t\titemPanel.setBounds(10, 30, 280, 150);\n\t\tadd(itemPanel);\n\t\tMain.getFrame().setVisible(true);;\n\t}",
"@AutoGenerated\n\tprivate HorizontalLayout buildLayoutButtons() {\n\t\tlayoutButtons = new HorizontalLayout();\n\t\tlayoutButtons.setImmediate(false);\n\t\tlayoutButtons.setWidth(\"-1px\");\n\t\tlayoutButtons.setHeight(\"-1px\");\n\t\tlayoutButtons.setMargin(false);\n\t\t\n\t\t// btnSave\n\t\tbtnSave = new Button();\n\t\tbtnSave.setCaption(\"Salvar\");\n\t\tbtnSave.setImmediate(true);\n\t\tbtnSave.setWidth(\"-1px\");\n\t\tbtnSave.setHeight(\"-1px\");\n\t\tlayoutButtons.addComponent(btnSave);\n\t\t\n\t\t// btnCancel\n\t\tbtnCancel = new Button();\n\t\tbtnCancel.setCaption(\"Cancelar\");\n\t\tbtnCancel.setImmediate(true);\n\t\tbtnCancel.setWidth(\"-1px\");\n\t\tbtnCancel.setHeight(\"-1px\");\n\t\tlayoutButtons.addComponent(btnCancel);\n\t\t\n\t\treturn layoutButtons;\n\t}",
"public BubblePanel()\n\t{\n\t\t// Set the layout to be border-style\n\t\tsuper( new BorderLayout());\n\t\t// Create panel defaults\n\t\tinitPanel();\n\t}",
"private void setupButtons()\n\t{\n\t\tequals.setText(\"=\");\n\t\tequals.setBackground(Color.RED);\n\t\tequals.setForeground(Color.WHITE);\n\t\tequals.setOpaque(true);\n\t\tequals.setFont(new Font(\"Lucida Grande\", Font.PLAIN, 50));\n\t\tequals.setBorder(new CompoundBorder(new LineBorder(Color.LIGHT_GRAY, 5), new LineBorder(Color.BLACK, 3)));\n\t\tclear.setText(\"C\");\n\t\tclear.setBackground(new Color(0, 170, 100));\n\t\tclear.setForeground(Color.WHITE);\n\t\tclear.setOpaque(true);\n\t\tclear.setFont(new Font(\"Lucida Grande\", Font.PLAIN, 50));\n\t\tclear.setBorder(new CompoundBorder(new LineBorder(Color.LIGHT_GRAY, 5), new LineBorder(Color.BLACK, 3)));\n\t\tbackspace.setText(\"<--\");\n\t\tbackspace.setBackground(new Color(0, 170, 100));\n\t\tbackspace.setForeground(Color.WHITE);\n\t\tbackspace.setOpaque(true);\n\t\tbackspace.setFont(new Font(\"Lucida Grande\", Font.PLAIN, 35));\n\t\tbackspace.setBorder(new CompoundBorder(new LineBorder(Color.LIGHT_GRAY, 5), new LineBorder(Color.BLACK, 3)));\n\t\tnegative.setText(\"+/-\");\n\t\tnegative.setBackground(Color.GRAY);\n\t\tnegative.setForeground(Color.WHITE);\n\t\tnegative.setOpaque(true);\n\t\tnegative.setFont(new Font(\"Lucida Grande\", Font.PLAIN, 35));\n\t\tnegative.setBorder(new CompoundBorder(new LineBorder(Color.LIGHT_GRAY, 5), new LineBorder(Color.BLACK, 3)));\n\t}",
"public void buildButtons() {\r\n\t\tImage temp1= display_img.getImage();\r\n\t\tImageIcon img=new ImageIcon(temp1.getScaledInstance(800, 800, Image.SCALE_SMOOTH));\r\n\t\timg1 = img.getImage();\r\n\t\tfor(int y=0;y<10;y++) {\r\n\t\t\tfor(int x=0; x<10; x++) {\r\n\t\t\t\tImage image = Toolkit.getDefaultToolkit().createImage(new FilteredImageSource(img1.getSource(), new CropImageFilter(x * 800 / 10, y * 800 / 10, 100, 100)));\r\n\t\t\t\tImageIcon icon = new ImageIcon(image);\r\n\t\t\t\tJButton temp = new JButton(icon);\r\n\t\t\t\ttemp.putClientProperty(\"position\", new Point(y,x));\r\n\t\t\t\tsolutions.add(new Point(y,x));\r\n\t\t\t\ttemp.putClientProperty(\"isLocked\", false);\r\n\t\t\t\ttemp.addMouseListener(new DragMouseAdapter());\r\n\t\t\t\tgrid[x][y]=temp;\r\n\r\n\t\t\t\tbuttons.add(temp);\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"public void initPanel()\n\t{\n\t\tthis.setVisible(false);\n\t\t//this.setLayout(new BorderLayout());\n \n\t\t//*Layout setup\n\t\t\n\t\tGroupLayout layout = new GroupLayout(this);\n\t\t//this.setLayout(layout);\n\n\t\tlayout.setAutoCreateGaps(true);\n\t\tlayout.setAutoCreateContainerGaps(true);\t\t\n\t\t\t\t\n\t\t//frame = new JFrame();\n offscreenImage = new BufferedImage(width, height, BufferedImage.TYPE_INT_ARGB);\n onscreenImage = new BufferedImage(width, height, BufferedImage.TYPE_INT_ARGB);\n offscreen = offscreenImage.createGraphics();\n onscreen = onscreenImage.createGraphics();\n setXscale();\n setXscale();\n offscreen.setColor(DEFAULT_CLEAR_COLOR);\n offscreen.fillRect(0, 0, width, height);\n setPenColor();\n setPenRadius();\n setFont();\n clear();\n\n // add antialiasing\n RenderingHints hints = new RenderingHints(RenderingHints.KEY_ANTIALIASING,\n RenderingHints.VALUE_ANTIALIAS_ON);\n hints.put(RenderingHints.KEY_RENDERING, RenderingHints.VALUE_RENDER_QUALITY);\n offscreen.addRenderingHints(hints);\n\n \n // frame stuff\n ImageIcon icon = new ImageIcon(onscreenImage);\n drawLabel = new JLabel(icon);\n\n drawLabel.addMouseListener(this);\n drawLabel.addMouseMotionListener(this);\n \n //Create buttons\n resetButton = new JButton();\n undoButton = new JButton();\n \n undoButton.setVisible(true);\n undoButton.setEnabled(true);\n undoButton.setName(\"Undo\");\n undoButton.setText(\"Undo\");\n undoButton.setSize(75, 30);\n undoButton.setPreferredSize(new Dimension(75,30));\n \n resetButton.setVisible(true);\n resetButton.setEnabled(true);\n resetButton.setName(\"Reset\");\n resetButton.setText(\"Reset\");\n \tresetButton.setSize(75, 30);\n \tresetButton.setPreferredSize(new Dimension(75,30));\n \t\n //this.add(resetButton, BorderLayout.NORTH);\n //this.add(undoButton, BorderLayout.NORTH);\n \n // JPanel mainPanel = new JPanel(new BorderLayout());\n\n // JPanel northPanel = new JPanel();\n // northPanel.add(resetButton);\n // northPanel.add(undoButton);\n // mainPanel.add(northPanel, BorderLayout.NORTH);\n // mainPanel.add(drawLabel, BorderLayout.CENTER);\n \n\n // generalColorValue = getColorParameter(Skin.GENERAL_TEXT_COLOR); \n //controlColorValue = getColorParameter(Skin.CONTROL_BACKGROUND_COLOR); \n \n\t\t//trimColorValue = getColorParameter(Skin.TRIM_COLOR); \n\t \n\t\tinitComboBox();\n\t\t//this.setContentPane(drawLabel); <---------------------------\n this.add(drawLabel, BorderLayout.CENTER);\n \n this.addKeyListener(this); // JLabel cannot get keyboard focus\n this.setResizable(true);\n this.setDefaultCloseOperation(JFrame.EXIT_ON_CLOSE); // closes all windows\n //this.setDefaultCloseOperation(JFrame.DISPOSE_ON_CLOSE); // closes only current window\n this.setTitle(name);\n // frame.setJMenuBar(createMenuBar());\n this.pack();\n this.requestFocusInWindow();\n this.setVisible(true);\n \n\t}",
"public ActionButtonPanel() {\n\t\tthis.setBackground(new Color(33, 162, 246));\n\t\tthis.setLayout(new FlowLayout());\n\t\t\n\t\tmoveShepherdButton = new ActionButton(new ImageIcon(Default.moveShepherdButtonUrl));\n\t\tmoveSheepButton = new ActionButton(new ImageIcon(Default.moveSheepButtonUrl));\n\t\tcoupleButton = new ActionButton(new ImageIcon(Default.coupleButtonUrl));\n\t\tcoupleSheepsButton = new ActionButton(new ImageIcon(Default.coupleSheepsButtonUrl));\n\t\tkillButton = new ActionButton(new ImageIcon(Default.killButtonUrl));\n\t\tbuyCardButton = new ActionButton(new ImageIcon(Default.buyCardButtonUrl));\n\t\t\n\t\tthis.add(moveShepherdButton);\n\t\tthis.add(moveSheepButton);\n\t\tthis.add(coupleButton);\n\t\tthis.add(coupleSheepsButton);\n\t\tthis.add(killButton);\n\t\tthis.add(buyCardButton);\n\t\t\n\t\tmoveShepherdButton.setEnabled(false);\n\t\tmoveSheepButton.setEnabled(false);\n\t\tcoupleButton.setEnabled(false);\n\t\tcoupleSheepsButton.setEnabled(false);\n\t\tkillButton.setEnabled(false);\n\t\tbuyCardButton.setEnabled(false);\n\t}",
"private void $$$setupUI$$$() {\n myContentPanel = new JPanel();\n myContentPanel.setLayout(new GridLayoutManager(1, 2, new Insets(0, 0, 0, 0), -1, -1));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(4, 1, new Insets(0, 0, 0, 0), -1, -1));\n myContentPanel.add(panel1, new GridConstraints(0, 1, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n myAcceptYoursButton = new JButton();\n myAcceptYoursButton.setEnabled(false);\n myAcceptYoursButton.setText(\"Accept Yours\");\n myAcceptYoursButton.setMnemonic('Y');\n myAcceptYoursButton.setDisplayedMnemonicIndex(7);\n panel1.add(myAcceptYoursButton, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final Spacer spacer1 = new Spacer();\n panel1.add(spacer1, new GridConstraints(3, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_VERTICAL, 1, GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n myAcceptTheirsButton = new JButton();\n myAcceptTheirsButton.setEnabled(false);\n myAcceptTheirsButton.setText(\"Accept Theirs\");\n myAcceptTheirsButton.setMnemonic('T');\n myAcceptTheirsButton.setDisplayedMnemonicIndex(7);\n panel1.add(myAcceptTheirsButton, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n myMergeButton = new JButton();\n myMergeButton.setEnabled(false);\n myMergeButton.setText(\"Merge\");\n myMergeButton.setMnemonic('M');\n myMergeButton.setDisplayedMnemonicIndex(0);\n panel1.add(myMergeButton, new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JBScrollPane jBScrollPane1 = new JBScrollPane();\n myContentPanel.add(jBScrollPane1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_WANT_GROW, null, null, null, 0, false));\n myItemsTable = new JBTable();\n myItemsTable.putClientProperty(\"Table.isFileList\", Boolean.FALSE);\n jBScrollPane1.setViewportView(myItemsTable);\n }",
"public void setupButton() {\n\t\tHBox buttonPane = new HBox();\n\t\tbuttonPane.setPrefHeight(20);\n\t\t_root.setBottom(buttonPane);\n\t\tButton b1 = new Button(\"Quit\");\t\n\t buttonPane.getChildren().addAll(b1);\n\t b1.setOnAction(new QuitHandler()); // register the button with QuitHandler\n\t buttonPane.setAlignment(Pos.CENTER);\n\t buttonPane.setFocusTraversable(false);\n\t\tbuttonPane.setStyle(\"-fx-background-color: darkblue;\");\n\n\t\n\t}",
"private void designComponents() \n\t{\n\t\tsetLayout(new BoxLayout(this, BoxLayout.Y_AXIS));\n\t\tsetBorder(BorderFactory.createLineBorder(Color.gray));\n\t}",
"public DrawFrame() \n {\n //Initiate title and layout of frame\n super( \"SuperPaint Application!\" );\n setLayout( new BorderLayout() );\n setDefaultCloseOperation( JFrame.EXIT_ON_CLOSE );\n setSize( 600, 600 );\n \n //Initiate draw panel and add it to the center\n panel = new DrawPanel( new JLabel(\"Use mouse to draw.\") );\n add( panel, BorderLayout.CENTER );\n \n //Initiate a panel to store buttons\n buttonJPanel = new JPanel();\n buttonJPanel.setLayout( new GridLayout( 1, AMOUNTOFBUTTONS, 20, 0 ));\n \n //Initiate JButtons and add to panel\n undoButton = new JButton(\"Undo\");\n buttonJPanel.add(undoButton);\n redoButton = new JButton(\"Redo\");\n buttonJPanel.add(redoButton);\n clearButton = new JButton(\"Clear\");\n buttonJPanel.add(clearButton);\n \n //Iniiate ComboBoxes and add to panel\n colorsJComboBox = new JComboBox( colorNames );\n colorsJComboBox.setMaximumRowCount(13);\n buttonJPanel.add(colorsJComboBox);\n shapesJComboBox = new JComboBox( shapeNames );\n shapesJComboBox.setMaximumRowCount(3);\n buttonJPanel.add(shapesJComboBox);\n \n //Initiate CheckBoxes and add to panel\n filledJCheckBox = new JCheckBox( \"Filled\" );\n buttonJPanel.add(filledJCheckBox);\n\n //Add button panel into draw panel\n add(buttonJPanel, BorderLayout.NORTH);\n \n //BUTTON HANDLING\n //Assign JButtons to handler\n ButtonHandler buttonHandler = new ButtonHandler();\n undoButton.addActionListener( buttonHandler );\n redoButton.addActionListener( buttonHandler );\n clearButton.addActionListener( buttonHandler );\n \n //Assign CheckBoxes to handler\n CheckBoxHandler checkBoxHandler = new CheckBoxHandler();\n filledJCheckBox.addItemListener( checkBoxHandler );\n \n //Assign Comboxes to handler \n ComboBoxHandler comboBoxHandler = new ComboBoxHandler();\n colorsJComboBox.addItemListener( comboBoxHandler );\n shapesJComboBox.addItemListener( comboBoxHandler );\n \n //Make frame visible\n setVisible( true );\n }",
"private JPanel createButtonPanel() {\n\t\tJPanel buttonPanel = new JPanel();\n\t\tbuttonPanel.setLayout(new BoxLayout(buttonPanel, BoxLayout.LINE_AXIS));\n\t\t\n\t\tGridBagConstraints gbc = new GridBagConstraints();\n gbc.gridwidth = GridBagConstraints.REMAINDER;\n gbc.anchor = GridBagConstraints.NORTH;\n gbc.anchor = GridBagConstraints.CENTER;\n gbc.fill = GridBagConstraints.HORIZONTAL;\n\t\t\n\t\tJButton okBtn = new JButton(\"Close\");\n\t\t\n\t\tokBtn.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent event) {\n \tsetVisible(false);\n }\n });\n\t\t\n\t\tJPanel buttons = new JPanel(new GridBagLayout());\n buttons.add(okBtn, gbc);\n \n gbc.weighty = 1;\n\t\tbuttonPanel.add(buttons, gbc);\n\t\tbuttonPanel.setBorder(BorderFactory.createEmptyBorder(10, 10, 10, 10));\n\n\t\treturn buttonPanel;\n\t}",
"private void setButtonDimensions() {\n\n int lButtonVisibility = mInfoLButton.getVisibility();\n int rButtonVisibility = mInfoRButton.getVisibility();\n\n if (lButtonVisibility == View.VISIBLE &&\n rButtonVisibility == View.VISIBLE) {\n\n mInfoLButton.setBackgroundResource(R.drawable.drawable_button_dialog_small);\n mInfoRButton.setBackgroundResource(R.drawable.drawable_button_dialog_small);\n\n mInfoLButton.setLayoutParams(mButtonLpSmall);\n mInfoRButton.setLayoutParams(mButtonLpSmall);\n } else {\n\n mInfoLButton.setBackgroundResource(R.drawable.drawable_button_dialog);\n mInfoRButton.setBackgroundResource(R.drawable.drawable_button_dialog);\n\n mInfoLButton.setLayoutParams(mButtonLp);\n mInfoRButton.setLayoutParams(mButtonLp);\n }\n }",
"private JPanel createButtonPanel(){\n JPanel buttonPanel = new JPanel();\n buttonPanel.setLayout(new BoxLayout(buttonPanel, BoxLayout.X_AXIS));\n buttonPanel.setBorder(BorderFactory.createEmptyBorder(VERTICAL_BUFFER,HORIZONTAL_BUFFER,0,HORIZONTAL_BUFFER));\n\n export = new JButton(\"Export\");\n cancel = new JButton(\"Cancel\");\n\n buttonPanel.add(Box.createHorizontalGlue());\n buttonPanel.add(export);\n buttonPanel.add(Box.createHorizontalStrut(HORIZONTAL_BUFFER));\n buttonPanel.add(cancel);\n buttonPanel.add(Box.createHorizontalGlue());\n\n return buttonPanel;\n }",
"LayoutType2(QuestionWindow questionWindow){\r\n setLayout(new GridLayout(3,1));\r\n setOpaque(false);\r\n questionText = new JTextField(Language.QUESTION_TEXT);\r\n questionText.setFont(new Font(Font.SERIF,Font.BOLD,22));\r\n abstractAnswers = new LinkedList<>();\r\n this.questionWindow = questionWindow;\r\n\r\n questionPanel = new JPanel();\r\n questionPanel.add(questionText);\r\n\r\n answersPanel = new JPanel(new GridLayout(5,1,3,3));\r\n\r\n buttonsPanel = new JPanel();\r\n addButton = new JButton(Language.ADD_ANSWER_BUTTON_TEXT);\r\n removeButton = new JButton(Language.REMOVE_ANSWER_BUTTON_TEXT);\r\n removeButton.setEnabled(false);\r\n nextButton = new JButton(Language.NEXT_QUESTION_BUTTON_TEXT);\r\n cancelButton = new JButton(Language.CANCEL_BUTTON_TEXT);\r\n\r\n\r\n addButton.addActionListener(new AddAnswerAction(this));\r\n removeButton.addActionListener(new RemoveAnswerAction(this));\r\n cancelButton.addActionListener(new CancelAction(this));\r\n nextButton.addActionListener(new NextQuestionAction());\r\n nextButton.setEnabled(false);\r\n buttonsPanel.add(cancelButton);\r\n buttonsPanel.add(removeButton);\r\n buttonsPanel.add(addButton);\r\n buttonsPanel.add(nextButton);\r\n\r\n\r\n\r\n questionPanel.setOpaque(false);\r\n answersPanel.setOpaque(false);\r\n buttonsPanel.setOpaque(false);\r\n\r\n add(questionPanel);\r\n add(answersPanel);\r\n add(buttonsPanel);\r\n setVisible(true);\r\n\r\n\r\n\r\n }",
"protected void masterLayout() {\r\n gbc.anchor = GridBagConstraints.CENTER;\r\n gbc.insets = new Insets(5, 5, 5, 5);\r\n gbc.fill = GridBagConstraints.NONE;\r\n gbc.weighty = 0.0;\r\n gbc.gridx = 0;\r\n gbc.gridy = 0;\r\n int jbHeight = applyButton.getPreferredSize().height;\r\n int jbWidth = applyButton.getPreferredSize().width;\r\n int mpHeight = mainPanel.getPanel().getPreferredSize().height;\r\n int mpWidth = mainPanel.getPanel().getPreferredSize().width;\r\n\r\n gbc.gridheight = (int) Math.ceil((double) mpHeight / jbHeight);\r\n gbc.gridwidth = (int) Math.ceil((double) mpWidth / jbWidth);\r\n\r\n this.add(mainPanel.getPanel(), gbc);\r\n\r\n gbc.gridy += gbc.gridheight;\r\n gbc.weighty = 1.0;\r\n gbc.fill = GridBagConstraints.VERTICAL;\r\n gbc.anchor = GridBagConstraints.CENTER;\r\n this.add(Box.createVerticalGlue(), gbc);\r\n\r\n gbc.gridx += gbc.gridwidth - 1;\r\n gbc.gridy += 1;\r\n gbc.weighty = 0.0;\r\n gbc.fill = GridBagConstraints.NONE;\r\n gbc.anchor = GridBagConstraints.EAST;\r\n gbc.insets = new Insets(10, 10, 10, 10);\r\n gbc.gridheight = 1;\r\n gbc.gridwidth = 1;\r\n\r\n applyButton.setVisible(true);\r\n\r\n this.add(applyButton, gbc);\r\n }",
"private void createButton() {\n this.setIcon(images.getImageIcon(fileName + \"-button\"));\n this.setActionCommand(command);\n this.setPreferredSize(new Dimension(width, height));\n this.setMaximumSize(new Dimension(width, height));\n }",
"private void geometry()\n\t\t{\n\t\tjLabelNickName = new JLabel(\"Pseudo: \");\n\t\tjLabelPort = new JLabel(\"Port: \");\n\t\tjNickname = new JTextField();\n\t\tjIPLabel = new JIPLabel();\n\t\tjIP = new JTextField();\n\t\tjPort = new JSpinner();\n\t\tjButtonConnection = new JButton(\"Connexion\");\n\n\t\tthis.setLayout(new GridLayout(-1, 1));\n\n\t\tthis.add(jLabelNickName);\n\t\tthis.add(jNickname);\n\t\tthis.add(jIPLabel);\n\t\tthis.add(jIP);\n\t\tthis.add(jLabelPort);\n\t\tthis.add(jPort);\n\t\tthis.add(Box.createVerticalStrut(SPACE));\n\t\tthis.add(jButtonConnection);\n\t\tthis.add(Box.createVerticalGlue());\n\t\t}",
"public void init() {\n setLayout(new GridLayout(n-1, n));\n setFont(new Font(\"SansSerif\", Font.BOLD, 24));\n \n // Baris 1\n add(makeButton(\"X\",Color.red));\n add(makeButton(\"X\",Color.red));\n add(makeButton(\"X\",Color.red));\n add(makeButton(\"Bksp\",Color.red));\n add(makeButton(\"CE\",Color.red));\n add(makeButton(\"X\",Color.red));\n \n // Baris 2\n add(makeButton(\"MC\",Color.red));\n add(new Button(\"7\"));\n add(new Button(\"8\"));\n add(new Button(\"9\"));\n add(new Button(\"/\"));\n add(new Button(\"sqrt\"));\n \n // Baris 3\n add(makeButton(\"MR\",Color.red));\n add(new Button(\"4\"));\n add(new Button(\"5\"));\n add(new Button(\"6\"));\n add(new Button(\"x\"));\n add(new Button(\"%\"));\n \n // Baris 4\n add(makeButton(\"MR\",Color.red));\n add(new Button(\"1\"));\n add(new Button(\"2\"));\n add(new Button(\"3\"));\n add(new Button(\"-\"));\n add(new Button(\"1/x\"));\n\n // Baris 5\n add(makeButton(\"M+\",Color.red));\n add(new Button(\"0\"));\n add(new Button(\"+/-\"));\n add(new Button(\".\"));\n add(new Button(\"+\"));\n add(new Button(\"=\"));\n }",
"private void setButtons(int width, int height) {\n\tint centerX = width / 2;\n\tint centerY = height / 2;\n\tplayButton.setPos(centerX - playButton.getWidth() / 2, centerY + 2\n\t\t* lineHeight);\n\tplaneButton_p1.setPos(centerX - planeButton_p1.getWidth() / 2, centerY\n\t\t+ 1 * lineHeight);\n\tplaneButton_p2.setPos(centerX - planeButton_p2.getWidth() / 2, centerY\n\t\t+ 0 * lineHeight);\n\toptionsButton.setPos(centerX - optionsButton.getWidth() / 2, centerY\n\t\t- 1 * lineHeight);\n\texitButton.setPos(centerX - exitButton.getWidth() / 2, centerY - 5\n\t\t* lineHeight);\n }",
"private void setViewLayout() {\n\t\tthis.setBorder(new EmptyBorder(15, 15, 15, 15));\n\t\tthis.setLayout(new GridLayout(2, 2, 15, 15));\n\t}",
"public ButtonPanel(CalculatorController appController)\n\t{\n\t\tsuper();\n\t\tthis.appController = appController;\n\t\tnumberLayout = new GridLayout(5, 4, 10, 10);\n\t\tzero = new CalculatorButton(appController, \"0\", Color.GRAY);\n\t\tone = new CalculatorButton(appController, \"1\", Color.GRAY);\n\t\ttwo = new CalculatorButton(appController, \"2\", Color.GRAY);\n\t\tthree = new CalculatorButton(appController, \"3\", Color.GRAY);\n\t\tfour = new CalculatorButton(appController, \"4\", Color.GRAY);\n\t\tfive = new CalculatorButton(appController, \"5\", Color.GRAY);\n\t\tsix = new CalculatorButton(appController, \"6\", Color.GRAY);\n\t\tseven = new CalculatorButton(appController, \"7\", Color.GRAY);\n\t\teight = new CalculatorButton(appController, \"8\", Color.GRAY);\n\t\tnine = new CalculatorButton(appController, \"9\", Color.GRAY);\n\t\tpoint = new CalculatorButton(appController, \".\", Color.GRAY);\n\t\tmultiply = new CalculatorButton(appController, \"x\", Color.BLUE);\n\t\tdivide = new CalculatorButton(appController, \"/\", Color.BLUE);\n\t\tadd = new CalculatorButton(appController, \"+\", Color.BLUE);\n\t\tsubtract = new CalculatorButton(appController, \"-\", Color.BLUE);\n\t\tans = new CalculatorButton(appController, \"Ans\", new Color(0, 170, 100));\n\t\tequals = new JButton();\n\t\tclear = new JButton();\n\t\tbackspace = new JButton();\n\t\tnegative = new JButton();\n\t\tsetupPanel();\n\t\tsetupButtons();\n\t\tsetupListeners();\n\t}",
"public ButtonPanel(SnakeFrame snakeFrame) {\n\t\tthis.snakeFrame =snakeFrame;\n\t\t//初始化面板信息\n\t\tinitPanel();\n\t\t//初始化组件信息\n\t\tinitComponents();\n\t\t//添加组件\n\t\taddComponents();\n\t}",
"private void createBottomButtons() {\n // Create a composite that will contain the control buttons.\n Composite bottonBtnComposite = new Composite(shell, SWT.NONE);\n GridLayout gl = new GridLayout(3, true);\n gl.horizontalSpacing = 10;\n bottonBtnComposite.setLayout(gl);\n GridData gd = new GridData(GridData.FILL_HORIZONTAL);\n bottonBtnComposite.setLayoutData(gd);\n\n // Create the Interpolate button.\n gd = new GridData(GridData.FILL_HORIZONTAL);\n interpolateBtn = new Button(bottonBtnComposite, SWT.PUSH);\n interpolateBtn.setText(\"Interpolate\");\n interpolateBtn.setLayoutData(gd);\n interpolateBtn.addSelectionListener(new SelectionAdapter() {\n @Override\n public void widgetSelected(SelectionEvent event) {\n ColorData upperColorData = upperColorWheel.getColorData();\n ColorData lowerColorData = lowerColorWheel.getColorData();\n\n colorBar.interpolate(upperColorData, lowerColorData, rgbRdo\n .getSelection());\n undoBtn.setEnabled(true);\n updateColorMap();\n }\n });\n\n // Create the Undo button.\n gd = new GridData(GridData.FILL_HORIZONTAL);\n undoBtn = new Button(bottonBtnComposite, SWT.PUSH);\n undoBtn.setText(\"Undo\");\n undoBtn.setEnabled(false);\n undoBtn.setLayoutData(gd);\n undoBtn.addSelectionListener(new SelectionAdapter() {\n @Override\n public void widgetSelected(SelectionEvent event) {\n undoBtn.setEnabled(colorBar.undoColorBar());\n updateColorMap();\n redoBtn.setEnabled(true);\n }\n });\n\n // Create the Redo button.\n gd = new GridData(GridData.FILL_HORIZONTAL);\n redoBtn = new Button(bottonBtnComposite, SWT.PUSH);\n redoBtn.setText(\"Redo\");\n redoBtn.setEnabled(false);\n redoBtn.setLayoutData(gd);\n redoBtn.addSelectionListener(new SelectionAdapter() {\n @Override\n public void widgetSelected(SelectionEvent event) {\n redoBtn.setEnabled(colorBar.redoColorBar());\n updateColorMap();\n undoBtn.setEnabled(true);\n }\n });\n\n // Create the Revert button.\n gd = new GridData(GridData.FILL_HORIZONTAL);\n revertBtn = new Button(bottonBtnComposite, SWT.PUSH);\n revertBtn.setText(\"Revert\");\n revertBtn.setLayoutData(gd);\n revertBtn.addSelectionListener(new SelectionAdapter() {\n @Override\n public void widgetSelected(SelectionEvent event) {\n colorBar.revertColorBar();\n updateColorMap();\n undoBtn.setEnabled(false);\n redoBtn.setEnabled(false);\n }\n });\n\n // Create the Save button.\n gd = new GridData(GridData.FILL_HORIZONTAL);\n saveBtn = new Button(bottonBtnComposite, SWT.PUSH);\n saveBtn.setText(\"Save\");\n saveBtn.setLayoutData(gd);\n if( seldCmapName == null ) {\n saveBtn.setEnabled(false);\n }\n \n saveBtn.addSelectionListener(new SelectionAdapter() {\n @Override\n public void widgetSelected(SelectionEvent event) {\n ColorMap cm = (ColorMap) cmapParams.getColorMap();\n seldCmapName = selCmapCombo.getText();\n \n// int sepIndx = seldCmapName.indexOf(File.separator);\n// String cmapCat = seldCmapName.substring(0,seldCmapName.indexOf(File.separator));\n// String cmapName = seldCmapName.substring( seldCmapName.indexOf(File.separator));\n if (lockedCmaps != null && lockedCmaps.isLocked(seldCmapName)) {\n \tMessageDialog confirmDlg = new MessageDialog( \n \t\t\tNcDisplayMngr.getCaveShell(), \n \t\t\t\"Save Colormap\", null, \n \t\t\t\"Colormap \" +seldCmapCat+File.separator +seldCmapName + \n \t\t\t\" already exists and is locked.\\n\\n\" +\n \t\t\t\"You cannot overwrite it.\",\n \t\t\tMessageDialog.INFORMATION, new String[]{\"OK\"}, 0);\n \tconfirmDlg.open();\n \tcolorBar.undoColorBar();\n updateColorMap();\n \treturn;\n } \n else if( ColorMapUtil.colorMapExists( seldCmapCat, seldCmapName ) ) {\n \tMessageDialog confirmDlg = new MessageDialog( \n \t\t\tNcDisplayMngr.getCaveShell(), \n \t\t\t\"Save Colormap\", null, \n \t\t\t\"Colormap \" +seldCmapCat+File.separator +seldCmapName + \n \t\t\t\" already exists.\\n\\n\" +\n \t\t\t\"Do you want to overwrite it?\",\n \t\t\tMessageDialog.QUESTION, new String[]{\"Yes\", \"No\"}, 0);\n \tconfirmDlg.open();\n\n \tif( confirmDlg.getReturnCode() == MessageDialog.CANCEL ) {\n \t\treturn;\n \t}\n }\n\n try {\n ColorMapUtil.saveColorMap( cm, seldCmapCat, seldCmapName );\n \n MessageDialog msgDlg = new MessageDialog( \n \t\t\tNcDisplayMngr.getCaveShell(), \n \t\t\t\"Colormap Saved\", null, \n \t\t\t\"Colormap \" +seldCmapCat+File.separator +seldCmapName + \n \t\t\t\" Saved.\",\n \t\t\tMessageDialog.INFORMATION, new String[]{\"OK\"}, 0);\n \tmsgDlg.open();\n } catch (VizException e) {\n MessageDialog msgDlg = new MessageDialog( \n \t\t\tNcDisplayMngr.getCaveShell(), \n \t\t\t\"Error\", null, \n \t\t\t\"Error Saving Colormap \" +seldCmapCat+File.separator +seldCmapName + \n \t\t\t\"\\n\"+e.getMessage(),\n \t\t\tMessageDialog.ERROR, new String[]{\"OK\"}, 0);\n \tmsgDlg.open();\n }\n\n completeSave();\n }\n });\n\n\n // \n // Create the Delete button.\n gd = new GridData(GridData.FILL_HORIZONTAL);\n gd.grabExcessHorizontalSpace = false;\n deleteBtn = new Button(bottonBtnComposite, SWT.PUSH);\n deleteBtn.setText(\"Delete\");\n deleteBtn.setLayoutData(gd);\n deleteBtn.addSelectionListener(new SelectionAdapter() {\n @Override\n public void widgetSelected(SelectionEvent event) {\n \tdeleteColormap();\n }\n });\n Label sep = new Label(shell, SWT.SEPARATOR|SWT.HORIZONTAL);\n gd = new GridData(GridData.FILL_HORIZONTAL);\n sep.setLayoutData(gd);\n\n // \n // Create the Delete button.\n gd = new GridData(GridData.HORIZONTAL_ALIGN_END);\n Button closeBtn = new Button(shell, SWT.PUSH);\n closeBtn.setText(\" Close \");\n closeBtn.setLayoutData(gd);\n closeBtn.addSelectionListener(new SelectionAdapter() {\n @Override\n public void widgetSelected(SelectionEvent event) {\n \tshell.dispose();\n }\n });\n }",
"public AWTBorderLayoutDemo () {\n setLayout(new BorderLayout(3, 3));\n // \"super\" Frame sets layout to BorderLayout,\n // horizontal and vertical gaps of 3 pixels\n\n // The components are added to the specified zone\n btnNorth = new Button(\"NORTH\");\n add(btnNorth, BorderLayout.NORTH);\n btnSouth = new Button(\"SOUTH\");\n add(btnSouth, BorderLayout.SOUTH);\n btnCenter = new Button(\"CENTER\");\n add(btnCenter, BorderLayout.CENTER);\n btnEast = new Button(\"EAST\");\n add(btnEast, BorderLayout.EAST);\n btnWest = new Button(\"WEST\");\n add(btnWest, BorderLayout.WEST);\n\n setTitle(\"BorderLayout Demo\"); // \"super\" Frame sets title\n setSize(280, 150); // \"super\" Frame sets initial size\n setVisible(true); // \"super\" Frame shows\n }",
"private void setupPanel()\n\t{\n\t\tthis.setLayout(baseLayout);\n\t\tqueryButton = new JButton(\"query\");\n\t\tthis.add(queryButton);\n\t\tthis.add(displayPane);\n\t\tdisplayArea = new JTextArea(10,30);\n\t\tadd(displayArea);\n\t\t\n\t\t\n\t}",
"private void setFixedSize(JButton mainButton, JButton arrowButton) {\n int width = (int)(mainButton.getPreferredSize().getWidth() + arrowButton.getPreferredSize().getWidth());\n int height = (int)Math.max(mainButton.getPreferredSize().getHeight(), arrowButton.getPreferredSize().getHeight());\n \n setMaximumSize(new Dimension(width, height));\n setMinimumSize(new Dimension(width, height));\n setPreferredSize(new Dimension(width, height));\n }",
"private void createpanel4() {\r\n\t\tpanels[3].setLayout(new FlowLayout(FlowLayout.CENTER, 20, 0));\r\n\r\n\t\texecute = new JButton(\"Login\") {\r\n\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic void paint(Graphics g) {\r\n\t\t\t\tg.drawImage(ImageLoader.getImage(\"black_0.4\"), 0, 0, null);\r\n\t\t\t\tsuper.paint(g);\r\n\t\t\t}\r\n\t\t};\r\n\t\texecute.setOpaque(false);\r\n\t\tif (System.getProperty(\"os.name\").startsWith(\"Windows\"))\r\n\t\t\texecute.setForeground(Color.WHITE);\r\n\t\telse\r\n\t\t\texecute.setForeground(Color.BLACK);\r\n\t\texecute.setBorderPainted(true);\r\n\t\texecute.setContentAreaFilled(false);\r\n\t\texecute.setFont(customFont.deriveFont(15f));\r\n\r\n\t\tcancel = new JButton(\"Cancel\") {\r\n\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic void paint(Graphics g) {\r\n\t\t\t\tg.drawImage(ImageLoader.getImage(\"black_0.4\"), 0, 0, null);\r\n\t\t\t\tsuper.paint(g);\r\n\t\t\t}\r\n\t\t};\r\n\t\tcancel.setOpaque(false);\r\n\t\tif (System.getProperty(\"os.name\").startsWith(\"Windows\"))\r\n\t\t\tcancel.setForeground(Color.WHITE);\r\n\t\telse\r\n\t\t\tcancel.setForeground(Color.BLACK);\r\n\t\tcancel.setBorderPainted(true);\r\n\t\tcancel.setContentAreaFilled(false);\r\n\t\tcancel.setFont(customFont.deriveFont(15f));\r\n\r\n\t\tcreateAccount = new JButton(\"New Account\") {\r\n\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic void paint(Graphics g) {\r\n\t\t\t\tg.drawImage(ImageLoader.getImage(\"black_0.4\"), 0, 0, null);\r\n\t\t\t\tsuper.paint(g);\r\n\t\t\t}\r\n\t\t};\r\n\t\tcreateAccount.setOpaque(false);\r\n\t\tif (System.getProperty(\"os.name\").startsWith(\"Windows\"))\r\n\t\t\tcreateAccount.setForeground(Color.WHITE);\r\n\t\telse\r\n\t\t\tcreateAccount.setForeground(Color.BLACK);\r\n\t\tcreateAccount.setBorderPainted(true);\r\n\t\tcreateAccount.setContentAreaFilled(false);\r\n\t\tcreateAccount.setFont(customFont.deriveFont(10f));\r\n\r\n\t\tcancel.setPreferredSize(new Dimension(120, 30));\r\n\t\tcreateAccount.setPreferredSize(new Dimension(120, 30));\r\n\t\texecute.setPreferredSize(new Dimension(120, 30));\r\n\r\n\t\tpanels[3].add(execute);\r\n\t\tpanels[3].add(createAccount);\r\n\t\tpanels[3].add(cancel);\r\n\t\tpanels[3].setOpaque(false);\r\n\t\tallComponents.add(panels[3]);\r\n\t\tthis.backPanel.add(allComponents);\r\n\t\tthis.getContentPane().add(backPanel);\r\n\t\tpanels[3].revalidate();\r\n\r\n\t\tcreateAccount.addMouseListener(\r\n\t\t\t\tnew LoginListener(createAccount, userinfo, passwordbox, guicontroller, cancel, createAccount));\r\n\t\tcancel.addMouseListener(new LoginListener(cancel, userinfo, passwordbox, guicontroller, cancel, createAccount));\r\n\t\texecute.addMouseListener(\r\n\t\t\t\tnew LoginListener(execute, userinfo, passwordbox, guicontroller, cancel, createAccount));\r\n\t}",
"private void addComponents(){\n GridBagConstraints constraints = new GridBagConstraints();\n constraints.anchor = GridBagConstraints.WEST;\n constraints.insets = new Insets(5, 5, 5, 5);\n constraints.fill = GridBagConstraints.BOTH;\n \n // Add components to the panel\n // Note>> the constraints are applied to both panels\n constraints.gridx = 0;\n constraints.gridy = 0; \n subPanel1.add(onDo1, constraints); // Add button to pane 1\n\n constraints.gridx = 1;\n subPanel1.add(onDo2, constraints); // Add button to pane 1\n \n constraints.gridx = 0;\n constraints.gridy = 1; \n subPanel1.add(onDo3, constraints); // Add button to pane 1\n subPanel2.add(l1, constraints); // Add button to pane 2\n \n constraints.gridx = 1;\n constraints.gridy = 1;\n subPanel1.add(onDo4, constraints); // Add button to pane 1\n \n\n // Set border for sub panel 1 \n subPanel1.setBorder(BorderFactory.createTitledBorder(\n BorderFactory.createEtchedBorder(), \"Events\"));\n \n // Set border for sub panel 2 \n subPanel2.setBorder(BorderFactory.createTitledBorder(\n BorderFactory.createEtchedBorder(), \"Debug\"));\n }",
"private void initializeButton(JPanel myPanel) {\n for (int row = 0; row < 8; row++) {\n for (int col = 0; col < 8; col++) {\n JButton myButton = new JButton();\n buttonGrid[row][col] = myButton;\n setButtonIcon(row,col);\n if ((row + col) % 2 == 0)\n myButton.setBackground(Color.WHITE);\n else\n myButton.setBackground(Color.GRAY);\n myButton.setOpaque(true);\n myButton.setBorderPainted(false);\n myButton.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n pieceButtonClicked(e);\n }\n });\n myPanel.add(myButton);\n }\n }\n }",
"private void buildPanel()\n {\n setLayout(new BorderLayout());\n JLabel instr = new JLabel(TOP_HELP);\n instr.setToolTipText(POPUP_HELP);\n add(instr, BorderLayout.NORTH);\n\n final JSplitPane splitPane = new JSplitPane(JSplitPane.HORIZONTAL_SPLIT);\n splitPane.setContinuousLayout(true);\n splitPane.setResizeWeight(.9);\n splitPane.setOneTouchExpandable(true);\n\n mMazeView.setMinimumSize(new Dimension(400, 200));\n splitPane.setLeftComponent(mMazeView);\n mMazeView.setModel(null);\n\n this.mOpenMazes = new MazeList(this.mMazeView);\n this.mOpenMazes.setMinimumSize(new Dimension(160, 0));\n JPanel rightPanel = new JPanel();\n rightPanel.setLayout(new BorderLayout());\n rightPanel.add(this.mOpenMazes, BorderLayout.CENTER);\n\n final JPanel rightPanelButtons = new JPanel(new BorderLayout());\n rightPanelButtons.add(makeNewMazeButton(), BorderLayout.NORTH);\n rightPanelButtons.add(makeRandomMazeButton(), BorderLayout.SOUTH);\n\n rightPanel.add(rightPanelButtons, BorderLayout.SOUTH);\n splitPane.setRightComponent(rightPanel);\n\n add(splitPane, BorderLayout.CENTER);\n splitPane.setDividerLocation(.8);\n\n addComponentListener(new ComponentAdapter()\n {\n boolean notShown = true;\n\n @Override\n public void componentShown(ComponentEvent e)\n {\n if (notShown)\n {\n splitPane.setDividerLocation(.8);\n notShown = false;\n }\n }\n });\n\n JToolBar tBar = new JToolBar();\n tBar.setOrientation(JToolBar.VERTICAL);\n tBar.setFloatable(false);\n ButtonGroup bg = new ButtonGroup();\n\n ImageIcon scaled = new ImageIcon(mPointIcon.getImage().getScaledInstance(40, 40, 0));\n JToggleButton tb = new JToggleButton(scaled);\n tb.setToolTipText(\"No Template\");\n tb.addActionListener(new TemplateActionListener(null));\n bg.add(tb);\n bg.setSelected(tb.getModel(), true);\n tBar.add(tb);\n\n for (MazeTemplate mt : mTemplates)\n {\n Image iconImage = mt.getTemplateIcon().getImage();\n scaled = new ImageIcon(iconImage.getScaledInstance(40, 40, 0));\n tb = new JToggleButton(scaled);\n tb.addActionListener(new TemplateActionListener(mt));\n tb.setToolTipText(mt.getTemplateDescription());\n bg.add(tb);\n tBar.add(tb);\n }\n\n add(tBar, BorderLayout.WEST);\n\n //Add an action for the 'r' key to change the template to the next orientation.\n this.getInputMap(JComponent.WHEN_ANCESTOR_OF_FOCUSED_COMPONENT).put(KeyStroke.getKeyStroke('r'),\n NEXT_ORIENTATION_ACTION_KEY);\n this.getActionMap().put(NEXT_ORIENTATION_ACTION_KEY, new AbstractAction()\n {\n @Override\n public void actionPerformed(ActionEvent e)\n {\n if (mCurrentTemplate != null)\n {\n mCurrentTemplate.nextOrientation();\n mMazeView.repaint();\n }\n }\n });\n\n mMouseAdapter = new TemplateMouseAdapter();\n\n mMazeView.addMouseListener(mMouseAdapter);\n mMazeView.addMouseMotionListener(mMouseAdapter);\n mMazeView.addMouseWheelListener(mMouseAdapter);\n }",
"public ButtonGrid()\n {\n \t//Sets the dimensions for the ButtonGrid\n \tframe.setLayout(new GridLayout(10, 10));\n JMenuBar menuBar = new JMenuBar();\n frame.setJMenuBar(menuBar);\n \n \n \n //Adds a file and puzzle drop down to the menu bar\n JMenu fileMenu = new JMenu(\"File\");\n JMenu puzzleMenu = new JMenu(\"Puzzle\");\n menuBar.add(fileMenu);\n menuBar.add(puzzleMenu);\n \n //Creates menu items and adds actionlisteners to them\n JMenuItem openAction = new JMenuItem(\"Open\");\n JMenuItem exitAction = new JMenuItem(\"Exit\");\n JMenuItem solveAction = new JMenuItem(\"Solve\");\n JMenuItem newStartAction = new JMenuItem(\"New Start\");\n JMenuItem newFinishAction = new JMenuItem(\"New Finish\");\n openAction.addActionListener(new MenuActionListener(this));\n exitAction.addActionListener(new MenuActionListener(this));\n solveAction.addActionListener(new MenuActionListener(this));\n newStartAction.addActionListener(new MenuActionListener(this));\n newFinishAction.addActionListener(new MenuActionListener(this));\n \n //Adds menu items to the drop-down menus\n fileMenu.add(openAction);\n fileMenu.addSeparator();\n fileMenu.add(exitAction);\n puzzleMenu.add(solveAction);\n puzzleMenu.add(newStartAction);\n puzzleMenu.add(newFinishAction);\n \n //Creates the grid of buttons with the default size being 10 by 10\n grid = new JButton[10][10];\n for(int y = 0; y < 10; y++)\n {\n \tfor(int x = 0; x < 10; x++)\n {\n \t\tgrid[y][x] = new JButton(\"\"); \n frame.add(grid[y][x]);\n }\n } \n frame.setDefaultCloseOperation(JFrame.EXIT_ON_CLOSE);\n frame.pack(); \n frame.setBounds(new Rectangle(330, 360));\n centerOnScreen();\n frame.setVisible(true); \n }",
"@AutoGenerated\r\n\tprivate HorizontalLayout buildButtonsLayout()\r\n\t{\n\t\tbuttonsLayout = new HorizontalLayout();\r\n\t\tbuttonsLayout.setImmediate(false);\r\n\t\tbuttonsLayout.setWidth(\"-1px\");\r\n\t\tbuttonsLayout.setHeight(\"-1px\");\r\n\t\tbuttonsLayout.setMargin(false);\r\n\t\tbuttonsLayout.setSpacing(true);\r\n\t\t\r\n\t\t// addButton\r\n\t\taddButton = new Button();\r\n\t\taddButton.setCaption(\"Add...\");\r\n\t\taddButton.setImmediate(true);\r\n\t\taddButton.setWidth(\"100px\");\r\n\t\taddButton.setHeight(\"-1px\");\r\n\t\tbuttonsLayout.addComponent(addButton);\r\n\t\t\r\n\t\t// editButton\r\n\t\teditButton = new Button();\r\n\t\teditButton.setCaption(\"Edit...\");\r\n\t\teditButton.setImmediate(true);\r\n\t\teditButton.setWidth(\"100px\");\r\n\t\teditButton.setHeight(\"-1px\");\r\n\t\tbuttonsLayout.addComponent(editButton);\r\n\t\t\r\n\t\t// deleteButton\r\n\t\tdeleteButton = new Button();\r\n\t\tdeleteButton.setCaption(\"Delete...\");\r\n\t\tdeleteButton.setImmediate(true);\r\n\t\tdeleteButton.setWidth(\"100px\");\r\n\t\tdeleteButton.setHeight(\"-1px\");\r\n\t\tbuttonsLayout.addComponent(deleteButton);\r\n\t\t\r\n\t\treturn buttonsLayout;\r\n\t}",
"public MainPanel()\n\t{\n\t\tsuper();\n\t\t\n\t\tthis.setLayout(new BoxLayout(this, BoxLayout.Y_AXIS)); \n\t\t_brickbackground = new ImageIcon(\"brickbackground.jpg\").getImage();\n\t\t\n \n\t\t_paddle2 = new PaddleShape();\n\t\t_paddle1 = new PaddleShape();\n \n\t\n\t\t \n\t\t\n\t\t\n\t\tHolder _holder = new Holder(BrickPanel);\n\t\t\n\t\tBrickPanel = new BrickPanel(_holder, _paddle1, _paddle2, controlPanel, this);\n\t\t\n\t\tMainMenu = new MainMenu(this);\n\t\tMainMenu.setLayout(new BoxLayout(MainMenu, BoxLayout.Y_AXIS));\n\t\tMainMenu.setPreferredSize(new Dimension(800, 450));\n\t\tMainMenu.setMaximumSize(new Dimension(800, 450));\n\t\t\n\t\tcontrolPanel = new ControlPanel(BrickPanel, this, _holder, _paddle1, _paddle2, MainMenu);\n\t\tcontrolPanel.setLayout(new GridLayout(1,5));\n\t\tcontrolPanel.setPreferredSize(new Dimension(800, 65));\n\t\tcontrolPanel.setMaximumSize(new Dimension(800, 65));\n\t\t\n\t\t\n\t\t\n\t\t\n\t\t\n\t\t\n\t\tthis.add(BrickPanel); \n\t\tthis.add(controlPanel); \n\t\tthis.add(MainMenu);\n\t\t\n\t\tcontrolPanel.setVisible(false);\n\t\tBrickPanel.setVisible(false);\n\t\tMainMenu.setVisible(true);\n\t\tMyClickListener listener = new MyClickListener(this, BrickPanel, _holder);\n\t\tthis.addMouseListener(listener);\n this.addMouseMotionListener(listener);\n this.addKeyListener(listener);\n\t\tthis.setFocusable(true);\n\t\t\n\t\t//create a button instead of the play rectangle !!!!!!!!!!!!!!!!\n\t\t\n\t\t\n\t\t\n\t}",
"public void paint(Graphics g) \n{ \n int i; \n int x=gRectangle.x;\n int y = gRectangle.y;\n int width=gRectangle.width;\n int height=gRectangle.height;\n \n g.setColor(ButtonColor); \n // Clickable Button \n // Unfortunately Java doesn't seem to have the concept of thickness \n // for borders. To get a border of a certain thickness, we have to \n // draw multiple rectangles having slightly different sizes \n \n for (i=0; i < GC_BUTTON_BORDER_THICKNESS; i++) \n { \n g.draw3DRect(x+i, y+i, width - 2*i+1, height - 2*i+1, raised); \n } \n g.fillRect(x+GC_BUTTON_BORDER_THICKNESS, \n y+GC_BUTTON_BORDER_THICKNESS, \n width -2* GC_BUTTON_BORDER_THICKNESS+2, \n height - 2*GC_BUTTON_BORDER_THICKNESS+2); \n \n // Put the label on the button \n \n g.setColor(Color.black); \n g.setFont(buttonFont);\n g.drawString(ButtonName, x+GC_BUTTON_BORDER_THICKNESS+GC_BUTTON_HORIZ_PAD,\n y+GC_BUTTON_BORDER_THICKNESS+GC_BUTTON_VERT_PAD+fontMaxAscent);\n \n \n // The following was added to see how big the alloted Canvas area was that was \n // made available to our MyButtonClass \n\n g.drawRect(0,0, gRectangle.width+2*GC_CANVAS_HORIZ_GAP-1,\n gRectangle.height+2*GC_CANVAS_VERT_GAP-1);\n\n }",
"private void $$$setupUI$$$() {\n mainPanel = new JPanel();\n mainPanel.setLayout(new GridLayoutManager(1, 1, new Insets(0, 0, 0, 0), -1, -1));\n final JPanel panel1 = new JPanel();\n panel1.setLayout(new GridLayoutManager(5, 1, new Insets(0, 0, 0, 0), -1, -1));\n mainPanel.add(panel1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_BOTH, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, null, null, null, 0, false));\n servicesButton = new JButton();\n servicesButton.setText(\"Services management\");\n panel1.add(servicesButton, new GridConstraints(1, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n surveysManagementButton = new JButton();\n surveysManagementButton.setText(\"Surveys management\");\n panel1.add(surveysManagementButton, new GridConstraints(2, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n connectingAndResultsButton = new JButton();\n connectingAndResultsButton.setText(\"Conecting surveys to services\");\n panel1.add(connectingAndResultsButton, new GridConstraints(3, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n final JLabel label1 = new JLabel();\n label1.setText(\"Choose option below\");\n panel1.add(label1, new GridConstraints(0, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_NONE, GridConstraints.SIZEPOLICY_FIXED, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n results = new JButton();\n results.setText(\"Browse the results\");\n panel1.add(results, new GridConstraints(4, 0, 1, 1, GridConstraints.ANCHOR_CENTER, GridConstraints.FILL_HORIZONTAL, GridConstraints.SIZEPOLICY_CAN_SHRINK | GridConstraints.SIZEPOLICY_CAN_GROW, GridConstraints.SIZEPOLICY_FIXED, null, null, null, 0, false));\n }",
"JPanel createButtonPane()\n {\n // create the Ok button\n _okButton = new JButton(\"OK\");\n _okButton.addActionListener(this);\n _panel.add(_okButton);\n\n // create the Cancel button\n _cancelButton = new JButton(\"Cancel\");\n _cancelButton.addActionListener(this);\n _panel.add(_cancelButton);\n\n // make ok button size same as cancel size\n _okButton.setPreferredSize(_cancelButton.getPreferredSize());\n\n /*\n * Use a BoxLayout for the Ok/Cancel button panel. How to use BoxLayout:\n * https://docs.oracle.com/javase/tutorial/uiswing/layout/box.html\n */\n JPanel tButtonPane = new JPanel();\n tButtonPane.setLayout(new BoxLayout(tButtonPane, BoxLayout.LINE_AXIS));\n tButtonPane.add(Box.createHorizontalGlue());\n tButtonPane.add(_okButton);\n tButtonPane.add(Box.createRigidArea(new Dimension(25, 0)));\n tButtonPane.add(_cancelButton);\n tButtonPane.add(Box.createHorizontalGlue());\n\n /*\n * To enlarge the button pane height, add a rigid area with extra height\n * but zero width.\n * Note that we could have just modified the height of the rigid area\n * between the ok and cancel buttons accordingly, instead of adding the\n * zero width rigid area here.\n */\n Dimension tDim = _okButton.getPreferredSize();\n tDim.width = 0;\n tDim.height += 20;\n tButtonPane.add(Box.createRigidArea(tDim));\n return tButtonPane;\n }",
"public ControlPanel(DrawingPanel c){\n canvas = c;\n this.colorButton = new JButton(\"Pick Color\");\n add(colorButton);\n panel = new JPanel();\n panel.setBackground(Color.BLUE);\n add(panel);\n this.circleButton = new JButton(\"Add Circle\");\n add(circleButton);\n this.squareButton = new JButton(\"Add Square\");\n add(squareButton);\n \n ClickListener listener = new ClickListener();\n this.colorButton.addActionListener(listener);\n this.circleButton.addActionListener(listener);\n this.squareButton.addActionListener(listener);}",
"public void createButtons() {\n\t\tescapeBackground = new GRect(200, 150, 300, 400);\n\t\tescapeBackground.setFilled(true);\n\t\tescapeBackground.setColor(Color.gray);\n\n\t\tbutton1 = new GButton(\"Return to Game\", 250, 175, 200, 50, Color.cyan);\n\t\tbutton3 = new GButton(\"Exit Level\", 250, 330, 200, 50, Color.cyan);\n\t\tbutton4 = new GButton(\"Return to Menu\", 250, 475, 200, 50, Color.cyan);\n\n\t\tescapeButtons.add(button1);\n\t\tescapeButtons.add(button3);\n\t\tescapeButtons.add(button4);\n\n\t}",
"private void createOperationsPanel() {\n\t\toperationsPanel = new JPanel(new GridLayout(5, 1));\n\n\t\tspanningTreeButton = new JButton(\"Árvore de cobertura\");\n\t\tspanningTreeButton.addActionListener(new SpanningTreeHandler());\n\n\t\tblockingStatesButton = new JButton(\"Estados bloqueantes\");\n\t\tblockingStatesButton.addActionListener(new BlockingStatesHandler());\n\n\t\tnonLimitedStatesButton = new JButton(\"Estados não-limitados\");\n\t\tnonLimitedStatesButton.addActionListener(new NonLimitedStatesHandler());\n\n\t\tnetworkConservationButton = new JButton(\"Conservação da rede\");\n\t\tnetworkConservationButton.addActionListener(new NetworkConservationHandler());\n\n\t\treachabelStateButton = new JButton(\"Estado alcançável\");\n\t\treachabelStateButton.addActionListener(new ReachableStateHandler());\n\n\t\toperationsPanel.add(spanningTreeButton);\n\t\toperationsPanel.add(blockingStatesButton);\n\t\toperationsPanel.add(nonLimitedStatesButton);\n\t\toperationsPanel.add(networkConservationButton);\n\t\toperationsPanel.add(reachabelStateButton);\n\n\t\tthis.add(operationsPanel, BorderLayout.WEST);\n\t}",
"private void createPanel() {\n JPanel panel = new JPanel();\n \n for(int i = 0; i < button.size(); i++){\n panel.add(button.get(i));\n }\n panel.add(label);\n \n add(panel);\n }",
"private void initializeButtonPanel() {\n buttonPanel = new ButtonPanel();\n radioPanel = new JPanel(new GridLayout(0, 1));\n ButtonGroup buttonGroup = new ButtonGroup();\n Collections.addAll(toDoButtonList,task1,task2,task3,task4,task5,task6);\n for (int i=0;i<toDoButtonList.size();i++){\n JRadioButton task = toDoButtonList.get(i);\n buttonGroup.add(task);\n radioPanel.add(task);\n }\n\n refresh();\n\n }",
"public JPanel emptyGameControllerView(){\n JPanel p_globalControls = new JPanel(new GridBagLayout());\n p_globalControls.setOpaque(false);\n \n GridBagConstraints c = new GridBagConstraints();\n\n //init\n JButton b_roll = new JButton();\n JButton b_bet5 = new JButton();\n JButton b_bet10 = new JButton();\n JButton b_deposit = new JButton();\n \n //format\n b_roll.setOpaque(false);\n b_roll.setMargin(new Insets(0, 0, 0, 0));\n b_roll.setBorder(new EmptyBorder(0, 0, 0, 0));\n try {\n Image img = ImageIO.read(getClass().getResource(\"./graphics/button_Roll.png\"));\n Image newimg = img.getScaledInstance(100,50,java.awt.Image.SCALE_SMOOTH ); \n b_roll.setIcon(new ImageIcon(newimg));\n }catch (IOException ex) {\n //do nothing...\n }\n b_bet5.setOpaque(false);\n b_bet5.setMargin(new Insets(0, 0, 0, 0));\n b_bet5.setBorder(new EmptyBorder(0, 0, 0, 0));\n try {\n Image img = ImageIO.read(getClass().getResource(\"./graphics/button_Bet5.png\"));\n Image newimg = img.getScaledInstance(100,50,java.awt.Image.SCALE_SMOOTH ); \n b_bet5.setIcon(new ImageIcon(newimg));\n }catch (IOException ex) {\n //do nothing...\n }\n b_bet10.setOpaque(false);\n b_bet10.setMargin(new Insets(0, 0, 0, 0));\n b_bet10.setBorder(new EmptyBorder(0, 0, 0, 0));\n try {\n Image img = ImageIO.read(getClass().getResource(\"./graphics/button_Bet10.png\"));\n Image newimg = img.getScaledInstance(100,50,java.awt.Image.SCALE_SMOOTH ); \n b_bet10.setIcon(new ImageIcon(newimg));\n }catch (IOException ex) {\n //do nothing...\n }\n b_deposit.setOpaque(false);\n b_deposit.setMargin(new Insets(0, 0, 0, 0));\n b_deposit.setBorder(new EmptyBorder(0, 0, 0, 0));\n try {\n Image img = ImageIO.read(getClass().getResource(\"./graphics/button_Deposit.png\"));\n Image newimg = img.getScaledInstance(145,30,java.awt.Image.SCALE_SMOOTH ); \n b_deposit.setIcon(new ImageIcon(newimg));\n }catch (IOException ex) {\n //do nothing...\n }\n \n //add to parent container\n c.anchor = GridBagConstraints.NORTHEAST;\n c.weightx = 1.0;\n c.weighty = 1.0;\n c.insets = new Insets(0,0,0,0);\n c.gridx = 0;\n c.gridx = 0;\n p_globalControls.add(b_bet5,c);\n c.gridx = 1;\n p_globalControls.add(b_bet10,c);\n c.insets = new Insets(0,60,0,5);\n c.gridx = 2;\n p_globalControls.add(b_roll,c);\n c.insets = new Insets(15,0,0,0);\n c.gridx = 3;\n p_globalControls.add(b_deposit,c);\n \n return p_globalControls;\n }",
"private void init(){\n\t\tbtn.setLabel(name);\n\t\tlbl.setText(\"\"+price+\" C\");\n\t\t\n\t\tlbl.setBackground(Color.lightGray);\n\t\tlbl.setFocusable(false);\n\t\tlbl.setPreferredSize(new Dimension(50,24));\n\t\tsetLayout(new GridBagLayout());\n\t\tadd(btn,new GridBagConstraints(0,0,1,1,1.0,0.0,\n\t\t\t GridBagConstraints.WEST,GridBagConstraints.HORIZONTAL,\n\t\t\t new Insets(5,10,0,0),10,4));\n\t\tadd(lbl,new GridBagConstraints(1,0,1,1,0.0,0.0,\n\t\t\t GridBagConstraints.CENTER,GridBagConstraints.NONE,\n\t\t\t new Insets(5,15,0,0),50,0));\n\t\tadd(wnd,new GridBagConstraints(2,0,1,1,0.0,0.0,\n\t\t\t GridBagConstraints.WEST,GridBagConstraints.NONE,\n\t\t\t new Insets(5,4,0,0),10,0));\n\t}",
"private void setupButtonUI(Button b, String ff, double f, double w, Pos p, double x, double y) {\n\t\tb.setFont(Font.font(ff, f));\n\t\tb.setMinWidth(w);\n\t\tb.setAlignment(p);\n\t\tb.setLayoutX(x);\n\t\tb.setLayoutY(y);\n\t}",
"private void initComponents() {\r\n\t\tResourceImageReference imageReference1 = new ResourceImageReference(\r\n\t\t\t\t\"/pds/web/resource/image/mainback-gray.jpg\");\r\n\t\tthis.setBackgroundImage(new FillImage(imageReference1));\r\n\t\tSplitPane splitPane1 = new SplitPane();\r\n\t\tsplitPane1.setStyleName(\"Default\");\r\n\t\tsplitPane1.setSeparatorVisible(false);\r\n\t\tadd(splitPane1);\r\n\t\tColumn column1 = new Column();\r\n\t\tsplitPane1.add(column1);\r\n\t\tpdsColumn = new Column();\r\n\t\tpdsColumn.setVisible(false);\r\n\t\tpdsColumn.setInsets(new Insets(new Extent(30, Extent.PX)));\r\n\t\tpdsColumn.setCellSpacing(new Extent(20, Extent.PX));\r\n\t\tRowLayoutData pdsColumnLayoutData = new RowLayoutData();\r\n\t\tpdsColumnLayoutData.setAlignment(new Alignment(Alignment.LEFT,\r\n\t\t\t\tAlignment.DEFAULT));\r\n\t\tpdsColumn.setLayoutData(pdsColumnLayoutData);\r\n\t\tcolumn1.add(pdsColumn);\r\n\t\tRow row4 = new Row();\r\n\t\trow4.setCellSpacing(new Extent(10, Extent.PX));\r\n\t\tpdsColumn.add(row4);\r\n\t\tButton button1 = new Button();\r\n\t\tbutton1.setStyleName(\"PlainWhite\");\r\n\t\tResourceImageReference imageReference2 = new ResourceImageReference(\r\n\t\t\t\t\"/pds/web/resource/image/accountroot.png\");\r\n\t\tbutton1.setIcon(imageReference2);\r\n\t\tbutton1.setText(\"Account Root\");\r\n\t\tbutton1.addActionListener(new ActionListener() {\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\t\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tonAccountRootActionPerformed(e);\r\n\t\t\t}\r\n\t\t});\r\n\t\trow4.add(button1);\r\n\t\tButton button10 = new Button();\r\n\t\tbutton10.setStyleName(\"PlainWhite\");\r\n\t\tResourceImageReference imageReference3 = new ResourceImageReference(\r\n\t\t\t\t\"/pds/web/resource/image/linkcontracts.png\");\r\n\t\tbutton10.setIcon(imageReference3);\r\n\t\tbutton10.setText(\"Link Contracts\");\r\n\t\tbutton10.addActionListener(new ActionListener() {\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\t\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tonLinkContractsActionPerformed(e);\r\n\t\t\t}\r\n\t\t});\r\n\t\trow4.add(button10);\r\n\t\tfacebookConnectorPanel = new FacebookConnectorPanel();\r\n\t\tfacebookConnectorPanel.setId(\"facebookConnectorPanel\");\r\n\t\trow4.add(facebookConnectorPanel);\r\n\t\tpersonalConnectorPanel = new PersonalConnectorPanel();\r\n\t\tpersonalConnectorPanel.setId(\"personalConnectorPanel\");\r\n\t\trow4.add(personalConnectorPanel);\r\n\t\tallfiledConnectorPanel = new AllfiledConnectorPanel();\r\n\t\tallfiledConnectorPanel.setId(\"allfiledConnectorPanel\");\r\n\t\trow4.add(allfiledConnectorPanel);\r\n\t\tLabel label1 = new Label();\r\n\t\tlabel1.setStyleName(\"Header\");\r\n\t\tlabel1.setText(\"Account Personas\");\r\n\t\tpdsColumn.add(label1);\r\n\t\tRow row7 = new Row();\r\n\t\tpdsColumn.add(row7);\r\n\t\taccountRootGrid = new AccountRootGrid();\r\n\t\trow7.add(accountRootGrid);\r\n\t\tLabel label2 = new Label();\r\n\t\tlabel2.setStyleName(\"Header\");\r\n\t\tlabel2.setText(\"Applications\");\r\n\t\tpdsColumn.add(label2);\r\n\t\tpdsWebAppGrid = new Grid();\r\n\t\tpdsWebAppGrid.setOrientation(Grid.ORIENTATION_HORIZONTAL);\r\n\t\tpdsWebAppGrid.setSize(5);\r\n\t\tpdsColumn.add(pdsWebAppGrid);\r\n\t\tLabel label3 = new Label();\r\n\t\tlabel3.setStyleName(\"Header\");\r\n\t\tlabel3.setText(\"Data Housekeeping\");\r\n\t\tpdsColumn.add(label3);\r\n\t\tRow row5 = new Row();\r\n\t\trow5.setCellSpacing(new Extent(20, Extent.PX));\r\n\t\tpdsColumn.add(row5);\r\n\t\tToolTipContainer toolTipContainer1 = new ToolTipContainer();\r\n\t\trow5.add(toolTipContainer1);\r\n\t\tButton button2 = new Button();\r\n\t\tbutton2.setStyleName(\"PlainWhite\");\r\n\t\tResourceImageReference imageReference4 = new ResourceImageReference(\r\n\t\t\t\t\"/pds/web/resource/image/data-clean.png\");\r\n\t\tbutton2.setIcon(imageReference4);\r\n\t\tbutton2.setText(\"Reset data\");\r\n\t\tbutton2.addActionListener(new ActionListener() {\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\t\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tonResetDataActionPerformed(e);\r\n\t\t\t}\r\n\t\t});\r\n\t\ttoolTipContainer1.add(button2);\r\n\t\tPanel panel1 = new Panel();\r\n\t\tpanel1.setStyleName(\"Tooltip\");\r\n\t\ttoolTipContainer1.add(panel1);\r\n\t\tLabel label4 = new Label();\r\n\t\tlabel4.setStyleName(\"Default\");\r\n\t\tlabel4.setText(\"This will clear all data from your Personal Cloud. Make sure you have a backup!\");\r\n\t\tpanel1.add(label4);\r\n\t\tToolTipContainer toolTipContainer2 = new ToolTipContainer();\r\n\t\trow5.add(toolTipContainer2);\r\n\t\tButton button3 = new Button();\r\n\t\tbutton3.setStyleName(\"PlainWhite\");\r\n\t\tResourceImageReference imageReference5 = new ResourceImageReference(\r\n\t\t\t\t\"/pds/web/resource/image/data-export.png\");\r\n\t\tbutton3.setIcon(imageReference5);\r\n\t\tbutton3.setText(\"Data Export\");\r\n\t\tbutton3.addActionListener(new ActionListener() {\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\t\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tonDataExportActionPerformed(e);\r\n\t\t\t}\r\n\t\t});\r\n\t\ttoolTipContainer2.add(button3);\r\n\t\tPanel panel2 = new Panel();\r\n\t\tpanel2.setStyleName(\"Tooltip\");\r\n\t\ttoolTipContainer2.add(panel2);\r\n\t\tLabel label5 = new Label();\r\n\t\tlabel5.setStyleName(\"Default\");\r\n\t\tlabel5.setText(\"This allows you to download all the contents of your Personal Cloud as an XDI file.\");\r\n\t\tpanel2.add(label5);\r\n\t\tToolTipContainer toolTipContainer3 = new ToolTipContainer();\r\n\t\trow5.add(toolTipContainer3);\r\n\t\tButton button11 = new Button();\r\n\t\tbutton11.setStyleName(\"PlainWhite\");\r\n\t\tResourceImageReference imageReference6 = new ResourceImageReference(\r\n\t\t\t\t\"/pds/web/resource/image/data-import.png\");\r\n\t\tbutton11.setIcon(imageReference6);\r\n\t\tbutton11.setText(\"Data Import\");\r\n\t\tbutton11.addActionListener(new ActionListener() {\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\t\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tonDataImportActionPerformed(e);\r\n\t\t\t}\r\n\t\t});\r\n\t\ttoolTipContainer3.add(button11);\r\n\t\tPanel panel3 = new Panel();\r\n\t\tpanel3.setStyleName(\"Tooltip\");\r\n\t\ttoolTipContainer3.add(panel3);\r\n\t\tLabel label6 = new Label();\r\n\t\tlabel6.setStyleName(\"Default\");\r\n\t\tlabel6.setText(\"This allows you to import data from an XDI file input your Personal Cloud.\");\r\n\t\tpanel3.add(label6);\r\n\t\tColumn column2 = new Column();\r\n\t\tcolumn2.setInsets(new Insets(new Extent(10, Extent.PX)));\r\n\t\tSplitPaneLayoutData column2LayoutData = new SplitPaneLayoutData();\r\n\t\tcolumn2LayoutData.setAlignment(new Alignment(Alignment.RIGHT,\r\n\t\t\t\tAlignment.DEFAULT));\r\n\t\tcolumn2LayoutData.setMinimumSize(new Extent(400, Extent.PX));\r\n\t\tcolumn2LayoutData.setMaximumSize(new Extent(400, Extent.PX));\r\n\t\tcolumn2.setLayoutData(column2LayoutData);\r\n\t\tsplitPane1.add(column2);\r\n\t\tImageIcon imageIcon1 = new ImageIcon();\r\n\t\tResourceImageReference imageReference7 = new ResourceImageReference(\r\n\t\t\t\t\"/pds/web/resource/image/pds-logo.png\");\r\n\t\timageIcon1.setIcon(imageReference7);\r\n\t\timageIcon1.setHeight(new Extent(45, Extent.PX));\r\n\t\timageIcon1.setWidth(new Extent(337, Extent.PX));\r\n\t\timageIcon1.setInsets(new Insets(new Extent(0, Extent.PX), new Extent(\r\n\t\t\t\t10, Extent.PX), new Extent(0, Extent.PX), new Extent(0,\r\n\t\t\t\tExtent.PX)));\r\n\t\tcolumn2.add(imageIcon1);\r\n\t\tRow row2 = new Row();\r\n\t\trow2.setAlignment(new Alignment(Alignment.RIGHT, Alignment.DEFAULT));\r\n\t\trow2.setInsets(new Insets(new Extent(0, Extent.PX), new Extent(0,\r\n\t\t\t\tExtent.PX), new Extent(0, Extent.PX), new Extent(10, Extent.PX)));\r\n\t\trow2.setCellSpacing(new Extent(10, Extent.PX));\r\n\t\tcolumn2.add(row2);\r\n\t\tImageIcon imageIcon2 = new ImageIcon();\r\n\t\tResourceImageReference imageReference8 = new ResourceImageReference(\r\n\t\t\t\t\"/pds/web/resource/image/projectdanube.png\");\r\n\t\timageIcon2.setIcon(imageReference8);\r\n\t\timageIcon2.setHeight(new Extent(68, Extent.PX));\r\n\t\timageIcon2.setWidth(new Extent(68, Extent.PX));\r\n\t\trow2.add(imageIcon2);\r\n\t\tColumn column3 = new Column();\r\n\t\tcolumn3.setCellSpacing(new Extent(10, Extent.PX));\r\n\t\trow2.add(column3);\r\n\t\tlogWindowCheckBox = new CheckBox();\r\n\t\tlogWindowCheckBox.setSelected(false);\r\n\t\tlogWindowCheckBox.setText(\"Show Log Window\");\r\n\t\tlogWindowCheckBox.addActionListener(new ActionListener() {\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\t\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tonLogWindowActionPerformed(e);\r\n\t\t\t}\r\n\t\t});\r\n\t\tcolumn3.add(logWindowCheckBox);\r\n\t\tdeveloperModeCheckBox = new CheckBox();\r\n\t\tdeveloperModeCheckBox.setSelected(false);\r\n\t\tdeveloperModeCheckBox.setText(\"Enable Developer Mode\");\r\n\t\tdeveloperModeCheckBox.addActionListener(new ActionListener() {\r\n\t\t\tprivate static final long serialVersionUID = 1L;\r\n\t\r\n\t\t\tpublic void actionPerformed(ActionEvent e) {\r\n\t\t\t\tonDeveloperModeActionPerformed(e);\r\n\t\t\t}\r\n\t\t});\r\n\t\tcolumn3.add(developerModeCheckBox);\r\n\t\tLogWindowPane logWindowPane1 = new LogWindowPane();\r\n\t\tlogWindowPane1.setVisible(false);\r\n\t\tadd(logWindowPane1);\r\n\t\tEndpointWindowPane accountWindowPane1 = new EndpointWindowPane();\r\n\t\tadd(accountWindowPane1);\r\n\t}",
"public void setLayout() {\n\t\tpersonenListe.getItems().addAll(deck.getPersonenOrdered());\n\t\tpersonenListe.setValue(\"Täter\");\n\t\twaffenListe.getItems().addAll(deck.getWaffenOrdered());\n\t\twaffenListe.setValue(\"Waffe\");\n\t\t// zimmerListe.getItems().addAll(deck.getZimmerOrdered());\n\t\tzimmerListe.setValue(\"Raum\");\n\n\t\tanklage.setMinSize(80, 120);\n\t\tanklage.setMaxSize(80, 120);\n\t\tanklage.setTextFill(Color.BLACK);\n\t\tanklage.setStyle(\"-fx-background-color: #787878;\");\n\n\t\twurfel.setMinSize(80, 120);\n\t\twurfel.setMaxSize(80, 120);\n\t\twurfel.setTextFill(Color.BLACK);\n\t\twurfel.setStyle(\"-fx-background-color: #787878;\");\n\n\t\tgang.setMinSize(80, 120);\n\t\tgang.setMaxSize(80, 120);\n\t\tgang.setTextFill(Color.BLACK);\n\t\tgang.setStyle(\"-fx-background-color: #787878;\");\n\n\t\ttop = new HBox();\n\t\ttop.setSpacing(1);\n\t\ttop.setAlignment(Pos.CENTER);\n\n\t\tbuttons = new HBox();\n\t\tbuttons.setSpacing(20);\n\t\tbuttons.setAlignment(Pos.CENTER);\n\t\tbuttons.getChildren().addAll(anklage, wurfel, gang);\n\n\t\tbottom = new HBox();\n\t\tbottom.setSpacing(150);\n\t\tbottom.setAlignment(Pos.CENTER);\n\t\tbottom.getChildren().addAll(close);\n\n\t\tfenster = new BorderPane();\n\t\tfenster.setStyle(\"-fx-background-image: url('media/ZugFensterResized.png');\");\n\t\tfenster.setTop(top);\n\t\tfenster.setCenter(buttons);\n\t\tfenster.setBottom(bottom);\n\t}",
"public GUI(int size, GUI_I a) {\n listeners = a;\n setLayout(new GridLayout(size, size, size, size));\n setSize(600, 600);\n // \"super\" Frame sets layout to 3x2 GridLayout, horizontal and verical gaps of 3 pixels\n\n // The components are added from left-to-right, top-to-bottom\n\n for (int x = 0; x < size; x++) {\n for (int y = 0; y < size; y++) {\n b[x][y] = (new Button((x + \",\" + y)));\n b[x][y].addActionListener(new buttonListener());\n add(b[x][y]);\n\n }\n }\n\n\n setTitle(\"GridLayout Demo\"); // \"super\" Frame sets title\n setSize(280, 150); // \"super\" Frame sets initial size\n setVisible(true); // \"super\" Frame shows\n }",
"public void createButtons() {\n\n addRow = new JButton(\"Add row\");\n add(addRow);\n\n deleteRow = new JButton(\"Delete row\");\n add(deleteRow);\n }",
"public Planner(){\r\n\t\tsetLayout(new BorderLayout());\r\n\r\n\t\taptManager=new AirportManager(this);\r\n\t\tapt=aptManager.getAirport();\r\n\r\n\r\n JPanel btnPanel= new JPanel();\r\n final JButton btnClear=new JButton(\"Clear All\");\r\n final JButton btnCal=new JButton(\"Make Plan\");\r\n\t\tfinal JButton btnMap=new JButton(\"View Map\");\r\n final JButton btnExit=new JButton(\"Save/Exit\");\r\n Color color = Color.RED.darker();\r\n btnCal.setToolTipText(\"Select 'Make Plan' to start the flight plan, after entering a valid starting airport and destination(s).\");\r\n btnCal.setFont(btnFont);\r\n\t\tbtnCal.setBackground(color);\r\n\t\tbtnCal.setForeground(Color.white);\r\n btnCal.addActionListener(this);\r\n btnClear.setToolTipText(\"Select 'Clear All' to clear all of the currently entered airport data within the Routine Planner.\");\r\n \tbtnClear.addActionListener(this);\r\n \tbtnClear.setFont(btnFont);\r\n \tbtnMap.setToolTipText(\"Select 'View Map' to view a map of the world and current airports.\");\r\n \tbtnMap.setFont(btnFont);\r\n \tbtnMap.addActionListener(this);\r\n \tcolor = Color.GREEN.darker();\r\n \tbtnExit.setToolTipText(\"Select 'Save/Exit' to save and exit the flight plan.\");\r\n \tbtnExit.setFont(btnFont);\r\n\t\tbtnExit.setBackground(color);\r\n\t\tbtnExit.setForeground(Color.white);\r\n \tbtnExit.addActionListener(this);\r\n\r\n \tbtnPanel.setLayout(new GridLayout(4,1,10,10));\r\n \tbtnCal.setPreferredSize(new Dimension(120,70));\r\n \tbtnPanel.add(btnCal);\r\n \tbtnPanel.add(btnClear);\r\n \tbtnPanel.add(btnMap);\r\n \tbtnPanel.add(btnExit);\r\n\r\n \tJPanel show=new JPanel();\r\n \tshow.setLayout(new BoxLayout(show,BoxLayout.Y_AXIS));\r\n \tshow.add(new InputPanel(0));\r\n \tshow.add(new JLabel(\"TO\"));\r\n \tshow.add(new InputPanel(1));\r\n \tmdnScreen=new MultiDestnPanel();\r\n \tshow.add(mdnScreen);\r\n\r\n \tJScrollPane js=new JScrollPane(show);\r\n \tjs.setPreferredSize(new Dimension(300,310));\r\n\r\n\r\n \tJPanel description=new JPanel(new GridLayout(2,1));\r\n \t MatteBorder matte = new MatteBorder(5, 5, 5, 5, Color.LIGHT_GRAY);\r\n des.setBorder(matte);\r\n des.setHorizontalTextPosition(JLabel.CENTER);\r\n \tdes.setVerticalTextPosition(JLabel.TOP);\r\n des.setFont(font);\r\n des.setOpaque(true);\r\n des.setBackground(Color.CYAN);\r\n\t\tdescription.add(des);\r\n \tdescription.add(new JLabel(new ImageIcon(\"image/airplane.png\")));\r\n \tdescription.setBorder(BorderFactory.createEmptyBorder(10, 10, 10, 10));\r\n\r\n \tJPanel routinePlanner=new JPanel();\r\n \troutinePlanner.add(js,BorderLayout.CENTER);\r\n \troutinePlanner.add(btnPanel,BorderLayout.EAST);\r\n \troutinePlanner.setBorder(new TitledBorder(\"Routine Planner\"));\r\n\r\n \taptManager.setPreferredSize(new Dimension(380,300));\r\n \taptManager.setBorder(new TitledBorder(\"Airport Manager\"));\r\n\r\n \tadd(description,BorderLayout.NORTH);\r\n \tadd(aptManager,BorderLayout.WEST);\r\n \tadd(routinePlanner,BorderLayout.CENTER);\r\n\r\n\t\tMap m=new Map(apt);\r\n\t\taptManager.setMap(m);\r\n \tmapScreen=new JDialog(); //map dialog set up\r\n \tmapScreen.add(m);\r\n \tmapScreen.setTitle(\"World Map\");\r\n \tmapScreen.pack();\r\n \tmapScreen.setLocationRelativeTo(null);\r\n \tmapScreen.setResizable(false);\r\n \tmapScreen.setDefaultCloseOperation(JFrame.DISPOSE_ON_CLOSE);\r\n }",
"public void setupBottomPanel() {\n\t\tURL url = getClass().getResource(\".coredata/background/BottomCenter.png\");\n\t\tchatSlot = new ImageIcon(Toolkit.getDefaultToolkit().getImage(url));\n\t\turl = getClass().getResource(\".coredata/background/LeftTeamBans.png\");\n\t\tblueBanSlot = new ImageIcon(Toolkit.getDefaultToolkit().getImage(url));\n\t\turl = getClass().getResource(\".coredata/background/RightTeamBans.png\");\n\t\tpurpleBanSlot = new ImageIcon(Toolkit.getDefaultToolkit().getImage(url));\n\t\tbottomPanel = new JLayeredPane();\n\t\tbottomPanel.setPreferredSize(new Dimension(1280, 243));\n\t\tJLabel blueBanLabel = new JLabel();\n\t\tJLabel chatLabel = new JLabel();\n\t\tJLabel purpleBanLabel = new JLabel();\n\t\tblueBanLabel.setIcon(blueBanSlot);\n\t\tchatLabel.setIcon(chatSlot);\n\t\tpurpleBanLabel.setIcon(purpleBanSlot);\n\t\tbottomPanel.add(blueBanLabel, new Integer(0));\n\t\tbottomPanel.add(chatLabel, new Integer(0));\n\t\tbottomPanel.add(purpleBanLabel, new Integer(0));\n\t\tquit = new JButton();\n\t\tquit.setName(\"quit\");\n\t\tquit.setOpaque(false);\n\t\tquit.addActionListener(this);\n\t\tquit.setBorderPainted(false);\n\t\tquit.setContentAreaFilled(false);\n\t\tquit.setBounds(27, 165, 240, 30);\n\t\tbottomPanel.add(quit, new Integer(1));\n\t\tcreateNoBanButton();\n\t\tadd(bottomPanel, BorderLayout.PAGE_END);\n\t\tblueBanLabel.setBounds(0, 0, 279, 243);\n\t\tchatLabel.setBounds(279, 0, 1004, 243);\n\t\tpurpleBanLabel.setBounds(1004, 0, 1280, 243);\n\t}",
"private void setPanel()\r\n\t{\r\n\t\tpanel = new JPanel();\r\n\t\tpanel.setLayout(new GridLayout(5, 2));\r\n\t\t\r\n\t\tpanel.add(bubbleL);\r\n\t\tpanel.add(bubblePB);\r\n\t\t\r\n\t\tpanel.add(insertionL);\r\n\t\tpanel.add(insertionPB);\r\n\t\t\r\n\t\tpanel.add(mergeL);\r\n\t\tpanel.add(mergePB);\r\n\t\t\r\n\t\tpanel.add(quickL);\r\n\t\tpanel.add(quickPB);\r\n\t\t\r\n\t\tpanel.add(radixL);\r\n\t\tpanel.add(radixPB);\r\n\t}",
"public ButtonPanel(MainPanel m) {\n\n\t\t// Send a reference to the Main Panel\n\t\t// to all of the buttons.\n\n\t\tstep = new StepButton(m);\n\t\tslow = new RunSlowButton(m);\n\t\tfast = new RunFastButton(m);\n\t\tstop = new StopButton(m);\n\t\tlower = new LowerHalfButton(m);\n\t\tupper = new UpperHalfButton(m);\n\t\trepeat = new RepeatButton(m);\n\t\tclear = new ResetButton(m);\n\t\tsetLayout(new FlowLayout());\n\n\t\t// Add all of the buttons\n\n\t\tadd(step);\n\t\tadd(slow);\n\t\tadd(fast);\n\t\tadd(stop);\n\t\tadd(lower);\n\t\tadd(upper);\n\t\tadd(repeat);\n\t\tadd(clear);\n\t}",
"public void setBorderPaneBottomMain(BorderPane bp){\n GridPane numPad = new GridPane();\n bp.setBottom(numPad); \n numPad.getStyleClass().add(\"nodeBkg\");\n \n //numPad setting for responsive \n numPad.setAlignment(Pos.CENTER);\n numPad.prefWidthProperty().bind(bp.widthProperty());\n numPad.prefHeightProperty().bind(bp.heightProperty());\n numPad.setHgap(4.0);\n numPad.setVgap(4.0);\n numPad.setPadding(new Insets (15));\n \n\n // create columns and rows // not sure why but it offsets it to the right?????\n for (int i = 0; i < 4; i++) {\n ColumnConstraints column = new ColumnConstraints();\n column.setPercentWidth(25);\n numPad.getColumnConstraints().add(column);\n }\n\n // essentialy i am altering it until it works 100% is below the screen (not an issue if numpad is set to centre of the borderPane)\n for (int i = 0; i <= 4; i++) { // if set numpad to bottom of BorderPane added a row to fix it extending over bottom (if numpad was set to borderPane center this would not be included)\n RowConstraints row = new RowConstraints();\n if (i < 4){\n row.setPercentHeight(15); //15 x 4 = 60\n }else{\n row.setPercentHeight(25); // 25% for margin at the bottom row (invisable) leaves 15% somewhere\n }\n \n numPad.getRowConstraints().add(row);\n }\n \n \n \n \n // create buttons\n \n Button empty = new Button (Constants.EMPTY);\n Button empty1 = new Button (Constants.EMPTY);\n Button empty2 = new Button (Constants.EMPTY);\n Button empty3 = new Button (Constants.EMPTY);\n Button enter = new Button(Constants.ENTER);\n Button clear = new Button (Constants.CLEAR);\n Button pageReturn = new Button (Constants.RETURN);\n\n Button zero = new Button(Constants.ZERO);\n Button one = new Button(Constants.ONE);\n Button two = new Button(Constants.TWO);\n Button three = new Button(Constants.THREE);\n Button four = new Button(Constants.FOUR);\n Button five = new Button(Constants.FIVE);\n Button six = new Button(Constants.SIX);\n Button seven = new Button(Constants.SEVEN);\n Button eight = new Button(Constants.EIGHT);\n Button nine = new Button(Constants.NINE); \n\n\n\n\n // add buttons to numPad\n //collumn 1\n numPad.add(one,0,0);\n numPad.add(four,0,1);\n numPad.add(seven,0,2);\n numPad.add(empty,0,3);\n\n // column 2\n numPad.add(two,1,0);\n numPad.add(five,1,1);\n numPad.add(eight,1,2);\n numPad.add(zero,1,3);\n\n // column 3\n numPad.add(three,2,0);\n numPad.add(six,2,1);\n numPad.add(nine,2,2);\n numPad.add(empty1,2,3);\n\n // coulumn 4\n numPad.add(empty2,3,0);\n numPad.add(clear,3,1);\n numPad.add(enter,3,2);\n numPad.add(empty3,3,3);\n \n\n \n// // set button size v2 Responsive\n empty.prefWidthProperty().bind(numPad.widthProperty());\n empty.prefHeightProperty().bind(numPad.heightProperty()); \n empty1.prefWidthProperty().bind(numPad.widthProperty());\n empty1.prefHeightProperty().bind(numPad.heightProperty()); \n empty2.prefWidthProperty().bind(numPad.widthProperty());\n empty2.prefHeightProperty().bind(numPad.heightProperty());\n empty3.prefWidthProperty().bind(numPad.widthProperty());\n empty3.prefHeightProperty().bind(numPad.heightProperty()); \n zero.prefWidthProperty().bind(numPad.widthProperty());\n zero.prefHeightProperty().bind(numPad.heightProperty());\n one.prefWidthProperty().bind(numPad.widthProperty());\n one.prefHeightProperty().bind(numPad.heightProperty());\n two.prefWidthProperty().bind(numPad.widthProperty());\n two.prefHeightProperty().bind(numPad.heightProperty());\n three.prefWidthProperty().bind(numPad.widthProperty());\n three.prefHeightProperty().bind(numPad.heightProperty());\n four.prefWidthProperty().bind(numPad.widthProperty());\n four.prefHeightProperty().bind(numPad.heightProperty());\n five.prefWidthProperty().bind(numPad.widthProperty());\n five.prefHeightProperty().bind(numPad.heightProperty());\n six.prefWidthProperty().bind(numPad.widthProperty());\n six.prefHeightProperty().bind(numPad.heightProperty());\n seven.prefWidthProperty().bind(numPad.widthProperty());\n seven.prefHeightProperty().bind(numPad.heightProperty());\n eight.prefWidthProperty().bind(numPad.widthProperty());\n eight.prefHeightProperty().bind(numPad.heightProperty());\n nine.prefWidthProperty().bind(numPad.widthProperty());\n nine.prefHeightProperty().bind(numPad.heightProperty());\n enter.prefWidthProperty().bind(numPad.widthProperty());\n enter.prefHeightProperty().bind(numPad.heightProperty());\n clear.prefWidthProperty().bind(numPad.widthProperty());\n clear.prefHeightProperty().bind(numPad.heightProperty());\n pageReturn.prefWidthProperty().bind(numPad.widthProperty());\n pageReturn.prefHeightProperty().bind(numPad.heightProperty());\n \n \n //Adding styles\n numPad.getStyleClass().add(\"nodeBkg\");\n enter.getStyleClass().add(\"enterButton\");\n clear.getStyleClass().add(\"clearButton\");\n \n zero.getStyleClass().add(\"genericButton\");\n one.getStyleClass().add(\"genericButton\");\n two.getStyleClass().add(\"genericButton\");\n three.getStyleClass().add(\"genericButton\");\n four.getStyleClass().add(\"genericButton\");\n five.getStyleClass().add(\"genericButton\");\n six.getStyleClass().add(\"genericButton\");\n seven.getStyleClass().add(\"genericButton\");\n eight.getStyleClass().add(\"genericButton\");\n nine.getStyleClass().add(\"genericButton\");\n empty.getStyleClass().add(\"genericButton\");\n empty1.getStyleClass().add(\"genericButton\");\n empty2.getStyleClass().add(\"genericButton\");\n empty3.getStyleClass().add(\"genericButton\");\n \n \n \n // set up button actions/events\n // under buttons\n //currentAccount == choosen Account\n // create the account stage\n // change stage\n\n \n one.setOnAction(new EventHandler<ActionEvent>() {\n @Override\n public void handle(ActionEvent event) {\n currentAccount = new SavingAccount();\n createSavingsStage();\n changeStage(mainStage,savingsStage);\n }\n });\n \n two.setOnAction(new EventHandler<ActionEvent>() {\n @Override\n public void handle(ActionEvent event) {\n currentAccount = new NetSavingAccount();\n createNetSavingsStage();\n changeStage(mainStage,netSavingsStage);\n }\n });\n \n three.setOnAction(new EventHandler<ActionEvent>() {\n @Override\n public void handle(ActionEvent event) {\n currentAccount = new ChequeAccount();\n createChequeStage();\n changeStage(mainStage,chequeStage);\n }\n });\n \n four.setOnAction(new EventHandler<ActionEvent>() {\n @Override\n public void handle(ActionEvent event) {\n currentAccount = new FixedAccount();\n createFixedStage();\n changeStage(mainStage,fixedStage);\n }\n });\n \n }",
"public Kal()\n {\n setDefaultCloseOperation( EXIT_ON_CLOSE );\n \n setLayout( new FlowLayout() );\n \n allTheShapes = new Shape[1000];\n \n boxButton = new JButton(\"box\");\n add(boxButton);\n boxButton.addActionListener(this);\n \n addMouseListener(this);\n addMouseMotionListener(this);\n \n setSize( 500,500);\n setVisible( true);\n \n theColorPicker = new ColorPicker3();\n \n }",
"private void preparePanel()\r\n\t{\r\n\t\t\r\n\t\tSystem.out.println(\"[INFO] <RADIOBUTTON_PANEL> Running preparePanel\"); // Debug\r\n\t\t\r\n\t\tthis.setLayout(new GridLayout(0,2)); // Infinite rows 2 columns\r\n\t\t\r\n\t\t// Create a button group for the radio buttons\r\n\t\tgroup = new ButtonGroup();\r\n\t\t\r\n\t\tfor (JRadioButton button : buttons) // Add each button to the array\r\n\t\t{\r\n\t\t\tthis.add(button);\r\n\t\t\tgroup.add(button); // Add the buttons to the button group\r\n\t\t}\r\n\t\t\r\n\t\t// Calculate the number of rows\r\n\t\tint numberOfRows = (buttons.length + 1)/2;\r\n\t\t\r\n\t\t// Make the panel the correct size, 40px per row\r\n\t\tthis.setPreferredSize(new Dimension(700,40*numberOfRows));\r\n\t\tthis.setMaximumSize(new Dimension(700,50*numberOfRows));\r\n\t}"
]
| [
"0.72088665",
"0.69284225",
"0.68910974",
"0.6736612",
"0.6732675",
"0.6701447",
"0.66616315",
"0.6618289",
"0.661206",
"0.65915036",
"0.6567303",
"0.6550717",
"0.65047294",
"0.64689577",
"0.6468821",
"0.6455311",
"0.6435587",
"0.63961613",
"0.63689876",
"0.6352809",
"0.6349881",
"0.6339891",
"0.6333737",
"0.63237226",
"0.6322043",
"0.62946135",
"0.6288865",
"0.6283572",
"0.62626296",
"0.6260027",
"0.6257037",
"0.6254865",
"0.6251804",
"0.6237724",
"0.6219745",
"0.6198937",
"0.6196493",
"0.6186857",
"0.61842567",
"0.6184034",
"0.6180576",
"0.61771977",
"0.61666805",
"0.61659116",
"0.6165511",
"0.616081",
"0.6155229",
"0.6136421",
"0.61286235",
"0.6124458",
"0.6118148",
"0.61178094",
"0.6117738",
"0.6093927",
"0.6093174",
"0.60804105",
"0.60746807",
"0.60743797",
"0.6073626",
"0.60649985",
"0.6058543",
"0.6047103",
"0.6045441",
"0.6041649",
"0.6040216",
"0.6030133",
"0.6023375",
"0.60216624",
"0.60155314",
"0.6013564",
"0.6005372",
"0.6003529",
"0.6003355",
"0.6002307",
"0.5995342",
"0.59835744",
"0.5975577",
"0.59724635",
"0.5964938",
"0.59485656",
"0.5940336",
"0.5937889",
"0.59329844",
"0.59240437",
"0.59209687",
"0.5919445",
"0.5919421",
"0.5910048",
"0.59094626",
"0.5905952",
"0.59021795",
"0.5895633",
"0.58954203",
"0.588973",
"0.5883089",
"0.58812416",
"0.5878263",
"0.5876165",
"0.5873803",
"0.5869971"
]
| 0.7495246 | 0 |
Inflate the menu; this adds items to the action bar if it is present. | @Override
public boolean onCreateOptionsMenu(Menu menu) {
getMenuInflater().inflate(R.menu.cards_list, menu);
return true;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n \tMenuInflater inflater = getMenuInflater();\n \tinflater.inflate(R.menu.main_activity_actions, menu);\n \treturn super.onCreateOptionsMenu(menu);\n }",
"@Override\n public void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n super.onCreateOptionsMenu(menu, inflater);\n inflater.inflate(R.menu.actions, menu);\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n \tgetMenuInflater().inflate(R.menu.actions, menu);\n \treturn super.onCreateOptionsMenu(menu);\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.actions_bar, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tMenuInflater inflater = getMenuInflater();\n\t\tinflater.inflate(R.menu.main_actions, menu);\n\n\t\treturn super.onCreateOptionsMenu(menu);\n\t}",
"@Override\r\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tMenuInflater inflater = getMenuInflater();\r\n\t\tinflater.inflate(R.menu.action_bar_menu, menu);\r\n\t\tmMenu = menu;\r\n\t\treturn super.onCreateOptionsMenu(menu);\r\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.act_bar_menu, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\r\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tMenuInflater inflater = getMenuInflater();\r\n inflater.inflate(R.menu.main_actions, menu);\r\n\t\treturn true;\r\n //return super.onCreateOptionsMenu(menu);\r\n\t}",
"@Override\r\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t MenuInflater inflater = getMenuInflater();\r\n\t inflater.inflate(R.menu.action_bar_all, menu);\r\n\t return super.onCreateOptionsMenu(menu);\r\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(android.view.Menu menu) {\n\t\t super.onCreateOptionsMenu(menu);\n\t\tMenuInflater muu= getMenuInflater();\n\t\tmuu.inflate(R.menu.cool_menu, menu);\n\t\treturn true;\n\t\t\n\t\t\n\t}",
"@Override\r\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.adventure_archive, menu);\r\n\t\treturn true;\r\n\t}",
"@Override\r\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.archive_menu, menu);\r\n\t\treturn true;\r\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.main_activity_actions, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.main_activity_actions, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.main_activity_actions, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n \tpublic void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n \t\tinflater.inflate(R.menu.main, menu);\n \t\tsuper.onCreateOptionsMenu(menu, inflater);\n \t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t MenuInflater inflater = getMenuInflater();\n\t inflater.inflate(R.menu.action_menu, menu);\n\t return super.onCreateOptionsMenu(menu);\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tsuper.onCreateOptionsMenu(menu);\n\t\tMenuInflater bow=getMenuInflater();\n\t\tbow.inflate(R.menu.menu, menu);\n\t\treturn true;\n\t\t}",
"@Override\n public void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n inflater.inflate(R.menu.action_menu, menu);\n super.onCreateOptionsMenu(menu, inflater);\n }",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tMenuInflater inflater = getMenuInflater();\n\t\tinflater.inflate(R.menu.main, menu);\n\t\treturn super.onCreateOptionsMenu(menu);\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tMenuInflater inflater = getMenuInflater();\n\t\tinflater.inflate(R.menu.main, menu);\n\t\treturn super.onCreateOptionsMenu(menu);\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tMenuInflater inflater = getMenuInflater();\n\t\tinflater.inflate(R.menu.main, menu);\n\t\treturn super.onCreateOptionsMenu(menu);\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tMenuInflater inflater = getMenuInflater();\n\t\tinflater.inflate(R.menu.main, menu);\n\t\treturn super.onCreateOptionsMenu(menu);\n\t}",
"@Override\t\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\t\t\n\t\t/* Inflate the menu; this adds items to the action bar if it is present */\n\t\tgetMenuInflater().inflate(R.menu.act_main, menu);\t\t\n\t\treturn true;\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflate = getMenuInflater();\n inflate.inflate(R.menu.menu, ApplicationData.amvMenu.getMenu());\n return true;\n }",
"@Override\n\t\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\t\tgetMenuInflater().inflate(R.menu.menu, menu);\n\t\t\treturn true; \n\t\t\t\t\t\n\t\t}",
"@Override\n\tpublic void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n\t\tinflater.inflate(R.menu.main, menu);\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.menu, menu);//Menu Resource, Menu\n return true;\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.menu, menu);//Menu Resource, Menu\n return true;\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) \n {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.menu_bar, menu);\n return true;\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.menu_item, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n\tpublic void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n\t\tinflater.inflate(R.menu.menu, menu);\n\t\tsuper.onCreateOptionsMenu(menu, inflater);\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t MenuInflater inflater = getMenuInflater();\n\t inflater.inflate(R.menu.menu, menu);\n\t return super.onCreateOptionsMenu(menu);\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tMenuInflater inflater = getMenuInflater();\n\t inflater.inflate(R.menu.menu, menu);\n\t \n\t\treturn super.onCreateOptionsMenu(menu);\n\t}",
"@Override\n\tpublic void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n\t\tsuper.onCreateOptionsMenu(menu, inflater);\n\t\t//menu.clear();\n\t\tinflater.inflate(R.menu.soon_to_be, menu);\n\t\t//getActivity().getActionBar().show();\n\t\t//getActivity().getActionBar().setBackgroundDrawable(\n\t\t\t\t//new ColorDrawable(Color.rgb(223, 160, 23)));\n\t\t//return true;\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n this.getMenuInflater().inflate(R.menu.main, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n super.onCreateOptionsMenu(menu, inflater);\n inflater.inflate(R.menu.main, menu);\n }",
"@Override\n\tpublic void onCreateOptionsMenu( Menu menu, MenuInflater inflater )\n\t{\n\t\tsuper.onCreateOptionsMenu( menu, inflater );\n\t}",
"@Override\r\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.main, menu);\r\n\t\treturn super.onCreateOptionsMenu(menu);\r\n\t}",
"@Override\r\n public boolean onCreateOptionsMenu(Menu menu) {\r\n \t// We must call through to the base implementation.\r\n \tsuper.onCreateOptionsMenu(menu);\r\n \t\r\n MenuInflater inflater = getMenuInflater();\r\n inflater.inflate(R.menu.main_menu, menu);\r\n\r\n return true;\r\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.main, menu);//Menu Resource, Menu\n return true;\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.main, menu);//Menu Resource, Menu\n return true;\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater= getMenuInflater();\n inflater.inflate(R.menu.menu_main, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n super.onCreateOptionsMenu(menu, inflater);\n inflater.inflate(R.menu.inter_main, menu);\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.menu, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.action, menu);\n\t\treturn true;\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.menu, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.menu, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public boolean onCreateOptionsMenu (Menu menu){\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.menu_main, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.custom_action_bar, menu);\n\t\treturn true;\n\t}",
"public void initMenubar() {\n\t\tremoveAll();\n\n\t\t// \"File\"\n\t\tfileMenu = new FileMenuD(app);\n\t\tadd(fileMenu);\n\n\t\t// \"Edit\"\n\t\teditMenu = new EditMenuD(app);\n\t\tadd(editMenu);\n\n\t\t// \"View\"\n\t\t// #3711 viewMenu = app.isApplet()? new ViewMenu(app, layout) : new\n\t\t// ViewMenuApplicationD(app, layout);\n\t\tviewMenu = new ViewMenuApplicationD(app, layout);\n\t\tadd(viewMenu);\n\n\t\t// \"Perspectives\"\n\t\t// if(!app.isApplet()) {\n\t\t// perspectivesMenu = new PerspectivesMenu(app, layout);\n\t\t// add(perspectivesMenu);\n\t\t// }\n\n\t\t// \"Options\"\n\t\toptionsMenu = new OptionsMenuD(app);\n\t\tadd(optionsMenu);\n\n\t\t// \"Tools\"\n\t\ttoolsMenu = new ToolsMenuD(app);\n\t\tadd(toolsMenu);\n\n\t\t// \"Window\"\n\t\twindowMenu = new WindowMenuD(app);\n\n\t\tadd(windowMenu);\n\n\t\t// \"Help\"\n\t\thelpMenu = new HelpMenuD(app);\n\t\tadd(helpMenu);\n\n\t\t// support for right-to-left languages\n\t\tapp.setComponentOrientation(this);\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.main, menu);\n\t\treturn super.onCreateOptionsMenu(menu);\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tsuper.onCreateOptionsMenu(menu);\n\t\tMenuInflater blowUp=getMenuInflater();\n\t\tblowUp.inflate(R.menu.welcome_menu, menu);\n\t\treturn true;\n\t}",
"@Override\r\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.listing, menu);\r\n\t\treturn true;\r\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.item, menu);\n return true;\n }",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.resource, menu);\n\t\treturn true;\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater= getMenuInflater();\n inflater.inflate(R.menu.menu,menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.main, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.main, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.home_action_bar, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.template, menu);\n\t\treturn true;\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n Log.d(\"onCreateOptionsMenu\", \"create menu\");\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.socket_activity_actions, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.main_menu, menu);//Menu Resource, Menu\n\n return true;\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.actionbar, menu);\n return true;\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(toolbar_res, menu);\n updateMenuItemsVisibility(menu);\n return true;\n }",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\t// \n\t\tMenuInflater mi = getMenuInflater();\n\t\tmi.inflate(R.menu.thumb_actv_menu, menu);\n\t\t\n\t\treturn super.onCreateOptionsMenu(menu);\n\t}",
"@Override\n\tpublic void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n\t\tsuper.onCreateOptionsMenu(menu, inflater);\n\t}",
"@Override\n\tpublic void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n\t\tsuper.onCreateOptionsMenu(menu, inflater);\n\t}",
"@Override\n\tpublic void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n\t\tsuper.onCreateOptionsMenu(menu, inflater);\n\t}",
"@Override\n public void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n super.onCreateOptionsMenu(menu, inflater);\n }",
"@Override\n\t\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\t\tgetMenuInflater().inflate(R.menu.main, menu);\n\t\t\treturn true;\n\t\t}",
"@Override\n\t\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\t\tgetMenuInflater().inflate(R.menu.main, menu);\n\t\t\treturn true;\n\t\t}",
"@Override\n\t\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\t\tgetMenuInflater().inflate(R.menu.main, menu);\n\t\t\treturn true;\n\t\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.swag_list_activity_menu, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n public void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n super.onCreateOptionsMenu(menu, inflater);\n\n }",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n MenuInflater inflater = getMenuInflater();\n inflater.inflate(R.menu.main_menu, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n\tpublic boolean onCreateOptionsMenu(android.view.Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.main, menu);\n\n\t\treturn true;\n\t}",
"@Override\n\t\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\t\tgetMenuInflater().inflate(R.menu.main, menu);\n\t\t\treturn true;\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.jarvi, menu);\n\t\treturn super.onCreateOptionsMenu(menu);\n\t}",
"public void onCreateOptionsMenu(Menu menu, MenuInflater inflater){\n }",
"@Override\n public void onCreateOptionsMenu(Menu menu, MenuInflater menuInflater) {\n menuInflater.inflate(R.menu.main, menu);\n\n }",
"@Override\r\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.add__listing, menu);\r\n\t\treturn true;\r\n\t}",
"@Override\r\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.actmain, menu);\r\n return true;\r\n }",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.buat_menu, menu);\n\t\treturn true;\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.layout.menu, menu);\n\t\treturn true;\n\t}",
"@Override\npublic boolean onCreateOptionsMenu(Menu menu) {\n\n\t\n\t\n\tgetMenuInflater().inflate(R.menu.main, menu);\n\t\n\treturn super.onCreateOptionsMenu(menu);\n}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.ichat, menu);\n\t\treturn true;\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.menu, menu);\n return super.onCreateOptionsMenu(menu);\n }",
"@Override\n\tpublic void onCreateOptionsMenu(Menu menu, MenuInflater inflater)\n\t{\n\t\tsuper.onCreateOptionsMenu(menu, inflater);\n\t\tinflater.inflate(R.menu.expenses_menu, menu);\n\t}",
"@Override\n \tpublic boolean onCreateOptionsMenu(Menu menu) {\n \t\tgetMenuInflater().inflate(R.menu.main, menu);\n \t\treturn true;\n \t}",
"@Override\n \tpublic boolean onCreateOptionsMenu(Menu menu) {\n \t\tgetMenuInflater().inflate(R.menu.main, menu);\n \t\treturn true;\n \t}",
"@Override\n \tpublic boolean onCreateOptionsMenu(Menu menu) {\n \t\tgetMenuInflater().inflate(R.menu.main, menu);\n \t\treturn true;\n \t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.action_bar, menu);\n return true;\n }",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tsuper.onCreateOptionsMenu(menu);\n\t\tMenuInflater blowUp = getMenuInflater();\n\t\tblowUp.inflate(R.menu.status, menu);\n\t\treturn true;\n\t}",
"@Override\r\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.menu, menu);\r\n\t\treturn true;\r\n\t}",
"@Override\n\tpublic void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n\t}",
"@Override\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tMenuInflater inflater = getMenuInflater();\n\t\tinflater.inflate(R.menu.main, menu);\n\t\treturn true;\n\t}",
"@Override\r\n\tpublic boolean onCreateOptionsMenu(Menu menu) {\n\t\tgetMenuInflater().inflate(R.menu.ui_main, menu);\r\n\t\treturn true;\r\n\t}",
"@Override\n public boolean onCreateOptionsMenu(Menu menu) {\n getMenuInflater().inflate(R.menu.main_activity_actions, menu);\n return true;\n }",
"@Override\n public void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n inflater.inflate(R.menu.menu_main, menu);\n super.onCreateOptionsMenu(menu, inflater);\n }",
"@Override\n public void onCreateOptionsMenu(Menu menu, MenuInflater inflater) {\n inflater.inflate(R.menu.menu_main, menu);\n super.onCreateOptionsMenu(menu, inflater);\n }"
]
| [
"0.7246102",
"0.7201358",
"0.7194834",
"0.7176498",
"0.71066517",
"0.7039537",
"0.7037961",
"0.70112145",
"0.70094734",
"0.69807225",
"0.6944953",
"0.69389373",
"0.6933199",
"0.6916928",
"0.6916928",
"0.6891486",
"0.68831646",
"0.68754137",
"0.68745375",
"0.68621665",
"0.68621665",
"0.68621665",
"0.68621665",
"0.68515885",
"0.68467957",
"0.68194443",
"0.6817494",
"0.6813087",
"0.6813087",
"0.6812847",
"0.6805774",
"0.6801204",
"0.6797914",
"0.6791314",
"0.6789091",
"0.67883503",
"0.6783642",
"0.6759701",
"0.6757412",
"0.67478645",
"0.6744127",
"0.6744127",
"0.67411774",
"0.6740183",
"0.6726017",
"0.6723245",
"0.67226785",
"0.67226785",
"0.67208904",
"0.67113477",
"0.67079866",
"0.6704564",
"0.6699229",
"0.66989094",
"0.6696622",
"0.66952467",
"0.66865396",
"0.6683476",
"0.6683476",
"0.6682188",
"0.6681209",
"0.6678941",
"0.66772443",
"0.6667702",
"0.66673946",
"0.666246",
"0.6657578",
"0.6657578",
"0.6657578",
"0.6656586",
"0.66544783",
"0.66544783",
"0.66544783",
"0.66524047",
"0.6651954",
"0.6650132",
"0.66487855",
"0.6647077",
"0.66467404",
"0.6646615",
"0.66464466",
"0.66449624",
"0.6644209",
"0.6643461",
"0.6643005",
"0.66421187",
"0.6638628",
"0.6634786",
"0.6633529",
"0.6632049",
"0.6632049",
"0.6632049",
"0.66315657",
"0.6628954",
"0.66281766",
"0.6627182",
"0.6626297",
"0.6624309",
"0.6619582",
"0.6618876",
"0.6618876"
]
| 0.0 | -1 |
Handle action bar item clicks here. The action bar will automatically handle clicks on the Home/Up button, so long as you specify a parent activity in AndroidManifest.xml. | @Override
public boolean onOptionsItemSelected(MenuItem item) {
int id = item.getItemId();
if (id == R.id.action_settings) {
return true;
}
return super.onOptionsItemSelected(item);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\n public boolean onOptionsItemSelected(MenuItem item) { Handle action bar item clicks here. The action bar will\n // automatically handle clicks on the Home/Up button, so long\n // as you specify a parent activity in AndroidManifest.xml.\n\n //\n // HANDLE BACK BUTTON\n //\n int id = item.getItemId();\n if (id == android.R.id.home) {\n // Back button clicked\n this.finish();\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n // app icon in action bar clicked; goto parent activity.\n onBackPressed();\n return true;\n default:\n return super.onOptionsItemSelected(item);\n }\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n // Respond to the action bar's Up/Home button\n case android.R.id.home:\n onBackPressed();\n return true;\n default:\n return super.onOptionsItemSelected(item);\n }\n }",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\r\n switch (id) {\r\n case android.R.id.home:\r\n // app icon in action bar clicked; go home\r\n this.finish();\r\n return true;\r\n default:\r\n return super.onOptionsItemSelected(item);\r\n }\r\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n if (id == android.R.id.home) {\n // app icon in action bar clicked; go home\n finish();\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n if (id == android.R.id.home) {\n Log.e(\"clik\", \"action bar clicked\");\n finish();\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n\t public boolean onOptionsItemSelected(MenuItem item) {\n\t int id = item.getItemId();\n\t \n\t\t\tif (id == android.R.id.home) {\n\t\t\t\t// Respond to the action bar's Up/Home button\n\t\t\t\t// NavUtils.navigateUpFromSameTask(this);\n\t\t\t\tonBackPressed();\n\t\t\t\treturn true;\n\t\t\t}\n\t \n\t \n\t return super.onOptionsItemSelected(item);\n\t }",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\r\n switch (item.getItemId()) {\r\n // Respond to the action bar's Up/Home button\r\n case android.R.id.home:\r\n finish();\r\n return true;\r\n }\r\n return super.onOptionsItemSelected(item);\r\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n // Respond to the action bar's Up/Home button\n case android.R.id.home:\n finish();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n //noinspection SimplifiableIfStatement\n\n switch (item.getItemId()) {\n case android.R.id.home:\n\n // app icon in action bar clicked; goto parent activity.\n this.finish();\n return true;\n default:\n\n return super.onOptionsItemSelected(item);\n\n }\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n //noinspection SimplifiableIfStatement\n\n switch (item.getItemId()) {\n case android.R.id.home:\n\n // app icon in action bar clicked; goto parent activity.\n this.finish();\n return true;\n default:\n\n return super.onOptionsItemSelected(item);\n\n }\n }",
"@Override\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t\tswitch (item.getItemId()) {\n\t\tcase android.R.id.home:\n\t\t\tonBackPressed();\n\t\t\treturn true;\n\t\tdefault:\n\t\t\treturn super.onOptionsItemSelected(item);\n\t\t}\n\t}",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n // Handle presses on the action bar items\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n case R.id.action_clear:\n return true;\n case R.id.action_done:\n\n return true;\n default:\n return super.onOptionsItemSelected(item);\n }\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n switch (id) {\n case android.R.id.home:\n onActionHomePressed();\n return true;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n switch (id) {\n case android.R.id.home:\n onBackPressed();\n break;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n switch (id) {\n case android.R.id.home:\n onBackPressed();\n break;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n\n switch (item.getItemId())\n {\n case android.R.id.home :\n super.onBackPressed();\n break;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId ()) {\n case android.R.id.home:\n onBackPressed ();\n return true;\n\n default:\n break;\n }\n return super.onOptionsItemSelected ( item );\n }",
"@Override\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t switch (item.getItemId()) {\n\t\tcase android.R.id.home:\n\t\t\t// app icon in action bar clicked; go home \n\t\t\tIntent intent = new Intent(this, Kelutral.class); \n\t\t\tintent.addFlags(Intent.FLAG_ACTIVITY_CLEAR_TOP); \n\t\t\tstartActivity(intent); \n\t\t\treturn true;\t\t\n\t case R.id.Search:\n\t \treturn onSearchRequested();\n\t\tcase R.id.AppInfo:\n\t\t\t// Place holder menu item\n\t\t\tIntent newIntent = new Intent(Intent.ACTION_VIEW,\n\t\t\t\t\tUri.parse(\"http://forum.learnnavi.org/mobile-apps/\"));\n\t\t\tstartActivity(newIntent);\n\t\t\treturn true;\n\t\tcase R.id.Preferences:\n\t\t\tnewIntent = new Intent(getBaseContext(), Preferences.class);\n\t\t\tstartActivity(newIntent);\n\t\t\treturn true;\t\n\t }\n\t return false;\n\t}",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n\n case android.R.id.home:\n onBackPressed();\n return true;\n\n }\n return super.onOptionsItemSelected(item);\n\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n\n default:\n return super.onOptionsItemSelected(item);\n }\n\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n // Intent homeIntent = new Intent(this, MainActivity.class);\n // homeIntent.addFlags(Intent.FLAG_ACTIVITY_CLEAR_TOP);\n // startActivity(homeIntent);\n finish();\n return true;\n default:\n return (super.onOptionsItemSelected(item));\n }\n\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n // setResult and close the activity when Action Bar Up Button clicked.\n if (item.getItemId() == android.R.id.home) {\n setResult(RESULT_CANCELED);\n finish();\n return true;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n if (id == android.R.id.home) {\n // This ID represents the Home or Up button. In the case of this\n // activity, the Up button is shown. Use NavUtils to allow users\n // to navigate up one level in the application structure. For\n // more details, see the Navigation pattern on Android Design:\n //\n // http://developer.android.com/design/patterns/navigation.html#up-vs-back\n //\n \tgetActionBar().setDisplayHomeAsUpEnabled(false);\n \tgetFragmentManager().popBackStack();\n return true;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n\n switch (item.getItemId()) {\n case android.R.id.home:\n super.onBackPressed();\n return true;\n\n default:\n // If we got here, the user's action was not recognized.\n // Invoke the superclass to handle it.\n return super.onOptionsItemSelected(item);\n\n }\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n //noinspection SimplifiableIfStatement\n if(id == android.R.id.home){\n onBackPressed();\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n if (id == android.R.id.home) {\n onBackPressed();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n default:\n return super.onOptionsItemSelected(item);\n\n }\n\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n }\n return super.onOptionsItemSelected(item);\n }",
"@RequiresApi(api = Build.VERSION_CODES.M)\n @Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n break;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n\n default:\n return super.onOptionsItemSelected(item);\n }\n }",
"@Override\r\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t\tif(item.getItemId()==android.R.id.home)\r\n\t\t{\r\n\t\t\tgetActivity().onBackPressed();\r\n\t\t}\r\n\t\treturn super.onOptionsItemSelected(item);\r\n\t}",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n if(item.getItemId()==android.R.id.home){\n super.onBackPressed();\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n switch (id) {\n case android.R.id.home:\n onBackPressed();\n return false;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n //Back arrow\n case android.R.id.home:\n onBackPressed();\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n default:\n return super.onOptionsItemSelected(item);\n }\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n default:\n return super.onOptionsItemSelected(item);\n }\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n default:\n return super.onOptionsItemSelected(item);\n }\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n // android.R.id.home是Android内置home按钮的id\n finish();\n break;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n super.onBackPressed();\n return true;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n this.onBackPressed();\n return false;\n }\n return false;\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n // Handle action bar item clicks here. The action bar will\n // automatically handle clicks on the Home/Up button, so long\n // as you specify a parent activity in AndroidManifest.xml.\n int id = item.getItemId();\n\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n return true;\n default:\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\r\n switch (item.getItemId()) {\r\n\r\n case android.R.id.home:\r\n /*Intent i= new Intent(getApplication(), MainActivity.class);\r\n i.setFlags(Intent.FLAG_ACTIVITY_NEW_TASK | Intent.FLAG_ACTIVITY_CLEAR_TOP);\r\n startActivity(i);*/\r\n onBackPressed();\r\n finish();\r\n return true;\r\n default:\r\n return super.onOptionsItemSelected(item);\r\n }\r\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n switch (id){\n case android.R.id.home:\n this.finish();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n // Pass the event to ActionBarDrawerToggle, if it returns\n // true, then it has handled the app icon touch event\n if (mDrawerToggle.onOptionsItemSelected(item)) {\n return true;\n }\n\n // Handle your other action bar items...\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n // Respond to the action bar's Up/Home button\n case android.R.id.home:\n NavUtils.navigateUpFromSameTask(getActivity());\n return true;\n case R.id.action_settings:\n Intent i = new Intent(getActivity(), SettingsActivity.class);\n startActivity(i);\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n //Fixes the Up Button\n if(id == android.R.id.home) {\n BuildRoute.this.finish();\n return true;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()){\n case android.R.id.home:\n onBackPressed();\n break;\n }\n return true;\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n\n if (id == android.R.id.home) {\n NavUtils.navigateUpFromSameTask(this);\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\r\n case android.R.id.home:\r\n onBackPressed();\r\n break;\r\n }\r\n return true;\r\n }",
"@Override\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t\tif (item.getItemId() == android.R.id.home) {\n\t\t\tfinish();\n\t\t}\n\t\treturn super.onOptionsItemSelected(item);\n\t}",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n\n onBackPressed();\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\r\n if ( id == android.R.id.home ) {\r\n finish();\r\n return true;\r\n }\r\n return super.onOptionsItemSelected(item);\r\n }",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\r\n\r\n //noinspection SimplifiableIfStatement\r\n if (id == R.id.home) {\r\n NavUtils.navigateUpFromSameTask(this);\r\n return true;\r\n }\r\n\r\n //noinspection SimplifiableIfStatement\r\n if (id == R.id.action_about) {\r\n AboutDialog();\r\n return true;\r\n }\r\n\r\n //noinspection SimplifiableIfStatement\r\n if (id == R.id.action_exit) {\r\n finish();\r\n return true;\r\n }\r\n\r\n\r\n return super.onOptionsItemSelected(item);\r\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n if (id == android.R.id.home) {\n\n this.finish();\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n if (id == android.R.id.home) {\n\n this.finish();\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n//noinspection SimplifiableIfStatement\n if (id == android.R.id.home) {\n// finish the activity\n onBackPressed();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item)\n {\n int id = item.getItemId();\n\n //noinspection SimplifiableIfStatement\n if( id == android.R.id.home ) // Back button of the actionbar\n {\n finish();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\r\n\t\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t\t\tswitch (item.getItemId()) {\r\n\t\t\tcase android.R.id.home:\r\n\t\t\t\tfinish();\r\n\t\t\t\tbreak;\r\n\t\t\tdefault:\r\n\t\t\t\tbreak;\r\n\t\t\t}\r\n\t\t\treturn super.onOptionsItemSelected(item);\r\n\t\t}",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n\n this.finish();\n return true;\n default:\n return super.onOptionsItemSelected(item);\n }\n\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n if (item.getItemId() == android.R.id.home) {\n onBackPressed();\n return true;\n }\n return false;\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n\n if(id == android.R.id.home){\n finish();\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n //noinspection SimplifiableIfStatement\n if (id == android.R.id.home) {\n onBackPressed();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n //noinspection SimplifiableIfStatement\n if (id == android.R.id.home) {\n onBackPressed();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n //noinspection SimplifiableIfStatement\n if (id == android.R.id.home) {\n onBackPressed();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n //noinspection SimplifiableIfStatement\n if (id == android.R.id.home) {\n onBackPressed();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\r\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t\tswitch (item.getItemId()) {\r\n\t\tcase android.R.id.home:\r\n\t\t\tsetResult(RESULT_OK, getIntent());\r\n\t\t\tfinish();\r\n\t\t\tbreak;\r\n\t\t}\r\n\t\treturn true;\r\n\t}",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n\n if (item.getItemId() == android.R.id.home) {\n finish();\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n finish();\n return true;\n default:\n // If we got here, the user's action was not recognized.\n // Invoke the superclass to handle it.\n return super.onOptionsItemSelected(item);\n\n }\n }",
"@Override\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t\tswitch (item.getItemId()) {\n\t\tcase android.R.id.home:\n\t\t\tfinish();\n\t\t\tbreak;\n\n\t\t}\n\t\treturn super.onOptionsItemSelected(item);\n\t}",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n switch (id) {\n\n case android.R.id.home:\n this.finish();\n return true;\n }\n return true;\n }",
"@Override\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t\tswitch (item.getItemId()) {\n\t\tcase android.R.id.home:\n\t\t\tfinish();\n\t\t\tbreak;\n\n\t\tdefault:\n\t\t\tbreak;\n\t\t}\n\t\treturn super.onOptionsItemSelected(item);\n\t}",
"@Override\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t\tint id = item.getItemId();\n\t\tif (id == android.R.id.home) {\n\t\t\tfinish();\n\t\t\treturn true;\n\t\t}\n\t\treturn super.onOptionsItemSelected(item);\n\t}",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\r\n if (id == android.R.id.home) {\r\n finish();\r\n return true;\r\n }\r\n return super.onOptionsItemSelected(item);\r\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n onBackPressed();\n //NavUtils.navigateUpFromSameTask(this);\n return true;\n default:\n return super.onOptionsItemSelected(item);\n }\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n // todo: goto back activity from here\n finish();\n return true;\n\n default:\n return super.onOptionsItemSelected(item);\n }\n }",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\r\n // Handle item selection\r\n switch (item.getItemId()) {\r\n case android.R.id.home:\r\n onBackPressed();\r\n return true;\r\n\r\n case me.cchiang.lookforthings.R.id.action_sample:\r\n// Snackbar.make(parent_view, item.getTitle() + \" Clicked \", Snackbar.LENGTH_SHORT).show();\r\n return true;\r\n default:\r\n return super.onOptionsItemSelected(item);\r\n }\r\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n if (id == android.R.id.home) {\n finish();\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n if (id == android.R.id.home) {\n finish();\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n case android.R.id.home:\n finish();\n return true;\n default:\n return super.onOptionsItemSelected(item);\n }\n\n\n }",
"@Override\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t\tswitch (item.getItemId()) {\n\t\tcase android.R.id.home:\n\t\t\tonBackPressed();\n\t\t\treturn true;\n\t\tcase R.id.scan_menu:\n\t\t\tonScan();\n\t\t\tbreak;\n\t\tcase R.id.opt_about:\n\t\t\t//onAbout();\n\t\t\tbreak;\n\t\tcase R.id.opt_exit:\n\t\t\tfinish();\n\t\t\tbreak;\n\t\tdefault:\n\t\t\treturn super.onOptionsItemSelected(item);\n\t\t}\n\t\treturn true;\n\t}",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n //noinspection SimplifiableIfStatement\n if (id == android.R.id.home) {\n super.onBackPressed();\n return true;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n switch (id) {\n case android.R.id.home:\n this.finish();\n return true;\n default:\n return super.onOptionsItemSelected(item);\n }\n }",
"@Override\n public boolean onOptionsItemSelected(@NonNull MenuItem item) {\n if (item.getItemId() == android.R.id.home) {\n onBackPressed();\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n switch (id) {\n case android.R.id.home:\n finish();\n return true;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId()) {\n\n case android.R.id.home:\n finish();\n return true;\n\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n if(id==android.R.id.home){\n finish();\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\r\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\r\n\t switch (item.getItemId()) {\r\n\t \t// back to previous page\r\n\t case android.R.id.home:\r\n\t finish();\r\n\t return true;\r\n\t }\r\n\t return super.onOptionsItemSelected(item);\r\n\t}",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n if (id == android.R.id.home) {\n finish();\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\r\n\r\n //noinspection SimplifiableIfStatement\r\n if (id == android.R.id.home) {\r\n // finish the activity\r\n onBackPressed();\r\n return true;\r\n }\r\n\r\n return super.onOptionsItemSelected(item);\r\n }",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\r\n\r\n //noinspection SimplifiableIfStatement\r\n if (id == android.R.id.home) {\r\n // finish the activity\r\n onBackPressed();\r\n return true;\r\n }\r\n\r\n return super.onOptionsItemSelected(item);\r\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n switch (item.getItemId())\n {\n case android.R.id.home:\n this.finish();\n return (true);\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n if (id == android.R.id.home) {\n finish();\n return true;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n if (id == android.R.id.home) {\n finish();\n return true;\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n switch (id){\n case R.id.home:{\n NavUtils.navigateUpFromSameTask(this);\n return true;\n }\n }\n return super.onOptionsItemSelected(item);\n }",
"@Override\n public boolean onOptionsItemSelected(MenuItem item) {\n int id = item.getItemId();\n\n //noinspection SimplifiableIfStatement\n switch(item.getItemId())\n {\n case android.R.id.home:\n super.onBackPressed();\n break;\n }\n\n return super.onOptionsItemSelected(item);\n }",
"@Override\n\tpublic boolean onOptionsItemSelected(MenuItem item) {\n\t\tswitch (item.getItemId()) {\n\t\tcase android.R.id.home:\n\t\t\tfinish();\n\t\t\treturn true;\n\n\t\tdefault:\n\t\t\treturn super.onOptionsItemSelected(item);\n\t\t}\n\t}",
"@Override\r\n public boolean onOptionsItemSelected(MenuItem item) {\n\r\n int id = item.getItemId();\r\n if(id==android.R.id.home){\r\n finish();\r\n return true;\r\n }\r\n return super.onOptionsItemSelected(item);\r\n }"
]
| [
"0.79036397",
"0.78051436",
"0.77656627",
"0.7726445",
"0.7630767",
"0.76211494",
"0.75842685",
"0.75296193",
"0.74868536",
"0.74574566",
"0.74574566",
"0.7437983",
"0.7422003",
"0.7402867",
"0.7391276",
"0.73864174",
"0.7378494",
"0.73696834",
"0.736246",
"0.7355139",
"0.73449135",
"0.7340738",
"0.7329403",
"0.7327573",
"0.7325295",
"0.7318255",
"0.73159224",
"0.7312879",
"0.73033696",
"0.73033696",
"0.73008657",
"0.7297531",
"0.72929823",
"0.7285663",
"0.7282749",
"0.72806233",
"0.7277895",
"0.72592133",
"0.72592133",
"0.72592133",
"0.725875",
"0.72585285",
"0.7249446",
"0.72242975",
"0.72188604",
"0.721602",
"0.7203672",
"0.720087",
"0.71988416",
"0.7192238",
"0.7184499",
"0.71768767",
"0.71679133",
"0.71665394",
"0.7153183",
"0.71526414",
"0.71351266",
"0.71341896",
"0.71341896",
"0.7128609",
"0.7128064",
"0.7123341",
"0.7122453",
"0.712232",
"0.71210843",
"0.7116595",
"0.7116595",
"0.7116595",
"0.7116595",
"0.7116421",
"0.71161103",
"0.71159387",
"0.7114029",
"0.71116006",
"0.71088904",
"0.71078885",
"0.7104719",
"0.70989364",
"0.7097548",
"0.7096198",
"0.7092782",
"0.7092782",
"0.70853245",
"0.7082456",
"0.70802784",
"0.70795983",
"0.7073409",
"0.70673656",
"0.7060751",
"0.70591253",
"0.7058957",
"0.7050524",
"0.70371544",
"0.70371544",
"0.70350724",
"0.70344317",
"0.70344317",
"0.7031844",
"0.70303893",
"0.70286727",
"0.7017757"
]
| 0.0 | -1 |
Shows a primitive text streaming response that prints the value of one of the REST params | public Response index() {
return new StreamingResponse("text/plain", "x = " + this.parameters.get("x"));
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@GET\n @Produces(MediaType.TEXT_PLAIN)\n public String getIt() {\n return \"Got it!\";\n }",
"@GET\r\n @Produces(MediaType.TEXT_PLAIN)\r\n public String getText() {\n return \"hai\";\r\n }",
"@Override\n\tpublic JavaCommonResponse getOutputResponse(String paramStream) {\n\t\tif (null == paramStream) {\n\t\t\treturn null;\n\t\t}\n\t\tActListResponse alr = JacksonUtil.readValue(paramStream, new TypeReference<ActListResponse>() {\n\t\t});\n\t\treturn alr;\n\t}",
"public Response hello() {\n \t\t\n \t\treturn new StreamingResponse(\"text/xml\", \"<a f=\\\"\" + this.parameters.get(\"y\") + \"\\\" />\");\n \t}",
"@GET\r\n\t@Produces(MediaType.TEXT_PLAIN)\r\n\tpublic String sayPlainTextHello() {\r\n\t\treturn \"You have sent a text/plain request to the Expense Server. It needs to see JSON data.\";\r\n\t}",
"@GET\n @Produces(MediaType.TEXT_PLAIN)\n public String sayPlainTextHello() {\n return \"Hello Jersey\";\n }",
"@GET\n\t@Produces({MediaType.TEXT_PLAIN})\n public String HelloWorldText2(){\n\t\treturn \"Hello World, Jersey\";\n\t}",
"@GET\r\n @Produces(MediaType.TEXT_PLAIN)\r\n public String sayPlainTextHello() {\r\n return \"Hello Jersey Plain\";\r\n }",
"@GET\n @Path(\"/get/{i}\")\n @Produces(MediaType.TEXT_PLAIN)\n public Response sayPlainTextHello(@PathParam(\"i\") String i) {\n\t if (map.get(i) != null)\n\t\t return Response.ok(map.get(i)).build();\n\t else\n\t\t return Response.status(404).build();\n }",
"@GET\n\n\t@Produces(MediaType.TEXT_PLAIN)\n\n\t//@Path(\"test\")\n\tpublic String getIt() {\n\n\t\treturn \"Got it!\";\n\t}",
"@GET\n\t@Path(\"/{param}\")\n\t@Produces(MediaType.APPLICATION_JSON)\n\t//@Consumes(MediaType.TEXT_XML)\n\tpublic Response sampleResourceGet(@PathParam(\"param\") String msg) {\n\t\t\n\t\tSystem.out.println(\"msg:::: \"+msg);\n\t\t\n\t\t//String result = \"<RestfulExample><H1>\" + msg + \"</H1></RestfulExample>\";\n\n\t\t\t\n\t\treturn Response.status(200).entity(msg).build();\n\n\t}",
"@GET\n @Produces(MediaType.TEXT_PLAIN)\n public Response getIt() {\n logger.info(\"Hello World method called.\");\n\n return Response\n .status(Response.Status.OK)\n .entity(\"Hello World\")\n .build();\n }",
"@Test\n\tpublic void getRequestWithQueryParamter() {\n\t\tgiven()\n\t\t.queryParam(\"fullText\", \"true\")\n\t\t.when()\n\t\t.get(\"https://restcountries.eu/rest/v2/name/aruba\")\n\t\t.then()\n\t\t.assertThat()\n\t\t.contentType(ContentType.JSON)\n\t\t.and()\n\t\t.statusCode(HttpStatus.SC_OK)\n\t\t.log().all();\n\t}",
"@GET\n @Produces({MediaType.TEXT_PLAIN, MediaType.APPLICATION_JSON})\n public Response getInfoText(@Context final UriInfo uriInfo)\n {\n // abort if object is not initialized, yet\n if (restObject == null)\n return HttpResponseFactory.createServerErrorResponse();\n\n // check if ?pretty=true or simply ?pretty\n boolean isPlainText = false;\n\n if (uriInfo.getQueryParameters().get(RestConstants.PRETTY_QUERY_PARAM) != null) {\n final String prettyValue = uriInfo.getQueryParameters().get(RestConstants.PRETTY_QUERY_PARAM).get(0);\n isPlainText = prettyValue.isEmpty() || prettyValue.equals(String.valueOf(true));\n }\n\n // forward GET request to the object\n try {\n if (isPlainText) {\n final String responseText = restObject.getAsPlainText();\n final String allowedRequests = getAllowedRequests()\n .replaceAll(RestConstants.LINE_START_REGEX, RestConstants.LINE_START_REPLACEMENT);\n return HttpResponseFactory.createPlainTextOkResponse(responseText + allowedRequests);\n } else {\n final Object responseObject = restObject.getAsJson(uriInfo.getQueryParameters());\n\n // abort if nothing could be retrieved\n if (responseObject == null)\n return HttpResponseFactory.createServerErrorResponse();\n\n // try to parse the JSON object\n return HttpResponseFactory.createOkResponse(gson.toJsonTree(responseObject));\n }\n } catch (final IllegalArgumentException e) {\n return HttpResponseFactory.createBadRequestResponse(e.getMessage());\n\n } catch (final RuntimeException e) { // NOPMD it's up to the implementation which exceptions to throw, but they are all treated equally\n return HttpResponseFactory.createKnownErrorResponse(e.getMessage());\n }\n }",
"public String toString() {\n return HTTP_VERSION + SP + code + SP + responseString;\n }",
"java.lang.String getResponse();",
"@GET\r\n\t@Produces(MediaType.TEXT_PLAIN)\r\n\tpublic String sayHello() {\r\n\t\treturn \"Hello Jersey\";\r\n\t}",
"String getParamsAsString();",
"@Path(\"/get9\")\n\t@GET\n\t@Produces(\"text/plain\")\n\tpublic String get9() {\n\t\tStringBuilder buf = new StringBuilder();\n\n\t\tbuf.append(\"Parameter Names: \\n\");\n\n\t\tfor (String param : uriInfo.getQueryParameters().keySet()) {\n\t\t\tbuf.append(param);\n\t\t\tbuf.append(\"\\n\");\n\t\t}\n\n\t\treturn buf.toString();\n\t}",
"@Override\n\t\t\t\tpublic void onResponse(String arg0) {\n\t\t\t\t\tSystem.out.println(arg0);\n\t\t\t\t\t\n\t\t\t\t}",
"@Override\n public String toString() {\n StringBuilder sb = new StringBuilder();\n sb.append(getVerbString() + \" \");\n sb.append(url != null ? url : \"*\");\n sb.append(\" RTSP/1.0\\r\\n\");\n sb.append(getHeadersString());\n\n // Insert a blank line\n sb.append(CRLF);\n\n if (getBufferSize() > 0) {\n sb.append(getBuffer());\n }\n\n return sb.toString();\n }",
"@GET\n @Path(value=\"/{a}/{b}\")\n @Produces(\"application/json\")\n public String getJSON(@PathParam(value=\"a\") int a,@PathParam(value=\"b\") int b) {\n //TODO return proper representation object\n int c = a + b;\n return \"{\\\"result\\\":\\\"\"+c+\"\\\"}\";\n }",
"@Test\n public void printResponse(){\n when().get(\"http:://34.223.219.142:1212/ords/hr/countries\")\n .body().prettyPrint();\n\n }",
"String getResponse();",
"@GET\n\t@Path(\"/test\")\n\t@Produces(\"text/plain\")\n\tpublic String resourceTest(){\n\t\treturn OpenstackNetProxyConstants.MESSAGE_TEST;\n\t}",
"@POST\n \t@Path(\"/text\")\n \t@Consumes(MediaType.TEXT_PLAIN)\n \t@Produces(MediaType.TEXT_PLAIN)\n \tpublic String textMethod(@QueryParam(\"token\") String token, String json) {\n \t\t// map json to json object \n \t\treturn token + \"::\" + json + \"\\n\";\n \t}",
"public Response getSimpleResponse(String msg){\n return new Response(new OutputSpeech(OutputSpeech.SpeechType.PlainText,msg));\n }",
"@GET\n @Path(\"\")\n @Produces(MediaType.APPLICATION_JSON)\n public Response getdefaultHelp(@HeaderParam(\"authorization\") String authString,\n @HeaderParam(\"userid\") String userid) {\n return Response.status(200).entity(\" API server is Alive!!\").build();\n }",
"@Test\n public void testSendGetParameterRequest() {\n String expected = \"GET_PARAMETER rtsp://172.10.20.30:554 RTSP/1.0\\r\\n\" + (((((((\"session: 2547019973447939919\\r\\n\" + \"cseq: 3\\r\\n\") + \"content-length: 31\\r\\n\") + \"content-type: text/parameters\\r\\n\") + \"\\r\\n\") + \"stream_state\\r\\n\") + \"position\\r\\n\") + \"scale\\r\\n\");\n byte[] content = (\"stream_state\\r\\n\" + (\"position\\r\\n\" + \"scale\\r\\n\")).getBytes(UTF_8);\n FullHttpRequest request = new io.netty.handler.codec.http.DefaultFullHttpRequest(RTSP_1_0, GET_PARAMETER, \"rtsp://172.10.20.30:554\");\n request.headers().add(SESSION, \"2547019973447939919\");\n request.headers().add(CSEQ, \"3\");\n request.headers().add(CONTENT_LENGTH, (\"\" + (content.length)));\n request.headers().add(CONTENT_TYPE, \"text/parameters\");\n request.content().writeBytes(content);\n EmbeddedChannel ch = new EmbeddedChannel(new RtspEncoder());\n ch.writeOutbound(request);\n ByteBuf buf = ch.readOutbound();\n String actual = buf.toString(UTF_8);\n buf.release();\n Assert.assertEquals(expected, actual);\n }",
"KafkaResponseParam getResponse();",
"@GET\n\t@Produces(\"text/plain\")\n\tpublic String getPlain() {\n\t\treturn msg + \"\\n\";\n\t}",
"@GET\n @Produces({\"application/xml\", \"application/json\"})\n @Path(\"/{version}\")\n public String query(@PathParam(\"version\") String version) {\n if (version.equals(NPSGlobalState.getTopologyManager().getTopologyOntHeadModelVersion())) {\n return \"LATEST\";\n }\n return \"OUTDATED\";\n }",
"@GetMapping(value = \"/hello\",produces = MediaType.TEXT_PLAIN_VALUE)\n public String sayHello(){\n return \"Hello World\";\n }",
"@Test(priority=2)\r\n\tpublic void logResponseBody()\r\n\t{\r\n\t\tgiven()\r\n\t\t.get(\"https://reqres.in/api/users/2\")\r\n\t\t.then()\r\n\t\t.log().body();\t\t\r\n\t}",
"public String toString()\r\n {\r\n StringBuffer buffer = new StringBuffer(30);\r\n\r\n buffer.append(this.url);\r\n\r\n if (this.parameters.size() > 0)\r\n {\r\n buffer.append('?');\r\n Set parameterSet = this.parameters.entrySet();\r\n\r\n Iterator iterator = parameterSet.iterator();\r\n\r\n while (iterator.hasNext())\r\n {\r\n Map.Entry entry = (Map.Entry) iterator.next();\r\n\r\n Object key = entry.getKey();\r\n Object value = entry.getValue();\r\n\r\n if (value == null)\r\n {\r\n buffer.append(key).append('='); // no value\r\n }\r\n else if (value.getClass().isArray())\r\n {\r\n Object[] values = (Object[]) value;\r\n for (int i = 0; i < values.length; i++)\r\n {\r\n if (i > 0)\r\n {\r\n buffer.append(TagConstants.AMPERSAND);\r\n }\r\n\r\n buffer.append(key).append('=').append(values[i]);\r\n }\r\n }\r\n else\r\n {\r\n buffer.append(key).append('=').append(value);\r\n }\r\n\r\n if (iterator.hasNext())\r\n {\r\n buffer.append(TagConstants.AMPERSAND);\r\n }\r\n }\r\n }\r\n\r\n if (this.anchor != null)\r\n {\r\n buffer.append('#');\r\n buffer.append(this.anchor);\r\n }\r\n\r\n return buffer.toString();\r\n }",
"public String getParameterFromR();",
"@Override\n public String toString() {\n StringBuilder sb = new StringBuilder();\n sb.append(\"{\");\n if (getHeaderParameters() != null)\n sb.append(\"HeaderParameters: \").append(getHeaderParameters()).append(\",\");\n if (getQueryStringParameters() != null)\n sb.append(\"QueryStringParameters: \").append(getQueryStringParameters()).append(\",\");\n if (getBodyParameters() != null)\n sb.append(\"BodyParameters: \").append(getBodyParameters());\n sb.append(\"}\");\n return sb.toString();\n }",
"public static void main(String[] args) {\n\n Client client = Client.create();\n WebResource resource = client.resource(\"http://localhost:8080/rest/query/strings\");\n MultivaluedMap<String, String> params = new MultivaluedMapImpl();\n params.add(\"param\", \"Here is one parameter\");\n params.add(\"param\", \"Here is two parameters\");\n String helloWorldResponse = resource.queryParams(params).accept(\n MediaType.TEXT_PLAIN).\n get(String.class);\n System.out.println(helloWorldResponse);\n }",
"public interface ILablePrintRestService {\n String getContainerCode(Integer number,String containerCode) throws BizCheckedException;\n String getMergeLable(@QueryParam(\"number\") Integer number);\n\n\n }",
"public String getResponseString() {\r\n\t\t// TODO - log message if this is ever called\r\n\t\treturn \"\";\r\n\t}",
"@Override\n public String toString()\n {\n return BasicLineFormatter.DEFAULT.formatRequestLine(null, this).toString();\n }",
"@GET\n // The Java method will produce content identified by the MIME Media type \"text/plain\"\n @Produces(\"text/plain\")\n public String getClichedMessage() {\n // Return some cliched textual content\n return \"Hello World22\";\n }",
"@Override\n public String toString() {\n StringBuilder sb = new StringBuilder();\n sb.append(\"{\");\n if (getVersion() != null)\n sb.append(\"version: \").append(getVersion()).append(\",\");\n if (getResource() != null)\n sb.append(\"resource: \").append(getResource()).append(\",\");\n if (getPath() != null)\n sb.append(\"path: \").append(getPath()).append(\",\");\n if (getHttpMethod() != null)\n sb.append(\"httpMethod: \").append(getHttpMethod()).append(\",\");\n if (getHeaders() != null)\n sb.append(\"headers: \").append(getHeaders().toString()).append(\",\");\n if (getMultiValueHeaders() != null)\n sb.append(\"multiValueHeaders: \").append(getMultiValueHeaders().toString()).append(\",\");\n if (getQueryStringParameters() != null)\n sb.append(\"queryStringParameters: \").append(getQueryStringParameters().toString()).append(\",\");\n if (getMultiValueQueryStringParameters() != null)\n sb.append(\"multiValueQueryStringParameters: \").append(getMultiValueQueryStringParameters().toString()).append(\",\");\n if (getPathParameters() != null)\n sb.append(\"pathParameters: \").append(getPathParameters().toString()).append(\",\");\n if (getStageVariables() != null)\n sb.append(\"stageVariables: \").append(getStageVariables().toString()).append(\",\");\n if (getRequestContext() != null)\n sb.append(\"requestContext: \").append(getRequestContext().toString()).append(\",\");\n if (getBody() != null)\n sb.append(\"body: \").append(getBody()).append(\",\");\n if (getIsBase64Encoded() != null)\n sb.append(\"isBase64Encoded: \").append(getIsBase64Encoded());\n sb.append(\"}\");\n return sb.toString();\n }",
"public void printOn(OutputStream stream) throws IOException{\n OutputStreamWriter out = new OutputStreamWriter(stream);\n\n String responseLine = protocolInitializationString();\n if( responseLine != null )\n out.write( responseLine + \"\\n\" );\n \n String headersString= headersAsString();\n if( headersString != null )\n out.write( headersString );\n \n Content c = contentObj();\n if( c!= null )\n out.write( c.toString() );\n \n out.flush();\n }",
"@Override\n public String toString(){\n String s;\n \n s = \"\\tparseOK: \" + parseOK + Constants.NL +\n \"\\trequest_uri: \" + request_uri + Constants.NL +\n \"\\tquery_string: \" + query_string + Constants.NL +\n \"\\trestAPIkeys: \" + restAPIkeys + Constants.NL +\n \"\\ttraceMsgQ: \" + traceMsgQ + Constants.NL;\n \n return s;\n }",
"String responseToString(MovilizerResponse response);",
"String getFullEffectWithExampleParametersAsString();",
"@AutoEscape\n\tpublic String getRespondText();",
"@Override\r\nprotected void doGet(HttpServletRequest req, HttpServletResponse resp) throws ServletException, IOException {\n\tPrintWriter a=resp.getWriter();\r\n\tint aid=Integer.parseInt(req.getParameter(\"aid\"));\r\n\tString name=req.getParameter(\"anames\");\r\n\ta.println(\"welcome \"+name);\r\n}",
"public static void printResponse(String response)\n\t{\n\t\n\t}",
"java.lang.String getOutput();",
"@GET\n @Produces(MediaType.TEXT_XML)\n public String sayXMLHello() {\n return \"<?xml version=\\\"1.0\\\"?>\" + \"<hello> Hello Jersey\" + \"</hello>\";\n }",
"public String GET(String name){\n return \"OK \" + this.clientData.get(name);\n }",
"public interface DetailMovie {\n @GET(\"{id}\")\n Call<DetailMovies> getData(@Path(\"id\") int id,\n @Query(\"api_key\") String api_key,\n @Query(\"language\") String language,\n @Query(\"append_to_response\") String append_to_response\n );\n}",
"Object visitorResponse();",
"@GetMapping(\"/echo\")\n String echo(@RequestParam(\"name\") String str) {\n return restTemplate.getForObject(String.format(\"http://nacos-discovery-provider/echo?name=%s\", appName + \" \" + str), String.class);\n }",
"com.indosat.eai.catalist.standardInputOutput.RequestType getRequest();",
"@GetMapping(\"/worker\")\r\n\tpublic String Hello() {\r\n\t\tStringBuilder response = new StringBuilder();\r\n\t\tresponse.append(\"<pre>\\nHello: \\n\");\r\n\t\tif (!test)\r\n\t\t\tresponse.append(\"instance: \" + getExample1PropertyValue() + \"\\n\");\r\n\t\tresponse.append(\"static: \" + getStaticValue() + \"\\n\");\r\n\t\tresponse.append(\"static (2): \" + getPropertiesParserStaticValue() + \"\\n\");\r\n\t\tresponse.append(\"injected: \" + getExample2PropertyValue() + \"\\n\");\r\n\t\tresponse.append(\"own: \" + getValue() + \"\\n\");\r\n\t\tresponse.append(\"</pre>\\n\");\r\n\t\treturn response.toString();\r\n\t}",
"@GetMapping\n public String echo(String name) {\n String path = String.format(\"http://%s/discovery?name=%s\", SERVER_NAME, name);\n return restTemplate.getForObject(path, String.class);\n }",
"@Path(\"/\")\n @GET\n @Produces(MediaType.APPLICATION_JSON) // indique que la réponse est en json\n public Response test(@Context final UriInfo ui) {\n\n return Response.ok(true).build();\n }",
"@Override\n\tprotected void doGet(HttpServletRequest req, HttpServletResponse resp) throws ServletException, IOException {\n\t\tresp.setCharacterEncoding(\"gbk\");\n\t\tresp.setContentType(\"text/html;charset=gbk\");\n\t\tPrintWriter out=resp.getWriter();\n\t\tServletContext context=this.getServletContext();\n\t\tEnumeration<String> paramNames=context.getInitParameterNames();\n\t\tout.println(\"all the paramName and paramValue are following\");\n\t\t\n\t\twhile(paramNames.hasMoreElements()) {\n\t\t\tString name=paramNames.nextElement();\n\t\t\tString value =context.getInitParameter(name);\n\t\t\tout.println(name+\":\"+value);\n\t\t\tout.println(\"<br/>\");\n\t\t}\n\t}",
"@Test\n\tpublic void trial01() {\n\t\tspec1.pathParam(\"id\", 3);\n\t\tResponse response =given().spec(spec1).get(\"/{id}\");\n\t\tresponse.prettyPrint();\n\t\t\n\t\tresponse.then().assertThat().statusCode(200).contentType(ContentType.JSON).statusLine(\"HTTP/1.1 200 OK\");\n\t}",
"@RequestMapping(\r\n value = \"/\",\r\n method = RequestMethod.GET,\r\n produces = MediaType.APPLICATION_JSON_VALUE)\r\n public ResponseEntity home(@RequestParam(value = \"text\", defaultValue = \"txt\") String text) throws IOException{\r\n String message = \"WELCOME TO LIRE SERVICES | THIS IS THE ROOT | PLEASE CALL THE RELEVANT PATH \\n\"\r\n + \"copyright(c) 2016 SLIIT Tone based voice synthesizer framework for voice based application development | Lire Version 0.1\";\r\n \r\n return new ResponseEntity<>(message, HttpStatus.OK);\r\n }",
"@Override\r\n\tpublic void service(Request request,Response response) {\n\t\tresponse.print(\"lalaa\");\r\n\r\n\t\t\r\n\t}",
"public void doGet(HttpServletRequest request, HttpServletResponse response)\n throws ServletException, IOException {\n response.setContentType(\"text/plain\");\n // Actual logic goes here.\n PrintWriter out = response.getWriter();\n out.println(\"Wolken,5534-0848-5100,0299-6830-9164\");\n\ttry \n\t{\n Get g = new Get(Bytes.toBytes(request.getParameter(\"userid\")));\n Result r = table.get(g);\n byte [] value = r.getValue(Bytes.toBytes(\"v\"),\n Bytes.toBytes(\"\"));\n\t\tString valueStr = Bytes.toString(value);\n\t\tout.println(valueStr);\n\t}\n\tcatch (Exception e)\n\t{\n\t\tout.println(e);\n\t}\n }",
"@GET\n @Produces(MediaType.TEXT_PLAIN)\n public Response sayBaaah(@Context HttpServletRequest request) {\n try {\n return RestUtilities.make200OkResponse(\"No sheep here.\\n\");\n } catch (Exception e) {\n return RestUtilities.make500AndLogSystemErrorResponse(request, e);\n }\n }",
"@GetMapping(path=\"/\", produces = \"application/json\")\n public String getAppDynamicsStream() \n {\n \tSystem.out.println(\"Retrieving KPI's from yml \"+\"KPI's are\" +config);\n \treturn config+\"Read performance metrics, weights from yml\";\n }",
"@Override\r\n\tpublic String showResult() {\n\t\treturn rps.toString();\r\n\t}",
"private void apiVersion(RoutingContext context) {\n context.response()\n .end(new JsonObject().put(\"version\", \"v1\").encodePrettily());\n }",
"@Get\r\npublic String represent() {\r\n return \"Study Design REST Service, version \" + StudyDesignConstants.VERSION;\r\n }",
"@GetMapping(\"helloQuery\")\n public String helloWithQueryParamGet(@RequestParam String coder) { // handler accepts data = dynamic handler\n return \"Hello, \" + coder + \"!\";\n }",
"@GET\n\t@Produces(MediaType.TEXT_PLAIN)\n\tpublic String getLabTestResource() {\n\t\treturn \"Got LabTestResource!\";\n\t}",
"public void setRespp(java.lang.CharSequence value) {\n this.respp = value;\n }",
"@GET\r\n @Produces(MediaType.APPLICATION_JSON)\r\n public String getIt() {\r\n // return \"Got it!\";\r\n \treturn appObj.readAppointment();\r\n }",
"Optional<String> getResponseBody();",
"String getRequest();",
"@GetMapping(\"/info\")\n public String info(){\n return \"info\";\n }",
"public String getParamString() {\n\t\tStringBuilder s = new StringBuilder();\n\t\tif (!((image instanceof SATImage ) ||\n\t\t\t\t(image instanceof IMAImage ))) {\n\t\t\ts.append(super.getParamString());\n\t\t} \n\t\ts.append(stringShort);\n\t\ts.append(\"(\");\n\t\ts.append(\")\");\n\t\treturn s.toString();\n\t}",
"@Path(\"/productos\")\n @GET\n @Produces(MediaType.APPLICATION_JSON) //Por que una track si la aceptaba (ejemplo) pero un producto no?\n public String productos(){\n return test.getProductos().get(\"Leche\").toString();\n\n }",
"@GetMapping(\"/echo/{str}\")\n String echoPathVariable(@PathVariable(\"str\") String str) {\n return restTemplate.getForObject(String.format(\"http://nacos-discovery-provider/echo/%s\", appName + \" \" + str), String.class);\n }",
"@GET\r\n @Produces(\"text/html\")\r\n public String getHtml() {\r\n return \"<html><body>the solution is :</body></html> \";\r\n }",
"protected String getListingParameter() {\n if (!isMono) {\n return listing ? \"/listing\" : \"/nolisting\";\n }\n return null;\n }",
"gen.grpc.hospital.examinations.Parameter getParameter(int index);",
"public void service(ServletRequest req, ServletResponse response) throws ServletException, IOException {\r\n\t\tString param = req.getParameter(\"id\");\r\n\t\tif(param != null){\r\n\t\t response.getWriter().write(\"<html><body>You sent a parameter</body></html>\");\r\n\t\t }else{\r\n\t\t response.getWriter().write(\"<html><body>You can send id parameter</body></html>\");\r\n\t\t }\r\n\t}",
"private SpeechletResponse getHelpResponse() {\n\t\tString speechText = \"Please ask Flight Check the status of a flight by providing the airline name followed by the flight number. For example, Flight Check, what is the status of Lufthansa flight 112. Now, what can I help you with?\";\n\t\t// Create the plain text output.\n\t\tPlainTextOutputSpeech speech = new PlainTextOutputSpeech();\n\t\tspeech.setText(speechText);\n\n\t\t// Create reprompt\n\t\tReprompt reprompt = new Reprompt();\n\t\treprompt.setOutputSpeech(speech);\n\n\t\treturn SpeechletResponse.newAskResponse(speech, reprompt);\n\t}",
"private String httpOk() {\n return \"HTTP/1.1 200 OK\\r\\n\"\n + \"Content-Type: text/html\\r\\n\"\n + \"\\r\\n\";\n }",
"@Override\n public String toString()\n {\n final StringBuilder sb = new StringBuilder(12);\n sb.append('(');\n sb.append(this.parameter.toString());\n sb.append(\")%\");\n return sb.toString();\n }",
"@GET\n @Produces(\"text/html\")\n public Response Hello() {\n return Response.status(Response.Status.OK).entity(\"This is a restaurant api service\").build();\n }",
"@RequestMapping(\"/main\")\r\n @Produces(\"text/plain\")\r\n @ResponseBody\r\n @GET\r\n public String mainPage() {\r\n System.out.println(\"mainPage\");\r\n return \"Main\";\r\n }",
"public GrizzletResponse getResponse();",
"String getExampleParameters();",
"@Override\n protected void doGet(HttpServletRequest request, HttpServletResponse response)\n throws ServletException, IOException {\n PrintWriter pw= response.getWriter();\n// pw.println(\"<h1>\" + mess+\"</h1>\");\n String text = \"some text\";\n text = request.getParameter(\"alldata\");\n// response.setContentType(\"text/plain\"); // Set content type of the response so that jQuery knows what it can expect.\n// response.setCharacterEncoding(\"UTF-8\"); // You want world domination, huh?\n// response.getWriter().write(text); \n pw.println(text);\n }",
"public String toString()\n\t{\n\t\tStringBuilder str = new StringBuilder();\n\t\t\n\t\tstr.append(\"[\");\n\t\tstr.append(getStatus());\n\t\tstr.append(\":\");\n\t\tif ( hasStatusMessage())\n\t\t\tstr.append(getStatusMessage());\n\t\telse\n\t\t\tstr.append(\"<NoMsg>\");\n\t\tstr.append(\":Values=\");\n\t\tstr.append(numberOfResponseValues());\n\t\tstr.append(\"]\");\n\t\t\n\t\treturn str.toString();\n\t}",
"@GET\n\t@Produces({\"text/turtle\",\"application/rdf+xml\"})\n\tResponse getResource(@HeaderParam(\"Accept\") String format);",
"@Override\r\n\tpublic java.lang.String toString()\r\n\t{\r\n\t\treturn \"appendParamToUrl\";\r\n\t}",
"@GetMapping(\"/query\")\n public String query(String query)\n {\n String returnVal;\n return returnVal;\n }",
"@Test\n public void testGetSingleTpTagRecordSetRepresentationAsString() {\n WebResource r = resource().path(\"RecordSet\").path(\"TpTag\").path(\"single\");\n // Assert String representation\n String expected = \"{\\\"startIndex\\\":0,\\\"pageSize\\\":10,\\\"totalNumberOfRecords\\\":1,\\\"records\\\":[{\\\"TpTag\\\":[{\\\"tagName\\\":\\\"tagname\\\",\\\"tpTagId\\\":10}]}]}\";\n String s = r.accept(MediaType.APPLICATION_JSON_TYPE).get(String.class);\n assertEquals(expected, s);\n }",
"private static String sendGET(final Long id) {\n return \"\";\r\n }",
"@GetAction(\"/txt\")\n public String text() {\n return \"Hello World!\";\n }",
"@Override\n public void onResponse(String response) {\n System.out.println(response.toString());\n }"
]
| [
"0.63051176",
"0.62705326",
"0.6145964",
"0.60926723",
"0.6000462",
"0.5982047",
"0.59739375",
"0.5956594",
"0.5890058",
"0.58482695",
"0.5701093",
"0.5591054",
"0.55790013",
"0.55382824",
"0.553069",
"0.54921126",
"0.5461552",
"0.54553515",
"0.5393708",
"0.5392196",
"0.5386362",
"0.53807074",
"0.53717166",
"0.53694123",
"0.53647757",
"0.52899265",
"0.5281123",
"0.51883143",
"0.5188102",
"0.51836365",
"0.51557106",
"0.5117265",
"0.5114495",
"0.5110991",
"0.51059073",
"0.5104871",
"0.5100899",
"0.5097285",
"0.5090672",
"0.50880027",
"0.5086926",
"0.50743425",
"0.5073781",
"0.5069516",
"0.50606537",
"0.5060613",
"0.50600004",
"0.5056713",
"0.5054547",
"0.50496536",
"0.5043943",
"0.5042056",
"0.5037287",
"0.50354093",
"0.5032278",
"0.5028198",
"0.50062656",
"0.5002553",
"0.49918023",
"0.4989702",
"0.4982732",
"0.49811277",
"0.49767128",
"0.49682626",
"0.49672154",
"0.4965086",
"0.49596655",
"0.49568877",
"0.4954295",
"0.49470896",
"0.49452332",
"0.4943911",
"0.49361452",
"0.49295378",
"0.49284258",
"0.492616",
"0.49226755",
"0.49176413",
"0.49158335",
"0.4913579",
"0.49066767",
"0.4906655",
"0.49047425",
"0.489378",
"0.48932412",
"0.4887272",
"0.48862448",
"0.4885505",
"0.48849642",
"0.48844948",
"0.48840934",
"0.4866229",
"0.48659986",
"0.48613316",
"0.4859325",
"0.48581183",
"0.48575532",
"0.4849869",
"0.48498282",
"0.48455134"
]
| 0.6043366 | 4 |
XML streaming response, that prints parameter "y", which is not encoded in the URL as a REST param and should be sent through POST or GET. This is to demo the functionality od merging REST and POST/GET params. | public Response hello() {
return new StreamingResponse("text/xml", "<a f=\"" + this.parameters.get("y") + "\" />");
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Response index() {\n \t\t\n \t\treturn new StreamingResponse(\"text/plain\", \"x = \" + this.parameters.get(\"x\"));\n \t}",
"@GET\n @Produces(MediaType.TEXT_XML)\n public String sayXMLHello() {\n return \"<?xml version=\\\"1.0\\\"?>\" + \"<hello> Hello Jersey\" + \"</hello>\";\n }",
"@Override\n\tpublic JavaCommonResponse getOutputResponse(String paramStream) {\n\t\tif (null == paramStream) {\n\t\t\treturn null;\n\t\t}\n\t\tActListResponse alr = JacksonUtil.readValue(paramStream, new TypeReference<ActListResponse>() {\n\t\t});\n\t\treturn alr;\n\t}",
"public void doGet(HttpServletRequest req, HttpServletResponse res)\tthrows ServletException, IOException {\n\t\t\n\t\tString[] elem = RequestUtils.querySplit(req.getRequestURI());\n\t\tif(elem.length == 2 && elem[1].equals(\"xml\")) { // we catch the file extension to determine the type of the result.\n\t\t\treq.setAttribute(\"xml\", true);\n\t\t} else {\n\t\t\treq.setAttribute(\"xml\", false);\n\t\t}\n\t\t\n\t\treq.getRequestDispatcher(forwardTo).forward(req, res);\n\n\t}",
"@Override\n public void doGet(HttpServletRequest request, HttpServletResponse response)\n throws IOException, ServletException {\n boolean wasXmlRequested = isRequestedFormatXml(request);\n if( ! wasXmlRequested ){\n super.doGet(request,response);\n }else{\n try {\n VitroRequest vreq = new VitroRequest(request);\n Configuration config = getConfig(vreq); \n ResponseValues rvalues = processRequest(vreq);\n \n response.setCharacterEncoding(\"UTF-8\");\n response.setContentType(\"text/xml;charset=UTF-8\");\n writeTemplate(rvalues.getTemplateName(), rvalues.getMap(), config, request, response);\n } catch (Exception e) {\n log.error(e, e);\n }\n }\n }",
"protected void processRequest(HttpServletRequest request, HttpServletResponse response) throws ServletException, IOException {\n\n String xml = \"\";\n\n Document doc = dummy();\n xml = xml2String(doc);\n //response.setContentType(\"text/html;charset=UTF-8\");\n response.setContentType(\"text/xml\");\n\n //response.setHeader(\"Expires\", \"0\");\n //response.setHeader(\"Cache-Control\", \"no-cache\");\n //response.setHeader(\"Pragma\", \"public\");\n String fileName = \"dump.xml\";\n response.setHeader(\"Content-Disposition\", \"attachment; filename=\\\"\" + fileName + \"\\\"\");\n // response.setCharacterEncoding(\"utf-8\");\n //response.setHeader(\"Transfer-Encoding\", \"Chunked\");\n //response.setBufferSize(baos.size());\n //response.flushBuffer();\n\n PrintWriter out = response.getWriter();\n try {\n out.println(xml);\n } finally {\n out.close();\n }\n\n }",
"@Override\r\n public void doGet(String path, HttpServletRequest request, HttpServletResponse response)\r\n throws Exception {\r\n // throw new UnsupportedOperationException();\r\n System.out.println(\"Inside the get\");\r\n response.setContentType(\"text/xml\");\r\n response.setCharacterEncoding(\"utf-8\");\r\n final Writer w = response.getWriter();\r\n w.write(\"inside the get\");\r\n w.close();\r\n }",
"Object visitorResponse();",
"public void setResponseXml(java.lang.String param){\n \n if (param != null){\n //update the setting tracker\n localResponseXmlTracker = true;\n } else {\n localResponseXmlTracker = true;\n \n }\n \n this.localResponseXml=param;\n \n\n }",
"public String getRequestInXML() throws Exception;",
"@GET\n @Path(\"/rest/{name}/{value}\")\n @Produces(MediaType.TEXT_XML)\n public String getXCRIXml(@PathParam(\"name\") String name, @PathParam(\"value\") String value) {\n TransformerFactory transFactory = TransformerFactory.newInstance();\n Transformer transformer;\n StringWriter buffer = new StringWriter();\n try {\n transformer = transFactory.newTransformer();\n transformer.setOutputProperty(OutputKeys.OMIT_XML_DECLARATION, \"no\");\n transformer.setOutputProperty(OutputKeys.INDENT, \"yes\");\n transformer.setOutputProperty(\"{http://xml.apache.org/xslt}indent-amount\", \"2\");\n transformer.transform(new DOMSource(xcriSession.searchCatalog(name, value)), new StreamResult(buffer));\n } catch (TransformerConfigurationException ex) {\n Logger.getLogger(XCRI_CAPRestService.class.getName()).log(Level.SEVERE, \"Problem outputting document\", ex);\n } catch (TransformerException ex) {\n Logger.getLogger(XCRI_CAPRestService.class.getName()).log(Level.SEVERE, \"Problem outputting document\", ex);\n }\n return buffer.toString();\n\n\n }",
"public java.lang.String getResponseXml(){\n return localResponseXml;\n }",
"@Override\r\n\tpublic void service(Request request,Response response) {\n\t\tresponse.print(\"lalaa\");\r\n\r\n\t\t\r\n\t}",
"@GET\n @Produces(MediaType.TEXT_PLAIN)\n public String getIt() {\n return \"Got it!\";\n }",
"@Get(\"xml\")\n public Representation toXml() {\n\n \tString status = getRequestFlag(\"status\", \"valid\");\n \tString access = getRequestFlag(\"location\", \"all\");\n\n \tList<Map<String, String>> metadata = getMetadata(status, access,\n \t\t\tgetRequestQueryValues());\n \tmetadata.remove(0);\n\n List<String> pathsToMetadata = buildPathsToMetadata(metadata);\n\n String xmlOutput = buildXmlOutput(pathsToMetadata);\n\n // Returns the XML representation of this document.\n StringRepresentation representation = new StringRepresentation(xmlOutput,\n MediaType.APPLICATION_XML);\n\n return representation;\n }",
"public String getParameterFromY();",
"protected void processRequest(HttpServletRequest request, HttpServletResponse response)\n throws ServletException, IOException {\n response.setContentType(\"text/html;charset=UTF-8\");\n \n XmlParser parser = new XmlParser();\n String [] urls = parser.leerUrls();\n \n CalcProxy calcProxy = new CalcProxy(urls);\n \n String pattern = request.getParameter(\"pattern\");\n String result = \"0\";\n String [] result2 = null;\n \n if (!pattern.equals(\"\")) {\n result = calcProxy.buscar(pattern);\n System.out.println(result);\n } else\n {\n result = calcProxy.listar();\n result2 = calcProxy.listarTxt().split(\"&\");\n System.out.println(result2.toString());\n }\n \n try (PrintWriter out = response.getWriter()) {\n /* TODO output your page here. You may use following sample code. */\n out.println(\"<!DOCTYPE html>\");\n out.println(\"<html>\");\n out.println(\"<head>\");\n out.println(\"<title>Servlet CalcServlet</title>\"); \n out.println(\"</head>\");\n out.println(\"<body>\");\n out.println(result);\n if(result2 != null)\n for(int i = 0; i < result2.length;i++)\n {\n // out.println(\"<p><a href=\\\"http://localhost:8080/sgarci18WasServer/files/urls.txt\\\" download=\\\"http://localhost:8080/sgarci18WasServer/files/urls.txt\\\">urls</a></p>\\n\");\n out.println(\"<p><a href=\\\"\"+ calcProxy.uri+\"/../\"+ result2[i]+\"\\\" download=\\\"\"+ calcProxy.uri+\"/../\"+ result2[i]+\"\\\">\"+ result2[i]+\"</a></p>\\n\"); //+url del json, pero no logre parsearlo\n }\n out.println(\"<p><a href=\\\"index.html\\\" title=\\\"pag principal\\\">Volver</a></p>\");\n out.println(\"</body>\");\n out.println(\"</html>\");\n }\n }",
"private static void setResponse(HttpServletResponse response, Integer status) {\n\t\tresponse.setContentType(\"text/XML\");\n\t\tresponse.setCharacterEncoding(\"UTF-8\");\n\t\ttry {\n\t\t\t//response.getWriter().write(\"<friendRequest:status id=\\\"friendRequestResponse\\\" value=\\\"\" + status + \"\\\" />\");\n\t\t\tresponse.getWriter().write(status.toString());\n\t\t} catch (Exception ignored) {};\n\t}",
"private static void setResponse(HttpServletResponse response, Integer status) {\n\t\tresponse.setContentType(\"text/XML\");\n\t\tresponse.setCharacterEncoding(\"UTF-8\");\n\t\ttry {\n\t\t\t//response.getWriter().write(\"<friendRequest:status id=\\\"friendRequestResponse\\\" value=\\\"\" + status + \"\\\" />\");\n\t\t\tresponse.getWriter().write(status.toString());\n\t\t} catch (Exception ignored) {};\n\t}",
"public void begin(HttpServletResponse response) throws IOException {\n super.begin(response);\n this.write(\"<?xml version=\\\"1.0\\\" encoding=\\\"UTF-8\\\"?>\");\n }",
"void writeTo(InternalResponse<?> response, InternalRequest<?> request);",
"@Override\n public void process(ContentRequest req, XMLWriter xml) throws IOException {\n xml.openElement(\"parameters\", true);\n Enumeration<String> names = req.getParameterNames();\n while (names.hasMoreElements()) {\n String paramName = names.nextElement();\n String[] values = req.getParameterValues(paramName);\n if (values != null) {\n for (String value : values) {\n xml.openElement(\"parameter\", false);\n xml.attribute(\"name\", paramName);\n xml.writeText(value);\n xml.closeElement();\n }\n }\n }\n xml.closeElement(); // close parameters\n }",
"public MyHTTPOutputStream(OutputStream os) {\n\t\tsuper(os);\n\t\tthis.myRequest = \"\";\n\t\tthis.myReply = \"\";\n\t}",
"@GET\n\t@Produces({MediaType.TEXT_PLAIN})\n public String HelloWorldText2(){\n\t\treturn \"Hello World, Jersey\";\n\t}",
"@GET\n\n\t@Produces(MediaType.TEXT_PLAIN)\n\n\t//@Path(\"test\")\n\tpublic String getIt() {\n\n\t\treturn \"Got it!\";\n\t}",
"private String leerRespuestaApi(InputStream stream) throws IOException {\n //NECESITAMOS UN LECTOR DEL FLUJO\n BufferedReader buffer = new BufferedReader(new InputStreamReader(stream));\n //TENEMOS QUE LEER EL FLUJO Y PONER UN SEPARADOR DE ENTER\n //ENTRE LAS LINEAS\n String linea = \"\";\n //UN STRINGBUFFER SIRVE PARA LEER CONTENIDO MUY GRANDE\n StringBuffer data = new StringBuffer();\n //EL SEPARADOR DE ENTER DE CADA LINEA\n String separador = \"\";\n //MIENTRAS QUE EXISTAN LINEAS EN EL XML, DENTRO BUCLE\n while ((linea = buffer.readLine()) != null) {\n //AÑADIMOS EL CONTENIDO DE DATOS A DATA\n data.append(separador + linea);\n separador = \"\\n\";\n }\n //RECUPERAMOS LOS DATOS COMO STRING\n String response = data.toString();\n return response;\n }",
"String getResponse();",
"@GET\n\t@Path(\"/{param}\")\n\t@Produces(MediaType.APPLICATION_JSON)\n\t//@Consumes(MediaType.TEXT_XML)\n\tpublic Response sampleResourceGet(@PathParam(\"param\") String msg) {\n\t\t\n\t\tSystem.out.println(\"msg:::: \"+msg);\n\t\t\n\t\t//String result = \"<RestfulExample><H1>\" + msg + \"</H1></RestfulExample>\";\n\n\t\t\t\n\t\treturn Response.status(200).entity(msg).build();\n\n\t}",
"@Override\n protected void configure() {\n flow(\"OutputParamsAsXML\")\n .from(\"http://localhost:8080\") //embedded http server that listen on 8080 port\n .filter(groovy(\"message.payload != \\\"/favicon.ico\\\"\")) //don't process the browser request for `favicon.ico`\n .transformWith(HttpRequestBodyToParamMap.class) //transform http request body to a map\n .transformWith(ObjectToXml.class) //transform the payload (map) to xml\n .messageProperties()\n .put(\"Content-Type\", \"text/xml\"); //sets the output content-type to xml\n }",
"@GET\n\t@Produces({\"text/turtle\",\"application/rdf+xml\"})\n\tResponse getResource(@HeaderParam(\"Accept\") String format);",
"@GET\n @Produces(MediaType.TEXT_PLAIN)\n public String sayPlainTextHello() {\n return \"Hello Jersey\";\n }",
"void requestOutput();",
"@GET\n @Produces(MediaType.APPLICATION_XML)\n \n public String getXml() {\n \n return \"<gps_data>\"\n + \"<gps_id>1</gps_id>\"\n + \"<gps_coord>107,-40</gps_coord>\"\n + \"<gps_time>12:00</gps_time>\"\n + \"</gps_data>\";\n }",
"private void writeResponse(SlingHttpServletRequest request, SlingHttpServletResponse response) throws IOException {\n\t\tresponse.setContentType(\"text/html\");\n\t\tresponse.setCharacterEncoding(\"utf-8\");\n\t\tPrintWriter pw = response.getWriter();\n\t\tpw.print(\"This is a CQ5 Response ... \");\n\t\tpw.print(getPageContent(request, \"/content/helloworld\"));\n\t\tpw.flush();\n\t\tpw.close();\n\t}",
"public org.tempuri.HISWebServiceStub.YPrintResponse yPrint(\r\n org.tempuri.HISWebServiceStub.YPrint yPrint68)\r\n throws java.rmi.RemoteException {\r\n org.apache.axis2.context.MessageContext _messageContext = new org.apache.axis2.context.MessageContext();\r\n\r\n try {\r\n org.apache.axis2.client.OperationClient _operationClient = _serviceClient.createClient(_operations[34].getName());\r\n _operationClient.getOptions().setAction(\"http://tempuri.org/YPrint\");\r\n _operationClient.getOptions().setExceptionToBeThrownOnSOAPFault(true);\r\n\r\n addPropertyToOperationClient(_operationClient,\r\n org.apache.axis2.description.WSDL2Constants.ATTR_WHTTP_QUERY_PARAMETER_SEPARATOR,\r\n \"&\");\r\n\r\n // create SOAP envelope with that payload\r\n org.apache.axiom.soap.SOAPEnvelope env = null;\r\n\r\n env = toEnvelope(getFactory(_operationClient.getOptions()\r\n .getSoapVersionURI()),\r\n yPrint68,\r\n optimizeContent(\r\n new javax.xml.namespace.QName(\"http://tempuri.org/\",\r\n \"yPrint\")),\r\n new javax.xml.namespace.QName(\"http://tempuri.org/\",\r\n \"YPrint\"));\r\n\r\n //adding SOAP soap_headers\r\n _serviceClient.addHeadersToEnvelope(env);\r\n // set the message context with that soap envelope\r\n _messageContext.setEnvelope(env);\r\n\r\n // add the message contxt to the operation client\r\n _operationClient.addMessageContext(_messageContext);\r\n\r\n //execute the operation client\r\n _operationClient.execute(true);\r\n\r\n org.apache.axis2.context.MessageContext _returnMessageContext = _operationClient.getMessageContext(org.apache.axis2.wsdl.WSDLConstants.MESSAGE_LABEL_IN_VALUE);\r\n org.apache.axiom.soap.SOAPEnvelope _returnEnv = _returnMessageContext.getEnvelope();\r\n\r\n java.lang.Object object = fromOM(_returnEnv.getBody()\r\n .getFirstElement(),\r\n org.tempuri.HISWebServiceStub.YPrintResponse.class);\r\n\r\n return (org.tempuri.HISWebServiceStub.YPrintResponse) object;\r\n } catch (org.apache.axis2.AxisFault f) {\r\n org.apache.axiom.om.OMElement faultElt = f.getDetail();\r\n\r\n if (faultElt != null) {\r\n if (faultExceptionNameMap.containsKey(\r\n new org.apache.axis2.client.FaultMapKey(\r\n faultElt.getQName(), \"YPrint\"))) {\r\n //make the fault by reflection\r\n try {\r\n java.lang.String exceptionClassName = (java.lang.String) faultExceptionClassNameMap.get(new org.apache.axis2.client.FaultMapKey(\r\n faultElt.getQName(), \"YPrint\"));\r\n java.lang.Class exceptionClass = java.lang.Class.forName(exceptionClassName);\r\n java.lang.reflect.Constructor constructor = exceptionClass.getConstructor(java.lang.String.class);\r\n java.lang.Exception ex = (java.lang.Exception) constructor.newInstance(f.getMessage());\r\n\r\n //message class\r\n java.lang.String messageClassName = (java.lang.String) faultMessageMap.get(new org.apache.axis2.client.FaultMapKey(\r\n faultElt.getQName(), \"YPrint\"));\r\n java.lang.Class messageClass = java.lang.Class.forName(messageClassName);\r\n java.lang.Object messageObject = fromOM(faultElt,\r\n messageClass);\r\n java.lang.reflect.Method m = exceptionClass.getMethod(\"setFaultMessage\",\r\n new java.lang.Class[] { messageClass });\r\n m.invoke(ex, new java.lang.Object[] { messageObject });\r\n\r\n throw new java.rmi.RemoteException(ex.getMessage(), ex);\r\n } catch (java.lang.ClassCastException e) {\r\n // we cannot intantiate the class - throw the original Axis fault\r\n throw f;\r\n } catch (java.lang.ClassNotFoundException e) {\r\n // we cannot intantiate the class - throw the original Axis fault\r\n throw f;\r\n } catch (java.lang.NoSuchMethodException e) {\r\n // we cannot intantiate the class - throw the original Axis fault\r\n throw f;\r\n } catch (java.lang.reflect.InvocationTargetException e) {\r\n // we cannot intantiate the class - throw the original Axis fault\r\n throw f;\r\n } catch (java.lang.IllegalAccessException e) {\r\n // we cannot intantiate the class - throw the original Axis fault\r\n throw f;\r\n } catch (java.lang.InstantiationException e) {\r\n // we cannot intantiate the class - throw the original Axis fault\r\n throw f;\r\n }\r\n } else {\r\n throw f;\r\n }\r\n } else {\r\n throw f;\r\n }\r\n } finally {\r\n if (_messageContext.getTransportOut() != null) {\r\n _messageContext.getTransportOut().getSender()\r\n .cleanup(_messageContext);\r\n }\r\n }\r\n }",
"private void writeResponseLine(final DataOutput out) throws IOException {\n out.writeBytes(HTTP_VERSION);\n out.writeBytes(SP);\n out.writeBytes(code + \"\");\n out.writeBytes(SP);\n if (responseString != null) {\n out.writeBytes(responseString);\n }\n out.writeBytes(CRLF);\n }",
"public interface RequestService {\n @GET(\"index?type=yule&key=d7e184978722fe31928061a05ac7980c\")\n Call<ResponseBody> getString();\n}",
"public interface NextBusXmlFeed {\n\n @GET(\"/service/publicXMLFeed?command=agencyList\")\n Call<AgenciesResponse> agencyList();\n\n @GET(\"/service/publicXMLFeed?command=routeList\")\n Call<RoutesResponse> routeList(@Query(\"a\") final String agency);\n\n @GET(\"/service/publicXMLFeed?command=routeConfig\")\n Call<RouteConfigResponse> routeConfig(@Query(\"a\") final String agency, @Query(\"r\") final String route);\n\n @GET(\"/service/publicXMLFeed?command=predictions\")\n Call<PredictionResponse> predictions(@Query(\"a\") final String agency, @Query(\"r\") final String route, @Query(\"s\") final String stop);\n}",
"@GET\r\n @Produces(MediaType.TEXT_PLAIN)\r\n public String sayPlainTextHello() {\r\n return \"Hello Jersey Plain\";\r\n }",
"@org.junit.Test\n public void testFilmAnnee2000() {\n WebTarget target = c.target(\"http://\"+BASE_URI.getHost()+\":\"+BASE_URI.getPort()+\"/film?annee=1940&titre=Fantasia\");\n String responseMsg = target.request().get(String.class);\n Assert.assertEquals(\"[{\\\"id\\\":\\\"tt0032455\\\",\\\"title\\\":\\\"Fantasia\\\",\\\"year\\\":1940,\\\"url\\\":\\\"http://www.omdbapi.com/?i=tt0032455&r=xml\\\"},{\\\"id\\\":\\\"tt0027606\\\",\\\"title\\\":\\\"Fantasia sottomarina\\\",\\\"year\\\":1940,\\\"url\\\":\\\"http://www.omdbapi.com/?i=tt0027606&r=xml\\\"}]\", responseMsg);\n }",
"@Test\n\t@Ignore\n\tpublic void testResponse() throws UnsupportedEncodingException {\n\t\tws = resource().path(\"omxdata\");\n\t\tClientResponse response = ws.accept(MediaType.APPLICATION_JSON).get(ClientResponse.class);\n\t\tassertEquals(200, response.getStatus());\n\t\tSystem.out.println(response.getStatus());\n\t}",
"public void response(String strresponse, String webservice);",
"Builder addResponseTransformer(GlobalRequestTransformer transformer);",
"public static void printResponse(String response)\n\t{\n\t\n\t}",
"public String getResponseXml() {\r\n if (null == recentResponse)\r\n return \"\";\r\n else\r\n return recentResponse.toString();\r\n }",
"public void doGet(HttpServletRequest request, HttpServletResponse response)\n\t\t\tthrows ServletException, IOException {\n\t\trequest.setCharacterEncoding(\"UTF-8\");\n\t\tresponse.setCharacterEncoding(\"UTF-8\");\n\n\t\t/** 读取接收到的xml消息 */\n\t\tStringBuffer sb = new StringBuffer();\n\t\tInputStream is = request.getInputStream();//获取POST数据,取得数据是二进制\n\t\tInputStreamReader isr = new InputStreamReader(is, \"UTF-8\");//字节流通向字符流的桥梁,一次读取一个一个字符,以文本格式输出,可以指定编码格式\n\t\tBufferedReader br = new BufferedReader(isr);\n\t\tString s = \"\";\n\t\t//逐行读取文件\n\t\twhile ((s = br.readLine()) != null) {\n\t\t\tsb.append(s);\n\t\t}\n\t\tString xml = sb.toString();\t//次即为接收到微信端发送过来的xml数据\n\n\t\tString result = \"\";\n\t\t/** 判断是否是微信接入激活验证,只有首次接入验证时才会收到echostr参数,此时需要把它直接返回 */\n\t\tString echostr = request.getParameter(\"echostr\");\n\t\tif (echostr != null && echostr.length() > 1) {\n\t\t\tresult = echostr;\n\t\t} else {\n\t\t\t//正常的微信处理流程\n\t\t\tresult = new WechatProcess().processWechatMag(xml);\n\t\t}\n\n\t\ttry {\n\t\t\tOutputStream os = response.getOutputStream();\n\t\t\tos.write(result.getBytes(\"UTF-8\"));\n\t\t\tos.flush();\n\t\t\tos.close();\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"java.lang.String getResponse();",
"@Override\n\t\t\t\t\tpublic void onResponse(String s) {\n\t\t\t\t\t\t\n\t\t\t\t\t}",
"@GET\r\n @Produces(MediaType.TEXT_PLAIN)\r\n public String getText() {\n return \"hai\";\r\n }",
"@Test\n public void testHTTPSPublisher() throws Exception {\n setCarbonHome();\n logger.info(\"Test case for HTTPS output publisher.\");\n SiddhiManager siddhiManager = new SiddhiManager();\n siddhiManager.setExtension(\"xml-output-mapper\", XMLSinkMapper.class);\n String inStreamDefinition = \"Define stream FooStream (message String,method String,headers String);\"\n + \"@sink(type='http',publisher.url='https://localhost:8009/abc',method='{{method}}',\"\n + \"headers='{{headers}}',\"\n + \"@map(type='xml', \"\n + \"@payload('{{message}}'))) \"\n + \"Define stream BarStream (message String,method String,headers String);\";\n String query = (\n \"@info(name = 'query') \"\n + \"from FooStream \"\n + \"select message,method,headers \"\n + \"insert into BarStream;\"\n );\n SiddhiAppRuntime siddhiAppRuntime = siddhiManager\n .createSiddhiAppRuntime(inStreamDefinition + query);\n InputHandler fooStream = siddhiAppRuntime.getInputHandler(\"FooStream\");\n siddhiAppRuntime.start();\n HttpsServerListenerHandler lst = new HttpsServerListenerHandler(8009);\n lst.run();\n fooStream.send(new Object[]{payload, \"POST\", \"'Name:John','Age:23'\"});\n while (!lst.getServerListener().isMessageArrive()) {\n Thread.sleep(10);\n }\n String eventData = lst.getServerListener().getData();\n Assert.assertEquals(eventData, expected);\n siddhiAppRuntime.shutdown();\n lst.shutdown();\n }",
"@GET\n @Produces(MediaType.APPLICATION_XML)\n public String getXml() {\n //TODO return proper representation object\n throw new UnsupportedOperationException();\n }",
"public static String m18355a(AbsResponseWrapper aVar, boolean z, boolean z2) {\n String a;\n if (aVar == null) {\n if (!Proxy.f16280c) {\n return \"response null\";\n }\n Log.e(\"TAG_PROXY_Response\", \"response null\");\n return \"response null\";\n } else if (!aVar.mo26446b()) {\n if (Proxy.f16280c) {\n Log.e(\"TAG_PROXY_Response\", \"response code: \" + aVar.mo26442a());\n }\n return \"response code: \" + aVar.mo26442a();\n } else {\n String a2 = aVar.mo26445a(\"Content-Type\", null);\n if (!m18372c(a2)) {\n if (Proxy.f16280c) {\n Log.e(\"TAG_PROXY_Response\", \"Content-Type: \" + a2);\n }\n return \"Content-Type: \" + a2;\n }\n int a3 = m18349a(aVar);\n if (a3 <= 0) {\n if (Proxy.f16280c) {\n Log.e(\"TAG_PROXY_Response\", \"Content-Length: \" + a3);\n }\n return \"Content-Length: \" + a3;\n } else if (z && ((a = aVar.mo26445a(\"Accept-Ranges\", null)) == null || !a.contains(\"bytes\"))) {\n if (Proxy.f16280c) {\n Log.e(\"TAG_PROXY_Response\", \"Accept-Ranges: \" + a);\n }\n return \"Accept-Ranges: \" + a;\n } else if (!z2 || aVar.mo26448d() != null) {\n return null;\n } else {\n if (!Proxy.f16280c) {\n return \"response body null\";\n }\n Log.e(\"TAG_PROXY_Response\", \"response body null\");\n return \"response body null\";\n }\n }\n }",
"String responseToString(MovilizerResponse response);",
"private static String paseResponse(HttpResponse response) {\n\t\tHttpEntity entity = response.getEntity();\n\t\t\n//\t\tlog.info(\"response status: \" + response.getStatusLine());\n\t\tString charset = EntityUtils.getContentCharSet(entity);\n//\t\tlog.info(charset);\n\t\t\n\t\tString body = null;\n\t\ttry {\n if (entity != null) { \n InputStream instreams = entity.getContent(); \n body = convertStreamToString(instreams); \n// System.out.println(\"result:\" + body);\n } \n//\t\t\tlog.info(body);\n\t\t} catch (ParseException e) {\n\t\t\te.printStackTrace();\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t\treturn body;\n\t}",
"@GET\r\n @Produces(MediaType.APPLICATION_XML)\r\n public String getXml() {\r\n //TODO return proper representation object\r\n throw new UnsupportedOperationException();\r\n }",
"@GET\r\n @Produces(MediaType.APPLICATION_XML)\r\n public String getXml() {\r\n //TODO return proper representation object\r\n throw new UnsupportedOperationException();\r\n }",
"@Override\n public void serialize(final Sequence result, final Set<SerializationAnnotation> serializationAnnotations, final HttpResponse response) throws RestXqServiceException {\n \n // some xquery functions can write directly to the output stream\n // (response:stream-binary() etc...)\n // so if output is already written then dont overwrite here\n if(response.isCommitted()) {\n return;\n }\n \n final Iterator<TypedValue> itResult = result.iterator();\n if(itResult.hasNext()) {\n final TypedValue firstResultPart = itResult.next();\n \n //determine if the first element in the sequence is rest:response\n Element elem = null;\n \n if(firstResultPart.getType().equals(Type.DOCUMENT)) {\n elem = ((Document)firstResultPart.getValue()).getDocumentElement();\n } else if(firstResultPart.getType().equals(Type.ELEMENT)) {\n elem = (Element)firstResultPart.getValue();\n }\n \n final Map<SerializationProperty, String> serializationProperties = new EnumMap<SerializationProperty, String>(SerializationProperty.class);\n serializationProperties.putAll(getDefaultSerializationProperties());\n \n //serialize either 1) rest:response and optional body, or 2) just the body\n if(elem != null && new QName(elem.getNamespaceURI(), elem.getLocalName()).equals(RestResponseHandler.REST_RESPONSE_ELEMENT_NAME)) {\n //set the rest:response and serialize the body if it exists\n \n processSerializationAnnotations(serializationAnnotations, serializationProperties);\n new RestResponseHandler().process(elem, serializationProperties, response);\n if(itResult.hasNext()) {\n \n final Sequence seqBody = result.tail();\n serializeBody(seqBody, response, serializationProperties);\n }\n } else {\n //serialize just the body\n processSerializationAnnotations(serializationAnnotations, serializationProperties);\n serializeBody(result, response, serializationProperties);\n }\n }\n }",
"public interface DetailMovie {\n @GET(\"{id}\")\n Call<DetailMovies> getData(@Path(\"id\") int id,\n @Query(\"api_key\") String api_key,\n @Query(\"language\") String language,\n @Query(\"append_to_response\") String append_to_response\n );\n}",
"Response filterResponse(Response currentResponse, HttpExchange exchange);",
"protected void processRequest(HttpServletRequest request, HttpServletResponse response)\n throws ServletException, IOException {\n \n response.setContentType(\"text/xml\");\n PrintWriter out = response.getWriter();\n try {\n String conferenceid=request.getParameter(\"conferenceid\");\n String xml_param=request.getParameter(\"url\");\n String output=\"\";\n\n DocumentBuilderFactory dbf = DocumentBuilderFactory.newInstance();\n DocumentBuilder db = dbf.newDocumentBuilder();\n Document dom = db.parse(xml_param);\n\n Element docEle = dom.getDocumentElement();\n\n NodeList sequence_list=docEle.getElementsByTagName(\"seq\").item(0).getChildNodes();\n int total=0;\n for(int i=0;i<sequence_list.getLength();i++){\n Node node_event=sequence_list.item(i);\n if(node_event.getNodeType()==Node.ELEMENT_NODE){\n String json_message=\"{\";\n\n String activity=node_event.getNodeName();\n json_message=json_message+\"\\\"event\\\":\\\"\"+activity+\"\\\"\";\n\n if(node_event.hasAttributes()){\n NamedNodeMap event_attribs=node_event.getAttributes();\n for(int j=0;j<event_attribs.getLength();j++){\n Node attrib=event_attribs.item(j);\n String attrib_name=attrib.getNodeName();\n String attrib_value=attrib.getNodeValue();\n json_message=json_message+\",\\\"\"+attrib_name+\"\\\":\\\"\"+attrib_value+\"\\\"\";\n }\n }\n if(node_event.hasChildNodes()){\n if(node_event.getFirstChild().getNodeType()==Node.TEXT_NODE){\n String text=node_event.getFirstChild().getNodeValue().trim();\n if(!text.equalsIgnoreCase(\"\")){\n json_message=json_message+\",\\\"text\\\":\\\"\"+text+\"\\\"\";\n }\n }\n NodeList subnodes=node_event.getChildNodes();\n if(subnodes.getLength()>1)\n {\n json_message=json_message+\",\\\"\"+subnodes.item(1).getNodeName()+\"\\\":[\";\n for(int j=0;j<subnodes.getLength();j++){\n Node subnode=subnodes.item(j);\n\n if(subnode.getNodeType()==Node.ELEMENT_NODE){\n json_message=json_message+\"\\\"\"+subnode.getFirstChild().getNodeValue()+\"\\\"\";\n json_message+=\",\";\n }\n }\n json_message=json_message.substring(0, json_message.length()-1);\n json_message+=\"]\";\n }\n }\n\n json_message+=\"}\";\n\n IEvent event =new Event();\n ((Event)event).setConferenceID(conferenceid);\n ((Event)event).setTimeStamp(System.currentTimeMillis());\n ((Event)event).setMessage(json_message);\n\n sendMessagesToQueue(event);\n total++;\n Thread.sleep(150);\n }\n }\n \n output=\"finish processing \"+total+\" objects\";\n out.println(\"<message>\"+output+\"</message>\");\n }catch(Exception ex){\n Logger.getLogger(XMLProcesser.class.getName()).log(Level.SEVERE, null, ex);\n }finally {\n out.close();\n }\n }",
"com.indosat.eai.catalist.standardInputOutput.RequestType getRequest();",
"public void sendYo (String username){\n try {\n URL obj = new URL(\"http://api.justyo.co/yo/\");\n HttpURLConnection con = (HttpURLConnection) obj.openConnection();\n con.setRequestMethod(\"POST\");\n String urlParameters = \"api_token=9831429c-5e02-4175-b0d1-c5cbe958e09a&username=\" + username;\n con.setDoOutput(true);\n DataOutputStream wr = new DataOutputStream(con.getOutputStream());\n wr.writeBytes(urlParameters);\n wr.flush();\n wr.close();\n int responseCode = con.getResponseCode();\n BufferedReader in = new BufferedReader(\n new InputStreamReader(con.getInputStream()));\n String inputLine;\n StringBuffer response = new StringBuffer();\n while ((inputLine = in.readLine()) != null) {\n response.append(inputLine);\n }\n in.close();\n }\n catch(Exception e){\n System.out.println(\"Error\");\n }\n }",
"public void parseResponse();",
"public String getParameterFromX();",
"@PUT\n @Consumes(MediaType.APPLICATION_XML) \n public void putXml(String content) {\n System.out.println(\"this is the content: \"+content);\n }",
"public void doGet(HttpServletRequest request, HttpServletResponse response)\r\n\t\t\tthrows ServletException, IOException {\r\n\r\n\t\tresponse.setContentType(\"text/xml\");\r\n\t\tPrintWriter out = response.getWriter();\r\n\t\tStringBuilder sb = new StringBuilder();\r\n\t\tDB_Job dbjob = new DB_Job();\r\n\t\tList<Job> mrjobs = null;\r\n\t\ttry {\r\n\t\t\tmrjobs = dbjob.getAll();\r\n\t\t} catch (Exception e) {\r\n\t\t\t// TODO Auto-generated catch block\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t\tsb.append(\"<jobs>\");\r\n\t\tfor(Job job: mrjobs)\r\n\t\t{\r\n\t\t\tsb.append(\"\\r <job name='\"+job.getName()+\"' iterative='\"+job.isIterative()+\"' jobid='\"+job.getId()+\"'>\");\r\n\t\t\tsb.append(\"\\r <parameters>\"+job.getParameters()+\"</parameters>\");\r\n\t\t\tsb.append(\"\\r <description>\"+job.getDescription()+\"</description>\");\r\n\t\t\tsb.append(\"\\r </job>\");\r\n\t\t}\r\n\t\tsb.append(\"\\r</jobs>\");\r\n\t\t//System.out.println(sb.toString());\r\n\t\tout.println(sb.toString());\r\n\t\tout.flush();\r\n\t\tout.close();\r\n\t}",
"public abstract String getResponse();",
"public interface Api {\n\n @GET(\"index\")\n Call<String> getSimple();\n\n @GET(\"getxml\")\n Call<String> getXml(@Query(\"code\") int code);\n\n @FormUrlEncoded\n @POST(\"postme\")\n Call<String> postSimple(@Field(\"from\") String foo);\n\n @Headers({\"Content-Type: application/xml\", \"Accept: application/json\"})\n @POST(\"postxml\")\n Call<String> postXml(@Body RequestBody aRequestBody);\n\n\n}",
"protected void doGet(HttpServletRequest request, HttpServletResponse response) throws ServletException, IOException {\n\t\t\n\t\tSomme sum=new Somme();\n\t\tString ok=request.getParameter(\"ok\");\n\t\tint a=Integer.parseInt(request.getParameter(\"a\"));\n\t\tint b=Integer.parseInt(request.getParameter(\"b\"));\n\t\tsum.setA(a);\n\t\tsum.setB(b);\n\t\trequest.setAttribute(\"ok\", ok);\n\t\trequest.setAttribute(\"somme\",sum.sum());\n\t\t\n\t\t\n\t\tthis.getServletContext().getRequestDispatcher( \"/WEB-INF/test.jsp\").forward( request, response );\n\t}",
"@Test\n\tpublic void testResponse() throws IOException {\n\t\tConfigurationManager config = new ConfigurationManager();\n\t\tHashMap<String, Handler> map = new HashMap<String,Handler>();\n\t\tHashMap<String, String> parameters = new HashMap<String, String>();\n\t\tcheckResponse(new RequestObject(\"\", \"\", parameters), HTTPConstants.BAD_REQUEST, map);\n\t\tcheckResponse(new RequestObject(\"PUT\", \"/reviewsearch\", parameters), HTTPConstants.NOT_ALLOWED, map);\n\t\tcheckResponse(new RequestObject(\"PULL\", \"/slackbot\", parameters), HTTPConstants.NOT_ALLOWED, map);\n\t\tcheckResponse(new RequestObject(\"GET\", \"/slackbot\", parameters), HTTPConstants.NOT_FOUND, map);\n\t\tcheckResponse(new RequestObject(\"POST\", \"/slackbot\", parameters), HTTPConstants.NOT_FOUND, map);\n\t\tmap.put(\"/slackbot\", new ChatHandler(config.getConfig()));\n\t\tcheckResponse(new RequestObject(\"POST\", \"/slackbot\", parameters), HTTPConstants.OK_HEADER, map);\n\t\tcheckResponse(new RequestObject(\"POST\", \"/reviewsearch\", parameters), HTTPConstants.NOT_FOUND, map);\n\t\tmap.put(\"/reviewsearch\", new ReviewSearchHandler(config.getConfig(), new InvertedIndex()));\n\t\tcheckResponse(new RequestObject(\"POST\", \"/reviewsearch\", parameters), HTTPConstants.OK_HEADER, map);\n\t\tparameters.put(\"query\", \"jumpers\");\n\t\tcheckResponse(new RequestObject(\"POST\", \"/reviewsearch\", parameters), HTTPConstants.OK_HEADER, map);\n\t\tparameters.put(\"unknown\", \"unknown\");\n\t\tcheckResponse(new RequestObject(\"POST\", \"/reviewsearch\", parameters), HTTPConstants.OK_HEADER, map);\n\t\tparameters.remove(\"query\");\n\t\tcheckResponse(new RequestObject(\"GET\", \"/reviewsearch\", parameters), HTTPConstants.OK_HEADER, map);\n\t\tcheckResponse(new RequestObject(\"GET\", \"/\", parameters), HTTPConstants.NOT_FOUND, map);\n\t}",
"@GET\n @Path(value=\"/{a}/{b}\")\n @Produces(\"application/json\")\n public String getJSON(@PathParam(value=\"a\") int a,@PathParam(value=\"b\") int b) {\n //TODO return proper representation object\n int c = a + b;\n return \"{\\\"result\\\":\\\"\"+c+\"\\\"}\";\n }",
"public static String sendPostRequest(String urlString,String body,String[] head,boolean dom)\n\t{\n InputStream instream;\n BufferedReader bfreader = null;\n String response = null;\n \n \n \n \n \n try \n {\n java.net.URL url = new java.net.URL(urlString);\n java.net.HttpURLConnection connection = (java.net.HttpURLConnection)url.openConnection(); // have to cast connection\n connection.setRequestMethod(\"POST\");\n connection.setDoOutput(true);\n connection.setReadTimeout(60000);\n \n \n \n if(head!=null)\n {\n\t for(int i=0;i<head.length;i=i+2)\n\t {\n\t \tconnection.setRequestProperty(head[i], head[i+1]);\n\t \t\n\t }\n }\n \n String utf8body= new String(body.getBytes(\"UTF-8\"));\n \n //writeFile(utf8body,\"01aft\");\n //writeFile(body,\"01bef\");\n \n OutputStream os = connection.getOutputStream();\n \n BufferedWriter osw = new BufferedWriter(new OutputStreamWriter(os));\n if(dom)\n {\n\t osw.write(0x0A);\n\t osw.write(0x09);\n\t }\n osw.write(utf8body);\n osw.flush();\n osw.close();\n \n \n connection.connect();\n instream=connection.getInputStream();\n bfreader=new BufferedReader(new InputStreamReader(instream,\"UTF-8\"));\n response=bfreader.readLine();\n //writeFile(response,\"instr\");\n \n connection.disconnect();\n \n \n } \n \n \n catch (Exception e) {\n \n \n // get stack trace as a String to return as document data\n java.io.StringWriter stringWriter = new java.io.StringWriter();\n e.printStackTrace( new java.io.PrintWriter( stringWriter ) );\n //result.setResponseData( stringWriter.toString() );\n //System.out.println(stringWriter);\n response = stringWriter.toString();\n \n \n }\n\t\t\n \n \n return response;\n\t\t\n\t\t\n\t}",
"@Test\n\tpublic void getRequestWithQueryParamter() {\n\t\tgiven()\n\t\t.queryParam(\"fullText\", \"true\")\n\t\t.when()\n\t\t.get(\"https://restcountries.eu/rest/v2/name/aruba\")\n\t\t.then()\n\t\t.assertThat()\n\t\t.contentType(ContentType.JSON)\n\t\t.and()\n\t\t.statusCode(HttpStatus.SC_OK)\n\t\t.log().all();\n\t}",
"@Path(\"/\")\n @GET\n @Produces(MediaType.APPLICATION_JSON) // indique que la réponse est en json\n public Response test(@Context final UriInfo ui) {\n\n return Response.ok(true).build();\n }",
"String getRequest();",
"public void startResponse()\n\t\t\t{\n\t\t\t\tsend(\"<response>\", false);\n\t\t\t}",
"public void doFilter(ServletRequest request, ServletResponse response,\n FilterChain chain) throws IOException, ServletException {\n \n if (!(request instanceof HttpServletRequest)) {\n chain.doFilter(request, response);\n return;\n }\n checkLocale();\n\n HttpServletRequest httpReq = (HttpServletRequest) request;\n HttpServletResponse httpRes = (HttpServletResponse) response;\n\n PrintWriter out = httpRes.getWriter();\n CharResponseWrapper wrapper = new CharResponseWrapper(httpRes);\n chain.doFilter(httpReq, wrapper);\n\n if (bDebug) {\n String reqUrl = httpReq.getRequestURL().toString();\n String queryString = httpReq.getQueryString();\n\n if (queryString != null) {\n reqUrl += \"?\" + queryString;\n }\n filterConfig.getServletContext().log(\"URL: \" + reqUrl);\n }\n\n // Its possible this is a RDC based JSP if:\n // 1) The content type is not set, or\n // 2) The content type is non-HTML\n if ( wrapper.getContentType() == null || \n !wrapper.getContentType().equals(STR_CONTENT_TYPE_HTML) ) {\n // 1) Improve aesthetics of VoiceXML output\n String trimmedResponse = trimResponse(wrapper.toString());\n // 2) Perform platform adaptations\n String adaptedResponse = performPlatformAdaptations(trimmedResponse);\n\n // Now that looks just fine\n httpRes.setContentLength(adaptedResponse.length());\n out.write(adaptedResponse);\n } else {\n // What a waste ;-)\n out.write(wrapper.toString());\n }\n\n // We're done\n out.close();\n }",
"public static YPrintResponse parse(\r\n javax.xml.stream.XMLStreamReader reader)\r\n throws java.lang.Exception {\r\n YPrintResponse object = new YPrintResponse();\r\n\r\n int event;\r\n javax.xml.namespace.QName currentQName = null;\r\n java.lang.String nillableValue = null;\r\n java.lang.String prefix = \"\";\r\n java.lang.String namespaceuri = \"\";\r\n\r\n try {\r\n while (!reader.isStartElement() && !reader.isEndElement())\r\n reader.next();\r\n\r\n currentQName = reader.getName();\r\n\r\n if (reader.getAttributeValue(\r\n \"http://www.w3.org/2001/XMLSchema-instance\",\r\n \"type\") != null) {\r\n java.lang.String fullTypeName = reader.getAttributeValue(\"http://www.w3.org/2001/XMLSchema-instance\",\r\n \"type\");\r\n\r\n if (fullTypeName != null) {\r\n java.lang.String nsPrefix = null;\r\n\r\n if (fullTypeName.indexOf(\":\") > -1) {\r\n nsPrefix = fullTypeName.substring(0,\r\n fullTypeName.indexOf(\":\"));\r\n }\r\n\r\n nsPrefix = (nsPrefix == null) ? \"\" : nsPrefix;\r\n\r\n java.lang.String type = fullTypeName.substring(fullTypeName.indexOf(\r\n \":\") + 1);\r\n\r\n if (!\"YPrintResponse\".equals(type)) {\r\n //find namespace for the prefix\r\n java.lang.String nsUri = reader.getNamespaceContext()\r\n .getNamespaceURI(nsPrefix);\r\n\r\n return (YPrintResponse) ExtensionMapper.getTypeObject(nsUri,\r\n type, reader);\r\n }\r\n }\r\n }\r\n\r\n // Note all attributes that were handled. Used to differ normal attributes\r\n // from anyAttributes.\r\n java.util.Vector handledAttributes = new java.util.Vector();\r\n\r\n reader.next();\r\n\r\n while (!reader.isStartElement() && !reader.isEndElement())\r\n reader.next();\r\n\r\n if ((reader.isStartElement() &&\r\n new javax.xml.namespace.QName(\r\n \"http://tempuri.org/\", \"YPrintResult\").equals(\r\n reader.getName())) ||\r\n new javax.xml.namespace.QName(\"\", \"YPrintResult\").equals(\r\n reader.getName())) {\r\n nillableValue = reader.getAttributeValue(\"http://www.w3.org/2001/XMLSchema-instance\",\r\n \"nil\");\r\n\r\n if (\"true\".equals(nillableValue) ||\r\n \"1\".equals(nillableValue)) {\r\n throw new org.apache.axis2.databinding.ADBException(\r\n \"The element: \" + \"YPrintResult\" +\r\n \" cannot be null\");\r\n }\r\n\r\n java.lang.String content = reader.getElementText();\r\n\r\n object.setYPrintResult(org.apache.axis2.databinding.utils.ConverterUtil.convertToString(\r\n content));\r\n\r\n reader.next();\r\n } // End of if for expected property start element\r\n\r\n else {\r\n }\r\n\r\n while (!reader.isStartElement() && !reader.isEndElement())\r\n reader.next();\r\n\r\n if (reader.isStartElement()) {\r\n // 2 - A start element we are not expecting indicates a trailing invalid property\r\n throw new org.apache.axis2.databinding.ADBException(\r\n \"Unexpected subelement \" + reader.getName());\r\n }\r\n } catch (javax.xml.stream.XMLStreamException e) {\r\n throw new java.lang.Exception(e);\r\n }\r\n\r\n return object;\r\n }",
"public void writeParameterToY(String parameterName);",
"public OrbitalResponse(OrbitalRequest request, String text) throws APIException\r\n {\r\n super(text, FormatType.XML);\r\n _request = request;\r\n }",
"boolean isSerializeResponse();",
"@Override\n\tprotected void doGet(SlingHttpServletRequest request, SlingHttpServletResponse response) throws ServletException,\n\t IOException {\n\t\twriteResponse(request, response);\n\t}",
"@GET\r\n @Produces(\"application/xml\")\r\n public String getXml() {\r\n //TODO return proper representation object\r\n throw new UnsupportedOperationException();\r\n }",
"public void test_001_Stream() throws Throwable {\n\n final String RESOURCE_URI = \"asimov_it_test_001_SP_PROXYING\";\n String uri = createTestResourceUri(RESOURCE_URI);\n\n HttpRequest request = createRequest().setUri(uri).addHeaderField(\"Cache-Control\" ,\"max-age=500\").getRequest();\n PrepareResourceUtil.prepareResource(uri, false);\n\n //miss\n sendRequest2(request, 10);\n //R1.2 miss\n checkMiss(request, 2, VALID_RESPONSE);\n }",
"public ServletResponse getResponse();",
"@GET\n\t@Produces(MediaType.TEXT_XML)\n\tpublic String getXMLList()\n\t{\n\t\tString myStr = \"<?xml version=\\\"1.0\\\" encoding=\\\"UTF-8\\\"?>\" + \"<parent>\" + \"<policy>\" + \" Hello, World\" + \"</policy>\" + \"<hello>\" + \" Hello, World\" + \"</hello>\" + \"</parent>\";\n\t\t// iterate via \"New way to loop\"\n\t\t/*System.out.println(\"Looping through the list to build the xml string\");\n\t\tfor (String policy : _policyList) \n\t\t{\n\t\t\tmyStr += \"<Policy>\" + policy + \"</Policy>\";\n\t\t}*/\n\n\t\treturn myStr;\n\t}",
"public void doPost(HttpServletRequest request, HttpServletResponse response) throws ServletException, IOException\n\t{\n\t\tString xml = request.getParameter(\"xml\");\n\t\tSystem.out.println(xml);\n\t\tPrintWriter out = response.getWriter();\n\t\tString result = \"<Items><Item><error>0</error><Message>ERROR</Message><MidID>OK</MidID></Item></Items>\";\n\t\tout.print(result);\n\t}",
"KafkaResponseParam getResponse();",
"HttpServletResponse getCurrentResponse();",
"@RequestMapping(value = \"/testHttpServletRequest\", params = { \"v1=Akebono\", \"v2\", \"!v3\" })\n @ResponseBody\n public String testE(final HttpServletRequest request) {\n System.out.println(\"testControl/testHttpServletRequest\");\n System.out.println(request.getParameter(\"v1\") + \" \" + request.getParameter(\"v2\"));\n\n request.setAttribute(\"message\", \"testHttpServletRequest\");\n return \"bonoland/testHttpServletRequest<br>\" + request.getParameter(\"v1\") + \" \" + request.getParameter(\"v2\");\n }",
"@Test\n public void testSend200OkResponseWithoutBody() {\n String expected = \"RTSP/1.0 200 OK\\r\\n\" + (((\"server: Testserver\\r\\n\" + \"cseq: 1\\r\\n\") + \"session: 2547019973447939919\\r\\n\") + \"\\r\\n\");\n HttpResponse response = new io.netty.handler.codec.http.DefaultHttpResponse(RTSP_1_0, OK);\n response.headers().add(SERVER, \"Testserver\");\n response.headers().add(CSEQ, \"1\");\n response.headers().add(SESSION, \"2547019973447939919\");\n EmbeddedChannel ch = new EmbeddedChannel(new RtspEncoder());\n ch.writeOutbound(response);\n ByteBuf buf = ch.readOutbound();\n String actual = buf.toString(UTF_8);\n buf.release();\n Assert.assertEquals(expected, actual);\n }",
"protected String handleResponse(final HttpResponse response, final HttpContext context) throws IOException {\n final HttpEntity entity = response.getEntity();\n if (null == entity.getContentType() || !entity.getContentType().getValue().startsWith(\"application/soap+xml\")) {\n throw new WinRmRuntimeIOException(\"Error when sending request to \" + targetURL + \"; Unexpected content-type: \" + entity.getContentType());\n }\n\n final InputStream is = entity.getContent();\n final Writer writer = new StringWriter();\n final Reader reader = new BufferedReader(new InputStreamReader(is, StandardCharsets.UTF_8));\n try {\n int n;\n final char[] buffer = new char[2048];\n while ((n = reader.read(buffer)) != -1) {\n writer.write(buffer, 0, n);\n }\n } catch (Exception e) {\n System.out.println(\"xxxxxxxxxxxxxxxxxxxx=>\");\n e.printStackTrace();\n } finally {\n closeQuietly(reader);\n closeQuietly(is);\n consume(response.getEntity());\n }\n\n return writer.toString();\n }",
"@Override\n\tpublic void service(Request request, Response response) {\n\t\tresponse.print(\"其他测试页面\");\n\t\t\n\t\t\n\t}",
"Response createResponse();",
"public void printOn(OutputStream stream) throws IOException{\n OutputStreamWriter out = new OutputStreamWriter(stream);\n\n String responseLine = protocolInitializationString();\n if( responseLine != null )\n out.write( responseLine + \"\\n\" );\n \n String headersString= headersAsString();\n if( headersString != null )\n out.write( headersString );\n \n Content c = contentObj();\n if( c!= null )\n out.write( c.toString() );\n \n out.flush();\n }",
"@Test\n public void testSendGetParameterRequest() {\n String expected = \"GET_PARAMETER rtsp://172.10.20.30:554 RTSP/1.0\\r\\n\" + (((((((\"session: 2547019973447939919\\r\\n\" + \"cseq: 3\\r\\n\") + \"content-length: 31\\r\\n\") + \"content-type: text/parameters\\r\\n\") + \"\\r\\n\") + \"stream_state\\r\\n\") + \"position\\r\\n\") + \"scale\\r\\n\");\n byte[] content = (\"stream_state\\r\\n\" + (\"position\\r\\n\" + \"scale\\r\\n\")).getBytes(UTF_8);\n FullHttpRequest request = new io.netty.handler.codec.http.DefaultFullHttpRequest(RTSP_1_0, GET_PARAMETER, \"rtsp://172.10.20.30:554\");\n request.headers().add(SESSION, \"2547019973447939919\");\n request.headers().add(CSEQ, \"3\");\n request.headers().add(CONTENT_LENGTH, (\"\" + (content.length)));\n request.headers().add(CONTENT_TYPE, \"text/parameters\");\n request.content().writeBytes(content);\n EmbeddedChannel ch = new EmbeddedChannel(new RtspEncoder());\n ch.writeOutbound(request);\n ByteBuf buf = ch.readOutbound();\n String actual = buf.toString(UTF_8);\n buf.release();\n Assert.assertEquals(expected, actual);\n }",
"@Test\n public void testStoreSaleAdjSale2() {\n String responseMsg = target.path(\"service/message\").queryParam(\"messageType\", \"0\").queryParam(\"productType\", \"ELMA\").queryParam(\"value\", \"2.0\").request().get(String.class);\n responseMsg = target.path(\"service/message\").queryParam(\"messageType\", \"1\").queryParam(\"productType\", \"ELMA\").queryParam(\"value\", \"2.0\").queryParam(\"ocurrence\", \"2\").request().get(String.class);\n responseMsg = target.path(\"service/message\").queryParam(\"messageType\", \"2\").queryParam(\"productType\", \"ELMA\").queryParam(\"value\", \"2.0\").queryParam(\"operator\", \"2\").request().get(String.class);\n assertEquals(\"SUCCESS\", responseMsg);\n }",
"public interface Api {\n @GET(\"satinApi\")\n Observable<WenBean>doGet(@Query(\"type\")int type,@Query(\"page\")int page);\n\n @GET(\"satinApi\")\n Observable<VideoBean>doPost(@Query(\"type\")int type, @Query(\"page\")int page);\n}",
"@PostMapping(value = \"/test/xml-request\", consumes = MediaType.APPLICATION_XML_VALUE, produces = MediaType.APPLICATION_XML_VALUE)\n public Mono<XmlResponse> testPostXml(@RequestBody XmlRequest request) {\n XmlResponse response = new XmlResponse();\n response.setId(request.getId());\n response.setName(\"name:\" + LocalDateTime.now());\n return Mono.just(response);\n }",
"@GET\n\t@Path(\"/test\")\n\t@Produces(\"text/plain\")\n\tpublic String resourceTest(){\n\t\treturn OpenstackNetProxyConstants.MESSAGE_TEST;\n\t}"
]
| [
"0.5732742",
"0.5659204",
"0.5373799",
"0.5356376",
"0.5295978",
"0.5273295",
"0.5220621",
"0.5168917",
"0.516881",
"0.51658475",
"0.5028106",
"0.49967024",
"0.49835435",
"0.49658287",
"0.49656615",
"0.49370518",
"0.4936427",
"0.4928491",
"0.4928491",
"0.49111944",
"0.48970136",
"0.4895822",
"0.48907474",
"0.48880535",
"0.4884906",
"0.48813203",
"0.48506516",
"0.48460215",
"0.48304078",
"0.48242176",
"0.48226112",
"0.48201606",
"0.4790319",
"0.47750866",
"0.47703582",
"0.474657",
"0.47426957",
"0.472698",
"0.47254536",
"0.47162896",
"0.47066912",
"0.47019556",
"0.46959522",
"0.46955645",
"0.46827284",
"0.4677831",
"0.46707305",
"0.4669779",
"0.46492952",
"0.46456242",
"0.46452135",
"0.46431506",
"0.46407768",
"0.46392328",
"0.46385205",
"0.46385205",
"0.46375224",
"0.46365428",
"0.46329182",
"0.4631406",
"0.463042",
"0.4616288",
"0.46140304",
"0.46125233",
"0.46121174",
"0.46094164",
"0.4605142",
"0.46030113",
"0.46022955",
"0.4598289",
"0.45922416",
"0.45890597",
"0.4581005",
"0.45805326",
"0.45756862",
"0.457405",
"0.4572056",
"0.4567861",
"0.45663166",
"0.45626688",
"0.4553528",
"0.45421016",
"0.45412245",
"0.45386055",
"0.45319873",
"0.45254797",
"0.45209768",
"0.451684",
"0.45129204",
"0.45095113",
"0.4508017",
"0.45058888",
"0.44830835",
"0.4477884",
"0.44748116",
"0.44669622",
"0.446372",
"0.44627482",
"0.44565076",
"0.44557124"
]
| 0.7018054 | 0 |
Created by VO2 on 04/04/2017. | public interface IClientService {
Client getClientById(Long id);
List<Client> findAll();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\n public void perish() {\n \n }",
"public final void mo51373a() {\n }",
"private stendhal() {\n\t}",
"@Override\n\tprotected void getExras() {\n\n\t}",
"@Override\n\tpublic void grabar() {\n\t\t\n\t}",
"@Override\n\tpublic void comer() {\n\t\t\n\t}",
"public void mo4359a() {\n }",
"@Override\r\n\tpublic void tires() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}",
"public void mo38117a() {\n }",
"@Override\n protected void getExras() {\n }",
"@Override\r\n\tpublic void dormir() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void comer() \r\n\t{\n\t\t\r\n\t}",
"@Override\n public void func_104112_b() {\n \n }",
"@Override\n public int describeContents() { return 0; }",
"@Override\n\tpublic void gravarBd() {\n\t\t\n\t}",
"@Override\n\tpublic void entrenar() {\n\t\t\n\t}",
"@Override\r\n\tpublic void rozmnozovat() {\n\t}",
"protected MetadataUGWD() {/* intentionally empty block */}",
"private static void cajas() {\n\t\t\n\t}",
"private void poetries() {\n\n\t}",
"@Override\r\n\t\tpublic void init() {\n\t\t\t\r\n\t\t}",
"@Override\n\tpublic void anular() {\n\n\t}",
"@Override\n public void memoria() {\n \n }",
"@Override\r\n\t\t\tpublic void annadir() {\n\r\n\t\t\t}",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"@Override\n\tprotected void interr() {\n\t}",
"@Override\n\tpublic void nadar() {\n\t\t\n\t}",
"@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}",
"public Pitonyak_09_02() {\r\n }",
"@Override\n public void inizializza() {\n\n super.inizializza();\n }",
"private void m50366E() {\n }",
"@Override\n public void init() {\n\n }",
"protected boolean func_70814_o() { return true; }",
"@Override\r\n\tpublic void anularFact() {\n\t\t\r\n\t}",
"private TMCourse() {\n\t}",
"private Rekenhulp()\n\t{\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\r\n\tpublic void publierEnchere() {\n\t\t\r\n\t}",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void initialize() {\n }",
"public final void mo91715d() {\n }",
"@Override\n\tpublic void sacrifier() {\n\t\t\n\t}",
"@Override\r\n\t\t\tpublic void ayuda() {\n\r\n\t\t\t}",
"@Override\n public void init() {\n }",
"public void mo6081a() {\n }",
"@Override\r\n\tprotected void doF4() {\n\t\t\r\n\t}",
"public void gored() {\n\t\t\n\t}",
"@Override\n void init() {\n }",
"@Override\n protected void initialize() \n {\n \n }",
"@Override\n protected void initialize() {\n\n \n }",
"@Override\n protected void init() {\n }",
"@Override\n public void init() {}",
"@Override\r\n\tpublic void init() {}",
"public void mo12930a() {\n }",
"@Override\n\tprotected void initialize() {\n\t\t\n\t}",
"@Override\n\tprotected void initialize() {\n\t\t\n\t}",
"Petunia() {\r\n\t\t}",
"@Override\n\tpublic int mettreAJour() {\n\t\treturn 0;\n\t}",
"private void init() {\n\n\t}",
"@Override public int describeContents() { return 0; }",
"@Override\r\n\tpublic void init() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void init() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void init() {\n\t\t\r\n\t}",
"@Override\n\tprotected void initData() {\n\t\t\n\t}",
"public void mo55254a() {\n }",
"@Override\n\tpublic void init() {\n\n\t}",
"@Override\n\tpublic void init() {\n\n\t}",
"@Override\n\tpublic void init() {\n\n\t}",
"@Override\n\tpublic void jugar() {\n\t\t\n\t}",
"public void mo21779D() {\n }",
"public void mo12628c() {\n }",
"@Override\n\tprotected void initialize() {\n\n\t}",
"Constructor() {\r\n\t\t \r\n\t }",
"@Override\n\tpublic void ligar() {\n\t\t\n\t}",
"@Override\n\tpublic void einkaufen() {\n\t}",
"protected void mo6255a() {\n }",
"@Override\r\n\tpublic void stehReagieren() {\r\n\t\t//\r\n\t}",
"@Override\n public void init() {\n\n }",
"@Override\n public void init() {\n\n }",
"public void mo1531a() {\n }",
"@Override\r\n\tprotected void initialize() {\r\n\t\t\r\n\t\t\r\n\t}",
"@Override\n\tprotected void initdata() {\n\n\t}",
"@Override\n\tpublic void one() {\n\t\t\n\t}",
"@Override\n\tpublic void create () {\n\n\t}"
]
| [
"0.59322405",
"0.59139955",
"0.5787655",
"0.57515794",
"0.57482195",
"0.56862485",
"0.56547445",
"0.56445664",
"0.56418705",
"0.56418705",
"0.56359327",
"0.5629546",
"0.5628964",
"0.5619978",
"0.5589597",
"0.5532765",
"0.5524808",
"0.55243593",
"0.55014074",
"0.5488316",
"0.5484067",
"0.5474898",
"0.54453325",
"0.5437526",
"0.54370373",
"0.5431655",
"0.5424785",
"0.5424785",
"0.5424785",
"0.5424785",
"0.5424785",
"0.5424785",
"0.5424785",
"0.5416871",
"0.54062355",
"0.5405551",
"0.5405551",
"0.53994924",
"0.539838",
"0.5391335",
"0.5382122",
"0.5366629",
"0.5361851",
"0.53606224",
"0.5357862",
"0.5351759",
"0.5351759",
"0.5351759",
"0.5351759",
"0.5351759",
"0.5351561",
"0.53512573",
"0.53512573",
"0.53512573",
"0.53512573",
"0.53512573",
"0.53512573",
"0.53472286",
"0.5335753",
"0.533391",
"0.5332991",
"0.5329643",
"0.5321678",
"0.53210014",
"0.5316667",
"0.53124535",
"0.5311866",
"0.5306614",
"0.5300255",
"0.5300229",
"0.52965724",
"0.5296143",
"0.5296143",
"0.5288586",
"0.52766424",
"0.5273046",
"0.52704746",
"0.526445",
"0.526445",
"0.526445",
"0.5263663",
"0.5253433",
"0.52510256",
"0.52510256",
"0.52510256",
"0.524884",
"0.5248277",
"0.52478707",
"0.5243879",
"0.5241833",
"0.5233331",
"0.5231406",
"0.5227547",
"0.52263933",
"0.5219626",
"0.5219626",
"0.52151096",
"0.5212709",
"0.52101034",
"0.5208749",
"0.5205707"
]
| 0.0 | -1 |
set characters by default | public DeluxeBurger(){
super("Deluxe", "sausageBacon", 14.54, "white");
super.addHamburgerAddition1("chips", 2.75);
super.addHamburgerAddition2("Drink", 1.81);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setCharacterSequence(String chars);",
"public void setNChar()\n/* */ {\n/* 1168 */ this.isNChar = true;\n/* */ }",
"@Override\n public void setCharacter(String character) {\n this.character = character;\n }",
"static public void setDefaultChar(char newMissingChar) {\n defaultChar = newMissingChar;\n }",
"public void setBasicChar(BasicChar wotCharacter) {\n this.wotCharacter = wotCharacter;\n }",
"static public void setDefaultChars(char[] newMissingChars) {\n defaultCharArray = newMissingChars;\n }",
"private void setLevelUpChars() {\n /*\n * check this if you need more symbol set's\n * TODO do this right @me\n\t\t */\n String charset = KeyboardHandler.current_charset;\n if (charset.length() == 36) {\n for (int i = 0; i < 6; ++i) {\n characterAreas.get(i).setChars(\n charset.substring(i * 6, (i + 1) * 6));\n }\n }\n\n if (charset.length() == 40) {\n Log.d(\"main\",charset);\n characterAreas.get(0).setChars(charset.substring(0, 6));\n characterAreas.get(1).setChars(charset.substring(6, 14));\n characterAreas.get(2).setChars(charset.substring(14, 20));\n characterAreas.get(3).setChars(charset.substring(20, 26));\n characterAreas.get(4).setChars(charset.substring(26, 34));\n characterAreas.get(5).setChars(charset.substring(34, 40));\n }\n }",
"public void setChar(Character c) {\n setText(String.valueOf(c));\n }",
"@Override\n public void setCharacterEncoding(String arg0) {\n\n }",
"public void set_char(_char param) {\n this.local_char = param;\n }",
"void setCharacter(int c) {\n setStat(c, character);\n }",
"public void setCharSet(List<Character> charSet){\n mCharSet = charSet;\n }",
"public void\nsetNucCharSymbol()\n{\n\tthis.setNucCharSymbol(new Font(\"Helvetica\", Font.PLAIN, ComplexDefines.DEFAULT_NUC_FONT_SIZE));\n}",
"public void set_char(int param) {\n this.local_char = param;\n }",
"public void setValue(char value)\n\t{\n\t\tthis.value = value;\n\t}",
"public void characters(String arg0) {\n\t\t\t\t\t\t\r\n\t\t\t\t\t}",
"@Override\r\n\tpublic void setLetter(char letter) {\r\n\t\tsuper.setLetter('*');\r\n\t}",
"Alphabet(String chars) {\n _chars = sanitizeChars(chars);\n }",
"MyChar() {\n\t\tmyChar = '0';\n\t}",
"private static void initExtendedSet() {\r\n ESCAPE_CHARS.add(\"$\");\r\n ESCAPE_CHARS.add(\"/\");\r\n ESCAPE_CHARS.add(\"+\");\r\n ESCAPE_CHARS.add(\"%\");\r\n\r\n EXT_CHARS.put(new Character('\\000'), \"%U\");\r\n EXT_CHARS.put(new Character('\\001'), \"$A\");\r\n EXT_CHARS.put(new Character('\\002'), \"$B\");\r\n EXT_CHARS.put(new Character('\\003'), \"$C\");\r\n EXT_CHARS.put(new Character('\\004'), \"$D\");\r\n EXT_CHARS.put(new Character('\\005'), \"$E\");\r\n EXT_CHARS.put(new Character('\\006'), \"$F\");\r\n EXT_CHARS.put(new Character('\\007'), \"$G\");\r\n EXT_CHARS.put(new Character('\\010'), \"$H\");\r\n EXT_CHARS.put(new Character('\\011'), \"$I\");\r\n EXT_CHARS.put(new Character('\\012'), \"$J\");\r\n EXT_CHARS.put(new Character('\\013'), \"$K\");\r\n EXT_CHARS.put(new Character('\\014'), \"$L\");\r\n EXT_CHARS.put(new Character('\\015'), \"$M\");\r\n EXT_CHARS.put(new Character('\\016'), \"$N\");\r\n EXT_CHARS.put(new Character('\\017'), \"$O\");\r\n EXT_CHARS.put(new Character('\\020'), \"$P\");\r\n EXT_CHARS.put(new Character('\\021'), \"$Q\");\r\n EXT_CHARS.put(new Character('\\022'), \"$R\");\r\n EXT_CHARS.put(new Character('\\023'), \"$S\");\r\n EXT_CHARS.put(new Character('\\024'), \"$T\");\r\n EXT_CHARS.put(new Character('\\025'), \"$U\");\r\n EXT_CHARS.put(new Character('\\026'), \"$V\");\r\n EXT_CHARS.put(new Character('\\027'), \"$W\");\r\n EXT_CHARS.put(new Character('\\030'), \"$X\");\r\n EXT_CHARS.put(new Character('\\031'), \"$Y\");\r\n EXT_CHARS.put(new Character('\\032'), \"$Z\");\r\n EXT_CHARS.put(new Character('\\033'), \"%A\");\r\n EXT_CHARS.put(new Character('\\034'), \"%B\");\r\n EXT_CHARS.put(new Character('\\035'), \"%C\");\r\n EXT_CHARS.put(new Character('\\036'), \"%D\");\r\n EXT_CHARS.put(new Character('\\037'), \"%E\");\r\n EXT_CHARS.put(new Character('\\177'), \"%T\"); // Also %X, %Y, %Z\r\n\r\n EXT_CHARS.put(new Character('!'), \"/A\");\r\n EXT_CHARS.put(new Character('\"'), \"/B\");\r\n EXT_CHARS.put(new Character('#'), \"/C\");\r\n EXT_CHARS.put(new Character('$'), \"/D\");\r\n EXT_CHARS.put(new Character('%'), \"/E\");\r\n EXT_CHARS.put(new Character('&'), \"/F\");\r\n EXT_CHARS.put(new Character('\\''), \"/G\");\r\n EXT_CHARS.put(new Character('('), \"/H\");\r\n EXT_CHARS.put(new Character(')'), \"/I\");\r\n EXT_CHARS.put(new Character('*'), \"/J\");\r\n EXT_CHARS.put(new Character('+'), \"/K\");\r\n EXT_CHARS.put(new Character(','), \"/L\");\r\n EXT_CHARS.put(new Character('/'), \"/O\");\r\n EXT_CHARS.put(new Character(':'), \"/Z\");\r\n EXT_CHARS.put(new Character(';'), \"%F\");\r\n EXT_CHARS.put(new Character('\\u00AB'), \"%G\");\r\n EXT_CHARS.put(new Character('='), \"%H\");\r\n EXT_CHARS.put(new Character('>'), \"%I\");\r\n EXT_CHARS.put(new Character('?'), \"%J\");\r\n EXT_CHARS.put(new Character('@'), \"%V\");\r\n EXT_CHARS.put(new Character('['), \"%K\");\r\n EXT_CHARS.put(new Character('\\\\'), \"%L\");\r\n EXT_CHARS.put(new Character(']'), \"%M\");\r\n EXT_CHARS.put(new Character('^'), \"%N\");\r\n EXT_CHARS.put(new Character('_'), \"%O\");\r\n EXT_CHARS.put(new Character('`'), \"%W\");\r\n EXT_CHARS.put(new Character('{'), \"%P\");\r\n EXT_CHARS.put(new Character('|'), \"%Q\");\r\n EXT_CHARS.put(new Character('}'), \"%R\");\r\n EXT_CHARS.put(new Character('~'), \"%S\");\r\n\r\n EXT_CHARS.put(new Character('a'), \"+A\");\r\n EXT_CHARS.put(new Character('b'), \"+B\");\r\n EXT_CHARS.put(new Character('c'), \"+C\");\r\n EXT_CHARS.put(new Character('d'), \"+D\");\r\n EXT_CHARS.put(new Character('e'), \"+E\");\r\n EXT_CHARS.put(new Character('f'), \"+F\");\r\n EXT_CHARS.put(new Character('g'), \"+G\");\r\n EXT_CHARS.put(new Character('h'), \"+H\");\r\n EXT_CHARS.put(new Character('i'), \"+I\");\r\n EXT_CHARS.put(new Character('j'), \"+J\");\r\n EXT_CHARS.put(new Character('k'), \"+K\");\r\n EXT_CHARS.put(new Character('l'), \"+L\");\r\n EXT_CHARS.put(new Character('m'), \"+M\");\r\n EXT_CHARS.put(new Character('n'), \"+N\");\r\n EXT_CHARS.put(new Character('o'), \"+O\");\r\n EXT_CHARS.put(new Character('p'), \"+P\");\r\n EXT_CHARS.put(new Character('q'), \"+Q\");\r\n EXT_CHARS.put(new Character('r'), \"+R\");\r\n EXT_CHARS.put(new Character('s'), \"+S\");\r\n EXT_CHARS.put(new Character('t'), \"+T\");\r\n EXT_CHARS.put(new Character('u'), \"+U\");\r\n EXT_CHARS.put(new Character('v'), \"+V\");\r\n EXT_CHARS.put(new Character('w'), \"+W\");\r\n EXT_CHARS.put(new Character('x'), \"+X\");\r\n EXT_CHARS.put(new Character('y'), \"+Y\");\r\n EXT_CHARS.put(new Character('z'), \"+Z\");\r\n }",
"public void setCh(char ch) {\r\n\t\tthis.ch = ch;\r\n\t}",
"@Override\n\tpublic void characters(String text) {\n\t\t\n\t}",
"public void setLetter(char letter){\r\n\t\tthis.letter = letter;\r\n\t}",
"public void setCharacterEncoding(String s) {\n\n\t}",
"public void setCharSet(String charSet) {\n this.charSet = charSet;\n }",
"public void setValue(CharSequence chars) throws ReadOnlyException {\n selectByText((String) chars);\n }",
"public void setRepersent(char rep)\n {\n this.repersent=rep;\n }",
"public void setBlankValue(char let){\n value = 0;\n letter = Character.toUpperCase(let);\n\n }",
"protected void setSymbol(char c){\r\n\t\tthis.symbol = c;\r\n\t}",
"public void set_charId(byte id){\n character_id = id;\n }",
"static public char getDefaultChar() {\n return defaultChar;\n }",
"public void setCharNum(Integer charNum) {\n this.charNum = charNum;\n }",
"public void setCharacter(String newCharacter)\n\t\t{\n\t\t\tcharacterName = newCharacter;\n\t\t}",
"public Builder setCharSet(List<Character> charSet){\n mCharSet = charSet;\n return this;\n }",
"public void generateCode() {\n\t\tthis.setCharacter();\n\t}",
"public void setLetter\n\t\t\t(char letter)\n\t\t\t{\n\t\t\tletters = letter == 'Q' ? \"QU\" : \"\"+letter;\n\t\t\tsetText (letters);\n\t\t\t}",
"private void setCharLimitOnFields() {\n Common.setCharLimit(nameField, Constants.CHAR_LIMIT_NORMAL);\n Common.setCharLimit(addressField, Constants.CHAR_LIMIT_LARGE);\n Common.setCharLimit(postalField, Constants.CHAR_LIMIT_NORMAL);\n Common.setCharLimit(phoneField, Constants.CHAR_LIMIT_NORMAL);\n }",
"public void setLetter() {\n\t\tconfirmButton.setEnabled(true);\n\t\tpassButton.setEnabled(true);\n\t\tfor (int i = 0; i < ROW; i++) {\n\t\t\tfor (int j = 0; j < COLUME; j++) {\n\t\t\t\tif (board[i][j].getText().equals(\"\")) {\n\t\t\t\t\tboard[i][j].setEditable(true);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t}",
"public void setCharSet(byte charSet) {\n\t\tthis.charSet = charSet;\n\t}",
"public void setCharSet(int charset)\n {\n byte cs = (byte)charset;\n if(charset > 127) {\n cs = (byte)(charset-256);\n }\n setCharSet(cs);\n }",
"@Override\n\t\tpublic void setCharacterEncoding(String env) throws UnsupportedEncodingException {\n\t\t\t\n\t\t}",
"public void setSezione(char sezione) {\r\n this.sezione = sezione;\r\n }",
"void init(char c);",
"private void initLetters(Set<String> s) {\n\t\tfill(s,'A','Z');\n\t\tfill(s,'a','z');\n }",
"@Override\n\tpublic void setCharacterEncoding(String env) throws UnsupportedEncodingException {\n\t\t\n\t}",
"private void setCharsetName(String aCharsetName) {\r\n\t\tcharsetName = aCharsetName;\r\n\t}",
"public SingleChar(char c) {\n super(SOME, NONE);\n this.c = c;\n }",
"void setMaxCharSize(int value);",
"@Override\r\n\t\tpublic void setPromptSymbol(Character symbol) {\n\r\n\t\t}",
"public void setMerkki(char merkki){\r\n this.merkki = merkki; \r\n }",
"public void setCharSet(int charSet) {\n\t\tthis.charSet = (byte)charSet;\n\t}",
"public void setSymbol(char symbol) {\n\t\tthis.symbol = symbol;\n\t}",
"public void setCharSet(byte charset)\n {\n font.setCharset(charset);\n }",
"void setExtraChar (int i, int val);",
"public void setPromptSymbol(Character symbol);",
"public void addStrangeCharacter() {\n strangeCharacters++;\n }",
"public void setName(String name) {\n characterName = name;\n }",
"public void setKey(char key){ this.key = key;}",
"public void setGlyph(char c, WritingShape glyph) {\n\t\tKey<WritingShape> key = getGlyphKey(c);\n\t\tproperties.set(key, glyph);\n\t}",
"public void setCharSet(String paramCharSet) {\n\tstrCharSet = paramCharSet;\n }",
"public void setCharset(String string) {\n\t\t\r\n\t}",
"public void setExtended(char extended)\n {\n this.extended = extended;\n }",
"public void setCharCount(long value) {\n this.charCount = value;\n }",
"static public char[] getDefaultChars() {\n return defaultCharArray;\n }",
"Alphabet() {\n this(\"ABCDEFGHIJKLMNOPQRSTUVWXYZ\");\n }",
"Alphabet() {\n this(\"ABCDEFGHIJKLMNOPQRSTUVWXYZ\");\n }",
"Alphabet() {\n this(\"ABCDEFGHIJKLMNOPQRSTUVWXYZ\");\n }",
"public void setInitial(char roomInitial) {\n\t\tthis.initial = roomInitial; \n\t}",
"@Override\n public void convertCharacter(char character, StringBuilder outputTextBuilder) {\n }",
"protected void setCharValue(String name, String value) throws CharConversionException, UnsupportedEncodingException {\r\n\r\n APICharFieldDescription field = getCharFieldDescription(name);\r\n getCharConverter().stringToByteArray(StringHelper.getFixLength(value, field.getLength()), getBytes(), getAbsoluteFieldOffset(field),\r\n field.getLength());\r\n }",
"void setSymbol(@MaxUtf8Length(20) CharSequence symbol);",
"public void setChars(char[] data, int row, int column) {\n\t\tcolumns[column].setChars(data, subset[row]);\n\t}",
"String charWrite();",
"public CCPackedGSMCharset() {\n super(NAME,ALIASES,\n BYTE_TO_CHAR_CAPITAL_C_CEDILLA,BYTE_TO_CHAR_ESCAPED_DEFAULT,\n CHAR_TO_BYTE_CAPITAL_C_CEDILLA,CHAR_TO_BYTE_ESCAPED_DEFAULT);\n }",
"void set(int n, char s) {\n set(n);\n set(s);\n }",
"public void setAsteroid(char newChar) {\r\n\t\tthis.asteroid = newChar;\r\n\t}",
"@Accessor(qualifier = \"quoteCharacter\", type = Accessor.Type.SETTER)\n\tpublic void setQuoteCharacter(final Character value)\n\t{\n\t\tgetPersistenceContext().setPropertyValue(QUOTECHARACTER, value);\n\t}",
"public static char getDefaultAttributeQuoteChar()\n {\n return defaults.attribute_quote_char;\n }",
"public void xsetCharacterString(org.apache.xmlbeans.XmlString characterString)\n {\n synchronized (monitor())\n {\n check_orphaned();\n org.apache.xmlbeans.XmlString target = null;\n target = (org.apache.xmlbeans.XmlString)get_store().find_element_user(CHARACTERSTRING$1, 0);\n if (target == null)\n {\n target = (org.apache.xmlbeans.XmlString)get_store().add_element_user(CHARACTERSTRING$0);\n }\n target.set(characterString);\n }\n }",
"public void setFirstLetterJCB() {\r\n try {\r\n firstLetterJCB.addItem(\"---\");\r\n firstLetterJCB.addItem(\"All\");\r\n for (int i = 0; i < 10; i++) {\r\n firstLetterJCB.addItem(new Integer(i));\r\n }\r\n for (char j = 'A'; j <= 'Z'; j++ ) {\r\n firstLetterJCB.addItem(new Character(j));\r\n }\r\n } catch (Exception e) {\r\n e.printStackTrace();\r\n }\r\n }",
"public void setText(char[] chars, int start, int length);",
"@Override\n public String getCharacterEncoding() {\n return null;\n }",
"public void resetSpecialChars(){\r\n //When a Greek symbols is missing (Backspace) from the Text Field its corresponding Greek button gets Enabled\r\n if(!anglefield.getText().contains(\"α\"))alpha_btn.setDisable(false);\r\n if(!anglefield.getText().contains(\"β\"))beta_btn.setDisable(false);\r\n if(!anglefield.getText().contains(\"γ\"))gamma_btn.setDisable(false);\r\n if(!anglefield.getText().contains(\"δ\"))delta_btn.setDisable(false);\r\n if(!anglefield.getText().contains(\"θ\"))theta_btn.setDisable(false);\r\n if(!anglefield.getText().contains(\"ɸ\"))phi_btn.setDisable(false);\r\n }",
"@Override\n public void characters(char[] ch, int start, int length)\n throws SAXException {\n\n // We don't need this, because our values are set as an attribute\n\n }",
"public void setText(String s) throws UnsupportedEncodingException {\n\t\tthis.text = s.getBytes(\"Cp437\");\n\t}",
"Builder addCharacter(String value);",
"public LetterSet() {\n this(\"enEN\");\n }",
"public JsonFactory setCharacterEscapes(CharacterEscapes esc)\n/* */ {\n/* 666 */ this._characterEscapes = esc;\n/* 667 */ return this;\n/* */ }",
"public void updateChar(int c) {\n\t\tchars = c;\n\t}",
"public void setGender(char gender) { this.gender = gender; }",
"protected final void setSuperscript() {\n setFontSize((int) (getFontSize() * 0.5d));\n yOffset -= getFontSize();\n }",
"@Override\n public void setDefault() {\n value = new byte[] {0x40};\n }",
"private String getCharacterString()\n {\n String returnString = \"Characters:\\n\\t\";\n Set<String> keys = characters.keySet();\n if(characters.size() <= 0) {\n returnString += \"[None]\";\n return returnString;\n }\n for(String character : keys) {\n returnString += \" [\" + character + \"]\";\n }\n return returnString;\n }",
"public void setVar126(java.lang.CharSequence value) {\n this.var126 = value;\n }",
"public void setEncodingAlpha(boolean encodeAlpha);",
"public void setGender(char gender) {\n\n if(gender=='m'||gender=='f'||gender=='M'||gender=='F')\n this.gender = gender;\n else this.gender ='*';\n }",
"public void setCap(String aCap) {\n cap = aCap;\n }",
"@Override\n public void btPutChar(int value) {\n }",
"public CharCharMap() {\n this(DEFAULT_INITIAL_SIZE, DEFAULT_LOAD_FACTOR);\n }",
"public void setChar(char data, int row, int column) {\n\t\tcolumns[column].setChar(data, subset[row]);\n\t}",
"void setCharacterStatistic(CharacterStatistic statistic);"
]
| [
"0.77039003",
"0.7249356",
"0.7187489",
"0.71028847",
"0.69934726",
"0.6964245",
"0.69199866",
"0.68655246",
"0.6856582",
"0.6742972",
"0.6742689",
"0.67363954",
"0.67329377",
"0.67283875",
"0.6673466",
"0.65839404",
"0.65652525",
"0.6536579",
"0.65326583",
"0.6400298",
"0.6379267",
"0.63719976",
"0.636935",
"0.6365663",
"0.63639456",
"0.63311595",
"0.6330886",
"0.63103086",
"0.62841773",
"0.6230743",
"0.62230766",
"0.61822593",
"0.61688685",
"0.61347526",
"0.61269444",
"0.61049545",
"0.6099521",
"0.60852724",
"0.6079509",
"0.6073841",
"0.60712695",
"0.6038026",
"0.6026407",
"0.6024549",
"0.59673256",
"0.5952893",
"0.5949362",
"0.59337765",
"0.5932298",
"0.5930995",
"0.5925008",
"0.5921377",
"0.59036714",
"0.5897367",
"0.58826756",
"0.5881521",
"0.5881307",
"0.5870343",
"0.58646345",
"0.58590716",
"0.5856427",
"0.58534884",
"0.58488876",
"0.58465",
"0.5844679",
"0.5844679",
"0.5844679",
"0.58167636",
"0.5813241",
"0.5800246",
"0.5797558",
"0.57832867",
"0.5781582",
"0.5779881",
"0.57721144",
"0.57705057",
"0.576632",
"0.5765183",
"0.57591575",
"0.5756841",
"0.57503986",
"0.57446486",
"0.5734922",
"0.5733309",
"0.5732604",
"0.57321244",
"0.5719404",
"0.5716509",
"0.57161367",
"0.57156616",
"0.5713854",
"0.5713544",
"0.571348",
"0.5708754",
"0.5690291",
"0.568449",
"0.56835216",
"0.5680803",
"0.5677702",
"0.5675047",
"0.56687886"
]
| 0.0 | -1 |
Test a Clock by setting up a simple test scenario of three timers, stopped independently from each other. Afterwards the result is logged. No errors should occur during this test. | @Test
public void test() throws InterruptedException{
final Clock clock=new Clock();
clock.addTimer("Jef");
clock.addTimer("An");
clock.addTimer("Eva");
clock.startAll();
Thread.sleep(5000); // Sleep 5 seconds
clock.stop("An");
Thread.sleep(2000); // Sleep 2 seconds
clock.stop("Jef");
Thread.sleep(3000); // Sleep 3 seconds
clock.stop("Eva");
clock.time();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public ClockTest( String testName )\r\n {\r\n super( testName );\r\n }",
"public void testTheClock() throws Exception\r\n {\r\n Clock clock = new SimpleClock();\r\n String timestamp = clock.getTimestamp();\r\n Logger logger = Logger.getLogger( \"test\" );\r\n logger.info( timestamp );\r\n }",
"@Test\n public void testStartAndStopTimer() throws InterruptedException {\n // Define inputs\n final CustomMetric metricDefinition = new CustomMetric(\"MyContext.MyMetric\");\n final String expectedMetricName = \"MyContext.MyMetric\";\n final String expectedTotalTimeMetricName = expectedMetricName + \"_totalTimeMs\";\n\n // Create empty config\n final Map<String, Object> config = new HashMap<>();\n\n // Create mock TopologyContet\n final MockTopologyContext mockTopologyContext = new MockTopologyContext();\n\n // Create recorder and call open.\n final StormRecorder recorder = new StormRecorder();\n recorder.open(config, mockTopologyContext);\n\n // Lets capture the metrics\n final MultiReducedMetric timerMetrics = (MultiReducedMetric) mockTopologyContext.getRegisteredMetricByName(\"TIMERS\");\n final MultiCountMetric counterMetrics = (MultiCountMetric) mockTopologyContext.getRegisteredMetricByName(\"COUNTERS\");\n\n // Lets time something. It's ok if this ends up being 0.\n recorder.startTimer(metricDefinition);\n recorder.stopTimer(metricDefinition);\n\n // Validate\n @SuppressWarnings(\"unchecked\")\n final Map<String, Long> timerValues = (Map<String, Long>) timerMetrics.getValueAndReset();\n assertEquals(1, timerValues.size(), \"Should have 1 value\");\n assertTrue(timerValues.containsKey(expectedMetricName), \"Should contain our key\");\n\n // Validate total timer got updated\n @SuppressWarnings(\"unchecked\")\n final Map<String, Long> counterValues = (Map<String, Long>) counterMetrics.getValueAndReset();\n assertEquals(1, counterValues.size(), \"Should have 1 value\");\n assertTrue(counterValues.containsKey(expectedTotalTimeMetricName), \"Should contain our key\");\n }",
"public void testTime()\n {\n SudokuTimer test = new SudokuTimer();\n\n mTimer.start();\n test.start();\n\n for (int i = 0; i < 1000000000; i++)\n {\n }\n\n assertTrue(mTimer.toString().equals(test.toString()));\n\n mTimer.stop();\n\n for (int i = 0; i < 1000000000; i++)\n {\n }\n\n assertFalse(mTimer.toString().equals(test.toString()));\n\n test.stop();\n mTimer.start();\n\n for (int i = 0; i < 1000000000; i++)\n {\n }\n\n mTimer.stop();\n\n //checks to the nearest second\n assertEquals(mTimer.getElapsedTime() / 1000,\n test.getElapsedTime() / 1000);\n }",
"public void testElapsedStartStop() throws Exception {\n \n if (isFastJUnitTesting()){\n return;\n }\n\n String testName = this.getName();\n\n /**\n * Number of second to wait before starting and stopping contest clock.\n */\n int secondsToWait = 3;\n\n long ms = secondsToWait * Constants.MS_PER_SECONDS;\n\n ContestTime contestTime = new ContestTime();\n\n contestTime.startContestClock();\n\n debugPrint(testName + \": sleep for \" + secondsToWait + \" seconds.\");\n Thread.sleep(ms);\n\n contestTime.stopContestClock();\n long actualSecs = contestTime.getElapsedSecs();\n assertTrue(\"After stop, expecting elapsed time secs > \" + secondsToWait + \", was=\" + secondsToWait, actualSecs >= secondsToWait);\n\n long actualMS = contestTime.getElapsedMS();\n assertTrue(\"After stop, expecting elapsed time ms > \" + ms + \", was=\" + actualMS, actualMS >= ms);\n\n contestTime.startContestClock();\n actualSecs = contestTime.getElapsedSecs();\n assertTrue(\"After stop, expecting elapsed time secs > \" + secondsToWait + \", was=\" + secondsToWait, actualSecs >= secondsToWait);\n\n debugPrint(testName + \": sleep for \" + secondsToWait + \" seconds.\");\n Thread.sleep(ms);\n\n actualMS = contestTime.getElapsedMS();\n assertTrue(\"After start, expecting elapsed time ms > \" + ms + \", was=\" + actualMS, actualMS >= ms);\n }",
"public void testCommands()\n {\n mTimer.stop();\n assertFalse(mTimer.isRunning());\n\n mTimer.start();\n assertTrue(mTimer.isRunning());\n\n mTimer.stop();\n assertFalse(mTimer.isRunning());\n\n mTimer.reset();\n assertFalse(mTimer.isRunning());\n assertEquals(mTimer.getElapsedTime(), 0);\n\n assertEquals(mTimer.toString(), \"00:00.000\");\n }",
"private static void timerTest3() {\n\t\tTimer timer = new Timer();\n\t\ttimer.scheduleAtFixedRate(new TimerTask() {\n\n\t\t\t@Override\n\t\t\tpublic void run() {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tSystem.out.println(\"timertest3\");\n\n\t\t\t}\n\t\t}, 2000, 1000);\n\n\t}",
"public static void main(String[] args) {\n\t\ttimerTest1();\n\t\ttimerTest2();\n//\t\ttimerTest3();\n\t\ttimerTest4();\n\n\t}",
"@Override\n\t\t\tpublic void run() {\n\t\t\t\tSystem.out.println(\"timertest3\");\n\n\t\t\t}",
"@Test\n public void testStartClock() {\n System.out.println(\"startClock\");\n OnOffButton testOnOff = new OnOffButton(\"\");\n testOnOff.startClock();\n \n }",
"public static void main(String args[]) {\n\t\t// Initialize a new digital clock, referenced by the variable\n\t\t// myClock, and initialized to 7h35. \n\t\tDigitalClock myClock = new DigitalClock(7,35);\n\t\t\tSystem.out.println(\"Expected time: 7h35\");\n\t\t\tSystem.out.println(\" \" + myClock.getHours() + \"h\" + myClock.getMinutes());\n\t\t// Initialize another new digital clock, referenced by the variable\n\t\t// yourClock, and initialized to 0h00. \n\t\tDigitalClock yourClock = new DigitalClock();\n\t\t\tSystem.out.println(\"Expected time: 0h00\");\n\t\t\tSystem.out.println(\" \" + yourClock.getHours() + \"h\" + yourClock.getMinutes());\n\t\t// Change the hours displayed by myClock to 33.\n\t\tmyClock.setHours(33);\n\t\t\tSystem.out.println(\"Expected time: 9h35\");\n\t\t\tSystem.out.println(\" \" + myClock.getHours() + \"h\" + myClock.getMinutes());\n\t\t// Introduce a local variable myMinutes, initialized with the\n\t\t// minutes displayed by myClock.\n\t\tint myMinutes = myClock.getMinutes();\n\t\t// Make the variable yourClock reference the digital clock referenced\n\t\t// by the variable myClock.\n\t\tyourClock = myClock;\n\t\t// Advance the minutes of the digital clock referenced by the\n\t\t// variable yourClock.\n\t\tyourClock.advanceMinutes();\n\t\t\tSystem.out.println(\"Expected time: 9h36\");\n\t\t\tSystem.out.println(\" \" + myClock.getHours() + \"h\" + myClock.getMinutes());\t\n\t\t\tSystem.out.println(\"Expected value: 35\");\n\t\t\tSystem.out.println(\" \" + myMinutes);\n\t}",
"public void testElapsedStartStopInContest() throws Exception {\n \n if (isFastJUnitTesting()){\n return;\n }\n\n String testName = this.getName();\n /**\n * Number of second to wait before starting and stopping contest clock.\n */\n int secondsToWait = 10;\n int siteNumber = 2;\n\n long ms = secondsToWait * Constants.MS_PER_SECONDS;\n\n IInternalContest contest = sampleContest.createContest(siteNumber, siteNumber, 12, 12, true);\n\n contest.startContest(siteNumber);\n\n debugPrint(testName + \": sleep for \" + secondsToWait + \" seconds.\");\n Thread.sleep(ms);\n\n contest.stopContest(siteNumber);\n long actualSecs = contest.getContestTime().getElapsedSecs();\n assertTrue(\"After stop, expecting elapsed time secs > \" + secondsToWait + \", was=\" + secondsToWait, actualSecs >= secondsToWait);\n\n long actualMS = contest.getContestTime().getElapsedMS();\n assertTrue(\"After stop, expecting elapsed time ms > \" + ms + \", was=\" + actualMS, actualMS >= ms);\n\n contest.startContest(siteNumber);\n actualSecs = contest.getContestTime().getElapsedSecs();\n assertTrue(\"After stop, expecting elapsed time secs > \" + secondsToWait + \", was=\" + secondsToWait, actualSecs >= secondsToWait);\n\n actualMS = contest.getContestTime().getElapsedMS();\n assertTrue(\"After start, expecting elapsed time ms > \" + ms + \", was=\" + actualMS, actualMS >= ms);\n }",
"@Test\r\n\t// numero 43\r\n\tvoid testGetTime() {\n\t\tclock.setVirtual(true);\r\n\t\tlong result = clock.getTime();\r\n\t\tlong expected = 0;\r\n\t\tassertEquals(expected, result);\r\n\t\r\n\t// numero 44\r\n\t\t//sinon cela retourne Date().getTime()\r\n\t\tclock.setVirtual(false);\r\n\t\tlong result2 = clock.getTime();\r\n\t\tlong expected2 = new Date().getTime();\r\n\t\tassertEquals(expected2, result2);\r\n\r\n\t}",
"public static void main (String args[]) {\t\t\t\t\t\t\t\t\t\t\t\t // 5\n\t\tSystem.out.println(\"Testing the Clock class...\");\n\n\t\tClock clock1 = new Clock(0.1);\n\t\tClock clock2 = new Clock(0.5);\n\t\tClock clock3 = new Clock(3.0);\n\n\t\tfor (int i = 0; i < 10; i++) {\n\n\t\t\tclock1.moveForward();\n\t\t\tclock2.moveForward();\n\t\t\tclock3.moveForward();\n\n\t\t\tSystem.out.println( \"Clock 1 time is \" + clock1.toString() );\n\t\t\tSystem.out.println( \"Clock 2 time is \" + clock2.toString() );\n\t\t\tSystem.out.println( \"Clock 3 time is \" + clock3.toString() );\n\t\t}\n\t}",
"private void mockSystemClock() {\n mockedStartTimestamp = record.getRecorder().getStartTimestamp();\n ShadowSystemClock.setCurrentTimeMillis(mockedStartTimestamp);\n }",
"@Test\n public void testTimelyTest() {\n }",
"public static void selfTest() {\n\talarmTest1();\n\t// Invoke your other test methods here ...\n }",
"@Test\r\n\tpublic void testGetTimeslot() {\r\n\t\tassertEquals(time1, breaku1.getTimeslot());\r\n\t\tassertEquals(time1, externu1.getTimeslot());\r\n\t\tassertEquals(time1, meetingu1.getTimeslot());\r\n\t\tassertEquals(time1, teachu1.getTimeslot());\r\n\t}",
"@Test\n public void testEJTimerTracking_AllBackground() {\n setDischarging();\n setProcessState(ActivityManager.PROCESS_STATE_RECEIVER);\n\n JobStatus jobStatus = createExpeditedJobStatus(\"testEJTimerTracking_AllBackground\", 1);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n }\n assertNull(mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n List<TimingSession> expected = new ArrayList<>();\n\n // Test single job.\n long start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(5 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, null, false);\n }\n expected.add(createTimingSession(start, 5 * SECOND_IN_MILLIS, 1));\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n // Test overlapping jobs.\n JobStatus jobStatus2 = createExpeditedJobStatus(\"testEJTimerTracking_AllBackground\", 2);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus2, null);\n }\n\n JobStatus jobStatus3 = createExpeditedJobStatus(\"testEJTimerTracking_AllBackground\", 3);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus3, null);\n }\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus2);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus3);\n }\n advanceElapsedClock(20 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus3, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus2, null, false);\n }\n expected.add(createTimingSession(start, MINUTE_IN_MILLIS, 3));\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n }",
"@Test\n public void testTimerTracking_ChargingAndDischarging() {\n setProcessState(ActivityManager.PROCESS_STATE_IMPORTANT_BACKGROUND);\n\n JobStatus jobStatus = createJobStatus(\"testTimerTracking_ChargingAndDischarging\", 1);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n }\n JobStatus jobStatus2 = createJobStatus(\"testTimerTracking_ChargingAndDischarging\", 2);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus2, null);\n }\n JobStatus jobStatus3 = createJobStatus(\"testTimerTracking_ChargingAndDischarging\", 3);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus3, null);\n }\n assertNull(mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n List<TimingSession> expected = new ArrayList<>();\n\n // A job starting while charging. Only the portion that runs during the discharging period\n // should be counted.\n setCharging();\n\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n setDischarging();\n long start = JobSchedulerService.sElapsedRealtimeClock.millis();\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, jobStatus, true);\n }\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n assertEquals(expected, mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n\n // One job starts while discharging, spans a charging session, and ends after the charging\n // session. Only the portions during the discharging periods should be counted. This should\n // result in two TimingSessions. A second job starts while discharging and ends within the\n // charging session. Only the portion during the first discharging portion should be\n // counted. A third job starts and ends within the charging session. The third job\n // shouldn't be included in either job count.\n setDischarging();\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus2);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n setCharging();\n expected.add(createTimingSession(start, 20 * SECOND_IN_MILLIS, 2));\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus3);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus3, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus2, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n setDischarging();\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n advanceElapsedClock(20 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, null, false);\n }\n expected.add(createTimingSession(start, 20 * SECOND_IN_MILLIS, 1));\n assertEquals(expected, mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n // A job starting while discharging and ending while charging. Only the portion that runs\n // during the discharging period should be counted.\n setDischarging();\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus2, null);\n mQuotaController.prepareForExecutionLocked(jobStatus2);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n setCharging();\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus2, null, false);\n }\n assertEquals(expected, mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n }",
"@Override\n\t\t\tpublic void run() {\n\t\t\t\tSystem.out.println(\"timertest4\");\n\n\t\t\t}",
"@Test\n public void resetClock_WhenCalled_ClockShouldBeResetTo0(){\n ContextManager.resetClock(\"David\");\n assertEquals(mockUser.clock , 0);\n\n }",
"@Test\n\tpublic void testMakeMeterSectionTimes() {\n\t\tScorePiece sp = new ScorePiece(MIDIImport.importMidiFile(midiTestGetMeterKeyInfo));\n\t\tScoreMetricalTimeLine smtl = new ScoreMetricalTimeLine(sp.getMetricalTimeLine());\n\n\t\tList<Long> expected = Arrays.asList(new Long[]{\n\t\t\t(long) 0, \n\t\t\t(long) 1800000, \n\t\t\t(long) 11400000, \n\t\t\t(long) 25800000, \n\t\t\t(long) 30600000, \n\t\t\t(long) 31350000\n\t\t});\n\n\t\tList<Long> actual = smtl.makeMeterSectionTimes();\n\n\t\tassertEquals(expected.size(), actual.size());\n\t\tfor (int i = 0; i < expected.size(); i++) {\n\t\t\tassertEquals(expected.get(i), actual.get(i));\t\t\n\t\t}\n\t\tassertEquals(expected, actual);\n\t}",
"@Test\n public void testTimerTracking_AllBackground() {\n setDischarging();\n setProcessState(ActivityManager.PROCESS_STATE_RECEIVER);\n\n JobStatus jobStatus = createJobStatus(\"testTimerTracking_AllBackground\", 1);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n }\n assertNull(mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n List<TimingSession> expected = new ArrayList<>();\n\n // Test single job.\n long start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(5 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, null, false);\n }\n expected.add(createTimingSession(start, 5 * SECOND_IN_MILLIS, 1));\n assertEquals(expected, mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n // Test overlapping jobs.\n JobStatus jobStatus2 = createJobStatus(\"testTimerTracking_AllBackground\", 2);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus2, null);\n }\n\n JobStatus jobStatus3 = createJobStatus(\"testTimerTracking_AllBackground\", 3);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus3, null);\n }\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus2);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus3);\n }\n advanceElapsedClock(20 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus3, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus2, null, false);\n }\n expected.add(createTimingSession(start, MINUTE_IN_MILLIS, 3));\n assertEquals(expected, mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n }",
"@Test\n public void testEJTimerTracking_ChargingAndDischarging() {\n setProcessState(ActivityManager.PROCESS_STATE_IMPORTANT_BACKGROUND);\n\n JobStatus jobStatus =\n createExpeditedJobStatus(\"testEJTimerTracking_ChargingAndDischarging\", 1);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n }\n JobStatus jobStatus2 =\n createExpeditedJobStatus(\"testEJTimerTracking_ChargingAndDischarging\", 2);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus2, null);\n }\n JobStatus jobStatus3 =\n createExpeditedJobStatus(\"testEJTimerTracking_ChargingAndDischarging\", 3);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus3, null);\n }\n assertNull(mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n List<TimingSession> expected = new ArrayList<>();\n\n // A job starting while charging. Only the portion that runs during the discharging period\n // should be counted.\n setCharging();\n\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n setDischarging();\n long start = JobSchedulerService.sElapsedRealtimeClock.millis();\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, jobStatus, true);\n }\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n\n // One job starts while discharging, spans a charging session, and ends after the charging\n // session. Only the portions during the discharging periods should be counted. This should\n // result in two TimingSessions. A second job starts while discharging and ends within the\n // charging session. Only the portion during the first discharging portion should be\n // counted. A third job starts and ends within the charging session. The third job\n // shouldn't be included in either job count.\n setDischarging();\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus2);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n setCharging();\n expected.add(createTimingSession(start, 20 * SECOND_IN_MILLIS, 2));\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus3);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus3, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus2, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n setDischarging();\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n advanceElapsedClock(20 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, null, false);\n }\n expected.add(createTimingSession(start, 20 * SECOND_IN_MILLIS, 1));\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n // A job starting while discharging and ending while charging. Only the portion that runs\n // during the discharging period should be counted.\n setDischarging();\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus2, null);\n mQuotaController.prepareForExecutionLocked(jobStatus2);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n setCharging();\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus2, null, false);\n }\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n }",
"public static void alarmTest1() {\n\tint durations[] = {1000, 10*1000, 100*1000};\n\tlong t0, t1;\n\tfor (int d : durations) {\n\t t0 = Machine.timer().getTime();\n\t ThreadedKernel.alarm.waitUntil (d);\n\t t1 = Machine.timer().getTime();\n\t System.out.println (\"alarmTest1: waited for \" + (t1 - t0) + \" ticks\");\n\t}\n }",
"public void testPeriodic() {\n \n }",
"public void testPeriodic() {\n \n }",
"public void testPeriodic() {\n \n }",
"@Test\n public void testEJTimerTracking_TempAllowlisting() {\n setDischarging();\n setProcessState(ActivityManager.PROCESS_STATE_RECEIVER);\n final long gracePeriodMs = 15 * SECOND_IN_MILLIS;\n setDeviceConfigLong(QcConstants.KEY_EJ_GRACE_PERIOD_TEMP_ALLOWLIST_MS, gracePeriodMs);\n Handler handler = mQuotaController.getHandler();\n spyOn(handler);\n\n JobStatus job1 = createExpeditedJobStatus(\"testEJTimerTracking_TempAllowlisting\", 1);\n JobStatus job2 = createExpeditedJobStatus(\"testEJTimerTracking_TempAllowlisting\", 2);\n JobStatus job3 = createExpeditedJobStatus(\"testEJTimerTracking_TempAllowlisting\", 3);\n JobStatus job4 = createExpeditedJobStatus(\"testEJTimerTracking_TempAllowlisting\", 4);\n JobStatus job5 = createExpeditedJobStatus(\"testEJTimerTracking_TempAllowlisting\", 5);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(job1, null);\n }\n assertNull(mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n List<TimingSession> expected = new ArrayList<>();\n\n long start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(job1);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(job1, job1, true);\n }\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n\n // Job starts after app is added to temp allowlist and stops before removal.\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n mTempAllowlistListener.onAppAdded(mSourceUid);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(job2, null);\n mQuotaController.prepareForExecutionLocked(job2);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(job2, null, false);\n }\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n // Job starts after app is added to temp allowlist and stops after removal,\n // before grace period ends.\n mTempAllowlistListener.onAppAdded(mSourceUid);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(job3, null);\n mQuotaController.prepareForExecutionLocked(job3);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n mTempAllowlistListener.onAppRemoved(mSourceUid);\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n long elapsedGracePeriodMs = 2 * SECOND_IN_MILLIS;\n advanceElapsedClock(elapsedGracePeriodMs);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(job3, null, false);\n }\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n elapsedGracePeriodMs += SECOND_IN_MILLIS;\n\n // Job starts during grace period and ends after grace period ends\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(job4, null);\n mQuotaController.prepareForExecutionLocked(job4);\n }\n final long remainingGracePeriod = gracePeriodMs - elapsedGracePeriodMs;\n start = JobSchedulerService.sElapsedRealtimeClock.millis() + remainingGracePeriod;\n advanceElapsedClock(remainingGracePeriod);\n // Wait for handler to update Timer\n // Can't directly evaluate the message because for some reason, the captured message returns\n // the wrong 'what' even though the correct message goes to the handler and the correct\n // path executes.\n verify(handler, timeout(gracePeriodMs + 5 * SECOND_IN_MILLIS)).handleMessage(any());\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(job4, job4, true);\n }\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n // Job starts and runs completely after temp allowlist grace period.\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(job5, null);\n mQuotaController.prepareForExecutionLocked(job5);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(job5, job5, true);\n }\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n }",
"@Test\n public void testInc(){\n CountDownTimer s1 = new CountDownTimer(1, 49, 30);\n \tfor(int i = 0; i < 15000; i++){\n \t\ts1.inc();\n }\n assertEquals(s1.toString(), \"5:59:30\");\n }",
"private static void timerTest1() {\n\t\tTimer timer = new Timer();\n\t\ttimer.schedule(new TimerTask() {\n\n\t\t\t@Override\n\t\t\tpublic void run() {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tSystem.out.println(\"timertest1\");\n\t\t\t\ttimer.cancel();\n\n\t\t\t}\n\t\t}, 2000);\n\n\t}",
"@Test\n public void testStopClock() {\n System.out.println(\"stopClock\");\n OnOffButton testOnOff = new OnOffButton(\"\");\n testOnOff.stopClock();\n \n\n }",
"public void testPeriodic() {\n Scheduler.getInstance().run();\n }",
"public static void setup() {\n\n timers = new LinkedList<>();\n }",
"@Override\n public void startClock() {\n state = ClockState.RUNNING;\n /*\n * Used as scaling factor for workload and virtual machine power --> Need to\n * scale output as well\n */\n double scalingFactor = this.clockTicksTillWorkloadChange*this.intervalDurationInMilliSeconds;\n clockEventPublisher.fireStartSimulationEvent(0, intervalDurationInMilliSeconds, scalingFactor);\n\n while (clockTickCount <= experimentDurationInClockTicks) {\n fireEvents();\n clockTickCount++;\n\n }\n clockEventPublisher.fireFinishSimulationEvent(clockTickCount, intervalDurationInMilliSeconds);\n\n }",
"public void testPeriodic() {\r\n }",
"@Override\n public void testPeriodic()\n {\n \n }",
"@Test\n public void testAdd(){\n \tCountDownTimer s1 = new CountDownTimer(1, 0, 0);\n \ts1.add(1800);\n \tassertEquals(s1.toString(), \"1:30:00\");\n \t\n \tCountDownTimer s2 = new CountDownTimer(0, 30, 0);\n \ts1.add(s2);\n \tassertEquals(s1.toString(), \"2:00:00\");\n }",
"public void testFindEmployeeOrdersWithTimer() {\n\t\tSystem.out.println(\"started test testFindEmployeeOrdersWithTimer\");\n\t\tlong start = System.currentTimeMillis();\n\t\tFlux<Order> empFoundOrders = employeeController.findEmployeeOrders(employee.getAge()).take(10);\n\t\t\n\t\tStepVerifier.withVirtualTime(() -> empFoundOrders)\n\t\t\t\t\t.expectSubscription()\n\t\t\t\t\t.thenAwait(Duration.ofHours(10))\n\t\t\t\t\t.expectNextCount(10)\n\t\t\t\t\t.verifyComplete();\n\t\tlong end = System.currentTimeMillis();\n\t\tdouble totatSeconds = (end-start)/1000;\n\t\tSystem.out.println(\"completed test testFindEmployeeOrdersWithTimer in time \"+totatSeconds);\n\t}",
"private static void timerTest4() {\n\t\tCalendar calendar = Calendar.getInstance();\n\t\tcalendar.set(Calendar.HOUR_OF_DAY, 14);\n\t\tcalendar.set(Calendar.MINUTE, 20);\n\t\tcalendar.set(Calendar.SECOND, 0);\n\t\tDate time = calendar.getTime();\n\n\t\tTimer timer = new Timer();\n\t\tSystem.out.println(\"wait ....\");\n\t\ttimer.scheduleAtFixedRate(new TimerTask() {\n\n\t\t\t@Override\n\t\t\tpublic void run() {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tSystem.out.println(\"timertest4\");\n\n\t\t\t}\n\t\t}, time, 24 * 60 * 60 * 1000);\n\n\t}",
"@Before\r\n\tpublic void setUp() { timeslots = new ArrayList<Timeslot>(); timetable = new Timetable(); System.setOut(new PrintStream(outContent)); }",
"@Test\n public void testTotalSeconds(){\n \tCountDownTimer s = new CountDownTimer(2, 45, 15);\n \tassertEquals(CountDownTimer.totalSeconds(s), 9915);\n \t\n \ts = new CountDownTimer();\n \tassertEquals(CountDownTimer.totalSeconds(s), 0);\n \t\n \ts = new CountDownTimer(\"1:00:30\");\n \tassertEquals(CountDownTimer.totalSeconds(s), 3630);\n }",
"public void testPeriodic() {\r\n \r\n }",
"public void testPeriodic() {\r\n \r\n }",
"@Override\n public void testPeriodic() {\n }",
"@Override\n public void testPeriodic() {\n }",
"@Override\n public void testPeriodic() {\n }",
"@Override\n public void testPeriodic() {\n }",
"@Override\n public void testPeriodic() {\n }",
"@Override\n public void testPeriodic() {\n }",
"@Override\n public void testPeriodic() {\n }",
"@Override\n public void testPeriodic() {\n }",
"@Override\n public void testPeriodic() {\n }",
"@Override\n public void testPeriodic() {\n }",
"@Test\n public void testC1() throws InterruptedException {\n\n System.out.println();\n System.out.println(\"Test C1\");\n System.out.println();\n\n c.tick();\n\n // Diesmal Liste mit Wissenschaftlern besorgen\n final List<Scientist> scientists = new LinkedList<>();\n\n final Thread[] startAll = m.startAll(2, 1, 100, 100, 1000, AlgorithmType.C, scientists);\n\n Assert.assertEquals(\"Es wurden nicht alle Threads erzeugt\", 2, startAll.length);\n Assert.assertEquals(\"Es wurden nicht alle Wissenschaftler erzeugt\", 2, scientists.size());\n\n for (Thread t : startAll) {\n t.join();\n System.out.println(\"joined \" + t.getName());\n }\n\n c.tick();\n assertTiming(300);\n\n Thread.sleep(EPS); // warten, bis sich auch die Timer beendet haben!\n Assert.assertEquals(NUM_NON_DEAMON, getNonDaemonThreads());\n\n // keiner darf wahnsinnig sein\n for (Scientist s : scientists) {\n Assert.assertEquals(false, s.isInsane());\n }\n\n }",
"public void clock(double period);",
"@Test\n public void testCreateEvent () throws InterruptedException\n {\n onView(withId(R.id.event_name_add_event)).perform(typeText(eventName), ViewActions.closeSoftKeyboard());\n // Wait function\n synchronized (this) {\n Thread.sleep((long) 1000);\n }\n\n\n // Test for add event location\n onView(withId(R.id.event_location_add_event)).perform(typeText(eventLocation), ViewActions.closeSoftKeyboard());\n // Wait function\n synchronized (this) {\n Thread.sleep((long) 1000);\n }\n\n // Test for STATIC event\n onView(withId(R.id.type_of_event_add_event)).perform(click());\n onView(withText(\"STATIC\")).perform(click());\n // Wait function\n synchronized (this) {\n Thread.sleep((long) 1000);\n }\n\n // Test for event color\n onView(withId(R.id.color_dropdown_add_event)).perform(click());\n onView(withText(\"ORANGE\")).perform(click());\n // Wait function\n synchronized (this) {\n Thread.sleep((long) 1000);\n }\n\n\n // Test for event start time\n onView(withId(R.id.start_time_add_event)).perform(click());\n onView(isAssignableFrom(TimePicker.class)).perform(setTime(11, 30));\n // Wait function\n onView(withText(\"OK\")).perform(click());\n synchronized (this) {\n Thread.sleep((long) 1000);\n }\n\n // Test for event end time\n onView(withId(R.id.end_time_add_event)).perform(click());\n onView(isAssignableFrom(TimePicker.class)).perform(setTime(15, 30));\n // Wait function\n onView(withText(\"OK\")).perform(click());\n synchronized (this) {\n Thread.sleep((long) 1000);\n }\n\n // Test for event end date\n onView(withId(R.id.end_date_add_event)).perform(click());\n onView(isAssignableFrom(DatePicker.class)).perform(setDate(2016,03, 20));\n // Wait function\n onView(withText(\"OK\")).perform(click());\n synchronized (this) {\n Thread.sleep((long) 1000);\n }\n\n\n // Test for add event description\n onView(withId(R.id.notes_add_event)).perform(typeText(eventNotes), ViewActions.closeSoftKeyboard());\n // Wait function\n synchronized (this)\n {\n Thread.sleep((long) 1000);\n }\n\n // Test for floating button - finished creating event\n onView(withId(R.id.fab_finished_event)).perform(click());\n synchronized (this) {\n Thread.sleep((long) 10000);\n }\n }",
"public void testPeriodic() {\n\t}",
"@Test\n public void Keypad() {\n Assert.assertEquals(11, Computation.keypadTime(\"91566165\",\"639485712\"));\n Assert.assertEquals(1, Computation.keypadTime(\"5111\",\"752961348\"));\n }",
"@Override\n public void testPeriodic() {\n //Diagnostics.writeString(\"State\", \"TEST\");\n }",
"@Override\n public void testPeriodic() {\n }",
"@Test\n public void testTimerTracking_TempAllowlisting() {\n // None of these should be affected purely by the temp allowlist changing.\n setDischarging();\n setProcessState(ActivityManager.PROCESS_STATE_RECEIVER);\n final long gracePeriodMs = 15 * SECOND_IN_MILLIS;\n setDeviceConfigLong(QcConstants.KEY_EJ_GRACE_PERIOD_TEMP_ALLOWLIST_MS, gracePeriodMs);\n Handler handler = mQuotaController.getHandler();\n spyOn(handler);\n\n JobStatus job1 = createJobStatus(\"testTimerTracking_TempAllowlisting\", 1);\n JobStatus job2 = createJobStatus(\"testTimerTracking_TempAllowlisting\", 2);\n JobStatus job3 = createJobStatus(\"testTimerTracking_TempAllowlisting\", 3);\n JobStatus job4 = createJobStatus(\"testTimerTracking_TempAllowlisting\", 4);\n JobStatus job5 = createJobStatus(\"testTimerTracking_TempAllowlisting\", 5);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(job1, null);\n }\n assertNull(mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n List<TimingSession> expected = new ArrayList<>();\n\n long start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(job1);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(job1, job1, true);\n }\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n assertEquals(expected,\n mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n\n // Job starts after app is added to temp allowlist and stops before removal.\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n mTempAllowlistListener.onAppAdded(mSourceUid);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(job2, null);\n mQuotaController.prepareForExecutionLocked(job2);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(job2, null, false);\n }\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n assertEquals(expected,\n mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n // Job starts after app is added to temp allowlist and stops after removal,\n // before grace period ends.\n mTempAllowlistListener.onAppAdded(mSourceUid);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(job3, null);\n mQuotaController.prepareForExecutionLocked(job3);\n }\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n mTempAllowlistListener.onAppRemoved(mSourceUid);\n long elapsedGracePeriodMs = 2 * SECOND_IN_MILLIS;\n advanceElapsedClock(elapsedGracePeriodMs);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(job3, null, false);\n }\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS + elapsedGracePeriodMs, 1));\n assertEquals(expected,\n mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n elapsedGracePeriodMs += SECOND_IN_MILLIS;\n\n // Job starts during grace period and ends after grace period ends\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(job4, null);\n mQuotaController.prepareForExecutionLocked(job4);\n }\n final long remainingGracePeriod = gracePeriodMs - elapsedGracePeriodMs;\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n advanceElapsedClock(remainingGracePeriod);\n // Wait for handler to update Timer\n // Can't directly evaluate the message because for some reason, the captured message returns\n // the wrong 'what' even though the correct message goes to the handler and the correct\n // path executes.\n verify(handler, timeout(gracePeriodMs + 5 * SECOND_IN_MILLIS)).handleMessage(any());\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n expected.add(createTimingSession(start, remainingGracePeriod + 10 * SECOND_IN_MILLIS, 1));\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(job4, job4, true);\n }\n assertEquals(expected,\n mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n // Job starts and runs completely after temp allowlist grace period.\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(job5, null);\n mQuotaController.prepareForExecutionLocked(job5);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(job5, job5, true);\n }\n expected.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n assertEquals(expected,\n mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n }",
"public void testPeriodic() {\n\n\t}",
"@Test\n public void testEJTimerTracking_Discharging() {\n setDischarging();\n setProcessState(ActivityManager.PROCESS_STATE_BACKUP);\n\n JobStatus jobStatus = createExpeditedJobStatus(\"testEJTimerTracking_Discharging\", 1);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n }\n\n assertNull(mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n List<TimingSession> expected = new ArrayList<>();\n\n long start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(5 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, null, false);\n }\n expected.add(createTimingSession(start, 5 * SECOND_IN_MILLIS, 1));\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n // Test overlapping jobs.\n JobStatus jobStatus2 = createExpeditedJobStatus(\"testEJTimerTracking_Discharging\", 2);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus2, null);\n }\n\n JobStatus jobStatus3 = createExpeditedJobStatus(\"testEJTimerTracking_Discharging\", 3);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus3, null);\n }\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus2);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus3);\n }\n advanceElapsedClock(20 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus3, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus2, null, false);\n }\n expected.add(createTimingSession(start, MINUTE_IN_MILLIS, 3));\n assertEquals(expected,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n }",
"@Test\n public void testRotationLatency() throws Exception {\n if (isTracesEnabled()) {\n createTraceDirectory();\n }\n mDevice.wakeUp();\n for (int i = 0; i < mIterationCount; i++) {\n mDevice.executeShellCommand(String.format(AM_START_COMMAND_TEMPLATE,\n Settings.ACTION_SETTINGS));\n mDevice.waitForIdle();\n if (null != mAtraceLogger) {\n mAtraceLogger.atraceStart(mTraceCategoriesSet, mTraceBufferSize,\n mTraceDumpInterval, mRootTrace,\n String.format(\"%s-%d\", TEST_ROTATION_LATENCY, i));\n }\n\n IWindowManager wm = WindowManagerGlobal.getWindowManagerService();\n wm.freezeRotation(Surface.ROTATION_0);\n mDevice.waitForIdle();\n wm.freezeRotation(Surface.ROTATION_90);\n mDevice.waitForIdle();\n wm.thawRotation();\n mDevice.waitForIdle();\n\n if (null != mAtraceLogger) {\n mAtraceLogger.atraceStop();\n }\n }\n mDevice.pressHome();\n mDevice.waitForIdle();\n }",
"@Test\n public void testTimerTracking_Discharging() {\n setDischarging();\n setProcessState(ActivityManager.PROCESS_STATE_BACKUP);\n\n JobStatus jobStatus = createJobStatus(\"testTimerTracking_Discharging\", 1);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n }\n\n assertNull(mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n List<TimingSession> expected = new ArrayList<>();\n\n long start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(5 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, null, false);\n }\n expected.add(createTimingSession(start, 5 * SECOND_IN_MILLIS, 1));\n assertEquals(expected, mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n // Test overlapping jobs.\n JobStatus jobStatus2 = createJobStatus(\"testTimerTracking_Discharging\", 2);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus2, null);\n }\n\n JobStatus jobStatus3 = createJobStatus(\"testTimerTracking_Discharging\", 3);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus3, null);\n }\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobStatus, null);\n mQuotaController.prepareForExecutionLocked(jobStatus);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus2);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobStatus3);\n }\n advanceElapsedClock(20 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus3, null, false);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobStatus2, null, false);\n }\n expected.add(createTimingSession(start, MINUTE_IN_MILLIS, 3));\n assertEquals(expected, mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n }",
"@Test\n\tpublic void test() throws InterruptedException {\n\t\tString firstTime = Time.main();\n\t\tString[] splitFirst = firstTime.split(\":\");\n\t\tThread.sleep(5000);\n\t\tString secondTime = Time.main();\n\t\tString[] splitSecond = secondTime.split(\":\");\n\t\t\n\t\t\n\t\tif(Integer.parseInt(splitFirst[2])>=55) //if first time was >= 55 seconds\n\t\t{\n\t\t\tassertEquals(Integer.parseInt(splitSecond[2]),(Integer.parseInt(splitFirst[2])+5)%60); //seconds should increase by 5 mod 60\n\n\t\t\tif(Integer.parseInt(splitFirst[1])==59) //if first time was 59 minutes\n\t\t\t{ \n\t\t\t\tassertTrue(splitFirst[1].equals(\"00\")); //reset to zero minutes\n\t\t\t\t\n\t\t\t\tif(Integer.parseInt(splitFirst[0])==23) //if first time was 23 hours\n\t\t\t\t\tassertTrue(splitFirst[0].equals(\"00\")); //reset to zero hours\n\t\t\t\telse //if first time is not 23 hours\n\t\t\t\t\tassertEquals(Integer.parseInt(splitFirst[0])+1, Integer.parseInt(splitSecond[0])); //hours should increase by 1\n\t\t\t}\n\t\t\telse //if first time was not 59 minutes\n\t\t\t{\n\t\t\t\tassertEquals(Integer.parseInt(splitFirst[1])+1, Integer.parseInt(splitSecond[1])); //minutes should increase by 1\n\t\t\t\tassertTrue(splitFirst[0].equals(splitSecond[0])); //hours should not change\n\t\t\t}\n\t\t}\n\t\telse //if first time was <= 55 seconds\n\t\t{\n\t\t\tassertEquals(Integer.parseInt(splitSecond[2]),(Integer.parseInt(splitFirst[2])+5)); //seconds should increase by 5\n\t\t\tassertTrue(splitFirst[1].equals(splitSecond[1])); //minutes should not change\n\t\t\tassertTrue(splitFirst[0].equals(splitSecond[0])); //hours should not change\n\t\t\t\n\t\t}\n\t\t\n\t}",
"public void test() {\n\t\tCount2Suspend c2s = new Count2Suspend();\n\n\t\t// first tick\n\t\tc2s.doTick(c2s.t);\n\t\tassertEquals(c2s.b0.isPresent(), ABSENT);\n\t\tassertEquals(c2s.b1.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c0.isPresent(), ABSENT);\n\t\t// second tick\n\t\tc2s.doTick();\n\t\tassertEquals(c2s.b0.isPresent(), ABSENT);\n\t\tassertEquals(c2s.b1.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c0.isPresent(), ABSENT);\n\t\t// third tick\n\t\tc2s.doTick(c2s.t);\n\t\tassertEquals(c2s.b0.isPresent(), PRESENT);\n\t\tassertEquals(c2s.b1.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c0.isPresent(), ABSENT);\n\t\t// fourth tick\n\t\tc2s.doTick(c2s.t, c2s.inhib);\n\t\tassertEquals(c2s.b0.isPresent(), ABSENT);\n\t\tassertEquals(c2s.b1.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c0.isPresent(), ABSENT);\n\t\t// fifth tick\n\t\tc2s.doTick();\n\t\tassertEquals(c2s.b0.isPresent(), PRESENT);\n\t\tassertEquals(c2s.b1.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c0.isPresent(), ABSENT);\n\t\t// sixth tick\n\t\tc2s.doTick(c2s.t, c2s.reset);\n\t\tassertEquals(c2s.b0.isPresent(), ABSENT);\n\t\tassertEquals(c2s.b1.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c0.isPresent(), ABSENT);\n\t\t// seventh tick\n\t\tc2s.doTick();\n\t\tassertEquals(c2s.b0.isPresent(), ABSENT);\n\t\tassertEquals(c2s.b1.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c0.isPresent(), ABSENT);\n\t\t// eighth tick\n\t\tc2s.doTick(c2s.t);\n\t\tassertEquals(c2s.b0.isPresent(), PRESENT);\n\t\tassertEquals(c2s.b1.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c0.isPresent(), ABSENT);\n\t\t// ninth tick\n\t\tc2s.doTick(c2s.t, c2s.inhib);\n\t\tassertEquals(c2s.b0.isPresent(), ABSENT);\n\t\tassertEquals(c2s.b1.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c0.isPresent(), ABSENT);\n\t\t// tenth tick\n\t\tc2s.doTick(c2s.t);\n\t\tassertEquals(c2s.b0.isPresent(), ABSENT);\n\t\tassertEquals(c2s.b1.isPresent(), PRESENT);\n\t\tassertEquals(c2s.c.isPresent(), ABSENT);\n\t\tassertEquals(c2s.c0.isPresent(), PRESENT);\n\t}",
"private static void timerTest2() {\n\t\tTimer timer = new Timer();\n\t\ttimer.schedule(new TimerTask() {\n\n\t\t\t@Override\n\t\t\tpublic void run() {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tif (count < 5) {\n\t\t\t\t\tSystem.out.println(\"timertest2\" + \" \" + ++count);\n\t\t\t\t} else {\n\t\t\t\t\ttimer.cancel();\n\t\t\t\t}\n\n\t\t\t}\n\t\t}, 2000, 1000);\n\n\t}",
"@Test\n public void testEqual () {\n CountDownTimer s1 = new CountDownTimer(5, 59, 00);\n CountDownTimer s2 = new CountDownTimer(6, 01, 00);\n CountDownTimer s3 = new CountDownTimer(6, 01, 00);\n CountDownTimer s4 = new CountDownTimer(\"5:59:00\");\n\n assertFalse(s1.equals(s2));\n assertTrue(s1.equals(s4));\n assertFalse(CountDownTimer.equals(s1,s3));\n assertTrue(CountDownTimer.equals(s2, s3));\n }",
"public void testPeriodic() {\n \t\n }",
"private void startClock() {\r\n\t\tTimer timer = new Timer(500, new ActionListener() {\t\t\r\n\t\t\t@Override\r\n\t\t\tpublic void actionPerformed(ActionEvent theEvent) {\r\n\t\t\t\tadvanceTime();\t\t\t\r\n\t\t\t}\r\n\t\t});\r\n timer.setRepeats(true);\r\n timer.setCoalesce(true);\r\n timer.setInitialDelay(0);\r\n timer.start();\r\n\t}",
"@Override\n public void run() {\n long startTime = System.nanoTime();\n\n int value = 0;\n int i = 0;\n LibInterfaceOneTest app2class = new LibInterfaceOneTest(\n getApplicationContext());\n System.gc();\n\n for (; i < testCases; i++) {\n value += app2class.testMethodCall2(value);\n }\n\n long finishTime = System.nanoTime();\n\n long totalTime = finishTime - startTime;\n\n long displayTime1 = (totalTime / 1000);\n long displayTime2 = (displayTime1 / 1000);\n long displayTime3 = (displayTime2 / 1000);\n Log.d(\"MAIN ACTIVITY\", \"Total: \" + value + \" total time: \"\n + totalTime + \" display: \" + displayTime1 + \", \"\n + displayTime2 + \", \" + displayTime3);\n longToChange = displayTime1;\n Toast.makeText(\n getApplicationContext(),\n \"Total Time : \" + displayTime1 + \" μs. \" + displayTime2\n + \" ms. \" + displayTime3 + \" ns.\",\n Toast.LENGTH_LONG).show();\n\n }",
"@Override\n\tpublic void testPeriodic() {}",
"@Test\n\tpublic void addButtons__wrappee__ShowTimeTest() throws Exception {\n\t\t\n\t\t\n\t\tif (Configuration.featureamp &&\n\t\t\t\tConfiguration.playengine &&\n\t\t\t\tConfiguration.choosefile &&\n\t\t\t\t!Configuration.mp3 &&\n\t\t\t\t!Configuration.ogg &&\n\t\t\t\tConfiguration.wav &&\n\t\t\t\tConfiguration.gui &&\n\t\t\t\tConfiguration.skins &&\n\t\t\t\tConfiguration.light &&\n\t\t\t\tConfiguration.filesupport &&\n\t\t\t\t!Configuration.showtime) {\t\n\t\t\tstart();\n\t\t\t\n\t\t\tWhitebox.invokeMethod(gui, \"addButtons__wrappee__GUI\");\n\t\t\tassertFalse(gui.showTime);\n\t\t}\n\t}",
"protected void runClock() {\r\n // stop gameClock while game is iconified\r\n if( isRunning && (getState() == Frame.NORMAL) ) {\r\n seconds++;\r\n\r\n int hrs = seconds / 3600;\r\n int mins = seconds / 60 - hrs * 60;\r\n int secs = seconds - mins * 60 - hrs * 3600;\r\n\r\n String strHr = (hrs < 10 ? \"0\" : \"\") + Integer.toString( hrs );\r\n String strMin = (mins < 10 ? \"0\" : \"\") + Integer.toString( mins );\r\n String strSec = (secs < 10 ? \"0\" : \"\") + Integer.toString( secs );\r\n\r\n timeMesg.setText( strHr + \":\" + strMin + \":\" + strSec );\r\n }\r\n }",
"public void clockChange(int time);",
"public void run() {\n\n long now = System.currentTimeMillis();\n //System.out.println(\"1: \" + this.getClass().getName() + \"#\" + id + \", \" + (System.currentTimeMillis()) + \" ms\");\n try {\n\n test.setUp();\n this.testReport = new TestReport(id, this.getClass().getName());\n while (alive.get()) {\n test.test(this.id);\n counter.incrementAndGet();\n }\n //long stop = System.currentTimeMillis();\n //System.out.println(\"2: \" + this.getClass().getName() + \"#\" + id + \", \" + stop + \" \" + (stop - now) + \" ms\");\n } catch (Exception e) {\n e.printStackTrace();\n } finally {\n try {\n test.tearDown();\n this.testReport.stopTimers();\n //testReport.printInfo();\n } catch (Exception e) {\n // ignore errors in tearDown for now\n }\n }\n\n }",
"@Override\n\tpublic void testPeriodic() {\n\t\n\t}",
"@Override\n\tpublic void testPeriodic() {\n\t\t\n\t}",
"@Override\n\tpublic void testPeriodic() {\n\t\t\n\t}",
"public void testPeriodic() {\n \tterrainStates();\n \tdebug();\n }",
"@Test\n public void testEJTimerTrackingSeparateFromRegularTracking() {\n setDischarging();\n setProcessState(ActivityManager.PROCESS_STATE_IMPORTANT_BACKGROUND);\n\n JobStatus jobReg1 = createJobStatus(\"testEJTimerTrackingSeparateFromRegularTracking\", 1);\n JobStatus jobEJ1 =\n createExpeditedJobStatus(\"testEJTimerTrackingSeparateFromRegularTracking\", 2);\n JobStatus jobReg2 = createJobStatus(\"testEJTimerTrackingSeparateFromRegularTracking\", 3);\n JobStatus jobEJ2 =\n createExpeditedJobStatus(\"testEJTimerTrackingSeparateFromRegularTracking\", 4);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStartTrackingJobLocked(jobReg1, null);\n mQuotaController.maybeStartTrackingJobLocked(jobEJ1, null);\n mQuotaController.maybeStartTrackingJobLocked(jobReg2, null);\n mQuotaController.maybeStartTrackingJobLocked(jobEJ2, null);\n }\n assertNull(mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n assertNull(mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n List<TimingSession> expectedRegular = new ArrayList<>();\n List<TimingSession> expectedEJ = new ArrayList<>();\n\n // First, regular job runs by itself.\n long start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobReg1);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobReg1, jobReg1, true);\n }\n expectedRegular.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n assertEquals(expectedRegular,\n mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n assertNull(mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n\n // Next, EJ runs by itself.\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobEJ1);\n }\n advanceElapsedClock(10 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobEJ1, null, false);\n }\n expectedEJ.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n assertEquals(expectedRegular,\n mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n assertEquals(expectedEJ,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n\n advanceElapsedClock(SECOND_IN_MILLIS);\n\n // Finally, a regular job and EJ happen to overlap runs.\n start = JobSchedulerService.sElapsedRealtimeClock.millis();\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobEJ2);\n }\n advanceElapsedClock(5 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.prepareForExecutionLocked(jobReg2);\n }\n advanceElapsedClock(5 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobEJ2, null, false);\n }\n expectedEJ.add(createTimingSession(start, 10 * SECOND_IN_MILLIS, 1));\n advanceElapsedClock(5 * SECOND_IN_MILLIS);\n synchronized (mQuotaController.mLock) {\n mQuotaController.maybeStopTrackingJobLocked(jobReg2, null, false);\n }\n expectedRegular.add(\n createTimingSession(start + 5 * SECOND_IN_MILLIS, 10 * SECOND_IN_MILLIS, 1));\n assertEquals(expectedRegular,\n mQuotaController.getTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n assertEquals(expectedEJ,\n mQuotaController.getEJTimingSessions(SOURCE_USER_ID, SOURCE_PACKAGE));\n }",
"@Override\r\n public void runTests() {\r\n getTemperature();\r\n }",
"public static void main(String[] args) \n { \n Timer timer = new Timer(); \n TimerTask task = new Helper(); \n\n timer.schedule(task, 3000, 5000); \n System.out.println(\"hi\");\n\n }",
"Clock tryGetClock();",
"public static void main(String[] atgs){\n\t\tLOGGER.debug(\"Created by: ALVIN C. ESTANISLAO, a.c.e\");\n\t\tLOGGER.debug(\"=== Start of Test ===\");\n\t\t\n\t\tTestClass test = new TestClass();\n\t\tint intReturnValue = MethodCallTimer.printTime(() -> test.testMethodA());\n\t\t//System.out.println(\"Return Value:\"+ intReturnValue);\n\t\tLOGGER.debug(\"Return Value:\"+ intReturnValue);\n\t\t\n\t\tlong longReturnValue = MethodCallTimer.printTime(() -> test.testMethodB());\n\t\t//System.out.println(\"Return Value:\"+longReturnValue);\n\t\tLOGGER.debug(\"Return Value:\"+longReturnValue);\n\t\t\n\t\t\n\t\t//System.out.println(\"=== End of Test ===\");\n\t\tLOGGER.debug(\"=== End of Test ===\");\n\t}",
"public interface ClockObserver {\n\t\n\t/**\n\t * Each time the global time is updated, this method is called\n\t * @param time\n\t */\n\tpublic void clockChange(int time);\n\t\n\t/**\n\t * Each time the jump time is updated, this method is called\n\t * @param nextJump\n\t */\n\tpublic void nextClockChange(int nextJump);\n\t\n\t/**\n\t * To know if the method is successfully called\n\t * @return true or false\n\t */\n\tpublic boolean isNextClockChangeCalled();\n\t\n\t/**\n\t * To know if the method is successfully called\n\t * @return true or false\n\t */\n\tpublic boolean isClockChangeCalled();\n}",
"public Clock() {\r\n this.hour = 0;\r\n this.minute = 0;\r\n }",
"@Override\n\tpublic void testPeriodic() {\n\t}",
"@Override\n\tpublic void testPeriodic() {\n\t}",
"@Override\n\tpublic void testPeriodic() {\n\n\t}",
"public void testPeriodic() {\n LiveWindow.run();\n }",
"public void testPeriodic() {\n LiveWindow.run();\n }",
"public void testPeriodic() {\n LiveWindow.run();\n }",
"public void testPeriodic() {\n LiveWindow.run();\n }",
"public void testPeriodic() {\n LiveWindow.run();\n }",
"public void testPeriodic() {\n LiveWindow.run();\n }",
"public void testPeriodic() {\n LiveWindow.run();\n }"
]
| [
"0.7145874",
"0.71346295",
"0.66045576",
"0.6604253",
"0.64399886",
"0.63086915",
"0.62234503",
"0.61611813",
"0.6149514",
"0.6148633",
"0.6137434",
"0.6086699",
"0.6085503",
"0.6083359",
"0.5986048",
"0.59798443",
"0.58954835",
"0.5878106",
"0.5868216",
"0.58437246",
"0.583189",
"0.58277404",
"0.57957536",
"0.5790602",
"0.5786757",
"0.57490754",
"0.5748301",
"0.5748301",
"0.5748301",
"0.57454276",
"0.57373244",
"0.57193506",
"0.5700448",
"0.56952965",
"0.56877416",
"0.568009",
"0.5679588",
"0.5678831",
"0.5674545",
"0.56421494",
"0.5641624",
"0.5638577",
"0.5628251",
"0.562625",
"0.562625",
"0.5620547",
"0.5620547",
"0.5620547",
"0.5620547",
"0.5620547",
"0.5620547",
"0.5620547",
"0.5620547",
"0.5620547",
"0.5620547",
"0.5618212",
"0.56153065",
"0.56150436",
"0.5614136",
"0.5606638",
"0.56017846",
"0.5591686",
"0.5571847",
"0.5564101",
"0.556381",
"0.5547464",
"0.55420035",
"0.552297",
"0.5522153",
"0.551436",
"0.5512477",
"0.551117",
"0.5509328",
"0.5504325",
"0.5501237",
"0.5500437",
"0.549666",
"0.5494515",
"0.54918873",
"0.54918396",
"0.5481492",
"0.5481492",
"0.54766893",
"0.54761124",
"0.54757273",
"0.5474227",
"0.5471058",
"0.5470354",
"0.54677874",
"0.5453115",
"0.5451711",
"0.5451711",
"0.54497015",
"0.5449323",
"0.5449323",
"0.5449323",
"0.5449323",
"0.5449323",
"0.5449323",
"0.5449323"
]
| 0.69300973 | 2 |
Calculate the value for the term based on this Predictor. | @Override
public double calcTerm( Map<String, Object> param_map )
{
double result = 0.0;
int cat = (Integer) param_map.get( name );
if( value == cat )
result = coefficient;
LOG.debug( String.format( "calc: %s, %d, %d, %e", name, value, cat, result ) );
return result;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"BigDecimal getTermValue();",
"private double[] computePredictionValues() {\n double[] predResponses = new double[D];\n for (int d = 0; d < D; d++) {\n double expDotProd = Math.exp(docLabelDotProds[d]);\n double docPred = expDotProd / (expDotProd + 1);\n predResponses[d] = docPred;\n }\n return predResponses;\n }",
"public float computeTermScore(int term, int dl, int tf, GlobalStats stats);",
"public double getValue();",
"@Override\n\tpublic int evaluate(){\n\t\treturn term.evaluate() + exp.evaluate();\n\t}",
"double getValue();",
"double getValue();",
"double getValue();",
"private double predict(String tweet) {\n\t\tDocumentCategorizerME myCategorizer = new DocumentCategorizerME(\n\t\t\t\t(DoccatModel) model);\n\t\tdouble[] outcomes = myCategorizer.categorize(tweet);\n\t\treturn Double.parseDouble(myCategorizer.getBestCategory(outcomes));\n\t}",
"float predict();",
"public double getValue() {\n return (numeratorValue * multiplier) / (denominatorValue * divisor);\n }",
"public double getValue() {\n return NUMERATOR / DENOMINATOR;\n }",
"public double getValue(){\n return (double) numerator / (double) denominator;\n }",
"public java.lang.Integer getTerm() {\n return term;\n }",
"@Override\n\tpublic double getValue() {\n\t\treturn value;\n\t}",
"public java.lang.Integer getTerm() {\n return term;\n }",
"public double getValue() {\n return value_;\n }",
"public double getValue() {\n return value_;\n }",
"public double getValue() {\n\t\treturn(value);\n\t}",
"private double getValue() {\n return value;\n }",
"protected float compute(){\n float result = 0f;\n String[] post = in2post(this.arr);\n result = post2ans(post);\n return result;\n }",
"@Override\n public double getValue()\n {\n return value;\n }",
"public abstract double getValue();",
"protected Float additionalTransformation(String term, Float value){\n\t\tif(!ENABLE_ADD_NORMALIZATION) return value;\n\t\t\n\t\tFloat result = value;\n\t\t//result *= this.weightTermUniqeness(term); \n\t\tresult = this.sigmoidSmoothing(result);\n\t\t\n\t\treturn result;\n\t}",
"@Override\n public Double getValue()\n {\n final ApdexSnapshot snapshot = getSnapshot();\n if (snapshot == null || snapshot.getSize() == 0)\n return 0.0D;\n\n final int satisfied = snapshot.getSatisfiedSize();\n final int tolerating = snapshot.getToleratingSize();\n final int total = snapshot.getSize();\n double score = (satisfied + (tolerating / 2.0)) / total;\n\n return score;\n }",
"@VTID(14)\r\n double getValue();",
"Double getValue();",
"public Expression getTerm() {\n return term;\n }",
"public double getValue() {\r\n return this.value;\r\n }",
"public double getValue() {\n return value;\n }",
"public double getValue() {\n return value;\n }",
"public double getValue() {\n return value;\n }",
"public abstract double computeValue(Density density);",
"@Override\r\n public Double evaluate(double number) {\r\n double result = this.reduce(0.0, t -> {\r\n Term term = (Term) t;\r\n return term.evaluate(number);\r\n });\r\n return result;\r\n }",
"public double getValue()\n {\n return this.value;\n }",
"public double getValue(){\n return value;\n }",
"public double getValue() {\n\t\treturn value;\n\t}",
"public double getValue() {\n\t\treturn value;\n\t}",
"public double getValue() {\n\t\treturn value;\n\t}",
"public double getValue() {\r\n\t\treturn value;\r\n\t}",
"public double getValue() {\n return this.value;\n }",
"public double getValue() {\n return this.value;\n }",
"public double getValue() {\n return this._value;\n }",
"double getBasedOnValue();",
"public double value() {\n return ((double) this.numerator / this.denominator);\n }",
"public double getObjective() {\n return multiClassClassifierObj() + binaryObj();\n// +(1-temperature)*getEntropy();\n }",
"int getLikelihoodValue();",
"@Override\n public double getOutput() {\n return this.inputValue;\n }",
"public double getValue() {\n\t\treturn this.value; \n\t}",
"public double getValue() {\n\t\treturn this.value;\n\t}",
"@Override\n public double getResult()\n {\n double result = this.factor1 + this.factor2;\n return result;\n }",
"public void Prediction() {\n System.out.println(\"\\nInput an x value: \");\n double x = inputs.nextDouble();\n double y = this.B0 + (this.B1 * x);\n System.out.println(\"The prediction made with \" + x + \" as the x value is: \" + y);\n System.out.println(\"\\nWhere y = B0 + (B1*xi) is substituted by:\\n y = \" + B0 + \" + (\" + B1 + \" * \" + x + \" )\\n\");\n }",
"public CLPObjective setTerm(double value) {\n\t\t_solver.setObjectiveOffset(value);\n\t\treturn this;\n\t}",
"public double getPredictedDistance() {\r\n return predictedDistance;\r\n }",
"@Override\n protected double elementValueTransformer(Word w, Double actualValue) {\n \n // computing words log frequencies * idf(word) : \n // log-freq(word) = { 0 when count(word)=0\n // 1+log(count(word)) when count(word)>0 }\n \n //return (actualValue==0.0 ? (0.0) : (1.0 + Math.log(actualValue)) ) \n // * idfProvider.getInverseDocumentFrequency(w);\n\n double tf = actualValue/(actualValue + 0.5 + 1.5*this.getOriginalSumOfValues()/idfProvider.getAverageDocumentLength());\n double idf = idfProvider.getInverseDocumentFrequency(w);\n \n double val = tf*idf;\n \n return val;\n \n }",
"public double getValue()\n\t{\n\t\treturn ifD1.getValue();// X100 lux\n\t}",
"float getValue();",
"float getValue();",
"float getValue();",
"public double getObjectiveValue() {\r\n return ObjectiveFunctionWrapper.this.m_use ? this.m_state\r\n .getObjectiveValue() : ObjectiveFunctionWrapper.this.m_default;\r\n }",
"double predict(Vector w);",
"public float evaluate(PhraseInfo p) {\n int numChords = p.gen.prog.get(p.gen.progIndex).size();\n int tn = Math.min(phraseLen, (int)Math.round(targetNotes * ((numChords + 1) / 3.0))); // not directly proportional.\n // scores: 50, 49, 46, 41, 34, 25 etc.\n int score = Math.max(0, 50 - (int)Math.round(Math.pow(Math.abs(p.noteCount - tn), 2)));\n return (float)Math.min(1.0f, score/50.0f);\n }",
"public double getValue() {\n\t\t// TODO Auto-generated method stub\n\t\treturn 1.00;\n\t}",
"double getPValue();",
"public double obtValor() {\r\n\t\treturn v;\r\n\t}",
"float getEvaluationResult();",
"public abstract double getPreis();",
"public double calculateValue () {\n return double1 * double2;\n }",
"@Override\n protected double getTFDocument(BasicStats stats, float termFreq, float docLength) {\n return ((k1 + 1) * termFreq / (k1 * (1 - b +\n b * docLength / stats.getAvgFieldLength()) + termFreq));\n }",
"public double calculate()\n {\n return ((this.getProduction() * this.getNumberOfStillages() + this.getLastCount() - this.getPrevCount()) * this.getProfileLength());\n }",
"public double get(RatingMatrixEntry pref) {\n return estimates[pref.getIndex()];\n }",
"public abstract double compute(double value);",
"public double getValue()\r\n\t{\r\n\t\treturn (double) value;\r\n\t}",
"public interface Term {\n\t\n\t/**\n\t * Get the coefficient of a term\n\t * @return the coefficient \n\t */\n\tpublic double getCoefficient();\n\t\n\t/**\n\t * Get the exponent of a term\n\t * @return the exponent\n\t */\n\tpublic int getExponent();\n\t\n\t/**\n\t * Evaluate a term by a given value. c = constant, a(c)^n \n\t * @param x The value to be evaluated \n\t * @return The result of the evaluated term \n\t */\n\tpublic double evaluate(double x);\n\t\n}",
"public double value() {\r\n return value;\r\n }",
"public Double getValue() {\n return value;\n }",
"public Double getValue() {\n return value;\n }",
"public abstract double evaluate(double value);",
"public double getTotalValue(){\r\n return this.quantity * this.price;\r\n }",
"public double calculateValue() {\n if (!isLeaf && Double.isNaN(value)) {\n for (List<LatticeNode> list : children) {\n double tempVal = 0;\n for (LatticeNode node : list) {\n tempVal += ((CALatticeNode) node).calculateValue();\n }\n if (!list.isEmpty())\n value = tempVal;\n }\n }\n weight = Math.abs(value);\n return value;\n }",
"@Override\n public double makePrediction(ParsedText text) {\n double pr = 0.0;\n\n /* FILL IN HERE */\n double productSpam = 0;\n double productNoSpam = 0;\n \n int i, tempSpam,tempNoSpam;\n int minSpam, minNoSpam ;\n \n \n for (String ng: text.ngrams) {\n \tminSpam = Integer.MAX_VALUE;\n \tminNoSpam = Integer.MAX_VALUE;\n \n\n \tfor (int h = 0;h < nbOfHashes; h++) {\n \t\ti = hash(ng,h);\n\n \t\ttempSpam = counts[1][h][i];\n \t\ttempNoSpam = counts[0][h][i];\n \t\t\n \t\t//System.out.print(tempSpam + \" \");\n\n \t\tminSpam = minSpam<tempSpam?minSpam:tempSpam; \n \t\tminNoSpam = minNoSpam<tempNoSpam?minNoSpam:tempNoSpam; \n \t\t\n \t}\n\n \t//System.out.println(minSpam + \"\\n\");\n \tproductSpam += Math.log(minSpam);\n \tproductNoSpam += Math.log(minNoSpam);\n }\n \n // size of set minus 1\n int lm1 = text.ngrams.size() - 1;\n \n //System.out.println((productNoSpam - productSpam ));\n //System.out.println((lm1*Math.log(this.classCounts[1]) - lm1*Math.log(this.classCounts[0])));\n\n //\n pr = 1 + Math.exp(productNoSpam - productSpam + lm1*(Math.log(classCounts[1]) - Math.log(classCounts[0])));\n // System.out.print(1.0/pr + \"\\n\");\n \n return 1.0 / pr;\n\n }",
"public double value(){\n\t return (double) this.f;\n }",
"@Override\n public double calculate(double input)\n {\n return input/getValue();\n }",
"private double predictFromTraining(Instances training) {\n\t\tdouble predictedValue = -1;\n\t\ttry{\n\t\t\t// new forecaster\n\t WekaForecaster forecaster = new WekaForecaster();\n\n\t // Set the targets we want to forecast\n\t forecaster.setFieldsToForecast(\"count\");\n\t \n\t // Default underlying classifier is SMOreg (SVM) - we'll use\n\t // gaussian processes for regression instead\n\t forecaster.setBaseForecaster(new GaussianProcesses());\n\t forecaster.getTSLagMaker().setTimeStampField(\"date\"); // date time stamp\n\t \n\t //System.out.println(dateFormat.format(new Date()) + \" buildForecaster\");\n\t \n\t // build the model\n\t forecaster.buildForecaster(training, System.out);\n\n\t //System.out.println(dateFormat.format(new Date()) + \" primeForecaster\");\n\t \n\t forecaster.primeForecaster(training);\n\t \n\t //System.out.println(dateFormat.format(new Date()) + \" forecaster.forecast\");\n\t \n\t // forecast for 1 unit beyond the end of the\n\t // training data\n\t List<List<NumericPrediction>> forecast = forecaster.forecast(1, System.out);\n\t \n\t //System.out.println(dateFormat.format(new Date()) + \" forecast.get\");\n\t \n\t // Getting the prediction:\n\t List<NumericPrediction> predsAtStep = forecast.get(0);\n\t NumericPrediction predForTarget = predsAtStep.get(0);\n \t//System.out.print(\"\" + predForTarget.predicted() + \" \");\n \tpredictedValue = predForTarget.predicted();\n\t\t}catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t\treturn predictedValue;\n\t}",
"double getValue() {\n return mValue;\n }",
"public abstract double calcular();",
"public double getResult()\n { \n return answer;\n }",
"public double getValue() {\n return this.num;\n }",
"public String getTerm() {\n return term;\n }",
"public double predict(final Calendar when) {\n final int index = this.instantGenerator.generate(when);\n final double val = this.predictor.predict(when);\n this.predictedIntraday[index] = val;\n return val;\n }",
"abstract double calculateCurrentDiscountRate();",
"public Prediction apply( double[] confidence );",
"@Override\n\tpublic double predict(SparseVector instance) {\n\t\treturn predict(instance, this.weights);\n\t}",
"public abstract double score(double tf, double docLength, double precomp);",
"java.lang.String getPredicted();",
"public House getPredicted() {\r\n return this.predicted;\r\n }",
"@Override\n\tpublic double evaluate() {\n\t\t// TODO Auto-generated method stub\n\t\treturn 0;\n\t}",
"public void prediction() {\n\t\txPriorEstimate = xPreviousEstimate;\n\t\tpPriorCovarianceError = pPreviousCovarianceError;\n\t}",
"public float getValue()\n\t{\n\t\treturn this.value;\n\t}",
"public abstract Object getDecisionValue();"
]
| [
"0.64094025",
"0.63533777",
"0.6068491",
"0.60643333",
"0.60501415",
"0.60131603",
"0.60131603",
"0.60131603",
"0.59835905",
"0.5952836",
"0.595261",
"0.5913688",
"0.58919",
"0.5846074",
"0.58399904",
"0.5820787",
"0.5811579",
"0.5782414",
"0.5780666",
"0.5767432",
"0.57449925",
"0.57322794",
"0.5716313",
"0.571363",
"0.57057846",
"0.5705687",
"0.5700167",
"0.568923",
"0.56870663",
"0.568644",
"0.568644",
"0.568644",
"0.56859046",
"0.56853837",
"0.56840074",
"0.5666676",
"0.56564564",
"0.56564564",
"0.56564564",
"0.5651637",
"0.5648256",
"0.5648256",
"0.56447715",
"0.5640462",
"0.56398344",
"0.5634527",
"0.56206685",
"0.5620404",
"0.56056917",
"0.55953187",
"0.55814165",
"0.55802834",
"0.5572892",
"0.5543107",
"0.5536721",
"0.5533696",
"0.55302596",
"0.55302596",
"0.55302596",
"0.55232036",
"0.55192673",
"0.54846793",
"0.54831487",
"0.5481529",
"0.5470578",
"0.5467576",
"0.54652876",
"0.5449937",
"0.54491514",
"0.5441713",
"0.5432884",
"0.542769",
"0.54174477",
"0.54141915",
"0.54057217",
"0.53871983",
"0.53871983",
"0.5379632",
"0.5368394",
"0.5346231",
"0.534038",
"0.5340055",
"0.534004",
"0.53345513",
"0.5333874",
"0.5328656",
"0.5327983",
"0.5325316",
"0.53146887",
"0.5297256",
"0.529517",
"0.52836144",
"0.52821076",
"0.5279588",
"0.5271943",
"0.52697456",
"0.52681625",
"0.5265205",
"0.5260652",
"0.5260311"
]
| 0.5919489 | 11 |
View Source ServiceBuilder generated this class. Modifications in this class will be overwritten the next time is generated. This interface is a model that represents the PmlFileReturningInfo table in the database. | public interface PmlFileReturningInfoModel extends BaseModel<PmlFileReturningInfo> {
public long getPrimaryKey();
public void setPrimaryKey(long pk);
public long getFileReturningInfoId();
public void setFileReturningInfoId(long fileReturningInfoId);
public String getFileId();
public void setFileId(String fileId);
public String getFileSender();
public void setFileSender(String fileSender);
public String getLicenseNumber();
public void setLicenseNumber(String licenseNumber);
public Date getIssuingDateLicense();
public void setIssuingDateLicense(Date issuingDateLicense);
public Date getReceiveLicenseDate();
public void setReceiveLicenseDate(Date receiveLicenseDate);
public String getDocumentNumber();
public void setDocumentNumber(String documentNumber);
public String getBillNumber();
public void setBillNumber(String billNumber);
public long getNumberMoney();
public void setNumberMoney(long numberMoney);
public String getNote();
public void setNote(String note);
public String getConclude();
public void setConclude(String conclude);
public PmlFileReturningInfo toEscapedModel();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public interface IMxlFile {\n String getBaseName();\n\n List<MxlAnnotation> getAnnotations();\n\n MxlText getText();\n\n String getRawData();\n}",
"public IFile getModelFile() {\r\n \t\treturn newFileCreationPage.getModelFile();\r\n \t}",
"public com.opentext.bn.converters.avro.entity.PayloadRef getFileInfo() {\n return fileInfo;\n }",
"public com.opentext.bn.converters.avro.entity.PayloadRef getFileInfo() {\n return fileInfo;\n }",
"public FileInfo getFileInfo() {\n return fileInfo;\n }",
"public interface Parser {\r\n\r\n /**\r\n * Parse and return List of EXIFContent.\r\n * @return\r\n */\r\n public abstract List<EXIFContent> parse();\r\n\r\n}",
"public interface PCSMetadata {\n\n /* Met Fields */\n String APPLICATION_SUCCESS_FLAG = \"ApplicationSuccessFlag\";\n\n String ON_DISK = \"OnDisk\";\n\n String TAPE_LOCATION = \"TapeLocation\";\n\n String PRODUCTION_LOCATION = \"ProductionLocation\";\n\n String PRODUCTION_LOCATION_CODE = \"ProductionLocationCode\";\n\n String DATA_VERSION = \"DataVersion\";\n\n String DATA_PROVIDER = \"DataProvider\";\n\n String COLLECTION_LABEL = \"CollectionLabel\";\n\n String COMMENTS = \"Comments\";\n\n String EXECUTABLE_PATHNAMES = \"ExecutablePathnames\";\n\n String EXECUTABLE_VERSIONS = \"ExecutableVersions\";\n\n String PROCESSING_LEVEL = \"ProcessingLevel\";\n\n String JOB_ID = \"JobId\";\n\n String TASK_ID = \"TaskId\";\n\n String PRODUCTION_DATE_TIME = \"ProductionDateTime\";\n\n String INPUT_FILES = \"InputFiles\";\n\n String PGE_NAME = \"PGEName\";\n\n String OUTPUT_FILES = \"OutputFiles\";\n \n String TEST_TAG = \"TestTag\";\n\n String SUB_TEST_TAG = \"SubTestTag\";\n\n String TEST_LOCATION = \"TestLocation\";\n\n String TEST_COUNTER = \"TestCounter\";\n\n String TEST_DATE = \"TestDate\";\n \n String START_DATE_TIME = \"StartDateTime\";\n\n String END_DATE_TIME = \"EndDateTime\";\n\n}",
"public interface ICustomerStatementInterface {\n\n public List<CustomerStatementModel> process(MultipartFile file) ;\n}",
"public interface SpectralFile_ScansLvlGt1Partial_FileContents_Root_IF {\n\n}",
"@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder() {\n return getFileInfo();\n }",
"@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder() {\n return getFileInfo();\n }",
"public interface IImageMetadata {\n\n public String getImageType();\n\n public void setImageType(String imageType);\n\n public String getFilename();\n\n public void setFilename(String filename);\n\n public DateTime getLastModified();\n\n public void setLastModified(DateTime d);\n\n public DateTime getCreated();\n\n public void setCreated(DateTime d);\n\n public long getSize();\n\n public void setSize(long size);\n\n public String getReadableSize();\n\n}",
"public be.e1.bssv.util.J569806.FtpListing.ProcessFileListing getProcessFileListing_Pt() \n throws javax.xml.rpc.ServiceException\n {\n\n if (mvar_ProcessFileListing_Pt == null) {\n mvar_ProcessFileListing_Pt =\n new be.e1.bssv.util.J569806.FtpListing.ProcessFileListing_Stub(_getPort(\"processFileListing_pt\"), this);\n }\n\n if (transportInfo != null && \n transportInfo instanceof weblogic.wsee.connection.transport.http.HttpTransportInfo) {\n ((javax.xml.rpc.Stub)mvar_ProcessFileListing_Pt)._setProperty(\n \"weblogic.wsee.connection.transportinfo\", \n (weblogic.wsee.connection.transport.http.HttpTransportInfo)transportInfo);\n }\n \n return mvar_ProcessFileListing_Pt;\n }",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadata getMetadata();",
"@NotNull\n @ApiModelProperty(example = \"y1234456789b\", required = true, value = \"The info file is an python file containing the package metadata.\")\n public String getInfoFile() {\n return infoFile;\n }",
"public interface FileContract {\n\n interface FileView extends BaseView {\n\n void uploadFilesDone(List<FileBean> data);\n\n void downloadFileDone(File file);\n\n void onProgress(int requestCode, int progress);\n }\n\n interface FileModel extends BaseModel {\n\n Call<BaseResp<List<FileBean>>> uploadFiles(ProgressRequestBody requestBody);\n\n Call<ResponseBody> downLoadFile(Long fileId, String filePath);\n\n }\n}",
"public IFile getIFile ();",
"public interface PIMItem {\n\n public static final int ATTR_NONE = 0;\n public static final int BINARY = 0;\n public static final int BOOLEAN = 1;\n public static final int DATE = 2;\n public static final int EXTENDED_ATTRIBUTE_MIN_VALUE = 0x1000000;\n public static final int EXTENDED_FIELD_MIN_VALUE = 0x1000000;\n public static final int INT = 3;\n public static final int STRING = 4;\n public static final int STRING_ARRAY = 5;\n\n public abstract PIMList getPIMList();\n\n public abstract void commit() throws PIMException;\n\n public abstract boolean isModified();\n\n public abstract int[] getFields();\n\n public abstract byte[] getBinary(int i, int j);\n\n public abstract void addBinary(int i, int j, byte abyte0[], int k, int l);\n\n public abstract void setBinary(int i, int j, int k, byte abyte0[], int l, int i1);\n\n public abstract long getDate(int i, int j);\n\n public abstract void addDate(int i, int j, long l);\n\n public abstract void setDate(int i, int j, int k, long l);\n\n public abstract int getInt(int i, int j);\n\n public abstract void addInt(int i, int j, int k);\n\n public abstract void setInt(int i, int j, int k, int l);\n\n public abstract String getString(int i, int j);\n\n public abstract void addString(int i, int j, String s);\n\n public abstract void setString(int i, int j, int k, String s);\n\n public abstract boolean getBoolean(int i, int j);\n\n public abstract void addBoolean(int i, int j, boolean flag);\n\n public abstract void setBoolean(int i, int j, int k, boolean flag);\n\n public abstract String[] getStringArray(int i, int j);\n\n public abstract void addStringArray(int i, int j, String as[]);\n\n public abstract void setStringArray(int i, int j, int k, String as[]);\n\n public abstract int countValues(int i);\n\n public abstract void removeValue(int i, int j);\n\n public abstract int getAttributes(int i, int j);\n\n public abstract void addToCategory(String s) throws PIMException;\n\n public abstract void removeFromCategory(String s);\n\n public abstract String[] getCategories();\n\n public abstract int maxCategories();\n}",
"public interface ProductProcessorMP0 extends ProductProcessor {\n\n\n\n\n void processFile(MultipartFile file, ContractImage contractImage, Contract contract) throws IOException, IllegalDataException;\n}",
"public interface FileType {\n\tString name();\n}",
"public interface IFileDataTypeReader {\n\t\n\t Map<String, String> getColumnAndDataType(String fileName, ExtendedDetails dbDetails) throws ZeasException;\n\t\n\t List<List<String>> getColumnValues() throws ZeasException;\n}",
"edu.usfca.cs.dfs.StorageMessages.RetrieveFileOrBuilder getRetrieveFileOrBuilder();",
"public interface OUTPUT_RESULTSDao {\n List<OUTPUT_RESULTS> getAllOutputReults();\n}",
"public interface Metadata<I extends MetadataInfo> {\n\n /** Metadata types */\n public enum MetadataType {\n /* New types must be added to the end of this list */\n TOPOLOGY() {\n @Override\n public String getKey() { return \"Topology\";}\n },\n TABLE() {\n @Override\n public String getKey() { return \"Table\";}\n },\n SECURITY() {\n @Override\n public String getKey() { return \"Security\";}\n };\n\n /**\n * Gets a unique string for this type. This string may be used as a\n * key into a metadata store.\n *\n * @return a unique string\n */\n abstract public String getKey();\n }\n\n /* The sequence number of an newly created metadata, empty object */\n public static final int EMPTY_SEQUENCE_NUMBER = 0;\n\n /**\n * Gets the type of this metadata object.\n *\n * @return the type of this metadata object\n */\n public MetadataType getType();\n\n /**\n * Gets the highest sequence number of this metadata object.\n * Returns -1 if the metadata has not been initialized.\n *\n * @return the highest sequence number of this metadata object\n */\n public int getSequenceNumber();\n\n /**\n * Gets an information object for this metadata. The returned object will\n * include the changes between this object and the metadata at the\n * specified sequence number. If the metadata object can not supply\n * information based on the sequence number an empty metadata information\n * object is returned.\n *\n * @param startSeqNum the inclusive start of the sequence of\n * changes to be included\n * @return a metadata info object\n */\n public I getChangeInfo(int startSeqNum);\n}",
"public interface FileInterface {\n\t/**\n\t * Operation that allows to read an input file to a data structure.\n\t */\n\tpublic void readFile();\n\t/**\n\t * Operation that allows to read an input file and select a specific fraction into a string array.\n\t * @return Array of strings containing a specific fraction of the file.\n\t */\n\tpublic String[] readClasses();\n}",
"public interface PupilInfoView extends MvpView<PupilInfoPresenter> {\n\n void onPupilLoaded(DbPupil dbPupil);\n}",
"@java.lang.Override\n public java.lang.String getFilePath() {\n return instance.getFilePath();\n }",
"@Override\n public String toString() {\n return \"INIPreferences{\" +\n \"fileName=\" + fileName +\n \", map=\" + map +\n \", isDirty=\" + isDirty +\n '}';\n }",
"public String getMappingFilePath();",
"public interface FileDescriptor {\n\t/**\n\t * The mapping file name. This is its name within the archive, the\n\t * expectation being that most times this will equate to a \"classpath\n\t * lookup resource name\".\n\t *\n\t * @return The mapping file resource name.\n\t */\n\tpublic String getName();\n\n\t/**\n\t * Retrieves access to the InputStream for the mapping file.\n\t *\n\t * @return Access to the InputStream for the mapping file.\n\t */\n\tpublic InputStream getStream();\n}",
"public interface ZIPContent {\n\n /**\n * Set entry name for zip file.\n *\n * @param ename Entry name\n */\n public void setEntryName(String ename);\n\n /**\n * If model implement this method, return entry name in .epub file\n *\n * @return String entryname or null\n */\n public String getEntryName();\n}",
"public interface TaskItem {\n \n public List<File> getAllFiles();\n \n public void addFiles(List<File> files) throws Exception;\n \n public File getFile(int index);\n \n public ItemType getType();\n \n public Integer getNumber();\n \n public String getDescription();\n}",
"public UploadedFileDTO getFile() {\r\n\t\ttype(ConfigurationItemType.FILE);\r\n\t\treturn fileValue;\r\n\t}",
"public interface WorkfileInfoInterface {\n\n /**\n * Get the short workfile name (the final segment of the full workfile name).\n *\n * @return the short workfile name.\n */\n String getShortWorkfileName();\n\n /**\n * Get the full workfile name.\n *\n * @return the full workfile name.\n */\n String getFullWorkfileName();\n\n /**\n * Get the size of the workfile.\n * @return the size of the workfile.\n */\n long getWorkfileSize();\n\n /**\n * Get the last change date for the workfile.\n * @return the last time the workfile changed.\n */\n Date getWorkfileLastChangedDate();\n\n /**\n * Get the File object associated with the workfile.\n * @return the File object associated with the workfile.\n */\n File getWorkfile();\n\n /**\n * Get the project name.\n * @return the project name.\n */\n String getProjectName();\n\n /**\n * Get the branch name.\n * @return the branch name.\n */\n String getBranchName();\n\n /**\n * Does the workfile exist.\n *\n * @return true if the workfile exists; false otherwise.\n */\n boolean getWorkfileExists();\n\n /**\n * Get the time (in seconds past the epoch) when the workfile was fetched. This represents the last 'get' or 'checkout'\n * operation for the given workfile.\n * @return a long representation of the last fetch date.\n */\n long getFetchedDate();\n\n /**\n * Set the fetched date.\n * @param time the time (in seconds past the epoch) when the workfile was last fetched.\n */\n void setFetchedDate(long time);\n\n /**\n * Get the revision string associated with the workfile.\n * @return the revision string associated with the workfile.\n */\n String getWorkfileRevisionString();\n\n /**\n * Set the revision string associated with the workfile.\n * @param revisionString the revision string to associate with this workfile.\n */\n void setWorkfileRevisionString(String revisionString);\n\n /**\n * Set the archive info to associate with this workfile.\n * @param archInfo the archive information to associate with this workfile.\n */\n void setArchiveInfo(ArchiveInfoInterface archInfo);\n\n /**\n * Get the archive info associated with this workfile.\n * @return the archive info associated with this workfile.\n */\n ArchiveInfoInterface getArchiveInfo();\n\n /**\n * Return true if this is a binary file.\n *\n * @return true if this is a binary file; false otherwise.\n */\n boolean getBinaryFileAttribute();\n\n /**\n * Set the binary flag attribute for this workfile info.\n * @param flag the binary flag attribute for this workfile info.\n */\n void setBinaryFileAttribute(boolean flag);\n}",
"public interface ISVNAnnotations {\n\n\t/**\n\t * Get the date of the last change for the given <code>lineNumber</code>\n\t * \n\t * @param lineNumber\n\t * @return date of last change\n\t */\n\tpublic abstract Date getChanged(int lineNumber);\n\n\t/**\n\t * Get the revision of the last change for the given <code>lineNumber</code>\n\t * \n\t * @param lineNumber\n\t * @return the revision of last change\n\t */\n\tpublic abstract long getRevision(int lineNumber);\n\n\t/**\n\t * Get the author of the last change for the given <code>lineNumber</code>\n\t * \n\t * @param lineNumber\n\t * @return the author of last change or null\n\t */\n\tpublic abstract String getAuthor(int lineNumber);\n\n\t/**\n\t * Get the content (line itself) of the given <code>lineNumber</code>\n\t * \n\t * @param lineNumber\n\t * @return the line content\n\t */\n\tpublic abstract String getLine(int lineNumber);\n\n\t/**\n\t * Get an input stream providing the content of the file being annotated.\n\t * \n\t * @return an inputstream of the content of the file\n\t */\n\tpublic abstract InputStream getInputStream();\n\n\t/**\n\t * Get the number of annotated lines\n\t * \n\t * @return number of lines of file being annotated\n\t */\n\tpublic abstract int numberOfLines();\n}",
"@XmlElement\n public int getFileTypeId() {\n return this.fileTypeId;\n }",
"public interface FileSource {\n\n String getCondition(int code, String lang);\n\n}",
"public interface FileWritable {\n\n /**\n * The required path and fileName where the report should be saved\n * @return the required FileName\n */\n String getFileName();\n\n /**\n * The required content to be shown on the report\n * @return content to be included\n */\n String getContent();\n}",
"public ProcessingResult getResult() {\n return new ProcessingResultImpl(documentationMap, configFilesList);\n }",
"public interface FileService extends PublicService {\n\n /**\n * Retrieves reference to a file by fileName\n */\n FileReference getFile(String fileName);\n \n /**\n * Creates a reference for a new file.\n * Use FileReference.getOutputStream() to set content for the file.\n * Requires user to be a member of a contributer or full roles.\n * @param fileName\n * @param toolId - optional parameter\n * @return\n */\n FileReference createFile(String fileName, String toolId);\n \n /**\n * Deletes the file.\n * Requires user to be a member of a contributer or full roles.\n * @param fileReferece\n */\n void deleteFile(FileReference fileReferece);\n \n /**\n * Returns a url to the file\n * Property WebSecurityUtil.DBMASTER_URL (dbmaster.url) is used as a prefix\n */\n URL toURL(FileReference fileReferece);\n}",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder();",
"public ReturnInfo()\r\n\t{\r\n\t\tsuper();\r\n\t}",
"File getFilePath()\r\n\t{\r\n\t\treturn fFilePath;\r\n\t}",
"@java.lang.Override\n public java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList() {\n return fileInfo_;\n }",
"public interface FileConstract {\n interface FileView extends BaseView<FilePresenter> {\n void refreshUI(List<FileBean> data);\n void showToast(String msg);\n }\n\n interface FilePresenter extends BasePresenter {\n void initData();\n\n void uploadFile(String path);\n }\n\n}",
"public Properties getImageMetaData() {\n\t\treturn null;\n\t}",
"@WebService(name = \"FileService\", targetNamespace = \"http://soap.web.lab/\")\n@XmlSeeAlso({\n ObjectFactory.class\n})\npublic interface FileService extends lab.web.FileService {\n\n\n /**\n * \n * @param arg0\n * @return\n * returns boolean\n * @throws ServiceException\n */\n @WebMethod\n @WebResult(targetNamespace = \"\")\n @RequestWrapper(localName = \"writeFile\", targetNamespace = \"http://soap.web.lab/\", className = \"WriteFile\")\n @ResponseWrapper(localName = \"writeFileResponse\", targetNamespace = \"http://soap.web.lab/\", className = \"WriteFileResponse\")\n public boolean writeFile(\n @WebParam(name = \"arg0\", targetNamespace = \"\")\n String arg0)\n throws ServiceException\n ;\n\n /**\n * \n * @return\n * returns java.util.List<java.lang.String>\n */\n @WebMethod\n @WebResult(targetNamespace = \"\")\n @RequestWrapper(localName = \"getListAllFiles\", targetNamespace = \"http://soap.web.lab/\", className = \"GetListAllFiles\")\n @ResponseWrapper(localName = \"getListAllFilesResponse\", targetNamespace = \"http://soap.web.lab/\", className = \"GetListAllFilesResponse\")\n public List<String> getListAllFiles();\n\n /**\n * \n * @param arg0\n * @return\n * returns boolean\n * @throws ServiceException\n */\n @WebMethod\n @WebResult(targetNamespace = \"\")\n @RequestWrapper(localName = \"deleteFile\", targetNamespace = \"http://soap.web.lab/\", className = \"DeleteFile\")\n @ResponseWrapper(localName = \"deleteFileResponse\", targetNamespace = \"http://soap.web.lab/\", className = \"DeleteFileResponse\")\n public boolean deleteFile(\n @WebParam(name = \"arg0\", targetNamespace = \"\")\n String arg0)\n throws ServiceException\n ;\n\n /**\n * \n * @param arg1\n * @param arg0\n * @return\n * returns boolean\n * @throws ServiceException\n */\n @WebMethod\n @WebResult(targetNamespace = \"\")\n @RequestWrapper(localName = \"downloadFile\", targetNamespace = \"http://soap.web.lab/\", className = \"DownloadFile\")\n @ResponseWrapper(localName = \"downloadFileResponse\", targetNamespace = \"http://soap.web.lab/\", className = \"DownloadFileResponse\")\n public boolean downloadFile(\n @WebParam(name = \"arg0\", targetNamespace = \"\")\n String arg0,\n @WebParam(name = \"arg1\", targetNamespace = \"\")\n String arg1)\n throws ServiceException\n ;\n\n}",
"@Local\r\npublic interface GenerarDocTodoRiesgoMontaje {\r\n\r\n\t/**\r\n\t * \r\n\t * <b> Permite Generar el XML Todo Riesgo Montaje </b>\r\n\t * <p>\r\n\t * [Author: Franklin Pozo B, Date: 02/06/2015]\r\n\t * </p>\r\n\t * \r\n\t * @param ramoRiesgoMontaje\r\n\t * @return\r\n\t * @throws HiperionException\r\n\t */\r\n\r\n\tString generarXmlTodoRiesgoMontaje(RamoRiesgoMontaje ramoRiesgoMontaje) throws HiperionException;\r\n\r\n}",
"@java.lang.Override\n public java.util.List<entities.Torrent.FileInfo> getFileInfoList() {\n return fileInfo_;\n }",
"@Override\n\tpublic String fileInfo(int product_id) {\n\t\treturn null;\n\t}",
"public com.opentext.bn.converters.avro.entity.PayloadRef.Builder getFileInfoBuilder() {\n if (fileInfoBuilder == null) {\n if (hasFileInfo()) {\n setFileInfoBuilder(com.opentext.bn.converters.avro.entity.PayloadRef.newBuilder(fileInfo));\n } else {\n setFileInfoBuilder(com.opentext.bn.converters.avro.entity.PayloadRef.newBuilder());\n }\n }\n return fileInfoBuilder;\n }",
"@Transient\n\tpublic File getFileObj() {\n\t\treturn fileObj;\n\t}",
"public MetaData getMetaData();",
"public Long getFileID()\n/* */ {\n/* 88 */ return this.fileID;\n/* */ }",
"public Long getInfile_()\n{\nreturn getInputDataItemId(\"infile_\");\n}",
"@Override\n\tpublic String getFileProperties() {\n\t\treturn null;\n\t}",
"@Generated(hash = 1451855236)\n public FileItemInfo getFileItemInfo() {\n long __key = this.fileId;\n if (fileItemInfo__resolvedKey == null || !fileItemInfo__resolvedKey.equals(__key)) {\n final DaoSession daoSession = this.daoSession;\n if (daoSession == null) {\n throw new DaoException(\"Entity is detached from DAO context\");\n }\n FileItemInfoDao targetDao = daoSession.getFileItemInfoDao();\n FileItemInfo fileItemInfoNew = targetDao.load(__key);\n synchronized (this) {\n fileItemInfo = fileItemInfoNew;\n fileItemInfo__resolvedKey = __key;\n }\n }\n return fileItemInfo;\n }",
"@Override\r\n\tpublic Map<String, Object> getMetadata() {\n\t\treturn null;\r\n\t}",
"public interface WorkflowService {\n void parseWf(File ff) throws Exception;\n}",
"public final FileInfoBase getFileInfo() {\r\n return fileInfo;\r\n }",
"public File getResultFile() {\r\n\t\treturn resultFile;\r\n\t}",
"stockFilePT102.StockFileDocument.StockFile getStockFile();",
"public String getMetaDataFileName() {\n return null;\n }",
"@Override\n public int getFile() {\n return file;\n }",
"Metadata getMetaData();",
"public edu.ustb.sei.mde.morel.resource.morel.IMorelMetaInformation getMetaInformation();",
"interface EntityUpdateResponse extends EntityUpdateRequest {\n\n /**\n * Returns true if this PI entity was written successfully, false\n * otherwise.\n *\n * @return true if this PI entity was written successfully, false\n * otherwise\n */\n boolean isSuccess();\n\n /**\n * Returns the status for this PI entity. If {@link #isSuccess()}\n * returns {@code true}, then this method is expected to return {@link\n * EntityUpdateStatus#OK}. If {@link EntityUpdateStatus#OTHER_ERROR} is\n * returned, further details might be provided in {@link #explanation()}\n * and {@link #throwable()}.\n *\n * @return status\n */\n EntityUpdateStatus status();\n\n /**\n * If the PI entity was NOT written successfully, this method returns a\n * message explaining the error occurred. Returns an empty string if\n * such message is not available, or {@code null} if no errors\n * occurred.\n *\n * @return error explanation or empty string or null\n */\n String explanation();\n\n /**\n * If the PI entity was NOT written successfully, this method returns\n * the internal throwable instance associated with the error (e.g. a\n * {@link io.grpc.StatusRuntimeException} instance). Returns null if\n * such throwable instance is not available or if no errors occurred.\n *\n * @return throwable instance associated with this PI entity\n */\n Throwable throwable();\n }",
"@Override\n\tpublic String getReferenceFiles() {\n\t\treturn model.getReferenceFiles();\n\t}",
"@Override\n\tpublic FileVO detailFile(int file_num) {\n\t\treturn workMapper.detailFile(file_num);\n\t}",
"public interface FileService {\n//todo\n\n}",
"public File getFile()\n {\n return file;\n }",
"public org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder() {\n return getMetadata();\n }",
"public org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder() {\n return getMetadata();\n }",
"public org.apache.calcite.avatica.proto.Responses.RpcMetadataOrBuilder getMetadataOrBuilder() {\n return getMetadata();\n }"
]
| [
"0.6320053",
"0.5837242",
"0.56380945",
"0.5633112",
"0.5452221",
"0.53746825",
"0.5370511",
"0.5285829",
"0.52808845",
"0.5239298",
"0.5239298",
"0.5165272",
"0.5135851",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.51277846",
"0.5119547",
"0.5106616",
"0.51022285",
"0.5100172",
"0.5044854",
"0.5038958",
"0.5028925",
"0.5017965",
"0.5008361",
"0.50078946",
"0.50064445",
"0.49955273",
"0.49949232",
"0.49937803",
"0.49878055",
"0.49743733",
"0.49711975",
"0.49557772",
"0.49488828",
"0.49411622",
"0.49285427",
"0.49243224",
"0.49192095",
"0.49154326",
"0.49002132",
"0.4892205",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.489216",
"0.4889924",
"0.48872015",
"0.48790452",
"0.48780274",
"0.48758048",
"0.4873989",
"0.48718557",
"0.48693943",
"0.48642433",
"0.48545364",
"0.48530358",
"0.48529664",
"0.48456243",
"0.48346272",
"0.48313132",
"0.4818758",
"0.48183852",
"0.4817765",
"0.4814119",
"0.48112318",
"0.48108923",
"0.48103747",
"0.4801799",
"0.4800312",
"0.4799655",
"0.47974697",
"0.47952768",
"0.4790017",
"0.47881532",
"0.47745523",
"0.47744364",
"0.47744364",
"0.47744364"
]
| 0.74526834 | 0 |
When mouse is clicked, the mouse pointer location is captured in the point p. | public void mouseClicked(MouseEvent e) {
p.x = e.getX();
p.y = e.getY();
repaint();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void pointToMouse() {\n pointToXY(p.mouseX,p.mouseY);\n }",
"public void mousePressed(MouseEvent e) {\n pX = e.getX();\n pY = e.getY();\n }",
"public abstract void mousePressed(Point p);",
"@Override\n\tpublic void mousePressed(MouseEvent e) {\n\t\tpvo3 = getPosition(e.getPoint());\n\t\t// System.out.println(pvo1.getX()+\",\"+pvo1.getY());\n\t}",
"public void mousePressed(MouseEvent e)\n {\n points.setX(e.getX());\n points.setY(e.getY());\n }",
"public void mousePressed(MouseEvent event)\n\t\t{\n\t\t\ttempPoint1 = event.getPoint();\n\t\t}",
"@Override\r\n\tpublic void mousePressed(MouseEvent e) {\n\t\tPoint point = new Point();\r\n\t\tpoint.x = e.getX();\r\n\t\tpoint.y = e.getY();\r\n\r\n\t switch (shape) {\r\n\t \r\n\t case LINE :\r\n\r\n\t \tthis.clicksforLine.add(point);\r\n\t \tbreak;\r\n\t case CIRCLE:\r\n\r\n\t \tthis.clicksforCircle.add(point);\r\n\t \tbreak;\r\n\t case POLYGON:\r\n\r\n\t \tthis.clicksforPoly.add(point);\r\n\t \tbreak;\r\n\t case CURVE:\r\n\r\n\t \tthis.clicksforCurve.add(point);\r\n\t \tbreak;\r\n\t case CLEAR:\r\n\t {\r\n\t }\r\n\t \tbreak;\r\n\t default:\r\n\t \tbreak;\r\n\t }\r\n \r\n\t\tSystem.out.println(point.x+ \",\"+point.y);\r\n repaint();\r\n\t\t\r\n\t}",
"public void mousePressed(MouseEvent e) {\n mouseX = e.getX();\n mouseY = e.getY();\n\n lastClicked = canvas.getElementAt(new GPoint(e.getPoint()));\n\n }",
"public Point getclickedPoint() {\r\n return clickedPoint;\r\n }",
"void mouseClicked(double x, double y, MouseEvent e );",
"@Override\n public void mousePressed(MouseEvent e) {\n x_pressed = e.getX();\n y_pressed = e.getY();\n \n }",
"@Override\n\tpublic void drawPoint(MouseEvent e, int state) {\n\n\t}",
"@Override\n public void mousePressed(MouseEvent e) {\n x_pressed = e.getX();\n y_pressed = e.getY();\n \n }",
"@Override\n public void mousePressed(MouseEvent e) {\n x_pressed = e.getX();\n y_pressed = e.getY();\n \n }",
"@Override\n public void mousePressed(MouseEvent e) {\n x_pressed = e.getX();\n y_pressed = e.getY();\n \n }",
"public void mouseClicked(int mouseX, int mouseY, int mouse) {}",
"public void setclickedPoint(Point cp) {\r\n this.clickedPoint = cp;\r\n }",
"void mousePressed(double x, double y, MouseEvent e );",
"@Override\npublic void mouseClicked(MouseEvent e)\n{\n\tSystem.out.println(e.getX() + \" :: \" + e.getY());\n}",
"Point userClickPoint();",
"public void mousePressed(MouseEvent e) {\n oldX = e.getX();\r\n oldY = e.getY();\r\n }",
"@Override\r\n\t\t\tpublic void mousePressed(MouseEvent e) {\n\t\t\t\tclickPoint = e.getPoint();\r\n\t\t\t\tselectionBounds = null;\r\n//\t\t\t\tSystem.out.println(\"Bac dau\" + e.getPoint().toString());\r\n\t\t\t\tbacdauX = (int) e.getPoint().getX();\r\n\t\t\t\tbacdauY = (int) e.getPoint().getY();\r\n\t\t\t}",
"public void mousePressed(MouseEvent e) // When mouse is pressed:\n {\n Location pt = new Location(e.getX(),e.getY());\n origPress = pt;\n\n if(hLine.contains(pt)) // If press is on hLine:\n {\n hLineGrabbed = true; // hLine is grabbed\n }\n\n if(vLine.contains(pt)) // If press is on vLine:\n {\n vLineGrabbed = true; // vLine is grabbed\n }\n\n lastPt = pt; // Set the point to lastPt\n }",
"@Override\n\tpublic void mousePressed(MouseEvent arg0) {\n\t\tint x = arg0.getX();\n\t\tint y = arg0.getY();\n\t\tcurrentPoint = getPoint(x, y);\n\t\tif (currentPoint == null) {\n\t\t\tcurrentPoint = createPoint(x, y);\n\t\t\trepaint();\n\t\t}\n\t}",
"void onMouseClicked(MouseEventContext mouseEvent);",
"public void mousePressed(MouseEvent e) {\n\t\t// It's true that the mouse is pressed\n\t\tmousePress = true;\n\t\t// Record the point user presses as starting point\n\t\tstartTrunk = new Point2D.Double(e.getX(), e.getY());\n\t}",
"@Override\r\n\tpublic void mousePressed(MouseEvent e) {\n\t\tpoints.add(new Point(e.getX(),e.getY()));\r\n\t\trepaint();\r\n\t}",
"private void formMousePressed(java.awt.event.MouseEvent evt) {\n xx=evt.getX();\n xy=evt.getY();\n \n }",
"private void formMousePressed(java.awt.event.MouseEvent evt) {\n xx=evt.getX();\n xy=evt.getY();\n \n }",
"@Override\n\tpublic void mouseClicked(MouseEvent e) {\n\t\tint x = e.getX();\n\t\tint y = e.getY();\n\t\tSystem.out.println(x);\n\t\tSystem.out.println(y);\n\t}",
"@Override\r\n\t\t\tpublic void mousePressed(MouseEvent e) {\n\t\t\t\torigin.x=e.getX();\r\n\t\t\t\torigin.y=e.getY();\r\n\t\t\t}",
"public abstract void mouseMoved(Point p);",
"@Override\n public void mousePressed(MouseEvent me) {\n mouse_x = me.getX();\n mouse_y = me.getY();\n super.mousePressed(me);\n }",
"@Override\n public void mousePressed(MouseEvent e) {\n // this.getVision().getCare().set(this.getVision().getSoul().newMemento());\n if (e.getButton() != MouseEvent.BUTTON1) {\n return;\n }\n if (getVerticallyPointOnGraph(e.getX(), e.getY()) != null) {\n setCurrentPoint(getVerticallyPointOnGraph(e.getX(), e.getY()));\n } else {\n setCurrentPoint(null);\n }\n \n if (getCurrentPoint() != null) {\n double toy = Math.min(Math.max(tCanvasPadding, e.getY()), getHeight() - bCanvasPadding);\n // System.out.println(\"moving to [\"+tox+\",\"+toy+\"]\");\n adapter.moveImagePoint(getCurrentPoint(), c2gy(toy));\n // getCurrentPoint().movePoint(getCurrentPoint(),\n // c2gx(tox),c2gy(toy,getCurrentPoint().getDataSet()));\n }\n // System.out.println(\"Current point is \"+currentPoint);\n }",
"public void mouseClicked( MouseEvent e )\n {\n x = e.getX(); y = e.getY();\n System.out.println(\"click at x=\"+x+\" y=\"+y);\n repaint();\n }",
"public void mousePressed(MouseEvent e) {\n xinitial = e.getX() / 5; //get the x value\r\n yinitial = e.getY() / 5; //get the y value\r\n }",
"private void drawPanelMousePressed(java.awt.event.MouseEvent evt) {\n \n clicks = evt.getPoint();\n \n clicks = getClosedPoint(clicks);\n //System.out.print(ClickSX + \", \" + ClickSY + \",\\n \" );\n \n }",
"@Override\n public void mousePressed(MouseEvent e) {\n\n prevMouse.x = x(e);\n prevMouse.y = y(e);\n\n // 3D mode\n if (getChart().getView().is3D()) {\n if (handleSlaveThread(e)) {\n return;\n }\n }\n\n // 2D mode\n else {\n\n Coord2d startMouse = prevMouse.clone();\n\n if (maintainInAxis)\n maintainInAxis(startMouse);\n\n\n\n // stop displaying mouse position on roll over\n mousePosition = new MousePosition();\n\n // start creating a selection\n mouseSelection.start2D = startMouse;\n mouseSelection.start3D = screenToModel(startMouse.x, startMouse.y);\n\n if (mouseSelection.start3D == null)\n System.err.println(\"Mouse.onMousePressed projection is null \");\n\n\n // screenToModel(bounds3d.getCorners())\n\n }\n }",
"@Override\r\n\t\t\tpublic void mouseDown(MouseEvent e) {\n\t\t\t\tx=e.x;\r\n\t\t\t\ty=e.y;\t\t\t\t\r\n\r\n\t\t\t}",
"@Override\n\tpublic void mousePressed(MouseEvent arg0) {\n\t\tgraphics.panel.requestFocus();\n\t\tx=arg0.getX();\n\t\ty=arg0.getY();\n\t}",
"public void mouseClicked( MouseEvent event ){}",
"@Override \n\t\t\tpublic void mousePressed(MouseEvent e) \n\t\t\t{\n\t\t\t\tbubblePosition.add(e.getPoint());//마우스를 누루면 누룬위치를 리스트에 저장 \n\t\t\t}",
"public void mouseClicked(MouseEvent event){}",
"void mouseClicked(MouseEvent mouseEvent);",
"public void mousePressed(MouseEvent e) {\n\n if(Objects.equals(ToolSelect.GetTool(), \"zoom/pan\")){\n released = false;\n sPoint = MouseInfo.getPointerInfo().getLocation();\n }else {\n\n startPoint = e.getPoint();\n shape = new ColoredRectangle(ToolSelect.GetBorderColor(), ToolSelect.GetFillColor(), new Rectangle(), ToolSelect.GetTool(), null);\n if (Objects.equals(ToolSelect.GetTool(), \"plot\") || Objects.equals(ToolSelect.GetTool(), \"line\")) {\n shape.shape.setBounds(e.getX(), e.getY(), 1, 1);\n }\n }\n\n }",
"public abstract void mouseClicked(MouseEvent e);",
"public void mousePressed(MouseEvent e)\n { \n this.startX=e.getX();\n this.startY=e.getY();\n\n }",
"public void mouseClicked(MouseEvent e) {}",
"public void mouseClicked(MouseEvent e) {}",
"public void mouseClicked(MouseEvent e) {}",
"public void mouseClicked(MouseEvent e) {}",
"@Override\n\tpublic void mousePressed(MouseEvent me) {\n\t\tstartPoint = new Point(me.getX(),me.getY());\n\t}",
"public void mousePressed(MouseEvent e) {}",
"public void mousePressed(MouseEvent e) {}",
"public void mousePressed(MouseEvent e) {}",
"public void mousePressed( MouseEvent event ){}",
"@Override\n public void onMouseClicked(MapMouseEvent ev) {\n \tint respuesta= JOptionPane.showConfirmDialog(null, \"¿Desea guardar este punto?\", \"Confirmar\",JOptionPane.YES_NO_OPTION);\n \tif(respuesta==0) {\n \t\tString texto=JOptionPane.showInputDialog(null, \"Nombre del lugar\");\n \t\tDirectPosition2D p = ev.getWorldPos();\n System.out.println(p.getX() + \" -- \" + p.getY());\n drawMyPoint(p.getX(), p.getY(), map, texto);\n \t}\n \telse{\n \t\tSystem.out.println(\"Punto no guardado\");\n \t}\n \n }",
"public void mousePressed (MouseEvent event) {}",
"public void mouseClicked (MouseEvent m) {\r\n \t//System.out.println(\"mouseClicked..\");\t\r\n }",
"public abstract void mousePressed(MousePressedEvent mp);",
"public void onMouseClicked(Posn p) {\n Posn temp = this.getGamePiece(p);\n int tempx = temp.x;\n int tempy = temp.y;\n for (int i = 0; i < this.width; i++) {\n for (int j = 0; j < height; j++) {\n if (tempx == i && tempy == j) {\n this.board.get(i).get(j).rotatePiece();\n }\n }\n }\n }",
"public void mouseClicked(MouseEvent e)\n {}",
"void mousePressed(MouseEvent mouseEvent);",
"public void mouseClicked(MouseEvent e) {\n\t\tdouble[] pointLocation = new double[3];\n\t\tdouble x = e.getX();\n\t\tdouble y = e.getY();\n\t\t\n\t\tplotContent.Click(x, y, pointLocation);\n\t\tif(pointLocation[0]==0.0&&pointLocation[1]==0.0&&pointLocation[2]==0.0) {\n\t\t\t\n\t\t}else {\n\t\t\ttradedetail.setText(\"\\n\"+\"Yield = \"+pointLocation[0]+\"\\n\"+\"Days_To_Maturity = \"+pointLocation[1]+\"\\n\"+\"Amount_CHF = \"+pointLocation[2]);\n\t\t}\n\t}",
"public void mousePressed(MouseEvent e) {\r\n }",
"@Override\n\tpublic void mouseClicked(MouseEvent e) {\n//\t\tPoint2D.Double view = new Point2D.Double(e.getX(), e.getY());\n//\t\tPoint2D.Double worldPoint = new Point2D.Double();\n//\t\tAffineTransform viewToWorld = new AffineTransform(1.0 / scale, 0, 0, 1.0 / scale, worldUpperLeft.getX(), worldUpperLeft.getY());\n//\t\tviewToWorld.transform(view, worldPoint);\n//\t\n//\t\t// check here if clicking a waypoint\n//\t\tint index = data.hitWaypointTest(worldPoint.getX(), worldPoint.getY());\n//\t\tif(index != -1) {\n////\t\t\tWaypoint w = data.getWaypoint(index);\n//\t\t\tGUIFunctions.updateWaypointDataFields(w);\n//\t\t} else \n//\t\t\tGUIFunctions.updateWaypointDataFields(null);\n\t}",
"public abstract void mouseClicked(MouseClickedEvent event);",
"public void mousePressed(MouseEvent e) {\n }",
"public void mouseClicked(MouseEvent e) { \r\n }",
"@Override\n public void mouseClicked(MouseEvent e) {\n //location where mouse was pressed\n Point mousePoint = e.getPoint();\n //conversion to location on frame\n Vec2 worldPoint = view.viewToWorld(mousePoint);\n float fx = e.getPoint().x;\n float fy = e.getPoint().y;\n float vx = worldPoint.x;\n float vy = worldPoint.y;\n //Completes checks for pressing of GUI components\n restartCheck(vx, vy);\n settingsCheck(vx, vy);\n zoomCheck(fx, fy);\n }",
"public void mousePressed(MouseEvent event)\r\n {\n }",
"public void mousePressed(MouseEvent e) {\n\t\t\t\n\t\t}",
"public void mousePressed(MouseEvent e) {\n\t\t\t\n\t\t}",
"public void mousePressed(MouseEvent e) {\n\t\t\t\n\t\t}",
"public void mousePressed(MouseEvent e) {\n\t\t\t\n\t\t}",
"public void mousePressed(MouseEvent e) {\n\t\tdouble x = e.getX();\n\t\tdouble y = e.getY();\n\t\tswitch (clickTracker) {\n\t\t\tcase 0:\n\t\t\t\t//figureDone = false;\n\t\t\t\tflipDirection.setEnabled(false);\n\t\t\t\tlastClick = new GPoint(x,y);\n\t\t\t\tlineActive = true;\n\t\t\t\tbreak;\n\t\t\tcase 1:\n\t\t\t\tlineActive = false;\n\t\t\t\tremove(centerCircle);\n\t\t\t\tdrawCenter(x, y);\n\t\t\t\t//println(lastClick + \" x \" + x + \" y \" +y);\n\t\t\t\t//double centerX = lastClick.getX();\n\t\t\t\t//double centerY = lastClick.getY();\n\t\t\t\tlastClick = new GPoint(lastClick.getX() + centerCircle.getWidth(), lastClick.getY());\n\t\t\t\tbreak;\n\t\t\t//case 2:\n\t\t\t\t//lastClick = new GPoint(x,y);\n\t\t\t\t//lineActive = true;\n\t\t\t\t//break;\n\t\t\tcase 2:\n\t\t\t\tlineActive = false;\n\t\t\t\tremove(outerCircle);\n\t\t\t\tdrawOuter(x, y);\n\t\t\t\tbreak;\n\t\t\tcase 3:\n\t\t\t\tlineActive = false;\n\t\t\t\tremove(armLine);\n\t\t\t\tdrawArm(x,y);\n\t\t\t\tinitalizeFigure();\n\t\t\t\tbreak;\n\t\t}\n\t\tclickTracker++;\n\t\tif (clickTracker == 3 || clickTracker == 2) lineActive = true;\n\t}",
"public void mousePressed(MouseEvent e) {\n \t\t\r\n \t}",
"public void mousePressed(MouseEvent e) {\n }",
"@Override\n public void mousePressed(MouseEvent e) {\n startDrag = new Point(e.getX(), e.getY());\n points.add(startDrag);\n repaint();\n }",
"public void mousePressed(MouseEvent e) {\n\n }",
"public void mousePressed(MouseEvent e)\n { }",
"public void mousePressed(MouseEvent e) {\n int i = 0;\n // Koordinaten des Mauszeigers sind relativ zum sichtbaren Bereich der\n // Zeichenflaeche. Also linke obere Ecke des sichtb. Bereichs holen\n // und beruecksichtigen.\n Rectangle r = ((JScrollPane) e.getSource()).getViewport().getViewRect();\n int f = model.getFactor(); // Zoomfaktor beachten\n int x = r.x + e.getX();\n x = x / f;\n int y = r.y + e.getY();\n y = y / f;\n\n moveP = model.getInterpolPoint(new Point(x, y, f));\n // Hilfspunkt erzeugen\n }",
"public void mousePressed(MouseEvent e) {\n\t\t\t\t\n\t\t\t}",
"public void mousePressed(MouseEvent e) {\n\t\t\t\t\n\t\t\t}",
"public void mouseClicked(MouseEvent e) {\n \t\t\r\n \t}",
"public void mousePressed(MouseEvent e) {\n ptDragStart = e.getPoint();\r\n mouseDragged = true;\r\n }",
"public void mouseClicked(MouseEvent e) {\n\n }",
"public void mousePressed(MouseEvent arg0) {\n\n }",
"public void mousePressed(MouseEvent arg0) {\n\n }",
"public void mousePressed(MouseEvent e)\n\t{\n\t\tint x = e.getX();\n\t\tint y = e.getY();\n\t\tlabel.setText(\"mouse Pressed at (\"+x+\", \"+y+\")\");\n\t}",
"public void mouseClicked(MouseEvent arg0) {\n }",
"public void mousePressed (MouseEvent m)\r\n {\r\n \tmousePressed = true;\r\n \tmouseReleased = false;\r\n \tmouseX = m.getX();\r\n \tmouseY = m.getY();\r\n \tpickObject(mouseX, mouseY, m);\r\n \t//System.out.println(\"mousePressed\");\r\n }",
"public void mouseClicked(MouseEvent e) {\n\t\t\t\n\t\t}",
"public void mouseClicked(MouseEvent e) {\n\t\t\t\n\t\t}",
"public void mouseClicked(int ex, int ey, int button) {\r\n\t}",
"public void mousePressed(MouseEvent e) {\n\t\t\n\t}",
"public void mousePressed(MouseEvent e) {\n\t\t\n\t}",
"public void mousePressed(MouseEvent e) {\n\t\t\n\t}",
"@Override\n\tpublic void mouseClicked(MouseEvent e)\n\t{\n\t\tSystem.out.println(e.getX()+\",\"+e.getY());\n\t\t\n\t\t//On envoie au controller les coordonnées selectionnées:\n\t\tcontroller.clicOnMap(e.getX(), e.getY());\n\t}",
"@Override\n public void mousePressed(MapEventMouse e) {\n if (SwingUtilities.isLeftMouseButton(e)) {\n start = e.getPoint();\n startCoordinate = e.getLocation();\n isDragging = true;\n end = null;\n }\n }"
]
| [
"0.7961015",
"0.7896092",
"0.7815865",
"0.7601644",
"0.7567838",
"0.7477334",
"0.74192435",
"0.74115306",
"0.737083",
"0.7283606",
"0.72808665",
"0.7274571",
"0.72531754",
"0.72531754",
"0.72531754",
"0.72477967",
"0.72443",
"0.7238943",
"0.72372234",
"0.71769786",
"0.7148182",
"0.7142908",
"0.7131067",
"0.70907307",
"0.7076238",
"0.7074941",
"0.70037854",
"0.699668",
"0.699668",
"0.69726026",
"0.6969332",
"0.6926277",
"0.69238377",
"0.69186264",
"0.6900454",
"0.68973225",
"0.6892378",
"0.68861127",
"0.68818516",
"0.6863209",
"0.68614244",
"0.6824772",
"0.68218184",
"0.68130726",
"0.6812184",
"0.6796597",
"0.6780138",
"0.67666054",
"0.67666054",
"0.67666054",
"0.67666054",
"0.67570657",
"0.67561984",
"0.67561984",
"0.67561984",
"0.67166024",
"0.6713078",
"0.6698059",
"0.6688161",
"0.6675838",
"0.66467077",
"0.6628942",
"0.662586",
"0.6604232",
"0.6603473",
"0.6601745",
"0.6580568",
"0.6574002",
"0.65619594",
"0.65492606",
"0.65460455",
"0.65350586",
"0.65350586",
"0.65350586",
"0.65350586",
"0.6524132",
"0.6522385",
"0.65212786",
"0.65151215",
"0.65089417",
"0.65068346",
"0.65067524",
"0.65001696",
"0.65001696",
"0.6497303",
"0.6494035",
"0.6488753",
"0.64776325",
"0.64776325",
"0.64725035",
"0.6468007",
"0.6458936",
"0.64578027",
"0.64578027",
"0.64473623",
"0.6447278",
"0.6447278",
"0.6447278",
"0.6436665",
"0.64344096"
]
| 0.80259424 | 0 |
Draw a small solid square around the point | public void paintComponent(Graphics g) {
super.paintComponent(g);
g.drawString("(" + p.x + ", " + p.y + ")", p.x, p.y);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void drawSquare(Graphics g, int x, int y, \n Tetrominoe shape) {\n Color colors[] = {\n new Color(0, 0, 0), new Color(204, 102, 102),\n new Color(102, 204, 102), new Color(102, 102, 204),\n new Color(204, 204, 102), new Color(204, 102, 204),\n new Color(102, 204, 204), new Color(218, 170, 0)\n };\n//left and top sides are brighter, bottom and right sides to look 3d\n Color color = colors[shape.ordinal()];\n\n g.setColor(color);\n g.fillRect(x + 1, y + 1, squareWidth() - 2, squareHeight() - 2);\n\n g.setColor(color.brighter());\n g.drawLine(x, y + squareHeight() - 1, x, y);\n g.drawLine(x, y, x + squareWidth() - 1, y);\n\n g.setColor(color.darker());\n g.drawLine(x + 1, y + squareHeight() - 1,\n x + squareWidth() - 1, y + squareHeight() - 1);\n g.drawLine(x + squareWidth() - 1, y + squareHeight() - 1,\n x + squareWidth() - 1, y + 1);\n\n }",
"public void drawOval(int x, int y, int width, int height);",
"public void draw() {\r\n /* DO NOT MODIFY */\r\n StdDraw.point(x, y);\r\n }",
"private void printSquareAroundPoint(int x, int y)\n {\n // System.out.println();\n }",
"@Override\n public void draw() {\n super.draw(); \n double radius = (this.getLevel() * 0.0001 + 0.025) * 2.5e10;\n double x = this.getR().cartesian(0) - Math.cos(rot) * radius;\n double y = this.getR().cartesian(1) - Math.sin(rot) * radius;\n StdDraw.setPenRadius(0.01);\n StdDraw.setPenColor(StdDraw.RED);\n StdDraw.point(x, y);\n \n }",
"public void draw() {\n /* DO NOT MODIFY */\n StdDraw.point(x, y);\n }",
"public void draw() {\n /* DO NOT MODIFY */\n StdDraw.point(x, y);\n }",
"public void draw() {\n /* DO NOT MODIFY */\n StdDraw.point(x, y);\n }",
"public void draw() {\n /* DO NOT MODIFY */\n StdDraw.point(x, y);\n }",
"private void drawSquare(int x, int y, Color color) {\r\n\t\t// sets the color to the passed in color.\r\n\t\tg.setColor(color);\r\n\t\t// draws a rectangle based on the given properties.\r\n\t\tg.fillRect(x * TetrisGame.SQUARE_LENGTH, y * TetrisGame.SQUARE_LENGTH,\r\n\t\t\t\t TetrisGame.SQUARE_LENGTH - 1,\r\n\t\t\t\t TetrisGame.SQUARE_LENGTH - 1);\r\n\t}",
"public void drawPixel(int x, int y, int color);",
"private static void drawSquare(Graphics2D g, int startX, int numSquare, int endLine, int pSize) {\r\n \r\n g.setColor(Color.BLACK);\r\n int width = (startX / numSquare);\r\n \r\n for(int i = 0; i < numSquare; i++) {\r\n g.drawLine(width * i + endLine, 0, width * i + endLine, pSize);\r\n g.drawLine(0, width * i + endLine, pSize, width * i + endLine);\r\n }\r\n \r\n }",
"public void strokeRectangle(int x, int y, int width, int height);",
"@Override\n\tpublic void draw(GraphicsContext gc) {\n\t\tgc.setFill(this.color.getColor());\n\t\tgc.fillRect(MyPoint.point[0], MyPoint.point[1], this.width, this.height);\n\t}",
"public void draw() {\n\t\tSystem.out.println(getMessageSource().getMessage(\"greeting2\", null, null));\r\n\r\n\t\tSystem.out.println(getMessageSource().getMessage(\"drawing.circle\", null, null));\r\n\t\tSystem.out.println(\"Center's Coordinates: (\" + getCenter().getX() + \", \" + getCenter().getY() + \")\");\r\n\t\tSystem.out.println(getMessageSource().getMessage(\"drawing.center\",\r\n\t\t\t\tnew Object[] { getCenter().getX(), getCenter().getY() }, \"Default point coordinates msg\", null));\r\n\t}",
"public void drawShape(Shape shape);",
"public void drawRect(int x, int y, int width, int height, int color);",
"private static void drawSquare(Graphics2D g, int pSize, int numOfSqr, int startX) {\r\n \r\n for(int i = 0; i < numOfSqr; i++) {\r\n g.setColor(Color.BLACK);\r\n g.fillRect(startX * i - numOfSqr, 0, numOfSqr, pSize);\r\n g.fillRect(0, startX * i - numOfSqr, pSize, numOfSqr);\r\n drawSquare(g, startX, numOfSqr, startX * i, pSize);\r\n \r\n }\r\n }",
"@Override\r\n\tpublic void draw() {\n\t\tPoint p = this.getP();\r\n\t\tint start_point = p.getX();\r\n\t\tint end_point = p.getY();\r\n\t\t\r\n\t\tint width = this.getWidth();\r\n\t\tint height = this.getHeight();\r\n\t\t\r\n\t\tSystem.out.println(\"�l�p�`��`�� �_(\" + start_point +\",\"+ end_point + \")����Ƃ��āA��\"+ width +\"����\"+ height +\"�̎l�p�`\");\r\n\t}",
"@Override\r\n\tpublic void draw(Graphics g) {\n\t\tg.setColor(this.color);\r\n\t\tg.fillOval((int)x, (int)y, side, side);\r\n\t\tg.setColor(this.color2);\r\n\t\tg.fillOval((int)x+5, (int)y+2, side/2, side/2);\r\n\t}",
"@Override\n public void drawMarker(PGraphics pg, float x, float y)\n {\n pg.noFill();\n pg.rectMode(CENTER);\n pg.rect(x,y,this.radius*2,this.radius*2,10);\n }",
"public abstract void drawPiece(int x, int y, Graphics g);",
"@Override public void onMouseClick( Location point ) {\n new FilledRect( verticalCorner, 5, 210, canvas );\n new FilledRect( horizontalCorner, 210, 5, canvas );\n\n verticalCorner.translate( -10, 0 );\n horizontalCorner.translate( 0, -10 );\n }",
"@Override\r\n\tpublic void draw(Graphics g) {\n\t\tg.setColor(Color.PINK);\r\n\t\tg.fillRect(getX(), getY(), getWidth(), getHeight());\r\n\t\t\r\n\t}",
"public Point(double x, double y) {\r\n this.x = x;\r\n this.y = y;\r\n this.c = Color.COLORLESS;\r\n }",
"@Override\n\tpublic void draw() {\n\t\tSystem.out.println(\"Square drawn\");\n\t}",
"public void drawSquareView() {\r\n \tview.updateSquare();\r\n \tview.drawSquare();\r\n }",
"private void drawPoint(float X, float Y, Paint p, int velocity) {\r\n if (_brushType == BrushType.Square) {\r\n /* Draw square thing */\r\n _offScreenCanvas.drawRect(X-5,Y+5,X+5,Y-5,_paint);\r\n } else if (_brushType == BrushType.Point) {\r\n /* Draw a pixel, maybe draw a sized rectangle */\r\n _offScreenCanvas.drawPoint(X,Y,_paint);\r\n } else if (_brushType == BrushType.Circle) {\r\n _offScreenCanvas.drawCircle(X, Y, _defaultRadius + velocity, _paint);\r\n } else if (_brushType == BrushType.SprayPaint) {\r\n /* Draw a random point in the radius */\r\n float x = genX(X);\r\n _offScreenCanvas.drawPoint(X + x,Y + genY(x),_paint);\r\n } else {\r\n /* Draw generic pixel? */\r\n _offScreenCanvas.drawPoint(X,Y,_paint);\r\n }\r\n }",
"public void strokeRoundRectangle(int x, int y, int width, int height, int radius);",
"public void draw() {\n StdDraw.setPenColor(StdDraw.BLACK);\n StdDraw.setPenRadius(0.01);\n for (Point2D point : points) {\n StdDraw.point(point.x(), point.y());\n }\n StdDraw.setPenRadius();\n }",
"@Override\r\n public final void draw(final Square s, final BufferedImage paper) {\n String red;\r\n String green;\r\n String blue;\r\n if (Integer.toHexString(s.getBorderColor().getRed()).length() == 1) {\r\n red = \"0\" + Integer.toHexString(s.getBorderColor().getRed());\r\n } else {\r\n red = Integer.toHexString(s.getBorderColor().getRed());\r\n }\r\n if (Integer.toHexString(s.getBorderColor().getGreen()).length() == 1) {\r\n green = \"0\" + Integer.toHexString(s.getBorderColor().getGreen());\r\n } else {\r\n green = Integer.toHexString(s.getBorderColor().getGreen());\r\n }\r\n if (Integer.toHexString(s.getBorderColor().getBlue()).length() == 1) {\r\n blue = \"0\" + Integer.toHexString(s.getBorderColor().getBlue());\r\n } else {\r\n blue = Integer.toHexString(s.getBorderColor().getBlue());\r\n }\r\n String color = \"#\" + red + green + blue;\r\n \r\n draw(new Line((String.valueOf(s.getxSus())), String.valueOf(s.getySus()),\r\n String.valueOf(s.getxSus() + s.getLatura() - 1), String.valueOf(s.getySus()), color,\r\n String.valueOf(s.getBorderColor().getAlpha()), paper), paper);\r\n\r\n draw(new Line((String.valueOf(s.getxSus() + s.getLatura() - 1)),\r\n String.valueOf(s.getySus()), String.valueOf(s.getxSus() + s.getLatura() - 1),\r\n String.valueOf(s.getySus() + s.getLatura() - 1), color,\r\n String.valueOf(s.getBorderColor().getAlpha()), paper), paper);\r\n\r\n draw(new Line((String.valueOf(s.getxSus() + s.getLatura() - 1)),\r\n String.valueOf(s.getySus() + s.getLatura() - 1), String.valueOf(s.getxSus()),\r\n String.valueOf(s.getySus() + s.getLatura() - 1), color,\r\n String.valueOf(s.getBorderColor().getAlpha()), paper), paper);\r\n\r\n draw(new Line((String.valueOf(s.getxSus())),\r\n String.valueOf(s.getySus() + s.getLatura() - 1), String.valueOf(s.getxSus()),\r\n String.valueOf(s.getySus()), color, String.valueOf(s.getBorderColor().getAlpha()),\r\n paper), paper);\r\n for (int i = s.getxSus() + 1; i < s.getxSus() + s.getLatura() - 1; i++) {\r\n for (int j = s.getySus() + 1; j < s.getySus() + s.getLatura() - 1; j++) {\r\n if (checkBorder(i, j, paper)) {\r\n paper.setRGB(i, j, s.getFillColor().getRGB());\r\n }\r\n }\r\n }\r\n\r\n }",
"public void display (Graphics2D g, double x, double y);",
"private void DrawOval(GL gl, float x, float y, float size, float r, float g, float b) {\n\t\t// Degeneracy = do not want\n\t\tif (m_length == 0.0f || m_width == 0.0f) {\n\t\t\treturn;\n\t\t}\n\n\n\t\t////int mct = (int) (1 / this.GetPEngine().m_uniscale);\n\t\t////mct = (mct / 2) / 100 * 100;\n\t\tgl.glPushMatrix();\n\t\tfloat theta = (float) Math.toRadians(m_slope);\n\t\t// Draw our line:\n\t\tgl.glLineWidth(2.0f);\n\n\t\tif (Iteration != 0) {\n\t\t\tfor (int i = 0; i < Iteration; i++) {\n\n\n\t\t\t\tif ((m_slope >= 0 && m_slope <= 45) || (m_slope >= 315 && m_slope <= 360)) {\n\t\t\t\t\tgl.glBegin(gl.GL_QUAD_STRIP);\n\t\t\t\t\t// Draw x- and y-axes:\n\t\t\t\t\tgl.glColor3f(0.0f, 0.0f, 0.0f);\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (100 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + 100 + (100 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (50 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + 100 + (50 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (0 + i * 200) * ((float) Math.cos(theta)), 100 + y_Start * 100 + (0 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (-50 + i * 200) * ((float) Math.cos(theta)), 100 + y_Start * 100 + (-50 + i * 200) * ((float) Math.sin(theta)));\n\n\t\t\t\t\tgl.glEnd();\n\n\t\t\t\t\tgl.glBegin(gl.GL_QUAD_STRIP);\n\t\t\t\t\t// Draw x- and y-axes:\n\t\t\t\t\tgl.glColor3f(0.0f, 0.0f, 0.0f);\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (-100 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + 100 + (-100 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (-50 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + 100 + (-50 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (0 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + -20 + (0 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (40 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + 20 + (40 + i * 200) * ((float) Math.sin(theta)));\n\n\n\n\t\t\t\t\tgl.glEnd();\n\t\t\t\t} else if ((m_slope >= 135 && m_slope < 225)) {\n\t\t\t\t\tgl.glBegin(gl.GL_QUAD_STRIP);\n\t\t\t\t\t// Draw x- and y-axes:\n\t\t\t\t\tgl.glColor3f(0.0f, 0.0f, 0.0f);\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (0 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + 100 + (0 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (50 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + 100 + (50 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (-100 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 - 100 + (-100 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + (-50 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 - 100 + (-50 + i * 200) * ((float) Math.sin(theta)));\n\n\n\t\t\t\t\tgl.glEnd();\n\n\t\t\t\t} else if (m_slope > 45 && m_slope < 135) {\n\t\t\t\t\tgl.glBegin(gl.GL_QUAD_STRIP);\n\t\t\t\t\t// Draw x- and y-axes:\n\t\t\t\t\tgl.glColor3f(0.0f, 0.0f, 0.0f);\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + -100 + (100 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (100 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + -100 + (50 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (50 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + 100 + (0 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (0 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + 100 + (-50 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (-50 + i * 200) * ((float) Math.sin(theta)));\n\n\t\t\t\t\tgl.glEnd();\n\t\t\t\t\tgl.glBegin(gl.GL_QUAD_STRIP);\n\t\t\t\t\t// Draw x- and y-axes:\n\t\t\t\t\tgl.glColor3f(0.0f, 0.0f, 0.0f);\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 - 100 + (-100 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (-100 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 - 100 + (-50 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (-50 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + 20 + (0 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (0 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + -20 + (40 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (40 + i * 200) * ((float) Math.sin(theta)));\n\n\n\n\t\t\t\t\tgl.glEnd();\n\t\t\t\t} else {\n\t\t\t\t\tgl.glBegin(gl.GL_QUAD_STRIP);\n\t\t\t\t\t// Draw x- and y-axes:\n\t\t\t\t\tgl.glColor3f(0.0f, 0.0f, 0.0f);\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + 100 + (-100 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (-100 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + 100 + (-50 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (-50 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 - 100 + (0 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (0 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 - 100 + (50 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (50 + i * 200) * ((float) Math.sin(theta)));\n\n\t\t\t\t\tgl.glEnd();\n\t\t\t\t\tgl.glBegin(gl.GL_QUAD_STRIP);\n\t\t\t\t\t// Draw x- and y-axes:\n\t\t\t\t\tgl.glColor3f(0.0f, 0.0f, 0.0f);\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + 100 + (100 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (100 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + 100 + (50 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (50 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 - 20 + (0 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (0 + i * 200) * ((float) Math.sin(theta)));\n\t\t\t\t\tgl.glVertex2d(x_Start * 100 + 20 + (-40 + i * 200) * ((float) Math.cos(theta)), y_Start * 100 + (-40 + i * 200) * ((float) Math.sin(theta)));\n\n\n\n\t\t\t\t\tgl.glEnd();\n\n\t\t\t\t}\n\n\t\t\t\tgl.glPopMatrix();\n\t\t\t}\n\t\t}\n\t}",
"public void drawRect(int x, int y, int width, int height);",
"public void draw(Polygon poly, float x, float y, float width, float height) {\n draw(poly, x, y, width, height, x, y, 0, 1, 1, 1, 1);\n }",
"@Override\n public void paintComponent() {\n Graphics2D graphics = gameInstance.getGameGraphics();\n graphics.setColor(Color.ORANGE);\n\n final int diff = (PacmanGame.GRID_SIZE/2) - pointCircleRadius;\n graphics.fill(new Ellipse2D.Double(this.x + diff, this.y + diff, pointCircleRadius*2, pointCircleRadius*2));\n }",
"public void drawSquare(double size) {\r\n\t\t\r\n\t\t//if the size is a negative number, throw an error\r\n\t\tif (size <= 0) {\r\n\t\t\tthrow new RuntimeException(\"Errordaniel - invalid size\");\r\n\t\t}\r\n\r\n\t\t//by the saved word 'super' we call to 'tailDown' function in 'SimpleTurtle' class from that we inherit her\r\n\t\t//take the turtle tail down so he will leave traces\r\n\t\tsuper.tailDown();\r\n\r\n\t\t//a square has 4 sides so the turtle should be rotated after 3 sides.\r\n\t\tfor (int i = 0; i < 3; i++) {\r\n\t\t\tmoveForward(size);\r\n\t\t\tsuper.turnRight(90);\r\n\t\t}\r\n\r\n\t\t//paint the last side\r\n\t\tmoveForward(size);\r\n\t}",
"public void draw()\n {\n Rectangle hatbox = new Rectangle(x, y, 20, 20);\n hatbox.fill();\n Rectangle brim = new Rectangle(x-10, y+20, 40, 0);\n brim.draw();\n Ellipse circle = new Ellipse (x, y+20, 20, 20);\n circle.draw();\n Ellipse circle2 = new Ellipse (x-10, y+40, 40, 40);\n circle2.draw();\n Ellipse circle3 = new Ellipse (x-20, y+80, 60, 60);\n circle3.draw();\n \n }",
"public void drawSquare(int c, int x, int y, Graphics g)\r\n\t\t{\r\n\t\t\tColor squareColor;\r\n\t\t\tint[] arr = getColor(c);\r\n\t\t\tif(arr.length == 0)\r\n\t\t\t\treturn;\r\n\t\t\tsquareColor = new Color(arr[0], arr[1], arr[2]);\r\n\t\t\tg.setColor(squareColor.darker());\r\n\t\t\tg.fillRect(x, y - SIZE, SIZE, SIZE);\r\n\t\t\tg.setColor(squareColor);\r\n\t\t\tg.fillRect(x + 1, y - SIZE+1, SIZE-3, SIZE-3);\r\n\t\t}",
"private void drawBox(Graphics2D g2d, int y, int wid, int hei) {\n g2d.setColor(Dark_Gray);\n Triangle triangle1 = new Triangle(new Point(wid / 3, y), new Point(2 * wid / 3, y), new Point(wid / 3, y + hei / 10));\n triangle1.fill(g2d);\n g2d.setColor(Light_Gray);\n Triangle triangle2 = new Triangle(new Point(2 * wid / 3, y + hei / 10), new Point(2 * wid / 3, y), new Point(wid / 3, y + hei / 10));\n triangle2.fill(g2d);\n Triangle triangle3 = new Triangle(new Point(wid / 3, y + hei / 10), new Point(wid / 3 + 8, y + hei / 10), new Point(wid / 3 + 8, y + hei / 10 - 8));\n triangle3.fill(g2d);\n g2d.setColor(Dark_Gray);\n Triangle triangle4 = new Triangle(new Point(2 * wid / 3, y), new Point(2 * wid / 3 - 8, y), new Point(2 * wid / 3 - 8, y + 8));\n triangle4.fill(g2d);\n g2d.setColor(Color.BLACK);\n g2d.fillRect(wid / 3 + 4, y + 4, wid / 3 - 8, hei / 10 - 8);\n }",
"@Override\n public void draw(Graphics graphics){\n graphics.fillRect(referencePoint.getX() + width / 3, referencePoint.getY() + height / 3, width / 3, height / 3);\n }",
"public static void main(Graphics2D g, int pSize, int sqrSize, int currX, int currY) {\r\n \r\n int tempSize = Math.round(Math.round(Math.sqrt(sqrSize))); \r\n int font = (((pSize / tempSize) / tempSize) / 3);\r\n int startX = (pSize / tempSize); \r\n \r\n drawSquare(g, pSize, tempSize, startX);\r\n highlight(g, currX, currY, (startX / tempSize));\r\n g.setFont(new Font(\"Helvetica\", Font.BOLD, font + 10));\r\n drawNum(g, pSize, sqrSize, tempSize, font);\r\n System.out.println(get());\r\n System.out.println(font);\r\n System.out.println(tempSize);\r\n System.out.println(startX);\r\n \r\n }",
"public void drawHealth(int x, int y) {\n pushMatrix();\n translate(x, y);\n scale(0.8f);\n smooth();\n noStroke();\n fill(0);\n beginShape();\n vertex(52, 17);\n bezierVertex(52, -5, 90, 5, 52, 40);\n vertex(52, 17);\n bezierVertex(52, -5, 10, 5, 52, 40);\n endShape();\n fill(255,0,0);\n beginShape();\n vertex(50, 15);\n bezierVertex(50, -5, 90, 5, 50, 40);\n vertex(50, 15);\n bezierVertex(50, -5, 10, 5, 50, 40);\n endShape();\n popMatrix();\n}",
"abstract void draw(Graphics g, int xoff, int yoff,\n int x, int y, int width, int height);",
"@Override\n public void paintPedestrian(Graphics g) {\n g.setColor(Color.BLUE);\n g.fillOval(x, y, 10, 10);\n g.setColor(Color.BLACK);\n g.drawOval(x, y, 10, 10);\n }",
"public void draw(Point location) {\n\t}",
"public void drawLine(float x, float y, float x2, float y2, float width, float u, float v, float texW, float texH) {\n throw new NotImplementedException(); // TODO Implement\n }",
"@Override\n public void draw() {\n drawAPI.drawCircle(radius, x, y); \n }",
"private void drawPiece(int row, int col, Graphics g, Color color){\r\n ((Graphics2D) g).setRenderingHint(RenderingHints.KEY_ANTIALIASING, RenderingHints.VALUE_ANTIALIAS_ON);\r\n ((Graphics2D) g).setRenderingHint(RenderingHints.KEY_RENDERING, RenderingHints.VALUE_RENDER_QUALITY);\r\n g.setColor(color);\r\n g.fillOval((col*tileSize)+2, (row*tileSize)+2, tileSize-4, tileSize-4);\r\n }",
"public void draw_square(Graphics g) {\n\t\tg.setColor(blank);\n\t\tg.fillRect(x_origin, y_origin, square_size, square_size);\n\t\t\n\t\tg.setColor(Color.black);\n\t\tg.drawRect(x_origin, y_origin, square_size, square_size);\n\t\t\n\t\tFont font = new Font(\"Courier New\", Font.BOLD, square_size / 4);\n\t\tg.setFont(font);\n\t\tg.setColor(Color.black);\n\t\tg.drawString(str_id, x_origin + (square_size / 2), y_origin + (square_size / 2));\n\t}",
"@Override\r\n\tpublic void render(Graphics g) {\n\t\tg.setColor(Color.yellow);\r\n\t\tg.fillRect((int) getX(), (int) getY(), 5, 10);\r\n\t}",
"public void draw() {\n for (Point2D p: mPoints) {\n StdDraw.filledCircle(p.x(), p.y(), 0.002);\n }\n }",
"@Override public void draw(){\n // this take care of applying all styles (colors/stroke)\n super.draw();\n // draw our shape\n pg.ellipseMode(PGraphics.CORNER); // TODO: make configurable\n pg.ellipse(0,0,getSize().x,getSize().y);\n }",
"@Override\r\n\tpublic void draw(Graphics g) {\n\t\tg.setColor(Color.green);\r\n\t\tg.fillRect(getX(), getY(), getWidth(), getHeight());\r\n\t}",
"void drawAt(DrawSurface d, Rectangle rect);",
"public void draw() {\n StdDraw.setPenColor(StdDraw.BLACK);\n StdDraw.setPenRadius(.01);\n for (Point2D p : s) {\n p.draw();\n }\n }",
"@Override\n public void draw(){\n ellipse(mouseX, mouseY, 50, 50);\n }",
"private void drawDataPoint(Graphics g, int radius, int x, int y)\r\n/* 123: */ {\r\n/* 124: 99 */ g.fillOval(x - radius, y - radius, 2 * radius, 2 * radius);\r\n/* 125: */ }",
"public GLGraphics drawPoint(float x, float y) {\n\t\tif (isInvalid(x) || isInvalid(y))\n\t\t\treturn this;\n\t\tgl.glBegin(GL.GL_POINTS);\n\t\tgl.glVertex3f(x, y, z);\n\t\tgl.glEnd();\n\t\treturn this;\n\t}",
"public void strength1(float x, float y){\n noStroke();\n fill(80);\n rect(x+7,y,66,6);\n bezier(x+7,y,x,y+1,x,y+5,x+7,y+6);\n bezier(x+73,y,x+80,y+1,x+80,y+5,x+73,y+6);\n rect(x+7,y+1,13,3);//1st blue ba\n bezier(x+7,y+1,x+1,y+2.5f,x+1,y+3.5f,x+7,y+4);\n}",
"@Override\n\tpublic void draw(Graphics g) {\n\t\tg.setColor(Color.PINK);\n\t\tg.fillRect(getx(), gety(), getwidth(), getheight());\n\t}",
"@Override\r\n\tpublic void display(GLAutoDrawable drawable) {\r\n\t\tGL2 gl = drawable.getGL().getGL2();\r\n\t\tgl.glClear(GL2.GL_COLOR_BUFFER_BIT);\r\n\r\n\t\t//points should be in the same zone\r\n\t\tDrawMPL(gl,0,0,30,25);\r\n\t\tDrawMPL(gl,0,0,-100,0);\r\n\t\tDrawMPL(gl,0,0,0,-100);\r\n\t\tDrawMPL(gl,-70,25,30,25);\r\n\t\tDrawMPL(gl,-70,25,-100,0);\r\n\t\tDrawMPL(gl,-70,25,-70,-75);\r\n\t\tDrawMPL(gl,-100,-100,-100,0);\r\n\t\tDrawMPL(gl,-100,-100,0,-100);\r\n\t\tDrawMPL(gl,-100,-100,-70,-75);\r\n\t\tDrawMPL(gl,-70,-75,30,-75);\r\n\t\tDrawMPL(gl,0,-100,30,-75);\r\n\t\tDrawMPL(gl,30,-75,30,25);\r\n\t}",
"public void draw(Graphics g) {\n int x = super.getX();\n int y = super.getY();\n int d = (int)radius*2; //d = diameter\n g.setColor(Color.BLACK);\n g.drawOval(265/2,235,265,265);\n g.drawLine(265, 115, 265, 500);\n\n int [ ] x2 = {27, 500, 265}; //lets work on that line?\n int [ ] y2 = {500, 500, 115};\n g.setColor(Color.black);\n g.drawPolygon(x2, y2, 3);\n\n }",
"private void drawCircle(GraphicsContext gc, double x, double y) {\r\n GraphicsContext gc1 = myCanvas.getGraphicsContext2D();\r\n gc1.setFill(randomColor());\r\n gc1.fillOval(x - 20, y - 20, 40, 40);\r\n }",
"public void star(float x, float y, float r, float R) {\n float angle = TWO_PI / 5;\n float halfAngle = angle/2.0f;\n beginShape();\n noStroke();\n for (float a = 0; a < TWO_PI; a += angle) {\n float sx = x + cos(a) * r;\n float sy = y + sin(a) * r;\n vertex(sx, sy);\n sx = x + cos(a+halfAngle) * R;\n sy = y + sin(a+halfAngle) * R;\n vertex(sx, sy);\n }\n endShape(CLOSE);\n}",
"private void paintPoint(int x, int y) {\n\t\traster.setDataElements(x, y, model.getDataElements(Color.BLACK.getRGB(), null));\t\t\n\t}",
"void draw();",
"@Override\n public void paintPedestrian(Graphics g) {\n\n g.setColor(Color.RED);\n g.fillOval(x, y, 10, 10);\n g.setColor(Color.BLACK);\n g.drawOval(x, y, 10, 10);\n }",
"public void drawLine(double x0, double y0, double x1, double y1, int red, int green, int blue){\n\t\tif( x0 > x1 ) {\n\t\t\tdouble xt = x0 ; x0 = x1 ; x1 = xt ;\n\t\t\tdouble yt = y0 ; y0 = y1 ; y1 = yt ;\n\t\t}\n\t\t\n\t\tdouble a = y1-y0;\n\t\tdouble b = -(x1-x0);\n\t\tdouble c = x1*y0 - x0*y1;\n\n\t\t\tif(y0<y1){ // Octant 1 or 2\n\t\t\t\tif( (y1-y0) <= (x1-x0) ) { //Octant 1\n\t\t\t\t\t\t\t\t\t\t\n\t\t\t\t\t// Calculate initial x and initial y\n\t\t\t\t\tint x = (int)Math.round(x0);\n\t\t\t\t\tint y = (int)Math.round((-a*x-c)/b);\n\t\t\t\t\t\n\t\t\t\t\tdouble d = a*(x+1) + b*(y+0.5) + c;\n\t\t\t\t\t\n\t\t\t\t\t// Do we need to go E or SE\n\t\t\t\t\twhile(x<=Math.round(x1)){\n\t\t\t\t\t\tRenderer.setPixel(x, y, red, green, blue);\n\t\t\t\t\t\tif(d<0){\n\t\t\t\t\t\t\td = d+a;\n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\td = d+a+b;\n\t\t\t\t\t\t\ty = y+1;\n\t\t\t\t\t\t}\n\t\t\t\t\t\tx = x+1;\n\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t} else { // Octant 2\n\t\t\t\t\t\t\t\t\t\t\n\t\t\t\t\t// Calculate initial x and initial y\n\t\t\t\t\tint y = (int)Math.round(y0);\n\t\t\t\t\tint x = (int)Math.round((-b*y-c)/a);\n\t\t\t\n\t\t\t\t\tdouble d = a*(x+0.5) + b*(y+1) + c;\n\t\t\t\t\t\n\t\t\t\t\t// Do we need to go SE or S\t\t\t\t\t\n\t\t\t\t\twhile(y<=Math.round(y1)){\n\t\t\t\t\t\tRenderer.setPixel(x, y, red, green, blue);\n\t\t\t\t\t\tif(d>0){\n\t\t\t\t\t\t\td = d+b; \n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\td = d+a+b;\n\t\t\t\t\t\t\tx = x+1;\n\t\t\t\t\t\t}\n\t\t\t\t\t\ty = y+1;\n\t\t\t\t\t}\t\t\t\t\t\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t\t\n\t\t\t} else { // Octant 7 or 8\n\t\t\t\tif( (y0-y1) <= (x1-x0) ) { // Octant 8\n\t\t\t\t\t\t\t\t\t\t\n\t\t\t\t\tint x = (int)Math.round(x0);\n\t\t\t\t\tint y = (int)Math.round((-a*x-c)/b);\t\t\t\t\t\n\t\t\t\t\t\n\t\t\t\t\tdouble d = a*(x+1) + b*(y-0.5) + c;\n\t\t\t\t\t\n\t\t\t\t\t// Do we need to go E or NE\t\t\t\t\t\n\t\t\t\t\twhile(x<=Math.round(x1)){\n\t\t\t\t\t\tRenderer.setPixel(x, y, red, green, blue);\n\t\t\t\t\t\tif(d>0){ \n\t\t\t\t\t\t\td = d+a;\n\t\t\t\t\t\t} else { \n\t\t\t\t\t\t\td = d+a-b;\n\t\t\t\t\t\t\ty = y-1;\n\t\t\t\t\t\t}\n\t\t\t\t\t\tx = x+1;\n\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t} else { //Octant 7\n\t\t\t\t\t\t\t\t\t\t\n\t\t\t\t\tint y = (int)Math.round(y0);\n\t\t\t\t\tint x = (int)Math.round((-b*y-c)/a);\n\t\t\t\t\t\n\t\t\t\t\tdouble d = a*(x+0.5) + b*(y-1) + c;\n\t\t\t\t\t\n\t\t\t\t\t// Do we need to go NE or N\n\t\t\t\t\twhile(y>=Math.round(y1)){\n\t\t\t\t\t\tRenderer.setPixel(x, y, red, green, blue);\n\t\t\t\t\t\tif(d<0){\n\t\t\t\t\t\t\td = d-b; \n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\td = d+a-b;\n\t\t\t\t\t\t\tx = x+1;\n\t\t\t\t\t\t}\n\t\t\t\t\t\ty = y-1;\n\t\t\t\t\t}\t\t\t\t\t\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\t\n\t\t}",
"public void draw();",
"public void draw();",
"public void draw();",
"@Override\n\tpublic void paint(Graphics2D g) {\n\t\tg.setColor(Color.WHITE);\n\t\tg.drawOval(this.x,this.y, width,height);\n\t\tg.fillOval(this.x,this.y, width,height);\n\t}",
"public void drawPellet(Graphics pane, int xLoc, int yLoc){\n\t\tpane.setColor(color);\n\t\tpane.fillOval(xLoc, yLoc, 20, 20);\n\t}",
"public abstract void drawFill();",
"public void zeichneQuadrate(){\n for (int i=0; i<10;i++)\n rect (50+i*25,50,25,25);\n }",
"public void draw(WorldLocation coord){\n \n }",
"@Override\n\tpublic void paintComponent(java.awt.Graphics g) {\n\t\tsuper.paintComponent(g);\n\t\tg.setColor(java.awt.Color.green);\n\t\tg.fillOval(x, y, 50, 50);\n\t\tg.setColor(java.awt.Color.black);\n\t\tg.drawOval(x, y, 50, 50);\n\t}",
"@Override\n\tpublic void draw(Graphics g) {\n\t\tg.setColor(Color.orange);\n\t\tg.fillRect(getX(), getY(), getW(), getH());\n\t}",
"public void draw(Graphics2D g, Dimension area);",
"public static void drawRectangle(int x, int y,int width, int height){\n for (int i = 0; i < y; i++) {\n System.out.println();\n }\n for (int i = 1; i < width; i++) {\n System.out.print(\"*\");\n }\n System.out.println(\"*\");\n for (int i = 0; i < height; i++) {\n System.out.print(\"*\");\n for (int j = 2; j < width; j++) {\n System.out.print(\" \");\n }\n System.out.println(\"*\");\n }\n for (int i = 0; i < width; i++) {\n System.out.print(\"*\");\n }\n\n }",
"private void paintTheImage() {\n SPainter bruhmoment = new SPainter(\"Kanizsa Square\" ,400,400);\n\n SCircle dot = new SCircle(75);\n paintBlueCircle(bruhmoment,dot);\n paintRedCircle(bruhmoment,dot);\n paintGreenCircles(bruhmoment,dot);\n\n SSquare square= new SSquare(200);\n paintWhiteSquare(bruhmoment,square);\n\n\n }",
"public Shape (int x, int y, Color color)\r\n {\r\n\tthis.x = x;\r\n\tthis.y = y;\r\n\tthis.color = color;\r\n }",
"public void drawSymmetricalPoints (int xc, int x, int yc, int y, Graphics g ){\r\n \tg.drawRect(xc + x, yc + y,1,1);\r\n \tg.drawRect(xc - x, yc + y,1,1);\r\n \tg.drawRect(xc + x, yc - y,1,1);\r\n \tg.drawRect(xc - x, yc - y,1,1);\r\n \tg.drawRect(xc + y, yc + x,1,1);\r\n \tg.drawRect(xc - y, yc + x,1,1);\r\n \tg.drawRect(xc + y, yc - x,1,1);\r\n \tg.drawRect(xc - y, yc - x,1,1);\r\n }",
"void displayFilledSquare(Button button, int row, int column, ChessPiece piece);",
"public void Draw(Graphics g)\n/* */ {\n/* 55 */ g.setColor(this.m_color);\n/* */ \n/* 57 */ Point prevPt = new Point(0, 0);Point currPt = new Point(0, 0);\n/* */ \n/* 59 */ for (double t = 0.0D; t < 1.01D; t += this.m_tValue) {\n/* 60 */ ptFromTVal(t, currPt);\n/* */ \n/* 62 */ if (t == 0.0D) {\n/* 63 */ prevPt.x = currPt.x;\n/* 64 */ prevPt.y = currPt.y;\n/* */ }\n/* */ \n/* 67 */ g.drawLine(prevPt.x, prevPt.y, currPt.x, currPt.y);\n/* */ \n/* 69 */ if (this.m_showTPoints) {\n/* 70 */ g.fillOval(currPt.x - this.PT_RADIUS, currPt.y - this.PT_RADIUS, this.PT_DIAMETER, this.PT_DIAMETER);\n/* */ }\n/* */ \n/* 73 */ prevPt.x = currPt.x;\n/* 74 */ prevPt.y = currPt.y;\n/* */ }\n/* */ }",
"public void draw(int x, int y, Graphics g) {\n\t\tg.setColor(Color.WHITE);\n\t\tg.fillRect(x*25, (y-1)*25, 25, 25);\n\t}",
"public void drawBox( Graphics window, Color i, int x, int y )\n\t{\n\t\twindow.setColor(i);\n\t\twindow.fillRect(x,y,100,100);\n\t\t// this code \"erases\" the center of the box by painting over it in white\n\t\twindow.setColor(Color.WHITE);\n\t\twindow.fillRect(x+10,y+10,80,80);\n\t}",
"@Override\n\tpublic void draw(Graphics g) {\n\t\tg.setColor(Color.ORANGE);\n\t\tg.fillRect(x, y, WIDTH, HEIGHT);\n\t}",
"@Override\n\tprotected void paintComponent(Graphics g) {\n\t\tsuper.paintComponent(g);\n\t\tint size, x, y;\n\t\tif (this.getHeight() < this.getWidth()) {\n\t\t\tsize = (int) (this.getHeight() / 1.5);\n\t\t} else {\n\t\t\tsize = (int) (this.getWidth() / 1.5);\n\t\t}\n\t\tx = (int) ((this.getWidth() / 2.0) - size / 2.0);\n\t\ty = (int) ((this.getHeight() / 2.0) - size / 2.0);\n\t\tint eyesize = (int) (size / 8.0);\n\t\tint eyex = (int) (x + size * 0.3 - eyesize / 2.0);\n\t\tint eyey = (int) (y + size * 0.4 - eyesize / 2.0);\n\t\tint eyex2 = (int) (x + size * 0.7 - eyesize / 2.0);\n\t\tint[] xpoints = {x, x + size, (int) (x + size / 2.0)};\n\t\tint[] ypoints = {(int) (y + size / 5.0), (int) (y + size / 5.0),\n\t\t\t\t(int) (y - size / 10.0)};\n\t\tPolygon hat = new Polygon(xpoints, ypoints, 3);\n\t\t\n\t\tif (zustand >0) {\n\t\t\tg.setColor(Color.GREEN);\n\t\t\tg.fillOval(x, y, size, size);\n\t\t\tg.setColor(Color.BLACK);\n\t\t\tg.fillOval(eyex, eyey, eyesize, eyesize);\n\t\t\tg.fillOval(eyex2, eyey, eyesize, eyesize);\n\t\t\tg.fillPolygon(hat);\n\t\t\tg.fillArc((int) (x + size / 5.0), (int) (y + size * 0.5),\n\t\t\t\t\t(int) (size * 0.6), (int) (size * 0.4), 0, -180);\n\t\t} else if (zustand == 0) {\n\t\t\tg.setColor(Color.YELLOW);\n\t\t\tg.fillOval(x, y, size, size);\n\t\t\tg.setColor(Color.BLACK);\n\t\t\tg.fillOval(eyex, eyey, eyesize, eyesize);\n\t\t\tg.fillOval(eyex2, eyey, eyesize, eyesize);\n\t\t\tg.fillPolygon(hat);\n\t\t\tg.fillRect(eyex, (int) (y + size * 0.75), eyex2 + eyesize - eyex,\n\t\t\t\t\t(int) (eyesize / 2.0));\n\t\t} else {\n\t\t\tg.setColor(Color.RED);\n\t\t\tg.fillOval(x, y, size, size);\n\t\t\tg.setColor(Color.BLACK);\n\t\t\tg.fillOval(eyex, eyey, eyesize, eyesize);\n\t\t\tg.fillOval(eyex2, eyey, eyesize, eyesize);\n\t\t\tg.fillPolygon(hat);\n\t\t\tg.fillArc((int) (x + size / 5.0), (int) (y + size * 0.6),\n\t\t\t\t\t(int) (size * 0.6), (int) (size * 0.4), 0, 180);\n\t\t}\n\t}",
"public Square(int x, int y, int side)\n\t{\n\t\tsuper();\n\t\toneside = side;\n\t\tanchor = new Point(x, y);\n\t\tvertices.add(new Point(x, y));\n\t\tvertices.add(new Point(x + side, y)); // upper right\n\t\tvertices.add(new Point(x + side, y + side)); // lower right\n\t\tvertices.add(new Point(x, y + side)); // lower left\n\t}",
"private void drawTopLeft1(Graphics g) {\r\n int pipX = 0;\r\n int pipY = 0;\r\n switch (state) {\r\n case 0:\r\n pipX = this.x + 4;\r\n pipY = this.y + 4;\r\n break;\r\n case 1:\r\n pipX = this.x - 12;\r\n pipY = this.y + 4;\r\n break;\r\n case 2:\r\n pipX = this.x - 12;\r\n pipY = this.y - 12;\r\n break;\r\n case 3:\r\n pipX = this.x + 4;\r\n pipY = this.y - 12;\r\n break;\r\n }\r\n g.fillOval(pipX, pipY, 8, 8);\r\n }",
"public abstract void drawEarthquake(PGraphics pg, float x, float y);",
"public abstract void drawEarthquake(PGraphics pg, float x, float y);",
"public void drawSquare(int x, int y, Color cellColor) {\n\t\tthis.theScreen.setColor(cellColor);\n\t\tthis.theScreen.fillRect(x, y, Preferences.CELL_SIZE,\n\t\t\t\tPreferences.CELL_SIZE);\n\t}",
"public void drawPoint(DrawPanelModel drawPanelModel);",
"void drawShape() {\n System.out.println(\"Drawing Triangle\");\n this.color.addColor();\n }",
"public static void showSquare(DrawingPanel panel, int i, boolean integrity) {\n //Graphics pen = panel.getGraphics();\n pen.fillRect(xTopLeft[i],yTopLeft[i],shapeSize[i],shapeSize[i]);\n if (integrity){// If the boolean parameter is true, it then changes the color to BLACK\n pen.setColor(Color.BLACK);\n }\n pen.drawRect(xTopLeft[i],yTopLeft[i],shapeSize[i],shapeSize[i]);//drawing the shape's border with the same xPos, yPos, size, and size.\n }",
"public void paint(Graphics g)\n {\n int X_x;\n int X_y;\n int Y_x;\n int Y_y;\n int Z_x;\n int Z_y;\n\n X_x = 0;\n X_y = 0;\n Y_x = 500;\n Y_y = 0;\n Z_x = 250;\n Z_y = 500;\n\n int currentX = X_x;\n int currentY = X_y;\n int targetX, targetY;\n int midwayX, midwayY;\n Random r = new Random();\n\n for(int i = 0; i < 10000; i++)\n {\n int random = r.nextInt(3);\n if(random == 0)\n {\n targetX = X_x;\n targetY = X_y;\n }\n else if(random == 1)\n {\n targetX = Y_x;\n targetY = Y_y;\n }\n else\n {\n targetX = Z_x;\n targetY = Z_y;\n }\n\n //halfway between\n currentX = (targetX + currentX) / 2;\n currentY = (targetY + currentY) / 2;\n g.drawLine(currentX, currentY, currentX, currentY);\n }\n }",
"public void draw(Graphics g){\n\n g.setColor(Color.red);\n g.drawLine(x1,y1,x2,y2);\n g.drawLine(x2,y2,x3,y3);\n g.drawLine(x3,y3,x1,y1);\n g.setFont(new Font(\"Courier\", Font.BOLD, 12));\n DecimalFormat fmt = new DecimalFormat(\"0.##\"); \n g.setColor(Color.blue);\n g.drawString(fmt.format(perimeter()) + \" \" + name,x1+2 , y1 -2);\n \n }",
"@Override\n\tpublic void draw(Graphics graphics) {\n\t\tgraphics.setColor(Color.black);\t\t\t\t\t\t\t\t\t//Farbe schwarz\n\t\tgraphics.drawRect(point.getX(),point.getY() , width, height);\t//malt ein leeren Rechteck\n\t}"
]
| [
"0.6841158",
"0.6481778",
"0.6406523",
"0.6390514",
"0.63790333",
"0.6376992",
"0.6376992",
"0.6376992",
"0.6376992",
"0.6258142",
"0.6244814",
"0.6230117",
"0.6098025",
"0.5990853",
"0.588803",
"0.588387",
"0.58698237",
"0.5863747",
"0.58463657",
"0.584251",
"0.5834106",
"0.5833126",
"0.5823982",
"0.5820618",
"0.58066016",
"0.58043987",
"0.5802045",
"0.5795786",
"0.57773674",
"0.5774586",
"0.5770914",
"0.57509243",
"0.57508934",
"0.57454264",
"0.5744615",
"0.57228196",
"0.57153285",
"0.5710947",
"0.5710618",
"0.5698433",
"0.56933165",
"0.5687689",
"0.5679551",
"0.56787837",
"0.56785923",
"0.56747866",
"0.5672678",
"0.56726646",
"0.56493497",
"0.5649124",
"0.564722",
"0.56442493",
"0.564239",
"0.5641036",
"0.5635639",
"0.5632059",
"0.56295717",
"0.5623928",
"0.5616596",
"0.561659",
"0.561624",
"0.5610762",
"0.56033707",
"0.55923194",
"0.55885905",
"0.5585029",
"0.5584723",
"0.5584015",
"0.55805457",
"0.55768454",
"0.55768454",
"0.55768454",
"0.5570898",
"0.5556149",
"0.5553382",
"0.5545983",
"0.55439794",
"0.5531811",
"0.55115944",
"0.55109376",
"0.5499937",
"0.5498361",
"0.5497763",
"0.5491859",
"0.54897594",
"0.5486171",
"0.5484603",
"0.548391",
"0.5477936",
"0.5471462",
"0.547118",
"0.5469487",
"0.546899",
"0.546899",
"0.54630274",
"0.54603463",
"0.54495394",
"0.54438543",
"0.5442681",
"0.54370683",
"0.54309523"
]
| 0.0 | -1 |
Create new PSMApplication object | @Override
public void onClick(View view) {
PSMApplication newApp = new PSMApplication();
newApp.setFullName(txtName.getText().toString());
newApp.setAddress(txtAddress.getText().toString());
newApp.setEmail(txtEmail.getText().toString());
newApp.setDocId(db.collection("PSMApplication").document().getId());// get id of new entry
// Record in the database
DocumentReference docRef = db.collection("PSMApplication").document(newApp.getDocId());
Task insert = docRef.set(newApp);
insert.addOnSuccessListener(o -> {
Log.d("TAG", "New PSM application added!");
// Show thank you message
txtThankYou.setVisibility(View.VISIBLE);
btnBack.setVisibility(View.VISIBLE);
btnApply.setEnabled(false);
txtName.setEnabled(false);
txtAddress.setEnabled(false);
txtEmail.setEnabled(false);
});
insert.addOnFailureListener(o->{
Log.e("TAG", "Failed to add new PSM application.");
Toast.makeText(ApplyPsmLicenseActivity.this, "An error occurred", Toast.LENGTH_SHORT).show();
finish();
});
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private NewApplication createNewApplication() {\n GetNewApplicationRequest req =\n recordFactory.newRecordInstance(GetNewApplicationRequest.class);\n GetNewApplicationResponse resp;\n try {\n resp = rm.getClientRMService().getNewApplication(req);\n } catch (YarnException e) {\n String msg = \"Unable to create new app from RM web service\";\n LOG.error(msg, e);\n throw new YarnRuntimeException(msg, e);\n }\n NewApplication appId =\n new NewApplication(resp.getApplicationId().toString(),\n new ResourceInfo(resp.getMaximumResourceCapability()));\n return appId;\n }",
"Appinfo createAppinfo();",
"public ApplicationCreator() {\n }",
"public Application create() {\n\t\tfinal Actor actorLogged = this.actorService.findActorLogged();\n\t\tAssert.notNull(actorLogged);\n\t\tthis.actorService.checkUserLoginMember(actorLogged);\n\n\t\tfinal Member memberLogged = (Member) actorLogged;\n\t\tAssert.isNull(memberLogged.getAssociation(), \"You already belong to an association\");\n\n\t\tApplication result;\n\n\t\tfinal Date moment = new Date(System.currentTimeMillis() - 1);\n\n\t\tresult = new Application();\n\t\tresult.setStatus(\"PENDING\");\n\t\tresult.setMoment(moment);\n\n\t\tresult.setMember(memberLogged);\n\n\t\treturn result;\n\t}",
"public MTApplication(){\r\n\t\tsuper();\r\n\t}",
"public App() {\n\t\tLog.d(\"App\", \"App created\");\n\t\tinstance = this;\n\t}",
"@Override // com.oculus.vrshell.panels.AndroidPanelApp\n public long createNativeInstance() {\n return nativeCreateInstance(0, 0);\n }",
"protected ApplicationMap createAppMapInstance (String mapname){\n\t\treturn new ApplicationMap(mapname);\t\t\n\t}",
"public Application()\r\n {\r\n pSlot = new ParkingSlot();\r\n cPark = new CarPark();\r\n }",
"public static void main ( String[] args ) {\n PhoneBook myApp = new PhoneBook(); \r\n }",
"public static Application getInstance(){\n\t\treturn getInstance (null);\n\t}",
"public static UILApplication getInstance() {\n\t\treturn instance;\n\t}",
"@Override\n public Handle<GameAppContext> createGameApp(String name, Handle<GameAppContext> parent, Map<String, String> additionalParams) \n {\n return manager.createGameApp(name, parent, additionalParams);\n }",
"CdapApplication createCdapApplication();",
"Manifest createManifest();",
"public PSFUDApplication()\n {\n loadSnapshot();\n }",
"public LocalAppLauncher() {\n }",
"ExpProtocolApplication createSimpleRunExtraProtocolApplication(ExpRun expRun, String name);",
"void launchApp();",
"public static IiTunes createiTunesApp() {\r\n return COM4J.createInstance( IiTunes.class, \"{DC0C2640-1415-4644-875C-6F4D769839BA}\" );\r\n }",
"public CMObject newInstance();",
"public AppInfo() {\n }",
"private final static Application getInstance(String[] args){\n\t\tif (instance == null){\n\t\t\t//istanziazione lazy\n\t\t\tinstance = new Application(args);\n\t\t\t\n\t\t\t//istanzia la finestra principale dell'interfaccia\n\t\t\tinstance.mainForm = new MainForm(instance);\n\t\t\t\n\t\t\t//registra la finestra principale su Application per le notoifiche\n\t\t\tinstance.addObserver (instance.mainForm);\n\t\t\t\n\t\t\t//prepara il timer per la notifica del progressing dell'avanzamento\n\t\t\tActionListener timerActionPerformer = new ActionListener (){\n\t\t\t\t/**\n\t\t\t\t * Gestisce evento timer.\n\t\t\t\t */\n\t\t\t\tpublic void actionPerformed (ActionEvent ae){\n\t\t\t\t\tinstance.setChanged ();\n\t\t\t\t\t//notifica l'avanzamento\n\t\t\t\t\tinstance.notifyObservers (ObserverCodes.CURRENT_PROGRESS_TIC);\n\t\t\t\t}\n\t\t\t};\n\t\t\tinstance.timer = new javax.swing.Timer (1000, timerActionPerformer);\n\t\t\tinstance.timer.stop();\n\t\t}\n\t\treturn instance; \n\t}",
"public DefaultApplication() {\n\t}",
"public static org.oep.ssomgt.model.Application createApplication(\n\t\tlong applicationId) {\n\t\treturn getService().createApplication(applicationId);\n\t}",
"public static MIDLetParamsApp getApplication() {\n return Application.getInstance(MIDLetParamsApp.class);\n }",
"public void setApp(Main application) { this.application = application;}",
"private App parseApp(JSONObject jsonObjet) {\n App yourApp = new App();\n addData(yourApp, jsonObjet);\n return yourApp;\n }",
"protected void buildAppWindow(PApplet p) {\n\t\tP.renderer = Config.getString(AppSettings.RENDERER, P.P3D);\n\t\tif(P.isOpenGL()) PJOGL.profile = Config.getInt(AppSettings.PJOGL_PROFILE, 4);\n\t\tif(Config.getBoolean(AppSettings.SPAN_SCREENS, false) == true) {\n\t\t\t// run fullscreen across all screens\n\t\t\tp.fullScreen(P.renderer, P.SPAN);\n\t\t} else if(Config.getBoolean(AppSettings.FULLSCREEN, false) == true) {\n\t\t\t// run fullscreen - default to screen #1 unless another is specified\n\t\t\tif(Config.getInt(AppSettings.FULLSCREEN_SCREEN_NUMBER, 1) != 1) P.error(\"AppSettings.FULLSCREEN_SCREEN_NUMBER is busted if not screen #1. Use AppSettings.SCREEN_X, etc.\");\n\t\t\tp.fullScreen(P.renderer); // , Config.getInt(AppSettings.FULLSCREEN_SCREEN_NUMBER, 1)\n\t\t} else if(Config.getBoolean(AppSettings.FILLS_SCREEN, false) == true) {\n\t\t\t// fills the screen, but not fullscreen\n\t\t\tp.size(p.displayWidth, p.displayHeight, P.renderer);\n\t\t} else {\n\t\t\tif(P.renderer == PRenderers.PDF) {\n\t\t\t\t// set headless pdf output file\n\t\t\t\tp.size(Config.getInt(AppSettings.WIDTH, 800),Config.getInt(AppSettings.HEIGHT, 600), P.renderer, Config.getString(AppSettings.PDF_RENDERER_OUTPUT_FILE, \"output/output.pdf\"));\n\t\t\t} else {\n\t\t\t\t// run normal P3D renderer\n\t\t\t\tp.size(Config.getInt(AppSettings.WIDTH, 800),Config.getInt(AppSettings.HEIGHT, 600), P.renderer);\n\t\t\t}\n\t\t}\n\t\t\n\t\t// SMOOTHING\n\t\tif(Config.getInt(AppSettings.SMOOTHING, AppSettings.SMOOTH_HIGH) == 0) {\n\t\t\tp.noSmooth();\n\t\t} else {\n\t\t\tp.smooth(Config.getInt(AppSettings.SMOOTHING, AppSettings.SMOOTH_HIGH));\t\n\t\t}\n\t\t\n\t\t// SET APP ICON\n\t\tString appIconFile = Config.getString(AppSettings.APP_ICON, \"haxademic/images/haxademic-logo.png\");\n\t\tString iconPath = FileUtil.getPath(appIconFile);\n\t\tif(FileUtil.fileExists(iconPath)) {\n\t\t\tPJOGL.setIcon(iconPath);\n\t\t}\n\t\t\n\t\t// DO WE DARE TRY THE RETINA SETTING?\n\t\tif(Config.getBoolean(AppSettings.RETINA, false) == true) {\n\t\t\tif(p.displayDensity() == 2) {\n\t\t\t\tp.pixelDensity(2);\n\t\t\t} else {\n\t\t\t\tP.error(\"Error: Attempting to set retina drawing on a non-retina screen\");\n\t\t\t}\n\t\t}\t\n\t}",
"Application getApplication();",
"@Override\n @SuppressWarnings(\"checkstyle:linelength\")\n public Application create(final TwilioRestClient client) {\n this.pathAccountSid = this.pathAccountSid == null ? client.getAccountSid() : this.pathAccountSid;\n Request request = new Request(\n HttpMethod.POST,\n Domains.API.toString(),\n \"/2010-04-01/Accounts/\" + this.pathAccountSid + \"/Applications.json\"\n );\n\n addPostParams(request);\n Response response = client.request(request);\n\n if (response == null) {\n throw new ApiConnectionException(\"Application creation failed: Unable to connect to server\");\n } else if (!TwilioRestClient.SUCCESS.test(response.getStatusCode())) {\n RestException restException = RestException.fromJson(response.getStream(), client.getObjectMapper());\n if (restException == null) {\n throw new ApiException(\"Server Error, no content\");\n }\n throw new ApiException(restException);\n }\n\n return Application.fromJson(response.getStream(), client.getObjectMapper());\n }",
"Program createProgram();",
"Program createProgram();",
"Program createProgram();",
"CdapCreateAppWithConfigStep createCdapCreateAppWithConfigStep();",
"public BazaarApplicationImpl() {\r\n\t\tsuper();\r\n\r\n\t}",
"public static Application getApp() {\n if (sApplication != null) return sApplication;\n throw new NullPointerException(\"u should init first\");\n }",
"private final void createAppPages() {\r\n\t\t//Instantiate Page objects that have no associated test properties\r\n\t\t//Note that if a test DOES need to specify test properties for one of these pages\r\n\t\t// (e.g., search terms), it can create its own local version of the page, and pass\r\n\t\t// the pagePropertiesFilenameKey argument, OR create it here, by calling createPage\r\n\t\t// instead of createStaticPage\r\n\r\n\t\t//Can also instantiate regular (i.e., with associated test properties) DD-specific\r\n\t\t// Page objects here, but typically it is best for the test or utility methods to do that;\r\n\t\t// if we do it here we may end up creating Page objects that never get used.\r\n }",
"public ParkingApp() {\n runApp();\n }",
"public BasicAppInfo() {\n super();\n }",
"public void setApp(PR1 application){\n this.application = application;\n }",
"protected void NewApp(String name, String code, String file, String web,\n String dir) {\n String webRoot = UIHelper.getStoragePath(AppManagerActivity.this);\n webRoot = webRoot + constants.SD_CARD_TBSSOFT_PATH3 + \"/\";\n File newfile = new File(webRoot + dir + \"/\" + file);\n/*\t\tFile newfile2 = new File(webRoot + dir + \"/\"\n + constants.WEB_CONFIG_FILE_NAME);*/\n try {\n newfile.createNewFile();\n } catch (IOException e) {\n // TODO Auto-generated catch block\n e.printStackTrace();\n }\n\n\n this.IniFile.writeIniString(webRoot + dir + \"/\" + file, \"TBSAPP\",\n \"defaultUrl\", web);\n this.IniFile.writeIniString(webRoot + dir + \"/\" + file, \"TBSAPP\", \"AppCode\",\n code);\n this.IniFile.writeIniString(webRoot + dir + \"/\" + file, \"TBSAPP\", \"AppName\",\n name);\n this.IniFile.writeIniString(webRoot + dir + \"/\" + file, \"TBSAPP\", \"AppVersion\",\n \"1.0\");\n AppManagerActivity.myThread handThread = new AppManagerActivity.myThread(dir, file);\n handThread.run();\n }",
"private static void initForProd() {\r\n try {\r\n appTokenManager = new AppTokenManager();\r\n app = new CerberusApp(301L, \"3dd25f8ef8429ffe\",\r\n \"526fbde088cc285a957f8c2b26f4ca404a93a3fb29e0dc9f6189de8f87e63151\");\r\n appTokenManager.addApp(app);\r\n appTokenManager.start();\r\n } catch (Exception e) {\r\n e.printStackTrace();\r\n }\r\n }",
"public static App getInstance() {\n return applicationInstance;\n }",
"public static AppTest create(Config config) {return null;}",
"public RubyObject createObject() {\n\t\treturn (RubyObject) RGSSProjectHelper.getInterpreter(project).runScriptlet(\"return RPG::Troop::Page.new\");\n\t}",
"public static Application getApp() {\n if (sApplication != null) {\n return sApplication;\n }\n Application app = getApplicationByReflect();\n init(app);\n return app;\n }",
"public CreateApplicationResponse createApplication(String name, CryptoProviderUtil keyConversionUtilities) {\n\n ApplicationEntity application = new ApplicationEntity();\n application.setName(name);\n application = applicationRepository.save(application);\n\n KeyGenerator keyGen = new KeyGenerator();\n KeyPair kp = keyGen.generateKeyPair();\n PrivateKey privateKey = kp.getPrivate();\n PublicKey publicKey = kp.getPublic();\n\n // Generate the default master key pair\n MasterKeyPairEntity keyPair = new MasterKeyPairEntity();\n keyPair.setApplication(application);\n keyPair.setMasterKeyPrivateBase64(BaseEncoding.base64().encode(keyConversionUtilities.convertPrivateKeyToBytes(privateKey)));\n keyPair.setMasterKeyPublicBase64(BaseEncoding.base64().encode(keyConversionUtilities.convertPublicKeyToBytes(publicKey)));\n keyPair.setTimestampCreated(new Date());\n keyPair.setName(name + \" Default Keypair\");\n masterKeyPairRepository.save(keyPair);\n\n // Create the default application version\n byte[] applicationKeyBytes = keyGen.generateRandomBytes(16);\n byte[] applicationSecretBytes = keyGen.generateRandomBytes(16);\n ApplicationVersionEntity version = new ApplicationVersionEntity();\n version.setApplication(application);\n version.setName(\"default\");\n version.setSupported(true);\n version.setApplicationKey(BaseEncoding.base64().encode(applicationKeyBytes));\n version.setApplicationSecret(BaseEncoding.base64().encode(applicationSecretBytes));\n applicationVersionRepository.save(version);\n\n CreateApplicationResponse response = new CreateApplicationResponse();\n response.setApplicationId(application.getId());\n response.setApplicationName(application.getName());\n\n return response;\n }",
"protected WebApplication newApplication() {\n return new DummyWebApplication();\n }",
"public StockApp()\n {\n reader = new InputReader();\n manager = new StockManager();\n menuSetup();\n }",
"public Application(String name, String dob, String gender, String income, String apt, String moveDate, String term, String approval, String username)\n {\n this.name = new SimpleStringProperty(name);\n this.dob = new SimpleStringProperty(dob);\n this.gender = new SimpleStringProperty(gender);\n this.income = new SimpleStringProperty(income);\n this.apt = new SimpleStringProperty(apt);\n this.moveDate = new SimpleStringProperty(moveDate);\n this.term = new SimpleStringProperty(term);\n this.approval = new SimpleStringProperty(approval);\n this.username = new SimpleStringProperty(username);\n }",
"private appR getApp() throws JAXBException, IOException {\n synchronized (application) {\r\n appR App = (appR) application.getAttribute(\"App\");\r\n if (App == null) {\r\n App = new appR();\r\n App.setFilePath(application.getRealPath(\"WEB-INF/Listings.xml\"));\r\n application.setAttribute(\"App\", App);\r\n }\r\n return App;\r\n }\r\n }",
"public static BlaiseGraphicsTestApp getApplication() {\n return Application.getInstance(BlaiseGraphicsTestApp.class);\n }",
"public Application() {\n\t\tinitComponents();\n\t\tthis.service = new PacienteService();\n\t\tthis.AtualizarTabelaPacientes();\n\t\tthis.sexo = this.rd_nao_informado.getText();\n\t\tthis.cb_estados.setSelectedIndex(24);\n\t}",
"private void newApplication() throws Exception{\n\t\t\n\t\tPrintWriter writer = new PrintWriter(new BufferedWriter(new FileWriter(this.appfile)));\n\t\tint counter = 0;\n\t\t\n\t\twriter.println(\"Scholarship\");\n\t\twriter.println(this.scholarship);\n\t\twriter.println();\n\t\twriter.println(\"Student\");\n\t\twriter.println(this.student);\n\t\twriter.println();\n\t\twriter.println(\"GPA\");\n\t\twriter.println(this.gpa);\n\t\twriter.println();\n\t\twriter.println(\"Education Level\");\n\t\twriter.println(this.edulvl);\n\t\twriter.println();\n\t\twriter.println(\"Date\");\n\t\twriter.println(this.date);\n\t\twriter.println();\n\t\twriter.println(\"Status\");\n\t\twriter.println(this.status);\n\t\twriter.println();\n\t\twriter.println(\"Priority\");\n\t\twriter.println(this.priority);\n\t\twriter.println();\n\n\t\twriter.close();\n\t\t\n\t}",
"public SNVAppModuleImpl() {\n }",
"CdapCreateAppStep createCdapCreateAppStep();",
"public ApplicationProcess(Map<String, String> progArgs, Map<String,String> sysProps) throws Exception {\n\t\tthis.progArgs = progArgs;\n\t\tthis.sysProps = sysProps;\n\t}",
"public ApplicationDescription() {}",
"private static PDP getPDPNewInstance(){\n\n PDPConfig pdpConfig = balana.getPdpConfig();\n return new PDP(pdpConfig);\n }",
"Instance createInstance();",
"public AppCall createBaseAppCall() {\r\n return new AppCall(getRequestCode());\r\n }",
"public MediaWSDemoApplication(BundleContext context) {\n\t\ttheContext = context ;\n\t}",
"Project createProject();",
"Project createProject();",
"Project createProject();",
"public JawaBotApp_Poh() {\n JawaBotApp_Poh.instance = this; // TODO: make private, use getInstance only.\n //Thread.dumpStack(); /// Where is this constructor called?\n }",
"public TAppAccess() {\n\t}",
"public RecruitingAppManagementImpl() {\n }",
"public void startApp()\r\n\t{\n\t}",
"@SuppressWarnings(\"unused\")\n private CreateOrUpdateApplicationResult() {\n }",
"public IMApplicationInfo getIMApplicationInfo(com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.imapplicationinfo.v1.IMApplicationInfo res){\n\t\tIMApplicationInfo iMApplicationInfo = new IMApplicationInfo();\n\t\t\n\t\tiMApplicationInfo.setRequestorID( res.getRequestorID() );\n\t\tiMApplicationInfo.setContextID( res.getContextID() );\n\t\tiMApplicationInfo.setCreatedBy( res.getCreatedBy() );\n\t\tiMApplicationInfo.setAgentNumber( res.getAgentNumber() );\n\t\tiMApplicationInfo.setPseudoCityCode( res.getPseudoCityCode() );\n\t\tiMApplicationInfo.setIsoCountry( res.getIsoCountry() );\n\t\tiMApplicationInfo.setIsoCurrency( res.getIsoCurrency() );\n\t\tiMApplicationInfo.setSalesOrg( res.getSalesOrg() );\n\t\tiMApplicationInfo.setAgentFirstName( res.getAgentFirstName() );\n\t\tiMApplicationInfo.setAgentLastName( res.getAgentLastName() );\n\t\t\n\t\tif( (res.getType() != null) && (res.getType().getCode() != null) ){\n\t\t\tiMApplicationInfo.setType( this.getUserType( res.getType() ) );\n\t\t}\n\t\tif( res.getSelectedAgent() != null ){\n\t\t\tiMApplicationInfo.setSelectedAgent( this.getAgent( res.getSelectedAgent() ) );\n\t\t}\n\t\t\n\t\treturn iMApplicationInfo;\n\t}",
"public Arguments create() throws IOException {\r\n Arguments args = new Arguments();\r\n ArrayList vmArgs = new ArrayList();\r\n \r\n // Start empty framework\r\n if (clean) {\r\n // Remove bundle directories\r\n File[] children = workDir.listFiles();\r\n for (int i=0; i<children.length; i++) {\r\n if (children[i].isDirectory() && children[i].getName().startsWith(\"bundle\")) {\r\n deleteDir(children[i]);\r\n }\r\n }\r\n }\r\n \r\n // Create system properties file\r\n File systemPropertiesFile = new File(workDir, \"system.properties\");\r\n Path path = new Path(systemPropertiesFile.getAbsolutePath());\r\n vmArgs.add(\"-Doscar.system.properties=\"+path.toString());\r\n \r\n // Set bundle cache dir\r\n writeProperty(systemPropertiesFile, PROPERTY_CACHE_DIR, new Path(workDir.getAbsolutePath()).toString(), false);\r\n \r\n // Set start level\r\n writeProperty(systemPropertiesFile, PROPERTY_STARTLEVEL, Integer.toString(startLevel), true);\r\n \r\n // System properties\r\n if (systemProperties != null) {\r\n for(Iterator i=systemProperties.entrySet().iterator();i.hasNext();) {\r\n Map.Entry entry = (Map.Entry) i.next();\r\n writeProperty(systemPropertiesFile, (String) entry.getKey(), (String) entry.getValue(), true);\r\n }\r\n }\r\n\r\n // Add bundle\r\n StringBuffer autoStart = new StringBuffer(\"\");\r\n StringBuffer autoInstall = new StringBuffer(\"\");\r\n for (Iterator i=bundles.entrySet().iterator();i.hasNext();) {\r\n Map.Entry entry = (Map.Entry) i.next();\r\n Integer level = (Integer) entry.getKey();\r\n \r\n // Add bundle install entries for this start level\r\n ArrayList l = (ArrayList) entry.getValue();\r\n autoStart.setLength(0);\r\n autoInstall.setLength(0);\r\n for (Iterator j = l.iterator() ; j.hasNext() ;) {\r\n BundleElement e = (BundleElement) j.next();\r\n if (e.getLaunchInfo().getMode() == BundleLaunchInfo.MODE_START) {\r\n if (autoStart.length()>0) {\r\n autoStart.append(\" \");\r\n }\r\n autoStart.append(\"file:\");\r\n autoStart.append(new Path(e.getBundle().getPath()).toString());\r\n } else {\r\n if (autoInstall.length()>0) {\r\n autoInstall.append(\" \");\r\n }\r\n autoInstall.append(\"file:\");\r\n autoInstall.append(new Path(e.getBundle().getPath()).toString());\r\n }\r\n }\r\n if (autoInstall.length()>0) {\r\n writeProperty(systemPropertiesFile, PROPERTY_AUTO_INSTALL+level, autoInstall.toString(), true);\r\n }\r\n if (autoStart.length()>0) {\r\n writeProperty(systemPropertiesFile, PROPERTY_AUTO_START+level, autoStart.toString(), true);\r\n }\r\n }\r\n \r\n args.setVMArguments((String[]) vmArgs.toArray(new String[vmArgs.size()]));\r\n return args;\r\n }",
"public ProjectModule() {\n packaging = AutomationConstant.PACKAGING_POM;\n }",
"public void init(Map<String, String> pParams, Application pApp) throws Exception;",
"public App create(App obj) {\n \n JsonNode node = getClient().post(Routes.APP_CREATE, toJsonNode(obj));\n App rapp = getMapper().convertValue(node, App.class);\n \n if (!node.has(\"id\")) {\n throw new ClientException(\"Missing ID on object creation\");\n }\n \n obj.merge(rapp);\n obj.setId(rapp.getId());\n\n return obj;\n }",
"public AuctionApp() {\r\n runAuctionApp();\r\n }",
"protected WebApplication createApplication(final String applicationClassName)\n\t{\n\t\ttry\n\t\t{\n\t\t\tClassLoader loader = Thread.currentThread().getContextClassLoader();\n\t\t\tif (loader == null)\n\t\t\t{\n\t\t\t\tloader = getClass().getClassLoader();\n\t\t\t}\n\n\t\t\t// see http://bugs.sun.com/bugdatabase/view_bug.do?bug_id=6500212\n\t\t\t// final Class<?> applicationClass = loader.loadClass(applicationClassName);\n\t\t\tfinal Class<?> applicationClass = Class.forName(applicationClassName, false, loader);\n\t\t\tif (WebApplication.class.isAssignableFrom(applicationClass))\n\t\t\t{\n\t\t\t\t// Construct WebApplication subclass\n\t\t\t\treturn (WebApplication)applicationClass.getDeclaredConstructor().newInstance();\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\tthrow new WicketRuntimeException(\"Application class \" + applicationClassName +\n\t\t\t\t\t\" must be a subclass of WebApplication\");\n\t\t\t}\n\t\t}\n\t\tcatch (ClassNotFoundException | InstantiationException | IllegalAccessException | SecurityException\n\t\t\t\t| NoSuchMethodException | InvocationTargetException e)\n\t\t{\n\t\t\tthrow new WicketRuntimeException(\"Unable to create application of class \" +\n\t\t\t\tapplicationClassName, e);\n\t\t}\n\t}",
"public CH340Application() {\n sContext = this;\n }",
"private AppointmentItem createBasicAppt() throws HarnessException{\n\t\tAppointmentItem appt = new AppointmentItem();\n\t\tappt.setSubject(\"appointment\" + ZimbraSeleniumProperties.getUniqueString());\n\t\tappt.setContent(\"content\" + ZimbraSeleniumProperties.getUniqueString());\n\t\n\n\t\t// Open the new mail form\n\t\tFormApptNew apptForm = (FormApptNew) app.zPageCalendar.zToolbarPressButton(Button.B_NEW);\n\t\tZAssert.assertNotNull(apptForm, \"Verify the new form opened\");\n\n\t\t// Fill out the form with the data\n\t\tapptForm.zFill(appt);\n\n\t\t// Send the message\n\t\tapptForm.zSubmit();\n\t\n\t\treturn appt;\n\t}",
"public CsclAppointeeMaster create(long id_);",
"@Override\n\tpublic ScienceAppExecute create(ScienceAppExecutePK scienceAppExecutePK) {\n\t\tScienceAppExecute scienceAppExecute = new ScienceAppExecuteImpl();\n\n\t\tscienceAppExecute.setNew(true);\n\t\tscienceAppExecute.setPrimaryKey(scienceAppExecutePK);\n\n\t\treturn scienceAppExecute;\n\t}",
"void setDefaultApp(String id);",
"public void startApp() {\n if (midletPaused) {\n resumeMIDlet ();\n } else {\n initialize ();\n startMIDlet ();\n }\n midletPaused = false;\n }",
"public void startApp() {\n if (midletPaused) {\n resumeMIDlet ();\n } else {\n initialize ();\n startMIDlet ();\n }\n midletPaused = false;\n }",
"public void startApp() {\n if (midletPaused) {\n resumeMIDlet();\n } else {\n initialize();\n startMIDlet();\n }\n midletPaused = false;\n }",
"@Override\r\n\tpublic ItemInstance createItemInstance() {\n\t\treturn new HpInstance();\r\n\t}",
"RestApplicationModel createRestApplicationModel();",
"@Override\n public OAuthApplicationInfo createApplication(OAuthAppRequest oauthAppRequest) throws APIManagementException {\n OAuthApplicationInfo oAuthApplicationInfo = oauthAppRequest.getOAuthApplicationInfo();\n\n // Subscriber's name should be passed as a parameter, since it's under the subscriber the OAuth App is created.\n String userId = (String) oAuthApplicationInfo.getParameter(ApplicationConstants.\n OAUTH_CLIENT_USERNAME);\n String applicationName = oAuthApplicationInfo.getClientName();\n String keyType = (String) oAuthApplicationInfo.getParameter(ApplicationConstants.APP_KEY_TYPE);\n String callBackURL = (String) oAuthApplicationInfo.getParameter(ApplicationConstants.APP_CALLBACK_URL);\n if (keyType != null) {\n applicationName = applicationName + '_' + keyType;\n }\n\n if (log.isDebugEnabled()) {\n log.debug(\"Trying to create OAuth application :\" + applicationName);\n }\n\n String tokenScope = (String) oAuthApplicationInfo.getParameter(\"tokenScope\");\n String[] tokenScopes = new String[1];\n tokenScopes[0] = tokenScope;\n\n org.wso2.carbon.apimgt.api.model.xsd.OAuthApplicationInfo info = null;\n\n try {\n org.wso2.carbon.apimgt.api.model.xsd.OAuthApplicationInfo applicationToCreate =\n new org.wso2.carbon.apimgt.api.model.xsd.OAuthApplicationInfo();\n applicationToCreate.setIsSaasApplication(oAuthApplicationInfo.getIsSaasApplication());\n applicationToCreate.setCallBackURL(callBackURL);\n applicationToCreate.setClientName(applicationName);\n applicationToCreate.setAppOwner(userId);\n applicationToCreate.setJsonString(oAuthApplicationInfo.getJsonString());\n applicationToCreate.setTokenType(oAuthApplicationInfo.getTokenType());\n info = createOAuthApplicationbyApplicationInfo(applicationToCreate);\n } catch (Exception e) {\n handleException(\"Can not create OAuth application : \" + applicationName, e);\n } \n\n if (info == null || info.getJsonString() == null) {\n handleException(\"OAuth app does not contains required data : \" + applicationName,\n new APIManagementException(\"OAuth app does not contains required data\"));\n }\n\n oAuthApplicationInfo.addParameter(\"tokenScope\", tokenScopes);\n oAuthApplicationInfo.setClientName(info.getClientName());\n oAuthApplicationInfo.setClientId(info.getClientId());\n oAuthApplicationInfo.setCallBackURL(info.getCallBackURL());\n oAuthApplicationInfo.setClientSecret(info.getClientSecret());\n oAuthApplicationInfo.setIsSaasApplication(info.getIsSaasApplication());\n\n try {\n JSONObject jsonObject = new JSONObject(info.getJsonString());\n\n if (jsonObject.has(ApplicationConstants.\n OAUTH_REDIRECT_URIS)) {\n oAuthApplicationInfo.addParameter(ApplicationConstants.\n OAUTH_REDIRECT_URIS, jsonObject.get(ApplicationConstants.OAUTH_REDIRECT_URIS));\n }\n\n if (jsonObject.has(ApplicationConstants.OAUTH_CLIENT_NAME)) {\n oAuthApplicationInfo.addParameter(ApplicationConstants.\n OAUTH_CLIENT_NAME, jsonObject.get(ApplicationConstants.OAUTH_CLIENT_NAME));\n }\n\n if (jsonObject.has(ApplicationConstants.OAUTH_CLIENT_GRANT)) {\n oAuthApplicationInfo.addParameter(ApplicationConstants.\n OAUTH_CLIENT_GRANT, jsonObject.get(ApplicationConstants.OAUTH_CLIENT_GRANT));\n }\n } catch (JSONException e) {\n handleException(\"Can not retrieve information of the created OAuth application\", e);\n }\n\n return oAuthApplicationInfo;\n\n }",
"public static ApplicationBase getApplication()\r\n {\r\n if (instance == null)\r\n {\r\n throw new IllegalStateException(\"Micgwaf was not (yet) initialized correctly: no instance of Application is known.\");\r\n }\r\n return instance;\r\n }",
"SAProcessInstanceBuilder createNewInstance(SProcessInstance processInstance);",
"public SimpleWorkspaceApplication (String[] args) {\n super (args, false);\n Frame f;\n commandHandler = new ApplicationCommandHandler ();\n MenuBar mb = setupMenu ();\n String title = getTitleInformation ();\n setCurrentFrame (f = new Frame (title != null ? title : \"Simple Workspace Application\"));\n f.setMenuBar (mb);\n String geometry = getGeometryInformation ();\n if (geometry == null)\n f.setBounds (0, 0, 600, 400);\n else {\n Rectangle desiredBounds = parseBounds (geometry);\n f.setBounds (desiredBounds.x, desiredBounds.y, desiredBounds.width, desiredBounds.height);\n }\n\n f.add (multiWkspView = new MultipleWorkspaceView (), BorderLayout.CENTER);\n f.addWindowListener(new WindowAdapter() {\n @Override\n public void windowClosing(WindowEvent e) {\n\tSystem.exit(0);\n }\n });\n }",
"@DISPID(1000) //= 0x3e8. The runtime will prefer the VTID if present\r\n @VTID(7)\r\n word._Application application();",
"@DISPID(1000) //= 0x3e8. The runtime will prefer the VTID if present\r\n @VTID(7)\r\n word._Application application();",
"public AppBean(Context context) {\n uid = SharedPreferencesUtils.getUid(context);\n device_id = DeviceUtils.getMobileIMEI(context);\n version = AppUtils.getAppVersion(context);\n device_name = DeviceUtils.getMobileModel();\n platform = context.getString(R.string.android);\n //osVersion = String.valueOf(DeviceUtils.getMobileSDK());\n //isRelease = AppUtils.isApkDebug(context) ? 0 : 1;\n //apiVersion = \"v2\";\n }",
"@DISPID(1610743808) //= 0x60020000. The runtime will prefer the VTID if present\r\n @VTID(7)\r\n @ReturnValue(type=NativeType.Dispatch)\r\n com4j.Com4jObject application();",
"@DISPID(3) //= 0x3. The runtime will prefer the VTID if present\r\n @VTID(7)\r\n visiotool.IVApplication application();",
"public static SPSConfig createSPSConfig() {\n return new SPSConfig();\n }",
"public static void main(String[] args) {\n // Create the system.\n Application.launch( args );\n }",
"public OSPApplication getOSPApp();",
"Prms createPrms();"
]
| [
"0.66394204",
"0.64292294",
"0.61971927",
"0.607761",
"0.6022351",
"0.5942246",
"0.5829075",
"0.5814762",
"0.580398",
"0.57874066",
"0.5728375",
"0.5712037",
"0.57110834",
"0.56979424",
"0.5682291",
"0.56330216",
"0.55946946",
"0.55943704",
"0.55760574",
"0.55613977",
"0.5552132",
"0.548078",
"0.5452123",
"0.5437609",
"0.5436055",
"0.543175",
"0.5404816",
"0.5399778",
"0.53996104",
"0.5387158",
"0.53594905",
"0.5356471",
"0.5356471",
"0.5356471",
"0.53130615",
"0.5312277",
"0.5296988",
"0.52906203",
"0.52786934",
"0.5276477",
"0.52567786",
"0.52550226",
"0.52533144",
"0.5239711",
"0.5230237",
"0.5228105",
"0.5209641",
"0.5206473",
"0.51662564",
"0.5157453",
"0.5155037",
"0.5153518",
"0.5150467",
"0.51485705",
"0.5142261",
"0.51324946",
"0.5128655",
"0.5112614",
"0.5105382",
"0.51009387",
"0.509902",
"0.50982684",
"0.50951535",
"0.50936115",
"0.50936115",
"0.50936115",
"0.50703716",
"0.50640947",
"0.50626004",
"0.5059786",
"0.504835",
"0.5046503",
"0.50404006",
"0.50340617",
"0.50325334",
"0.50237453",
"0.5023578",
"0.5018362",
"0.50161034",
"0.5013033",
"0.5010691",
"0.50019085",
"0.49949807",
"0.49932313",
"0.49932313",
"0.49827647",
"0.49821237",
"0.49787596",
"0.49769583",
"0.4974074",
"0.49685282",
"0.49654093",
"0.4957872",
"0.4957872",
"0.49515545",
"0.49332032",
"0.49323028",
"0.4931648",
"0.4925104",
"0.49026105",
"0.4900546"
]
| 0.0 | -1 |
setter for result page | public void updateScores(double attempt) {
if(previousScore == 0){
previousScore = currentScore;
}else{
beforePreviousScore = previousScore;
previousScore = currentScore;
}
this.currentScore = 100*(attempt
- (benchmark - (maximumMark - benchmark)/NUMBEROFLEVEL))
/(((maximumMark - benchmark)/NUMBEROFLEVEL)*2);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setResultsPage(int resultsPage)\r\n\t{\r\n\t\tthis.resultsPage = resultsPage;\r\n\t}",
"public void setPage(int value) {\n this.page = value;\n }",
"public void setResultsPerPage(int resultsPerPage)\r\n\t{\r\n\t\tthis.resultsPerPage = resultsPerPage;\r\n\t}",
"public void setPage(SQLInteger page) {\n\t\tthis.page = page;\n\t}",
"public void setResult() {\n }",
"public void setPage(Integer page) {\n this.page = page;\n }",
"public void setPage(int page) {\n this.page = page;\n }",
"public QueryResultBuilder<T> setPage(Option<Page> page);",
"public int getResultsPage()\r\n\t{\r\n\t\treturn this.resultsPage;\r\n\t}",
"public void setPage(Page page) {this.page = page;}",
"void setNumberOfResults(int numberOfResults);",
"protected void setPageInformation(PageableList<?> result,\r\n ResultSpecification resultSpecification) {\r\n int pagingInterval = getIntParameter(PARAM_PAGING_INTERVAL, 5);\r\n pageInformation = QueryParameters.getPageInformation(result, resultSpecification,\r\n pagingInterval);\r\n\r\n }",
"public void setReturnPage(String returnPage) {this.returnPage=returnPage;}",
"protected void setPageInformation(QueryParameters queryParameters,\r\n PageableList<? extends IdentifiableEntityData> result) {\r\n int pagingInterval = getIntParameter(PARAM_PAGING_INTERVAL, 5);\r\n pageInformation = queryParameters.getPageInformation(result, pagingInterval);\r\n }",
"void setFirstResult(int offset);",
"public void setPageInfo(){\n\t\tif(AllP>=1){\n\t\t\tPageInfo=\"<table border='0' cellpadding='3'><tr><td>\";\n\t\t\tPageInfo+=\"Show: \"+PerR+\"/\"+AllR+\" Records! \";\n\t\t\tPageInfo+=\"Current page: \"+CurrentP+\"/\"+AllP;\n\t\t\tPageInfo+=\"</td></tr></table>\";\t\t\t\n\t\t}\t\t\t\t\n\t}",
"void setPagination(Pagination pagination);",
"@Override\n\tprotected void setAllResultsToPar() {\n\t}",
"@Override\n public void setResult(Object result) throws EngineException {\n \n }",
"public void setPage(Page page) {\n this.page=page;\n }",
"public void setPage(Page page) {\n this.page=page;\n }",
"public void setNumResultsPerPage(int newNumResults) {\n this.numResultsPerPage = newNumResults;\n this.pageNumber = 1;\n this.errorMessage = \"\";\n }",
"public void setResult(Object result) {\n this.result = result;\n }",
"public void setPageNo(int pageNo) {\n this.pageNo = pageNo;\n }",
"@Override\r\n\tpublic String select() {\n\t\tList<Object> paramList=new ArrayList<Object>();\r\n\t\tparamList.add(numPerPage*(pageIndex-1));\r\n\t\tparamList.add(numPerPage);\r\n\t\tthis.setResultMesg(adminDao.doCount(), adminDao.doSelect(paramList));\r\n\t\treturn SUCCESS;\r\n\t}",
"@Override\n protected void completeIndexerSearchResult(String response, IndexerSearchResult indexerSearchResult, AcceptorResult acceptorResult, SearchRequest searchRequest, int offset, Integer limit) {\n Document doc = Jsoup.parse(response);\n if (doc.select(\"table.xMenuT\").size() > 0) {\n Element navigationTable = doc.select(\"table.xMenuT\").get(1);\n Elements pageLinks = navigationTable.select(\"a\");\n boolean hasMore = !pageLinks.isEmpty() && pageLinks.last().text().equals(\">\");\n boolean totalKnown = false;\n indexerSearchResult.setOffset(searchRequest.getOffset());\n int total = searchRequest.getOffset() + 100; //Must be at least as many as already loaded\n if (!hasMore) { //Parsed page contains all the available results\n total = searchRequest.getOffset() + indexerSearchResult.getSearchResultItems().size();\n totalKnown = true;\n }\n indexerSearchResult.setHasMoreResults(hasMore);\n indexerSearchResult.setTotalResults(total);\n indexerSearchResult.setTotalResultsKnown(totalKnown);\n } else {\n indexerSearchResult.setHasMoreResults(false);\n indexerSearchResult.setTotalResults(0);\n indexerSearchResult.setTotalResultsKnown(true);\n }\n indexerSearchResult.setPageSize(100);\n indexerSearchResult.setOffset(offset);\n }",
"public PaginatedResultSetXmlGenerator()\n {\n super();\n m_recsPerPage = DEFAULT_RPP;\n m_pagesPerBatch = DEFAULT_PPB;\n m_pageNumber = 0;\n m_taskVector = new Vector();\n m_profiles = new HashMap();\n }",
"public void setResult(Result result) {\n this.result = result;\n }",
"public void setResult (String Result);",
"public void setResult(final Integer res) {\n this.result = res;\n }",
"public void setResult(final Object value)\n\t{\n\t\tsetResult( getSession().getSessionContext(), value );\n\t}",
"public void setResult(Result result) {\n\t\tthis._result = result;\n\t}",
"protected void setResult(R result) {\n _result = result;\n }",
"public void setEndPage(int value) {\n this.endPage = value;\n }",
"public void setFirstResult(int begin) {\n\r\n\t}",
"public void setResult(String result)\r\n\t{\r\n\t\tthis.result = result;\r\n\t}",
"public static void setResult(String resultInfo) {\n }",
"public void setPage(String page) {\r\n pageEL = page;\r\n }",
"public void setPageNo(long pageNo) {\r\n\t\tif (pageNo < 1) {\r\n\t\t\tthis.pageNo = 1;\r\n\t\t} else {\r\n\t\t\tthis.pageNo = pageNo;\r\n\t\t}\r\n\t}",
"protected void maybeSetResultPropertyValue(int result) {\r\n String res = Integer.toString(result);\r\n if (resultProperty != null) {\r\n getProject().setNewProperty(resultProperty, res);\r\n }\r\n }",
"public void setResult(T result) {\n this.result = result;\n }",
"@RequestMapping(value = \"/\", method = RequestMethod.GET)\n\tpublic String result(ModelMap model) {\n\t\tmodel.put(\"page\", 0);\n\n\t\treturn \"index\";\n\t}",
"public interface PagedResult<T> {\r\n\r\n\t/*\r\n\t * Result code\r\n\t */\r\n\t\r\n\tpublic static final int RESULT_CODE_OK = 0;\r\n\t\r\n\tpublic static final int RESULT_CODE_KO = -1;\r\n\t\r\n\tpublic static final int FIRST_PAGE_INDEX = 1;\r\n\t\r\n\t/**\r\n\t * The method getElementCount() returns this value if the element count is unavalable\r\n\t */\r\n\tpublic final static Integer ELEMENT_COUNT_UNAVAILABLE = -1;\r\n\t\r\n\t/**\r\n\t * <p>The position of the first element of the current pages ( (currentPage-1) * perPage )</p> \r\n\t * \r\n\t * @return\toffset of the first element in this page\r\n\t */\r\n\tpublic Integer getOffset();\r\n\t\r\n\t/**\r\n\t * <p>Maximum number of elements in a page</p>\r\n\t * \r\n\t * @return\tmaximum number of elements in a page\r\n\t */\r\n\tpublic Integer getPerPage();\r\n\r\n\t/**\r\n\t * <p>Total number of elements in all pages</p>\r\n\t * \r\n\t * @return\ttotal number of elements in all pages\r\n\t */\r\n\tpublic Long getElementCount();\r\n\t\r\n\t/**\r\n\t * <p>Position of current page ( in the range 1 - n )</p>\r\n\t * \r\n\t * @return\tposition of current page\r\n\t */\r\n\tpublic Integer getCurrentPage();\t\r\n\t\r\n\t/**\r\n\t * <p>Total number of pages</p>\r\n\t * \r\n\t * @return\ttotal number of pages\r\n\t */\r\n\tpublic Integer getPageCount();\t\r\n\t\r\n\t/**\r\n\t * <p>Number of elements in current page</p>\r\n\t * \r\n\t * @return\tthe size of the current page\r\n\t */\r\n\tpublic Integer getCurrentPageSize();\r\n\t\r\n\t/**\r\n\t * <p>Elements in the current page</p>\r\n\t * \r\n\t * @return\telements in the current page\r\n\t */\r\n\tpublic Iterator<T> getPageElements();\r\n\r\n\t/**\r\n\t * <p>Elements in the current page</p>\r\n\t * \r\n\t * @return\telements in the current page\r\n\t */\r\n\tpublic List<T> getPageElementsList();\r\n\t\r\n\t/**\r\n\t * <p>Iterator over page numbers ( 1 - n )</p>\r\n\t * \r\n\t * @return\titerator over page numbers ( 1 - n )\r\n\t */\r\n\tpublic Iterator<Integer> getPageCountIterator();\r\n\t\r\n\t/**\r\n\t * Result code for this page\r\n\t * \r\n\t * @return\r\n\t */\r\n\tpublic int getResultCode();\r\n\t\r\n\t/**\r\n\t * Additional info of this page.\r\n\t * \r\n\t * @return\r\n\t */\r\n\tpublic Map<String, Object> getInfo();\r\n\t\r\n\t\r\n\t/** \r\n\t * <code>true</code> if this is the last page.\r\n\t * \r\n\t * @return\r\n\t */\r\n\tpublic boolean isLastPage();\r\n\t\r\n\t/** \r\n\t * <code>true</code> if this is the last page.\r\n\t * \r\n\t * @return\r\n\t */\r\n\tpublic boolean isFirstPage();\t\r\n\t\r\n\t\r\n\t// ******* additiona method for virtual paging *******\r\n\t\r\n\t// *******************************************************************************************\r\n\t// *******************************************************************************************\r\n\t// * VIRTUAL PAGING IS A METHOD WHERE A VIRTUAL PAGE IS MAPPED INTO A BIGGER PAGE *\r\n\t// *******************************************************************************************\r\n\t// *******************************************************************************************\r\n\t\r\n\t/**\r\n\t * Virtual search key\r\n\t * \r\n\t * @return\r\n\t */\r\n\tpublic String getVirtualSearchKey();\r\n\t\r\n\tpublic Integer getRealPerPage();\r\n\t\r\n\tpublic Integer getRealCurrentPage();\r\n\t\r\n\tpublic PagedResult<T> getVirtualPage( int currentPage );\r\n\t\r\n\tpublic boolean isSupportVirtualPaging();\r\n\t\r\n\t\r\n\t// ******* additiona method for full result *******\r\n\t\r\n\t// *******************************************************************************************\r\n\t// *******************************************************************************************\r\n\t// * FULL RESULT IS A METHOD OF ACCESS PAGE WHERE ALL ELEMENTS ARE ACCESSIBLE ONLY ITERATING *\r\n\t// *******************************************************************************************\r\n\t// *******************************************************************************************\r\n\t\r\n\t/**\r\n\t * <code>true</code> if the the page contains the full result\r\n\t * \r\n\t * @return\r\n\t */\r\n\tpublic boolean isFullResult();\r\n\r\n}",
"public void setRowsPerPage(int rowsPerPage) {\n this.rowsPerPage=rowsPerPage;\n }",
"public void setPageIndex(int pageIndex) {\n this.pageIndex = pageIndex;\n }",
"public void setResult(String result)\n {\n this.result = result;\n }",
"public void setPage(Page page) {\n\t\tthis.page = page;\n\t}",
"public void setRecordsPerPage(int p_int)\n {\n m_recsPerPage = p_int < 1 ? DEFAULT_RPP : p_int;\n }",
"public void setPageSize(int value) {\n this.pageSize = value;\n }",
"private void setResult(String term){\n\t\taddResponseToResult(term);\n\t}",
"public Result(Page page, List content) {\n\t\tthis.page = page;\n\t\tthis.content = content;\n\t}",
"void setPage(int index) throws IndexOutOfBoundsException;",
"public Set getPages () {\n return pages;\n }",
"@Override\n\tprotected void parseResult() {\n\t\t\n\t}",
"public PaginatedResult<T> start(ResultPage resultPage) {\n return start(resultPage, null);\n }",
"public void setResult(String result) {\n this.result = result;\n }",
"public void setPagination(Query query) {\r\n\t\tif (getCount() != null && getCount() > 0) {\r\n\t\t\tquery.setMaxResults(getCount());\r\n\t\t}\r\n\t\tif (getPage() != null && getCount() != null) {\r\n\t\t\tquery.setFirstResult(getCount() * (getPage() - 1));\r\n\t\t}\r\n\t}",
"public int getPages(){\n return pages;\n }",
"public void setNumResults(int numResults) {\n mNumResults = numResults;\n }",
"public void setCurrentPage(int pageNumber) {\n\t\t\n\t}",
"public String getReturnPage() {return returnPage;}",
"public void setResult(String result) {\n this.result = result;\n }",
"public void setFirstResult(int val) throws HibException;",
"void setQueryResultsUrl(String queryResultsUrl);",
"public void setPage(ICPage page) {\n \t\t_page = page;\n \t}",
"private void setQueryResults(final QueryResultBundle bundle){\n\t\t// Get the sort info\n\t\tthis.synapseClient.getSortFromTableQuery(this.startingQuery.getSql(), new AsyncCallback<List<SortItem>>() {\n\t\t\t\n\t\t\t@Override\n\t\t\tpublic void onSuccess(List<SortItem> sortItems) {\n\t\t\t\tsetQueryResultsAndSort(bundle, sortItems);\n\t\t\t}\n\t\t\t\n\t\t\t@Override\n\t\t\tpublic void onFailure(Throwable caught) {\n\t\t\t\tshowError(caught);\n\t\t\t}\n\t\t});\n\n\t}",
"public void setPageNum(String pageNum) {\r\n this.pageNum = pageNum;\r\n }",
"private void setResultSet(final ResultSet value) {\n\n resultSet = value;\n }",
"public void setNextPage(boolean value) {\n this.nextPage = value;\n }",
"public void setResultDoc(ResultDoc resultDoc) {\n\t\tthis.resultDoc = resultDoc;\n\t}",
"@Override\n public PageResult<Ares2ClusterDO> selectByQueryWithPage(Ares2ClusterQuery query) {\n PageResult<Ares2ClusterDO> result = new PageResult<Ares2ClusterDO>();\n result.setPageSize(query.getPageSize());\n result.setPageNo(query.getPageNo());\n result.setTotalCount(this.countByQuery(query));\n result.setResult(this.selectByQuery(query));\n return result;\n }",
"@Override\r\n\tpublic String paging(String sql) {\n\t\treturn null;\r\n\t}",
"public void setResults(ArrayList<Integer> results){\n this.results = results;\n }",
"public void setFirstResult(java.lang.Integer firstResult)\r\n {\r\n this.firstResult = firstResult;\r\n }",
"public void setPageableParams(Page pageObj) {\n\n if(pageObj ==null){\n\n return;\n\n }\n // Set the current page number\n setPageNumber(pageObj.getNumber());\n\n // Set the total pages\n setTotalPages(pageObj.getTotalPages());\n\n // Set the total elements in all pages\n setTotalElements(pageObj.getTotalElements());\n\n }",
"public void setPageSize(int pageSize) {\n this.pageSize = pageSize;\n }",
"public void setResults(Map<String, StepResult> newResults)\n {\n results = newResults;\n }",
"@Override\n\tpublic void onLoadMore() {\n\t\tpage++;\n\t\texecutorService.submit(new Runnable() {\n\n\t\t\t@Override\n\t\t\tpublic void run() {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\ttry {\n\t\t\t\t\tgetResultByKeyword(page);\n\t\t\t\t} catch (Exception e) {\n\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\te.printStackTrace();\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\t}",
"public void setPages(int pages) {\n this.pages = pages;\n }",
"void setUsePage(boolean page);",
"public void setPage(Page page) throws SQLException {\n\t\tif (page.getId() == -1) {\n\t\t\tpage.setId(upodDao.nextAvailableId(Table.PAGE));\n\t\t}\n\t\tupodDao.setPage(page);\n\t}",
"public void setResult(download.Map result) {\n this.result = result;\n }",
"public void setSite(ResultSite site) {\n this.site = site;\n }",
"@Override\n\tpublic void setView(Resultado resultado, HttpServletRequest request, HttpServletResponse response) {\n\n\t}",
"public void nextPage() {\n\t\tthis.skipEntries += NUM_PER_PAGE;\n\t\tloadEntries();\n\t}",
"public int getPageNo() {\n return pageNo;\n }",
"public void setResult(final SessionContext ctx, final Object value)\n\t{\n\t\tsetProperty(ctx, RESULT,value);\n\t}",
"public void setStartPage(int value) {\n this.startPage = value;\n }",
"public static void setMethodResult(String methodSignature, Object result) {\n MockPageContext.methodResults.put(methodSignature, result);\n }",
"private void updateTotalPageNumbers() {\n totalPageNumbers = rows.size() / NUM_ROWS_PER_PAGE;\n }",
"public void setPages(int pages) {\n this.pages = pages;\n }",
"void xsetNumberOfResults(org.apache.xmlbeans.XmlInt numberOfResults);",
"@Override\n public int doStartTag() throws JspException {\n\n int pageCount = (this.recordCount + this.pageSize - 1) / this.pageSize;\n StringBuilder sb = new StringBuilder();\n\n if (this.recordCount != 0 && this.recordCount > this.pageSize) {\n sb.append(\"<ol class=\\\"paginator\\\">\");\n if (this.pageNo > pageCount) {\n this.pageNo = pageCount;\n }\n if (this.pageNo < 1) {\n this.pageNo = 1;\n }\n HttpServletRequest request = (HttpServletRequest) this.pageContext.getRequest();\n\n url = request.getAttribute(\"originalUrl\").toString();\n url += \"?\";\n if (StringUtil.isNotEmpty(request.getQueryString())) {\n String queryString = request.getQueryString();\n url += queryString.replaceAll(\"page=[0-9]*\", \"\");\n if (!url.endsWith(\"&\") && !url.endsWith(\"?\")) {\n url += \"&\";\n }\n }\n\n if (this.pageNo > 1) {\n sb.append(\"<li class=\\\"paginator__item paginator__item--prev\\\"><a class=\\\"paginator__item__text\\\" href='\" + this.url + \"page=\" + (this.pageNo - 1) + \"'><span class=\\\"paginator__item__text__icon\\\"></span></a></li>\");\n }\n int start = 1;\n if (this.pageNo > 4) {\n start = this.pageNo - 1;\n sb.append(\"<li class=\\\"paginator__item paginator__item--number\\\"><a class=\\\"paginator__item__text\\\" href='\" + this.url + \"page=1'>1</a></li>\");\n sb.append(\"<li class=\\\"paginator__item paginator__item--number\\\"><a class=\\\"paginator__item__text\\\" href='\" + this.url + \"page=2'>2</a></li>\");\n sb.append(\"<li class=\\\"paginator__item paginator__item--ellipsis\\\"><span class=\\\"paginator__item__text\\\"><span class=\\\"paginator__item__text__icon\\\"></span></span></li>\");\n }\n int end = this.pageNo + 1;\n if (end > pageCount) {\n end = pageCount;\n }\n for (int i = start; i <= end; i++) {\n if (this.pageNo == i) {\n sb.append(\"<li class=\\\"paginator__item paginator__item--number paginator__item--current\\\"><span class=\\\"paginator__item__text\\\">\" + i + \"</span></li>\");\n } else {\n sb.append(\"<li class=\\\"paginator__item paginator__item--number\\\"><a class=\\\"paginator__item__text\\\" href='\" + this.url + \"page=\" + i + \"'>\").append(i).append(\"</a></li>\");\n }\n }\n if (end < pageCount - 2) {\n sb.append(\"<li class=\\\"paginator__item paginator__item--ellipsis\\\"><span class=\\\"paginator__item__text\\\"><span class=\\\"paginator__item__text__icon\\\"></span></span></li>\");\n }\n if (end < pageCount - 1) {\n sb.append(\"<li class=\\\"paginator__item paginator__item--number\\\"><a class=\\\"paginator__item__text\\\" href='\" + this.url + \"page=\" + (pageCount - 1) + \"'>\").append((pageCount - 1) + \"</a></li>\");\n }\n if (end < pageCount) {\n sb.append(\"<li class=\\\"paginator__item paginator__item--number\\\"><a class=\\\"paginator__item__text\\\" href='\" + this.url + \"page=\" + pageCount + \"'>\").append(pageCount + \"</a></li>\");\n }\n if (this.pageNo != pageCount) {\n sb.append(\"<li class=\\\"paginator__item paginator__item--next\\\"><a class=\\\"paginator__item__text\\\" href='\" + this.url + \"page=\" + (this.pageNo + 1) + \"'><span class=\\\"paginator__item__text__icon\\\"></span></a></li>\");\n }\n }\n if (anchor != null) {\n sb.append(\"<script type='text/javascript'>$('.paginator a').each(function(){var href=$(this).attr('href');$(this).attr('href',href+'\" + anchor + \"')});</script>\");\n }\n sb.append(\"</ol>\");\n try {\n this.pageContext.getOut().println(sb.toString());\n } catch (IOException e) {\n // TODO Auto-generated catch block\n\n e.printStackTrace();\n }\n return 0;\n }",
"@Override\r\n\t\t\t\t\t\tpublic void run() {\n\t\t\t\t\t\t\tprgDlg.setMax(nTotalPage);\r\n\t\t\t\t\t\t\tprgDlg.setProgress(nPage);\r\n\t\t\t\t\t\t}",
"public void setPageSize(int pageSize) {\r\n\t\tif (pageSize < 1) {\r\n\t\t\tthis.pageSize = DEF_COUNT;\r\n\t\t} else {\r\n\t\t\tthis.pageSize = pageSize;\r\n\t\t}\r\n\t}",
"@Override\n protected void initResultTable() {\n }",
"public void run() {\n getPage(page + 1, false);\n }",
"@Override\n\tpublic void setPaging(PagingInterface paging) {\n\t\t\n\t}",
"@Override\n\tpublic void setPaging(PagingInterface paging) {\n\t\t\n\t}",
"public interface PagableResult {\n Integer getTotal();\n Integer getResults();\n}",
"public int getPage() {\n return page;\n }"
]
| [
"0.7555428",
"0.67759496",
"0.6622171",
"0.6608995",
"0.6523983",
"0.6480086",
"0.64516693",
"0.6414685",
"0.6375814",
"0.6367598",
"0.63650703",
"0.63621736",
"0.6343399",
"0.6249615",
"0.61816853",
"0.6164545",
"0.6143013",
"0.6128392",
"0.6122097",
"0.6094955",
"0.6094955",
"0.6091459",
"0.6075245",
"0.60733014",
"0.6066686",
"0.60565823",
"0.604357",
"0.60318846",
"0.5981875",
"0.5965817",
"0.59401286",
"0.59314185",
"0.5920645",
"0.59026396",
"0.5893696",
"0.5892133",
"0.5875871",
"0.58565277",
"0.58552504",
"0.5850889",
"0.58413965",
"0.58262587",
"0.58194596",
"0.58112836",
"0.58020556",
"0.5800973",
"0.5784427",
"0.5779078",
"0.5777464",
"0.5776661",
"0.57551634",
"0.5744095",
"0.57310414",
"0.5727514",
"0.5721883",
"0.57120687",
"0.5702892",
"0.56878203",
"0.56803024",
"0.5679882",
"0.5671869",
"0.5671167",
"0.5661314",
"0.56405944",
"0.5640133",
"0.56355876",
"0.56295544",
"0.5594342",
"0.55916244",
"0.55913675",
"0.55893457",
"0.55723196",
"0.55661136",
"0.5565142",
"0.55588096",
"0.5549767",
"0.5546363",
"0.55168056",
"0.5506002",
"0.5486838",
"0.54819417",
"0.54815656",
"0.5481513",
"0.54780823",
"0.5473042",
"0.5462886",
"0.54577893",
"0.54569024",
"0.5454006",
"0.54536694",
"0.544773",
"0.5444111",
"0.54367214",
"0.54359066",
"0.5431662",
"0.5430502",
"0.5426063",
"0.54240185",
"0.54240185",
"0.5421218",
"0.54209036"
]
| 0.0 | -1 |
Initialization: Parse an XMLFile | public DOMParser() { ; } | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void initParser(String file) {\n if (checkFileExists(file)) {\n parseXml(file);\n }\n }",
"public void parseXmlFile(String fileName){\n\t\t//get the factory\n\t\tDocumentBuilderFactory dbf = DocumentBuilderFactory.newInstance();\n\t\t\n\t\ttry {\n\t\t\t//Using factory get an instance of document builder\n\t\t\tDocumentBuilder db = dbf.newDocumentBuilder();\n\t\t\t\n\t\t\t//parse using builder to get DOM representation of the XML file\n\t\t\tdoc = db.parse(fileName);\n\t\t} catch(ParserConfigurationException pce) {\n\t\t\tpce.printStackTrace();\n\t\t} catch(SAXException se) {\n\t\t\tSystem.err.println(\"Malformed XML: Make sure to provide a valid XML document.\");\n\t\t} catch(IOException ioe) {\n\t\t\tSystem.err.println(\"File not found: Path to a valid XML file has to be specified.\" );\n\t\t}\n\t}",
"public void parseDocument(File XMLInputFile) throws FunctionException {\r\n\t\t\t\r\n\t\t\tLog.log(\"XMLParser -> parseDocument started\");\r\n\t\t\t\r\n\t\t\ttry {\r\n\t\t\t\t//get a factory\r\n\t\t\t\tSAXParserFactory spf = SAXParserFactory.newInstance();\r\n\t\t\t\t//get a new instance of parser\r\n\t\t\t\tSAXParser sp = spf.newSAXParser();\r\n\t\t\t\t//parse the file and also register this class for call backs\r\n\t\t\t\tsp.parse(XMLInputFile, this);\r\n\t\t\t}catch(SAXException se) {\r\n\t\t\t\tthrow new FunctionException(\"SAXException had occurred.\\n\"+se.getMessage());\r\n\t\t\t}catch(ParserConfigurationException pce) {\r\n\t\t\t\tthrow new FunctionException(\"ParserConfigurationException had occurred.\\n\"+pce.getMessage());\r\n\t\t\t}catch (IOException ie) {\r\n\t\t\t\tthrow new FunctionException(\"IOException had occurred.\\n\"+ie.getMessage());\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\tLog.log(\"XMLParser -> parseDocument completed\");\r\n\t\t}",
"public void parseDocument(String XMLFilePath) {\n\t \n\t SAXParserFactory spf = SAXParserFactory.newInstance();\n\t try {\n\t\tSAXParser sp = spf.newSAXParser();\n\t\tsp.parse(XMLFilePath, this);\n\t }catch(SAXException se) {\n\t\tse.printStackTrace();\n\t }catch(ParserConfigurationException pce) {\n\t\tpce.printStackTrace();\n\t }catch (IOException ie) {\n\t\tie.printStackTrace();\n\t }\n\t}",
"public void parseXML(String XML);",
"public XmlParser(String strFile) throws XmlException\n {\n File fXmlFile = new File(strFile);\n DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\n DocumentBuilder dBuilder;\n try\n {\n dBuilder = dbFactory.newDocumentBuilder();\n doc = dBuilder.parse(fXmlFile);\n doc.getDocumentElement().normalize();\n }\n catch (ParserConfigurationException ex)\n {\n throw new XmlException(\"Unable to initialize XML parser for: \" + strFile);\n }\n catch (SAXException ex)\n {\n throw new XmlException(\"Incorrect XML format: \" + strFile);\n }\n catch (IOException ex)\n {\n throw new XmlException(\"Unable to open XML file: \" + strFile);\n }\n }",
"@Before\n\tpublic void initParser() {\n\t\tXMLTagParser.init(file);\n\t}",
"public Document setUpDocumentToParse() throws ParserConfigurationException, SAXException, IOException{\n\t\tFile file = new File (dataFilePath);\n\t\tDocumentBuilderFactory documentBuilderFactory = DocumentBuilderFactory.newInstance();\n\t\tDocumentBuilder documentBuilder = documentBuilderFactory.newDocumentBuilder();\n\t\tDocument document = documentBuilder.parse(file);\n\n\t\treturn document;\n\t}",
"public PropertiesDocument(File xmlFile) throws ParserConfigurationException, SAXException, IOException {\n\t\tthis.documentBuilderFactory = DocumentBuilderFactory.newInstance();\n this.documentBuilder = documentBuilderFactory.newDocumentBuilder();\n\t\tthis.document = this.documentBuilder.parse(xmlFile);\n\t\tthis.properties = documentToProperties(this.document);\n\t}",
"@Override\r\n\tpublic void initializeFromFile(File inputXmlFile) {\n\t\tDocumentBuilderFactory factory = DocumentBuilderFactory.newInstance();\r\n\t\ttry {\r\n\t\t\tDocumentBuilder builder = factory.newDocumentBuilder();\r\n\t\t\tDocument doc = builder.parse(inputXmlFile);\r\n\t\t\tNodeList xmlNodeList;\r\n\t\t\tNodeList xmlEdgeList;\r\n\t\t\txmlNodeList = doc.getElementsByTagName(\"node\");\r\n\r\n\t\t\tfor(int i=0;i<xmlNodeList.getLength();i++) {\r\n\r\n\t\t\t\tNode p=xmlNodeList.item(i);\r\n\t\t\t\tElement xmlNode =(Element) p;\r\n\t\t\t\tNodeList.add(xmlNode);\r\n\t\t\t\tNodeMap.put(Integer.parseInt(xmlNode.getAttribute(\"id\")),xmlNode);\r\n\r\n\r\n\t\t\t\t}\r\n\t\t\txmlEdgeList = doc.getElementsByTagName(\"edge\");\r\n\r\n\r\n\t\t\tfor(int j=0;j<xmlEdgeList.getLength();j++) {\r\n\t\t\t\tNode p = xmlEdgeList.item(j);\r\n\t\t\t\tElement xmlNode = (Element) p;\r\n\t\t\t\tEdgeList.add(xmlNode);\r\n\r\n\t\t\t}\r\n\r\n\t\t} catch (ParserConfigurationException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t} catch (SAXException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t} catch(IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\r\n\t}",
"public XPathParser(String xmlFileName) {\n this(new InputSource(xmlFileName), defaultContextNode);\n }",
"public void readXMLFile(File file) {\n\t\treadXMLFile(file, -1, 0);\n\t}",
"public XmlParser(String xmlFile) throws ParserConfigurationException, SAXException, IOException \n\t{\n\t\tFile fXmlFile = new File(xmlFile);\n\t\tDocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\n\t\tDocumentBuilder dBuilder = dbFactory.newDocumentBuilder();\n\t\tDocument doc = dBuilder.parse(fXmlFile);\n\t\tdoc.getDocumentElement().normalize();\n\n\t\tNodeList nList = doc.getElementsByTagName(\"MedlineCitation\");\n\t\tfor (int temp = 0; temp < nList.getLength(); temp++) {\n\n\t\t\tNode nNode = nList.item(temp);\n\t\t\tif (nNode.getNodeType() == Node.ELEMENT_NODE) {\n\n\t\t\t\tElement eElement = (Element) nNode;\n\n\t\t\t\tString[] ID = getTagValue(\"PMID\", eElement);\n\t\t\t\tint pmid = new Integer(ID[0]).intValue();\t\t \n \n\t\t\t\t\n\t\t\t\tString[] articleTitle = getTagValue(\"ArticleTitle\",eElement);\n\t\t\t\tif(articleTitle!=null)\n\t\t\t\t{\t\n\t\t\t\t\ttokenizeText(articleTitle, pmid, false);\t\t\t\n\t\t\t\t}\n\n\n\t\t\t\tString[] articleText = getTagValue(\"AbstractText\",eElement);\t\t\t\n\t\t\t\tif (articleText!=null)\n\t\t\t\t{\n\t\t\t\t\ttokenizeText(articleText, pmid, true);\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t}",
"private Document initialize() {\r\n Document doc = null;\r\n try {\r\n File file = new File(\"./evidence.xml\");\r\n DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\r\n DocumentBuilder docBuilder = dbFactory.newDocumentBuilder();\r\n doc = docBuilder.parse(file);\r\n doc.getDocumentElement().normalize();\r\n } catch (ParserConfigurationException | IOException | SAXException e) {\r\n System.err.println(\"Parser failed parse file:\"+e.getMessage());\r\n }\r\n return doc;\r\n }",
"@Override\r\n\tpublic void initFromXMLfile(URL arg0) throws InitializingException {\n\t}",
"private void processXMLFile( File xmlFile ) throws SAXException, IOException, ParserConfigurationException {\r\n\t\t\r\n\t\t//parse the uploaded xml file\r\n\t\tDocumentBuilderFactory domFactory = DocumentBuilderFactory.newInstance();\r\n\t\t\r\n\t\tdomFactory.setValidating(false);\r\n\t\tdomFactory.setIgnoringComments(true);\r\n\t\t\r\n\t\tDocumentBuilder docBuilder = domFactory.newDocumentBuilder();\r\n\t\t\t\r\n\t\tDocument doc = docBuilder.parse(xmlFile);\r\n\t\t\t\t\r\n\t\tElement employeesNode = doc.getDocumentElement();\r\n\t\t\r\n\t\tNodeList employees = employeesNode.getElementsByTagName(\"Employee\");\r\n\t\t\r\n\t\tLogger.debug(\"found \" + employees.getLength() + \" employees in xml document\");\r\n\t\t\r\n\t\tfor (int i=0; i<employees.getLength(); i++ ) {\r\n\t\t\t\r\n\t\t\tHashMap<String,String> contactObject = new HashMap<String,String>();\r\n\t\t\t\r\n\t\t\tElement employee = (Element) employees.item(i);\r\n\t\t\t\r\n\t\t\tcontactObject.put( \"id\", employee.getAttribute(\"id\") );\r\n\t\t\tcontactObject.put( \"givenname\", ContactsImport.getXmlChildNodeValue( employee, \"GivenName\") );\r\n\t\t\tcontactObject.put( \"sn\", ContactsImport.getXmlChildNodeValue( employee, \"SurName\") );\r\n\t\t\tcontactObject.put( \"title\", ContactsImport.getXmlChildNodeValue( employee, \"JobTitle\") );\r\n\t\t\tcontactObject.put( \"mail\", ContactsImport.getXmlChildNodeValue( employee, \"EmailAddress\") );\r\n\t\t\tcontactObject.put( \"telephonenumber\", ContactsImport.getXmlChildNodeValue( employee, \"PhoneNumber\") );\r\n\t\t\t\r\n\t\t\tcreateContact(contactObject);\r\n\t\t\t\r\n\t\t}\r\n\t\t\r\n\t}",
"public Document parse(File aFile)\n\t\t\t\t throws org.xml.sax.SAXException, java.io.IOException {\n\t\t/**\n\t\t * @todo Fix/implement this later\n\t\t */\n\t\tthrow new SAXException(\"Not supported\");\n\t}",
"public CommandProcessXML(String filePath){\n _xmlFile = new File(filePath);\n _dbFactory = DocumentBuilderFactory.newInstance();\n }",
"public static Document parseXML(File xmlFile) throws BaseException\r\n\t{\r\n\t\tDocument xmlDoc = null;\r\n\t\t// Ensure that the file is present and can be read.\r\n\t\tif (xmlFile != null && xmlFile.canRead())\r\n\t\t{\r\n\t\t\ttry\r\n\t\t\t{\r\n\t\t\t\txmlDoc = parseXML(new FileInputStream(xmlFile));\r\n\t\t\t} catch (FileNotFoundException e)\r\n\t\t\t{\r\n\t\t\t\tthrow new BaseException(\"ERR_FILE_PARSE\", \"Unable to load file provided\", e);\r\n\t\t\t}\r\n\t\t}\r\n\t\treturn xmlDoc;\r\n\t}",
"private static Document initializeXML(String filePath) throws Exception {\n\t\ttry {\n\t\t\tlogger.info(\"Initializing the xml file :\" + filePath);\n\t\t\txmlDocument = DocumentBuilderFactory.newInstance().newDocumentBuilder().parse(new File(filePath));\n\t\t\txmlDocument.getDocumentElement().normalize();\n\t\t\treturn xmlDocument;\n\t\t} catch (Exception e) {\n\n\t\t\tlogger.error(\"Error while reading from XML. File Path : \" + filePath + \" \\n\" + e.getMessage());\n\t\t\tthrow (new Exception(e.getMessage()));\n\n\t\t}\n\t}",
"private void readXML() {\n\t\tSAXParserFactory factory = SAXParserFactory.newInstance();\n\t\tXMLReader handler = new XMLReader();\n\t\tSAXParser parser;\n\t\t\n\t\t//Parsing xml file\n\t\ttry {\n\t\t\tparser = factory.newSAXParser();\n\t\t\tparser.parse(\"src/data/users.xml\", handler);\n\t\t\tgroupsList = handler.getGroupNames();\n\t\t} catch(SAXException e) {\n\t\t\te.printStackTrace();\n\t\t} catch (ParserConfigurationException e) {\n\t\t\te.printStackTrace();\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t};\n\t}",
"public void parseXML(String xmlString) {\n DocumentBuilderFactory builderFactory = DocumentBuilderFactory.newInstance(); \n Document document = null; \n try { \n //DOM parser instance \n DocumentBuilder builder = builderFactory.newDocumentBuilder(); \n \n //parse an XML file into a DOM tree, in this case, change the filepath to xml String \n document = builder.parse(new File(filePath));\n \n //get root element, which is <Airports>\n Element rootElement = document.getDocumentElement(); \n \n //traverse child elements. retrieve all the <Airport>\n NodeList nodes = rootElement.getChildNodes(); \n for (int i=0; i < nodes.getLength(); i++) \n { \n Node node = nodes.item(i); \n if (node.getNodeType() == Node.ELEMENT_NODE) { \n Element airport = (Element) node; \n \n //process child element \n String code = airport.getAttribute(\"Code\");\n String name = airport.getAttribute(\"Name\"); \n \n // child node of airport\n NodeList airportChildren = airport.getChildNodes();\n \n // value of longitude & latitude\n String longitude = airportChildren.item(1).getTextContent();\n String latitude = airportChildren.item(2).getTextContent();\n \n Location location = new Location(longitude, latitude);\n airportList.add(new Airport(code, name, location));\n } \n } \n \n // another approach to traverse all the listNode by tagName \n /*NodeList nodeList = rootElement.getElementsByTagName(\"book\"); \n if(nodeList != null) \n { \n for (int i = 0 ; i < nodeList.getLength(); i++) \n { \n Element element = (Element)nodeList.item(i); \n String id = element.getAttribute(\"id\"); \n } \n }*/\n // add the DOM object to the airportList\n } catch (ParserConfigurationException e) { \n e.printStackTrace(); \n } catch (SAXException e) { \n e.printStackTrace(); \n } catch (IOException e) { \n e.printStackTrace(); \n } \n }",
"public XMLHandler(File file) {\n this.file = file;\n }",
"public PragyanXmlParser(InputStream file) {\r\n\t\tfileToParse = file;\r\n\t\tcharWriter = new CharArrayWriter();\r\n\t\tdateWriter = new CharArrayWriter();\r\n\t\tformat = new SimpleDateFormat(\"dd-MM-yyyy HH:mm\"); \r\n\t\t\r\n\t}",
"public XmlPullParser getLocalXML(String filename) throws IOException {\r\n\t\ttry {\r\n\t\t\tin = mContext.getAssets().open(filename);\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\r\n\t\ttry {\r\n\t\t\tXmlPullParser parser = Xml.newPullParser();\r\n\t\t\tparser.setFeature(XmlPullParser.FEATURE_PROCESS_NAMESPACES, false);\r\n\t\t\tparser.setInput(in, null);\r\n\t\t\tparser.nextTag();\r\n\t\t\treturn parser;\r\n\t\t} catch (XmlPullParserException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\r\n\t\treturn null;\r\n\t}",
"private void parseXmlFile(InputStream file)\n {\n\tDocumentBuilderFactory dbf = DocumentBuilderFactory.newInstance();\n\n\ttry\n\t{\n\t // Using factory get an instance of document builder\n\t //Log.d(Constants.TAG, \"XMLReader::parseXmlFile - Creating a new Document Builder.\");\n\t DocumentBuilder db = dbf.newDocumentBuilder();\n\n\t // parse using builder to get DOM representation of the XML file\n\t //Log.d(Constants.TAG, \"XMLReader::parseXmlFile - Attempting to parse the file.\");\n\t // This line causes the program to crash when attempting to read the SVG file, which is in XML format.\n\t dom = db.parse(file);\n\t //Log.d(Constants.TAG, \"XMLReader::parseXmlFile - Finished parsing the file.\");\n\t}\n\tcatch (ParserConfigurationException pce)\n\t{\n\t Log.d(Constants.TAG, \"ParserConfigurationException MSG: \" + pce.getMessage());\n\n\t pce.printStackTrace();\n\t}\n\tcatch (SAXException se)\n\t{\n\t Log.d(Constants.TAG, \"SAXException MSG: \" + se.getMessage());\n\n\t se.printStackTrace();\n\t}\n\tcatch (IOException ioe)\n\t{\n\t Log.d(Constants.TAG, \"IOException MSG: \" + ioe.getMessage());\n\n\t ioe.printStackTrace();\n\t}\n\tcatch (Exception e)\n\t{\n\t Log.d(Constants.TAG, \"Exception MSG: \" + e.getMessage());\n\t e.printStackTrace();\n\t}\n\n\t//Log.d(Constants.TAG, \"XMLReader::parseXmlFile() Exiting!\");\n }",
"public void parse()\n throws ClassNotFoundException, IllegalAccessException,\n\t InstantiationException, IOException, SAXException,\n\t ParserConfigurationException\n {\n\tSAXParser saxParser = SAXParserFactory.newInstance().newSAXParser();\n\txmlReader = saxParser.getXMLReader();\n\txmlReader.setContentHandler(this);\n\txmlReader.setEntityResolver(this);\n\txmlReader.setErrorHandler(this);\n\txmlReader.setDTDHandler(this);\n\txmlReader.parse(xmlSource);\n\t}",
"public GongDomObject(File file) throws ParserConfigurationException, InvalidTagException, SAXException, IOException {\r\n super(file);\r\n }",
"public static Document parseXMLFile(final File file) throws IOException {\n\t\ttry {\t\t\t\n\t\t\tfinal DocumentBuilderFactory builderFactory = DocumentBuilderFactory.newInstance();\n\t\t\tfinal DocumentBuilder documentBuilder = builderFactory.newDocumentBuilder();\n\t\t\tfinal Document document = documentBuilder.parse(file);\n\t\t\t\n\t\t\treturn document;\n\t\t} catch (ParserConfigurationException | SAXException e) {\n\t\t\tthrow new RuntimeException(e);\n\t\t}\n\t}",
"public MySaxParser() {\n\t\ttry {\n\t\t\tSAXParser parser=SAXParserFactory.newInstance().newSAXParser();\n\t\t\tparser.parse(new File(GAME_FILE), this);\n\t\t} catch (ParserConfigurationException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (SAXException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}catch (IOException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t}",
"public void parse() throws ParserConfigurationException, SAXException, IOException, XMLStreamException {\n\t\tString currentElem = null;\n\t\tCard card = null;\n\t\tType type = null;\n\t\tAuthor author = null;\n\n\t\tXMLInputFactory xmlFactory = XMLInputFactory.newInstance();\n\t\tXMLEventReader xmlReader = xmlFactory.createXMLEventReader(new StreamSource(xmlFileName));\n\n\t\twhile (xmlReader.hasNext()) {\n\t\t\tXMLEvent event = xmlReader.nextEvent();\n\n\t\t\tif (event.isCharacters() && event.asCharacters().isWhiteSpace()) {\n\t\t\t\tcontinue;\n\t\t\t}\n\n\t\t\tif (event.isStartElement()) {\n\t\t\t\tStartElement startElement = event.asStartElement();\n\t\t\t\tcurrentElem = startElement.getName().getLocalPart();\n\n\t\t\t\tif (currentElem.equals(\"OldCards\")) {\n\t\t\t\t\toldCards = new OldCards();\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t\tif (currentElem.equals(\"Card\")) {\n\t\t\t\t\tcard = new Card();\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t\tif (currentElem.equals(\"Type\")) {\n\t\t\t\t\ttype = new Type();\n\t\t\t\t\tAttribute attribute = startElement.getAttributeByName(new QName(\"send\"));\n\t\t\t\t\tif (attribute != null) {\n\t\t\t\t\t\ttype.setSend(Boolean.parseBoolean(attribute.getValue()));\n\t\t\t\t\t}\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t\tif (currentElem.equals(\"Author\")) {\n\t\t\t\t\tauthor = new Author();\n\t\t\t\t\tAttribute attribute = startElement.getAttributeByName(new QName(\"famous\"));\n\t\t\t\t\tif (attribute != null) {\n\t\t\t\t\t\tauthor.setFamous(Boolean.parseBoolean(attribute.getValue()));\n\t\t\t\t\t}\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t}\n\n\t\t\tif (event.isCharacters()) {\n\t\t\t\tCharacters characters = event.asCharacters();\n\n\t\t\t\tif (currentElem.equals(\"Thema\")) {\n\t\t\t\t\tcard.setThema(characters.getData());\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t\tif (currentElem.equals(\"Type\")) {\n\t\t\t\t\ttype.setType(characters.getData());\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t\tif (currentElem.equals(\"Country\")) {\n\t\t\t\t\tcard.setCountry(characters.getData());\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t\tif (currentElem.equals(\"Year\")) {\n\t\t\t\t\tcard.setYear(Integer.parseInt(characters.getData()));\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t\tif (currentElem.equals(\"Author\")) {\n\t\t\t\t\tauthor.setName(characters.getData());\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t\tif (currentElem.equals(\"Valuable\")) {\n\t\t\t\t\tcard.setValuable(characters.getData());\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t}\n\n\t\t\tif (event.isEndElement()) {\n\t\t\t\tEndElement endElement = event.asEndElement();\n\t\t\t\tString localName = endElement.getName().getLocalPart();\n\n\t\t\t\tif (localName.equals(\"Card\")) {\n\t\t\t\t\toldCards.getCards().add(card);\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t\tif (localName.equals(\"Type\")) {\n\t\t\t\t\tcard.setType(type);\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t\tif (localName.equals(\"Author\")) {\n\t\t\t\t\tcard.getAuthors().add(author);\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t}\n\n\t\t}\n\t\txmlReader.close();\n\t}",
"@PublicAtsApi\n public XmlText( File xmlFile ) throws XMLException {\n StringBuilder sb = new StringBuilder();\n try (BufferedReader br = new BufferedReader(new FileReader(xmlFile))) {\n String line = null;\n while ( (line = br.readLine()) != null) {\n sb.append(line);\n }\n init(sb.toString());\n } catch (IOException | XMLException e) {\n throw new XMLException(\"Error parsing XML file: \" + xmlFile.getAbsolutePath(), e);\n }\n }",
"private static Document parseXmlFile(String strXml) {\n // get the factory\n final DocumentBuilderFactory dbf = DocumentBuilderFactory.newInstance();\n\n try {\n // Using factory get an instance of document builder\n final DocumentBuilder db = dbf.newDocumentBuilder();\n final Document dom;\n File file;\n\n file = new File(strXml);\n if (!file.exists()) {\n strXml = \"data/\" + strXml;\n }\n\n // Parse using builder to get DOM representation of the XML file\n dom = db.parse(strXml);\n\n return dom;\n } catch (final Exception e) {\n Verbose.log(Level.SEVERE, e, \"Laoding Specifications\",\n e.getMessage());\n } // end try\n\n return null;\n }",
"private static void staxReader(File file) throws XMLStreamException, FileNotFoundException, FactoryConfigurationError, IOException {\n\n FileInputStream fis = new FileInputStream(file);\n Page[] ns0pages = StaxPageParser.pagesFromFile(fis);\n\n// reporter(ns0pages);\n }",
"public static void parseXML(String filename) {\n SAXBuilder builder = new SAXBuilder();\n \n //reading XML document\n Document xml = null;\n try {\n xml = builder.build(new File(filename));\n } catch (JDOMException e) {\n e.printStackTrace();\n } catch (IOException e) {\n e.printStackTrace();\n }\n \n //getting root element from XML document\n Element root = xml.getRootElement();\n if (root != null)\n {\n\t Element queryNode = root.getChild(\"query\");\n\t if (queryNode != null)\n\t {\n\t\t Element rcNode = queryNode.getChild(\"recentchanges\");\n\t\t \n\t\t List<Element> rcList = rcNode.getChildren();\n\t\t \n\t\t \n\t\t \n\t\t //Iterating over all childs in XML\n\t\t Iterator<Element> itr = rcList.iterator();\n\t\t while(itr.hasNext()){\n\t\t \tElement rc = itr.next();\n\t\t \tString user = rc.getAttributeValue(\"user\");\n\t\t \tString userId = rc.getAttributeValue(\"userid\");\n\t\t \tString pageId = rc.getAttributeValue(\"pageid\");\n\t\t \tString title = rc.getAttributeValue(\"title\");\n\t\t \tString timestamp = rc.getAttributeValue(\"timestamp\");\n\t\t \tString comments = rc.getAttributeValue(\"comment\");\n\t\t \tString type = rc.getAttributeValue(\"type\");\n\t\t \tString oldRevId = rc.getAttributeValue(\"old_revid\");\n\t\t \tString newRevId = rc.getAttributeValue(\"revid\");\n\t\t \tString recentChangeId = rc.getAttributeValue(\"rcid\");\n\t\t \t\n\t\t// \t //reading attribute from Element using JDOM\n\t\t// System.out.println(\"User: \" + user + \" | User_ID: \" + userId + \" | Page_ID: \" + pageId + \n\t\t// \t\t\" | Title: \" + title + \" | Timestamp: \" + timestamp + \" | Recent_Change_ID: \" + recentChangeId + \" | Old_Rev_ID: \" + oldRevId + \n\t\t// \t\t\" | New_Rev_ID: \" + newRevId + \" | Type: \" + type); \n\t\t \t\n\t\t \ttry {\n\t\t\t\t\t\tcluster.writeWikiResults(user, userId, timestamp, pageId, title, recentChangeId, oldRevId, newRevId, type);\n\t\t\t\t\t\t System.out.println(count++);\n\t\t\t\t\t} catch (ParseException e) {\n\t\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t} catch (InterruptedException e) {\n\t\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t}\n\t\t }\n\t }\n } \n }",
"org.apache.ant.common.model.Project parseXMLBuildFile(java.io.File xmlBuildFile) throws org.apache.ant.common.util.ExecutionException;",
"public void loadFromXml(File configFile) throws XMLQroxyConfigException {\n try {\n SAXParserFactory factory = SAXParserFactory.newInstance();\n SAXParser saxParser = factory.newSAXParser();\n saxParser.parse(configFile, this);\n } catch (ParserConfigurationException | SAXException | IOException e) {\n throw new XMLQroxyConfigException(\"Error while parsing the config file: \" + e.getMessage(), e);\n }\n }",
"private static Document parseXmlFile(String in) {\n try {\n DocumentBuilderFactory dbf = DocumentBuilderFactory.newInstance();\n DocumentBuilder db = dbf.newDocumentBuilder();\n InputSource is = new InputSource(new StringReader(in));\n return db.parse(is);\n } catch (ParserConfigurationException e) {\n throw new RuntimeException(e);\n } catch (SAXException e) {\n throw new RuntimeException(e);\n } catch (IOException e) {\n throw new RuntimeException(e);\n }\n }",
"static void processFile(File xmlFile) {\n Document doc = null;\n try {\n doc = builder.parse(xmlFile);\n }\n catch (IOException e) {\n e.printStackTrace();\n System.exit(3);\n }\n catch (SAXException e) {\n System.out.println(\"Parsing error on file \" + xmlFile);\n System.out.println(\" (not supposed to happen with supplied XML files)\");\n e.printStackTrace();\n System.exit(3);\n }\n \n /* At this point 'doc' contains a DOM representation of an 'Items' XML\n * file. Use doc.getDocumentElement() to get the root Element. */\n System.out.println(\"Successfully parsed - \" + xmlFile);\n \n /* Fill in code here (you will probably need to write auxiliary\n methods). */\n \n Element[] elems = getElementsByTagNameNR(doc.getDocumentElement(), \"Item\");\n for(Element e : elems) {\n\n String itemId = e.getAttribute(\"ItemID\");\n String name = getElementTextByTagNameNR(e, \"Name\");\n String currently = strip(getElementTextByTagNameNR(e, \"Currently\"));\n String buy_price = strip(getElementTextByTagNameNR(e, \"Buy_Price\"));\n String first_bid = strip(getElementTextByTagNameNR(e, \"First_Bid\"));\n String number_of_bids = getElementTextByTagNameNR(e, \"Number_of_Bids\");\n String country = getElementTextByTagNameNR(e, \"Country\");\n String started = changeTime(getElementTextByTagNameNR(e, \"Started\"));\n String ends = changeTime(getElementTextByTagNameNR(e, \"Ends\"));\n Element seller = getElementByTagNameNR(e, \"Seller\");\n String sellerId = seller.getAttribute(\"UserID\");\n String sellerRatings = seller.getAttribute(\"Rating\");\n String location = getElementTextByTagNameNR(e, \"Location\");\n Element locate = getElementByTagNameNR(e, \"Location\");\n String latitude = locate.getAttribute(\"Latitude\");\n String longitude = locate.getAttribute(\"Longitude\");\n String description = getElementTextByTagNameNR(e, \"Description\");\n if(description.length() > 4000)\n description = description.substring(0, 4001);\n\n // add the record to the list\n items.add(itemRecord(itemId, name, currently, buy_price, first_bid, number_of_bids, country,\n started, ends, sellerId, location, latitude, longitude, description));\n\n // add the category infomation and belongsTo information\n Element[] cates = getElementsByTagNameNR(e, \"Category\");\n for(Element c : cates) {\n String cate = getElementText(c);\n if(category.containsKey(cate) == false) {\n int cnt = category.size();\n category.put(cate, cnt);\n }\n int index = category.get(cate);\n String caterecord = itemId + columnSeparator + index;\n belongsTo.add(caterecord);\n }\n\n // add the user information\n if(users.containsKey(sellerId)) {\n users.get(sellerId).sellRating = sellerRatings;\n }\n else {\n User u = new User(sellerId);\n u.sellRating = sellerRatings;\n users.put(sellerId, u);\n }\n\n // add the bid infromation and bider inforamtion\n Element[] ebids = getElementsByTagNameNR(getElementByTagNameNR(e, \"Bids\"), \"Bid\");\n for(Element b : ebids) {\n Element bidder = getElementByTagNameNR(b, \"Bidder\");\n String bidderId = bidder.getAttribute(\"UserID\");\n String bidderRating = bidder.getAttribute(\"Rating\");\n String bidderloc = getElementTextByTagNameNR(bidder, \"Location\");\n String biddercoun = getElementTextByTagNameNR(bidder, \"Country\");\n String amount = strip(getElementTextByTagNameNR(b, \"Amount\"));\n String time = changeTime(getElementTextByTagNameNR(b, \"Time\"));\n\n\n if(users.containsKey(bidderId) == false) {\n User u = new User(bidderId);\n users.put(bidderId, u);\n }\n users.get(bidderId).location = bidderloc;\n users.get(bidderId).country = biddercoun;\n users.get(bidderId).bidRating = bidderRating;\n bids.add(bidRecord(itemId, bidderId, time, amount));\n }\n\n }\n \n \n /**************************************************************/\n \n }",
"public Document parseFile(String fileName) {\r\n log.debug(\"Parsing XML file... \" + fileName);\r\n DocumentBuilder docBuilder;\r\n Document doc = null;\r\n DocumentBuilderFactory docBuilderFactory = DocumentBuilderFactory.newInstance();\r\n docBuilderFactory.setIgnoringElementContentWhitespace(true);\r\n try {\r\n docBuilder = docBuilderFactory.newDocumentBuilder();\r\n }\r\n catch (ParserConfigurationException e) {\r\n log.debug(\"Wrong parser configuration: \" + e.getMessage());\r\n return null;\r\n }\r\n File sourceFile = new File(fileName);\r\n try {\r\n doc = docBuilder.parse(sourceFile);\r\n setDocument(doc);\r\n }\r\n catch (SAXException e) {\r\n log.debug(\"Wrong XML file structure: \" + e.getMessage());\r\n return null;\r\n }\r\n catch (IOException e) {\r\n log.debug(\"Could not read source file: \" + e.getMessage());\r\n }\r\n log.debug(\"XML file parsed\");\r\n return doc; \r\n }",
"public void parse(String fileName) throws Exception;",
"public static Document parseXMLFile(final String fileName) throws IOException {\n\t\treturn parseXMLFile(new File(fileName));\n\t}",
"public void parse(String filename);",
"private void parseFiles() throws ParserException{\n NodeList fileNodesList = root.getElementsByTagName(\"file\");\n for(int i=0; i<fileNodesList.getLength(); i++){\n filesToProcess.add(getFile((Element) fileNodesList.item(i)));\n }\n }",
"public XMLData () {\r\n\r\n //code description\r\n\r\n try {\r\n DocumentBuilder builder = DocumentBuilderFactory.newInstance().newDocumentBuilder();\r\n this.document = builder.newDocument(); \r\n }\r\n catch (ParserConfigurationException err) {}\r\n\r\n }",
"public void parse() throws ParserConfigurationException, SAXException,\n\t\t\tIOException, XMLStreamException {\n\n\t\tGem gem = new Gem();\n\t\tVisualParameters params = new VisualParameters();\n\n\t\t// current element name holder\n\t\tString currentElement = null;\n\n\t\tXMLInputFactory factory = XMLInputFactory.newInstance();\n\n\t\tfactory.setProperty(XMLInputFactory.IS_NAMESPACE_AWARE, true);\n\n\t\tXMLEventReader reader = factory.createXMLEventReader(new StreamSource(\n\t\t\t\txmlFileName));\n\n\t\twhile (reader.hasNext()) {\n\t\t\tXMLEvent event = reader.nextEvent();\n\n\t\t\t// skip any empty content\n\t\t\tif (event.isCharacters() && event.asCharacters().isWhiteSpace()) {\n\t\t\t\tcontinue;\n\t\t\t}\n\n\t\t\t// handler for start tags\n\t\t\tif (event.isStartElement()) {\n\t\t\t\tStartElement startElement = event.asStartElement();\n\t\t\t\tcurrentElement = startElement.getName().getLocalPart();\n\n\t\t\t\tif (XML.FOND.equalsTo(currentElement)) {\n\t\t\t\t\tfond = new Fond();\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t\tif (XML.GEM.equalsTo(currentElement)) {\n\t\t\t\t\tgem = new Gem();\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t\tif (XML.VISUAL_PARAMETRS.equalsTo(currentElement)) {\n\t\t\t\t\tparams = new VisualParameters();\n\t\t\t\t\tAttribute attribute = startElement\n\t\t\t\t\t\t\t.getAttributeByName(new QName(XML.VALUE_COLOR\n\t\t\t\t\t\t\t\t\t.value()));\n\t\t\t\t\tif (attribute != null) {\n\t\t\t\t\t\tparams.setValueColor(EnumColors.fromValue(attribute\n\t\t\t\t\t\t\t\t.getValue()));\n\t\t\t\t\t}\n\t\t\t\t\tattribute = startElement.getAttributeByName(new QName(\n\t\t\t\t\t\t\tXML.TRANSPARENCY.value()));\n\t\t\t\t\tif (attribute != null) {\n\t\t\t\t\t\tparams.setTransparency(Integer.valueOf(attribute\n\t\t\t\t\t\t\t\t.getValue()));\n\t\t\t\t\t}\n\t\t\t\t\tattribute = startElement.getAttributeByName(new QName(\n\t\t\t\t\t\t\tXML.FACETING.value()));\n\t\t\t\t\tif (attribute != null) {\n\t\t\t\t\t\tparams.setFaceting(Integer.valueOf(attribute.getValue()));\n\t\t\t\t\t}\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t}\n\n\t\t\t// handler for contents\n\t\t\tif (event.isCharacters()) {\n\t\t\t\tCharacters characters = event.asCharacters();\n\n\t\t\t\tif (XML.NAME.equalsTo(currentElement)) {\n\t\t\t\t\tgem.setName(characters.getData());\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t\tif (XML.PRECIOUSNESS.equalsTo(currentElement)) {\n\t\t\t\t\tgem.setPreciousness(Boolean.valueOf(characters.getData()));\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t\tif (XML.ORIGIN.equalsTo(currentElement)) {\n\t\t\t\t\tgem.setOrigin(characters.getData());\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t\tif (XML.VALUE.equalsTo(currentElement)) {\n\t\t\t\t\tgem.setValue(Double.valueOf(characters.getData()));\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t}\n\n\t\t\t// handler for end tags\n\t\t\tif (event.isEndElement()) {\n\t\t\t\tEndElement endElement = event.asEndElement();\n\t\t\t\tString localName = endElement.getName().getLocalPart();\n\n\t\t\t\tif (XML.GEM.equalsTo(localName)) {\n\t\t\t\t\tfond.getGem().add(gem);\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\n\t\t\t\tif (XML.VISUAL_PARAMETRS.equalsTo(localName)) {\n\t\t\t\t\t// just add answer to container\n\t\t\t\t\tgem.setVisualParameters(params);\n\t\t\t\t\tcontinue;\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treader.close();\n\t}",
"public void readXmlFile() {\r\n try {\r\n ClassLoader classLoader = getClass().getClassLoader();\r\n File credentials = new File(classLoader.getResource(\"credentials_example.xml\").getFile());\r\n DocumentBuilderFactory Factory = DocumentBuilderFactory.newInstance();\r\n DocumentBuilder Builder = Factory.newDocumentBuilder();\r\n Document doc = Builder.parse(credentials);\r\n doc.getDocumentElement().normalize();\r\n username = doc.getElementsByTagName(\"username\").item(0).getTextContent();\r\n password = doc.getElementsByTagName(\"password\").item(0).getTextContent();\r\n url = doc.getElementsByTagName(\"url\").item(0).getTextContent();\r\n setUsername(username);\r\n setPassword(password);\r\n setURL(url);\r\n } catch (Exception error) {\r\n System.out.println(\"Error in parssing the given xml file: \" + error.getMessage());\r\n }\r\n }",
"public XPathParser(String xmlFileName, String contextNode) {\n this(new InputSource(xmlFileName), contextNode);\n }",
"public ParseXML() throws XmlPullParserException, IOException\n {\n\t input =\"<?xml version=\\\"1.0\\\" encoding=\\\"UTF-8\\\"?><Balls version=1.0><ball><name>900 Global Hook! Black </name><brand>900 Global</brand><release_date>05/15/2012</release_date><radius_of_gyration>2.551</radius_of_gyration><differential>0.046</differential><mass_biass_diff>n/a</mass_biass_diff><lane_condition>Medium</lane_condition><finish>Polished</finish><coverstock>Reactive Resin</coverstock><coverstock_name>S43 Pearl Reactive</coverstock_name><factory_finish>n/a</factory_finish><core_type>Symmetric</core_type><core_name>n/a</core_name></ball><ball><name>900 Global Hook! Hybrid</name><brand>900 Global</brand><release_date>05/15/2012</release_date><radius_of_gyration>2.551</radius_of_gyration><differential>0.046</differential><mass_biass_diff>n/a</mass_biass_diff><lane_condition>Medium</lane_condition><finish>Polished</finish><coverstock>Hybrid Reactive</coverstock><coverstock_name>S43 Hybrid Reactive</coverstock_name><factory_finish>n/a</factory_finish><core_type>Symmetric</core_type><core_name>Symmetric (10# has a pancake core)</core_name></ball>\"; \n\t parse();\n }",
"public Object fromXML(File xmlFile) throws XMLUtilityException {\r\n\t\tObject beanObject = null;\r\n\t\tbeanObject = unmarshaller.fromXML(xmlFile);\r\n\t\treturn beanObject;\r\n\t}",
"void read(XmlPullParser xmlPullParser) throws IOException, XmlPullParserException;",
"private void loadFile() {\n String xmlContent = \"<?xml version=\\\"1.0\\\" encoding=\\\"UTF-8\\\"?><atomic-mass-table mass-units=\\\"u\\\" abundance-units=\\\"Mole Fraction\\\"><entry symbol=\\\"H\\\" atomic-number=\\\"1\\\"> <natural-abundance> <mass value=\\\"1.00794\\\" error=\\\"0.00007\\\" /> <isotope mass-number=\\\"1\\\"> <mass value=\\\"1.0078250319\\\" error=\\\"0.00000000006\\\" /> <abundance value=\\\"0.999885\\\" error=\\\"0.000070\\\" /> </isotope> <isotope mass-number=\\\"2\\\"> <mass value=\\\"2.0141017779\\\" error=\\\"0.0000000006\\\" /> <abundance value=\\\"0.000115\\\" error=\\\"0.000070\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"He\\\" atomic-number=\\\"2\\\"> <natural-abundance> <mass value=\\\"4.002602\\\" error=\\\"0.000002\\\" /> <isotope mass-number=\\\"3\\\"> <mass value=\\\"3.0160293094\\\" error=\\\"0.0000000012\\\" /> <abundance value=\\\"0.00000134\\\" error=\\\"0.00000003\\\" /> </isotope> <isotope mass-number=\\\"4\\\"> <mass value=\\\"4.0026032497\\\" error=\\\"0.0000000015\\\" /> <abundance value=\\\"0.99999866\\\" error=\\\"0.00000003\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Li\\\" atomic-number=\\\"3\\\"> <natural-abundance> <mass value=\\\"6.9421\\\" error=\\\"0.002\\\" /> <isotope mass-number=\\\"3\\\"> <mass value=\\\"6.0151223\\\" error=\\\"0.0000005\\\" /> <abundance value=\\\"0.0759\\\" error=\\\"0.0004\\\" /> </isotope> <isotope mass-number=\\\"7\\\"> <mass value=\\\"7.0160041\\\" error=\\\"0.0000005\\\" /> <abundance value=\\\"0.9241\\\" error=\\\"0.0004\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Be\\\" atomic-number=\\\"4\\\"> <natural-abundance> <mass value=\\\"9.012182\\\" error=\\\"0.000003\\\" /> <isotope mass-number=\\\"9\\\"> <mass value=\\\"9.0121822\\\" error=\\\"0.0000004\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"B\\\" atomic-number=\\\"5\\\"> <natural-abundance> <mass value=\\\"10.881\\\" error=\\\"0.007\\\" /> <isotope mass-number=\\\"10\\\"> <mass value=\\\"10.0129371\\\" error=\\\"0.0000003\\\" /> <abundance value=\\\"0.199\\\" error=\\\"0.007\\\" /> </isotope> <isotope mass-number=\\\"11\\\"> <mass value=\\\"11.0093055\\\" error=\\\"0.0000004\\\" /> <abundance value=\\\"0.801\\\" error=\\\"0.007\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"C\\\" atomic-number=\\\"6\\\"> <natural-abundance> <mass value=\\\"12.0107\\\" error=\\\"0.0008\\\" /> <isotope mass-number=\\\"12\\\"> <mass value=\\\"12\\\" error=\\\"0\\\" /> <abundance value=\\\"0.9893\\\" error=\\\"0.0008\\\" /> </isotope> <isotope mass-number=\\\"13\\\"> <mass value=\\\"13.003354838\\\" error=\\\"0.000000005\\\" /> <abundance value=\\\"0.0107\\\" error=\\\"0.0008\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"N\\\" atomic-number=\\\"7\\\"> <natural-abundance> <mass value=\\\"14.0067\\\" error=\\\"0.0002\\\" /> <isotope mass-number=\\\"14\\\"> <mass value=\\\"14.0030740074\\\" error=\\\"0.0000000018\\\" /> <abundance value=\\\"0.99636\\\" error=\\\"0.00020\\\" /> </isotope> <isotope mass-number=\\\"15\\\"> <mass value=\\\"15.000108973\\\" error=\\\"0.000000012\\\" /> <abundance value=\\\"0.00364\\\" error=\\\"0.00020\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"O\\\" atomic-number=\\\"8\\\"> <natural-abundance> <mass value=\\\"15.9994\\\" error=\\\"0.0003\\\" /> <isotope mass-number=\\\"16\\\"> <mass value=\\\"15.9949146223\\\" error=\\\"0.0000000025\\\" /> <abundance value=\\\"0.99759\\\" error=\\\"0.00016\\\" /> </isotope> <isotope mass-number=\\\"17\\\"> <mass value=\\\"16.99913150\\\" error=\\\"0.00000022\\\" /> <abundance value=\\\"0.00038\\\" error=\\\"0.00001\\\" /> </isotope> <isotope mass-number=\\\"18\\\"> <mass value=\\\"17.9991604\\\" error=\\\"0.0000009\\\" /> <abundance value=\\\"0.00205\\\" error=\\\"0.00014\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"F\\\" atomic-number=\\\"9\\\"> <natural-abundance> <mass value=\\\"18.9984032\\\" error=\\\"0.0000005\\\" /> <isotope mass-number=\\\"19\\\"> <mass value=\\\"18.99840320\\\" error=\\\"0.00000007\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ne\\\" atomic-number=\\\"10\\\"> <natural-abundance> <mass value=\\\"20.1797\\\" error=\\\"0.0006\\\" /> <isotope mass-number=\\\"20\\\"> <mass value=\\\"19.992440176\\\" error=\\\"0.000000003\\\" /> <abundance value=\\\"0.9048\\\" error=\\\"0.0003\\\" /> </isotope> <isotope mass-number=\\\"21\\\"> <mass value=\\\"20.99384674\\\" error=\\\"0.00000004\\\" /> <abundance value=\\\"0.0027\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"22\\\"> <mass value=\\\"21.99138550\\\" error=\\\"0.00000025\\\" /> <abundance value=\\\"0.0925\\\" error=\\\"0.0003\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Na\\\" atomic-number=\\\"11\\\"> <natural-abundance> <mass value=\\\"22.989770\\\" error=\\\"0.000002\\\" /> <isotope mass-number=\\\"23\\\"> <mass value=\\\"22.98976966\\\" error=\\\"0.00000026\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Mg\\\" atomic-number=\\\"12\\\"> <natural-abundance> <mass value=\\\"24.3050\\\" error=\\\"0.0006\\\" /> <isotope mass-number=\\\"24\\\"> <mass value=\\\"23.98504187\\\" error=\\\"0.00000026\\\" /> <abundance value=\\\"0.7899\\\" error=\\\"0.0004\\\" /> </isotope> <isotope mass-number=\\\"25\\\"> <mass value=\\\"24.98583700\\\" error=\\\"0.00000026\\\" /> <abundance value=\\\"0.1000\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"26\\\"> <mass value=\\\"25.98259300\\\" error=\\\"0.00000026\\\" /> <abundance value=\\\"0.1101\\\" error=\\\"0.0003\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Al\\\" atomic-number=\\\"13\\\"> <natural-abundance> <mass value=\\\"26.981538\\\" error=\\\"0.000002\\\" /> <isotope mass-number=\\\"27\\\"> <mass value=\\\"26.98153841\\\" error=\\\"0.00000024\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Si\\\" atomic-number=\\\"14\\\"> <natural-abundance> <mass value=\\\"28.0855\\\" error=\\\"0.0003\\\" /> <isotope mass-number=\\\"28\\\"> <mass value=\\\"27.97692649\\\" error=\\\"0.00000022\\\" /> <abundance value=\\\"0.92223\\\" error=\\\"0.00019\\\" /> </isotope> <isotope mass-number=\\\"29\\\"> <mass value=\\\"28.97649468\\\" error=\\\"0.00000022\\\" /> <abundance value=\\\"0.04685\\\" error=\\\"0.00008\\\" /> </isotope> <isotope mass-number=\\\"30\\\"> <mass value=\\\"29.97377018\\\" error=\\\"0.00000022\\\" /> <abundance value=\\\"0.03092\\\" error=\\\"0.00011\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"P\\\" atomic-number=\\\"15\\\"> <natural-abundance> <mass value=\\\"30.973761\\\" error=\\\"0.000002\\\" /> <isotope mass-number=\\\"31\\\"> <mass value=\\\"30.97376149\\\" error=\\\"0.00000027\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"S\\\" atomic-number=\\\"16\\\"> <natural-abundance> <mass value=\\\"32.065\\\" error=\\\"0.005\\\" /> <isotope mass-number=\\\"32\\\"> <mass value=\\\"31.97207073\\\" error=\\\"0.00000015\\\" /> <abundance value=\\\"0.9499\\\" error=\\\"0.0026\\\" /> </isotope> <isotope mass-number=\\\"33\\\"> <mass value=\\\"32.97145854\\\" error=\\\"0.00000015\\\" /> <abundance value=\\\"0.0075\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"34\\\"> <mass value=\\\"33.96786687\\\" error=\\\"0.00000014\\\" /> <abundance value=\\\"0.0425\\\" error=\\\"0.0024\\\" /> </isotope> <isotope mass-number=\\\"36\\\"> <mass value=\\\"35.96708088\\\" error=\\\"0.00000025\\\" /> <abundance value=\\\"0.0001\\\" error=\\\"0.0001\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Cl\\\" atomic-number=\\\"17\\\"> <natural-abundance> <mass value=\\\"35.453\\\" error=\\\"0.002\\\" /> <isotope mass-number=\\\"35\\\"> <mass value=\\\"34.96885271\\\" error=\\\"0.00000004\\\" /> <abundance value=\\\"0.7576\\\" error=\\\"0.0010\\\" /> </isotope> <isotope mass-number=\\\"37\\\"> <mass value=\\\"36.96590260\\\" error=\\\"0.00000005\\\" /> <abundance value=\\\"0.2424\\\" error=\\\"0.0010\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ar\\\" atomic-number=\\\"18\\\"> <natural-abundance> <mass value=\\\"39.948\\\" error=\\\"0.001\\\" /> <isotope mass-number=\\\"36\\\"> <mass value=\\\"35.96754626\\\" error=\\\"0.00000027\\\" /> <abundance value=\\\"0.0003365\\\" error=\\\"0.000030\\\" /> </isotope> <isotope mass-number=\\\"38\\\"> <mass value=\\\"37.9627322\\\" error=\\\"0.0000005\\\" /> <abundance value=\\\"0.000632\\\" error=\\\"0.000005\\\" /> </isotope> <isotope mass-number=\\\"40\\\"> <mass value=\\\"39.962383124\\\" error=\\\"0.000000005\\\" /> <abundance value=\\\"0.996003\\\" error=\\\"0.000030\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"K\\\" atomic-number=\\\"19\\\"> <natural-abundance> <mass value=\\\"39.0983\\\" error=\\\"0.0001\\\" /> <isotope mass-number=\\\"39\\\"> <mass value=\\\"38.9637069\\\" error=\\\"0.0000003\\\" /> <abundance value=\\\"0.932581\\\" error=\\\"0.000044\\\" /> </isotope> <isotope mass-number=\\\"40\\\"> <mass value=\\\"39.96399867\\\" error=\\\"0.00000029\\\" /> <abundance value=\\\"0.000117\\\" error=\\\"0.000001\\\" /> </isotope> <isotope mass-number=\\\"41\\\"> <mass value=\\\"40.96182597\\\" error=\\\"0.00000028\\\" /> <abundance value=\\\"0.067302\\\" error=\\\"0.000044\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ca\\\" atomic-number=\\\"20\\\"> <natural-abundance> <mass value=\\\"40.078\\\" error=\\\"0.004\\\" /> <isotope mass-number=\\\"40\\\"> <mass value=\\\"39.9625912\\\" error=\\\"0.0000003\\\" /> <abundance value=\\\"0.96941\\\" error=\\\"0.00156\\\" /> </isotope> <isotope mass-number=\\\"42\\\"> <mass value=\\\"41.9586183\\\" error=\\\"0.0000004\\\" /> <abundance value=\\\"0.00647\\\" error=\\\"0.00023\\\" /> </isotope> <isotope mass-number=\\\"43\\\"> <mass value=\\\"42.9587668\\\" error=\\\"0.0000005\\\" /> <abundance value=\\\"0.00135\\\" error=\\\"0.00010\\\" /> </isotope> <isotope mass-number=\\\"44\\\"> <mass value=\\\"43.9554811\\\" error=\\\"0.0000009\\\" /> <abundance value=\\\"0.02086\\\" error=\\\"0.00110\\\" /> </isotope> <isotope mass-number=\\\"46\\\"> <mass value=\\\"45.9536927\\\" error=\\\"0.0000025\\\" /> <abundance value=\\\"0.00004\\\" error=\\\"0.00003\\\" /> </isotope> <isotope mass-number=\\\"48\\\"> <mass value=\\\"47.952533\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.00187\\\" error=\\\"0.00021\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Sc\\\" atomic-number=\\\"21\\\"> <natural-abundance> <mass value=\\\"44.955910\\\" error=\\\"0.000008\\\" /> <isotope mass-number=\\\"45\\\"> <mass value=\\\"44.9559102\\\" error=\\\"0.0000012\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ti\\\" atomic-number=\\\"22\\\"> <natural-abundance> <mass value=\\\"47.867\\\" error=\\\"0.001\\\" /> <isotope mass-number=\\\"46\\\"> <mass value=\\\"45.9526295\\\" error=\\\"0.0000012\\\" /> <abundance value=\\\"0.0825\\\" error=\\\"0.0003\\\" /> </isotope> <isotope mass-number=\\\"47\\\"> <mass value=\\\"46.9517637\\\" error=\\\"0.0000010\\\" /> <abundance value=\\\"0.0744\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"48\\\"> <mass value=\\\"47.9479470\\\" error=\\\"0.0000010\\\" /> <abundance value=\\\"0.7372\\\" error=\\\"0.0003\\\" /> </isotope> <isotope mass-number=\\\"49\\\"> <mass value=\\\"48.9478707\\\" error=\\\"0.0000010\\\" /> <abundance value=\\\"0.0541\\\" error=\\\"0.0002\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"V\\\" atomic-number=\\\"23\\\"> <natural-abundance> <mass value=\\\"50.9415\\\" error=\\\"0.0001\\\" /> <isotope mass-number=\\\"50\\\"> <mass value=\\\"49.9471627\\\" error=\\\"0.0000014\\\" /> <abundance value=\\\"0.00250\\\" error=\\\"0.00004\\\" /> </isotope> <isotope mass-number=\\\"51\\\"> <mass value=\\\"50.9439635\\\" error=\\\"0.0000014\\\" /> <abundance value=\\\"0.99750\\\" error=\\\"0.00004\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Cr\\\" atomic-number=\\\"24\\\"> <natural-abundance> <mass value=\\\"51.9961\\\" error=\\\"0.0006\\\" /> <isotope mass-number=\\\"50\\\"> <mass value=\\\"49.9460495\\\" error=\\\"0.0000014\\\" /> <abundance value=\\\"0.04345\\\" error=\\\"0.00013\\\" /> </isotope> <isotope mass-number=\\\"52\\\"> <mass value=\\\"51.9405115\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.83789\\\" error=\\\"0.00018\\\" /> </isotope> <isotope mass-number=\\\"53\\\"> <mass value=\\\"52.9406534\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.09501\\\" error=\\\"0.00017\\\" /> </isotope> <isotope mass-number=\\\"54\\\"> <mass value=\\\"53.938846\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.02365\\\" error=\\\"0.00007\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Mn\\\" atomic-number=\\\"25\\\"> <natural-abundance> <mass value=\\\"54.938049\\\" error=\\\"0.000009\\\" /> <isotope mass-number=\\\"55\\\"> <mass value=\\\"54.9380493\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Fe\\\" atomic-number=\\\"26\\\"> <natural-abundance> <mass value=\\\"55.845\\\" error=\\\"0.002\\\" /> <isotope mass-number=\\\"54\\\"> <mass value=\\\"53.9396147\\\" error=\\\"0.0000014\\\" /> <abundance value=\\\"0.05845\\\" error=\\\"0.00035\\\" /> </isotope> <isotope mass-number=\\\"56\\\"> <mass value=\\\"55.9349418\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.91754\\\" error=\\\"0.00036\\\" /> </isotope> <isotope mass-number=\\\"57\\\"> <mass value=\\\"56.9353983\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.02119\\\" error=\\\"0.00010\\\" /> </isotope> <isotope mass-number=\\\"58\\\"> <mass value=\\\"57.9332801\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.00282\\\" error=\\\"0.00004\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Co\\\" atomic-number=\\\"27\\\"> <natural-abundance> <mass value=\\\"58.933200\\\" error=\\\"0.000009\\\" /> <isotope mass-number=\\\"59\\\"> <mass value=\\\"59.9331999\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ni\\\" atomic-number=\\\"28\\\"> <natural-abundance> <mass value=\\\"58.6934\\\" error=\\\"0.0002\\\" /> <isotope mass-number=\\\"58\\\"> <mass value=\\\"57.9353477\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.680769\\\" error=\\\"0.000089\\\" /> </isotope> <isotope mass-number=\\\"60\\\"> <mass value=\\\"59.9307903\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.262231\\\" error=\\\"0.000077\\\" /> </isotope> <isotope mass-number=\\\"61\\\"> <mass value=\\\"60.9310601\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.011399\\\" error=\\\"0.000006\\\" /> </isotope> <isotope mass-number=\\\"62\\\"> <mass value=\\\"61.9283484\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.0036345\\\" error=\\\"0.000017\\\" /> </isotope> <isotope mass-number=\\\"64\\\"> <mass value=\\\"63.9279692\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.009256\\\" error=\\\"0.000009\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Cu\\\" atomic-number=\\\"29\\\"> <natural-abundance> <mass value=\\\"63.546\\\" error=\\\"0.003\\\" /> <isotope mass-number=\\\"63\\\"> <mass value=\\\"62.9296007\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.6915\\\" error=\\\"0.0015\\\" /> </isotope> <isotope mass-number=\\\"65\\\"> <mass value=\\\"64.9277938\\\" error=\\\"0.0000019\\\" /> <abundance value=\\\"0.3085\\\" error=\\\"0.0015\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Zn\\\" atomic-number=\\\"30\\\"> <natural-abundance> <mass value=\\\"65.409\\\" error=\\\"0.004\\\" /> <isotope mass-number=\\\"64\\\"> <mass value=\\\"63.9291461\\\" error=\\\"0.0000018\\\" /> <abundance value=\\\"0.48268\\\" error=\\\"0.00321\\\" /> </isotope> <isotope mass-number=\\\"66\\\"> <mass value=\\\"65.9260364\\\" error=\\\"0.0000017\\\" /> <abundance value=\\\"0.27975\\\" error=\\\"0.00077\\\" /> </isotope> <isotope mass-number=\\\"67\\\"> <mass value=\\\"66.9271305\\\" error=\\\"0.0000017\\\" /> <abundance value=\\\"0.04102\\\" error=\\\"0.00021\\\" /> </isotope> <isotope mass-number=\\\"68\\\"> <mass value=\\\"67.9248473\\\" error=\\\"0.0000017\\\" /> <abundance value=\\\"0.19024\\\" error=\\\"0.00123\\\" /> </isotope> <isotope mass-number=\\\"70\\\"> <mass value=\\\"69.925325\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.00631\\\" error=\\\"0.00009\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ga\\\" atomic-number=\\\"31\\\"> <natural-abundance> <mass value=\\\"69.723\\\" error=\\\"0.001\\\" /> <isotope mass-number=\\\"69\\\"> <mass value=\\\"68.925581\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.60108\\\" error=\\\"0.00009\\\" /> </isotope> <isotope mass-number=\\\"71\\\"> <mass value=\\\"70.9247073\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.39892\\\" error=\\\"0.00009\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ge\\\" atomic-number=\\\"32\\\"> <natural-abundance> <mass value=\\\"72.64\\\" error=\\\"0.01\\\" /> <isotope mass-number=\\\"70\\\"> <mass value=\\\"69.9242500\\\" error=\\\"0.0000019\\\" /> <abundance value=\\\"0.2038\\\" error=\\\"0.0018\\\" /> </isotope> <isotope mass-number=\\\"72\\\"> <mass value=\\\"71.9220763\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.2731\\\" error=\\\"0.0026\\\" /> </isotope> <isotope mass-number=\\\"73\\\"> <mass value=\\\"72.9234595\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.0776\\\" error=\\\"0.0008\\\" /> </isotope> <isotope mass-number=\\\"74\\\"> <mass value=\\\"73.9211784\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.3672\\\" error=\\\"0.0015\\\" /> </isotope> <isotope mass-number=\\\"76\\\"> <mass value=\\\"75.9214029\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.0783\\\" error=\\\"0.0007\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"As\\\" atomic-number=\\\"33\\\"> <natural-abundance> <mass value=\\\"74.92160\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"75\\\"> <mass value=\\\"74.9215966\\\" error=\\\"0.0000018\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Se\\\" atomic-number=\\\"34\\\"> <natural-abundance> <mass value=\\\"78.96\\\" error=\\\"0.03\\\" /> <isotope mass-number=\\\"74\\\"> <mass value=\\\"73.9224767\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.0089\\\" error=\\\"0.0004\\\" /> </isotope> <isotope mass-number=\\\"76\\\"> <mass value=\\\"75.9192143\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.0937\\\" error=\\\"0.0029\\\" /> </isotope> <isotope mass-number=\\\"77\\\"> <mass value=\\\"76.9199148\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.0763\\\" error=\\\"0.0016\\\" /> </isotope> <isotope mass-number=\\\"78\\\"> <mass value=\\\"77.9173097\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.2377\\\" error=\\\"0.0028\\\" /> </isotope> <isotope mass-number=\\\"80\\\"> <mass value=\\\"79.9165221\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.4961\\\" error=\\\"0.0041\\\" /> </isotope> <isotope mass-number=\\\"82\\\"> <mass value=\\\"81.9167003\\\" error=\\\"0.0000022\\\" /> <abundance value=\\\"0.0873\\\" error=\\\"0.0022\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Br\\\" atomic-number=\\\"35\\\"> <natural-abundance> <mass value=\\\"79.904\\\" error=\\\"0.001\\\" /> <isotope mass-number=\\\"79\\\"> <mass value=\\\"78.9183379\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.5069\\\" error=\\\"0.0007\\\" /> </isotope> <isotope mass-number=\\\"81\\\"> <mass value=\\\"80.916291\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.4931\\\" error=\\\"0.0007\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Kr\\\" atomic-number=\\\"36\\\"> <natural-abundance> <mass value=\\\"83.798\\\" error=\\\"0.002\\\" /> <isotope mass-number=\\\"78\\\"> <mass value=\\\"77.920388\\\" error=\\\"0.000007\\\" /> <abundance value=\\\"0.00355\\\" error=\\\"0.00003\\\" /> </isotope> <isotope mass-number=\\\"80\\\"> <mass value=\\\"79.916379\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.02286\\\" error=\\\"0.00010\\\" /> </isotope> <isotope mass-number=\\\"82\\\"> <mass value=\\\"81.9134850\\\" error=\\\"0.0000028\\\" /> <abundance value=\\\"0.11593\\\" error=\\\"0.00031\\\" /> </isotope> <isotope mass-number=\\\"83\\\"> <mass value=\\\"82.914137\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.11500\\\" error=\\\"0.00019\\\" /> </isotope> <isotope mass-number=\\\"84\\\"> <mass value=\\\"83.911508\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.56987\\\" error=\\\"0.00015\\\" /> </isotope> <isotope mass-number=\\\"86\\\"> <mass value=\\\"85.910615\\\" error=\\\"0.000005\\\" /> <abundance value=\\\"0.17279\\\" error=\\\"0.00041\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Rb\\\" atomic-number=\\\"37\\\"> <natural-abundance> <mass value=\\\"85.4678\\\" error=\\\"0.0003\\\" /> <isotope mass-number=\\\"85\\\"> <mass value=\\\"84.9117924\\\" error=\\\"0.0000027\\\" /> <abundance value=\\\"0.7217\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"87\\\"> <mass value=\\\"86.9091858\\\" error=\\\"0.0000028\\\" /> <abundance value=\\\"0.2783\\\" error=\\\"0.0002\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Sr\\\" atomic-number=\\\"38\\\"> <natural-abundance> <mass value=\\\"87.62\\\" error=\\\"0.01\\\" /> <isotope mass-number=\\\"84\\\"> <mass value=\\\"83.913426\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.0056\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"86\\\"> <mass value=\\\"85.9092647\\\" error=\\\"0.0000025\\\" /> <abundance value=\\\"0.0986\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"87\\\"> <mass value=\\\"86.9088816\\\" error=\\\"0.0000025\\\" /> <abundance value=\\\"0.0700\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"88\\\"> <mass value=\\\"87.9056167\\\" error=\\\"0.0000025\\\" /> <abundance value=\\\"0.8258\\\" error=\\\"0.0001\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Y\\\" atomic-number=\\\"39\\\"> <natural-abundance> <mass value=\\\"88.90585\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"89\\\"> <mass value=\\\"88.9058485\\\" error=\\\"0.0000026\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Zr\\\" atomic-number=\\\"40\\\"> <natural-abundance> <mass value=\\\"91.224\\\" error=\\\"0.002\\\" /> <isotope mass-number=\\\"90\\\"> <mass value=\\\"89.9047022\\\" error=\\\"0.0000024\\\" /> <abundance value=\\\"0.5145\\\" error=\\\"0.0040\\\" /> </isotope> <isotope mass-number=\\\"91\\\"> <mass value=\\\"90.9056434\\\" error=\\\"0.0000023\\\" /> <abundance value=\\\"0.1122\\\" error=\\\"0.0005\\\" /> </isotope> <isotope mass-number=\\\"92\\\"> <mass value=\\\"91.9050386\\\" error=\\\"0.0000023\\\" /> <abundance value=\\\"0.1715\\\" error=\\\"0.0008\\\" /> </isotope> <isotope mass-number=\\\"94\\\"> <mass value=\\\"93.9063144\\\" error=\\\"0.0000026\\\" /> <abundance value=\\\"0.1738\\\" error=\\\"0.0028\\\" /> </isotope> <isotope mass-number=\\\"96\\\"> <mass value=\\\"95.908275\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0280\\\" error=\\\"0.0009\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Nb\\\" atomic-number=\\\"41\\\"> <natural-abundance> <mass value=\\\"92.90638\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"93\\\"> <mass value=\\\"92.9063762\\\" error=\\\"0.0000024\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Mo\\\" atomic-number=\\\"42\\\"> <natural-abundance> <mass value=\\\"95.94\\\" error=\\\"0.02\\\" /> <isotope mass-number=\\\"92\\\"> <mass value=\\\"91.906810\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.1477\\\" error=\\\"0.0031\\\" /> </isotope> <isotope mass-number=\\\"94\\\"> <mass value=\\\"93.9050867\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.0923\\\" error=\\\"0.0010\\\" /> </isotope> <isotope mass-number=\\\"95\\\"> <mass value=\\\"94.9058406\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.1590\\\" error=\\\"0.0009\\\" /> </isotope> <isotope mass-number=\\\"96\\\"> <mass value=\\\"95.9046780\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.1668\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"97\\\"> <mass value=\\\"96.9030201\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.0956\\\" error=\\\"0.0005\\\" /> </isotope> <isotope mass-number=\\\"98\\\"> <mass value=\\\"97.9054069\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.2419\\\" error=\\\"0.0026\\\" /> </isotope> <isotope mass-number=\\\"100\\\"> <mass value=\\\"99.907476\\\" error=\\\"0.000006\\\" /> <abundance value=\\\"0.0967\\\" error=\\\"0.0020\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ru\\\" atomic-number=\\\"44\\\"> <natural-abundance> <mass value=\\\"101.07\\\" error=\\\"0.02\\\" /> <isotope mass-number=\\\"96\\\"> <mass value=\\\"95.907604\\\" error=\\\"0.000009\\\" /> <abundance value=\\\"0.0554\\\" error=\\\"0.0014\\\" /> </isotope> <isotope mass-number=\\\"98\\\"> <mass value=\\\"97.905287\\\" error=\\\"0.000007\\\" /> <abundance value=\\\"0.0187\\\" error=\\\"0.0003\\\" /> </isotope> <isotope mass-number=\\\"99\\\"> <mass value=\\\"98.9059385\\\" error=\\\"0.0000022\\\" /> <abundance value=\\\".01276\\\" error=\\\"0.0014\\\" /> </isotope> <isotope mass-number=\\\"100\\\"> <mass value=\\\"99.9042189\\\" error=\\\"0.0000022\\\" /> <abundance value=\\\"0.1260\\\" error=\\\"0.0007\\\" /> </isotope> <isotope mass-number=\\\"101\\\"> <mass value=\\\"100.9055815\\\" error=\\\"0.0000022\\\" /> <abundance value=\\\"0.1706\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"102\\\"> <mass value=\\\"101.9043488\\\" error=\\\"0.0000022\\\" /> <abundance value=\\\"0.3155\\\" error=\\\"0.0014\\\" /> </isotope> <isotope mass-number=\\\"104\\\"> <mass value=\\\"103.905430\\\" error=\\\".01862\\\" /> <abundance value=\\\"0.1862\\\" error=\\\"0.0027\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Rh\\\" atomic-number=\\\"45\\\"> <natural-abundance> <mass value=\\\"1025.90550\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"103\\\"> <mass value=\\\"102.905504\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Pd\\\" atomic-number=\\\"46\\\"> <natural-abundance> <mass value=\\\"106.42\\\" error=\\\"0.01\\\" /> <isotope mass-number=\\\"102\\\"> <mass value=\\\"101.905607\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0102\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"104\\\"> <mass value=\\\"103.904034\\\" error=\\\"0.000005\\\" /> <abundance value=\\\"0.1114\\\" error=\\\"0.0008\\\" /> </isotope> <isotope mass-number=\\\"105\\\"> <mass value=\\\"104.905083\\\" error=\\\"0.000005\\\" /> <abundance value=\\\"0.2233\\\" error=\\\"0.0008\\\" /> </isotope> <isotope mass-number=\\\"106\\\"> <mass value=\\\"105.903484\\\" error=\\\"0.000005\\\" /> <abundance value=\\\"0.2733\\\" error=\\\"0.0003\\\" /> </isotope> <isotope mass-number=\\\"108\\\"> <mass value=\\\"107.903895\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.2646\\\" error=\\\"0.0009\\\" /> </isotope> <isotope mass-number=\\\"110\\\"> <mass value=\\\"109.905153\\\" error=\\\"0.000012\\\" /> <abundance value=\\\"0.1172\\\" error=\\\"0.0009\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ag\\\" atomic-number=\\\"47\\\"> <natural-abundance> <mass value=\\\"107.8682\\\" error=\\\"0.0002\\\" /> <isotope mass-number=\\\"107\\\"> <mass value=\\\"106.905093\\\" error=\\\"0.000006\\\" /> <abundance value=\\\"0.51839\\\" error=\\\"0.00008\\\" /> </isotope> <isotope mass-number=\\\"109\\\"> <mass value=\\\"108.904756\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.48161\\\" error=\\\"0.00008\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Cd\\\" atomic-number=\\\"48\\\"> <natural-abundance> <mass value=\\\"112.411\\\" error=\\\"0.008\\\" /> <isotope mass-number=\\\"106\\\"> <mass value=\\\"105.906458\\\" error=\\\"0.000006\\\" /> <abundance value=\\\"0.0125\\\" error=\\\"0.0006\\\" /> </isotope> <isotope mass-number=\\\"108\\\"> <mass value=\\\"107.904183\\\" error=\\\"0.000006\\\" /> <abundance value=\\\"0.0089\\\" error=\\\"0.0003\\\" /> </isotope> <isotope mass-number=\\\"110\\\"> <mass value=\\\"109.903006\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1249\\\" error=\\\"0.0018\\\" /> </isotope> <isotope mass-number=\\\"111\\\"> <mass value=\\\"110.904182\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1280\\\" error=\\\"0.0012\\\" /> </isotope> <isotope mass-number=\\\"112\\\"> <mass value=\\\"111.9027577\\\" error=\\\"0.0000030\\\" /> <abundance value=\\\"0.2413\\\" error=\\\"0.0021\\\" /> </isotope> <isotope mass-number=\\\"113\\\"> <mass value=\\\"112.9044014\\\" error=\\\"0.0000030\\\" /> <abundance value=\\\"0.1222\\\" error=\\\"0.0012\\\" /> </isotope> <isotope mass-number=\\\"114\\\"> <mass value=\\\"113.9033586\\\" error=\\\"0.0000030\\\" /> <abundance value=\\\"0.2873\\\" error=\\\"0.0042\\\" /> </isotope> <isotope mass-number=\\\"116\\\"> <mass value=\\\"115.904756\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0749\\\" error=\\\"0.0018\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"In\\\" atomic-number=\\\"49\\\"> <natural-abundance> <mass value=\\\"114.818\\\" error=\\\"0.003\\\" /> <isotope mass-number=\\\"113\\\"> <mass value=\\\"112.904062\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.0429\\\" error=\\\"0.0005\\\" /> </isotope> <isotope mass-number=\\\"115\\\"> <mass value=\\\"114.903879\\\" error=\\\"0.000040\\\" /> <abundance value=\\\"0.9571\\\" error=\\\"0.0005\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Sn\\\" atomic-number=\\\"50\\\"> <natural-abundance> <mass value=\\\"118.710\\\" error=\\\"0.007\\\" /> <isotope mass-number=\\\"112\\\"> <mass value=\\\"111.904822\\\" error=\\\"0.000005\\\" /> <abundance value=\\\"0.0097\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"114\\\"> <mass value=\\\"113.902783\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0066\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"115\\\"> <mass value=\\\"114.903347\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0034\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"116\\\"> <mass value=\\\"115.901745\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1454\\\" error=\\\"0.0009\\\" /> </isotope> <isotope mass-number=\\\"117\\\"> <mass value=\\\"116.902955\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0768\\\" error=\\\"0.0007\\\" /> </isotope> <isotope mass-number=\\\"118\\\"> <mass value=\\\"117.901608\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2422\\\" error=\\\"0.0009\\\" /> </isotope> <isotope mass-number=\\\"119\\\"> <mass value=\\\"118.903311\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0859\\\" error=\\\"0.0004\\\" /> </isotope> <isotope mass-number=\\\"120\\\"> <mass value=\\\"119.9021985\\\" error=\\\"0.0000027\\\" /> <abundance value=\\\"0.3258\\\" error=\\\"0.0009\\\" /> </isotope> <isotope mass-number=\\\"122\\\"> <mass value=\\\"121.9034411\\\" error=\\\"0.0000029\\\" /> <abundance value=\\\"0.0463\\\" error=\\\"0.0003\\\" /> </isotope> <isotope mass-number=\\\"124\\\"> <mass value=\\\"123.9052745\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.0579\\\" error=\\\"0.0005\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Sb\\\" atomic-number=\\\"51\\\"> <natural-abundance> <mass value=\\\"121.760\\\" error=\\\"0.001\\\" /> <isotope mass-number=\\\"121\\\"> <mass value=\\\"120.9038222\\\" error=\\\"0.0000026\\\" /> <abundance value=\\\"0.5721\\\" error=\\\"0.0005\\\" /> </isotope> <isotope mass-number=\\\"123\\\"> <mass value=\\\"122.9042160\\\" error=\\\"0.0000022\\\" /> <abundance value=\\\"0.4279\\\" error=\\\"0.0005\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Te\\\" atomic-number=\\\"52\\\"> <natural-abundance> <mass value=\\\"127.60\\\" error=\\\"0.03\\\" /> <isotope mass-number=\\\"120\\\"> <mass value=\\\"119.904026\\\" error=\\\"0.000011\\\" /> <abundance value=\\\"0.0009\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"122\\\"> <mass value=\\\"121.9030558\\\" error=\\\"0.0000029\\\" /> <abundance value=\\\"0.0255\\\" error=\\\"0.0012\\\" /> </isotope> <isotope mass-number=\\\"123\\\"> <mass value=\\\"122.9042711\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.0089\\\" error=\\\"0.0003\\\" /> </isotope> <isotope mass-number=\\\"124\\\"> <mass value=\\\"123.9028188\\\" error=\\\"0.0000016\\\" /> <abundance value=\\\"0.0474\\\" error=\\\"0.0014\\\" /> </isotope> <isotope mass-number=\\\"125\\\"> <mass value=\\\"124.9044241\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.0707\\\" error=\\\"0.0015\\\" /> </isotope> <isotope mass-number=\\\"126\\\"> <mass value=\\\"125.9033049\\\" error=\\\"0.0000020\\\" /> <abundance value=\\\"0.1884\\\" error=\\\"0.0025\\\" /> </isotope> <isotope mass-number=\\\"128\\\"> <mass value=\\\"127.9044615\\\" error=\\\"0.0000019\\\" /> <abundance value=\\\"0.3174\\\" error=\\\"0.0008\\\" /> </isotope> <isotope mass-number=\\\"130\\\"> <mass value=\\\"129.9062229\\\" error=\\\"0.0000021\\\" /> <abundance value=\\\"0.3408\\\" error=\\\"0.0062\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"I\\\" atomic-number=\\\"53\\\"> <natural-abundance> <mass value=\\\"126.90447\\\" error=\\\"0.00003\\\" /> <isotope mass-number=\\\"127\\\"> <mass value=\\\"126.904468\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Xe\\\" atomic-number=\\\"54\\\"> <natural-abundance> <mass value=\\\"131.293\\\" error=\\\"0.006\\\" /> <isotope mass-number=\\\"124\\\"> <mass value=\\\"123.9058954\\\" error=\\\"0.0000021\\\" /> <abundance value=\\\"0.000952\\\" error=\\\"0.000003\\\" /> </isotope> <isotope mass-number=\\\"126\\\"> <mass value=\\\"125.904268\\\" error=\\\"0.000007\\\" /> <abundance value=\\\"0.000890\\\" error=\\\"0.000002\\\" /> </isotope> <isotope mass-number=\\\"128\\\"> <mass value=\\\"127.9035305\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.019102\\\" error=\\\"0.000008\\\" /> </isotope> <isotope mass-number=\\\"129\\\"> <mass value=\\\"128.9047799\\\" error=\\\"0.0000009\\\" /> <abundance value=\\\"0.264006\\\" error=\\\"0.000082\\\" /> </isotope> <isotope mass-number=\\\"130\\\"> <mass value=\\\"129.9035089\\\" error=\\\"0.0000011\\\" /> <abundance value=\\\"0.040710\\\" error=\\\"0.000013\\\" /> </isotope> <isotope mass-number=\\\"131\\\"> <mass value=\\\"130.9050828\\\" error=\\\"0.0000018\\\" /> <abundance value=\\\"0.212324\\\" error=\\\"0.000030\\\" /> </isotope> <isotope mass-number=\\\"132\\\"> <mass value=\\\"131.9041546\\\" error=\\\"0.0000015\\\" /> <abundance value=\\\"0.269086\\\" error=\\\"0.000033\\\" /> </isotope> <isotope mass-number=\\\"134\\\"> <mass value=\\\"133.9053945\\\" error=\\\"0.0000009\\\" /> <abundance value=\\\"0.104357\\\" error=\\\"0.000021\\\" /> </isotope> <isotope mass-number=\\\"136\\\"> <mass value=\\\"135.907220\\\" error=\\\"0.000008\\\" /> <abundance value=\\\"0.088573\\\" error=\\\"0.000044\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Cs\\\" atomic-number=\\\"55\\\"> <natural-abundance> <mass value=\\\"132.90545\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"133\\\"> <mass value=\\\"132.905447\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ba\\\" atomic-number=\\\"56\\\"> <natural-abundance> <mass value=\\\"137.327\\\" error=\\\"0.007\\\" /> <isotope mass-number=\\\"130\\\"> <mass value=\\\"129.906311\\\" error=\\\"0.000007\\\" /> <abundance value=\\\"0.00106\\\" error=\\\"0.00001\\\" /> </isotope> <isotope mass-number=\\\"132\\\"> <mass value=\\\"131.905056\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.00101\\\" error=\\\"0.00001\\\" /> </isotope> <isotope mass-number=\\\"134\\\"> <mass value=\\\"133.904504\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.02417\\\" error=\\\"0.00018\\\" /> </isotope> <isotope mass-number=\\\"135\\\"> <mass value=\\\"134.905684\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.000003\\\" error=\\\"0.00012\\\" /> </isotope> <isotope mass-number=\\\"136\\\"> <mass value=\\\"135.904571\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.07854\\\" error=\\\"0.00024\\\" /> </isotope> <isotope mass-number=\\\"137\\\"> <mass value=\\\"136.905822\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.11232\\\" error=\\\"0.00024\\\" /> </isotope> <isotope mass-number=\\\"138\\\"> <mass value=\\\"137.905242\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.71698\\\" error=\\\"0.00042\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"La\\\" atomic-number=\\\"57\\\"> <natural-abundance> <mass value=\\\"138.9055\\\" error=\\\"0.0002\\\" /> <isotope mass-number=\\\"138\\\"> <mass value=\\\"137.907108\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.00090\\\" error=\\\"0.00001\\\" /> </isotope> <isotope mass-number=\\\"139\\\"> <mass value=\\\"138.906349\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.99910\\\" error=\\\"0.00001\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ce\\\" atomic-number=\\\"58\\\"> <natural-abundance> <mass value=\\\"140.116\\\" error=\\\"0.001\\\" /> <isotope mass-number=\\\"136\\\"> <mass value=\\\"135.907140\\\" error=\\\"0.000050\\\" /> <abundance value=\\\"0.00185\\\" error=\\\"0.00002\\\" /> </isotope> <isotope mass-number=\\\"138\\\"> <mass value=\\\"137.905986\\\" error=\\\"0.000011\\\" /> <abundance value=\\\"0.00251\\\" error=\\\"0.00002\\\" /> </isotope> <isotope mass-number=\\\"140\\\"> <mass value=\\\"139.905\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.88450\\\" error=\\\"0.00051\\\" /> </isotope> <isotope mass-number=\\\"142\\\"> <mass value=\\\"141.909241\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.11114\\\" error=\\\"0.00051\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Pr\\\" atomic-number=\\\"59\\\"> <natural-abundance> <mass value=\\\"140.90765\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"141\\\"> <mass value=\\\"140.907648\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Nd\\\" atomic-number=\\\"60\\\"> <natural-abundance> <mass value=\\\"144.24\\\" error=\\\"0.03\\\" /> <isotope mass-number=\\\"142\\\"> <mass value=\\\"141.907719\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.272\\\" error=\\\"0.005\\\" /> </isotope> <isotope mass-number=\\\"143\\\"> <mass value=\\\"142.909810\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.122\\\" error=\\\"0.002\\\" /> </isotope> <isotope mass-number=\\\"144\\\"> <mass value=\\\"143.910083\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.238\\\" error=\\\"0.003\\\" /> </isotope> <isotope mass-number=\\\"145\\\"> <mass value=\\\"144.912569\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.083\\\" error=\\\"0.001\\\" /> </isotope> <isotope mass-number=\\\"146\\\"> <mass value=\\\"145.913113\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.172\\\" error=\\\"0.003\\\" /> </isotope> <isotope mass-number=\\\"148\\\"> <mass value=\\\"147.916889\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.057\\\" error=\\\"0.001\\\" /> </isotope> <isotope mass-number=\\\"150\\\"> <mass value=\\\"149.920887\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.056\\\" error=\\\"0.002\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Sm\\\" atomic-number=\\\"62\\\"> <natural-abundance> <mass value=\\\"150.36\\\" error=\\\"0.03\\\" /> <isotope mass-number=\\\"144\\\"> <mass value=\\\"143.911996\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.0307\\\" error=\\\"0.0007\\\" /> </isotope> <isotope mass-number=\\\"147\\\"> <mass value=\\\"146.914894\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1499\\\" error=\\\"0.0018\\\" /> </isotope> <isotope mass-number=\\\"148\\\"> <mass value=\\\"147.914818\\\" error=\\\"0.1124\\\" /> <abundance value=\\\"0.1124\\\" error=\\\"0.0010\\\" /> </isotope> <isotope mass-number=\\\"149\\\"> <mass value=\\\"148.917180\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1382\\\" error=\\\"0.0007\\\" /> </isotope> <isotope mass-number=\\\"150\\\"> <mass value=\\\"149.917272\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0738\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"152\\\"> <mass value=\\\"151.919729\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2675\\\" error=\\\"0.0016\\\" /> </isotope> <isotope mass-number=\\\"154\\\"> <mass value=\\\"153.922206\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2275\\\" error=\\\"0.0029\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Eu\\\" atomic-number=\\\"63\\\"> <natural-abundance> <mass value=\\\"151.964\\\" error=\\\"0.001\\\" /> <isotope mass-number=\\\"151\\\"> <mass value=\\\"150.919846\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.4781\\\" error=\\\"0.0006\\\" /> </isotope> <isotope mass-number=\\\"153\\\"> <mass value=\\\"152.921227\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.5219\\\" error=\\\"0.0006\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Gd\\\" atomic-number=\\\"64\\\"> <natural-abundance> <mass value=\\\"157.25\\\" error=\\\"0.03\\\" /> <isotope mass-number=\\\"152\\\"> <mass value=\\\"151.919789\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0020\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"154\\\"> <mass value=\\\"153.920862\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0218\\\" error=\\\"0.0003\\\" /> </isotope> <isotope mass-number=\\\"155\\\"> <mass value=\\\"154.922619\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1480\\\" error=\\\"0.0012\\\" /> </isotope> <isotope mass-number=\\\"156\\\"> <mass value=\\\"155.922120\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2047\\\" error=\\\"0.0009\\\" /> </isotope> <isotope mass-number=\\\"157\\\"> <mass value=\\\"156.923957\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1565\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"158\\\"> <mass value=\\\"157.924101\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2484\\\" error=\\\"0.0007\\\" /> </isotope> <isotope mass-number=\\\"160\\\"> <mass value=\\\"159.927051\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2186\\\" error=\\\"0.0019\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Tb\\\" atomic-number=\\\"65\\\"> <natural-abundance> <mass value=\\\"158.92534\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"159\\\"> <mass value=\\\"158.925343\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Dy\\\" atomic-number=\\\"66\\\"> <natural-abundance> <mass value=\\\"162.500\\\" error=\\\"0.001\\\" /> <isotope mass-number=\\\"156\\\"> <mass value=\\\"155.924278\\\" error=\\\"0.000007\\\" /> <abundance value=\\\"0.00056\\\" error=\\\"0.00003\\\" /> </isotope> <isotope mass-number=\\\"158\\\"> <mass value=\\\"157.924405\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.00095\\\" error=\\\"0.00003\\\" /> </isotope> <isotope mass-number=\\\"160\\\"> <mass value=\\\"159.925194\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.02329\\\" error=\\\"0.00018\\\" /> </isotope> <isotope mass-number=\\\"161\\\"> <mass value=\\\"160.926930\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.18889\\\" error=\\\"0.00042\\\" /> </isotope> <isotope mass-number=\\\"162\\\"> <mass value=\\\"161.926795\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.25475\\\" error=\\\"0.00036\\\" /> </isotope> <isotope mass-number=\\\"163\\\"> <mass value=\\\"162.928728\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.24896\\\" error=\\\"0.00042\\\" /> </isotope> <isotope mass-number=\\\"164\\\"> <mass value=\\\"163.929171\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.28260\\\" error=\\\"0.00054\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ho\\\" atomic-number=\\\"67\\\"> <natural-abundance> <mass value=\\\"164.93032\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"165\\\"> <mass value=\\\"164.930319\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Er\\\" atomic-number=\\\"68\\\"> <natural-abundance> <mass value=\\\"167.259\\\" error=\\\"0.003\\\" /> <isotope mass-number=\\\"162\\\"> <mass value=\\\"161.928775\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.00139\\\" error=\\\"0.00005\\\" /> </isotope> <isotope mass-number=\\\"164\\\"> <mass value=\\\"163.929197\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.01601\\\" error=\\\"0.00003\\\" /> </isotope> <isotope mass-number=\\\"166\\\"> <mass value=\\\"165.930290\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.33503\\\" error=\\\"0.00036\\\" /> </isotope> <isotope mass-number=\\\"167\\\"> <mass value=\\\"166.932046\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.22869\\\" error=\\\"0.00009\\\" /> </isotope> <isotope mass-number=\\\"168\\\"> <mass value=\\\"167.932368\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.26978\\\" error=\\\"0.00018\\\" /> </isotope> <isotope mass-number=\\\"170\\\"> <mass value=\\\"169.935461\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.14910\\\" error=\\\"0.00036\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Tm\\\" atomic-number=\\\"69\\\"> <natural-abundance> <mass value=\\\"168.93421\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"169\\\"> <mass value=\\\"168.934211\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Yb\\\" atomic-number=\\\"70\\\"> <natural-abundance> <mass value=\\\"173.04\\\" error=\\\"0.03\\\" /> <isotope mass-number=\\\"168\\\"> <mass value=\\\"167.933895\\\" error=\\\"0.000005\\\" /> <abundance value=\\\"0.0013\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"170\\\"> <mass value=\\\"169.934759\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0304\\\" error=\\\"0.0015\\\" /> </isotope> <isotope mass-number=\\\"171\\\"> <mass value=\\\"170.936323\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1428\\\" error=\\\"0.0057\\\" /> </isotope> <isotope mass-number=\\\"172\\\"> <mass value=\\\"171.936378\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2183\\\" error=\\\"0.0067\\\" /> </isotope> <isotope mass-number=\\\"173\\\"> <mass value=\\\"172.938207\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1613\\\" error=\\\"0.0027\\\" /> </isotope> <isotope mass-number=\\\"174\\\"> <mass value=\\\"173.938858\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.3183\\\" error=\\\"0.0092\\\" /> </isotope> <isotope mass-number=\\\"176\\\"> <mass value=\\\"175.942569\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1276\\\" error=\\\"0.0041\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Lu\\\" atomic-number=\\\"71\\\"> <natural-abundance> <mass value=\\\"174.967\\\" error=\\\"0.001\\\" /> <isotope mass-number=\\\"175\\\"> <mass value=\\\"174.9407682\\\" error=\\\"0.0000028\\\" /> <abundance value=\\\"0.9741\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"176\\\"> <mass value=\\\"175.9426827\\\" error=\\\"0.0000028\\\" /> <abundance value=\\\"0.0259\\\" error=\\\"0.0002\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Hf\\\" atomic-number=\\\"72\\\"> <natural-abundance> <mass value=\\\"178.49\\\" error=\\\"0.02\\\" /> <isotope mass-number=\\\"174\\\"> <mass value=\\\"173.940042\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.0016\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"176\\\"> <mass value=\\\"175.941403\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0526\\\" error=\\\"0.0007\\\" /> </isotope> <isotope mass-number=\\\"177\\\"> <mass value=\\\"176.9432204\\\" error=\\\"0.0000027\\\" /> <abundance value=\\\"0.1860\\\" error=\\\"0.0009\\\" /> </isotope> <isotope mass-number=\\\"178\\\"> <mass value=\\\"177.9436981\\\" error=\\\"0.0000027\\\" /> <abundance value=\\\"0.2728\\\" error=\\\"0.0007\\\" /> </isotope> <isotope mass-number=\\\"179\\\"> <mass value=\\\"178.9488154\\\" error=\\\"0.0000027\\\" /> <abundance value=\\\"0.1362\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"180\\\"> <mass value=\\\"179.9465488\\\" error=\\\"0.0000027\\\" /> <abundance value=\\\"0.3508\\\" error=\\\"0.0016\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ta\\\" atomic-number=\\\"73\\\"> <natural-abundance> <mass value=\\\"180.9479\\\" error=\\\"0.0001\\\" /> <isotope mass-number=\\\"180\\\"> <mass value=\\\"179.947466\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.00012\\\" error=\\\"0.00002\\\" /> </isotope> <isotope mass-number=\\\"181\\\"> <mass value=\\\"180.947996\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.99988\\\" error=\\\"0.00002\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"W\\\" atomic-number=\\\"74\\\"> <natural-abundance> <mass value=\\\"183.84\\\" error=\\\"0.01\\\" /> <isotope mass-number=\\\"180\\\"> <mass value=\\\"179.946706\\\" error=\\\"0.000005\\\" /> <abundance value=\\\"0.0012\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"182\\\"> <mass value=\\\"181.948205\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.265\\\" error=\\\"0.0016\\\" /> </isotope> <isotope mass-number=\\\"183\\\"> <mass value=\\\"182.9502242\\\" error=\\\"0.0000030\\\" /> <abundance value=\\\"0.1431\\\" error=\\\"0.0004\\\" /> </isotope> <isotope mass-number=\\\"184\\\"> <mass value=\\\"183.9509323\\\" error=\\\"0.0000030\\\" /> <abundance value=\\\"0.3064\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"186\\\"> <mass value=\\\"185.954362\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2843\\\" error=\\\"0.0019\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Re\\\" atomic-number=\\\"75\\\"> <natural-abundance> <mass value=\\\"186.207\\\" error=\\\"0.001\\\" /> <isotope mass-number=\\\"185\\\"> <mass value=\\\"184.952955\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.3740\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"187\\\"> <mass value=\\\"186.9557505\\\" error=\\\"0.0000030\\\" /> <abundance value=\\\"0.6260\\\" error=\\\"0.0002\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Os\\\" atomic-number=\\\"76\\\"> <natural-abundance> <mass value=\\\"190.23\\\" error=\\\"0.03\\\" /> <isotope mass-number=\\\"184\\\"> <mass value=\\\"183.952491\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0002\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"186\\\"> <mass value=\\\"185.953838\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0159\\\" error=\\\"0.0003\\\" /> </isotope> <isotope mass-number=\\\"187\\\"> <mass value=\\\"186.9557476\\\" error=\\\"0.0000030\\\" /> <abundance value=\\\"0.0196\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"188\\\"> <mass value=\\\"187.9558357\\\" error=\\\"0.0000030\\\" /> <abundance value=\\\"0.1324\\\" error=\\\"0.0008\\\" /> </isotope> <isotope mass-number=\\\"189\\\"> <mass value=\\\"188.958145\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1615\\\" error=\\\"0.0005\\\" /> </isotope> <isotope mass-number=\\\"190\\\"> <mass value=\\\"189.958445\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2626\\\" error=\\\"0.0002\\\" /> </isotope> <isotope mass-number=\\\"192\\\"> <mass value=\\\"191.961479\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.4078\\\" error=\\\"0.0019\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Ir\\\" atomic-number=\\\"77\\\"> <natural-abundance> <mass value=\\\"192.217\\\" error=\\\"0.003\\\" /> <isotope mass-number=\\\"191\\\"> <mass value=\\\"190.960591\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.373\\\" error=\\\"0.002\\\" /> </isotope> <isotope mass-number=\\\"193\\\"> <mass value=\\\"192.962923\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.627\\\" error=\\\"0.002\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Pt\\\" atomic-number=\\\"78\\\"> <natural-abundance> <mass value=\\\"195.078\\\" error=\\\"0.002\\\" /> <isotope mass-number=\\\"190\\\"> <mass value=\\\"189.959930\\\" error=\\\"0.000007\\\" /> <abundance value=\\\"0.00014\\\" error=\\\"0.00001\\\" /> </isotope> <isotope mass-number=\\\"192\\\"> <mass value=\\\"191.961035\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.00782\\\" error=\\\"0.00007\\\" /> </isotope> <isotope mass-number=\\\"194\\\"> <mass value=\\\"193.962663\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.32967\\\" error=\\\"0.00099\\\" /> </isotope> <isotope mass-number=\\\"195\\\"> <mass value=\\\"194.964774\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.33832\\\" error=\\\"0.00010\\\" /> </isotope> <isotope mass-number=\\\"196\\\"> <mass value=\\\"195.964934\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.25242\\\" error=\\\"0.00041\\\" /> </isotope> <isotope mass-number=\\\"198\\\"> <mass value=\\\"197.967875\\\" error=\\\"0.000005\\\" /> <abundance value=\\\"0.07163\\\" error=\\\"0.00055\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Au\\\" atomic-number=\\\"79\\\"> <natural-abundance> <mass value=\\\"196.96655\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"197\\\"> <mass value=\\\"196.966551\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Hg\\\" atomic-number=\\\"80\\\"> <natural-abundance> <mass value=\\\"200.59\\\" error=\\\"0.02\\\" /> <isotope mass-number=\\\"196\\\"> <mass value=\\\"195.965814\\\" error=\\\"0.000004\\\" /> <abundance value=\\\"0.0015\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"198\\\"> <mass value=\\\"197.966752\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0997\\\" error=\\\"0.0020\\\" /> </isotope> <isotope mass-number=\\\"199\\\"> <mass value=\\\"198.968262\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1687\\\" error=\\\"0.0022\\\" /> </isotope> <isotope mass-number=\\\"200\\\"> <mass value=\\\"199.968309\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2310\\\" error=\\\"0.0019\\\" /> </isotope> <isotope mass-number=\\\"201\\\"> <mass value=\\\"200.970285\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.1318\\\" error=\\\"0.0009\\\" /> </isotope> <isotope mass-number=\\\"202\\\"> <mass value=\\\"201.970625\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2986\\\" error=\\\"0.0026\\\" /> </isotope> <isotope mass-number=\\\"204\\\"> <mass value=\\\"203.973475\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.0687\\\" error=\\\"0.0015\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Tl\\\" atomic-number=\\\"81\\\"> <natural-abundance> <mass value=\\\"204.3833\\\" error=\\\"0.0002\\\" /> <isotope mass-number=\\\"203\\\"> <mass value=\\\"202.972329\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.2952\\\" error=\\\"0.0001\\\" /> </isotope> <isotope mass-number=\\\"205\\\"> <mass value=\\\"204.974412\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.7048\\\" error=\\\"0.0001\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Pb\\\" atomic-number=\\\"82\\\"> <natural-abundance> <mass value=\\\"207.2\\\" error=\\\"0.1\\\" /> <isotope mass-number=\\\"204\\\"> <mass value=\\\"203.973028\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.014\\\" error=\\\"0.001\\\" /> </isotope> <isotope mass-number=\\\"206\\\"> <mass value=\\\"205.974449\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.241\\\" error=\\\"0.001\\\" /> </isotope> <isotope mass-number=\\\"207\\\"> <mass value=\\\"206.975880\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.221\\\" error=\\\"0.001\\\" /> </isotope> <isotope mass-number=\\\"208\\\"> <mass value=\\\"207.976636\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"0.524\\\" error=\\\"0.001\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Bi\\\" atomic-number=\\\"83\\\"> <natural-abundance> <mass value=\\\"208.98038\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"209\\\"> <mass value=\\\"208.980384\\\" error=\\\"0.000003\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Th\\\" atomic-number=\\\"90\\\"> <natural-abundance> <mass value=\\\"232.0381\\\" error=\\\"0.0001\\\" /> <isotope mass-number=\\\"232\\\"> <mass value=\\\"232.0380495\\\" error=\\\"0.0000022\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"Pa\\\" atomic-number=\\\"91\\\"> <natural-abundance> <mass value=\\\"231.03588\\\" error=\\\"0.00002\\\" /> <isotope mass-number=\\\"231\\\"> <mass value=\\\"231.03588\\\" error=\\\"0.00002\\\" /> <abundance value=\\\"1\\\" error=\\\"0\\\" /> </isotope> </natural-abundance> </entry><entry symbol=\\\"U\\\" atomic-number=\\\"92\\\"> <natural-abundance> <mass value=\\\"238.02891\\\" error=\\\"0.00003\\\" /> <isotope mass-number=\\\"234\\\"> <mass value=\\\"234.0409447\\\" error=\\\"0.0000022\\\" /> <abundance value=\\\"0.000054\\\" error=\\\"0.000005\\\" /> </isotope> <isotope mass-number=\\\"235\\\"> <mass value=\\\"235.0439222\\\" error=\\\"0.0000021\\\" /> <abundance value=\\\"0.007204\\\" error=\\\"0.000006\\\" /> </isotope> <isotope mass-number=\\\"238\\\"> <mass value=\\\"238.0507835\\\" error=\\\"0.0000022\\\" /> <abundance value=\\\"0.992742\\\" error=\\\"0.000010\\\" /> </isotope> </natural-abundance> </entry></atomic-mass-table>\";\n try {\n// this.document = DocumentBuilderFactory.newInstance().newDocumentBuilder().parse(in);\n this.document = XMLParser.parse(xmlContent);\n } catch (Exception e) {\n throw new RuntimeException(\"Error reading atomic_system.xml.\");\n }\n\n NodeList nodes = document.getElementsByTagName(\"entry\");\n\n for (int i = 0; i < nodes.getLength(); i++) {\n Node node = nodes.item(i);\n\n String symbol = node.getAttributes().getNamedItem(\"symbol\").getNodeValue();\n\n entries.put(symbol, new Entry(node));\n }\n }",
"public Document parseFile(InputStream inputStream) {\r\n \r\n try {\r\n setDocument(docBuilder.parse(inputStream));\r\n }\r\n catch (SAXException e) {\r\n log.debug(\"Wrong XML file structure: \" + e.getMessage());\r\n return null;\r\n }\r\n catch (IOException e) {\r\n \te.printStackTrace();\r\n log.debug(\"Could not read source file: \" + e.getMessage());\r\n }\r\n log.debug(\"XML file parsed\");\r\n return getDocument();\r\n }",
"public XMLReader()\r\n {\r\n \r\n String filePathHead = \"\";\r\n\r\n Path inputPath = Paths.get(\"src\\\\dataFiles\");\r\n\r\n try\r\n {\r\n filePathHead = inputPath.toRealPath().toString();\r\n System.out.println(\"PATH: \" + inputPath.toRealPath().toString());\r\n }\r\n catch (NoSuchFileException x)\r\n {\r\n System.err.format(\"%s: no such\" + \" file or directory%n\", filePathHead);\r\n // Logic for case when file doesn't exist.\r\n }\r\n catch (IOException x)\r\n {\r\n System.err.format(\"%s%n\", x);\r\n // Logic for other sort of file error.\r\n }\r\n }",
"public void initializeXmlParser(InputStream in) throws XmlPullParserException, IOException {\n\n try {\n\t\t\tXmlPullParser parser = Xml.newPullParser();\n\t\t\tparser.setFeature(XmlPullParser.FEATURE_PROCESS_NAMESPACES, false);\n\t\t\tparser.setInput(in, null);\n\t\t\tparser.nextTag();\n\t\t\treadAndApplyTags(parser);\n\t\t} finally {\n\t\t\tin.close();\n\t\t}\n\t}",
"public void open(){\n\t\ttry {\n\t\t\tdocFactory = DocumentBuilderFactory.newInstance();\n\t\t\tdocBuilder = docFactory.newDocumentBuilder();\n\t\t\tdoc = docBuilder.parse(ManipXML.class.getResourceAsStream(path));\n\t\t\t\n\t\t} catch (ParserConfigurationException e) {\n\t\t\te.printStackTrace();\n\t\t} catch (SAXException e) {\n\t\t\te.printStackTrace();\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"private void loadData(final String filePath)\r\n {\r\n try\r\n {\r\n File fXMLFile = new File(filePath);\r\n DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\r\n DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();\r\n Document doc = dBuilder.parse(fXMLFile);\r\n parseXMLDocument(doc);\r\n }\r\n catch (ParserConfigurationException ex)\r\n {\r\n System.err.println(\"\\t ParserConfigurationException caught at XMLReader.loadData\");\r\n ex.printStackTrace();\r\n }\r\n catch (SAXException ex)\r\n {\r\n System.err.println(\"\\t SAXException caught at XMLReader.loadData\");\r\n ex.printStackTrace();\r\n }\r\n catch (IOException ex)\r\n {\r\n System.err.println(\"\\t IOException caught at XMLReader.loadData\");\r\n ex.printStackTrace();\r\n }\r\n }",
"public void parseXml(String file) {\n\n try {\n\n debug(\"\\n\\nIn the beginning God created the heaven and the world...\\n\\n\");\n\n File fXmlFile = new File(\"./levels/\" + file);\n DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\n DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();\n Document doc = dBuilder.parse(fXmlFile);\n\n doc.getDocumentElement().normalize();\n debug(\"Chosen entity: \" + doc.getDocumentElement().getNodeName());\n\n NodeList placeList = doc.getElementsByTagName(\"place\");\n NodeList passageList = doc.getElementsByTagName(\"passage\");\n NodeList furnitureList = doc.getElementsByTagName(\"furniture\");\n NodeList storyList = doc.getElementsByTagName(\"story\");\n\n // Create object arrays\n ArrayList<Place> places = new ArrayList<>();\n ArrayList<Item> items = new ArrayList<>();\n ArrayList<Passage> passages = new ArrayList<>();\n ArrayList<Furniture> furnitures = new ArrayList<Furniture>();\n\n // parse story text\n Node storyNode = storyList.item(0);\n Element storyElement = (Element) storyNode;\n debug(\"Intro: \" + storyElement.getElementsByTagName(\"introduction\").item(0).getTextContent());\n debug(\"Level: \" + storyElement.getElementsByTagName(\"name\").item(0).getTextContent());\n debug(\"Version: \" + storyElement.getElementsByTagName(\"version\").item(0).getTextContent());\n // add story elements to world\n world.setIntroduction(\n storyElement.getElementsByTagName(\"introduction\").item(0).getTextContent());\n world.setLevelName(storyElement.getElementsByTagName(\"name\").item(0).getTextContent());\n world.setLevelVersion(storyElement.getElementsByTagName(\"version\").item(0).getTextContent());\n\n // parse all existing Places\n for (int placeCounter = 0; placeCounter < placeList.getLength(); placeCounter++) {\n Node placeNode = placeList.item(placeCounter);\n\n debug(\"\\nCurrent Element: \" + placeNode.getNodeName());\n\n if (placeNode.getNodeType() == Node.ELEMENT_NODE) {\n Element placeElement = (Element) placeNode;\n\n debug(\"- Ending: \" + placeElement.getAttribute(\"end\"));\n debug(\"- id: \" + placeElement.getAttribute(\"id\"));\n debug(\"- Name: \" + placeElement.getElementsByTagName(\"name\").item(0).getTextContent());\n debug(\"- Description: \"\n + placeElement.getElementsByTagName(\"description\").item(0).getTextContent());\n\n // Create Places.\n places.add(new Place(placeElement.getElementsByTagName(\"name\").item(0).getTextContent(),\n placeElement.getElementsByTagName(\"description\").item(0).getTextContent().replace(\"\\\\n\", \"\\n\")));\n\n // add EndingPlace to World, set endingText to Places' Description\n if (placeElement.getAttribute(\"end\").equals(\"bad\")) {\n world.addBadEnding(places.get(placeCounter),\n places.get(placeCounter).getDescription());\n } else if(placeElement.getAttribute(\"end\").equals(\"good\")) {\n world.addGoodEnding(places.get(placeCounter),\n places.get(placeCounter).getDescription());\n }\n \n // parse all existing Place Items\n NodeList itemList = placeElement.getElementsByTagName(\"item\");\n\n for (int itemCounter = 0; itemCounter < itemList.getLength(); itemCounter++) {\n Node itemNode = itemList.item(itemCounter);\n\n Element itemElement = (Element) itemNode;\n\n debug(\"- Item\" + itemCounter + \":\");\n debug(\"- - Name: \" + itemElement.getElementsByTagName(\"name\").item(0).getTextContent());\n debug(\"- - Description: \"\n + itemElement.getElementsByTagName(\"description\").item(0).getTextContent());\n\n // Create items.\n items.add(new Item(itemElement.getElementsByTagName(\"name\").item(0).getTextContent(),\n itemElement.getElementsByTagName(\"description\").item(0).getTextContent()));\n // Set items in current place.\n places.get(placeCounter).addObjectToPlace(getIncludedItem(itemElement, items));\n\n }\n }\n }\n\n // parse all furniture\n for (int furnitureCounter = 0; furnitureCounter < furnitureList\n .getLength(); furnitureCounter++) {\n Node furnitureNode = furnitureList.item(furnitureCounter);\n\n Element furnitureElement = (Element) furnitureNode;\n\n debug(\"\\nCurrent Element: \" + furnitureNode.getNodeName());\n\n debug(\"- Furniture\" + furnitureCounter);\n debug(\"- - In Place: \"\n + furnitureElement.getElementsByTagName(\"in-place\").item(0).getTextContent());\n debug(\n \"- - Name: \" + furnitureElement.getElementsByTagName(\"name\").item(0).getTextContent());\n debug(\"- - Description: \"\n + furnitureElement.getElementsByTagName(\"description\").item(0).getTextContent());\n\n // Create furniture objects\n furnitures.add(\n new Furniture(furnitureElement.getElementsByTagName(\"name\").item(0).getTextContent(), // name\n furnitureElement.getElementsByTagName(\"description\").item(0).getTextContent(), // description\n furnitureElement.getElementsByTagName(\"in-place\").item(0).getTextContent()));\n\n NodeList furnitureItemList = furnitureElement.getElementsByTagName(\"content-item\");\n\n // parse all Furniture Items\n for (int furnitureItemCounter = 0; furnitureItemCounter < furnitureItemList\n .getLength(); furnitureItemCounter++) {\n Node furnitureItemNode = furnitureItemList.item(furnitureItemCounter);\n\n Element furnitureItemElement = (Element) furnitureItemNode;\n\n debug(\"- - Content Items:\");\n debug(\"- - - Name: \"\n + furnitureItemElement.getElementsByTagName(\"name\").item(0).getTextContent());\n debug(\"- - - Description: \"\n + furnitureItemElement.getElementsByTagName(\"description\").item(0).getTextContent());\n\n addItems(furnitureItemElement, furnitures, items, furnitureCounter);\n\n }\n\n NodeList furnitureObstacleList = furnitureElement.getElementsByTagName(\"obstacle\");\n\n // parse all Furniture Obstacles\n for (int furnitureObstacleCounter = 0; furnitureObstacleCounter < furnitureObstacleList\n .getLength(); furnitureObstacleCounter++) {\n Node furnitureObstacleNode = furnitureObstacleList.item(furnitureObstacleCounter);\n\n Element furnitureObstacleElement = (Element) furnitureObstacleNode;\n\n debug(\"- - Obstacle:\");\n debug(\"- - - Description: \" + furnitureObstacleElement.getElementsByTagName(\"description\")\n .item(0).getTextContent());\n debug(\"- - - Resolution: \" + furnitureObstacleElement.getElementsByTagName(\"resolution\")\n .item(0).getTextContent());\n // debug(\"- - - Requirement: \" +\n // furnitureObstacleElement.getElementsByTagName(\"requiredItem\").item(0).getTextContent());\n\n // create furniture obstacle\n if (furnitureObstacleElement.getAttribute(\"type\").equals(\"double\")) {\n // double Item obstacle\n furnitures.get(furnitureCounter)\n .setObstalce(new DoubleItemObstacle(\"\",\n furnitureObstacleElement.getElementsByTagName(\"description\").item(0)\n .getTextContent(),\n furnitureObstacleElement.getElementsByTagName(\"resolution\").item(0)\n .getTextContent(),\n getRequiredItem(items,\n furnitureObstacleElement.getElementsByTagName(\"requiredItem\").item(0)\n .getTextContent()),\n getRequiredItem(items, furnitureObstacleElement\n .getElementsByTagName(\"additionalItem\").item(0).getTextContent())));\n\n } else if (furnitureObstacleElement.getAttribute(\"type\").equals(\"riddle\")) {\n // riddle Obstacle\n furnitures.get(furnitureCounter)\n .setObstalce(new RiddleObstacle(\"\",\n furnitureObstacleElement.getElementsByTagName(\"description\").item(0)\n .getTextContent(),\n furnitureObstacleElement.getElementsByTagName(\"resolution\").item(0)\n .getTextContent(),\n furnitureObstacleElement.getElementsByTagName(\"requiredAnswer\").item(0)\n .getTextContent()));\n\n } else {\n // normal Obstacle\n furnitures.get(furnitureCounter)\n .setObstalce(new ItemObstacle(\"\",\n furnitureObstacleElement.getElementsByTagName(\"description\").item(0)\n .getTextContent(),\n furnitureObstacleElement.getElementsByTagName(\"resolution\").item(0)\n .getTextContent(),\n getRequiredItem(items, furnitureObstacleElement\n .getElementsByTagName(\"requiredItem\").item(0).getTextContent())));\n }\n // add damage points to obstacle\n if (!furnitureObstacleElement.getAttribute(\"damage\").equals(\"\")) {\n passages.get(furnitureCounter).getObstacle()\n .setDamagepoints(Integer.parseInt(furnitureObstacleElement.getAttribute(\"damage\")));\n }\n\n }\n\n }\n\n // Add current furniture to its containing Place\n setFurnitureInPlace(furnitures, places);\n\n // parse all existing passages\n for (int passageCounter = 0; passageCounter < passageList.getLength(); passageCounter++) {\n Node passageNode = passageList.item(passageCounter);\n\n debug(\"\\nCurrent Element: \" + passageNode.getNodeName());\n\n if (passageNode.getNodeType() == Node.ELEMENT_NODE) {\n Element passageElement = (Element) passageNode;\n\n debug(\"- id: \" + passageElement.getAttribute(\"id\"));\n debug(\"- Name: \" + passageElement.getElementsByTagName(\"name\").item(0).getTextContent());\n debug(\"- Description: \"\n + passageElement.getElementsByTagName(\"description\").item(0).getTextContent());\n debug(\"- Comes from: \"\n + passageElement.getElementsByTagName(\"comeFrom\").item(0).getTextContent());\n debug(\"- Connects to: \"\n + passageElement.getElementsByTagName(\"connectTo\").item(0).getTextContent());\n\n // Create Passage with connected Places.\n passages\n .add(new Passage(passageElement.getElementsByTagName(\"name\").item(0).getTextContent(),\n passageElement.getElementsByTagName(\"description\").item(0).getTextContent(),\n getFromPlace(passageElement, places), // from this Place\n getFollowPlace(passageElement, places)) // to that Place\n );\n\n // parse all existing Passage Obstacles\n NodeList obstacleList = passageElement.getElementsByTagName(\"obstacle\");\n\n for (int obstacleCounter = 0; obstacleCounter < obstacleList\n .getLength(); obstacleCounter++) {\n Node obstacleNode = obstacleList.item(obstacleCounter);\n\n Element obstacleElement = (Element) obstacleNode;\n\n debug(\"- Obstacle\" + passageCounter + \":\");\n debug(\"- - Description: \"\n + obstacleElement.getElementsByTagName(\"description\").item(0).getTextContent());\n debug(\"- - Resolution: \"\n + obstacleElement.getElementsByTagName(\"resolution\").item(0).getTextContent());\n // debug(\"- - Required Item: \" +\n // obstacleElement.getElementsByTagName(\"requiredItem\").item(0).getTextContent());\n\n // Create the obstacle for each passage.\n if (obstacleElement.getAttribute(\"type\").equals(\"double\")) {\n // double Item obstacle\n passages.get(passageCounter)\n .setObstacle(new DoubleItemObstacle(\"\",\n obstacleElement.getElementsByTagName(\"description\").item(0).getTextContent(),\n obstacleElement.getElementsByTagName(\"resolution\").item(0).getTextContent(),\n getRequiredItem(items,\n obstacleElement.getElementsByTagName(\"requiredItem\").item(0)\n .getTextContent()),\n getRequiredItem(items, obstacleElement.getElementsByTagName(\"additionalItem\")\n .item(0).getTextContent())));\n\n } else if (obstacleElement.getAttribute(\"type\").equals(\"riddle\")) {\n // riddle Obstacle\n passages.get(passageCounter).setObstacle(new RiddleObstacle(\"\",\n obstacleElement.getElementsByTagName(\"description\").item(0).getTextContent(),\n obstacleElement.getElementsByTagName(\"resolution\").item(0).getTextContent(),\n obstacleElement.getElementsByTagName(\"requiredAnswer\").item(0).getTextContent()));\n\n } else {\n // normal Obstacle\n passages.get(passageCounter)\n .setObstacle(new ItemObstacle(\"\",\n obstacleElement.getElementsByTagName(\"description\").item(0).getTextContent(),\n obstacleElement.getElementsByTagName(\"resolution\").item(0).getTextContent(),\n getRequiredItem(items, obstacleElement.getElementsByTagName(\"requiredItem\")\n .item(0).getTextContent())));\n }\n\n // add damage points to obstacle\n if (!obstacleElement.getAttribute(\"damage\").equals(\"\")) {\n passages.get(passageCounter).getObstacle()\n .setDamagepoints(Integer.parseInt(obstacleElement.getAttribute(\"damage\")));\n }\n\n\n }\n }\n }\n\n startingPlace = places.get(0);\n\n // Add Places to GameWorld\n addPlacesToWorld(places, world);\n\n // set starting Place in GameWorld\n if (world.getStartingPlace() == null) {\n world.setStartingPlace(startingPlace);\n }\n\n debug(\"\\n\\n\");\n debug(\"World has successfully been created! God saw all that he had made, and it was good.\");\n debug(\"\\n\\n\\n\\n\");\n\n } catch (Exception e) {\n e.printStackTrace();\n }\n\n }",
"void processElement(File documentPath) \n\t\t\tthrows XMLFormatException;",
"public void init() { \n\t\ttry { \n\t\t\tDocumentBuilderFactory factory = DocumentBuilderFactory.newInstance(); \n\t\t\tDocumentBuilder builder = factory.newDocumentBuilder(); \n\t\t\tthis.document = builder.newDocument(); \n\t\t\tlogger.info(\"initilize the document success.\");\n\t\t} catch (ParserConfigurationException e) { \n\t\t\t\n\t\t\tlogger.error(e.getMessage());\n\t\t} \n\t}",
"private void loadFromXml(String fileName) throws IOException {\n\t\tElement root = new XmlReader().parse(Gdx.files.internal(fileName));\n\n\t\tthis.name = root.get(\"name\");\n\t\tGdx.app.log(\"Tactic\", \"Loading \" + this.name + \"...\");\n\n\t\tArray<Element> players = root.getChildrenByName(\"player\");\n\t\tint playerIndex = 0;\n\t\tfor (Element player : players) {\n\t\t\t//int shirt = player.getInt(\"shirt\"); // shirt number\n\t\t\t//Gdx.app.log(\"Tactic\", \"Location for player number \" + shirt);\n\n\t\t\t// regions\n\t\t\tArray<Element> regions = player.getChildrenByName(\"region\");\n\t\t\tfor (Element region : regions) {\n\t\t\t\tString regionName = region.get(\"name\"); // region name\n\n\t\t\t\tthis.locations[playerIndex][Location.valueOf(regionName).ordinal()] = new Vector2(region.getFloat(\"x\"), region.getFloat(\"y\"));\n\n\t\t\t\t//Gdx.app.log(\"Tactic\", locationId + \" read\");\n\t\t\t}\n\t\t\tplayerIndex++;\n\t\t}\t\n\t}",
"public void readxml() throws JAXBException, FileNotFoundException {\n Player loadplayer = xml_methods.load();\n logger.info(\"player name: \" + loadplayer.getName());\n if (!item.isEmpty()) {\n logger.trace(loadplayer.getitem(0).getName());\n }\n tfName.setText(loadplayer.getName());\n isset = true;\n player = loadplayer;\n\n }",
"protected void startParsing(String xsdName, String xmlName, String outputFileName){\n boolean isValid = this.inputXSD(xsdName, xmlName, outputFileName);\n if(isValid){\n System.out.println(\"xml data is parsed successfully!\");\n }else {\n System.out.println(\"Program failed to parse xml data!\");\n }\n }",
"public Parser(File file) {\n \t\t\ttry {\n \t\t\t\tload(new FileInputStream(file));\n \t\t\t} catch (Exception e) {\n \t\t\t\t// continue ... actual parsing will report errors\n \t\t\t}\n \t\t}",
"public void runParser() throws Exception {\n\t\tparseXmlFile();\r\n\t\t\r\n\t\t//get each employee element and create a Employee object\r\n\t\tparseDocument();\r\n\t\t\r\n\t\t//Iterate through the list and print the data\r\n\t\t//printData();\r\n\t\t\r\n\t}",
"public Document parse (String filePath) {\n Document document = null;\n try {\n /* DOM parser instance */\n DocumentBuilder builder = builderFactory.newDocumentBuilder();\n /* parse an XML file into a DOM tree */\n document = builder.parse(filePath);\n } catch (ParserConfigurationException e) {\n e.printStackTrace();\n } catch (SAXException e) {\n e.printStackTrace();\n } catch (IOException e) {\n e.printStackTrace();\n }\n return document;\n }",
"void loadXML(String path,\n SourceParameters parameters)\n throws SAXException, ProcessingException, IOException;",
"public static Document loadXmlFile(String fname) {\r\n try {\r\n Document doc = DocumentBuilderFactory.newInstance()\r\n .newDocumentBuilder().parse(fname);\r\n return doc;\r\n } catch (Exception e) {\r\n logger.log(Level.SEVERE, \"exception\", e);\r\n }\r\n\r\n return null;\r\n }",
"public ArticParser(String pathToXML) throws OmniPageParsingException, IOException {\n super(pathToXML);\n setPageSettings();\n }",
"public void readXML() {\n\t try {\n\n\t \t//getting xml file\n\t \t\tFile fXmlFile = new File(\"cards.xml\");\n\t\t\tDocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\n\t\t\tDocumentBuilder dBuilder = dbFactory.newDocumentBuilder();\n\t\t\tDocument doc = dBuilder.parse(fXmlFile);\n\t\t \n\t\t\t//doc.getDocumentElement().normalize(); ???\n\t\t \n\t\t \t//inserting card IDs and Effects into arrays\n\t\t\tNodeList nList = doc.getElementsByTagName(\"card\");\n\t\t\tfor (int i = 0; i < nList.getLength(); i++) {\n\t\t\t\tNode nNode = nList.item(i);\n\t\t\t\tif (nNode.getNodeType() == Node.ELEMENT_NODE) {\n\t\t\t\t\tElement eElement = (Element) nNode;\n\t\t\t\t\tint id = Integer.parseInt(eElement.getAttribute(\"id\"));\n\t\t\t\t\tString effect = eElement.getElementsByTagName(\"effect\").item(0).getTextContent();\n\t\t\t\t\tidarr.add(id);\n\t\t\t\t\teffsarr.add(effect);\n\t\t\t\t}\n\t\t\t}\n\t } catch (Exception e) {\n\t\t\te.printStackTrace();\n\t }\n }",
"public void init() {\r\n\t\ttry {\r\n\t\t\tSAXParserFactory factory = SAXParserFactory.newInstance();\r\n\t\t\t//factory.setValidating(true);\r\n\t\t\t//factory.setFeature(\r\n\t\t\t//\t\t\"http://apache.org/xml/features/validation/schema\", true);\r\n\t\t\tfactory.setNamespaceAware(true);\r\n\t\t\t_parser = factory.newSAXParser();\r\n\t\t} catch (Exception e) {\r\n\t\t\tlog.error(e.getMessage());\r\n\t\t\te.printStackTrace();\r\n\t\t\tLoggerUtilsServlet.logErrors(e);\r\n\t\t}\r\n\t}",
"protected XmlLoader(@NotNull File xmlFile, @Nullable DataContext context, Key<?>... keys) throws XmlParseException {\n\t\tcheckParams(context, keys);\n\t\tthis.dataContext = context;\n\t\tthis.document = getDocumentFromFile(xmlFile);\n\t}",
"public void load(String filename){\n //Create a file if its not already on disk\n File extDir = new File(this.getFilesDir(), filename);\n\n //Read text from file\n StringBuilder text = new StringBuilder();\n\n\n //Needs lots of try and catch blocks because so much can go wrong\n try{\n\n BufferedReader br = new BufferedReader(new FileReader(extDir));\n String line;\n\n while ((line = br.readLine()) != null) {\n text.append(line);\n text.append('\\n');\n }//end while\n\n br.close();//Close the buffer\n }//end try\n catch (FileNotFoundException e){//If file not found on disk here.\n Toast.makeText(this, \"There was no data to load\", Toast.LENGTH_LONG).show();\n e.printStackTrace();\n }\n\n catch (IOException e)//If io Exception here\n {\n Toast.makeText(this, \"Error loading file\", Toast.LENGTH_LONG).show();\n e.printStackTrace();\n }//end catch\n\n\n //Set the data from the file content and conver it to a String\n String data = new String(text);\n\n //Safety first Parse data if available.\n if (data.length() > 0) {\n parseXML(data);\n }\n else\n Toast.makeText(this, \"There is no data to display\", Toast.LENGTH_LONG).show();\n }",
"public static Document loadXmlFile(File file) {\r\n try {\r\n Document doc = DocumentBuilderFactory.newInstance()\r\n .newDocumentBuilder().parse(file);\r\n\r\n return doc;\r\n } catch (Exception e) {\r\n logger.log(Level.SEVERE, \"exception\", e);\r\n }\r\n\r\n return null;\r\n }",
"private void parseXML(String rawXML){\n Log.w(\"AndroidParseXMLActivity\", \"Start Parsing\");\n SAXParserFactory factory = SAXParserFactory.newInstance();\n try {\n\n //Use the sax parser to parse the raw XML.\n SAXParser saxParser = factory.newSAXParser();\n XMLReader xmlreader = saxParser.getXMLReader();\n\n //Use the handler to parse the XML to text\n PaintingXMLHandler handler = new PaintingXMLHandler();\n xmlreader.setContentHandler(handler);\n\n //Objects to read the stream.\n InputSource inStream = new InputSource();\n inStream.setCharacterStream(new StringReader(rawXML));\n\n //Parse the input stream\n xmlreader.parse(inStream);\n\n //Get the map markers from the handler.\n if (handler.getPaintLines() != null) {\n touchArea.loadPainting(handler.getPaintLines());\n }\n setBackgroundColor(handler.getBackground());\n\n\n Toast.makeText(this, \"Loaded\", Toast.LENGTH_LONG).show();\n } catch (ParserConfigurationException e) {\n Toast.makeText(this, \"Error 1 reading xml file.\", Toast.LENGTH_LONG).show();\n e.printStackTrace();\n } catch (SAXException e) {\n Toast.makeText(this, \"Error 2 reading xml file.\", Toast.LENGTH_LONG).show();\n e.printStackTrace();\n }catch(IOException e){\n Toast.makeText(this, \"Error 3 reading xml file.\", Toast.LENGTH_LONG).show();\n e.printStackTrace();\n }\n }",
"public void parseFile(String chemin) {\n try {\n XMLReader xr = XMLReaderFactory.createXMLReader();\n CarburantsParser SaxRead = new CarburantsParser();\n\n xr.setContentHandler(SaxRead);\n xr.parse(chemin);\n\n this.listOfLists = SaxRead.getListOfLists();\n\n LOGGER.info(\"Parsing Ok\");\n\n this.notifyObservers();\n\n } catch (Exception e) {\n LOGGER.error(\"Problème lors du parsing : \" + e);\n }\n }",
"@Override\n\tpublic void parseXML(Element root) throws Exception {\n\t\t\n\t}",
"public ServerParser() \n\t{\n\t\t m_fileNames = new ArrayList<String>();\n\t\t m_fileNames.add(\"xml/time_context_element.xml\");\n\t\t m_fileNames.add(\"xml/location_context_element.xml\");\n\t m_fileNames.add(\"xml/velocity_context_element.xml\");\n\t m_fileNames.add(\"xml/temperature_context_element.xml\");\n\t}",
"private NodeList getNodeListFromFile(String xmlFileName) throws ParserConfigurationException, SAXException, IOException {\r\n\t\ttry{\r\n\t\t\t//sample XMLParser code, nothing to change\r\n\t\t\tFile fXmlFile = new File(xmlFileName);\r\n\t\t\tDocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\r\n\t\t\tDocumentBuilder dBuilder = dbFactory.newDocumentBuilder();\r\n\t\t\tDocument doc = dBuilder.parse(fXmlFile);\r\n\t\t\tdoc.getDocumentElement().normalize();\r\n\t\t\treturn doc.getElementsByTagName(\"element\");\r\n\t\t} catch ( Throwable throwable ) {\r\n\t\t System.out.println(throwable.getMessage());\r\n\t\t}\r\n\t\treturn null;\r\n\t}",
"private static SimpleNode parse(String filename) throws ParseException {\n\t\tParser parser;\n\t\t// open file as input stream\n\t\ttry {\n\t\t\tparser = new Parser(new java.io.FileInputStream(filename));\n\t\t}\n\t\tcatch (java.io.FileNotFoundException e) {\n\t\t\tSystem.out.println(\"ERROR: file \" + filename + \" not found.\");\n\t\t\treturn null;\n\t\t}\n\t\t// parse and return root node\n\t\treturn parser.parse();\n\t}",
"public AceDocument (String textFileName, String APFfileName) {\n\t\ttry {\n\t\t// initialize APF reader\n\t\tif (builder == null) {\n\t\t\tDocumentBuilderFactory factory = DocumentBuilderFactory.newInstance();\n\t\t\tfactory.setValidating(false);\n\t\t\tbuilder = factory.newDocumentBuilder();\n\t\t\t}\n\t\t\tanalyzeDocument (textFileName, APFfileName);\n\t\t} catch (SAXException e) {\n\t\t\tSystem.err.println (\"AceDocument: Exception in initializing APF reader: \" + e);\n\t\t} catch (IOException e) {\n\t\t\tSystem.err.println (\"AceDocument: Exception in initializing APF reader: \" + e);\n\t\t} catch (ParserConfigurationException e) {\n\t\t\tSystem.err.println (\"AceDocument: Exception in initializing APF reader: \" + e);\n\t\t}\n\t}",
"Map<String, String> Read_File(XmlPullParser xmlPullParser, List<Tags_To_Read> tags, String account_Name) throws NullPointerException, XML_Reader_Exception;",
"public XMLElement(PApplet sketch, String filename)\n/* */ {\n/* 174 */ this();\n/* 175 */ this.sketch = sketch;\n/* 176 */ init(sketch.createReader(filename));\n/* */ }",
"public String LoadXML(String filename) throws org.xml.sax.SAXException,\n\t\t\tSAXException {\n\t\tDocumentBuilderFactory factory = DocumentBuilderFactory.newInstance();\n\t\t// factory.setValidating(true);\n\t\t// factory.\n\t\tfactory.setIgnoringElementContentWhitespace(true);\n\t\tDocument doc = null;\n\t\ttry {\n\t\t\tDocumentBuilder builder = factory.newDocumentBuilder();\n\t\t\tFile file = new File(filename);\n\t\t\tdoc = builder.parse(file);\n\t\t\t// Do something with the document here.\n\t\t} catch (ParserConfigurationException e) {\n\t\t} catch (IOException e) {\n\t\t}\n\t\treturn doc.getElementsByTagName(\"text\").item(0).getFirstChild()\n\t\t\t\t.getNodeValue();\n\t}",
"public Document load(final String filename) throws IOException, SAXException {\n final DocumentBuilderFactory factory = DocumentBuilderFactory.newInstance();\n factory.setNamespaceAware(true);\n final DocumentBuilder builder;\n try {\n builder = factory.newDocumentBuilder();\n } catch (final ParserConfigurationException pce) {\n pce.printStackTrace();\n return null;\n }\n final InputStream inputStream = getClass().getResourceAsStream(filename);\n if (inputStream != null) {\n // for files found in JARs\n return builder.parse(inputStream);\n } else {\n // for files directly on the file system\n return builder.parse(new File(filename));\n }\n }",
"public void testXmlReader() throws Exception {\n File file = new File(\"src/test/resources/reader/sample.xml\");\n final URL testdata = file.toURI().toURL();\n reader.parse(testdata, creator);\n assertEquals(\"Did not create expected number of nodes\", 1, creator.size());\n }",
"public XGMMLReader(String fileName) {\n \t\ttry {\n \t\t\tnetworkStream = new FileInputStream(fileName);\n \t\t} catch (FileNotFoundException e) {\n \t\t\te.printStackTrace();\n \t\t}\n \t\tinitialize();\n \t}",
"@Override\n public void parseXml(Element ele, LoadContext lc) {\n\n }",
"public FeatureDictionary(File f) \n\t\tthrows IOException, SAXException, BoxerXMLException {\n\tthis(ParseXML.readFileToElement(f));\n }",
"public abstract T readFromXml(XmlPullParser parser, int version, Context context)\n throws IOException, XmlPullParserException;",
"private void parseDocument()\n {\n\tElement docEle = dom.getDocumentElement();\n\n\t// get a nodelist of <employee> elements\n\tNodeList nl = docEle.getElementsByTagName(\"path\");\n\tif (nl != null && nl.getLength() > 0)\n\t{\n\t for (int i = 0; i < nl.getLength(); i++)\n\t {// System.out.println(i);\n\n\t\t// get the employee element\n\t\tElement el = (Element) nl.item(i);\n\n\t\t// get the Employee object\n\t\tmakeRoom(el);\n\n\t }\n\n\t //Log.d(\"NUMROOMS\", \"numRooms = \" + numDetectedRooms + \" \" + \"numHallways = \" + numDetectedHallways);\n\t}\n\t// This will read in the numbers. This is possibly useful for giving the rooms their correct numbers.\n\t// Find all of the glyphs within the room using it's coordinates and the ID designated by roomsMap.\n\t// Organize their coordinates from left to right and translate the filename to what number they are.\n\t// These numbers from left to right are the room number.\n\n\t/*\n\t * NodeList glyphs = docEle.getElementsByTagName(\"use\"); if (nl != null && glyphs.getLength() > 0) { for (int i = 0; i < glyphs.getLength(); i++) {\n\t * \n\t * //get the employee element Element el = (Element) glyphs.item(i); //System.out.println(el.getAttribute(\"id\")); String x = el.getAttribute(\"x\"); String y = el.getAttribute(\"y\");\n\t * \n\t * //Create a new Employee with the value read from the xml nodes\n\t * \n\t * myGlyphs.add(new Point((int)Double.parseDouble(x), (int)(Double.parseDouble(y))));\n\t * \n\t * } }\n\t */\n\n\t//Log.d(Constants.TAG, \"XMLReader::parseDocument() Exiting!\");\n }",
"public Repository fromXml(String file) {\n File xmlFile = new File(file);\n Repository repository = new Repository();\n Contracts contracts = null;\n JAXBContext jaxbContext;\n try {\n jaxbContext = JAXBContext.newInstance(Contracts.class);\n Unmarshaller jaxbUnmarshaller = jaxbContext.createUnmarshaller();\n if (!xmlFile.exists()) System.out.println(\"File does not exist\");\n assert jaxbUnmarshaller != null;\n contracts = (Contracts) jaxbUnmarshaller.unmarshal(xmlFile);\n } catch (JAXBException e) {\n e.printStackTrace();\n }\n assert contracts != null;\n repository.setArrayList((ArrayList<Contract>) contracts.getContractList());\n\n return repository;\n\n }",
"public void parse(File file, HandlerBase handler) throws SAXException,\n IOException {\n if (file == null) {\n throw new IllegalArgumentException(\"file must not be null\");\n }\n if (file.isDirectory()) {\n throw new IllegalArgumentException(\"file must not be a directory\");\n }\n InputSource source = new InputSource(\"file:\" + file.getAbsolutePath());\n parse(source, handler);\n }",
"private boolean parse(String fileName)\r\n {\r\n\t/* Make sure xml file exists */\r\n\tFile xml = new File(fileName);\r\n\tif(!xml.exists())\r\n\t {\r\n\t\tSystem.out.println(\"Error (parse): \" + fileName + \" does not exists\");\r\n\t\treturn false;\r\n\t }\r\n\r\n\t/* Create the filename */\r\n\ttry{\r\n\t /* create the parser */\r\n\t DefaultHandler handler = new ETDHandler(fileName);\r\n\r\n\t /* Remember, Remember, the fifth friday of every december */\r\n\t SAXParserFactory sax_fac = SAXParserFactory.newInstance();\r\n\t SAXParser sax_parser = sax_fac.newSAXParser();\r\n\t sax_parser.parse(xml, handler);\r\n\r\n\t}\r\n\tcatch(Throwable t)\r\n\t {\r\n\t\tSystem.out.println(\"Error (parse): \" + t.getMessage());\r\n\t\tt.printStackTrace();\r\n\t }\r\n\r\n\treturn true;\r\n }",
"public Document getDocFromFile(String filename)\r\n throws ParserConfigurationException{\r\n {\r\n DocumentBuilderFactory dbf = DocumentBuilderFactory.newInstance();\r\n DocumentBuilder db = dbf.newDocumentBuilder();\r\n Document doc = null;\r\n try{\r\n doc = db.parse(filename);\r\n }\r\n catch (Exception ex){\r\n System.out.println(\"XML parse failure\");\r\n ex.printStackTrace();\r\n }\r\n return doc;\r\n } \r\n }",
"public void process(final String filename) throws JDOMException, IOException {\n\n // Parsing our XML file being located below \"resources\"\n final Document docInput = builder.build(\n getClass().getClassLoader().getResource(filename)\n );\n\n // Accessing the document's root element <catalog>\n final Element docRoot = docInput.getRootElement();\n\n // Accessing the <item> children of parent element <catalog>\n docRoot.getChildren().stream().\n map(item -> \"Article: \" + item.getText() +\n \", order number: \" + item.getAttributeValue(\"orderNo\")).\n forEach(System.out::println);\n }",
"public static void main(String[] args) throws ParserConfigurationException, SAXException, IOException {\r\n\t\tSAXParserFactory spf = SAXParserFactory.newInstance();\r\n\t\t// Create the parser from the factory instance\r\n\t\t// two exceptions to the main method\r\n\t\tSAXParser sp = spf.newSAXParser();\r\n\r\n\t\t/*\r\n\t\t * Parse the XML document. Event based parsing it sends it to a handler . It need a\r\n\t\t * handler to Accepts 2 parameters. The file and the handler.\r\n\t\t */\r\n\t\t\r\n\t\t//set the file path and handler. The handler can implement certain interfaces. Throw exceptions to the mail\r\n\t\tsp.parse(\"C:/GitHub/MyJava/MyJavaProject/src/com/stoneriver/xml/validation/intro.xml\", new MyHandler());\r\n\r\n\t}",
"public static void parseXML(String strXmlContent) {\n\t\tSAXParserFactory spf = SAXParserFactory.newInstance();\r\n\t\ttry {\r\n\t\t\tSAXParser saxParser = spf.newSAXParser();\r\n\t\t\tsaxParser.parse(new ByteArrayInputStream(strXmlContent.getBytes()),\r\n\t\t\t\t\tnew SAXXMLReader());\r\n\t\t} catch (Exception e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\r\n\t}",
"public HelperClass parseXML(File file1)\n\t{\n\t\tString a =null;\n\t\tList<String> list1 = new ArrayList<String>();\n\t\tString id = \"\";\n\n\t\tDocumentBuilderFactory factory = DocumentBuilderFactory.newInstance();\n\t\ttry\n\t\t{\n\t\t\tDocumentBuilder builder = factory.newDocumentBuilder();\n\t\t\tDocument doc = builder.parse(file1.toString());\n\t\t\tElement root = doc.getDocumentElement();\n\t\t\tid = root.getAttribute(\"id\");\n\t\t\t\n\t\t\tNodeList requirementList = doc.getElementsByTagName(\"requirements\");\n\t\t\tfor(int k=0;k<requirementList.getLength();k++) \n\t\t\t{\n\t\t\t\tNode r = requirementList.item(k);\n\t\t\t\tif(r.getNodeType() == Node.ELEMENT_NODE)\n\t\t\t\t{\n\t\t\t\t\tElement requirement = (Element) r;\n\t\t\t\t\tNodeList nameList = requirement.getChildNodes();\n\t\t\t\t\tfor(int j=0;j<nameList.getLength();j++)\n\t\t\t\t\t{\n\t\t\t\t\t\tNode n = nameList.item(j); \n\t\t\t\t\t\tif(n.getNodeType() == Node.ELEMENT_NODE)\n\t\t\t\t\t\t{\n\t\t\t\t\t\t\tElement name3 = (Element) n;\n\t\t\t\t\t\t\ta = name3.getTextContent();\n\t\t\t\t\t\t\tlist1.add(a);\n\t\t\t\t\t\t\tSystem.out.println(a);\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\n\t\t} catch (ParserConfigurationException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (SAXException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (IOException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\n\t\tHelperClass toolIdMap = new HelperClass();\n\t\ttoolIdMap.setKey(id);\n\t\ttoolIdMap.setTools(list1);\n\t\treturn toolIdMap;\n\n\t}",
"public void parse(File file, DefaultHandler handler) throws SAXException,\n IOException {\n if (file == null) {\n throw new IllegalArgumentException(\"file must not be null\");\n }\n if (file.isDirectory()) {\n throw new IllegalArgumentException(\"file must not be a directory\");\n }\n InputSource source = new InputSource(\"file:\" + file.getAbsolutePath());\n parse(source, handler);\n }",
"public static void main(String[] args) throws ParserConfigurationException, SAXException, IOException{\n\t File inputFile = new File(\"C:\\\\Users\\\\msamiull\\\\workspace\\\\jgraphx-master\\\\t.xml\");\r\n DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\r\n DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();\r\n Document doc = dBuilder.parse(inputFile);\r\n \r\n\t\tdoc.getDocumentElement().normalize();\r\n System.out.println(\"Main element :\"+ doc.getDocumentElement().getNodeName());\r\n// NodeList nodeList = doc.getElementsByTagName(\"root\");\r\n \r\n NodeList nodeList = doc.getElementsByTagName(\"iOOBN\");\r\n// NamedNodeMap attribList = doc.getAttributes();\r\n \r\n// nonRecursiveParserXML(nList, doc);\r\n\r\n ArrayList<String> tagList = new ArrayList<String>();\r\n// tagList.add(\"mxCell\");\r\n// tagList.add(\"mxGeometry\");\r\n// tagList.add(\"mxPoint\");\r\n tagList.add(\"Node\");\r\n tagList.add(\"state\");\r\n tagList.add(\"tuple\"); // purposely i raplced \"datarow\" by \"tuple\" so that my parser can consider state first before tuple/data\r\n tagList.add(\"parent\");\r\n \r\n recursiveParserXML(nodeList, tagList);\r\n\r\n }"
]
| [
"0.7447327",
"0.7233485",
"0.6888907",
"0.6825626",
"0.667728",
"0.66404825",
"0.6639242",
"0.6615304",
"0.6573589",
"0.6547343",
"0.6521103",
"0.649521",
"0.6466943",
"0.64530134",
"0.6448934",
"0.6434653",
"0.64085853",
"0.6406413",
"0.6392416",
"0.6383519",
"0.6374431",
"0.63699377",
"0.6367345",
"0.63476086",
"0.63463724",
"0.6285374",
"0.627462",
"0.6261902",
"0.62381",
"0.622851",
"0.62203985",
"0.62170035",
"0.6204124",
"0.62012833",
"0.6193962",
"0.6190949",
"0.618995",
"0.616565",
"0.61597335",
"0.61445624",
"0.6141412",
"0.6135802",
"0.6106429",
"0.61051697",
"0.61009634",
"0.6100861",
"0.6078708",
"0.60722566",
"0.60650903",
"0.6047524",
"0.6046574",
"0.6029533",
"0.60285586",
"0.60144186",
"0.6010861",
"0.60079485",
"0.600512",
"0.6001911",
"0.5998168",
"0.5958747",
"0.5953654",
"0.5952923",
"0.5944254",
"0.5924545",
"0.592004",
"0.5920033",
"0.5918356",
"0.5902615",
"0.59001327",
"0.5887221",
"0.58725196",
"0.58660257",
"0.5863011",
"0.5860222",
"0.5838078",
"0.583482",
"0.58182734",
"0.5816019",
"0.58119607",
"0.5811183",
"0.5804694",
"0.57907015",
"0.5786521",
"0.5784673",
"0.57699203",
"0.5738772",
"0.5717068",
"0.57136613",
"0.57108206",
"0.5684987",
"0.5681876",
"0.5662641",
"0.56619954",
"0.56551814",
"0.5652665",
"0.5652333",
"0.5646115",
"0.5642863",
"0.5640376",
"0.5638227",
"0.5637894"
]
| 0.0 | -1 |
Create DOM representation of an XML document. | public void parseXmlFile(String fileName){
//get the factory
DocumentBuilderFactory dbf = DocumentBuilderFactory.newInstance();
try {
//Using factory get an instance of document builder
DocumentBuilder db = dbf.newDocumentBuilder();
//parse using builder to get DOM representation of the XML file
doc = db.parse(fileName);
} catch(ParserConfigurationException pce) {
pce.printStackTrace();
} catch(SAXException se) {
System.err.println("Malformed XML: Make sure to provide a valid XML document.");
} catch(IOException ioe) {
System.err.println("File not found: Path to a valid XML file has to be specified." );
}
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void createDocument() {\n\t\t\tDocumentBuilderFactory dbf = DocumentBuilderFactory.newInstance();\r\n\t\t\ttry {\r\n\t\t\t//get an instance of builder\r\n\t\t\tDocumentBuilder db = dbf.newDocumentBuilder();\r\n\r\n\t\t\t//create an instance of DOM\r\n\t\t\tdom = db.newDocument();\r\n\r\n\t\t\t}catch(ParserConfigurationException pce) {\r\n\t\t\t\t//dump it\r\n\t\t\t\tSystem.out.println(\"Error while trying to instantiate DocumentBuilder \" + pce);\r\n\t\t\t\tSystem.exit(1);\r\n\t\t\t}\r\n\r\n\t\t}",
"private void createDocument(){\n\t\tDocumentBuilderFactory dbf = DocumentBuilderFactory.newInstance();\n\t\ttry {\n\t\t//get an instance of builder\n\t\tDocumentBuilder db = dbf.newDocumentBuilder();\n\n\t\t//create an instance of DOM\n\t\tdom = db.newDocument();\n\n\t\t}catch(ParserConfigurationException pce) {\n\t\t\t//dump it\n\t\t\tSystem.out.println(\"Error while trying to instantiate DocumentBuilder \" + pce);\n\t\t\tSystem.exit(1);\n\t\t}\n }",
"public static XMLDocument create()\n {\n return new XMLDocument();\n }",
"public Document getAsXMLDOM () {\r\n\r\n //code description\r\n\r\n return document;\r\n\r\n }",
"Document toXml() throws ParserConfigurationException, TransformerException, IOException;",
"private Document createXMLDocumentStructure() {\r\n\t\tDocumentBuilderFactory dbf = DocumentBuilderFactory.newInstance();\r\n\t\tDocumentBuilder builder = null;\r\n\t\ttry {\r\n\t\t\tbuilder = dbf.newDocumentBuilder();\r\n\t\t} catch (ParserConfigurationException e) {\r\n\t\t\t// TODO Auto-generated catch block\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t\t\r\n\t\t// Creates the Document\r\n\t\tDocument serviceDoc = builder.newDocument();\r\n\t\t/*\r\n\t\t * Create the XML Tree\r\n\t\t */\r\n\t\tElement root = serviceDoc.createElement(\"service\");\r\n\r\n\t\tserviceDoc.appendChild(root);\r\n\t\treturn serviceDoc;\r\n\t}",
"public static Document createDocument( StringNode root )\r\n\t\tthrows ParserConfigurationException\r\n\t{\r\n \tDocumentBuilderFactory docBuilderFactory = DocumentBuilderFactory.newInstance();\r\n DocumentBuilder docBuilder = docBuilderFactory.newDocumentBuilder();\r\n Document doc = docBuilder.newDocument();\r\n String name = root.getName();\r\n Element element = doc.createElement( name );\r\n doc.appendChild( element );\r\n addElement( doc, element, root );\r\n return doc;\r\n\t}",
"public static Document newDocument() throws XMLException{\n\t\ttry{\n\t\t\tfinal DocumentBuilderFactory factory = DocumentBuilderFactory.newInstance();\t\t\t\n\t\t\tfinal DocumentBuilder builder = factory.newDocumentBuilder();\n\t\t\tfinal Document doc = builder.newDocument();\n\t\t\treturn doc;\n\t\t}catch(Exception e){\n\t\t\te.printStackTrace();\n\t\t\tthrow new XMLException(e);\n\t\t}\n\t}",
"Object create(Document doc) throws IOException, SAXException, ParserConfigurationException;",
"public XML xml() {\n return new XMLDocument(new Xembler(this.dirs).domQuietly());\n }",
"public static void initXMLdoc() throws Exception {\n\tDocumentBuilderFactory factory = DocumentBuilderFactory.newInstance();\n DocumentBuilder builder = factory.newDocumentBuilder();\n DOMImplementation impl = builder.getDOMImplementation();\n\n\tdoc = impl.createDocument(null,null,null);\n }",
"public Document saveAsXML() {\n\tDocument xmldoc= new DocumentImpl();\n\tElement root = createFeaturesElement(xmldoc);\n\txmldoc.appendChild(root);\n\treturn xmldoc;\n }",
"public Document newDocument() {\n\t\treturn new org.apache.xerces.dom.DocumentImpl();\n\t}",
"DocumentRoot createDocumentRoot();",
"DocumentRoot createDocumentRoot();",
"DocumentRoot createDocumentRoot();",
"DocumentRoot createDocumentRoot();",
"protected Element createDocument() {\r\n // create the dom tree\r\n DocumentBuilder builder = getDocumentBuilder();\r\n Document doc = builder.newDocument();\r\n Element rootElement = doc.createElement(TESTSUITES);\r\n doc.appendChild(rootElement);\r\n\r\n generatedId = 0;\r\n\r\n // get all files and add them to the document\r\n File[] files = getFiles();\r\n for (int i = 0; i < files.length; i++) {\r\n File file = files[i];\r\n try {\r\n if(file.length()>0) {\r\n Document testsuiteDoc\r\n = builder.parse(\"file:///\" + file.getAbsolutePath());\r\n Element elem = testsuiteDoc.getDocumentElement();\r\n // make sure that this is REALLY a testsuite.\r\n if (TESTSUITE.equals(elem.getNodeName())) {\r\n addTestSuite(rootElement, elem);\r\n generatedId++;\r\n } else {\r\n }\r\n } else {\r\n }\r\n } catch (SAXException e) {\r\n // a testcase might have failed and write a zero-length document,\r\n // It has already failed, but hey.... mm. just put a warning\r\n } catch (IOException e) {\r\n }\r\n }\r\n return rootElement;\r\n }",
"public XMLDocument() {\r\n xml = new StringBuilder();\r\n }",
"protected static org.w3c.dom.Document setUpXML(String nodeName)\n throws ParserConfigurationException\n {\n //try\n //{\n DocumentBuilderFactory myFactory = DocumentBuilderFactory.newInstance();\n DocumentBuilder myDocBuilder = myFactory.newDocumentBuilder();\n DOMImplementation myDOMImpl = myDocBuilder.getDOMImplementation();\n // resultDocument = myDOMImpl.createDocument(\"at.ac.tuwien.dbai.pdfwrap\", \"PDFResult\", null);\n org.w3c.dom.Document resultDocument =\n myDOMImpl.createDocument(\"at.ac.tuwien.dbai.pdfwrap\", nodeName, null);\n return resultDocument;\n //}\n //catch (ParserConfigurationException e)\n //{\n // e.printStackTrace();\n // return null;\n //}\n\n }",
"public static Document createDocument(final Element element) {\n\t\tfinal DOMImplementation domImplementation = element.getOwnerDocument().getImplementation(); //get the DOM implementation used to create the document\n\t\t//create a new document corresponding to the element\n\t\t//TODO bring over the doctype, if needed\n\t\tfinal Document document = domImplementation.createDocument(element.getNamespaceURI(), element.getNodeName(), null);\n\t\tfinal Node importedNode = document.importNode(element, true); //import the element into our new document\n\t\tdocument.replaceChild(importedNode, document.getDocumentElement()); //set the element clone as the document element of the new document\n\t\treturn document; //return the document we created\n\t}",
"public Element generateElement(Document dom);",
"private Doc(String documentElementName) {\n e = d.createElement(documentElementName);\n d.appendChild(e);\n }",
"public static Document getXmlDom(String xmlFilePath) {\n Document doc = null;\n try {\n Builder builder = new Builder();\n File file = new File(xmlFilePath);\n doc = builder.build(file);\n\n } catch (ParsingException e) {\n e.printStackTrace();\n } catch (IOException e) {\n e.printStackTrace();\n }\n return doc;\n }",
"public XMLDocument ()\r\n\t{\r\n\t\tthis (DEFAULT_XML_VERSION, true);\r\n\t}",
"public Element toXml(Document doc)\n {\n if (null == doc)\n throw new IllegalArgumentException(\"Must provide a valid Document\");\n Element root = doc.createElement(XML_NODE_NAME);\n root.setAttribute(XML_NAME_ATTR, m_name);\n if (m_displayName.length() > 0)\n root.setAttribute(XML_DISPLAYNAME_ATTR, m_displayName);\n root.setAttribute(XML_DIMENSION_ATTR, m_dimension);\n root.setAttribute(XML_CHOICESET_ATTR, m_choiceSet);\n if (m_description.length() > 0)\n PSXmlDocumentBuilder.addElement(doc, root, XELEM_DESCRIPTION,\n m_description);\n\n // psxctl:ParamList\n if (m_params.size() > 0)\n {\n Element paramList = doc.createElement( XELEM_PARAMLIST );\n for (Iterator iter = m_params.iterator(); iter.hasNext();)\n {\n PSControlParameter param = (PSControlParameter) iter.next();\n paramList.appendChild(param.toXml(doc));\n }\n root.appendChild(paramList);\n }\n\n // psxctl:AssociatedFileList\n if (m_files.size() > 0)\n {\n Element files = doc.createElement( XELEM_FILES );\n for (Iterator iter = m_files.iterator(); iter.hasNext();)\n {\n PSFileDescriptor file = (PSFileDescriptor) iter.next();\n files.appendChild( file.toXml( doc ) );\n }\n root.appendChild(files);\n }\n\n // psxctl:Dependencies\n if (m_dependencies.size() > 0)\n {\n Element dependencies = doc.createElement( XELEM_DEPENDENCIES );\n for (Iterator iter = m_dependencies.iterator(); iter.hasNext();)\n {\n PSDependency dependency = (PSDependency) iter.next();\n dependencies.appendChild( dependency.toXml( doc ) );\n }\n root.appendChild(dependencies);\n }\n\n return root;\n }",
"public XMLData () {\r\n\r\n //code description\r\n\r\n try {\r\n DocumentBuilder builder = DocumentBuilderFactory.newInstance().newDocumentBuilder();\r\n this.document = builder.newDocument(); \r\n }\r\n catch (ParserConfigurationException err) {}\r\n\r\n }",
"public static Document createNewDocument(String rootName, Version version) {\r\n try {\r\n DocumentBuilder db = DocumentBuilderFactory.newInstance()\r\n .newDocumentBuilder();\r\n Document doc = db.newDocument();\r\n Node root = doc.createElement(rootName);\r\n if (version != null) {\r\n addAttr(doc, root, \"version\", version);\r\n }\r\n\r\n doc.appendChild(root);\r\n return doc;\r\n } catch (Exception e) {\r\n logger.log(Level.SEVERE, \"exception\", e);\r\n }\r\n\r\n return null;\r\n }",
"public static void outputXMLdoc() throws Exception {\n // transform the Document into a String\n DOMSource domSource = new DOMSource(doc);\n TransformerFactory tf = TransformerFactory.newInstance();\n Transformer transformer = tf.newTransformer();\n transformer.setOutputProperty(OutputKeys.METHOD, \"xml\");\n transformer.setOutputProperty(OutputKeys.ENCODING,\"UTF-8\");\n transformer.setOutputProperty(\"{http://xml.apache.org/xslt}indent-amount\", \"4\");\n transformer.setOutputProperty(OutputKeys.INDENT, \"yes\");\n java.io.StringWriter sw = new java.io.StringWriter();\n StreamResult sr = new StreamResult(sw);\n transformer.transform(domSource, sr);\n String xml = sw.toString();\n\n\tSystem.out.println(xml);\n\n }",
"public DocumentManipulator() {\n\t\ttry {\n\t\t\tthis.document = XMLUtils.buildDocument();\n\t\t} catch (UnsupportedEncodingException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (SAXException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (IOException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (ParserConfigurationException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t\t//-- Init Xpath\n\t\tinit();\n\t}",
"public DocumentBuilderFactory createDocumentBuilderFactory() throws FactoryConfigurationError {\n return DocumentBuilderFactory.newInstance();\n }",
"public XmlDocumentDefinition() {\n }",
"public Element toDOMElement(Document doc) {\r\n Element root = doc.createElement(SnarfConstants.SITE_NODE);\r\n root.setAttribute(SnarfConstants.NAME_ATTRIB, myName);\r\n for (int k = 0; k < myPackages.size(); k++) {\r\n Package pkg = getPackage(k);\r\n Element el = pkg.toDOMElement(doc);\r\n root.appendChild(el);\r\n }\r\n return root;\r\n }",
"public Element toXML(Document document) {\n\t\tif (document == null)\n\t\t\treturn null;\n\n\t\t// create root node\n\t\tElement w_node = document.createElement(\"GlycanWorkspace\");\n\n\t\t// create configuration node\n\t\tstoreToConfiguration(true);\n\t\tw_node.appendChild(theConfiguration.toXML(document));\n\n\t\t// create structures node\n\t\tw_node.appendChild(theStructures.toXML(document));\n\n\t\treturn w_node;\n\t}",
"protected abstract Element toXmlEx(Document doc);",
"public static Document createJdomDoc(String xmlString) {\n\t\ttry {\n\t\t\tSAXBuilder builder = new SAXBuilder();\n\t\t\tDocument doc = builder.build(new ByteArrayInputStream(xmlString.getBytes()));\n\t\t\treturn doc;\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t} catch (JDOMException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\n\t\treturn null;\n\t}",
"public static Element newRootElement()\n {\n Element element = null;\n \n try\n {\n javax.xml.parsers.DocumentBuilderFactory factory =\n javax.xml.parsers.DocumentBuilderFactory.newInstance();\n \n javax.xml.parsers.DocumentBuilder builder =\n factory.newDocumentBuilder();\n \n Document document = builder.newDocument();\n Element holder = document.createElement(\"root\");\n document.appendChild(holder);\n element = document.getDocumentElement();\n }\n catch(Exception ex) { ex.printStackTrace(); }\n \n return element;\n }",
"Element toXML();",
"@SuppressWarnings(\"unchecked\")\n\tpublic Document getDocument() {\n\t\tDocument doc = this.documentBuilder.newDocument();\n\t\t\n\t\tElement rootElement = doc.createElement(\"properties\");\n\t\tdoc.appendChild(rootElement);\n\t\t\n\t\tEnumeration<String> keys = (Enumeration<String>) this.properties.propertyNames();\n\t\t\n\t\twhile (keys.hasMoreElements()) {\n\t\t\tString key = keys.nextElement();\n\t\t\tElement entry = doc.createElement(\"entry\");\n\t\t\tentry.setAttribute(\"key\", key);\n\t\t\tentry.setTextContent(this.getProperty(key));\n\t\t\trootElement.appendChild(entry);\n\t\t}\n\t\t\n\t\treturn doc;\n\t}",
"public static Document createHexDocument( StringNode root )\r\n\t\tthrows ParserConfigurationException\r\n\t{\r\n \tDocumentBuilderFactory docBuilderFactory = DocumentBuilderFactory.newInstance();\r\n DocumentBuilder docBuilder = docBuilderFactory.newDocumentBuilder();\r\n Document doc = docBuilder.newDocument();\r\n Element element = doc.createElement( convertHex( root.getName() ));\r\n doc.appendChild( element );\r\n addHexElement( doc, element, root );\r\n return doc;\r\n\t}",
"@Override\n @NotNull\n public XmlDocument getDocument() {\n final XmlDocument document = findChildByClass(XmlDocument.class);\n assert document != null;\n return document;\n }",
"public static Document createDOMDocumentFromXmlFile(File file)\n throws ParserConfigurationException, IOException, SAXException {\n\n if (!file.exists()) {\n throw new RuntimeException(\"Could not find XML file: \" + file.getAbsolutePath());\n }\n\n DocumentBuilder documentBuilder = DocumentBuilderFactory.newInstance().newDocumentBuilder();\n Document xmlDocument = documentBuilder.parse(file);\n\n return xmlDocument;\n }",
"public Doc newDocument(String documentElementName) {\n return new Doc(documentElementName);\n }",
"public static String toXml(Document dom)\n {\n return new DOMReader().read(dom).asXML();\n }",
"public static DocumentBuilder getXMLBuilder() {\n\n return getXMLBuilder( false, true, false, false, false, false, false, null );\n }",
"public static Document createDOMDocumentFromXmlStream(InputStream inStream)\n throws ParserConfigurationException, IOException, SAXException {\n\n DocumentBuilder documentBuilder = DocumentBuilderFactory.newInstance().newDocumentBuilder();\n Document xmlDocument = documentBuilder.parse(inStream);\n\n return xmlDocument;\n }",
"public static Document getXMLDoc(String filename) throws ParserConfigurationException, IOException, SAXException {\n\n File xmlFile = new File(filename);\n\n // create instance of the document builder factory to get the builder\n DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\n\n // get the document builder from the factory\n DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();\n\n // parse the file into the doc\n Document doc = dBuilder.parse(xmlFile);\n\n // normalize doc\n doc.getDocumentElement().normalize();\n\n return doc;\n }",
"public WalkerDocument newDocument() { return newDocument((IOptions)null); }",
"public String getXML() //Perhaps make a version of this where the header DTD can be manually specified\n { //Also allow changing of generated tags to user specified values\n \n String xml = new String();\n xml= \"<?xml version = \\\"1.0\\\"?>\\n\";\n xml = xml + generateXML();\n return xml;\n }",
"public static Document getDocument(byte xml[])\n {\n return XMLTools.getDocument(xml, false);\n }",
"protected final XMLCDomFactory getDomFactory() { return fDOMFactory; }",
"protected final XMLCDomFactory getDomFactory() { return fDOMFactory; }",
"protected final XMLCDomFactory getDomFactory() { return fDOMFactory; }",
"public static Document getXMLDocument(InputStream stream) \n\t\t\tthrows ParserConfigurationException, \n\t\t\tSAXException, IOException {\n\t\tDocumentBuilderFactory factory = DocumentBuilderFactory\n\t\t\t\t.newInstance();\n\t\tDocumentBuilder builder = factory\n\t\t\t\t.newDocumentBuilder();\n\t\tDocument document = builder.parse(stream);\n\t\treturn document;\n\t}",
"public Node createDOMSubtree(final Document doc) {\n int i;\n String aName;\n Node childNode;\n Element element;\n IBiNode tmp;\n\n element = doc.createElementNS(this.namespaceURI, this.eName);\n\n // add attributes\n if (this.attrs != null) {\n for (i = 0; i < this.attrs.getLength(); i++) {\n aName = this.attrs.getLocalName(i);\n\n if (\"\".equals(aName)) {\n aName = this.attrs.getQName(i);\n }\n\n element.setAttribute(aName, this.attrs.getValue(i));\n }\n }\n\n // create DOM-tree of children\n if (this.child != null) {\n tmp = this.child;\n\n while (tmp != null) {\n childNode = tmp.createDOMSubtree(doc);\n\n if (childNode != null) {\n element.appendChild(childNode);\n }\n\n tmp = tmp.getSibling();\n }\n }\n\n this.namespaceURI = null;\n this.eName = null;\n this.attrs = null;\n\n this.setNode(element);\n return element;\n }",
"private DOMs() {\n }",
"public static Document newDocument(final String xmlContent, boolean useNamespaces) throws IOException, SAXException, ParserConfigurationException, XMLException {\n\t\tfinal ByteArrayInputStream in = new ByteArrayInputStream(xmlContent.getBytes());\n\t\treturn XMLHelper.parse(in, useNamespaces);\n\t}",
"public abstract WalkerDocument newDocument(IOptions options);",
"public static org.dom4j.Document convert( org.w3c.dom.Document dom) \r\n {\n org.dom4j.io.DOMReader reader = new org.dom4j.io.DOMReader();\r\n return reader.read(dom);\r\n }",
"public void init() { \n\t\ttry { \n\t\t\tDocumentBuilderFactory factory = DocumentBuilderFactory.newInstance(); \n\t\t\tDocumentBuilder builder = factory.newDocumentBuilder(); \n\t\t\tthis.document = builder.newDocument(); \n\t\t\tlogger.info(\"initilize the document success.\");\n\t\t} catch (ParserConfigurationException e) { \n\t\t\t\n\t\t\tlogger.error(e.getMessage());\n\t\t} \n\t}",
"public abstract String toXML();",
"public abstract String toXML();",
"public abstract String toXML();",
"private static DocumentBuilderFactory getDocumentBuilderFactory(){\r\n\t\tif(documentBuilderFactory == null){\r\n\t\t\tdocumentBuilderFactory = DocumentBuilderFactory.newInstance();\r\n\t\t}\r\n\t\treturn documentBuilderFactory;\r\n\t}",
"private static Document convertStringToDocument(String xmlStr) {\n DocumentBuilderFactory factory = DocumentBuilderFactory.newInstance(); \n DocumentBuilder builder; \n try \n { \n builder = factory.newDocumentBuilder(); \n Document doc = builder.parse( new InputSource( new StringReader( xmlStr ) ) ); \n return doc;\n } catch (Exception e) { \n e.printStackTrace(); \n } \n return null;\n }",
"public interface SDXHelper {\n /**\n * Creates a DOM <CODE>Element</CODE> node and appends it as a child\n * to the given <CODE>parent</CODE> element. The attributes stored by\n * the SAX object are retrieved and set to the created DOM object.\n *\n * @param namespaceURI The namespace URI for the new element\n * @param localName The local name for the new element\n * @param qualifiedName The qualified name for the new element\n * @param attributes The attributes for the new element\n * @param parent The parent for the new element or\n * <CODE>null</CODE> if this is a root element\n * @return The created DOM <CODE>Element</CODE>\n */\n public Element createElement(String namespaceURI, String qualifiedName,\n Attributes attributes, Element parent);\n\n /**\n * Creates a DOM <CODE>Text</CODE> node and appends it as a child\n * to the given <CODE>parent</CODE> element or just appends the data\n * to the last child of <CODE>parent</CODE> if that last child is\n * a <CODE>Text</CODE> node. In other words, this method doesn't allow\n * the creation of adjacent <CODE>Text</CODE> nodes and creates\n * a <CODE>Text</CODE> node only when this is necessary.\n *\n * @param data The character data for the text node\n * @param parent The parent for the text node\n * @return The created or existent <CODE>Text</CODE> node\n */\n public Text createTextNode(String data, Element parent);\n\n /**\n * Creates a DOM <CODE>CDATASection</CODE> node and appends it as a child\n * to the given <CODE>parent</CODE> element or just appends the data\n * to the last child of <CODE>parent</CODE> if that last child is\n * a <CODE>CDATASection</CODE> node and <CODE>newCDATA</CODE> is\n * <CODE>false</CODE>. In other words, this method avoids the creation\n * of adjacent <CODE>CDATASection</CODE> nodes and creates a\n * <CODE>CDATASection</CODE> node only when this is necessary or required.\n *\n * @param data The character data for the CDATA section\n * @param newCDATA Indicates the beginning of a new CDATA section\n * @param parent The parent for the CDATA section\n * @return The created or existent\n * <CODE>CDATASection</CODE> node\n */\n public CDATASection createCDATASection(String data, boolean newCDATA,\n Element parent);\n\n /**\n * Creates a DOM <CODE>ProcessingInstruction</CODE> node and appends it\n * as a child to the given <CODE>parent</CODE> element.\n *\n * @param target The target for the new processing instruction\n * @param data The data for the new processing instruction\n * @param parent The parent for the new processing instruction\n * @return The created <CODE>ProcessingInstruction</CODE>\n */\n public ProcessingInstruction createProcessingInstruction(\n String target, String data, Element parent);\n\n /**\n * Creates a DOM <CODE>Comment</CODE> node and appends it as a child\n * to the given <CODE>parent</CODE> element.\n *\n * @param data The data for the new comment\n * @param parent The parent for the new comment\n * @return The created <CODE>Comment</CODE> node\n */\n public Comment createComment(String data, Element parent);\n}",
"public static Document getDocument(String xml)\n {\n return XMLTools.getDocument(StringTools.getBytes(xml), false);\n }",
"public static Document getDocument(InputStream input)\n {\n return XMLTools.getDocument(input, false);\n }",
"Object create(Element element) throws IOException, SAXException, ParserConfigurationException;",
"public DocumentBuilder newDocumentBuilder()\n throws ParserConfigurationException {\n return(new DocumentBuilderImpl(this.isNamespaceAware(),\n this.isValidating()));\n }",
"private void createDOMTree(){\n\t\t\tElement rootEle = dom.createElement(\"html\");\r\n\t\t\tdom.appendChild(rootEle);\r\n\t\t\t\r\n\t\t\t//\t\t\tcreates <head> and <title> tag\r\n\t\t\tElement headEle = dom.createElement(\"head\");\r\n\t\t\tElement titleEle = dom.createElement(\"title\");\r\n\t\t\t\r\n\t\t\t//\t\t\tset value to <title> tag\r\n\t\t\tText kuerzelText = dom.createTextNode(\"Auswertung\");\r\n\t\t\ttitleEle.appendChild(kuerzelText);\r\n\t\t\theadEle.appendChild(titleEle);\r\n\t\t\t\r\n\t\t\tElement linkEle = dom.createElement(\"link\");\r\n\t\t\tlinkEle.setAttribute(\"rel\", \"stylesheet\");\r\n\t\t\tlinkEle.setAttribute(\"type\", \"text/css\");\r\n\t\t\tlinkEle.setAttribute(\"href\", \"./format.css\");\r\n\t\t\theadEle.appendChild(linkEle);\r\n\t\t\t\r\n\t\t\trootEle.appendChild(headEle);\r\n\t\t\t\r\n\t\t\t\r\n\t\t\tElement bodyEle = dom.createElement(\"body\");\r\n\t\t\tElement divEle = dom.createElement(\"div\");\r\n\t\t\tdivEle.setAttribute(\"id\", \"cont\");\r\n\t\t\t\r\n\t\t\tVector<String> tmp = myData.get(0);\r\n\t\t\tElement h2Ele = dom.createElement(\"h2\");\r\n\t\t\tString h1Str = \"\";\r\n\t\t\tfor(Iterator i = tmp.iterator(); i.hasNext(); )\r\n\t\t\t{\r\n\t\t\t\th1Str = h1Str + (String)i.next() + \" \";\r\n\t\t\t}\r\n\t\t\tText aText = dom.createTextNode(h1Str);\r\n\t\t\th2Ele.appendChild(aText);\r\n\t\t\tdivEle.appendChild(h2Ele);\r\n\t\t\tmyData.remove(0);\r\n\t\t\t\r\n\t\t\tElement tableEle = dom.createElement(\"table\");\r\n//\t\t\ttableEle.setAttribute(\"border\", \"1\");\r\n\t\t\t\r\n\t\t\ttmp = myData.get(0);\r\n\t\t\tElement trHeadEle = createTrHeadElement(tmp);\r\n\t\t\ttableEle.appendChild(trHeadEle);\r\n\t\t\tmyData.remove(0);\r\n\t\t\t\r\n\t\t\tIterator it = myData.iterator();\r\n\t\t\twhile(it.hasNext()) {\r\n\t\t\t\ttmp = (Vector<String>)it.next();\r\n\t\t\t\tElement trEle = createTrElement(tmp);\r\n\t\t\t\ttableEle.appendChild(trEle);\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\tdivEle.appendChild(tableEle);\r\n\t\t\tbodyEle.appendChild(divEle);\r\n\t\t\trootEle.appendChild(bodyEle);\r\n\t\t\t\r\n\t\t}",
"protected Element toDOMElement(CoreDocumentImpl document) {\n ElementImpl element = new ElementImpl(document, \"user\");\n element.setAttribute(\"id\", this.getId());\n element.setAttribute(\"name\", this.getName());\n element.setAttribute(\"email\", this.getEmail());\n element.setAttribute(\"password\", this.getPassword());\n return element;\n }",
"public static Document createXsd(Principal principal, CoalesceEntityTemplate template)\n throws ParserConfigurationException\n {\n CoalesceEntity entity = template.createNewEntity();\n\n DocumentBuilderFactory factory = DocumentBuilderFactory.newInstance();\n factory.setNamespaceAware(true);\n\n Document doc = factory.newDocumentBuilder().newDocument();\n\n Element element = doc.createElementNS(NS_XML_URI, \"schema\");\n element.setPrefix(NS_XML);\n doc.appendChild(element);\n\n String nameSpace = createNameSpace(template.getClassName(), template.getName());\n\n element.setAttribute(\"targetNamespace\", nameSpace);\n element.setAttribute(\"xmlns:\" + NS_TARGET, nameSpace);\n element.setAttribute(\"xmlns:jxb\", \"http://java.sun.com/xml/ns/jaxb\");\n element.setAttribute(\"elementFormDefault\", \"qualified\");\n element.setAttribute(\"attributeFormDefault\", \"qualified\");\n element.setAttribute(\"jxb:version\", \"2.1\");\n element.setAttribute(\"version\", template.getVersion());\n\n createComplexType(principal, doc, entity);\n\n try\n {\n // TODO Something with how the Document is created prevents it from\n // being used as a DOMSource. Serializing it and Deserializing it\n // appears to resolve the issue at a performance hit. It would be\n // nice to remove this step.\n return XmlHelper.loadXmlFrom(XmlHelper.formatXml(doc));\n }\n catch (SAXException | IOException e)\n {\n throw new ParserConfigurationException(e.getMessage());\n }\n\n }",
"private static DocumentBuilder instantiateParser()\n throws IOException {\n\n DocumentBuilder parser = null;\n\n try {\n DocumentBuilderFactory fac = DocumentBuilderFactory.newInstance();\n fac.setNamespaceAware( true );\n fac.setValidating( false );\n fac.setIgnoringElementContentWhitespace( false );\n parser = fac.newDocumentBuilder();\n return parser;\n } catch ( ParserConfigurationException e ) {\n throw new IOException( \"Unable to initialize DocumentBuilder: \" + e.getMessage() );\n }\n }",
"public ConferenceInfoDocument()\n\t\tthrows XMLException\n\t{\n\t\ttry {\n\t\t\tdocument = XMLUtils.createDocument();\n\t\t}\n\t\tcatch (Exception e) {\n\t\t\tlogger.error(\"Failed to create a new document.\", e);\n\t\t\tthrow (new XMLException(e.getMessage()));\n\t\t}\n\n\t\tconferenceInfo = document.createElementNS(NAMESPACE, CONFERENCE_INFO_ELEMENT_NAME);\n\t\tdocument.appendChild(conferenceInfo);\n\n\t\tsetVersion(1);\n\n\t\tconferenceDescription = document.createElement(CONFERENCE_DESCRIPTION_ELEMENT_NAME);\n\t\tconferenceInfo.appendChild(conferenceDescription);\n\n\t\tconferenceState = document.createElement(CONFERENCE_STATE_ELEMENT_NAME);\n\t\tconferenceInfo.appendChild(conferenceState);\n\t\tsetUserCount(0);\n\n\t\tusers = document.createElement(USERS_ELEMENT_NAME);\n\t\tconferenceInfo.appendChild(users);\n\t}",
"public String printToXml()\n {\n XMLOutputter outputter = new XMLOutputter();\n outputter.setFormat(org.jdom.output.Format.getPrettyFormat());\n return outputter.outputString(this.toXml());\n }",
"public static Document copy(Node xml)\r\n throws SAXException,\r\n IOException,\r\n TransformerConfigurationException,\r\n TransformerException \r\n {\r\n return XMLUtil.getOwnerDocument(copy(xml, (Node)null));\r\n }",
"public static synchronized Document parseToDocument(String xmlText) throws UMROException {\r\n xmlText = xmlText.substring(xmlText.indexOf('<'));\r\n Document document = null;\r\n try {\r\n DocumentBuilderFactory domFactory = DocumentBuilderFactory.newInstance();\r\n domFactory.setNamespaceAware(true);\r\n DocumentBuilder builder = domFactory.newDocumentBuilder();\r\n document = builder.parse(new InputSource(new StringReader(xmlText)));\r\n } catch (IOException ex) {\r\n throw new UMROException(\"IOException while parsing document: \" + ex);\r\n } catch (ParserConfigurationException ex) {\r\n throw new UMROException(\"ParserConfigurationException while parsing document: \" + ex);\r\n } catch (SAXException ex) {\r\n throw new UMROException(\"SAXException while parsing document: \" + ex);\r\n }\r\n return document;\r\n }",
"public DocumentBuilderFactoryImpl() {\n super();\n }",
"protected synchronized DocumentBuilder getDocumentBuilder() throws ParserConfigurationException {\r\n if (documentBuilder != null) {\r\n return documentBuilder;\r\n } else {\r\n // create the document builder\r\n DocumentBuilderFactory factory = DocumentBuilderFactory.newInstance();\r\n factory.setNamespaceAware(true);\r\n this.documentBuilder = factory.newDocumentBuilder();\r\n return this.documentBuilder;\r\n }\r\n }",
"public Document getXML() {\n\t\treturn null;\n\t}",
"public DOMParser() { ; }",
"public String generatedXmlFile(Document doc){\n\t\tStringWriter sw = new StringWriter();\r\n\t\t\t\ttry {\r\n\t\t\t\t\t\r\n\t\t\t\t\tTransformerFactory tf = TransformerFactory.newInstance();\r\n\t\t\t\t\tTransformer transformer = tf.newTransformer();\r\n\t\t\t\t\ttransformer.setOutputProperty(OutputKeys.OMIT_XML_DECLARATION, \"no\");\r\n\t\t\t\t\ttransformer.setOutputProperty(OutputKeys.METHOD, \"xml\");\r\n\t\t\t\t\ttransformer.setOutputProperty(OutputKeys.INDENT, \"yes\");\r\n\t\t\t\t\ttransformer.setOutputProperty(OutputKeys.ENCODING, \"UTF-8\");\r\n\r\n\t\t\t\t\ttransformer.transform(new DOMSource(doc), new StreamResult(sw));\r\n\t\t\t\t\t\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception ex) {\r\n\t\t\t\t\tthrow new RuntimeException(\"Error converting to String\", ex);\r\n\t\t\t\t}\r\n\t\t\t\treturn sw.toString();\r\n\t}",
"public static Document loadXMLFrom(String xml) throws Exception {\n\t\tSource source = new StreamSource(new StringReader(xml));\n\t\tDOMResult result = new DOMResult();\n\t\tTransformerFactory.newInstance().newTransformer().transform(source, result);\n\t\treturn (Document) result.getNode();\n\t}",
"public DocumentWrapper(XmlNode doc, String baseURI, Configuration config) {\n //System.err.println(\"Creating DocumentWrapper for \" +node);\n this.node = doc;\n this.parent = null;\n this.index = 0;\n //super(doc, null, 0);\n if (doc.get_NodeType().Value != XmlNodeType.Document) {\n throw new IllegalArgumentException(\"Node must be a DOM Document\");\n }\n node = doc;\n nodeKind = Type.DOCUMENT;\n this.baseURI = baseURI;\n docWrapper = this;\n\n// // Find out if this is a level-3 DOM implementation\n// Method[] methods = doc.getClass().getMethods();\n// for (int i=0; i<methods.length; i++) {\n// if (methods[i].getName().equals(\"isSameNode\")) {\n// level3 = true;\n// break;\n// }\n// }\n //System.err.println(\"Setting configuration\");\n setConfiguration(config);\n }",
"public static PSMLDocument createDocument(Profile profile) {\n return getService().createDocument(profile);\n }",
"public static Document convertStringToDocument(String xmlStr) {\n\t DocumentBuilderFactory factory = DocumentBuilderFactory.newInstance(); \n\t DocumentBuilder builder; \n\t try \n\t { \n\t builder = factory.newDocumentBuilder(); \n\t Document doc = builder.parse( new InputSource( new StringReader( xmlStr ) ) ); \n\t \n\t return doc;\n\t } catch (Exception e) { \n\t \tString mensajeError = \"Error en el formato del archivo XML\" + \"\\nIntÚntelo denuevo con otro archivo\";\n\t\t\t\tJOptionPane.showMessageDialog(null,mensajeError,\"Parsing Error\",JOptionPane.ERROR_MESSAGE); \n\t\t\t\te.printStackTrace();\n\t } \n\t return null;\n\t }",
"public static native Element createDom(DomConfig config) /*-{\r\n\t\tvar configJS = [email protected]::getJsObject()();\r\n\t\treturn $wnd.Ext.DomHelper.createDom(configJS);\r\n\t}-*/;",
"public XMLDocument (double version, boolean standalone)\r\n\t{\r\n\t\tprolog = new Vector<Object> (2);\r\n\t\tStringBuffer versionStr = new StringBuffer ();\r\n\t\tversionStr.append (\"<?xml version=\\\"\");\r\n\t\tversionStr.append (version);\r\n\t\tversionStr.append (\"\\\" standalone=\\\"\");\r\n\t\tif (standalone)\r\n\t\t\tversionStr.append (\"yes\\\"?>\");\r\n\t\telse\r\n\t\t\tversionStr.append (\"no\\\"?>\\n\");\r\n\t\tthis.versionDecl = versionStr.toString ();\r\n\t\t/**\r\n * FIXME: ECS currently does not do any ordering of attributes. Although\r\n * about 99% of the time, this has no problems, in the initial XML\r\n * declaration, it can be a problem in certain frameworks (e.g.\r\n * Cocoon/Xerces/Xalan). So instead of adding an element here, we have\r\n * to store this first command in a String and add it to the output at\r\n * output time.\r\n */\r\n\t\t/**\r\n * PI versionDecl = new PI().setTarget(\"xml\"); if (standalone)\r\n * versionDecl.addInstruction(\"standalone\", \"yes\"); else\r\n * versionDecl.addInstruction(\"standalone\", \"no\");\r\n * versionDecl.setVersion(version); prolog.addElement(versionDecl);\r\n */\r\n\t}",
"public Element toXml(Document doc)\n {\n if (doc == null)\n throw new IllegalArgumentException(\"doc may not be null\");\n\n Element root = doc.createElement(getRelationType());\n\n // add our db state\n addComponentState(root);\n\n for (int i = 0; i < m_keyNames.size(); i++)\n {\n PSXmlDocumentBuilder.addElement(doc, root,\n m_keyNames.get(i).toString(), m_keyValues.get(i).toString());\n }\n\n return root;\n }",
"public static void serializeXML\n (org.w3c.dom.Document resultDocument, Writer output)\n throws IOException\n {\n\n OutputFormat myOutputFormat =\n new OutputFormat(resultDocument,\n \"UTF-8\",\n true);\n\n // output used to be replaced with System.out\n XMLSerializer s =\n new XMLSerializer(output,\n myOutputFormat);\n\n try {\n s.serialize(resultDocument);\n // next line added by THA 21.03.05\n output.flush();\n }\n catch (IOException e) {\n System.err.println(\"Couldn't serialize document: \"+\n e.getMessage());\n throw e;\n }\n\n // end of addition\n }",
"public String toXML() {\n StringWriter stringWriter = new StringWriter();\n PrintWriter printWriter = new PrintWriter(stringWriter, true);\n toXML(printWriter);\n return stringWriter.toString();\n }",
"public static Document getDocument(InputSource in){\t\t\n\t\ttry {\n\t\t\tDocumentBuilderFactory docbuilderf = DocumentBuilderFactory.newInstance();\n\t\t\tDocumentBuilder docb = docbuilderf.newDocumentBuilder();\n\t\t\treturn docb.parse(in);\n\t\t} catch (SAXException e) {\n\t\t\t// TODO Parseprobleem... Invalide bestand.\n\t\t\tthrow new RuntimeException(e);\n\t\t} catch (IOException e) {\n\t\t\t// TODO IOException, bestand bestaat niet of doet iets anders.\n\t\t\te.printStackTrace();\n\t\t\tthrow new RuntimeException(e);\n\t\t} catch (ParserConfigurationException e) {\n\t\t\t// Configuratie zou moeten werken\n\t\t\tthrow new RuntimeException(e);\n\t\t}\n\t}",
"public String formatXml(String str) throws UnsupportedEncodingException, IOException, DocumentException {\n\t\tSAXReader reader = new SAXReader();\r\n\t\t// System.out.println(reader);\r\n\t\t// 注释:创建一个串的字符输入流\r\n\t\tStringReader in = new StringReader(str);\r\n\t\tDocument doc = reader.read(in);\r\n\t\t// System.out.println(doc.getRootElement());\r\n\t\t// 注释:创建输出格式\r\n\t\tOutputFormat formater = OutputFormat.createPrettyPrint();\r\n\t\t// 注释:设置xml的输出编码\r\n\t\tformater.setEncoding(\"utf-8\");\r\n\t\t// 注释:创建输出(目标)\r\n\t\tStringWriter out = new StringWriter();\r\n\t\t// 注释:创建输出流\r\n\t\tXMLWriter writer = new XMLWriter(out, formater);\r\n\t\t// 注释:输出格式化的串到目标中,执行后。格式化后的串保存在out中。\r\n\t\twriter.write(doc);\r\n\r\n\t\tString destXML = out.toString();\r\n\t\twriter.close();\r\n\t\tout.close();\r\n\t\tin.close();\r\n\t\t// 注释:返回我们格式化后的结果\r\n\t\treturn destXML;\r\n\t}",
"private Document initialize() {\r\n Document doc = null;\r\n try {\r\n File file = new File(\"./evidence.xml\");\r\n DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\r\n DocumentBuilder docBuilder = dbFactory.newDocumentBuilder();\r\n doc = docBuilder.parse(file);\r\n doc.getDocumentElement().normalize();\r\n } catch (ParserConfigurationException | IOException | SAXException e) {\r\n System.err.println(\"Parser failed parse file:\"+e.getMessage());\r\n }\r\n return doc;\r\n }",
"@Nonnull\r\n private static Document _createDummyPayload () {\n final Document aXMLDoc = XMLFactory.newDocument ();\r\n final Node aRoot = aXMLDoc.appendChild (aXMLDoc.createElement (\"test\"));\r\n aRoot.appendChild (aXMLDoc.createTextNode (\"Text content\"));\r\n return aXMLDoc;\r\n }",
"@DOMSupport(DomLevel.ONE)\r\n@JsMetatype\r\npublic interface Document extends Node {\r\n\t\r\n\r\n\t/**\r\n\t * This is a convenience attribute that allows direct access to the child \r\n\t * node that is the document element of the document.\r\n\t */\r\n\t@Property Element getDocumentElement();\r\n\t\r\n\t/**\r\n\t * An attribute specifying the encoding used for this document at the time of the parsing. \r\n\t * This is null when it is not known, such as when the Document was created in memory.\r\n\t * @return\r\n\t * @since DOM Level 3\r\n\t */\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@Property String getInputEncoding();\r\n\r\n\t/**\r\n\t * An attribute specifying, as part of the XML declaration, \r\n\t * the encoding of this document. This is null when unspecified or when it is not known, \r\n\t * such as when the Document was created in memory.\r\n\t * @return\r\n\t * @since DOM Level 3\r\n\t */\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@Property String getXmlEncoding();\r\n\r\n\t/**\r\n\t * An attribute specifying, as part of the XML declaration, whether this document is standalone. \r\n\t * This is false when unspecified.\r\n\t * @return\r\n\t * @since DOM Level 3\r\n\t */\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@Property boolean getXmlStandalone();\r\n\t\r\n\t/**\r\n\t * An attribute specifying, as part of the XML declaration, whether this document is standalone.\r\n\t * @param xmlStandalone\r\n\t * @since DOM Level 3\r\n\t */\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@Property void setXmlStandalone(boolean xmlStandalone);\r\n\r\n\t/**\r\n\t * An attribute specifying, as part of the XML declaration, the version number of this document. \r\n\t * If there is no declaration and if this document supports the \"XML\" feature, the value is \"1.0\". \r\n\t * If this document does not support the \"XML\" feature, the value is always null. \r\n\t * Changing this attribute will affect methods that check for invalid characters in XML names. \r\n\t * Application should invoke Document.normalizeDocument() in order to check for invalid characters \r\n\t * in the Nodes that are already part of this Document. \r\n\t * DOM applications may use the DOMImplementation.hasFeature(feature, version) method with \r\n\t * parameter values \"XMLVersion\" and \"1.0\" (respectively) to determine if an implementation \r\n\t * supports [XML 1.0]. DOM applications may use the same method with parameter values \"XMLVersion\" \r\n\t * and \"1.1\" (respectively) to determine if an implementation supports [XML 1.1]. \r\n\t * In both cases, in order to support XML, an implementation must also support the \"XML\" feature \r\n\t * defined in this specification. Document objects supporting a version of the \"XMLVersion\" feature \r\n\t * must not raise a NOT_SUPPORTED_ERR exception for the same version number when using \r\n\t * Document.xmlVersion. \r\n\t * @since DOM Level 3\r\n\t */\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@Property String getXmlVersion();\r\n\t\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@Property void setXmlVersion(String xmlVersion);\r\n\r\n\t/**\r\n\t * An attribute specifying whether error checking is enforced or not. \r\n\t * When set to false, the implementation is free to not test every possible error case normally \r\n\t * defined on DOM operations, and not raise any DOMException on DOM operations or report errors \r\n\t * while using Document.normalizeDocument(). In case of error, the behavior is undefined. \r\n\t * This attribute is true by default.\r\n\t * @return\r\n\t * @since DOM Level 3\r\n\t */\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@Property boolean getStrictErrorChecking();\r\n\t\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@Property void setStrictErrorChecking(boolean strictErrorChecking);\r\n\r\n\t/**\r\n\t * The location of the document or null if undefined or if the Document was created using \r\n\t * DOMImplementation.createDocument. No lexical checking is performed when setting this attribute; \r\n\t * this could result in a null value returned when using Node.baseURI. \r\n\t * Beware that when the Document supports the feature \"HTML\" [DOM Level 2 HTML], \r\n\t * the href attribute of the HTML BASE element takes precedence over this attribute \r\n\t * when computing Node.baseURI. \r\n\t * @return\r\n\t * @since DOM Level 3\r\n\t */\r\n\t@Property String getDocumentURI();\r\n\t@DOMSupport( DomLevel.THREE)\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P, BrowserType.OPERA_9P})\r\n\t@Property void setDocumentURI(String documentURI);\r\n \r\n\t/**\r\n\t * The configuration used when Document.normalizeDocument() is invoked. \r\n\t * @return\r\n\t * @since DOM Level 3\r\n\t */\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@BrowserSupport(BrowserType.UNDEFINED)\r\n\t@Property DOMConfiguration getDomConfig();\r\n\t\r\n\t /**\r\n * The Document Type Declaration (see DocumentType) associated with this document. \r\n * For XML documents without a document type declaration this returns null. For HTML documents, \r\n * a DocumentType object may be returned, independently of the presence or absence of document type \r\n * declaration in the HTML document. This provides direct access to the DocumentType node, \r\n * child node of this Document. This node can be set at document creation time and later changed \r\n * through the use of child nodes manipulation methods, such as Node.insertBefore, \r\n * or Node.replaceChild. Note, however, that while some implementations may instantiate \r\n * different types of Document objects supporting additional features than the \"Core\", \r\n * such as \"HTML\" [DOM Level 2 HTML], based on the DocumentType specified at creation time, \r\n * changing it afterwards is very unlikely to result in a change of the features supported.\r\n * @return\r\n * @since DOM Level 3\r\n */\r\n @DOMSupport(DomLevel.THREE)\r\n @Property DocumentType getDoctype();\r\n \r\n\t/**\r\n\t * The DOMImplementation object that handles this document. \r\n\t * A DOM application may use objects from multiple implementations.\r\n\t */\r\n @Property DOMImplementation getImplementation();\r\n\r\n\t/**\r\n\t * Creates an element of the type specified. Note that the instance \r\n\t * returned implements the <code>Element</code> interface, so attributes \r\n\t * can be specified directly on the returned object.\r\n\t * <br>In addition, if there are known attributes with default values, \r\n\t * <code>Attr</code> nodes representing them are automatically created \r\n\t * and attached to the element.\r\n\t * <br>To create an element with a qualified name and namespace URI, use \r\n\t * the <code>createElementNS</code> method.\r\n\t * @param tagName The name of the element type to instantiate. For XML, \r\n\t * this is case-sensitive, otherwise it depends on the \r\n\t * case-sensitivity of the markup language in use. In that case, the \r\n\t * name is mapped to the canonical form of that markup by the DOM \r\n\t * implementation.\r\n\t * @return A new <code>Element</code> object with the \r\n\t * <code>nodeName</code> attribute set to <code>tagName</code>, and \r\n\t * <code>localName</code>, <code>prefix</code>, and \r\n\t * <code>namespaceURI</code> set to <code>null</code>.\r\n\t * @exception DOMException\r\n\t * INVALID_CHARACTER_ERR: Raised if the specified name is not an XML \r\n\t * name according to the XML version in use specified in the \r\n\t * <code>Document.xmlVersion</code> attribute.\r\n\t */\r\n @FactoryFunc\r\n\t@Function Element createElement(String tagName);\r\n\r\n\t/**\r\n\t * Creates a <code>Text</code> node given the specified string.\r\n\t * @param data The data for the node.\r\n\t * @return The new <code>Text</code> object.\r\n\t */\r\n\t@Function Text createTextNode(String data);\r\n\r\n\t/**\r\n\t * Returns a <code>NodeList</code> of all the <code>Elements</code> in \r\n\t * document order with a given tag name and are contained in the \r\n\t * document.\r\n\t * @param tagname The name of the tag to match on. The special value \"*\" \r\n\t * matches all tags. For XML, the <code>tagname</code> parameter is \r\n\t * case-sensitive, otherwise it depends on the case-sensitivity of the \r\n\t * markup language in use. \r\n\t * @return A new <code>NodeList</code> object containing all the matched \r\n\t * <code>Elements</code>.\r\n\t */\r\n\t@FactoryFunc\r\n @JsArray(Node.class)\r\n\t@Function NodeList getElementsByTagName(String tagname);\r\n\t\r\n @BrowserSupport({BrowserType.NONE})\r\n @ARename(name = \"getElementsByTagName\")\r\n @JstExclude\r\n @Function NodeList byTag(String tagName);\r\n\r\n\t/**\r\n\t * Imports a node from another document to this document, without altering \r\n\t * or removing the source node from the original document; this method \r\n\t * creates a new copy of the source node. The returned node has no \r\n\t * parent; (<code>parentNode</code> is <code>null</code>).\r\n\t */\r\n @DOMSupport(DomLevel.TWO)\r\n @BrowserSupport({BrowserType.FIREFOX_1P, BrowserType.OPERA_7P})\r\n @Function Node importNode(Node importedNode, boolean deep);\r\n\r\n\t/**\r\n\t * Returns the <code>Element</code> that has an ID attribute with the \r\n\t * given value. If no such element exists, this returns <code>null</code>\r\n\t * . If more than one element has an ID attribute with that value, what \r\n\t * is returned is undefined. \r\n\t * <br> The DOM implementation is expected to use the attribute \r\n\t * <code>Attr.isId</code> to determine if an attribute is of type ID. \r\n\t * <p ><b>Note:</b> Attributes with the name \"ID\" or \"id\" are not of type \r\n\t * ID unless so defined.\r\n\t * @param elementId The unique <code>id</code> value for an element.\r\n\t * @return The matching element or <code>null</code> if there is none.\r\n\t * @since DOM Level 2\r\n\t */\r\n @DOMSupport(DomLevel.TWO)\r\n @Function Element getElementById(String elementId);\r\n \r\n @BrowserSupport({BrowserType.NONE})\r\n @ARename(name = \"getElementById\")\r\n @JstExclude\r\n @Function Element byId(String elementId);\r\n\r\n \r\n\t/**\r\n\t * Creates an Attr of the given name. Note that the Attr instance can then be set on an Element \r\n\t * using the setAttributeNode method. To create an attribute with a qualified name and namespace URI, \r\n\t * use the createAttributeNS method.\r\n\t * @param name\r\n\t * @return\r\n\t */\r\n @Function Attr createAttribute(String name);\r\n \r\n\t/**\r\n\t * Creates an element of the given qualified name and namespace URI. Per [XML Namespaces], \r\n\t * applications must use the value null as the namespaceURI parameter for methods \r\n\t * if they wish to have no namespace.\r\n\t * @param namespaceURI\r\n\t * @param qualifiedName\r\n\t * @return\r\n\t * @since DOM Level 2\r\n\t */\r\n @DOMSupport(DomLevel.TWO)\r\n @BrowserSupport({BrowserType.FIREFOX_2P, BrowserType.OPERA_9P})\r\n @Function Element createElementNS(String namespaceURI, String qualifiedName);\r\n \r\n\t/**\r\n\t * Creates an attribute of the given qualified name and namespace URI. Per [XML Namespaces], \r\n\t * applications must use the value null as the namespaceURI parameter for methods \r\n\t * if they wish to have no namespace.\r\n\t * @param namespaceURI\r\n\t * @param qualifiedName\r\n\t * @return\r\n\t * @since DOM Level 2\r\n\t */\r\n @DOMSupport(DomLevel.TWO)\r\n @BrowserSupport({BrowserType.FIREFOX_2P, BrowserType.OPERA_9P})\r\n\t@Function Attr createAttributeNS(String namespaceURI, String qualifiedName);\r\n\r\n\t/**\r\n\t * Returns a NodeList of all the Elements with a given local name and namespace URI in document order.\r\n\t * @param namespaceURI\r\n\t * @param localName\r\n\t * @return\r\n\t * @since DOM Level 2\r\n\t */\r\n\t@DOMSupport(DomLevel.TWO)\r\n @BrowserSupport({BrowserType.FIREFOX_2P, BrowserType.OPERA_9P, BrowserType.IE_9P})\r\n @JsArray(Node.class)\r\n @FactoryFunc\r\n\t@Function NodeList getElementsByTagNameNS(String namespaceURI, String localName);\r\n \r\n @BrowserSupport({BrowserType.NONE})\r\n @ARename(name = \"getElementsByTagNameNS\")\r\n @JstExclude\r\n @Function NodeList byTagNS(String namespaceURI, String localName);\r\n \r\n\t/**\r\n\t * Creates an EntityReference object. In addition, if the referenced entity is known, \r\n\t * the child list of the EntityReference node is made the same as that of the corresponding Entity node.\r\n\t * @param name\r\n\t * @return\r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@Function EntityReference createEntityReference(String name);\r\n \r\n\t/**\r\n\t * Creates a Comment node given the specified string.\r\n\t * @param data\r\n\t * @return\r\n\t */\r\n\t@Function Comment createComment(String data);\r\n\r\n\t/**\r\n\t * Creates a CDATASection node whose value is the specified string.\r\n\t * @param data\r\n\t * @return\r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @BrowserSupport({BrowserType.FIREFOX_2P, BrowserType.OPERA_9P})\r\n\t@Function CDATASection createCDATASection(String data);\r\n\r\n\t/**\r\n\t * Creates a ProcessingInstruction node given the specified name and data strings.\r\n\t * @param target\r\n\t * @param data\r\n\t * @return\r\n\t */\r\n\r\n\t@DOMSupport(DomLevel.ONE)\r\n @BrowserSupport({BrowserType.FIREFOX_2P, BrowserType.OPERA_9P})\r\n\t@Function ProcessingInstruction createProcessingInstruction(String target, String data);\r\n \r\n\t/**\r\n\t * Creates an empty DocumentFragment object. \r\n\t * @return\r\n\t */\r\n\t@Function DocumentFragment createDocumentFragment();\r\n\r\n\t/**\r\n\t * Attempts to adopt a node from another document to this document. \r\n\t * If supported, it changes the ownerDocument of the source node, its children, \r\n\t * as well as the attached attribute nodes if there are any. \r\n\t * If the source node has a parent it is first removed from the child list of its parent. \r\n\t * This effectively allows moving a subtree from one document to another (unlike importNode() \r\n\t * which create a copy of the source node instead of moving it). \r\n\t * When it fails, applications should use Document.importNode() instead. \r\n\t * Note that if the adopted node is already part of this document (i.e. the source and \r\n\t * target document are the same), this method still has the effect of removing the source node \r\n\t * from the child list of its parent, if any. \r\n\t * The following list describes the specifics for each type of node. \r\n\t * @param source\r\n\t * @return\r\n\t * @since DOM Level 3\r\n\t */\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P, BrowserType.OPERA_9P})\r\n\t@Function Node adoptNode(Node source);\r\n\r\n\t/**\r\n\t * This method acts as if the document was going through a save and load cycle, \r\n\t * putting the document in a \"normal\" form. As a consequence, this method updates the \r\n\t * replacement tree of EntityReference nodes and normalizes Text nodes, as defined in \r\n\t * the method Node.normalize(). Otherwise, the actual result depends on the features being set \r\n\t * on the Document.domConfig object and governing what operations actually take place. \r\n\t * Noticeably this method could also make the document namespace well-formed according to \r\n\t * the algorithm described in Namespace Normalization, check the character normalization, \r\n\t * remove the CDATASection nodes, etc. See DOMConfiguration for details. \r\n\t * @since DOM Level 3\r\n\t *\r\n\t */\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@Function void normalizeDocument();\r\n\r\n\t/**\r\n\t * Rename an existing node of type ELEMENT_NODE or ATTRIBUTE_NODE. When possible this simply changes \r\n\t * the name of the given node, otherwise this creates a new node with the specified name \r\n\t * and replaces the existing node with the new node as described below. If simply changing the name of\r\n\t * the given node is not possible, the following operations are performed: a new node is created, \r\n\t * any registered event listener is registered on the new node, any user data attached to the old node \r\n\t * is removed from that node, the old node is removed from its parent if it has one, the children \r\n\t * are moved to the new node, if the renamed node is an Element its attributes are moved to the \r\n\t * new node, the new node is inserted at the position the old node used to have in its parent's \r\n\t * child nodes list if it has one, the user data that was attached to the old node is attached to \r\n\t * the new node.\r\n\t * When the node being renamed is an Element only the specified attributes are moved, \r\n\t * default attributes originated from the DTD are updated according to the new element name. \r\n\t * In addition, the implementation may update default attributes from other schemas. \r\n\t * Applications should use Document.normalizeDocument() to guarantee these attributes are up-to-date. \r\n\t * When the node being renamed is an Attr that is attached to an Element, the node is first removed \r\n\t * from the Element attributes map. Then, once renamed, either by modifying the existing node or \r\n\t * creating a new one as described above, it is put back. In addition,\r\n\t * <ul>\r\n\t * <li>a user data event NODE_RENAMED is fired,</li>\r\n\t * <li>when the implementation supports the feature \"MutationNameEvents\", \r\n\t * each mutation operation involved in this method fires the appropriate event, \r\n\t * and in the end the event {http://www.w3.org/2001/xml-events, DOMElementNameChanged} or \r\n\t * {http://www.w3.org/2001/xml-events, DOMAttributeNameChanged} is fired.</li>\r\n\t * </ul>\r\n\t * @param n\r\n\t * @param namespaceURI\r\n\t * @param qualifiedName\r\n\t * @return\r\n\t * @since DOM Level 3\r\n\t */\r\n\t@DOMSupport(DomLevel.THREE)\r\n\t@BrowserSupport({BrowserType.FIREFOX_2P})\r\n\t@Function Node renameNode(Node n, \r\n String namespaceURI, \r\n String qualifiedName);\r\n\r\n\t/**\r\n\t * The get the last modified date & time of the document. \r\n\t * \r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property String getLastModified();\r\n\r\n\t/**\r\n\t * The get the document background color \r\n\t * \r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property String getBgColor();\r\n\r\n\t/**\r\n\t * The get the active link color \r\n\t * \r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property String getAlinkColor();\r\n\r\n\t/**\r\n\t * The get the visited link color \r\n\t * \r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property String getVlinkColor();\r\n\r\n\t/**\r\n\t * The get the link color \r\n\t * \r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property String getLinkColor();\r\n\r\n\t/**\r\n\t * The get the protocol \r\n\t * \r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property String getProtocol();\r\n\r\n\t/**\r\n\t * The get the cookie \r\n\t * \r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property String getCookie();\r\n\r\n\t/**\r\n\t * The get the document fg color \r\n\t * \r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property String getFgColor();\r\n\r\n\t/**\r\n\t * The get the state of the document \r\n\t * \r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property String getReadyState();\r\n\r\n\t/**\r\n\t * The get the security of the document \r\n\t * \r\n\t */\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property String getSecurity();\r\n\t\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property void setBgColor(String value);\r\n\t\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property void setFgColor(String value);\r\n\t\r\n\t@DOMSupport(DomLevel.ONE)\r\n @Property void setLinkColor(String value);\r\n}",
"public Node makeNode(Document xmlDoc) {\r\n Element out = xmlDoc.createElement(this.parent.getHeader());\r\n this.parent.updateSave();\r\n if (this.nodeText != null) {\r\n out.setTextContent(nodeText);\r\n }\r\n this.makeAtributes(out);\r\n for (int i = 0; i < this.children.size(); i++) {\r\n out.appendChild(this.children.get(i).makeNode(xmlDoc));\r\n }\r\n return out;\r\n}",
"public static final Document parse(final InputSource input) {\r\n if (logB.isDebugEnabled()) {\r\n logB.debug(\"XmlFactory.parse : begin\");\r\n }\r\n\r\n Document document = null;\r\n\r\n try {\r\n input.setEncoding(ENCODING);\r\n document = getFactory().newDocumentBuilder().parse(input);\r\n } catch (final SAXException se) {\r\n logB.error(\"XmlFactory.parse : error\", se);\r\n } catch (final IOException ioe) {\r\n logB.error(\"XmlFactory.parse : error\", ioe);\r\n } catch (final ParserConfigurationException pce) {\r\n logB.error(\"XmlFactory.parse : error\", pce);\r\n }\r\n\r\n if (logB.isInfoEnabled()) {\r\n logB.info(\"XmlFactory.parse : exit : \" + document);\r\n }\r\n\r\n return document;\r\n }",
"public void buildDocument() {\n/* 220 */ setDocument(getDocumentLoader().getDocument(getClass()), \"text/html\", \"ISO-8859-1\");\n/* */ \n/* 222 */ syncAccessMethods();\n/* */ }",
"public static Document getNamespaceAwareDocument(Document inputDocument) {\r\n return bytesToXml(doc2bytes(inputDocument), true);\r\n }"
]
| [
"0.7592214",
"0.75508565",
"0.73276615",
"0.7321202",
"0.7206171",
"0.7153396",
"0.6929297",
"0.67786545",
"0.66497433",
"0.658112",
"0.65507674",
"0.65467924",
"0.64916563",
"0.64307874",
"0.64307874",
"0.64307874",
"0.64307874",
"0.6374853",
"0.6300943",
"0.6284289",
"0.623846",
"0.62350935",
"0.62002814",
"0.6181197",
"0.6149824",
"0.6142144",
"0.61239636",
"0.6096654",
"0.6088354",
"0.6071929",
"0.59543496",
"0.5904071",
"0.5863832",
"0.5820471",
"0.5815381",
"0.5807997",
"0.5773944",
"0.5736151",
"0.572604",
"0.57218885",
"0.56825954",
"0.56816596",
"0.56787455",
"0.5660913",
"0.56584984",
"0.5635618",
"0.56085503",
"0.5579491",
"0.55620354",
"0.5555762",
"0.5546786",
"0.5546786",
"0.5546786",
"0.5546511",
"0.5531299",
"0.55309117",
"0.5520598",
"0.54990387",
"0.5487508",
"0.548708",
"0.5485458",
"0.5485458",
"0.5485458",
"0.54834026",
"0.54649484",
"0.54607105",
"0.54483825",
"0.54430157",
"0.542812",
"0.54264176",
"0.5426346",
"0.54261565",
"0.5417746",
"0.54163086",
"0.5411587",
"0.54052794",
"0.54050744",
"0.5388326",
"0.5377869",
"0.53661036",
"0.5361435",
"0.53558934",
"0.5348488",
"0.53453684",
"0.5343137",
"0.53377265",
"0.5337123",
"0.5332875",
"0.5313834",
"0.5311743",
"0.53030705",
"0.529863",
"0.5289846",
"0.52835023",
"0.5281314",
"0.52649647",
"0.52644205",
"0.52628994",
"0.52628577",
"0.526232",
"0.5257394"
]
| 0.0 | -1 |
float f=3.6f; / accepted In Java, when you type a decimal number as 3.6, its interpreted as a double. double is a 64bit precision IEEE 754 floating point, while float is a 32bit precision IEEE 754 floating point. As a float is less precise than a double, the conversion cannot be performed implicitly. If you want to create a float, you should end your number with f (i.e.: 3.6f). | public static void main(String[] args) {
Runtime rt = Runtime.getRuntime();
System.out.println("Available Free Memory: " + rt.freeMemory());
for(int i=0; i<10000; i++ ) {
GC1 x = new GC1(i);
}
System.out.println("Free Memory before call to gc(): " +rt.freeMemory());
System.runFinalization();
System.gc();
System.out.println(" Free Memory after call to gc(): " +
rt.freeMemory());
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public float evaluateAsFloat();",
"public void setfVal(float value){\n this.fVal = value;\n }",
"public final void ruleFloat() throws RecognitionException {\n\n \t\tint stackSize = keepStackSize();\n \t\n try {\n // InternalMyDsl.g:216:2: ( ( 'Float' ) )\n // InternalMyDsl.g:217:2: ( 'Float' )\n {\n // InternalMyDsl.g:217:2: ( 'Float' )\n // InternalMyDsl.g:218:3: 'Float'\n {\n before(grammarAccess.getFloatAccess().getFloatKeyword()); \n match(input,12,FOLLOW_2); \n after(grammarAccess.getFloatAccess().getFloatKeyword()); \n\n }\n\n\n }\n\n }\n catch (RecognitionException re) {\n reportError(re);\n recover(input,re);\n }\n finally {\n\n \trestoreStackSize(stackSize);\n\n }\n return ;\n }",
"public Flt(float f) {this.f = new Float(f);}",
"public static void main(String[] args){\n\t\tFloat f=new Float(12);\r\n\t}",
"public static float fVal( Number n ){\n if ( n == null )\n return 0f;\n return n.floatValue();\n }",
"public static boolean floatType(FileInputStream f){\n if(observer != null){\n observer.parser.setCurrentRule(\"floatType\", true);\n }\n CToken t = new CToken();\n\n t = getUsePeek(f);\n \n if(!t.token.equals(\"float\") && !t.token.equals(\"double\")){\n return false;\n }\n \n CScanner.needToUsePeekedToken = false;\n if(observer != null){\n observer.parser.setCurrentRule(\"floatType\", false);\n }\n return true;\n }",
"private static void setValueFloat(float value)\n {\n Util.valueFloat = value;\n }",
"public Value(float f) {\n aFloat = f;\n itemClass = Float.class;\n type = DataType.FLOAT;\n }",
"FloatValue createFloatValue();",
"FloatValue createFloatValue();",
"public final void mo8765a(float f) {\n }",
"@Test\n\tpublic void float1() {\n\t\tfloat actualValue = Maximum.getmaximum1(12f,14f,15f);\n\t\tAssert.assertEquals(15,actualValue ,0);\n\t}",
"public float toFloat() {\n return (float) numerator/(float) denominator;\n }",
"protected float toFloat(String s){\n return Float.parseFloat(s);\n }",
"double floatField(String name, boolean isDefined, double value,\n FloatSpecification spec) throws NullField, InvalidFieldValue;",
"@Test\n\tvoid testAddFloat() {\n\t\tfloat result = calculator.add(3.4F,1F);\n\t\tassertEquals(4.4,result,0.0000009536732);//delta\n\t}",
"public FloatType asFloat() {\n return TypeFactory.getIntType(toInt(this.getValue())).asFloat();\n }",
"public boolean isAfloat(){\n \treturn afloat;\r\n }",
"public float toFloat(){\n\t\tString s = txt().trim();\n\t\tfloat i;\n\t\ttry{\n\t\t\ti = Float.parseFloat(s);\n\t\t}catch(NumberFormatException exp){\n\t\t\texp.printStackTrace();\n\t\t\treturn 0f;\n\t\t\t\n\t\t}\n\t\treturn i;\t\n\t}",
"public static float leerFloat() {\n\t\tthrow new UnsupportedOperationException();\n\t}",
"include<stdio.h>\nint main()\n{\n int celcius;\n float faren;\n scanf(\"%d\",&celcius);\n faren=(celcius*1.8)+32;\n printf(\"%.2f\",faren);\n \n}",
"public static void main(String[] args)\n {\n\n double myDouble = 3.14;\n float myFloat = 3.14f; //Removing the f will cause an error due to lossy conversion\n double yourDouble = myFloat; //Widening/lossless conversions won't raise errors\n }",
"void mo84656a(float f);",
"void mo56155a(float f);",
"public Float convertStringToFloat(String s ) {\n\t\t\treturn Float.valueOf(s);\n\t\t}",
"@ZenCodeType.Caster\n @ZenCodeType.Method\n default float asFloat() {\n \n return notSupportedCast(BasicTypeID.FLOAT);\n }",
"static float queryFloat (String prompt)\n\t{\n\t\tString entry ;\n\t\tfloat entryFloat ;\n\t\tSystem.out.print (prompt) ;\n\t\tentry = scanIn.nextLine() ;\n\t\tif (entry.length() == 0)\n\t\t{\n\t\t\tentryFloat = 0f ;\n\t\t}\n\t\telse\n\t\t{\n\t\t\tentryFloat = Float.parseFloat (entry) ;\n\t\t}\n\n\t\treturn entryFloat ;\n\t}",
"public float readFloat() {\n\t\tif(!isInit) return 0F;\n\t\tfloat result = 0F;\n\t\tisListening = true;\n\t\twriteLine(\"Waiting for Float input...\");\n\t\twhile(isListening) {\n\t\t\ttry {\n\t\t\t\tresult = Float.parseFloat(inputArea.getText());\n\t\t\t} catch(NumberFormatException nfe) {\n\t\t\t\tresult= 0F;\n\t\t\t}\n\t\t}\n\t\tinputArea.setText(\"\");\n\t\twriteLine(\"Input: \" + result);\n\t\treturn result;\n\t}",
"@Test\n public void test_TCM__float_getFloatValue() {\n Attribute attr = new Attribute(\"test\", \"1.00000009999e+10f\");\n float flt = 1.00000009999e+10f;\n try {\n assertTrue(\"incorrect float conversion\",\n attr.getFloatValue() == flt);\n } catch (DataConversionException e) {\n fail(\"couldn't convert to float\");\n }\n\n // test an invalid float\n\n attr.setValue(\"1.00000009999e\");\n try {\n attr.getFloatValue();\n fail(\"incorrect float conversion from non float\");\n } catch (DataConversionException e) {\n\t\t\t// Do nothing\n\t\t} catch (Exception e) {\n\t\t\tfail(\"Unexpected exception \" + e.getClass());\n }\n\n }",
"float readFloat();",
"public final void mFLOAT_TYPE() throws RecognitionException {\n try {\n int _type = FLOAT_TYPE;\n // /Users/benjamincoe/HackWars/C.g:183:2: ( 'float' )\n // /Users/benjamincoe/HackWars/C.g:183:4: 'float'\n {\n match(\"float\"); \n\n\n }\n\n this.type = _type;\n }\n finally {\n }\n }",
"public Float getT1B11Ffs6() {\r\n return t1B11Ffs6;\r\n }",
"public final EObject ruleFloatLiteral() throws RecognitionException {\n EObject current = null;\n\n Token lv_value_1_0=null;\n\n enterRule(); \n \n try {\n // ../com.jaspersoft.studio.editor.jrexpressions/src-gen/com/jaspersoft/studio/editor/jrexpressions/parser/antlr/internal/InternalJavaJRExpression.g:1738:28: ( ( () ( (lv_value_1_0= RULE_FLOAT ) ) ) )\n // ../com.jaspersoft.studio.editor.jrexpressions/src-gen/com/jaspersoft/studio/editor/jrexpressions/parser/antlr/internal/InternalJavaJRExpression.g:1739:1: ( () ( (lv_value_1_0= RULE_FLOAT ) ) )\n {\n // ../com.jaspersoft.studio.editor.jrexpressions/src-gen/com/jaspersoft/studio/editor/jrexpressions/parser/antlr/internal/InternalJavaJRExpression.g:1739:1: ( () ( (lv_value_1_0= RULE_FLOAT ) ) )\n // ../com.jaspersoft.studio.editor.jrexpressions/src-gen/com/jaspersoft/studio/editor/jrexpressions/parser/antlr/internal/InternalJavaJRExpression.g:1739:2: () ( (lv_value_1_0= RULE_FLOAT ) )\n {\n // ../com.jaspersoft.studio.editor.jrexpressions/src-gen/com/jaspersoft/studio/editor/jrexpressions/parser/antlr/internal/InternalJavaJRExpression.g:1739:2: ()\n // ../com.jaspersoft.studio.editor.jrexpressions/src-gen/com/jaspersoft/studio/editor/jrexpressions/parser/antlr/internal/InternalJavaJRExpression.g:1740:5: \n {\n if ( state.backtracking==0 ) {\n\n current = forceCreateModelElement(\n grammarAccess.getFloatLiteralAccess().getFloatLiteralAction_0(),\n current);\n \n }\n\n }\n\n // ../com.jaspersoft.studio.editor.jrexpressions/src-gen/com/jaspersoft/studio/editor/jrexpressions/parser/antlr/internal/InternalJavaJRExpression.g:1745:2: ( (lv_value_1_0= RULE_FLOAT ) )\n // ../com.jaspersoft.studio.editor.jrexpressions/src-gen/com/jaspersoft/studio/editor/jrexpressions/parser/antlr/internal/InternalJavaJRExpression.g:1746:1: (lv_value_1_0= RULE_FLOAT )\n {\n // ../com.jaspersoft.studio.editor.jrexpressions/src-gen/com/jaspersoft/studio/editor/jrexpressions/parser/antlr/internal/InternalJavaJRExpression.g:1746:1: (lv_value_1_0= RULE_FLOAT )\n // ../com.jaspersoft.studio.editor.jrexpressions/src-gen/com/jaspersoft/studio/editor/jrexpressions/parser/antlr/internal/InternalJavaJRExpression.g:1747:3: lv_value_1_0= RULE_FLOAT\n {\n lv_value_1_0=(Token)match(input,RULE_FLOAT,FOLLOW_RULE_FLOAT_in_ruleFloatLiteral4160); if (state.failed) return current;\n if ( state.backtracking==0 ) {\n\n \t\t\tnewLeafNode(lv_value_1_0, grammarAccess.getFloatLiteralAccess().getValueFLOATTerminalRuleCall_1_0()); \n \t\t\n }\n if ( state.backtracking==0 ) {\n\n \t if (current==null) {\n \t current = createModelElement(grammarAccess.getFloatLiteralRule());\n \t }\n \t\tsetWithLastConsumed(\n \t\t\tcurrent, \n \t\t\t\"value\",\n \t\tlv_value_1_0, \n \t\t\"FLOAT\");\n \t \n }\n\n }\n\n\n }\n\n\n }\n\n\n }\n\n if ( state.backtracking==0 ) {\n leaveRule(); \n }\n }\n \n catch (RecognitionException re) { \n recover(input,re); \n appendSkippedTokens();\n } \n finally {\n }\n return current;\n }",
"public static float promptForFloat(String prompt, float min, float max) {\n if(min > max) throw new IllegalArgumentException(\"min cannot be greater than max.\");\n float result = (float) promptForDouble(prompt, min, max);\n return result;\n }",
"public static float getValueFloat()\n {\n return Util.valueFloat;\n }",
"public static float inputFloat()\n\t{\n\t\treturn(sc.nextFloat());\n\t}",
"public float floatValue()\n\t\t{\n\t\t\treturn (float) doubleValue();\n\t\t}",
"float toFloat(String value, float divideBy) {\n value = value.trim();\n if (value.indexOf(\"9999\") > -1) {\n // .9999's were made floatnull - check for them!\n if (value.indexOf(\".9999\") == -1) value = \"\"; // ub01\n } // if (value.indexOf(\"9999\") > -1)s\n return (!\"\".equals(value)\n ? new Float(value).floatValue() / divideBy\n : Tables.FLOATNULL);\n }",
"Double getTotalFloat();",
"public T caseFloat(org.uis.lenguajegrafico.lenguajegrafico.Float object)\n {\n return null;\n }",
"public static Float toFloat(Object o,byte type) throws ExecException {\n try {\n switch (type) {\n case BOOLEAN:\n return (Boolean) o ? Float.valueOf(1.0F) : Float.valueOf(0.0F);\n\n case INTEGER:\n return new Float(((Integer)o).floatValue());\n\n case LONG:\n return new Float(((Long)o).floatValue());\n\n case FLOAT:\n return (Float)o;\n\n case DOUBLE:\n return new Float(((Double)o).floatValue());\n\n case DATETIME:\n return new Float(Long.valueOf(((DateTime)o).getMillis()).floatValue());\n\n case BYTEARRAY:\n return Float.valueOf(((DataByteArray)o).toString());\n\n case CHARARRAY:\n return Float.valueOf((String)o);\n\n case BIGINTEGER:\n return Float.valueOf(((BigInteger)o).floatValue());\n\n case BIGDECIMAL:\n return Float.valueOf(((BigDecimal)o).floatValue());\n\n case NULL:\n return null;\n\n case BYTE:\n case MAP:\n case INTERNALMAP:\n case TUPLE:\n case BAG:\n case UNKNOWN:\n default:\n int errCode = 1071;\n String msg = \"Cannot convert a \" + findTypeName(o) +\n \" to a Float\";\n throw new ExecException(msg, errCode, PigException.INPUT);\n }\n } catch (ClassCastException cce) {\n throw cce;\n } catch (ExecException ee) {\n throw ee;\n } catch (NumberFormatException nfe) {\n int errCode = 1074;\n String msg = \"Problem with formatting. Could not convert \" + o + \" to Float.\";\n throw new ExecException(msg, errCode, PigException.INPUT, nfe);\n } catch (Exception e) {\n int errCode = 2054;\n String msg = \"Internal error. Could not convert \" + o + \" to Float.\";\n throw new ExecException(msg, errCode, PigException.BUG);\n }\n }",
"public float floatValue() {\n return (float) value;\n }",
"public static void addFloatData(OWLIndividual owlIndi, float value, String property, OWLOntology onto, OWLDataFactory factory, OWLOntologyManager manager){\n\t\tOWLDataProperty p = factory.getOWLDataProperty(IRI.create(Settings.uri+property));\n\t\tOWLLiteral owlc = factory.getOWLLiteral(Float.toString(value), factory.getOWLDatatype(xsdFloat));\n\t manager.applyChange(new AddAxiom(onto, factory.getOWLDataPropertyAssertionAxiom(p, owlIndi, owlc)));\n\t}",
"public FloatLiteral(float val,int my_line, int my_column){\n\t\trawValue = Float.toString(val); // Will convert to int value in semantic check\n\t\tvalue = val;//Returns a new float with value represented by the String val\n\t\tlineNumber= my_line;\n\t\tcolNumber=my_column;\n\t}",
"public float floatValue() {\r\n return (float) intValue();\r\n }",
"void mo72112a(float f);",
"@Test\n public void whenGivenFloat_ShouldReturnThirdPositionMax() {\n FindMaximum max = new FindMaximum();\n Float X= (Float) max.checkMaximum(10.3f,20.3f,30.3f);\n Float expected=30.3f;\n Assert.assertEquals(expected,X);\n }",
"@Override\r\n\tpublic String toString() {\n\t\treturn \"float\";\r\n\t}",
"@Override\n\tpublic void fishfloat()\n\t{\n\t\tSystem.out.println(super.getName() + \" is floating\");\n\n\t}",
"@Override\r\n public Class getClassType() {\r\n return float.class;\r\n }",
"private static float m6542a(float f, float f2, float f3) {\n return Math.min(f2, Math.max(f, f3));\n }",
"public abstract float read_float();",
"public static float promptForFloat(String prompt, float min, float max) throws IOException {\r\n\t\treturn (float) promptForDouble(prompt, min, max);\r\n\t}",
"public float toFloat(String stringItem) {\n Float floatItem = (float) 0.0;\n try {\n floatItem = Float.valueOf(stringItem);\n } // try\n catch (NumberFormatException ioError) {\n System.out.print(\"Error converting \" + stringItem);\n System.out.print(\" to a floating point number::\");\n System.out.println(\" Termio.ToFloat method.\");\n } // catch\n return floatItem;\n }",
"double getFloatingPointField();",
"private static float toFloat (String string) {\n return Float.valueOf(string).floatValue();\n }",
"public final Float _parseFloat(JsonParser jVar, DeserializationContext gVar) throws IOException {\n JsonToken l = jVar.mo29328l();\n if (l == JsonToken.VALUE_NUMBER_FLOAT || l == JsonToken.VALUE_NUMBER_INT) {\n return Float.valueOf(jVar.mo29250F());\n }\n if (l == JsonToken.VALUE_STRING) {\n String trim = jVar.mo29334t().trim();\n if (trim.length() == 0) {\n return (Float) _coerceEmptyString(gVar, this._primitive);\n }\n if (_hasTextualNull(trim)) {\n return (Float) _coerceTextualNull(gVar, this._primitive);\n }\n char charAt = trim.charAt(0);\n if (charAt != '-') {\n if (charAt != 'I') {\n if (charAt == 'N' && _isNaN(trim)) {\n return Float.valueOf(Float.NaN);\n }\n } else if (_isPosInf(trim)) {\n return Float.valueOf(Float.POSITIVE_INFINITY);\n }\n } else if (_isNegInf(trim)) {\n return Float.valueOf(Float.NEGATIVE_INFINITY);\n }\n _verifyStringForScalarCoercion(gVar, trim);\n try {\n return Float.valueOf(Float.parseFloat(trim));\n } catch (IllegalArgumentException unused) {\n return (Float) gVar.mo31517b(this._valueClass, trim, \"not a valid Float value\", new Object[0]);\n }\n } else if (l == JsonToken.VALUE_NULL) {\n return (Float) _coerceNullToken(gVar, this._primitive);\n } else {\n if (l == JsonToken.START_ARRAY) {\n return (Float) _deserializeFromArray(jVar, gVar);\n }\n return (Float) gVar.mo31493a(this._valueClass, jVar);\n }\n }",
"public static float toFloat(byte [] bytes) {\n return toFloat(bytes, 0);\n }",
"public float mo12718a(float f) {\n return f;\n }",
"public static float toFloat(byte [] bytes, int offset) {\n return Float.intBitsToFloat(toInt(bytes, offset, SIZEOF_INT));\n }",
"public final void mFLOAT() throws RecognitionException {\n try {\n int _type = FLOAT;\n int _channel = DEFAULT_TOKEN_CHANNEL;\n CommonToken d=null;\n CommonToken r=null;\n\n // /Users/devdatta.kulkarni/Documents/Cassandra/apache-cassandra-0.8.6-src/src/java/org/apache/cassandra/cql/Cql.g:588:5: (d= INTEGER r= RANGEOP | INTEGER '.' INTEGER )\n int alt7=2;\n alt7 = dfa7.predict(input);\n switch (alt7) {\n case 1 :\n // /Users/devdatta.kulkarni/Documents/Cassandra/apache-cassandra-0.8.6-src/src/java/org/apache/cassandra/cql/Cql.g:588:7: d= INTEGER r= RANGEOP\n {\n int dStart1859 = getCharIndex();\n mINTEGER(); \n d = new CommonToken(input, Token.INVALID_TOKEN_TYPE, Token.DEFAULT_CHANNEL, dStart1859, getCharIndex()-1);\n int rStart1863 = getCharIndex();\n mRANGEOP(); \n r = new CommonToken(input, Token.INVALID_TOKEN_TYPE, Token.DEFAULT_CHANNEL, rStart1863, getCharIndex()-1);\n\n d.setType(INTEGER);\n emit(d);\n r.setType(RANGEOP);\n emit(r);\n \n\n }\n break;\n case 2 :\n // /Users/devdatta.kulkarni/Documents/Cassandra/apache-cassandra-0.8.6-src/src/java/org/apache/cassandra/cql/Cql.g:595:9: INTEGER '.' INTEGER\n {\n mINTEGER(); \n match('.'); \n mINTEGER(); \n\n }\n break;\n\n }\n state.type = _type;\n state.channel = _channel;\n }\n finally {\n }\n }",
"public float getFloatValue() {\n \t\treturn floatValue;\n \t}",
"public void write(float f) {\n write(String.valueOf(f));\n }",
"public static Float castFloat(Object obj) {\n\t\tif (obj instanceof Number) {\n\t\t\treturn ((Number) obj).floatValue();\n\t\t}\n\n\t\treturn null;\n\t}",
"public double getF();",
"public float convert(float f)\n {\n return (f/150);\n }",
"public void setFloat(boolean value) {\r\n\t\tisFloatType = value;\r\n\t}",
"public final EObject ruleFloatDataType() throws RecognitionException {\n EObject current = null;\n\n Token otherlv_0=null;\n\n enterRule(); \n \n try {\n // ../de.hs_rm.cs.vs.dsm.flow/src-gen/de/hs_rm/cs/vs/dsm/parser/antlr/internal/InternalFlow.g:4532:28: ( (otherlv_0= 'float' () ) )\n // ../de.hs_rm.cs.vs.dsm.flow/src-gen/de/hs_rm/cs/vs/dsm/parser/antlr/internal/InternalFlow.g:4533:1: (otherlv_0= 'float' () )\n {\n // ../de.hs_rm.cs.vs.dsm.flow/src-gen/de/hs_rm/cs/vs/dsm/parser/antlr/internal/InternalFlow.g:4533:1: (otherlv_0= 'float' () )\n // ../de.hs_rm.cs.vs.dsm.flow/src-gen/de/hs_rm/cs/vs/dsm/parser/antlr/internal/InternalFlow.g:4533:3: otherlv_0= 'float' ()\n {\n otherlv_0=(Token)match(input,72,FOLLOW_72_in_ruleFloatDataType10328); \n\n \tnewLeafNode(otherlv_0, grammarAccess.getFloatDataTypeAccess().getFloatKeyword_0());\n \n // ../de.hs_rm.cs.vs.dsm.flow/src-gen/de/hs_rm/cs/vs/dsm/parser/antlr/internal/InternalFlow.g:4537:1: ()\n // ../de.hs_rm.cs.vs.dsm.flow/src-gen/de/hs_rm/cs/vs/dsm/parser/antlr/internal/InternalFlow.g:4538:5: \n {\n\n current = forceCreateModelElement(\n grammarAccess.getFloatDataTypeAccess().getFloatDataTypeAction_1(),\n current);\n \n\n }\n\n\n }\n\n\n }\n\n leaveRule(); \n }\n \n catch (RecognitionException re) { \n recover(input,re); \n appendSkippedTokens();\n } \n finally {\n }\n return current;\n }",
"public final float nextFloat() {\n return ((state = (state << 29 | state >>> 35) * 0xAC564B05L) * 0x818102004182A025L & 0xffffffL) * 0x1p-24f;\n }",
"public static final SourceModel.Expr showFloat(SourceModel.Expr f) {\n\t\t\treturn \n\t\t\t\tSourceModel.Expr.Application.make(\n\t\t\t\t\tnew SourceModel.Expr[] {SourceModel.Expr.Var.make(Functions.showFloat), f});\n\t\t}",
"@Test\n public void test_column_type_detection_float() throws SQLException {\n ColumnInfo info = testColumnTypeDetection(\"x\", NodeFactory.createLiteral(\"12.3e4\", XSDDatatype.XSDfloat), true, Types.FLOAT, Float.class.getCanonicalName());\n Assert.assertEquals(7, info.getScale());\n Assert.assertEquals(15, info.getPrecision());\n Assert.assertTrue(info.isSigned());\n }",
"include<stdio.h>\nint main()\n{\n float d;\n \n scanf(\"%f\", &d);\n float r = d/2;\n float a;\n a = 3.14 * r * r;\n printf(\"%.2f\", a);\n return 0;\n}",
"FloatAttribute(String name, float value) {\r\n super(name);\r\n this.value = value;\r\n }",
"public final void mFLOAT() throws RecognitionException {\n try {\n int _type = FLOAT;\n int _channel = DEFAULT_TOKEN_CHANNEL;\n // Office.g:973:6: ( ( ( '-' )? ( ( '1' .. '9' ) ( '0' .. '9' )* | '0' ) '.' ( '0' .. '9' )+ ) )\n // Office.g:974:2: ( ( '-' )? ( ( '1' .. '9' ) ( '0' .. '9' )* | '0' ) '.' ( '0' .. '9' )+ )\n {\n // Office.g:974:2: ( ( '-' )? ( ( '1' .. '9' ) ( '0' .. '9' )* | '0' ) '.' ( '0' .. '9' )+ )\n // Office.g:974:3: ( '-' )? ( ( '1' .. '9' ) ( '0' .. '9' )* | '0' ) '.' ( '0' .. '9' )+\n {\n // Office.g:974:3: ( '-' )?\n int alt5=2;\n int LA5_0 = input.LA(1);\n\n if ( (LA5_0=='-') ) {\n alt5=1;\n }\n switch (alt5) {\n case 1 :\n // Office.g:974:4: '-'\n {\n match('-'); \n\n }\n break;\n\n }\n\n\n // Office.g:974:9: ( ( '1' .. '9' ) ( '0' .. '9' )* | '0' )\n int alt7=2;\n int LA7_0 = input.LA(1);\n\n if ( ((LA7_0 >= '1' && LA7_0 <= '9')) ) {\n alt7=1;\n }\n else if ( (LA7_0=='0') ) {\n alt7=2;\n }\n else {\n NoViableAltException nvae =\n new NoViableAltException(\"\", 7, 0, input);\n\n throw nvae;\n\n }\n switch (alt7) {\n case 1 :\n // Office.g:974:10: ( '1' .. '9' ) ( '0' .. '9' )*\n {\n if ( (input.LA(1) >= '1' && input.LA(1) <= '9') ) {\n input.consume();\n }\n else {\n MismatchedSetException mse = new MismatchedSetException(null,input);\n recover(mse);\n throw mse;\n }\n\n\n // Office.g:974:21: ( '0' .. '9' )*\n loop6:\n do {\n int alt6=2;\n int LA6_0 = input.LA(1);\n\n if ( ((LA6_0 >= '0' && LA6_0 <= '9')) ) {\n alt6=1;\n }\n\n\n switch (alt6) {\n \tcase 1 :\n \t // Office.g:\n \t {\n \t if ( (input.LA(1) >= '0' && input.LA(1) <= '9') ) {\n \t input.consume();\n \t }\n \t else {\n \t MismatchedSetException mse = new MismatchedSetException(null,input);\n \t recover(mse);\n \t throw mse;\n \t }\n\n\n \t }\n \t break;\n\n \tdefault :\n \t break loop6;\n }\n } while (true);\n\n\n }\n break;\n case 2 :\n // Office.g:974:35: '0'\n {\n match('0'); \n\n }\n break;\n\n }\n\n\n match('.'); \n\n // Office.g:974:44: ( '0' .. '9' )+\n int cnt8=0;\n loop8:\n do {\n int alt8=2;\n int LA8_0 = input.LA(1);\n\n if ( ((LA8_0 >= '0' && LA8_0 <= '9')) ) {\n alt8=1;\n }\n\n\n switch (alt8) {\n \tcase 1 :\n \t // Office.g:\n \t {\n \t if ( (input.LA(1) >= '0' && input.LA(1) <= '9') ) {\n \t input.consume();\n \t }\n \t else {\n \t MismatchedSetException mse = new MismatchedSetException(null,input);\n \t recover(mse);\n \t throw mse;\n \t }\n\n\n \t }\n \t break;\n\n \tdefault :\n \t if ( cnt8 >= 1 ) break loop8;\n EarlyExitException eee =\n new EarlyExitException(8, input);\n throw eee;\n }\n cnt8++;\n } while (true);\n\n\n }\n\n\n _channel = 99; \n\n }\n\n state.type = _type;\n state.channel = _channel;\n }\n finally {\n \t// do for sure before leaving\n }\n }",
"public static void fieldSetFloat(final Class<?> cls, final String name,\r\n final Object inst, final float value) throws SecurityException,\r\n NoSuchFieldException, IllegalArgumentException, IllegalAccessException {\r\n final Field field = jvmGetField(cls, name);\r\n field.setFloat(inst, value);\r\n }",
"public static float getFloatProperty(OWLIndividual owlIndi, String property, OWLOntology onto, OWLDataFactory factory){\n\t\tfloat f = -5;\n\t\tOWLLiteral o = null;\n\t\ttry{\n\t\t\tOWLDataProperty p = factory.getOWLDataProperty(IRI.create(Settings.uri+property));\n\t\t\to = owlIndi.getDataPropertyValues(p, onto).iterator().next();\n\t\t\tf = Float.parseFloat(o.getLiteral());\n\t\t}catch(Exception e){}\n\t\tif (f!=-5){\n\t\t\treturn f;\n\t\t}else{\n\t\t\treturn 0.0f;\n\t\t}\n\t}",
"public float toFloat() {\n return this.toFloatArray()[0];\n }",
"public static float readFloat()\n \n {\n float f=0.0f;\n String wort=\"xxxx\";\n try {\n wort=eingabe.readLine();\n f=Float.valueOf(wort).floatValue() ;\n } catch(IOException e1) {\n System.out.println(\"Eingabefehler, bitte noch einmal!\");\n f=readFloat();\n } catch(NumberFormatException e2) {\n if(wort.equals(\"\"))\n System.out.println(\"Bitte etwas eingeben, noch einmal:\");\n else {\n System.out.print(\"Fehler beim Format, \");\n System.out.println(\"bitte noch einmal!\");}\n f=readFloat();\n }\n return f;\n }",
"float getEFloat();",
"public float floatValue() {\n\t\treturn (float) mDouble;\n\t}",
"public final void mFLOAT() throws RecognitionException {\r\n try {\r\n final int _type = SparqlMarcoLexer.FLOAT;\r\n final int _channel = BaseRecognizer.DEFAULT_TOKEN_CHANNEL;\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:58:5: ( ( '0' .. '9' )+\r\n // '.' ( '0' .. '9' )* ( EXPONENT )? | '.' ( '0' .. '9' )+ ( EXPONENT )? | ( '0' ..\r\n // '9' )+ EXPONENT )\r\n int alt11 = 3;\r\n alt11 = this.dfa11.predict(this.input);\r\n switch (alt11) {\r\n case 1:\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:58:9: ( '0' .. '9'\r\n // )+\r\n int cnt5 = 0;\r\n loop5: do {\r\n int alt5 = 2;\r\n final int LA5_0 = this.input.LA(1);\r\n\r\n if (LA5_0 >= '0' && LA5_0 <= '9') {\r\n alt5 = 1;\r\n }\r\n\r\n switch (alt5) {\r\n case 1:\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:58:10:\r\n // '0' .. '9'\r\n {\r\n this.matchRange('0', '9');\r\n\r\n }\r\n break;\r\n\r\n default:\r\n if (cnt5 >= 1) {\r\n break loop5;\r\n }\r\n final EarlyExitException eee = new EarlyExitException(5, this.input);\r\n throw eee;\r\n }\r\n cnt5++;\r\n } while (true);\r\n this.match('.');\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:58:25: ( '0' ..\r\n // '9' )*\r\n loop6: do {\r\n int alt6 = 2;\r\n final int LA6_0 = this.input.LA(1);\r\n\r\n if (LA6_0 >= '0' && LA6_0 <= '9') {\r\n alt6 = 1;\r\n }\r\n\r\n switch (alt6) {\r\n case 1:\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:58:26:\r\n // '0' .. '9'\r\n {\r\n this.matchRange('0', '9');\r\n\r\n }\r\n break;\r\n\r\n default:\r\n break loop6;\r\n }\r\n } while (true);\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:58:37: ( EXPONENT\r\n // )?\r\n int alt7 = 2;\r\n final int LA7_0 = this.input.LA(1);\r\n if (LA7_0 == 'E' || LA7_0 == 'e') {\r\n alt7 = 1;\r\n }\r\n switch (alt7) {\r\n case 1:\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:58:37:\r\n // EXPONENT\r\n {\r\n this.mEXPONENT();\r\n\r\n }\r\n break;\r\n\r\n }\r\n break;\r\n case 2:\r\n this.match('.');\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:59:13: ( '0' ..\r\n // '9' )+\r\n int cnt8 = 0;\r\n loop8: do {\r\n int alt8 = 2;\r\n final int LA8_0 = this.input.LA(1);\r\n\r\n if (LA8_0 >= '0' && LA8_0 <= '9') {\r\n alt8 = 1;\r\n }\r\n\r\n switch (alt8) {\r\n case 1:\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:59:14:\r\n // '0' .. '9'\r\n {\r\n this.matchRange('0', '9');\r\n\r\n }\r\n break;\r\n\r\n default:\r\n if (cnt8 >= 1) {\r\n break loop8;\r\n }\r\n final EarlyExitException eee = new EarlyExitException(8, this.input);\r\n throw eee;\r\n }\r\n cnt8++;\r\n } while (true);\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:59:25: ( EXPONENT\r\n // )?\r\n int alt9 = 2;\r\n final int LA9_0 = this.input.LA(1);\r\n if (LA9_0 == 'E' || LA9_0 == 'e') {\r\n alt9 = 1;\r\n }\r\n switch (alt9) {\r\n case 1:\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:59:25:\r\n // EXPONENT\r\n {\r\n this.mEXPONENT();\r\n\r\n }\r\n break;\r\n\r\n }\r\n break;\r\n case 3:\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:60:9: ( '0' .. '9'\r\n // )+\r\n int cnt10 = 0;\r\n loop10: do {\r\n int alt10 = 2;\r\n final int LA10_0 = this.input.LA(1);\r\n\r\n if (LA10_0 >= '0' && LA10_0 <= '9') {\r\n alt10 = 1;\r\n }\r\n\r\n switch (alt10) {\r\n case 1:\r\n // /Users/Marco/Desktop/Tesi Davide/Antlr-doc/SparqlMarco.g:60:10:\r\n // '0' .. '9'\r\n {\r\n this.matchRange('0', '9');\r\n\r\n }\r\n break;\r\n\r\n default:\r\n if (cnt10 >= 1) {\r\n break loop10;\r\n }\r\n final EarlyExitException eee = new EarlyExitException(10, this.input);\r\n throw eee;\r\n }\r\n cnt10++;\r\n } while (true);\r\n this.mEXPONENT();\r\n break;\r\n default:\r\n break;\r\n\r\n }\r\n this.state.type = _type;\r\n this.state.channel = _channel;\r\n } finally {\r\n }\r\n }",
"public void mo3777a(float f) {\n this.f1443S = f;\n }",
"boolean hasFloat();",
"boolean mo61579as(float f);",
"public final float float_literal() throws RecognitionException {\n float value = 0.0f;\n\n\n CommonTree FLOAT_LITERAL195 = null;\n\n try {\n // D:\\\\decomplier_tools\\\\smali\\\\smali\\\\smali\\\\src\\\\main\\\\antlr3\\\\smaliTreeWalker.g:1196:3: ( FLOAT_LITERAL )\n // D:\\\\decomplier_tools\\\\smali\\\\smali\\\\smali\\\\src\\\\main\\\\antlr3\\\\smaliTreeWalker.g:1196:5: FLOAT_LITERAL\n {\n FLOAT_LITERAL195 = (CommonTree) match(input, FLOAT_LITERAL, FOLLOW_FLOAT_LITERAL_in_float_literal3307);\n value = LiteralTools.parseFloat((FLOAT_LITERAL195 != null ? FLOAT_LITERAL195.getText() : null));\n }\n\n } catch (RecognitionException re) {\n reportError(re);\n recover(input, re);\n } finally {\n // do for sure before leaving\n }\n return value;\n }",
"public Float getFloat(String key)\n\t{\n\t\tDouble d = getDouble(key);\n\t\tif(d == null)\n\t\t\treturn null;\n\t\treturn d.floatValue();\n\t}",
"@Override\n public FloatType divideToFloat(FloatType dividend) {\n double floatDivisor = this.asFloat().getValue();\n double floatDividend = dividend.getValue();\n return TypeFactory.getFloatType(floatDividend / floatDivisor);\n }",
"@Override\r\n\tpublic boolean isFloat() {\r\n\t\treturn isFloatType;\r\n\t}",
"public FloatBase(org.semanticwb.platform.SemanticObject base)\r\n {\r\n super(base);\r\n }",
"public void set_float(float param) {\n this.local_float = param;\n }",
"public Float getFloat(float defaultVal) {\n return get(ContentType.FloatType, defaultVal);\n }",
"@Override\n public FloatType multiplyToFloat(FloatType multiplicand) {\n double floatMultiplier = this.asFloat().getValue();\n double floatMultiplicand = multiplicand.getValue();\n return TypeFactory.getFloatType(floatMultiplicand * floatMultiplier);\n }",
"public float f(String key) throws AgentBuilderRuntimeException {\n\t\treturn getFloat(key).floatValue();\n\t}",
"public float getFloat(String subExpression) {\n return (float)getNumber(subExpression);\n }",
"public float nextFloat(){\r\n\t\tint rand = nextInt();\r\n\t\treturn (float)(rand & 0x007fffff)/((float) 0x007fffff);\r\n\t}",
"float applyAsFloat(T value);",
"public float floatValue() {\n return (float) m_value;\n }",
"private static float m3378a(float f, float f2, float f3) {\n return f < f2 ? f2 : f > f3 ? f3 : f;\n }",
"public final EObject ruleRealLiteral() throws RecognitionException {\n EObject current = null;\n int ruleRealLiteral_StartIndex = input.index();\n Token lv_floatValue_0_0=null;\n\n enterRule(); \n \n try {\n if ( state.backtracking>0 && alreadyParsedRule(input, 112) ) { return current; }\n // ../de.jevopi.mitra2/src-gen/de/jevopi/mitra2/parser/antlr/internal/InternalMitraParser.g:4714:28: ( ( (lv_floatValue_0_0= RULE_FLOAT ) ) )\n // ../de.jevopi.mitra2/src-gen/de/jevopi/mitra2/parser/antlr/internal/InternalMitraParser.g:4715:1: ( (lv_floatValue_0_0= RULE_FLOAT ) )\n {\n // ../de.jevopi.mitra2/src-gen/de/jevopi/mitra2/parser/antlr/internal/InternalMitraParser.g:4715:1: ( (lv_floatValue_0_0= RULE_FLOAT ) )\n // ../de.jevopi.mitra2/src-gen/de/jevopi/mitra2/parser/antlr/internal/InternalMitraParser.g:4716:1: (lv_floatValue_0_0= RULE_FLOAT )\n {\n // ../de.jevopi.mitra2/src-gen/de/jevopi/mitra2/parser/antlr/internal/InternalMitraParser.g:4716:1: (lv_floatValue_0_0= RULE_FLOAT )\n // ../de.jevopi.mitra2/src-gen/de/jevopi/mitra2/parser/antlr/internal/InternalMitraParser.g:4717:3: lv_floatValue_0_0= RULE_FLOAT\n {\n lv_floatValue_0_0=(Token)match(input,RULE_FLOAT,FOLLOW_RULE_FLOAT_in_ruleRealLiteral9607); if (state.failed) return current;\n if ( state.backtracking==0 ) {\n\n \t\t\tnewLeafNode(lv_floatValue_0_0, grammarAccess.getRealLiteralAccess().getFloatValueFLOATTerminalRuleCall_0()); \n \t\t\n }\n if ( state.backtracking==0 ) {\n\n \t if (current==null) {\n \t current = createModelElement(grammarAccess.getRealLiteralRule());\n \t }\n \t\tsetWithLastConsumed(\n \t\t\tcurrent, \n \t\t\t\"floatValue\",\n \t\tlv_floatValue_0_0, \n \t\t\"FLOAT\");\n \t \n }\n\n }\n\n\n }\n\n\n }\n\n if ( state.backtracking==0 ) {\n leaveRule(); \n }\n }\n \n \tcatch (RecognitionException re) { \n \t recover(input,re); \n \t appendSkippedTokens();\n \t}\n finally {\n if ( state.backtracking>0 ) { memoize(input, 112, ruleRealLiteral_StartIndex); }\n }\n return current;\n }",
"private void float_to_float_step( ExpressionNode nd, VMState vms ) {\n Assert.check( vms.top().at( nd ) == null ) ;\r\n \r\n // Clear the selection\r\n vms.top().setSelected( null ) ;\r\n \r\n // Get values of operands\r\n double x = getFloatOperand( nd, vms, 0 ) ;\r\n \r\n // Compute the value\r\n double value ;\r\n switch( op_code ) {\r\n case FABS :\r\n value = x < 0 ? -x : x ;\r\n break ;\r\n case SIN :\r\n value = Math.sin(x) ;\r\n break ;\r\n case COS :\r\n value = Math.cos(x) ;\r\n break ;\r\n case TAN :\r\n value = Math.tan(x) ;\r\n break ;\r\n case ASIN :\r\n value = Math.asin(x) ;\r\n break ;\r\n case ACOS :\r\n value = Math.acos(x) ;\r\n break ;\r\n case ATAN :\r\n value = Math.atan(x) ;\r\n break ;\r\n case EXP :\r\n value = Math.exp(x) ;\r\n break ;\r\n case EXPM1 :\r\n // This won't give as good a result as the real expm1\r\n // function.\r\n value = Math.exp(x-1.0) ;\r\n break ;\r\n case LOG :\r\n value = Math.log(x) ;\r\n break ;\r\n case LOG10 :\r\n value = Math.log(x) / Math.log( 10 ) ;\r\n break ;\r\n case LOG1P :\r\n // This won't give as good a result as the real log1p\r\n // function.\r\n value = Math.log(x+1.0);\r\n break ;\r\n case CEIL :\r\n value = Math.ceil(x) ;\r\n break ;\r\n case FLOOR :\r\n value = Math.floor(x) ;\r\n break ;\r\n case SIGNUM :\r\n if(x == Double.NaN ) {\r\n value = x ; }\r\n else if( x == 0.0 ) {\r\n value = x ; }\r\n else if( x < 0 ) {\r\n value = -1.0 ; }\r\n else {\r\n value = +1.0 ; }\r\n break ;\r\n case ROUND :\r\n value = Math.round(x) ;\r\n break ;\r\n case SQRT :\r\n value = Math.sqrt(x) ;\r\n break ;\r\n case SINH :\r\n value = (pow(Math.E, x) - pow(Math.E, -x)) / 2.0 ;\r\n break ;\r\n case COSH :\r\n value = (pow(Math.E, x) + pow(Math.E, -x)) / 2.0 ;\r\n break ;\r\n case TANH :\r\n value = (pow(Math.E, x) - pow(Math.E, -x))\r\n / (pow(Math.E, x) + pow(Math.E, -x)) ;\r\n break ;\r\n case TODEGS :\r\n value = x * 57.2957795 ;\r\n break ;\r\n case TORADS :\r\n value = x / 57.2957795 ;\r\n break ;\r\n case RINT :\r\n value = Math.rint(x) ;\r\n break ;\r\n case CBRT :\r\n if( x == Double.NaN ) value = Double.NaN ;\r\n else if( x < 0 ) value = -pow( -x, 1.0/3.0);\r\n else value = pow(x,1.0/3.0) ;\r\n break ;\r\n case ULP_DOUBLE :\r\n if( x == Double.NaN )\r\n value = Double.NaN ;\r\n else if( x == Double.NEGATIVE_INFINITY || x == Double.POSITIVE_INFINITY )\r\n value = Double.POSITIVE_INFINITY ;\r\n else if( x == 0.0 )\r\n value = Double.MIN_VALUE ;\r\n else {\r\n /* TODO\r\n * Fix this algorithm.\r\n */\r\n Assert.apology(\"ulp is not implemented\") ;\r\n value = 0.0 ; }\r\n break ;\r\n case ULP_FLOAT :\r\n // The assumption is that converting from a float\r\n // to a double loses nothing and is invertable.\r\n float xf = (float) x ; // Get back to the float.\r\n if( xf == Float.NaN )\r\n value = Float.NaN ;\r\n else if( xf == Float.NEGATIVE_INFINITY || xf == Float.POSITIVE_INFINITY )\r\n value = Float.POSITIVE_INFINITY ;\r\n else if( xf == 0.0 )\r\n value = Float.MIN_VALUE ;\r\n else {\r\n /* TODO\r\n * Fix this algorithm.\r\n */\r\n Assert.apology(\"ulp is not implemented\") ;\r\n value = 0.0 ; }\r\n break ;\r\n default: Assert.check(false) ; value = 0 ;\r\n }\r\n \r\n AbstractFloatDatum d = putFloatResult(nd, vms, value);\r\n \r\n // NOTE: mpbl May 2008 I believe this is superfluous\r\n \r\n vms.top().map(nd, d) ;\r\n }"
]
| [
"0.686971",
"0.6745878",
"0.67265934",
"0.66145796",
"0.6601977",
"0.6573846",
"0.6378541",
"0.6362256",
"0.6346636",
"0.6327591",
"0.6327591",
"0.63234675",
"0.63202024",
"0.62783337",
"0.62757283",
"0.62484604",
"0.6239212",
"0.62382555",
"0.62036943",
"0.62026954",
"0.6200455",
"0.61962867",
"0.6183011",
"0.6176912",
"0.61546135",
"0.61474377",
"0.6146784",
"0.61263704",
"0.6114899",
"0.6109563",
"0.6104466",
"0.6092738",
"0.60886306",
"0.60841286",
"0.60834473",
"0.60780674",
"0.6071645",
"0.60642236",
"0.60563207",
"0.6040487",
"0.60309476",
"0.60180295",
"0.601717",
"0.6005957",
"0.5992348",
"0.59887",
"0.5988418",
"0.59870315",
"0.59853655",
"0.5983183",
"0.59824806",
"0.597857",
"0.5966864",
"0.59525293",
"0.5952058",
"0.5950921",
"0.5947011",
"0.5944303",
"0.5933635",
"0.59306175",
"0.5925131",
"0.5923414",
"0.59198684",
"0.59195954",
"0.591567",
"0.5900778",
"0.58993804",
"0.58978444",
"0.5888996",
"0.5887829",
"0.5885903",
"0.5885097",
"0.58802444",
"0.58789676",
"0.58758444",
"0.5873428",
"0.5867494",
"0.58592284",
"0.5852842",
"0.5852442",
"0.5852318",
"0.5849992",
"0.5847898",
"0.58477634",
"0.5846881",
"0.58463323",
"0.5845546",
"0.5845387",
"0.5835656",
"0.58350474",
"0.5828172",
"0.58247423",
"0.5815125",
"0.58124757",
"0.5806525",
"0.5799829",
"0.579775",
"0.57915616",
"0.57819784",
"0.57800156",
"0.57777303"
]
| 0.0 | -1 |
String sql = "select spbh, sum(zdwsl) zdwjhsl from t_cgjh_det t "; | @Override
public DataGrid toYwrk(String cgjhDetIds){
String sql = "select cd.spbh, isnull(max(cd.zdwsl), 0) zdwjhsl, isnull(sum(yd.zdwsl), 0) zdwyrsl, isnull(max(cd.zdwdj), 0) zdwdj"
+ " from t_cgjh_det cd " +
"left join t_cgjh_ywrk cy on cd.id = cy.cgjhdetId " +
"left join t_ywrk y on y.ywrklsh = cy.ywrklsh " +
"left join t_ywrk_det yd on y.ywrklsh = yd.ywrklsh and yd.spbh = cd.spbh ";
//String sql = "select spbh,sum(zdwsl) zdwsl from t_cgjh_det d ";
Map<String, Object> params = new HashMap<String, Object>();
// if(cgjhlshs != null && cgjhlshs.trim().length() > 0){
// String[] cs = cgjhlshs.split(",");
// sql += "where ";
// for(int i = 0; i < cs.length; i++){
//// sql += "cd.id = '" + cs[i] + "'";
// sql += "d.cgjhlsh = ? ";
// params.put(String.valueOf(i), cs[i]);
// if(i != cs.length - 1){
// sql += " or ";
// }
// }
//// sql += " group by cd.spbh";
// }
// sql += " group by spbh";
if(cgjhDetIds != null && cgjhDetIds.trim().length() > 0){
String[] cs = cgjhDetIds.split(",");
sql += "where ";
for(int i = 0; i < cs.length; i++){
sql += "cd.id = ? ";
params.put(String.valueOf(i), cs[i]);
if(i != cs.length - 1){
sql += " or ";
}
}
sql += " group by cd.spbh";
}
List<Object[]> l = detDao.findBySQL(sql, params);
List<CgjhDet> nl = new ArrayList<CgjhDet>();
for(Object[] os : l){
String spbh = (String)os[0];
BigDecimal zdwjhsl = new BigDecimal(os[1].toString());
BigDecimal zdwyrsl = new BigDecimal(os[2].toString());
BigDecimal zdwdj = new BigDecimal(os[3].toString());
TSp sp = spDao.get(TSp.class, spbh);
CgjhDet cd = new CgjhDet();
cd.setSpbh(spbh);
cd.setSpmc(sp.getSpmc());
cd.setSpcd(sp.getSpcd());
cd.setSppp(sp.getSppp());
cd.setSpbz(sp.getSpbz());
cd.setZdwdj(zdwdj);
cd.setZdwjhsl(zdwjhsl);
cd.setZdwyrsl(zdwyrsl);
cd.setZdwsl(zdwjhsl.subtract(zdwyrsl));
cd.setZjldwId(sp.getZjldw().getId());
cd.setZjldwmc(sp.getZjldw().getJldwmc());
cd.setSpje(cd.getZdwdj().multiply(cd.getZdwsl()));
if(sp.getCjldw() != null){
cd.setCjldwId(sp.getCjldw().getId());
cd.setCjldwmc(sp.getCjldw().getJldwmc());
if(sp.getZhxs().compareTo(Constant.BD_ZERO) != 0){
cd.setZhxs(sp.getZhxs());
cd.setCdwdj(zdwdj.multiply(sp.getZhxs()).multiply(new BigDecimal("1").add(Constant.SHUILV)).setScale(4, BigDecimal.ROUND_HALF_UP));
cd.setCdwjhsl(zdwjhsl.divide(sp.getZhxs(), 3, BigDecimal.ROUND_HALF_UP));
cd.setCdwyrsl(zdwyrsl.divide(sp.getZhxs(), 3, BigDecimal.ROUND_HALF_UP));
cd.setCdwsl(cd.getCdwjhsl().subtract(cd.getCdwyrsl()));
}
}
nl.add(cd);
}
nl.add(new CgjhDet());
DataGrid dg = new DataGrid();
dg.setRows(nl);
return dg;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public float totalSalida(String fecha){\n float total = 0;\n connect();\n ResultSet result = null;\n String sql = \"select sum(requisiciones.total) as salidas from requisiciones where fecha LIKE ?\";\n try{\n PreparedStatement ps = connect.prepareStatement(sql);\n ps.setString(1, fecha);\n result = ps.executeQuery();\n if(result != null){\n total = result.getFloat(\"salidas\"); \n }\n connect.close();\n return total;\n }catch(SQLException ex){\n ex.printStackTrace();\n } \n return total;\n }",
"public float getProductTotalMoney(){\n connect();\n float total = 0;\n String sql = \"SELECT SUM(subtotal) + (SUM(subtotal) * (SELECT iva FROM configuraciones)) FROM productos\";\n ResultSet result = null;\n \n try{\n PreparedStatement ps = connect.prepareStatement(sql);\n result = ps.executeQuery();\n //result = getQuery(sql);\n if(result != null){\n while(result.next()){\n total = result.getFloat(1);\n }\n }\n connect.close();\n }catch(SQLException ex){\n ex.printStackTrace();\n }\n return total; \n }",
"float getTotalCost() throws SQLException;",
"public String getSum();",
"public float totalEntrada(String fecha){\n float total = 0;\n connect();\n ResultSet result = null;\n String sql = \"select sum(facturas.total_venta) as entradas from facturas where fecha LIKE ?\";\n try{\n PreparedStatement ps = connect.prepareStatement(sql);\n ps.setString(1, fecha);\n result = ps.executeQuery();\n if(result != null){\n total = result.getFloat(\"entradas\"); \n }\n connect.close();\n return total;\n }catch(SQLException ex){\n ex.printStackTrace();\n } \n return total;\n }",
"@Override\n\tpublic double getSumOfCost() {\n\t String sql=\"SELECT SUM(cost) FROM supplier_product\";\n\t double total=this.getJdbcTemplate().queryForObject(sql, double.class);\n\t\treturn total;\n\t}",
"public List viewTotalInscritosBD();",
"BigDecimal getSumOfTransactionsRest(TransferQuery query);",
"@SuppressWarnings(\"static-access\")\n\tpublic Integer getTotalAccountingRowsFromDB () {\n\t\tString queryGetTotalAccountingRows =\n\t\t\t\t\"SELECT\\r\\n\" + \n\t\t\t\t\"(SELECT COUNT(*) FROM STAGING.T_STGL_GENERAL_LEDGER GL \\r\\n\" + \n\t\t\t\t\"WHERE GL.CURRENT_FLAG = 1 AND \\r\\n\" + \n\t\t\t\t\"GL.GL_CYCLE_DATE = '\"+ currentCycleDate +\"'\\r\\n\" + //ex: 2021-12-31 20:00:00.000\n\t\t\t\t\"GL.GL_PRCS_DATE = '\"+ currentProcDate + \"' AND \\r\\n\" + //ex: 2021-12-31 00:00:00.000\n\t\t\t\t\"GL.GL_GL_SRC = 'T') AS 'TRANSACTION ACCOUNTING ROWS',\\r\\n\" + \n\t\t\t\t\"'+' AS ' ',\\r\\n\" + \n\t\t\t\t\"\\r\\n\" + \n\t\t\t\t\"(SELECT COUNT(*) FROM STAGING.T_STGL_GENERAL_LEDGER GL \\r\\n\" + \n\t\t\t\t\"WHERE GL.CURRENT_FLAG = 1 \\r\\n\" + \n\t\t\t\t\"AND GL.GL_CYCLE_DATE = '\"+ currentCycleDate +\"' \\r\\n\" + \n\t\t\t\t\"AND GL.GL_GL_SRC = 'S') AS 'SUSPENSE ACCOUNTING ROWS',\\r\\n\" + \n\t\t\t\t\"'=' AS ' ',\\r\\n\" + \n\t\t\t\t\"\\r\\n\" + \n\t\t\t\t\"(SELECT COUNT(*) FROM STAGING.T_STGL_GENERAL_LEDGER GL \\r\\n\" + \n\t\t\t\t\"WHERE GL.CURRENT_FLAG = 1 \\r\\n\" + \n\t\t\t\t\"GL.GL_CYCLE_DATE = '\"+ currentCycleDate +\"'\\r\\n\" + //ex: 2021-12-31 20:00:00.000\n\t\t\t\t\"GL.GL_PRCS_DATE = '\"+ currentProcDate + \"' AND \\r\\n\" + //ex: 2021-12-31 00:00:00.000\n\t\t\t\t\"AND GL.GL_GL_SRC = 'T')\\r\\n\" + \n\t\t\t\t\"+\\r\\n\" + \n\t\t\t\t\"(SELECT COUNT(*) FROM STAGING.T_STGL_GENERAL_LEDGER GL \\r\\n\" + \n\t\t\t\t\"WHERE GL.CURRENT_FLAG = 1 \\r\\n\" + \n\t\t\t\t\"AND GL.GL_CYCLE_DATE = '\"+ currentCycleDate +\"' \\r\\n\" + \n\t\t\t\t\"AND GL.GL_GL_SRC = 'S')\\r\\n\" + \n\t\t\t\t\"AS 'TOTAL ACCOUNTING ROWS';\\r\\n\" + \n\t\t\t\t\"\\r\\n\" + \n\t\t\t\t\"\\r\\n\" + \n\t\t\t\t\"SELECT * FROM STAGING.T_STGL_GENERAL_LEDGER GL \\r\\n\" + \n\t\t\t\t\"WHERE GL.CURRENT_FLAG = 1 AND \\r\\n\" + \n\t\t\t\t\"GL.GL_CYCLE_DATE = '\"+ currentCycleDate +\"'\\r\\n\" + //ex: 2021-12-31 20:00:00.000\n\t\t\t\t\"GL.GL_PRCS_DATE = '\"+ currentProcDate + \"' AND \\r\\n\" + //ex: 2021-12-31 00:00:00.000 \n\t\t\t\t\"GL.GL_GL_SRC = 'T'\\r\\n\" + \n\t\t\t\t\"ORDER BY GL.GL_CYCLE_DATE DESC\\r\\n\" + \n\t\t\t\t\"---------------------------------------------------\\r\\n\" + \n\t\t\t\t\"SELECT * FROM STAGING.T_STGL_GENERAL_LEDGER GL \\r\\n\" + \n\t\t\t\t\"WHERE GL.CURRENT_FLAG = 1 AND \\r\\n\" + \n\t\t\t\t\"AND GL.GL_CYCLE_DATE = '\"+ currentCycleDate +\"' \\r\\n\" + \n\t\t\t\t\"GL.GL_GL_SRC = 'S'\\r\\n\" + \n\t\t\t\t\"ORDER BY GL.GL_CYCLE_DATE DESC\\r\\n\" + \n\t\t\t\t\"\";\n\t\t\n\t\tconn.createSQLServerConn();\n\t\ttry {\n\t\t\ttotalAccountingRows=conn.fetchTotalAccountingRowsFromDB(queryGetTotalAccountingRows); //only stores 1st column of trans number from ResultSet\n\t\t} catch(Exception e) {\n\t\t\tReports.logAMessage(LogStatus.ERROR, \"Exception: \" + e.getMessage());\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn totalAccountingRows;\n\t}",
"public static double totalcommision(int salesman_id) {\r\n\r\n\t\tResultSet rs = null;\r\n\r\n\t\tdouble total_amount = 0;\r\n\r\n\t\tString query = \"SELECT DISTINCT(appliance_name) AS apname ,(SELECT CountNumberAppliance(apname,\"\r\n\t\t\t\t+ salesman_id + \")) FROM appliance\";\r\n\t\tint count;\r\n\t\tString name;\r\n\t\ttry (Connection con = Connect.getConnection()) {\r\n\r\n\t\t\tPreparedStatement stmt = (PreparedStatement) con\r\n\t\t\t\t\t.prepareStatement(query);\r\n\t\t\trs = stmt.executeQuery();\r\n\t\t\tSystem.out.println(query);\r\n\r\n\t\t\twhile (rs.next()) {\r\n\t\t\t\tname = rs.getString(1);\r\n\t\t\t\tif (name.equalsIgnoreCase(\"5 wott\")) {\r\n\t\t\t\t\tcount = rs.getInt(2);\r\n\r\n\t\t\t\t\tif ((count >= 10) && (count <= 20)) {\r\n\t\t\t\t\t\ttotal_amount = count * 5;\r\n\t\t\t\t\t} else if ((count >= 21) && (count <= 35)) {\r\n\t\t\t\t\t\ttotal_amount = count * 10;\r\n\t\t\t\t\t} else if ((count >= 36) && (count <= 50)) {\r\n\t\t\t\t\t\ttotal_amount = count * 20;\r\n\t\t\t\t\t} else if ((count >= 51)) {\r\n\t\t\t\t\t\ttotal_amount = count * 30;\r\n\t\t\t\t\t}\r\n\r\n\t\t\t\t} else if (name.equalsIgnoreCase(\"10 wott\")) {\r\n\t\t\t\t\tcount = rs.getInt(2);\r\n\r\n\t\t\t\t\tif ((count >= 10) && (count <= 20)) {\r\n\t\t\t\t\t\ttotal_amount = count * 15;\r\n\t\t\t\t\t} else if ((count >= 21) && (count <= 35)) {\r\n\t\t\t\t\t\ttotal_amount = count * 10;\r\n\t\t\t\t\t} else if ((count >= 36) && (count <= 50)) {\r\n\t\t\t\t\t\ttotal_amount = count * 20;\r\n\t\t\t\t\t} else if ((count >= 51)) {\r\n\t\t\t\t\t\ttotal_amount = count * 30;\r\n\t\t\t\t\t}\r\n\r\n\t\t\t\t} else if (name.equalsIgnoreCase(\"15 wott\")) {\r\n\t\t\t\t\tcount = rs.getInt(2);\r\n\r\n\t\t\t\t\tif ((count >= 10) && (count <= 20)) {\r\n\t\t\t\t\t\ttotal_amount = count * 35;\r\n\t\t\t\t\t} else if ((count >= 21) && (count <= 35)) {\r\n\t\t\t\t\t\ttotal_amount = count * 45;\r\n\t\t\t\t\t} else if ((count <= 36) && (count <= 50)) {\r\n\t\t\t\t\t\ttotal_amount = count * 55;\r\n\t\t\t\t\t} else if ((count <= 51)) {\r\n\t\t\t\t\t\ttotal_amount = count * 65;\r\n\t\t\t\t\t}\r\n\r\n\t\t\t\t} else if (name.equalsIgnoreCase(\"20 wott\")) {\r\n\t\t\t\t\tcount = rs.getInt(2);\r\n\r\n\t\t\t\t\tif ((count >= 10) && (count <= 20)) {\r\n\t\t\t\t\t\ttotal_amount = count * 45;\r\n\t\t\t\t\t} else if ((count >= 21) && (count <= 35)) {\r\n\t\t\t\t\t\ttotal_amount = count * 55;\r\n\t\t\t\t\t} else if ((count >= 36) && (count <= 50)) {\r\n\t\t\t\t\t\ttotal_amount = count * 65;\r\n\t\t\t\t\t} else if ((count >= 51)) {\r\n\t\t\t\t\t\ttotal_amount = count * 75;\r\n\t\t\t\t\t}\r\n\r\n\t\t\t\t}\r\n\r\n\t\t\t}\r\n\r\n\t\t} catch (SQLException e) {\r\n\t\t\tlogger.error(\"\", e);\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t\treturn total_amount;\r\n\t}",
"double getSum();",
"double getSum();",
"BigDecimal getSumOfTransactions(StatisticalDTO dto) throws DaoException;",
"public String sumatoria(String columna) {\r\n\t\ttry {\r\n\t\t\tdouble total = 0;\r\n\t\t\tDouble cAux = new Double(total);\r\n\t\t\tString totalChar = \"\";\r\n\t\t\tString valchar = \"\";\r\n\t\t\tfor (int i = 1; i <= this.elemVS.size(); i++) {\r\n\t\t\t\tvalchar = (getObject(i, columna)).toString();\r\n\t\t\t\ttotal = total + (Double.valueOf(valchar)).doubleValue();\r\n\t\t\t}\r\n\t\t\ttotalChar = Double.toString(total);\r\n\t\t\treturn totalChar;\r\n\t\t}\r\n\t\tcatch (Exception e) {\r\n\t\t\treturn \" \" + elemVS.size();\r\n\t\t}\r\n\t}",
"public String sumatoria(int columna) {\r\n\t\ttry {\r\n\t\t\tdouble total = 0;\r\n\t\t\tDouble cAux = new Double(total);\r\n\t\t\tString totalChar = \"\";\r\n\t\t\tString valchar = \"\";\r\n\t\t\tfor (int i = 1; i <= this.elemVS.size(); i++) {\r\n\t\t\t\tvalchar = (getObject(i, columna)).toString();\r\n\t\t\t\ttotal = total + (Double.valueOf(valchar)).doubleValue();\r\n\t\t\t}\r\n\t\t\ttotalChar = Double.toString(total);\r\n\t\t\treturn totalChar;\r\n\t\t}\r\n\t\tcatch (Exception e) {\r\n\t\t\treturn \" \";\r\n\t\t}\r\n\t}",
"public BigDecimal getStmtAmt();",
"public String totalMultaCliente(String id_cliente) throws SQLException {\n System.out.println(\"asdj89asduasd8asd8\");\n // Prepara conexão p/ receber o comando SQL\n String sql = \"SELECT SUM(multa.valor) AS totalMulta FROM multa \"\n + \"INNER JOIN cliente ON multa.id_cliente = cliente.id_cliente \"\n + \"WHERE cliente.id_cliente = ? \"\n + \"GROUP BY cliente.id_cliente;\";\n PreparedStatement stmt = this.conexao.prepareStatement(sql);\n stmt.setString(1, id_cliente);\n\n // Recebe o resultado da consulta SQL\n ResultSet rs = stmt.executeQuery();\n\n rs.next();\n String totalMulta = String.valueOf(rs.getFloat(\"totalMulta\"));\n\n System.out.println(totalMulta);\n\n // Fecha a conexão com o BD\n rs.close();\n stmt.close();\n\n // Retorna a lista de registros, gerados pela consulta\n System.out.println(\"asdj89asduasd8asd8\");\n return totalMulta;\n\n }",
"public int sumofPrice(){\n\t\tSQLiteDatabase db = this.getReadableDatabase();\n\t\tString selectQuery = \"SELECT SUM(price) FROM \" + TABLE_SHOP;\n\t\tCursor cur = db.rawQuery(selectQuery, null);\n\t\tint total=0;\n\t\tif(cur.moveToFirst())\n\t\t{\n\t\t\ttotal = cur.getInt(0);\n\t\t}\n\t\treturn total;\n\t}",
"@Override\n\tpublic ResultSet displayTotalFinancialBudget() {\n\t\tResultSet rs = null;\n\t\ttry {\n\t\t\tc=MakeConnection.getConnection();\n\t\t} catch (ClassNotFoundException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (SQLException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t\ttry {\n\t\t\tPreparedStatement pr=c.prepareStatement(\"select sum(TrainingModule.Budget) from TrainingModule NATURAL JOIN link_tm_tp\");\n\t\t\trs=pr.executeQuery();\n\t\t\t\treturn rs;\n\t\t\t\n\t\t} catch (SQLException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t\treturn rs;\n\t}",
"public String ejecutarSQLselect(String sql, int div){\n String line=\"\";\n try {\n iniciarConexion();\n ResultSet rs = this.statement.executeQuery(sql);\n if (rs.next()){ \n String paquete = rs.getString(\"dataInstrumento\");\n String token[]=paquete.split(\";\");\n double aux []=new double[token.length];\n for(int i=0;i<aux.length;i++){\n aux[i]+=Double.parseDouble(token[i]);\n }\n while (rs.next()) {\n paquete = rs.getString(\"dataInstrumento\");\n String token2[]=paquete.split(\";\");\n for(int i=0;i<aux.length;i++){\n aux[i]+=Double.parseDouble(token2[i]);\n }\n }\n for(int i=0;i<aux.length-1;i++){\n line+=aux[i]/div+\";\";// posible error entteros\n }\n line+=aux[aux.length-1]/div;\n } \n rs.close();\n cerrarConexion();\n } catch (SQLException ex) {\n System.out.println(ex);\n }\n return line;\n }",
"@Test\n public void testAggregateSql() throws Exception {\n String fields = \"year, month, min(depdelay), max(arrdelay)\";\n String expectedSql = \"SELECT year,month,MIN(depdelay),MAX(arrdelay) FROM airline GROUP BY year,month\";\n Assert.assertEquals(expectedSql, AggregateField.toSql(AggregateField.fromSqlFieldSpecs(fields), \"airline\"));\n }",
"private String getSql(Map map){\n \tStringBuilder sql = new StringBuilder();\n \t\n \tsql.append(\" select account.FNumber number,REPLACE(account.FLongNumber, '!', '.') transLongNumber,account.FLongNumber longNumber,account.FName_l2 name, \");\n \tsql.append(\" account.FLevel level1,account.FIsLeaf isLeaf,account.FId id,account.FParentID parentid, \");\n \tsql.append(\" org.FId fullOrgUnitid,project.FId curProjectid \");\n \tsql.append(\" from T_FDC_CostAccount account \");\n \tsql.append(\" left join T_FDC_CurProject project ON account.FCurProject = project.FID \");\n \tsql.append(\" left join T_FDC_CostAccount parent ON account.FParentID = parent.FID \");\n \tsql.append(\" left join T_ORG_BaseUnit org ON account.FFullOrgUnit = org.FID \");\n \tsql.append(\" where 1=1 \");\n \tsql.append(\" and account.FLongNumber like '5002%' \");//只取科目502开头的科目\n \tif(map.get(\"fullOrgUnit\")!=null){\n OrgStructureInfo oui = (OrgStructureInfo)map.get(\"fullOrgUnit\");\n if(oui != null && oui.getUnit() != null){\n FullOrgUnitInfo info = oui.getUnit();\n \tsql.append(\" and account.FFullOrgUnit = '\"+info.getId().toString()+\"' \");\n }\n \t}\n \tif(map.get(\"curProject\")!=null){\n \t\tCurProjectInfo projectInfo = (CurProjectInfo)map.get(\"curProject\");\n \tsql.append(\" and account.FCurProject = '\"+projectInfo.getId().toString()+\"' \");\n \t}\n \tsql.append(\" order by REPLACE(account.FLongNumber, '!', '.') asc \");\n \t\n \treturn sql.toString();\n }",
"@Override\r\n\tpublic List<InformationDTO> findSum() {\n\t\treturn sqlSessionTemplate.selectList(typeNameSpace + \".findSum\");\r\n\t}",
"private static double calculateDist(StringBuffer sb, Statement stmt) throws SQLException{\n\t\tdouble distance;\n\t\tResultSet d=stmt.executeQuery(sb.toString());\n\t\td.next();\n\t\tdistance=d.getDouble(1);\n\t\t\n\t\treturn distance;\n\t}",
"public static int selectTotalWattage() throws Exception {\n Connection connection = DriverManager.getConnection(\"jdbc:postgresql://127.0.0.1:10000/tiana18\", \"tiana18web\", \"<password>\");\n ResultSet result1 = connection.createStatement().executeQuery(\"SELECT ((SELECT SUM(wattage) FROM public.electronics) + \" +\n \"(SELECT (SUM(wattage)) FROM public.switchedelectronics WHERE ison = true)) \" +\n \"AS result;\");\n ResultSet result2 = connection.createStatement().executeQuery(\"select * from public.lights where ison = true;\");\n int i = 0;\n while (result2.next())\n {\n i++;\n }\n connection.close();\n result1.next();\n return result1.getInt(1) + (i * 60);\n }",
"private void getSum() {\n double sum = 0;\n for (int i = 0; i < remindersTable.getRowCount(); i++) {\n sum = sum + parseDouble(remindersTable.getValueAt(i, 3).toString());\n }\n String rounded = String.format(\"%.2f\", sum);\n ledgerTxtField.setText(rounded);\n }",
"@Query(value = \"SELECT sum(total_lkr) FROM receipt WHERE rec_date BETWEEN :Date1 and :Date2\", nativeQuery = true)\n\tBigDecimal TotalrevanuelastYear(@Param(\"Date1\") LocalDate Date1, @Param(\"Date2\") LocalDate Date2);",
"public double obtenerTotalCarrito() throws DBException {\r\n\t\tdouble precioTotal = 0;\r\n\t\tString sentSQL = \"SELECT SUM(precio) FROM carrito\";\r\n\t\ttry {\r\n\t\t\tStatement st = conexion.createStatement();\r\n\t\t\tResultSet rs = st.executeQuery(sentSQL);\r\n\t\t\tif(rs.next()) {\r\n\t\t\t\tprecioTotal = rs.getDouble(1);\r\n\t\t\t}\r\n\t\t\trs.close();\r\n\t\t\tst.close();\r\n\t\t\tLOG.log(Level.INFO,\"Precio total obtenido\");\r\n\t\t} catch (SQLException e) {\r\n\t\t\t// TODO Auto-generated catch block\r\n\t\t\te.printStackTrace();\r\n\t\t\tLOG.log(Level.WARNING,e.getMessage());\r\n\t\t\tthrow new DBException(\"No se ha podido ejecutar la query\");\r\n\t\t}\r\n\t\treturn precioTotal;\r\n\t}",
"public double sum() {\n double resultat = 0;\n for (int i = 0; i < tab.size(); i++) {\n resultat += CalculatorArray.sum(tab.get(i));\n }\n System.out.println(\"Sum colonne:\" + resultat);\n return resultat;\n }",
"private String getUnionQuery(TaxChallan taxChallan,Object[][] tdsParameter, String ledgerCode) {\r\n\t\t\r\n\t\tString salaryQuery = \"\";\r\n\t\tString arrearstQuery = \"\";\r\n\t\tString settlementQuery = \"\";\r\n\t\t//String allowanceQuery = \"\";\r\n\t\tString challanQuery = \"\";\r\n\t\tString bonusQuery = \"\";\r\n\t\tString leaveEncashmentQuery = \"\";\r\n\t\tString OverTimeQuery = \"\";\r\n\t\t//-------------------------Start of query---------------------------------------\r\n\t\ttry{\r\n\t\tchallanQuery = \"SELECT EMPID, ETOKEN, ENAME, TO_CHAR(SUM(AMT),9999999990.99) FROM ( \";\r\n\t\t\r\n\t\t\tif(ledgerCode != null && ledgerCode.length() > 0){\r\n\t\t\t\t/**\r\n\t\t\t\t * Query for Salary\r\n\t\t\t\t */\r\n\t\t\t\tsalaryQuery=\"SELECT DISTINCT HRMS_SAL_DEBITS_\"+taxChallan.getYear()+\".EMP_ID AS EMPID,EMP_TOKEN AS ETOKEN,EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME AS ENAME \"\r\n\t\t\t\t+\" ,TO_CHAR(SUM(NVL(SAL_AMOUNT,0)),9999999990.99) AS AMT \"\r\n\t\t\t\t+\" FROM HRMS_SAL_DEBITS_\"+taxChallan.getYear()+\" \"\r\n\t\t\t\t+\" INNER JOIN HRMS_EMP_OFFC ON HRMS_SAL_DEBITS_\"+taxChallan.getYear()+\".EMP_ID = HRMS_EMP_OFFC.EMP_ID \" \r\n\t\t\t\t+\" INNER JOIN HRMS_SALARY_\"+taxChallan.getYear()+\" ON (HRMS_SALARY_\"+taxChallan.getYear()+\".EMP_ID = HRMS_SAL_DEBITS_\"+taxChallan.getYear()+\".EMP_ID \" \r\n\t\t\t\t+\" and HRMS_SALARY_\"+taxChallan.getYear()+\".SAL_LEDGER_CODE = HRMS_SAL_DEBITS_\"+taxChallan.getYear()+\".SAL_LEDGER_CODE) \"\r\n\t\t\t\t+\" WHERE HRMS_SALARY_\"+taxChallan.getYear()+\".SAL_DIVISION=\"+taxChallan.getDivId()+\" AND SAL_DEBIT_CODE=\"+String.valueOf(tdsParameter[0][0])+\" AND SAL_LEDGER_CODE IN(\"+ledgerCode+\") \" +\r\n\t\t\t\t \" AND HRMS_SAL_DEBITS_\"+taxChallan.getYear()+\".EMP_ID NOT IN(SELECT EMP_ID FROM HRMS_TAX_CHALLAN_DTL \"\r\n\t\t\t\t+\" INNER JOIN HRMS_TAX_CHALLAN ON (HRMS_TAX_CHALLAN.CHALLAN_CODE = HRMS_TAX_CHALLAN_DTL.CHALLAN_CODE ) \"\r\n\t\t\t\t+\" WHERE CHALLAN_MONTH = \"+taxChallan.getMonth()+\" AND CHALLAN_YEAR=\"+taxChallan.getYear()+\" AND CHALLAN_DIVISION_ID=\"+taxChallan.getDivId()+\")\";\r\n\t\t\t\tlogger.info(\"taxChallan.getOnHold()======\"+taxChallan.getOnHold());\r\n\t\t\t\tif(taxChallan.getOnHold().equals(\"Yes\")){\r\n\t\t\t\t\tsalaryQuery += \" AND SAL_ONHOLD='Y' \";\r\n\t\t\t\t} //end of if\r\n\t\t\t\telse if(taxChallan.getOnHold().equals(\"No\")){\r\n\t\t\t\t\tsalaryQuery += \" AND SAL_ONHOLD='N' \";\r\n\t\t\t\t} //end of else if\r\n\t\t\t\tsalaryQuery+=\" GROUP BY HRMS_SAL_DEBITS_\"+taxChallan.getYear()+\".EMP_ID,EMP_TOKEN,EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME \";\r\n\t\t\t\t\r\n\t\t\t} //end of ledgerCode if\r\n\t\t\t\r\n\t\t\tchallanQuery +=salaryQuery;\r\n\t\t\tif(taxChallan.getIncludeArrears().equals(\"true\")){\r\n\t\t\t\tif(taxChallan.getIncludeSalary().equals(\"true\")){\r\n\t\t\t\t\tarrearstQuery +=\" UNION \";\r\n\t\t\t\t} //end of if\r\n\t\t\t\r\n\t\t\t/**\r\n\t\t\t * Query for Arrears \r\n\t\t\t */\r\n\t\t\tarrearstQuery +=\" SELECT ARREARS_EMP_ID AS EMPID,EMP_TOKEN AS ETOKEN,EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME AS ENAME, \"\r\n\t\t\t\t+\" TO_CHAR(SUM(NVL(ARREARS_AMT,0)),9999999990.99) AS AMT \"\r\n\t\t\t\t+\" FROM HRMS_ARREARS_DEBIT_\"+taxChallan.getYear()+\" \"\r\n\t\t\t\t+\" INNER JOIN HRMS_DEBIT_HEAD ON HRMS_DEBIT_HEAD.DEBIT_CODE = HRMS_ARREARS_DEBIT_\"+taxChallan.getYear()+\".ARREARS_DEBIT_CODE \" \r\n\t\t\t\t+\" INNER JOIN HRMS_EMP_OFFC ON HRMS_ARREARS_DEBIT_\"+taxChallan.getYear()+\".ARREARS_EMP_ID = HRMS_EMP_OFFC.EMP_ID \"\r\n\t\t\t\t+\" WHERE ARREARS_CODE IN (SELECT ARREARS_CODE FROM HRMS_ARREARS_LEDGER WHERE ARREARS_PAID_MONTH = \"+taxChallan.getMonth()+\" \" \r\n\t\t\t\t+\" AND ARREARS_PAID_YEAR = \"+taxChallan.getYear()+\" AND ARREARS_DIVISION = \"+taxChallan.getDivId()+\") AND ARREARS_DEBIT_CODE = \"+String.valueOf(tdsParameter[0][0])+\" \" +\r\n\t\t\t\t \" AND ARREARS_EMP_ID NOT IN (SELECT EMP_ID FROM HRMS_TAX_CHALLAN_DTL \"\r\n\t\t\t\t+\" INNER JOIN HRMS_TAX_CHALLAN ON (HRMS_TAX_CHALLAN.CHALLAN_CODE = HRMS_TAX_CHALLAN_DTL.CHALLAN_CODE AND CHALLAN_ARREARS_FLAG='Y') \"\r\n\t\t\t\t+\" WHERE CHALLAN_MONTH = \"+taxChallan.getMonth()+\" AND CHALLAN_YEAR=\"+taxChallan.getYear()+\" AND CHALLAN_DIVISION_ID=\"+taxChallan.getDivId()+\") \"\r\n\t\t\t\t+\" GROUP BY ARREARS_EMP_ID,EMP_TOKEN,EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME \";\r\n\t\t\t\r\n\t\t} //end of includeArrears if\r\n\t\t\t\r\n\t\t\tchallanQuery +=arrearstQuery;\r\n\t\t\tif(taxChallan.getIncludeSettlement().equals(\"true\")){\r\n\t\t\t\tif(taxChallan.getIncludeSalary().equals(\"true\")){\r\n\t\t\t\t\tsettlementQuery +=\" UNION \";\r\n\t\t\t\t} //end of if\r\n\t\t\t\tsettlementQuery += \" SELECT SETTL_ECODE AS EMPID,EMP_TOKEN AS ETOKEN,EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME AS ENAME, \"\r\n\t\t\t\t+\" TO_CHAR(SUM(NVL(SETTL_AMT,0)),9999999990.99)+TO_CHAR(nvl((SETTL_TAX_AMT),0),9999999990.99) AS AMT FROM HRMS_SETTL_DEBITS \"\r\n\t\t\t\t+\" INNER JOIN HRMS_SETTL_HDR ON (HRMS_SETTL_HDR.SETTL_CODE = HRMS_SETTL_DEBITS.SETTL_CODE) \"\r\n\t\t\t\t+\" INNER JOIN HRMS_EMP_OFFC ON (HRMS_EMP_OFFC.EMP_ID = HRMS_SETTL_HDR.SETTL_ECODE) \"\r\n\t\t\t\t+\" INNER JOIN HRMS_RESIGN ON (HRMS_RESIGN.RESIGN_CODE = HRMS_SETTL_HDR.SETTL_RESGNO) \" \r\n\t\t\t\t+\" WHERE (SETTL_MTH_TYPE IN ('OH','CO')) AND RESIGN_WITHDRAWN = 'N' AND EMP_DIV = \"+taxChallan.getDivId()+\" \"\r\n\t\t\t\t+\" AND TO_CHAR(SETTL_SETTLDT,'MM')=\"+taxChallan.getMonth()+\" AND TO_CHAR(SETTL_SETTLDT,'YYYY')=\"+taxChallan.getYear()+\" \"\r\n\t\t\t\t+\" AND SETTL_DEBIT_CODE=\"+String.valueOf(tdsParameter[0][0])+\" \" +\r\n\t\t\t\t \" AND SETTL_ECODE NOT IN (SELECT EMP_ID FROM HRMS_TAX_CHALLAN_DTL \"\r\n\t\t\t\t+\" INNER JOIN HRMS_TAX_CHALLAN ON (HRMS_TAX_CHALLAN.CHALLAN_CODE = HRMS_TAX_CHALLAN_DTL.CHALLAN_CODE) \"\r\n\t\t\t\t+\" WHERE CHALLAN_MONTH = \"+taxChallan.getMonth()+\" AND CHALLAN_YEAR=\"+taxChallan.getYear()+\" AND CHALLAN_DIVISION_ID=\"+taxChallan.getDivId()+\") \" \r\n\t\t\t\t+\" GROUP BY SETTL_ECODE,EMP_TOKEN,EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME,SETTL_TAX_AMT \";\r\n\t\t\t\t\r\n\t\t\t} //end of includeSettlement if\r\n\t\t\t\r\n\t\t\tchallanQuery +=settlementQuery;\r\n\t\t\t\r\n\t\t\t/*if(taxChallan.getIncludeAllowance().equals(\"true\")){\r\n\t\t\t\ttaxChallan.setHidIncludeAllow(\"true\");\r\n\t\t\t\tif(taxChallan.getIncludeSalary().equals(\"true\") || taxChallan.getIncludeSettlement().equals(\"true\")){\r\n\t\t\t\t\tallowanceQuery +=\" UNION \";\r\n\t\t\t\t} //end of if\r\n\t\t\t\tallowanceQuery += \" SELECT HRMS_ALLOWANCE_EMP_DTL.ALLW_EMP_ID AS EMPID,EMP_TOKEN AS ETOKEN,EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME AS ENAME, \"\r\n\t\t\t\t+\" NVL(SUM(ALLW_TAX_AMT),0) AS AMT \"\r\n\t\t\t\t+\" FROM HRMS_ALLOWANCE_HDR \"\r\n\t\t\t\t+\" INNER JOIN HRMS_ALLOWANCE_EMP_DTL ON (HRMS_ALLOWANCE_EMP_DTL.ALLW_ID = HRMS_ALLOWANCE_HDR.ALLW_ID) \"\r\n\t\t\t\t+\" INNER JOIN HRMS_EMP_OFFC ON (HRMS_EMP_OFFC.EMP_ID = HRMS_ALLOWANCE_EMP_DTL.ALLW_EMP_ID) \"\r\n\t\t\t\t+\" INNER JOIN HRMS_CREDIT_HEAD ON (HRMS_CREDIT_HEAD.CREDIT_CODE = HRMS_ALLOWANCE_HDR.ALLW_CREDIT_HEAD) \"\r\n\t\t\t\t+\" AND TO_CHAR(ALLW_PROCESS_DATE,'MM')=\"+taxChallan.getMonth()+\" \"\r\n\t\t\t\t+\" AND TO_CHAR(ALLW_PROCESS_DATE,'YYYY')=\"+taxChallan.getYear()+\" \" \r\n\t\t\t\t+\" AND HRMS_ALLOWANCE_HDR.ALLW_DIVISION = \"+taxChallan.getDivId()+\" \" +\r\n\t\t\t\t \" AND HRMS_ALLOWANCE_EMP_DTL.ALLW_EMP_ID NOT IN (SELECT EMP_ID FROM HRMS_TAX_CHALLAN_DTL \"\r\n\t\t\t\t+\" INNER JOIN HRMS_TAX_CHALLAN ON (HRMS_TAX_CHALLAN.CHALLAN_CODE = HRMS_TAX_CHALLAN_DTL.CHALLAN_CODE) \"\r\n\t\t\t\t+\" WHERE CHALLAN_MONTH = \"+taxChallan.getMonth()+\" AND CHALLAN_YEAR=\"+taxChallan.getYear()+\" AND CHALLAN_DIVISION_ID=\"+taxChallan.getDivId()+\") \"\r\n\t\t\t\t+\" GROUP BY HRMS_ALLOWANCE_EMP_DTL.ALLW_EMP_ID,EMP_TOKEN,EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME \";\r\n\t\t\t\t\r\n\t\t\t} //end of includeAllowance if\r\n\t\t\t\r\n\t\t\tchallanQuery +=allowanceQuery;*/\r\n\t\t\tif(taxChallan.getIncludeBonus().equals(\"true\")){\r\n\t\t\t\tif(taxChallan.getIncludeSalary().equals(\"true\")){\r\n\t\t\t\t\tbonusQuery +=\" UNION \";\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tbonusQuery += \" SELECT HRMS_BONUS_EMP.EMP_ID AS EMPID, NVL(EMP_TOKEN,' ') AS ETOKEN, NVL(EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME,' ') AS ENAME, TO_CHAR(SUM(NVL(HRMS_BONUS_EMP.BONUS_TAX_AMT,0)),9999999990.99) AS AMT\" \r\n\t\t\t\t\t+ \" FROM HRMS_BONUS_EMP \"\r\n\t\t\t\t\t+ \" INNER JOIN HRMS_BONUS_HDR ON (HRMS_BONUS_HDR.BONUS_CODE = HRMS_BONUS_EMP.BONUS_CODE)\"\r\n\t\t\t\t\t+ \" INNER JOIN HRMS_EMP_OFFC ON (HRMS_EMP_OFFC.EMP_ID = HRMS_BONUS_EMP.EMP_ID)\"\r\n\t\t\t\t\t+ \" WHERE HRMS_BONUS_HDR.DIV_CODE=\"+taxChallan.getDivId()+\" AND HRMS_BONUS_HDR.PAY_MONTH=\"+taxChallan.getMonth()+\" AND HRMS_BONUS_HDR.PAY_YEAR = \"+taxChallan.getYear()\r\n\t\t\t\t\t+ \" AND HRMS_BONUS_HDR.PAY_IN_SAL='N' AND HRMS_BONUS_HDR.DEDUCT_TAX='Y'\"\r\n\t\t\t\t\t+ \" GROUP BY HRMS_BONUS_EMP.EMP_ID, NVL(EMP_TOKEN,' '), NVL(EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME,' ')\";\r\n\t\t\t\t\r\n\t\t\t} \r\n\t\t\tchallanQuery +=bonusQuery;\r\n\t\t\t\r\n\t\t\tif(taxChallan.getIncludeLeaveEncashment().equals(\"true\")){\r\n\t\t\t\tif(taxChallan.getIncludeSalary().equals(\"true\")){\r\n\t\t\t\t\tleaveEncashmentQuery +=\" UNION \";\r\n\t\t\t\t}\r\n\t\t\t\tleaveEncashmentQuery += \" SELECT HRMS_ENCASHMENT_PROCESS_DTL.EMP_ID AS EMPID, NVL(EMP_TOKEN,' ') AS ETOKEN, NVL(EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME,' ') AS ENAME, TO_CHAR(SUM(NVL(ENCASHMENT_TDS_AMOUNT,0)),9999999990.99) AS AMT\"\r\n\t\t\t\t\t+ \" FROM HRMS_ENCASHMENT_PROCESS_DTL \"\r\n\t\t\t\t\t+ \" INNER JOIN HRMS_EMP_OFFC ON (HRMS_EMP_OFFC.EMP_ID = HRMS_ENCASHMENT_PROCESS_DTL.EMP_ID) \"\r\n\t\t\t\t\t+ \" INNER JOIN HRMS_ENCASHMENT_PROCESS_HDR ON (HRMS_ENCASHMENT_PROCESS_HDR.ENCASHMENT_PROCESS_CODE = HRMS_ENCASHMENT_PROCESS_DTL.ENCASHMENT_PROCESS_CODE)\"\r\n\t\t\t\t\t+ \" WHERE HRMS_ENCASHMENT_PROCESS_HDR.ENCASHMENT_PROCESS_DIVISION =\"+taxChallan.getDivId()+\" AND HRMS_ENCASHMENT_PROCESS_HDR.ENCASHMENT_INCLUDE_SAL_MONTH = \"+taxChallan.getMonth()\r\n\t\t\t\t\t+ \" AND HRMS_ENCASHMENT_PROCESS_HDR.ENCASHMENT_INCLUDE_SAL_YEAR= \"+taxChallan.getYear()+\" AND HRMS_ENCASHMENT_PROCESS_HDR.ENCASHMENT_INCLUDE_SAL_FLAG = 'N'\"\r\n\t\t\t\t\t+ \" GROUP BY HRMS_ENCASHMENT_PROCESS_DTL.EMP_ID, NVL(EMP_TOKEN,' '), NVL(EMP_FNAME||' '||EMP_MNAME||' '||EMP_LNAME,' ')\";\r\n\r\n\t\t\t} \r\n\t\t\tchallanQuery +=leaveEncashmentQuery;\r\n\t\t\t\r\n\t\t\tif(taxChallan.getIncludeOverTime().equals(\"true\")){\r\n\t\t\t\tif(taxChallan.getIncludeSalary().equals(\"true\")){\r\n\t\t\t\t\tOverTimeQuery +=\" UNION \";\r\n\t\t\t\t}\r\n\t\t\t\tOverTimeQuery += \"\";\r\n\t\t\t} \r\n\t\t\tchallanQuery +=OverTimeQuery;\r\n\t\t\t\r\n\t\t\tchallanQuery +=\" ) GROUP BY EMPID, ETOKEN, ENAME\";\r\n\t\t}catch(Exception e){\r\n\t\t\tlogger.error(\"exception in union challan query\",e);\r\n\t\t} //end of catch\r\n\t\treturn challanQuery;\r\n\t}",
"public ResultSet getAccno(Long ano)throws SQLException {\n\trs=DbConnect.getStatement().executeQuery(\"select balance from bank where Accno=\"+ano+\"\");\r\n\treturn rs;\r\n}",
"public List GetSoupKitchenTable() {\n\n //ArrayList<FoodPantry> fpantries = new ArrayList<FoodPantry>();\n\n\n //here we want to to a SELECT * FROM food_pantry table\n MapSqlParameterSource params = new MapSqlParameterSource();\n //here we want to get total from food pantry table\n String sql = \"SELECT * FROM cs6400_sp17_team073.Soup_kitchen\";\n\n List<SoupKitchen> skitchens = jdbcTemplate.query(sql, new SkitchenMapper());\n\n\n\n return skitchens;\n }",
"public int findDanymicRecordDetailTotal(long sgid,String wbuid,DanymicUserSiftDto siftDto);",
"private int getTotalSaleCost(String saleCodeS)\r\n\t{\r\n\t\tResultSet rs = null;\r\n\t\tArrayList<String> arr = new ArrayList<>();\r\n\t\tint sum = 0;\r\n\t\t\r\n\t\tString query = \"select sum(cost) FROM salesReport where saleCode = ?\";\r\n\t\tarr.add(saleCodeS);\r\n\t\t\r\n\t\ttry\r\n\t\t{\r\n\t\t\tClientUI.chat.accept(\"\");\r\n\t\t\trs = ChatClient.selectWithParameters(query, arr);\r\n\t\t\t\r\n\t\t\twhile(rs.next())\r\n\t\t\t{\r\n\t\t\t\tsum = rs.getInt(\"sum(cost)\");\r\n\t\t\t}\r\n\t\t} \r\n\t\tcatch (Exception e)\r\n\t\t{\r\n\t\t\tSystem.err.println(\"Error : MarketingManagerReports : client server problem\");\t\t\te.printStackTrace();\r\n\t\t}\r\n\t\t\r\n\t\treturn sum;\r\n\t}",
"public int totexp()\n {\n SQLiteDatabase db1 = this.getReadableDatabase();\n String stmt = \"SELECT SUM(AMOUNT) FROM EXPENSE\";\n Cursor tot = db1.rawQuery(stmt, null);\n if(tot.getCount()==0)\n {\n return 0;\n }\n else {\n tot.moveToFirst();\n int amount = tot.getInt(0);\n tot.close();\n return amount;\n }\n }",
"public List<BudgetTotals> getBudgetTotals() throws SQLException{\n BudgetTotals found = null;\n List<BudgetTotals> allBT = new ArrayList<BudgetTotals>();\n DatabaseConnection dbaInfo = new DatabaseConnection();\n Connection conn = dbaInfo.getConnection();\n PreparedStatement stmt = conn.prepareCall(\"SELECT bud_category, sum(bud_budgeted_amount) AS budgetTotal, sum(bud_actual_amount) AS actualTotal FROM finance.budget GROUP BY bud_category\");\n ResultSet rs = stmt.executeQuery();\n while (rs.next()){\n found = new BudgetTotals();\n found.setCategory(rs.getString(\"bud_category\"));\n found.setBudgetTotal(rs.getDouble(\"budgetTotal\"));\n found.setActualTotal(rs.getDouble(\"actualTotal\"));\n allBT.add(found);\n }\n return allBT;\n }",
"public Double getRawGross(int month, int day, int year, int storeCode, int...hour ) {\r\n//\t\tString query = \"SELECT SUM(IF(o.RETURN=0,i.SELL_PRICE*i.QUANTITY,p.AMT)) FROM invoice_item i, invoice o, payment_item p WHERE MONTH (o.TRANS_DT) = '\"+month+\"' && YEAR(o.TRANS_DT) = '\"+year+\"' && DAY(o.TRANS_DT) = '\"+day+\"' AND i.OR_NO = o.OR_NO AND p.OR_NO = o.OR_NO AND p.STORE_CODE = o.STORE_CODE AND o.STORE_CODE = '\"+storeCode+\"'\";\r\n\t\tString query = \"SELECT SUM(i.SELL_PRICE*i.QUANTITY) FROM invoice_item i, invoice o WHERE MONTH (o.TRANS_DT) = '\"+month+\"' && YEAR(o.TRANS_DT) = '\"+year+\"' && DAY(o.TRANS_DT) = '\"+day+\"' AND i.OR_NO = o.OR_NO AND i.STORE_CODE = o.STORE_CODE AND o.STORE_CODE = '\"+storeCode+\"'\"\r\n\t\t + \" AND NOT EXISTS (SELECT 1 FROM INVOICE_SET s WHERE s.OR_NO = o.OR_NO) \";\r\n\t\t\r\n\t\tif (hour.length > 0) {\r\n\t\t\tquery += \" AND HOUR(o.TRANS_DT) = \" + hour[0];\r\n\t\t}\r\n\t\t\r\n\t\tSystem.out.println(\"RAW GROSS QUERY = \" + query);\r\n\t\t\r\n\t\tResultSet rs = Main.getDBManager().executeQuery(query);\r\n//\t\tResultSet rs = Main.getDBManager().executeQuery(\"SELECT sum(p.AMT) from payment_item p WHERE MONTH (p.TRANS_DT) = '\"+month+\"' && YEAR(p.TRANS_DT) = '\"+year+\"' && DAY(p.TRANS_DT) = '\"+day+\"' AND p.STORE_CODE = '\"+storeCode+\"'\");\r\n\t\tDouble dailySale = 0.0d;\r\n\t\ttry {\r\n\t\t\twhile(rs.next()){\r\n//\t\t\t\tdouble amount = rs.getDouble(1);\r\n//\t\t\t\tdailySale = amount/getVatRate();\r\n\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\tdailySale = rs.getDouble(1);\r\n\t\t\t\tlogger.debug(\"Raw Gross BEFORE SUBTRACTION: \"+dailySale);\r\n\t\t\t\t\r\n\t\t\t\tdailySale = dailySale - getDeductibles(month, day, year, storeCode) + getCompletedTransactions(month, day, year, storeCode);\r\n\t\t\t\tlogger.debug(\"Raw Gross AFTER SUBTRACTION: \"+dailySale);\r\n\t\t\t}\r\n\t\t} catch (SQLException e) {\r\n\t\t\tLoggerUtility.getInstance().logStackTrace(e);\r\n\t\t}\r\n//\t\tdailySale = dailySale - getDeductibles(month, day, year, storeCode) + getCompletedTransactions(month, day, year, storeCode);\r\n\t\tlogger.debug(\"Raw Gross: \"+dailySale);\r\n\t\treturn dailySale;\r\n\t}",
"@Override\n public long getTotalHargaById(String idTransaksi) {\n long totalHarga = 0;\n\n try {\n String query = \"SELECT SUM(b.jml_barang * c.harga) AS \\\"Total Harga\\\" FROM transaksi a INNER JOIN detail_transaksi b ON a.id = b.id_transaksi LEFT JOIN barang c ON b.id_barang = c.id\";\n query += \" WHERE a.id = ?\";\n\n PreparedStatement ps = Koneksi().prepareStatement(query);\n ps.setString(1, idTransaksi);\n ResultSet rs = ps.executeQuery();\n\n if (rs.next()) {\n totalHarga = rs.getInt(1);\n }\n } catch (SQLException se) {\n se.printStackTrace();\n } catch (Exception e) {\n e.printStackTrace();\n }\n\n return totalHarga;\n }",
"float getCPC() throws SQLException;",
"public java.math.BigDecimal getSum() {\n\treturn sum;\n}",
"public void Close(int bin, int amount, String serial){\n try{ \r\n c = DbConnect.getConnection();\r\n //Select and add up the rows where sale is not closed. \r\n pstmt = c.prepareStatement(\"Select SUM(sale_amount) from till_tape where sale_closed = 0\");\r\n rs = pstmt.executeQuery(); \r\n System.out.println(\"Executed select\");\r\n rs.next();\r\n int num = rs.getInt(1);//change to return of int value\r\n System.out.println(num);\r\n //Update rows where sale_closed = 0 to confirm the sale\r\n pstmt = c.prepareStatement(\"Update till_tape SET sale_closed = 1 where sale_closed = 0\");\r\n pstmt.executeUpdate();\r\n System.out.println(\"Executed update\");\r\n //Modify the values of the ticket rows, unsold, actual gross, actual prizes\r\n //use stack database\r\n\r\n }catch (Exception e) { e.printStackTrace(); }\r\n \r\n}",
"public double getSUM() {\n return sum;\n }",
"public String getSum() {\n return sum;\n }",
"BigDecimal getTotal();",
"BigDecimal getTotal();",
"public Object sum(String field) {\n return buildQueryBuilder().sum(field);\n }",
"@Override\n\tpublic double getSumofCost(String supplierName) {\n\t\tString sql=\"SELECT SUM(h.cost) FROM supplier s INNER JOIN supplier_product h on s.supplier_id=h.supplier_supplier_id WHERE supplier_name=?\";\n\t\tdouble total=this.getJdbcTemplate().queryForObject(sql, Double.class, supplierName);\n\t\treturn total;\n\t}",
"private void querySumMenu()\n\t{\n\t\tclearPanel(getPanel1());\n\t\t\n\t\tJLabel label1=new JLabel(\"This is the total numbers\\nFor:\"+getValue1()+\"and\"+getValue2());\n\t\t\n\t\t//get table from sumQuery and put it in table\n\t\tJTable table=getQuery1().sumQuery(); \n\t\t\n\t\tJScrollPane scrolltable = new JScrollPane(table);\n\t\tlabel1.setBounds(100,10,400,40);\n\t\tscrolltable.setBounds(500,10,500,500);\n\t\tgetPanel1().add(scrolltable);\n\t\tgetPanel1().add(getButton3());\n\t\tgetPanel1().add(getButton4());\n\t\tgetButton3().setBounds(260,10,180,60);\n\t\tgetButton4().setBounds(80,10,180,60);\n\t}",
"public int findTotalDenovo() throws DAOException;",
"public long consultarTotalPagoFechaMoneda(String fecha, String moneda) {\n long total = 0;\n Connection con = null;\n try {\n con = Recurso.Conexion.getPool().getDataSource().getConnection();\n String sql = \"SELECT sum(p.total) \"\n + \"FROM premio p\"\n + \" where \"\n + \" p.fecha='\" + fecha + \"' and p.moneda='\" + moneda + \"'\";\n PreparedStatement str;\n str = con.prepareStatement(sql);\n ResultSet rs = str.executeQuery();\n\n while (rs.next()) {\n total = rs.getLong(1);\n }\n str.close();\n rs.close();\n } catch (SQLException ex) {\n ex.printStackTrace();\n } finally {\n if (con != null) {\n try {\n con.close();\n } catch (SQLException ex) {\n Logger.getLogger(GestorPremio.class.getName()).log(Level.SEVERE, null, ex);\n }\n }\n return total;\n }\n\n }",
"public ResultSet retBalance(Long userid) throws SQLException {\n\trs=DbConnect.getStatement().executeQuery(\"Select balance from account where accno=\"+userid+\"\");\r\n\treturn rs;\r\n}",
"int getSuma();",
"int getSumaAdunata();",
"public BigDecimal getSumOfOutstanding(){\n\t\t BigDecimal a = new BigDecimal(0);\r\n//\t\t int outstandingIndex = 0;\r\n//\t\t for (int i=0 ; i<mColumnNames.length ; i++){\r\n//\t\t\t if (mColumnNames[i].equals(DBService.OUTSTANDING)){\r\n//\t\t\t\t outstandingIndex = i;\r\n//\t\t\t\t break;\r\n//\t\t\t }\r\n//\t\t }\r\n\t\t \r\n\t\t for (int i=0 ; i<getRowCount() ; i++){\r\n\t\t\t float value = (Float)getValueAt(i, 11);\r\n\t\t\t \r\n\t\t\t if (value != 0){\r\n\t\t\t\t BigDecimal b = new BigDecimal(value);\r\n\t\t\t\t a = a.add(b);\r\n\t\t\t }\r\n\t\t }\r\n\t\t \r\n\t\t return a;\r\n\t }",
"private void totalQuantityInventory(String drugName, String expireDate) {\r\n\r\n\t\tPreparedStatement ps = null, ps2 = null;\r\n\t\tResultSet rs = null, rs2 = null;\r\n\t\tint qttyDemandedTotal2 = 0;\r\n\t\tString qry = \"Select quantity, batchNo, voucherNo, Re_Order_Qtty,category From drug_inventory where expiryDate=? and\"\r\n\t\t\t\t+ \" description=?\";\r\n\r\n\t\tString qry2 = \"SELECT SUM(quantityDemanded) as quantitd from counterdrugordertable \"\r\n\t\t\t\t+ \"where expiryDate=? AND drugNameOrder =?\";\r\n\r\n\t\ttry {\r\n\r\n\t\t\ttry {\r\n\t\t\t\tps = St_MaryConnection.getConnection().prepareStatement(qry);\r\n\t\t\t\tps.setString(1, expireDate);\r\n\t\t\t\tps.setString(2, drugName);\r\n\r\n\t\t\t\t//\r\n\t\t\t\tps2 = St_MaryConnection.getConnection().prepareStatement(qry2);\r\n\t\t\t\tps2.setString(1, expireDate);\r\n\t\t\t\tps2.setString(2, drugName);\r\n\t\t\t\trs2 = ps2.executeQuery();\r\n\r\n\t\t\t\twhile (rs2.next()) {\r\n\t\t\t\t\tqttyDemandedTotal2 = rs2.getInt(\"quantitd\");\r\n\t\t\t\t\tSystem.out.println(qttyDemandedTotal2);\r\n\t\t\t\t}\r\n\r\n\t\t\t} catch (SQLException exc) {\r\n\t\t\t\tSystem.out.println(\"getting the remaining qtty from inventory table error\\n\" + exc);\r\n\t\t\t}\r\n\r\n\t\t\trs = ps.executeQuery();\r\n\t\t\twhile (rs.next()) {\r\n\r\n\t\t\t\tString batchNo = rs.getString(\"batchNo\");\r\n\t\t\t\tString voucherNo = rs.getString(\"voucherNo\");\r\n\t\t\t\tint qttyReamaining = rs.getInt(\"quantity\");\r\n\t\t\t\tString reOrderQ = rs.getString(\"Re_Order_Qtty\");\r\n\t\t\t\tString category = rs.getString(\"category\");\r\n\r\n\t\t\t\tinputLabel[2].setText(\"Re-Order Quantity:____________ \" + reOrderQ+\"____\");\r\n\t\t\t\tinputLabel[3].setText(\"Unit Of Issue:____________\" + category+\"____\");\r\n\r\n\t\t\t\tmodel2.addRow(new String[] { \"\" + (qttyDemandedTotal2 + qttyReamaining), \"\" + qttyReamaining, voucherNo,\r\n\t\t\t\t\t\tbatchNo });\r\n\r\n\t\t\t}\r\n\t\t} catch (SQLException exc) {\r\n\t\t\tSystem.out.println(\"getting the remaining qtty from inventory table error\\n\" + exc);\r\n\t\t}\r\n\t}",
"public String get2dQuery() throws SQLException {\r\n String temp = \"\";\r\n String utemp = \"\";\r\n String sqlstr = \"\";\r\n String temp1 = \"\";\r\n String in_qry = \"\";\r\n\r\n int nocol = 0;\r\n\r\n Connection con = null;\r\n CallableStatement st = null;\r\n ResultSet rs = null;\r\n ProgenConnection pg = null;\r\n// pg = new ProgenConnection();\r\n nonViewByList = new ArrayList();\r\n nonViewByListRT = new ArrayList();\r\n\r\n\r\n sqlstr = this.headerQuery;\r\n nonViewbyColumnList = null;\r\n try {\r\n\r\n con = getConnection(this.elementIdForConn);\r\n st = con.prepareCall(sqlstr);\r\n rs = st.executeQuery();\r\n\r\n\r\n\r\n\r\n int i = 1;\r\n\r\n while (rs.next()) {\r\n temp = rs.getString(1).replace(\"'\", \"''\");\r\n /*\r\n * if (temp.length()>=30) temp1= temp.substring(1,20) +\"..\"\r\n * +temp.substring(temp.length()-5,temp.length()-1); else\r\n temp1=temp;\r\n */\r\n temp1 = \"A\" + i;\r\n i++;\r\n\r\n //temp1= temp1.replace(\" & \",\"\");\r\n\r\n if (nonViewbyColumnList == null) {\r\n nonViewbyColumnList = temp;\r\n } else {\r\n nonViewbyColumnList += \",\" + temp;\r\n }\r\n nonViewByList.add(temp1);\r\n nonViewByListRT.add(temp1);\r\n nonViewByMap.put(temp1, temp);\r\n if (this.summReq.equalsIgnoreCase(\"COUNTDISTINCT\")) {\r\n utemp = utemp + \" , nvl( count (distinct ( Case when \" + headerViewByCol + \" = '\" + temp + \"' then \" + this.measureName + \" else null end )) ,0) \\\"\" + temp1 + \"\\\" \";\r\n } else {\r\n utemp = utemp + \" , nvl(\" + this.summReq + \"( Case when \" + headerViewByCol + \" = '\" + temp + \"' then \" + this.measureName + \" else null end ) ,0) \\\"\" + temp1 + \"\\\" \";\r\n }\r\n\r\n nocol = nocol + 1;\r\n }\r\n } catch (SQLException e) {\r\n logger.error(\"Exception:\", e);\r\n } finally {\r\n if (rs != null) {\r\n rs.close();\r\n }\r\n if (st != null) {\r\n st.close();\r\n }\r\n if (con != null) {\r\n con.close();\r\n }\r\n }\r\n\r\n temp = \"\";\r\n sqlstr = \"\";\r\n //nonViewByListRT.add(\"r_total\");\r\n //nonViewByMap.put(\"r_total\", \"Total\");\r\n\r\n\r\n\r\n\r\n {\r\n in_qry = \"\";\r\n in_qry = in_qry + \" select \" + viewByCol + \" \";\r\n in_qry = in_qry + utemp + \" \";\r\n //in_qry = in_qry + utemp + \" , nvl(\" + this.summReq + \" ( \" + this.measureName + \" ),0 ) \\\"r_total\\\" \";\r\n in_qry = in_qry + this.fromTables;\r\n in_qry = in_qry + this.whereClause;\r\n in_qry = in_qry + \"group by \" + viewByColGroup + \" , \" + orderByColGroup + \" \";\r\n if (this.summReq.equalsIgnoreCase(\"COUNTDISTINCT\")) {\r\n in_qry = in_qry + \" having nvl(ABS( count(distinct ( \" + this.measureName + \" ) )),0 ) >0 \";\r\n } else {\r\n in_qry = in_qry + \" having nvl(ABS(\" + this.summReq + \" ( \" + this.measureName + \" ) ),0 ) >0 \";\r\n }\r\n if (defaultSortedColumn != null && !\"\".equalsIgnoreCase(defaultSortedColumn)) {\r\n if (!defaultSortedColumn.equalsIgnoreCase(\"Time\")) {\r\n //in_qry = in_qry + \"order by \" + orderByColGroup + \" \";\r\n in_qry = in_qry + \"order by \" + defaultSortedColumn + \" \";\r\n }\r\n } else {\r\n in_qry = in_qry + \"order by \" + orderByColGroup + \" \";\r\n //in_qry = in_qry + \"order by \" + \"A_\" + defaultSortedColumn + \" \";\r\n }\r\n\r\n //in_qry = in_qry + \"order by \" + orderByColGroup + \" \";\r\n\r\n\r\n sqlstr = in_qry;\r\n\r\n }\r\n return sqlstr;\r\n }",
"private double getColmunSum(TableColumn<Component, String> column) {\r\n double sum = 0;\r\n for (Component component : components) {\r\n sum += Double.parseDouble(column.getCellData(component).replace(',', '.'));\r\n }\r\n return sum;\r\n }",
"public List<Meta> obtTotalVentaXLineaProductos(Integer numPeri, Integer idPers) throws SQLException, Exception{\n \n CallableStatement statement = null;\n ResultSet rsConsulta = null;\n Connection cnConexion = null;\n List<Meta> lstResult = new ArrayList<>();\n \n try {\n \n cnConexion = ConexionBD.obtConexion();\n String strFiltro = \"\";\n \n if(idPers > 0 ){\n strFiltro += \" AND S1.ID_PERS = \" + idPers;\n }\n \n String sql = \"SELECT \" +\n \" S1.ID_PERS\\n\" +\n \" ,USU.COD_USUARIO\\n\" +\n \" ,CASE WHEN V2.COD_STIPOPROD = 'VI_SICVINILCORTE' THEN 'VI_SICVINILCORTE' ELSE 'VI_SICPAPELTAPIZ' END AS COD_STIPOPROD\\n\" +\n \" ,CASE WHEN V2.COD_STIPOPROD = 'VI_SICVINILCORTE' THEN 'VINIL CORTE' ELSE 'PAPEL TAPIZ' END AS DES_STIPOPROD\\n\" +\n \" ,SUM((T1.NUM_VALOR * T1.NUM_CANTIDAD) - (NVL(T1.NUM_MTODSCTO,0) * T1.NUM_CANTIDAD)) AS NUM_TOTALVENTA \\n\" +\n \" FROM SIC3DOCUPROD T1\\n\" +\n \" JOIN SIC1DOCU S1 ON T1.ID_DOCU = S1.ID_DOCU \\n\" +\n \" JOIN SIC1PROD T3 ON T3.ID_PROD = T1.ID_PROD \\n\" +\n \" JOIN VI_SICSTIPOPROD V2 ON V2.ID_STIPOPROD = T3.ID_STIPOPROD\\n\" +\n \" JOIN SIC1STIPODOCU T6 ON T6.ID_STIPODOCU = S1.ID_STIPODOCU\\n\" +\n \" JOIN SIC3DOCUESTA RELESTA ON RELESTA.ID_DOCU = S1.ID_DOCU\\n\" +\n \" AND TO_CHAR(RELESTA.FEC_HASTA,'DD/MM/YYYY') = '31/12/2400' \\n\" +\n \" JOIN VI_SICESTA ESTA ON ESTA.ID_ESTA = RELESTA.ID_ESTADOCU\\n\" +\n \" AND ((ESTA.COD_ESTA = 'VI_SICESTAFINALIZADO' AND T6.COD_STIPODOCU IN ('VI_SICFACTURA','VI_SICBOLETA','VI_SICSINDOCU')))\\n\" +\n \" JOIN SIC1USUARIO USU ON USU.ID_USUARIO = S1.ID_PERS\\n\" +\n \" WHERE S1.ID_SCLASEEVEN = 2 \" + \n \" AND TO_NUMBER(TO_CHAR(S1.FEC_DESDE,'YYYYMM')) = \" + numPeri + strFiltro +\n \" GROUP BY CASE WHEN COD_STIPOPROD = 'VI_SICVINILCORTE' THEN 'VI_SICVINILCORTE' ELSE 'VI_SICPAPELTAPIZ' END \" +\n \" ,CASE WHEN V2.COD_STIPOPROD = 'VI_SICVINILCORTE' THEN 'VINIL CORTE' ELSE 'PAPEL TAPIZ' END \" +\n \" ,USU.COD_USUARIO \" +\n \" ,S1.ID_PERS\";\n \n \n \n statement = cnConexion.prepareCall( sql,\n ResultSet.TYPE_SCROLL_SENSITIVE,\n ResultSet.CONCUR_READ_ONLY,\n ResultSet.CLOSE_CURSORS_AT_COMMIT ); \n \n rsConsulta = statement.executeQuery(); \n \n while(rsConsulta.next()){\n\n Meta obj = new Meta();\n \n String codStipoprod = rsConsulta.getString(\"COD_STIPOPROD\");\n BigDecimal numTotalVentasMes = rsConsulta.getBigDecimal(\"NUM_TOTALVENTA\");\n \n BigDecimal numPorcAlcanzado;\n if(codStipoprod.equals(\"VI_SICVINILCORTE\")){\n obj.setDesMeta(\"% Logrado Meta(Vinil)\");\n numPorcAlcanzado = new BigDecimal((numTotalVentasMes.doubleValue()/Constantes.CONS_METAMESTOTALVENTAVINIL) * 100).setScale(2,BigDecimal.ROUND_HALF_UP);\n obj.setNumTotalventameta(new BigDecimal(Constantes.CONS_METAMESTOTALVENTAVINIL));\n }\n else{\n obj.setDesMeta(\"% Logrado Meta(Papel)\");\n numPorcAlcanzado = new BigDecimal((numTotalVentasMes.doubleValue()/Constantes.CONS_METAMESTOTALVENTAPAPEL) * 100).setScale(2,BigDecimal.ROUND_HALF_UP);\n obj.setNumTotalventameta(new BigDecimal(Constantes.CONS_METAMESTOTALVENTAPAPEL));\n }\n \n Sic1pers objPers = new Sic1pers();\n objPers.setIdPers(rsConsulta.getBigDecimal(\"ID_PERS\"));\n objPers.setDesPers(rsConsulta.getString(\"COD_USUARIO\"));\n \n obj.setCodStipoprod(codStipoprod);\n obj.setDesStipoprod(rsConsulta.getString(\"DES_STIPOPROD\"));\n obj.setNumTotalventalogrado(numTotalVentasMes);\n obj.setNumPorclogrado(numPorcAlcanzado);\n obj.setSic1pers(objPers);\n \n lstResult.add(obj); \n }\n }catch(Exception ex){\n throw new Exception(ex.getMessage());\n }finally{\n if(statement != null)\n statement.close();\n if(rsConsulta != null)\n rsConsulta.close();\n if(cnConexion != null)\n cnConexion.close();\n }\n \n return lstResult;\n }",
"@Test\n public void complex_subQuery() {\n NumberPath<BigDecimal> sal = Expressions.numberPath(BigDecimal.class, \"sal\");\n // alias for the subquery\n PathBuilder<BigDecimal> sq = new PathBuilder<BigDecimal>(BigDecimal.class, \"sq\");\n // query execution\n query().from(query().from(Constants.employee).select(Constants.employee.salary.add(Constants.employee.salary).add(Constants.employee.salary).as(sal)).as(sq)).select(sq.get(sal).avg(), sq.get(sal).min(), sq.get(sal).max()).fetch();\n }",
"String toSql();",
"public static Double getSal(String rfc) {\n\t\tDouble result = 0.0;\n\t\ttry\n\t\t{\n\t\t\tstmt = conn.createStatement();\n\t\t\tquery = \"SELECT SALARY \" + \"FROM CREDIT.CUSTOMER \" + \"WHERE RFC='\" + rfc + \"'\";\n\t\t\trs = stmt.executeQuery(query);\n\t\t\t\n\t\t\twhile (rs.next())\n\t\t\t{\n\t\t\t\tresult = Double.parseDouble(rs.getString(1));\n\t\t\t}\n\t\t\tSystem.out.println(getMethodName(1) + \"\\t\" + result);\n\t\t\t\n\t\t} catch (SQLException e)\n\t\t{\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn result;\n\t}",
"public List<ReporteRetencionesResumido> getRetencionSRIResumido(int mes, int anio, int idOrganizacion)\r\n/* 27: */ {\r\n/* 28: 58 */ String sql = \"SELECT new ReporteRetencionesResumido(f.fechaEmisionRetencion,f.fechaRegistro,f.fechaEmision, CONCAT(f.establecimiento,'-',f.puntoEmision,'-',f.numero),\\tf.identificacionProveedor,c.descripcion,CASE WHEN c.tipoConceptoRetencion = :tipoConceptoFUENTE then (SUM(COALESCE(dfp.baseImponibleRetencion, 0)+COALESCE(dfp.baseImponibleTarifaCero, 0) +COALESCE(dfp.baseImponibleDiferenteCero, 0)+COALESCE(dfp.baseImponibleNoObjetoIva, 0))) else COALESCE(dfp.baseImponibleRetencion, 0) end,dfp.porcentajeRetencion,dfp.valorRetencion,\\tc.codigo,CASE WHEN c.tipoConceptoRetencion = :tipoConceptoIVA then 'IVA' WHEN c.tipoConceptoRetencion = :tipoConceptoFUENTE then 'FUENTE' WHEN c.tipoConceptoRetencion = :tipoConceptoISD then 'ISD' else '' end,f.numeroRetencion) FROM DetalleFacturaProveedorSRI dfp INNER JOIN dfp.facturaProveedorSRI f INNER JOIN dfp.conceptoRetencionSRI c WHERE MONTH(f.fechaRegistro) =:mes\\tAND YEAR(f.fechaRegistro) =:anio AND f.estado!=:estadoAnulado AND f.indicadorSaldoInicial!=true AND f.idOrganizacion = :idOrganizacion\\tGROUP BY c.codigo,f.numero,f.puntoEmision,\\tf.establecimiento, f.identificacionProveedor,\\tc.descripcion,dfp.baseImponibleRetencion,dfp.porcentajeRetencion,dfp.valorRetencion,f.fechaEmisionRetencion,f.fechaRegistro,f.fechaEmision,f.numeroRetencion, c.tipoConceptoRetencion ORDER BY c.tipoConceptoRetencion, c.codigo \";\r\n/* 29: */ \r\n/* 30: */ \r\n/* 31: */ \r\n/* 32: */ \r\n/* 33: */ \r\n/* 34: */ \r\n/* 35: */ \r\n/* 36: */ \r\n/* 37: */ \r\n/* 38: */ \r\n/* 39: */ \r\n/* 40: */ \r\n/* 41: */ \r\n/* 42: */ \r\n/* 43: */ \r\n/* 44: */ \r\n/* 45: 75 */ Query query = this.em.createQuery(sql);\r\n/* 46: 76 */ query.setParameter(\"mes\", Integer.valueOf(mes));\r\n/* 47: 77 */ query.setParameter(\"anio\", Integer.valueOf(anio));\r\n/* 48: 78 */ query.setParameter(\"estadoAnulado\", Estado.ANULADO);\r\n/* 49: 79 */ query.setParameter(\"idOrganizacion\", Integer.valueOf(idOrganizacion));\r\n/* 50: 80 */ query.setParameter(\"tipoConceptoIVA\", TipoConceptoRetencion.IVA);\r\n/* 51: 81 */ query.setParameter(\"tipoConceptoFUENTE\", TipoConceptoRetencion.FUENTE);\r\n/* 52: 82 */ query.setParameter(\"tipoConceptoISD\", TipoConceptoRetencion.ISD);\r\n/* 53: 83 */ List<ReporteRetencionesResumido> lista = query.getResultList();\r\n/* 54: */ \r\n/* 55: 85 */ return lista;\r\n/* 56: */ }",
"@Override\n\tpublic List<Basesalary> listSum(String basesalarycate) {\n\t\treturn findByHql(\"select basesalarysum from basesalary where basesalarycate='\"+basesalarycate+\"'\");\n\t}",
"private int sum(AFormula o1){\n\t\t\t\t\n\t\t\t\treturn o1.calculate(customerType, weekdayCount, weekendCount);\n\t\t\t\t\n\t\t\t}",
"float getCTR() throws SQLException;",
"public Double getSummaryOf(List<String> listGroupsBy, String colname, int st) {\n\t\tif (cursorNo < 0 || rows.size() <= 0) {\n\t\t\treturn Double.valueOf(0);\n\t\t}\n\t\tif (st == SUMMARY_SUM) {\n\t\t\tdouble vl = 0;\n\t\t\tMap<String, Object> mp = new HashMap<String, Object>();\n\n\t\t\tsetgroupByRows(listGroupsBy, mp, cursorNo);\n\t\t\tif (getFieldValue(cursorNo, colname) != null) {\n\t\t\t\tvl = vl + ((Number) getFieldValue(cursorNo, colname)).doubleValue();\n\t\t\t}\n\n\t\t\tfor (int i = cursorNo - 1; i >= 0; i--) {\n\t\t\t\tif (isOldRowDiff(listGroupsBy, mp, i)) {\n\t\t\t\t\treturn vl;\n\t\t\t\t} else {\n\t\t\t\t\tif (getFieldValue(i, colname) != null) {\n\t\t\t\t\t\tvl = vl + ((Number) getFieldValue(i, colname)).doubleValue();\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t\treturn vl;\n\t\t}\n\t\treturn Double.valueOf(0);\n\t}",
"BigDecimal getSumaryTechoCveFuente(BudgetKeyEntity budgetKeyEntity);",
"@Override\n\tpublic double totalPresentase(UUID idPemb) {\n\t\tQuery query = sessionFactory.getCurrentSession().createQuery(\"SELECT sum(k.persentase_komponen) as res \"\n\t\t\t\t+ \"FROM komponen_nilai k WHERE id_pemb='\" + idPemb + \"'\");\n\t\tList<Object[]> results = (List<Object[]>)query.list();\n\t\tfor (Object[] result : results) {\n\t\t\tdouble res = (Double) result[0];\n\t\t\tSystem.out.println(res);\n\t\t}\n\t\treturn 0;\n\t}",
"public int getSoupKitchenCount() {\n\n MapSqlParameterSource params = new MapSqlParameterSource();\n //here we want to get total from food pantry table\n String sql = \"SELECT COUNT(*) FROM cs6400_sp17_team073.Soup_kitchen\";\n\n Integer skcount = jdbc.queryForObject(sql,params,Integer.class);\n\n return skcount;\n }",
"public int getHiveReportCount(String sql) throws RaptorException {\n\t\t//select t from (select count(*) t from (select * from program)x)x1;\n\t\tint count = 0;\n String countSql = \"select t from (select count(*) t from (\"+ sql + \")\" + (Globals.isPostgreSQL() || Globals.isMySQL() ?\" AS \":\"\") + \" x) AS x1\";\n\n DataSet ds = null;\n\t\t// try {\n\t\tString dbInfo = getDBInfo();\n\t\tSystem.out.println(\"SQL getReportCount()- \" + countSql);\n\t\ttry { \n\t\t\tds = ConnectionUtils.getDataSet(countSql, dbInfo);\n\t\t\tint totalRows = 0;\n\t\t\tString dbType = \"\";\n\t\t\tif (!isNull(dbInfo) && (!dbInfo.equals(AppConstants.DB_LOCAL))) {\n\t\t\t\ttry {\n\t\t\t\t\torg.openecomp.portalsdk.analytics.util.RemDbInfo remDbInfo = new org.openecomp.portalsdk.analytics.util.RemDbInfo();\n\t\t\t\t\tdbType = remDbInfo.getDBType(dbInfo);\n\t\t\t\t} catch (Exception ex) {\n\t\t\t\t\tthrow new RaptorException(ex);\t\t \t\n\t\t\t\t}\n\t\t\t} \n\t\t\tif( ds.getRowCount()>0) {\n\t\t\t\tcount = Integer.parseInt(ds.getString(0,0));\n\t\t\t}\n\t\t} catch (NumberFormatException ex) {}\n\t\treturn count;\n\n\t}",
"@Query(value = \"SELECT IF(count(transaction_details.transferred_Amt)>0, \" +\n \"(select sum(transaction_details.transferred_Amt) \" +\n \"FROM transaction_details where transaction_details.sender_Acct_No=?1), 0) \\n\" +\n \"FROM transaction_details where transaction_details.sender_Acct_No=?1\", nativeQuery = true)\n double getTransferredAmtBySender(Integer senderAcctNo);",
"public int getremainingstock(String selection,String item) throws SQLException\n {\n // int stock_rate[]= new int [2];\n PreparedStatement remaining_stock = conn.prepareStatement(\"Select stock from purchases where Categroy=? and Item=? \");\n remaining_stock.setString(1, selection);\n remaining_stock.setString(2, item);\n ResultSet remaining_stock_rows = remaining_stock.executeQuery(); \n \n int sum=0,current=0;\n while(remaining_stock_rows.next()) \n {\n sum=Integer.parseInt(remaining_stock_rows.getString(1));\n \n \n }\n return sum;\n }",
"public void demo6() {\n\n\t\t\t\t\tConnection con = null;\n\t\t\t\t\ttry {\n\t\t\t\t\t\tcon = DriverManager.getConnection(\"jdbc:mysql://localhost:3306/test\",\"root\",\"root\");\n\n\t\t\t\t\t\tCallableStatement cs = con.prepareCall(\"{? = call totalEmps()}\");\n\n\t\t\t\t\t\t\n\t\t\t\t\t\tcs.registerOutParameter(1, Types.INTEGER);\n\t\t\t\t\t\t\n\t\t\t\t\t\tcs.execute();\n\t\t\t\t\t\tint res = cs.getInt(1);\n\t\t\t\t\t\tSystem.out.println(\"Total Products: \" + res);\n\n\t\t\t\t\t} catch (Exception e) {\n\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t} finally {\n\t\t\t\t\t\t//DbUtils.closeConnection();\n\t\t\t\t\t}\n\n\t\t\t\t}",
"public java.math.BigDecimal getSumm() {\n\treturn summ;\n}",
"public String getStatement() {\n\tStringBuilder statement = new StringBuilder(\"Statement for \" + name + \"\\n\"); \n double total = 0.0;\n for (Account account : accounts) {\n statement.append(\"\\n\" + statementForAccount(account) + \"\\n\");\n total += account.sumTransactions();\n }\n statement.append(\"\\nTotal In All Accounts \" + toDollars(total));\n return statement.toString();\n }",
"@Override\npublic JsonArray queryStatistics(String date, Employee em) throws Exception {\n\tint [] montharr= {31,28,31,30,31,30,31,31,30,31,30,31};\n\tSystem.out.println(date);\n\tint year;\n\tint month;\n\tif(date.length()==0){\n\t\tmonth = new Date().getMonth()+1;\n\t\tyear= new Date().getYear()+1900;\n\t}else{\n\t\tString[] s=date.split(\"-\");\n\t\tyear=Integer.parseInt(s[0]);\n\t\tmonth=Integer.parseInt(s[1]);\n\t}\n\t\n\t\n\tList<Map<String,Object>> lstMap = new LinkedList<Map<String,Object>>();\n\tfor (int i = 1; i <=montharr[month-1] ; i++) {\n\t\tStringBuffer buffer =new StringBuffer(\"select SUM(c.golds) from consumption c,machineinfo m where c.fmachineid=m.id and m.state!=-1 and c.type=-1 and m.empid=\")\n\t\t\t\t.append(em.getId()).append(\" and year(c.createtime) =\").append(year)\n\t\t\t\t.append(\" and month(c.createtime) =\").append(month).append(\" and day(c.createtime) =\").append(i);;\n\t\t\t\tSystem.out.println(buffer);\n\t\t\t\tMap<String,Object> map = new HashMap<String,Object>();\n\t\t\t\tList<Object> lst = databaseHelper.getResultListBySql(buffer.toString());\n\t\t\t\t\n\t\t\t\tmap.put(\"nums\", lst==null?\"0\":lst.size()==0?\"0\":lst.get(0)==null?\"0\":lst.get(0).toString());\n\t\t\t\tmap.put(\"time\", i+\"日\");\n\t\t\t\tmap.put(\"month\", month);\n\t\t\t\tlstMap.add(map);\n\t}\n\tString result = new Gson().toJson(lstMap);\n\tJsonArray jarr = (JsonArray) new JsonParser().parse(result);\n\treturn jarr;\n}",
"public static ResultSet estatistica() throws SQLException {\n\t\t\n\t\treturn objcon.createStatement().executeQuery(\"SELECT COUNT(*) TOT, MIN(PRECO) MENOR, MAX(PRECO) MAIOR, AVG(PRECO) MEDIA FROM TABPRODUTOS\");\n\t}",
"double getTotal();",
"@Override\n\tpublic Integer getTotalNum(String hql) {\n\t\treturn super.findTotleNum(hql);\n\t}",
"@Insert({\n \"insert into SALEORDERDETAIL (SOID, LINENO, \",\n \"MID, MNAME, STANDARD, \",\n \"UNITID, UNITNAME, \",\n \"NUM, BEFOREDISCOUNT, \",\n \"DISCOUNT, PRICE, \",\n \"TOTALPRICE, TAXRATE, \",\n \"TOTALTAX, TOTALMONEY, \",\n \"BEFOREOUT, ESTIMATEDATE, \",\n \"LEFTNUM, ISGIFT, \",\n \"FROMBILLTYPE, FROMBILLID)\",\n \"values (#{soid,jdbcType=VARCHAR}, #{lineno,jdbcType=DECIMAL}, \",\n \"#{mid,jdbcType=VARCHAR}, #{mname,jdbcType=VARCHAR}, #{standard,jdbcType=VARCHAR}, \",\n \"#{unitid,jdbcType=VARCHAR}, #{unitname,jdbcType=VARCHAR}, \",\n \"#{num,jdbcType=DECIMAL}, #{beforediscount,jdbcType=DECIMAL}, \",\n \"#{discount,jdbcType=DECIMAL}, #{price,jdbcType=DECIMAL}, \",\n \"#{totalprice,jdbcType=DECIMAL}, #{taxrate,jdbcType=DECIMAL}, \",\n \"#{totaltax,jdbcType=DECIMAL}, #{totalmoney,jdbcType=DECIMAL}, \",\n \"#{beforeout,jdbcType=DECIMAL}, #{estimatedate,jdbcType=TIMESTAMP}, \",\n \"#{leftnum,jdbcType=DECIMAL}, #{isgift,jdbcType=DECIMAL}, \",\n \"#{frombilltype,jdbcType=DECIMAL}, #{frombillid,jdbcType=VARCHAR})\"\n })\n int insert(Saleorderdetail record);",
"public String EjecutarSql() {\n String rta = \"\";\n try {\n Statement stmt = dbConecta.createStatement();\n rta += stmt.executeUpdate(CadenaSql);\n dbConecta.close();\n\n } catch (SQLException ex) {\n rta = ex.getMessage();\n }\n return rta;\n }",
"public void ProductsTotal(DefaultTableModel tableModel){\n connect();\n ResultSet result = null;\n tableModel.setRowCount(0);\n tableModel.setColumnCount(0);\n String sql = \"SELECT id_producto as Id, descripcion, presentacion, cantidad, precio, subtotal, proveedor \"\n + \"FROM productos ORDER BY descripcion\";\n \n try{\n PreparedStatement ps = connect.prepareStatement(sql);\n result = ps.executeQuery();\n if(result != null){\n int columnNumber = result.getMetaData().getColumnCount();\n for(int i = 1; i < columnNumber; i++){\n tableModel.addColumn(result.getMetaData().getColumnName(i));\n }\n while(result.next()){\n Object []obj = new Object[columnNumber];\n for(int i = 1; i < columnNumber; i++){\n obj[i-1] = result.getObject(i);\n }\n tableModel.addRow(obj);\n }\n }\n connect.close();\n }catch(SQLException ex){\n ex.printStackTrace();\n }\n }",
"public Quantity<Q> getSum(Unit<Q> unit) {\n return sum.to(unit);\n }",
"public ResultSet getAmountByLocation() throws SQLException {\r\n String statement = \"SELECT Location, COUNT(Location) AS Amount FROM appointments GROUP BY Location\";\r\n return conn.prepareStatement(statement).executeQuery();\r\n }",
"Integer calculate(String columnValue);",
"public static int getNrOrSum(boolean number, boolean plz5) throws SQLException, ClassNotFoundException{\n\t\tStatement stmt = getConnection();\n\t\tStringBuffer sb = new StringBuffer();\n\tif (plz5){\n\t\tif (number)\n\t\t\t{ sb.append(\"SELECT COUNT (id) FROM criteriasplz51\");}\n\t\telse\n\t\t\t{ sb.append(\"SELECT SUM(CAST(_c1 AS int)) FROM criteriasplz51\");}\n\t\t}\n\telse{\n\t\tif (number)\n\t\t{ sb.append(\"SELECT COUNT (id) FROM criteriasplz81\");}\n\telse\n\t\t{ sb.append(\"SELECT SUM(CAST(_c1 AS int)) FROM criteriasplz81\");}\n\t}\n\t\t\n\t\n\t\tResultSet t=stmt.executeQuery(sb.toString());\n\t\tt.next();\n\t\tint sum=t.getInt(1);\n\t\tif (number)\n\t\t\t{System.out.println(\"numberofpolygons: \"+sum);}\n\t\telse\n\t\t\t{System.out.println(\"sum: \"+sum);}\n\n\t\treturn sum;\n\t}",
"public int total(){\n int rows = 0;\n \n try {\n rs = stmt.executeQuery \n (\"SELECT * FROM JEREMY.TICKET\");\n while (rs.next()) {rows++;}\n System.out.println(\"There are \"+ rows + \" record in the table\"); \n \n } catch (Exception e) {}\n \n return rows;\n }",
"public String displaySum()\n {\n return null;\n }",
"@Override\n\tpublic Double getSumofCost(String supplyStartDate, String supplyLastDate) {\n\t\tString sql=\"SELECT SUM(h.cost) FROM supplier s INNER JOIN supplier_product h on s.supplier_id=h.supplier_supplier_id WHERE buy_date>=?::Date and buy_date<=?::Date\";\n\t\tDouble total=this.getJdbcTemplate().queryForObject(sql, Double.class, supplyStartDate, supplyLastDate);\n\t\treturn total;\n\t}",
"DataSet sql(HiveContext context, String sql);",
"ZonalStatistic getZonalStatistic(int id) throws SQLException;",
"public Vector listaAsignaturasTotal(String nombre_titulacion)\n {\n try\n { \n //Se obtiene una conexion\n Connection conexion = this.bbdd.getConexion();\n\n //Se prepara la query\n String query = \"SELECT * FROM asignaturatotal \";\n query += \"WHERE tit_nombre='\"+nombre_titulacion+\"' AND activa = 's'\";\n\n //Se crea un vector de asignaturas\n Vector vectorAsignaturas = new Vector();\n\n //Se ejecuta la query\n Statement st = conexion.createStatement();\n ResultSet resultado = st.executeQuery(query);\n\n //Para cada fila se creará un objeto y se rellenará\n //con los valores de las columnas.\n while(resultado.next())\n {\n asignatura asignatura = new asignatura();\n\n asignatura.setCodigo(resultado.getString(\"codigo\"));\n asignatura.setTitulo(resultado.getString(\"titulo\"));\n asignatura.setFechaInicio(resultado.getDate(\"fechainicio\"));\n asignatura.setFechaFin(resultado.getDate(\"fechafin\"));\n asignatura.setResponsable(resultado.getString(\"responsable\"));\n asignatura.setEmail(resultado.getString(\"email\"));\n asignatura.setTelefono(resultado.getString(\"telefono\"));\n\n //Se añade la asignatura al vector de asignaturas\n vectorAsignaturas.add(asignatura);\n }\n\n //Se cierra la conexión\n this.bbdd.cerrarConexion(conexion);\n\n return vectorAsignaturas;\n }\n catch(SQLException e)\n {\n System.out.println(\"Error al acceder a las asignaturas de la Base de Datos: \"+e.getMessage());\n return null;\n }\n }",
"public void makeSql() {\n\t\tfor(int i=0; i<arr_sql.length; i++) {\n\t\t\tarr_sql[i] = new StringBuffer();\n\t\t}\n\t\t\n\t\t/*\n\t\t * 공통코드 쿼리\n\t\t * 대리점구분 : CU006\n\t\t * 직판구분 : CU012\n\t\t * 지역 : SY006\n\t\t * 계약상태 : CU013\n\t\t * 사용유무 : SY011\n\t\t * 보증보험회사 : CU010\n\t\t * 하위대리점여부 : CU011\n\t\t */\n\t\tarr_sql[0].append (\"SELECT\t\t\t\t\t\t\t\t\t\t\\n\")\n\t\t\t\t .append (\"\t' ' head, ' ' detail, '전체' detail_nm \\n\")\n\t\t\t\t .append (\"FROM DUAL \\n\")\n\t\t\t\t .append (\"UNION ALL \\n\")\n\t\t\t\t .append (\"SELECT \\n\")\n\t\t\t\t .append (\"\tB.head, B.detail, B.detail_nm \\n\")\n\t\t\t\t .append (\"FROM \\n\")\n\t\t\t\t .append (\"\tSALES.TSY011 A, \\n\")\n\t\t\t\t .append (\"\tSALES.TSY010 B \\n\")\n\t\t\t\t .append (\"WHERE 1=1 \\n\")\n\t\t\t\t .append (\" AND A.head = B.head \\n\")\n\t\t\t\t .append (\" AND B.head = ? \\n\")\n\t\t\t\t .append (\" AND LENGTH (rtrim(B.detail)) > 0 \\n\");\n\t\t\n\t\t/*\n\t\t * 대리점 조회\n\t\t */\n\t\tarr_sql[1].append(\"SELECT T1.client_sid\t\t\t \t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 매출처SID \t*/\n\t \t\t .append(\"\t\t ,T1.vend_cd \t\t\t\t\t\t\t\t\t\t\t\t \t\t\t\t\\n\")\t/* [회계]거래처 코드 \t*/\n\t \t\t .append(\"\t\t ,T1.client_cd \t\t\t\t\t\t\t\t\t\t\t\t \t\t\t\t\\n\")\t/* 매출처 코드 \t*/\n\t \t\t .append(\"\t\t ,T1.client_nm \t\t\t\t\t\t\t\t\t\t\t\t \t\t\t\t\\n\")\t/* 매출처 명 \t*/\n\t \t\t .append(\"\t\t ,T1.client_gu \t\t\t\t\t\t\t\t\t\t\t\t \t\t\t\t\\n\")\t/* 매출처구분 :CU005 \t*/\n\t \t\t \n\t \t\t .append(\"\t\t ,T1.agen_gu \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 대리점구분 :CU006 \t*/\n\t \t\t .append(\"\t\t ,T1.dir_yn \t\t\t\t\t\t\t\t\t\t\t\t \t\t\t\t\\n\")\t/* 직판여부 :CU012 \t*/\n\t \t\t .append(\"\t\t ,T1.area_cd \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 지역코드 :SY006 \t*/\n\t \t\t .append(\"\t\t ,T1.sal_dam_sid \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 영업담당자코드[TSY410] */\n\t \t\t .append(\"\t\t ,T1.client_dam_nm \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 매출처담당자 \t*/\n\t \t\t \n\t \t\t .append(\"\t\t ,T1.tel_no \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 전화번호 \t*/\n\t \t\t .append(\"\t\t ,T1.mobile_no \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 휴대전화 \t*/\n\t \t\t .append(\"\t\t ,T1.fax_no \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* FAX번호 \t*/\n\t \t\t .append(\"\t\t ,T1.e_mail \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 이메일 \t*/\n\t \t\t .append(\"\t\t ,T1.zip_cd \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 우편번호[TSY110] */\n\t \t\t \n\t \t\t .append(\"\t\t ,T1.address1 \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 주소1 \t*/\n\t \t\t .append(\"\t\t ,T1.address2 \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 주소2 \t*/\n\t \t\t .append(\"\t\t ,T1.commi_rate \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 수수료율 \t*/\n\t \t\t .append(\"\t\t ,T1.cunt_status \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 계약상태 :CU013 \t*/\n\t \t\t .append(\"\t\t ,T1.bancod \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 은행코드 [BANKCODE] */\n\t \t\t \n\t \t\t .append(\"\t\t ,T1.bank_acc_no \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 은행계좌번호 \t*/\n\t \t\t .append(\"\t\t ,T1.bank_acct_nm \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 예금주 \t*/\n\t \t\t .append(\"\t\t ,T1.use_yn \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 사용여부 :SY011 \t*/ \n\t \t\t .append(\"\t\t ,T1.client_url\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 홈페이지 URL\t\t\t\t*/\n\t \t\t .append(\"\t\t ,T2.sal_dam_nm \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 영업담당자명 \t*/\n\t \t\t .append(\"\t\t ,T3.vend_nm \t\t\t\t\t\t\t\t\t\t\t\t \t\t\t\t\\n\")\t/* 거래처명 \t*/\n\t \t\t \n\t \t\t .append(\"\t\t ,T4.bannam \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 은행명 \t*/\n\t \t\t .append(\"\t\t ,SALES.FN_DETAIL_NM ( 'CU006',T1.agen_gu) AS agen_gu_name \t\t\t\t\t\\n\")\t/* 대리점구분명 \t\t\t\t*/ \n\t \t\t .append(\"\t\t ,SALES.FN_DETAIL_NM ( 'CU012',T1.dir_yn) AS dir_yn_name \t\t\t\t\t\\n\")\t/* 직판여부명 \t\t\t\t*/ \n\t \t\t .append(\"\t\t ,SALES.FN_DETAIL_NM ( 'SY006',T1.area_cd) AS area_nm\t\t\t\t\t\t\t\\n\")\t/* 지역명 \t\t\t\t*/\n\t \t\t .append(\"\t\t ,SALES.FN_DETAIL_NM ( 'CU013',T1.cunt_status) AS cunt_status_name \t\t\t\\n\")\t/* 계약상태명 \t\t\t\t*/\n\n\t \t\t .append(\"\t\t ,SALES.FN_DETAIL_NM ( 'SY011',T1.use_yn) AS use_yn_name \t\t\t\\n\")\t/* 사용여부명 \t\t\t \t*/\n\n\t \t\t .append(\"FROM SALES.TCU030 T1 LEFT OUTER JOIN SALES.TSY410 T2 ON T1.SAL_DAM_SID = T2.SAL_DAM_SID \\n\")\n\t \t\t .append(\"\t\t LEFT OUTER JOIN ACCOUNT.GCZM_VENDER T3 ON T1.VEND_CD = T3.VEND_CD \t\t\t\t\t\\n\")\n\t \t\t .append(\"\t\t LEFT OUTER JOIN ACCOUNT.BANKCODE T4 ON T1.BANCOD = T4.BANCOD \t\t\t\t\t\\n\")\n\t \t\t .append(\"WHERE 1 = 1 \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\n\t \t\t .append(\"\t\t AND T1.client_GU = '1' \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\");\n\t\t/*\n\t\t * 계약정보 조회\n\t\t */\n\t\tarr_sql[2].append(\"SELECT T1.client_sid\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 매출처SID \t*/\n\t\t\t\t .append(\"\t\t ,T1.cont_date\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\") \t/* 계약일자 \t*/\n\t\t\t\t .append(\"\t\t ,T1.expire_date\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 만기일자 \t*/\n\t\t\t\t .append(\"\t\t ,TO_NUMBER(T1.insur_amt) AS insur_amt\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 보험료 \t*/\n\t\t\t\t .append(\"\t\t ,T1.insur_comp_cd\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 보증보험회사:CU010 \t*/\n\t\t\t\t .append(\"\t\t ,SALES.FN_DETAIL_NM ('CU010',T1.insur_comp_cd) AS insur_comp_cd_name\t\t\\n\") \t/* 보증보험회사명 \t\t*/ \n\t\t\t\t .append(\"FROM SALES.TCU031 T1 \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\n\t\t\t\t .append(\"WHERE 1=1\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\");\n\t\t \n\t\n\t\t/*\n\t\t * 지점정보 조회\n\t\t */\n\t\tarr_sql[3].append(\"SELECT T1.client_sid\t\t\t\t\t\t\t\t\t\t\t\t\\n\") \t/* 매출처SID \t\t*/\n\t\t\t\t .append(\"\t\t ,T1.branch_cd\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 지점코드 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,T1.branch_nm \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\") \t/* 지점명 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,T1.area_cd\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\") \t/* 지역코드:SY006 \t\t*/\n\t\t\t\t .append(\"\t\t ,T1.client_down_yn \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 하위대리점여부:CU011 \t*/\n\t\t\t\t .append(\"\t\t ,T1.empno \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 담당자 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,T1.tel_no \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 전화번호 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,T1.mobile_no \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 휴대폰 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,T1.fax_no \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 팩스번호 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,T1.branch_url \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\")\t/* 지점홈페이지 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,SALES.FN_DETAIL_NM ( 'SY006', T1.area_cd) AS area_nm\t\t\t\t\t\t\t\\n\") \t/* 지역명:SY006 \t\t*/\n\t\t\t\t .append(\"\t\t ,SALES.FN_DETAIL_NM ( 'CU011',T1.client_down_yn) AS client_down_yn_name \t\\n\")\t/* 하위대리점여부명 \t\t*/\n\t\t\t\t .append(\"FROM SALES.TCU032 T1\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\\n\");\n\t\t\n\t\t\n\t\t/*\n\t\t * 대리점 등록\n\t\t */\n\n\t\tarr_sql[4].append(\"INSERT INTO SALES.TCU030 (\")\n\t\t\t\t .append(\"\t\t\t\t client_sid \\n\")\t\n\t\t\t\t .append(\"\t\t\t\t,vend_cd \\n\")\t/* [회계]거래처 코드 \t*/\n\t\t\t\t .append(\"\t\t\t\t,client_cd \\n\")\t/* 매출처 코드 \t*/\n\t\t\t\t .append(\"\t\t\t\t,client_nm \\n\")\t/* 매출처 명 \t*/\n\t\t\t\t .append(\"\t\t\t\t,client_gu \\n\")\t/* 매출처구분 :CU005 \t*/\n\t\t\t\t .append(\"\t\t\t\t,agen_gu \\n\")\t/* 대리점구분 :CU006 \t*/\n\t\t\t\t \n\t\t\t\t .append(\"\t\t\t\t,dir_yn \\n\")\t/* 직판여부 :CU012 \t*/\n\t\t\t\t .append(\"\t\t\t\t,area_cd \\n\")\t/* 지역코드 :SY006 \t*/\n\t\t\t\t .append(\"\t\t\t\t,sal_dam_sid \\n\")\t/* 영업담당자코드[TSY410] \t*/\n\t\t\t\t .append(\"\t\t\t\t,client_dam_nm \\n\")\t/* 매출처담당자 \t*/\n\t\t\t\t .append(\"\t\t\t\t,tel_no \\n\")\t/* 전화번호 \t*/\n\t\t\t\t \n\t\t\t\t .append(\"\t\t\t\t,mobile_no \\n\")\t/* 핸드폰 \t*/\n\t\t\t\t .append(\"\t\t\t\t,fax_no \\n\")\t/* FAX번호 \t*/\n\t\t\t\t .append(\"\t\t\t\t,e_mail \\n\")\t/* 이메일 \t*/\n\t\t\t\t .append(\"\t\t\t\t,zip_cd \\n\")\t/* 소재지우편번호[TSY110] */\n\t\t\t\t .append(\"\t\t\t\t,address1 \\n\")\t/* 소재지주소1 \t*/\n\t\t\t\t \n\t\t\t\t .append(\"\t\t\t\t,address2 \\n\")\t/* 소재지주소2 \t*/\n\t\t\t\t .append(\"\t\t\t\t,commi_rate \t\\n\") \t/* 수수료율 \t*/\n\t\t\t\t .append(\"\t\t\t\t,cunt_status \\n\")\t/* 계약상태 :CU013 \t*/\n\t\t\t\t .append(\"\t\t\t\t,bancod\t\t\t\\n\") \t/* 은행코드 \t\t\t\t\t*/\n\t\t\t\t .append(\"\t\t\t\t,bank_acc_no \\n\")\t/* 은행계좌번호[BANKCODE] \t*/\n\t\t\t\t \n\t\t\t\t .append(\"\t\t\t\t,bank_acct_nm\t\\n\")\t/* 예금주 \t\t\t\t\t*/\n\t\t\t\t .append(\"\t\t\t\t,use_yn\t\t\t\\n\")\t/* 사용여부 \t\t\t\t\t*/\n\t\t\t\t\n\t\t\t\t .append(\"\t\t \t\t,u_date \t\\n\") \t/* 최종수정일자 \t*/\n\t \t\t .append(\"\t\t \t\t,u_empno \t\\n\")\t/* 최종수정자사번 \t*/\n\t \t\t .append(\"\t\t \t\t,u_ip \\n\")\t/* 최종수정IP */\t\t\t\n\t \t\t .append(\"\t\t\t\t,client_url\t\t\\n\")\t/* 홈페이지 */\n\t\t\t\t .append(\"\t\t\t)\t\t\t\t\t\\n\")\n\t\t\t\t \n\t\t\t\t .append(\"VALUES\t\t\t\t\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t(\t \t\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t\tSALES.SWS_TCU030_ID.NEXTVAL,?,?,?,?,?,\t\t\\n\")\t\n\t\t\t\t .append(\"\t\t\t\t?,?,?,?,?,\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t\t?,?,?,?,?,\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t\t?,?,?,?,?,\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t\t?,?,SYSTIMESTAMP,?,?,?\t\\n\")\n\t\t\t\t .append(\"\t\t\t)\");\n\t\t\n\t\n\t\t\n\t\t/*\n\t\t * 계약정보 등록\n\t\t */\n\t\tarr_sql[5].append(\"INSERT INTO SALES.TCU031 ( \t\\n\")\n\t\t\t\t .append(\" \t client_SID\t\t\t\\n\")\t/* 매출처SID \t*/\n\t\t\t\t .append(\"\t\t ,cont_date\t\t\t\t\\n\") \t/* 계약일자 \t*/\n\t\t\t\t .append(\"\t\t ,expire_date\t\t\t\\n\")\t/* 만기일자 \t*/\n\t\t\t\t .append(\"\t\t ,insur_amt\t\t\t\t\\n\")\t/* 보험료 \t*/\n\t\t\t\t .append(\"\t\t ,insur_comp_cd\t\t\t\\n\")\t/* 보증보험회사:CU010 \t*/\n\t\t\t\t \n\t\t\t\t .append(\"\t\t ,u_date\t\t\t\t\\n\")\t/* 최종수정일자 \t*/\n\t\t\t\t .append(\"\t\t ,u_empno \t\t\t\t\\n\") \t/* 최종수정자사번 \t*/\n\t\t\t\t .append(\"\t\t ,u_ip\t\t\t\t\t\\n\")\t/* 최종수정IP \t*/\n\t\t\t\t .append(\"\t\t)\t\t\t\t\t\t\\n\")\n\t\t\t\t \n\t\t\t\t .append(\"VALUES\t\t\t\t\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t(\t \t\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t\t?,?,?,?,?,\t\t\\n\")\t\n\t\t\t\t .append(\"\t\t\t\tSYSTIMESTAMP,?,?\t\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t)\");\n\t\t\t\t\t\n\t\t/*\n\t\t * 지점정보 등록\n\t\t */\n\t\t\n\t\tarr_sql[6].append(\"INSERT INTO SALES.TCU032 ( \t\\n\")\n\t\t\t\t .append(\"\t\t client_SID\t\t\t\\n\") \t/* 매출처SID \t\t*/\n\t\t\t\t .append(\"\t\t ,branch_cd\t\t\t\t\\n\")\t/* 지점코드 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,branch_nm \t\t\t\\n\") \t/* 지점명 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,area_cd\t\t\t\t\\n\") \t/* 지역코드:SY006 \t\t*/\n\t\t\t\t .append(\"\t\t ,client_down_yn \t\t\\n\")\t/* 하위대리점여부:CU011 \t*/\n\t\t\t\t \n\t\t\t\t .append(\"\t\t ,empno \t\t\t\t\\n\")\t/* 담당자 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,tel_no \t\t\t\t\\n\")\t/* 전화번호 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,mobile_no \t\t\t\\n\")\t/* 휴대폰 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,fax_no \t\t\t\t\\n\")\t/* 팩스번호 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,branch_url \t\t\t\\n\")\t/* 지점홈페이지 \t\t\t*/\n\t\t\t\t \n\t\t\t\t .append(\"\t\t ,u_date \t\t\t\t\\n\")\t/* 최종수정일자 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,u_empno \t\t\t\t\\n\")\t/* 최종수정자사번 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,u_ip \t\t\t\t\\n\")\t/* 최종수정IP \t\t*/\n\t\t\t\t .append(\"\t)\t\t\t\t\t\t\\n\")\n\t\t\t\t .append(\"VALUES\t\t\t\t\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t(\t \t\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t\t?,?,?,?,?,\t\t\\n\")\t\n\t\t\t\t .append(\"\t\t\t\t?,?,?,?,?,\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t\tSYSTIMESTAMP,?,?\t\t\t\\n\")\n\t\t\t\t .append(\"\t\t\t)\");\n\t\t\n\t\t/*\n\t\t * 대리점 수정\n\t\t */\n\n\t\tarr_sql[7].append(\"UPDATE SALES.TCU030 SET \t\t\t\t\t\t\\n\")\n\t\t\t\t .append(\"\t\t vend_cd\t\t= ? \t\t\t\t\\n\")\t/* [회계]거래처 코드 \t*/\n\t\t\t\t .append(\"\t\t,client_nm\t\t= ? \t\t\t\t\\n\")\t/* 매출처 명 \t*/\n\t\t\t\t .append(\"\t\t,agen_gu\t\t= ? \t\t\t\t \t\\n\")\t/* 대리점구분 :CU006 \t*/\n\t\t\t\t .append(\"\t\t,dir_yn\t\t\t= ? \t\t\t\t\\n\")\t/* 직판여부 :CU012 \t*/\n\t\t\t\t .append(\"\t\t,area_cd \t= ? \t\t\t\t\t\\n\")\t/* 지역코드 :SY006 \t*/\n\n\t\t\t\t .append(\"\t\t,sal_dam_sid\t= ? \t\t\t\t\t\\n\")\t/* 영업담당자코드[TSY410] */\n\t\t\t\t .append(\"\t\t,client_dam_nm\t= ? \t\t\t\t\t\\n\")\t/* 매출처담당자 \t*/\n\t\t\t\t .append(\"\t\t,tel_no = ?\t\t\t\t\t\t\\n\")\t/* 전화번호 \t*/\n\t\t\t\t .append(\"\t\t,mobile_no = ?\t\t\t\t\t\t\\n\")\t/* 핸드폰 \t*/\n\t\t\t\t .append(\"\t\t,fax_no = ?\t\t\t\t\t\t\\n\")\t/* FAX번호 \t*/\n\n\t\t\t\t .append(\"\t\t,e_mail = ?\t\t\t\t\t\t\\n\")\t/* 이메일 \t*/\n\t\t\t\t .append(\"\t\t,zip_cd = ?\t\t\t\t\t\t\\n\")\t/* 소재지우편번호[TSY110] \t*/\n\t\t\t\t .append(\"\t\t,address1 = ?\t\t\t\t\t\t\\n\")\t/* 소재지주소1 \t*/\n\t\t\t\t .append(\"\t\t,address2 = ?\t\t\t\t\t\t\\n\")\t/* 소재지주소2 \t*/\n\t\t\t\t .append(\"\t\t,commi_rate \t= ?\t\t\t\t\t\t\\n\") \t/* 수수료율 \t*/\n\n\t\t\t\t .append(\"\t\t,cunt_status = ?\t\t\t\t\t\t\\n\")\t/* 계약상태 :CU013 \t*/\n\t\t\t\t .append(\"\t\t,bancod\t\t\t= ?\t\t\t\t\t\t\\n\") \t/* 은행코드\t \t\t\t\t*/\n\t\t\t\t .append(\"\t\t,bank_acc_no = ?\t\t\t\t\t\t\\n\")\t/* 은행계좌번호[BANKCODE]\t\t*/\n\t\t\t\t .append(\"\t\t,bank_acct_nm\t= ?\t\t\t\t\t\t\\n\")\t/* 예금주 \t\t\t\t\t*/\n\t\t\t\t .append(\"\t\t,use_yn\t\t\t= ?\t\t\t\t\t\t\\n\")\t/* 사용여부 \t\t\t\t\t*/\n\n\t\t\t\t .append(\"\t\t,u_date \t= SYSTIMESTAMP\t\t\\n\") \t/* 최종수정일자 \t*/\n\t \t\t .append(\"\t\t,u_empno \t= ?\t\t\t\t\t\t\\n\")\t/* 최종수정자사번 \t*/\n\t \t\t .append(\"\t\t,u_ip = ?\t\t\t\t\t\t\\n\")\t/* 최종수정IP */\n\t \t\t .append(\"\t,client_url = ?\t\t\t\t\t\t\\n\")\t/* 홈페이지 */\n\t\t\t\t .append (\"WHERE client_sid \t= ? \t\t\t\t\\n\");\n\t\t\t\t \n\t\t/*\n\t\t * 계약정보 수정\n\t\t */\n\t\tarr_sql[8].append(\"UPDATE SALES.TCU031 SET\t\t\t\t\t\t\\n\")\n\t\t\t\t .append(\"\t\t cont_date\t\t\t= ?\t\t\t\t\t\\n\") \t/* 계약일자 \t*/\n\t\t\t\t .append(\"\t\t ,expire_date\t\t= ?\t\t\t\t\t\\n\")\t/* 만기일자 \t*/\n\t\t\t\t .append(\"\t\t ,insur_amt\t\t\t= ?\t\t\t\t\t\\n\")\t/* 보험료 \t*/\n\t\t\t\t .append(\"\t\t ,insur_comp_cd\t\t= ?\t\t\t\t\t\\n\")\t/* 보증보험회사:CU010 \t*/\n\t\t\t\t \n\t\t\t\t .append(\"\t\t ,u_date\t\t\t= SYSTIMESTAMP\t\\n\")\t/* 최종수정일자 \t*/\n\t\t\t\t .append(\"\t\t ,u_empno \t\t\t= ?\t\t\t\t\t\\n\") \t/* 최종수정자사번 \t*/\n\t\t\t\t .append(\"\t\t ,u_ip\t\t\t\t= ?\t\t\t\t\t\\n\")\t/* 최종수정IP \t*/\n\t\t\t\t .append (\"WHERE client_sid \t\t= ? AND cont_date = ? \\n\");\n\t\t\t\t\n\t\t\t\t \n\t\t\t\t\t\n\t\t/*\n\t\t * 지점정보 수정\n\t\t */\n\t\t\n\t\tarr_sql[9].append(\"UPDATE SALES.TCU032 SET \t\t\t\t\t\t\t\\n\")\n\t\t\t\t .append(\"\t\t branch_nm \t\t= ?\t\t\t\t\t\t\\n\") \t/* 지점명 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,area_cd\t\t\t= ?\t\t\t\t\t\t\\n\") \t/* 지역코드:SY006 \t\t*/\n\t\t\t\t .append(\"\t\t ,client_down_yn \t= ?\t\t\t\t\t\t\\n\")\t/* 하위대리점여부:CU011 \t*/\n\t\t\t\t \n\t\t\t\t .append(\"\t\t ,empno \t\t\t= ?\t\t\t\t\t\t\\n\")\t/* 담당자 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,tel_no \t\t\t= ?\t\t\t\t\t\t\\n\")\t/* 전화번호 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,mobile_no \t\t= ?\t\t\t\t\t\t\\n\")\t/* 휴대폰 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,fax_no \t\t\t= ?\t\t\t\t\t\t\\n\")\t/* 팩스번호 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,branch_url \t\t= ?\t\t\t\t\t\t\\n\")\t/* 지점홈페이지 \t\t\t*/\n\t\t\t\t \n\t\t\t\t .append(\"\t\t ,u_date \t\t\t= SYSTIMESTAMP\t\t\t\t\t\t\\n\")\t/* 최종수정일자 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,u_empno \t\t\t= ?\t\t\\n\")\t/* 최종수정자사번 \t\t\t*/\n\t\t\t\t .append(\"\t\t ,u_ip \t\t\t= ?\t\t\t\t\t\t\\n\")\t/* 최종수정IP \t\t*/\n\t\t\t\t .append (\"WHERE client_sid = ? AND branch_cd \t= ?\t\t\\n\");\n\t\t\n\t\t arr_sql[10].append(\"DELETE FROM SALES.TCU030 WHERE client_sid = ?\");\t\n\t\t arr_sql[11].append(\"DELETE FROM SALES.TCU031 WHERE client_sid = ? AND cont_date = ?\");\n\t\t arr_sql[12].append(\"DELETE FROM SALES.TCU032 WHERE client_sid = ? AND branch_cd = ?\");\n\t\t \n\t\t \n\t\t /*\n\t\t * Client SID 얻어오기\n\t\t */\n\t\t\t\n\t\t\tarr_sql[13].append(\"SELECT client_sid FROM SALES.TCU030 WHERE client_cd = ?\\n\");\n\t\t\t\n\t\t/*\n\t\t * 수수료율 조회\n\t\t */\n\t\t\tarr_sql[14].append(\"SELECT\t\t\t\t\t\t\t\t\\n\")\n\t\t\t\t\t\t.append(\" T1.CLIENT_SID AS CLIENT_SID\t\\n\") /* 매출처SID */\n\t\t\t\t\t\t.append(\" ,T1.FR_DATE AS FR_DATE \t\\n\") /* 시작일자 */\n\t\t\t\t\t\t.append(\" ,T1.TO_DATE AS TO_DATE \t\\n\") /* 종료일자 */\n\t\t\t\t\t\t.append(\" ,T1.WEEKEND_YN AS WEEKEND_YN \t\\n\") /* 주말여부 */\n\t\t\t\t\t\t.append(\" ,T1.COMMI_RATE AS COMMI_RATE\t\\n\") /* 수수료율 */\n\t\t\t\t\t\t.append(\"FROM SALES.TCU033 T1 \t\\n\")\n\t\t\t\t\t\t.append(\"WHERE 1=1 \t\t\t\t\t\t\t\\n\");\n\t\t\t\t\t\t\n\t\t/*\n\t\t * 수수료율 등록\n\t\t */\n\t\t\t\n\t\t\tarr_sql[15].append(\"INSERT INTO SALES.TCU033 ( \t\\n\")\n\t\t\t\t\t\t .append(\" \t CLIENT_SID\t\t\t\\n\")\t/* 매출처SID \t*/\n\t\t\t\t\t\t .append(\"\t\t ,FR_DATE\t\t\t\t\\n\") \t/* 시작일자 \t*/\n\t\t\t\t\t\t .append(\"\t\t ,TO_DATE\t\t\t\\n\")\t/* 종료일자 \t*/\n\t\t\t\t\t\t .append(\"\t\t ,COMMI_RATE\t\t\t\t\\n\")\t/* 수수료율 \t*/\n\t\t\t\t\t\t .append(\"\t\t ,WEEKEND_YN\t\t\t\\n\")\t/* 주말여부 \t*/\n\t\t\t\t\t\t .append(\"\t\t ,I_DATE\t\t\t\t\\n\")\t/* 최종입력일자 \t*/\n\t\t\t\t\t\t .append(\"\t\t ,I_EMPNO \t\t\t\t\\n\") \t/* 최종입력자사번 \t*/\n\t\t\t\t\t\t .append(\"\t\t ,I_IP\t\t\t\t\t\\n\")\t/* 최종입력IP \t*/\t\t\t\t\t\t \n\t\t\t\t\t\t .append(\"\t\t ,u_date\t\t\t\t\\n\")\t/* 최종수정일자 \t*/\n\t\t\t\t\t\t .append(\"\t\t ,u_empno \t\t\t\t\\n\") \t/* 최종수정자사번 \t*/\n\t\t\t\t\t\t .append(\"\t\t ,u_ip\t\t\t\t\t\\n\")\t/* 최종수정IP \t*/\n\t\t\t\t\t\t .append(\"\t\t)\t\t\t\t\t\t\\n\")\n\t\t\t\t\t\t \n\t\t\t\t\t\t .append(\"VALUES\t\t\t\t\t\t\\n\")\n\t\t\t\t\t\t .append(\"\t\t\t(\t \t\t\t\\n\")\n\t\t\t\t\t\t .append(\"\t\t\t\t?,?,?,?, ?,\t\t\\n\")\t\n\t\t\t\t\t\t .append(\"\t\t\t\tSYSTIMESTAMP,?,?, SYSTIMESTAMP,?,?\t\\n\")\n\t\t\t\t\t\t .append(\"\t\t\t)\");\n\t\t/*\n\t\t * 수수료율 수정\n\t\t */\n\t\t\tarr_sql[16].append(\"UPDATE SALES.TCU033 SET\t\t\t\t\t\t\\n\") \n\t\t\t\t\t .append(\"\t\t TO_DATE\t\t\t= ?\t\t\t\t\t\\n\")\t/* 종료일자 \t*/\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\n\t\t\t\t\t .append(\"\t\t ,COMMI_RATE\t\t= ?\t\t\t\t\t\\n\")\t/* 수수료율 \t*/\n\t\t\t\t\t .append(\"\t\t ,WEEKEND_YN\t\t= ?\t\t\t\t\t\\n\")\t/* 주말여부 \t*/\n\t\t\t\t\t \n\t\t\t\t\t \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\n\t\t\t\t\t .append(\"\t\t ,u_date\t\t\t= SYSTIMESTAMP\t\\n\")\t/* 최종수정일자 \t*/\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\n\t\t\t\t\t .append(\"\t\t ,u_empno \t\t\t= ?\t\t\t\t\t\\n\") \t/* 최종수정자사번 \t*/\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\n\t\t\t\t\t .append(\"\t\t ,u_ip\t\t\t\t= ?\t\t\t\t\t\\n\")\t/* 최종수정IP \t*/\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\n\t\t\t\t\t .append (\"WHERE client_sid \t\t= ? AND FR_DATE = ? AND WEEKEND_YN=? \\n\"); \n\t\t/*\n\t\t * 수수료율 삭제\n\t\t */\n\t\tarr_sql[17].append(\"DELETE FROM SALES.TCU033 WHERE client_sid = ? AND fr_date = ? AND WEEKEND_YN=? \");\t \n\t\t\t \n\n\t}",
"public void sumar(){\n recogidaDatos();\n System.out.println(\"El resultado de la suma es: \" + (numerando1 + numerando2));\n System.out.println(\"***********************************\");\n\n }",
"static double sum(Map<Integer, Map<String, Object>> dict, String col){\n\t\tdouble sum = 0;\n\t\t\n\t\tfor(Integer key : dict.keySet()){\n\t\t\tsum += (double) dict.get(key).get(col);\n\t\t}\n\t\t\n\t\treturn sum;\n\t}",
"@Select({\n \"select\",\n \"SOID, LINENO, MID, MNAME, STANDARD, UNITID, UNITNAME, NUM, BEFOREDISCOUNT, DISCOUNT, \",\n \"PRICE, TOTALPRICE, TAXRATE, TOTALTAX, TOTALMONEY, BEFOREOUT, ESTIMATEDATE, LEFTNUM, \",\n \"ISGIFT, FROMBILLTYPE, FROMBILLID\",\n \"from SALEORDERDETAIL\",\n \"where SOID = #{soid,jdbcType=VARCHAR}\",\n \"and LINENO = #{lineno,jdbcType=DECIMAL}\"\n })\n @ConstructorArgs({\n @Arg(column=\"SOID\", javaType=String.class, jdbcType=JdbcType.VARCHAR, id=true),\n @Arg(column=\"LINENO\", javaType=Long.class, jdbcType=JdbcType.DECIMAL, id=true),\n @Arg(column=\"MID\", javaType=String.class, jdbcType=JdbcType.VARCHAR),\n @Arg(column=\"MNAME\", javaType=String.class, jdbcType=JdbcType.VARCHAR),\n @Arg(column=\"STANDARD\", javaType=String.class, jdbcType=JdbcType.VARCHAR),\n @Arg(column=\"UNITID\", javaType=String.class, jdbcType=JdbcType.VARCHAR),\n @Arg(column=\"UNITNAME\", javaType=String.class, jdbcType=JdbcType.VARCHAR),\n @Arg(column=\"NUM\", javaType=Long.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"BEFOREDISCOUNT\", javaType=BigDecimal.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"DISCOUNT\", javaType=BigDecimal.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"PRICE\", javaType=BigDecimal.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"TOTALPRICE\", javaType=BigDecimal.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"TAXRATE\", javaType=BigDecimal.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"TOTALTAX\", javaType=BigDecimal.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"TOTALMONEY\", javaType=BigDecimal.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"BEFOREOUT\", javaType=Long.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"ESTIMATEDATE\", javaType=Date.class, jdbcType=JdbcType.TIMESTAMP),\n @Arg(column=\"LEFTNUM\", javaType=Long.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"ISGIFT\", javaType=Short.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"FROMBILLTYPE\", javaType=Short.class, jdbcType=JdbcType.DECIMAL),\n @Arg(column=\"FROMBILLID\", javaType=String.class, jdbcType=JdbcType.VARCHAR)\n })\n Saleorderdetail selectByPrimaryKey(@Param(\"soid\") String soid, @Param(\"lineno\") Long lineno);",
"@Select({\n \"select\",\n \"user_id, measure_date, contract_id, consultant_uid, collar, wrist, bust, shoulder_width, \",\n \"mid_waist, waist_line, sleeve, hem, back_length, front_length, arm, forearm, \",\n \"front_breast_width, back_width, pants_length, crotch_depth, leg_width, thigh, \",\n \"lower_leg, height, weight, body_shape, stance, shoulder_shape, abdomen_shape, \",\n \"payment, invoice\",\n \"from A_SUIT_MEASUREMENT\",\n \"where user_id = #{userId,jdbcType=INTEGER}\",\n \"and measure_date = #{measureDate,jdbcType=TIMESTAMP}\"\n })\n @Results({\n @Result(column=\"user_id\", property=\"userId\", jdbcType=JdbcType.INTEGER, id=true),\n @Result(column=\"measure_date\", property=\"measureDate\", jdbcType=JdbcType.TIMESTAMP, id=true),\n @Result(column=\"contract_id\", property=\"contractId\", jdbcType=JdbcType.INTEGER),\n @Result(column=\"consultant_uid\", property=\"consultantUid\", jdbcType=JdbcType.INTEGER),\n @Result(column=\"collar\", property=\"collar\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"wrist\", property=\"wrist\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"bust\", property=\"bust\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"shoulder_width\", property=\"shoulderWidth\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"mid_waist\", property=\"midWaist\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"waist_line\", property=\"waistLine\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"sleeve\", property=\"sleeve\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"hem\", property=\"hem\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"back_length\", property=\"backLength\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"front_length\", property=\"frontLength\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"arm\", property=\"arm\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"forearm\", property=\"forearm\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"front_breast_width\", property=\"frontBreastWidth\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"back_width\", property=\"backWidth\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"pants_length\", property=\"pantsLength\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"crotch_depth\", property=\"crotchDepth\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"leg_width\", property=\"legWidth\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"thigh\", property=\"thigh\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"lower_leg\", property=\"lowerLeg\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"height\", property=\"height\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"weight\", property=\"weight\", jdbcType=JdbcType.DOUBLE),\n @Result(column=\"body_shape\", property=\"bodyShape\", jdbcType=JdbcType.INTEGER),\n @Result(column=\"stance\", property=\"stance\", jdbcType=JdbcType.INTEGER),\n @Result(column=\"shoulder_shape\", property=\"shoulderShape\", jdbcType=JdbcType.INTEGER),\n @Result(column=\"abdomen_shape\", property=\"abdomenShape\", jdbcType=JdbcType.INTEGER),\n @Result(column=\"payment\", property=\"payment\", jdbcType=JdbcType.INTEGER),\n @Result(column=\"invoice\", property=\"invoice\", jdbcType=JdbcType.VARCHAR)\n })\n ASuitMeasurement selectByPrimaryKey(@Param(\"userId\") Integer userId, @Param(\"measureDate\") Date measureDate);",
"public static void main(String[] args) throws SQLException {\n\t\tdao.DBBean daodao = new dao.DBBean();\r\n\t\tString sql = \"select * from msql.peizhi where xuhao ='1'\";\r\n\t\tResultSet rs = daodao.query(sql);\r\n\t\twhile(rs.next()){\r\n\t\t\tdouble sname = rs.getDouble(\"bxishu\");\r\n\t\t\tSystem.out.println(sname);\r\n\t\t}\r\n\t\t\r\n\t\t//sql = \"insert into msql.peizhi(xuhao)values('2')\";\r\n\t\t//daodao.update(sql);\r\n\t\t\r\n\t\tsql = \"update msql.peizhi set bsensorx = '3' where xuhao = '2'\";\r\n\t\tdaodao.update(sql);\r\n\t\t}",
"public void executeQuery() {\n\n \n String query=\"insert into Cost (Date,Employee_Cost,Selling,Inventory_Cost,Wastage) values ('\"+date+\"','\"+Employee_Amount+\"','\"+Sale_total_amount+\"','\"+Inventory_total_Cost+\"','\"+Wastage_Cost+\"')\";\n Connection con = DBconnect.connectdb();\n Statement st;\n\n try {\n st = con.createStatement();\n st.executeUpdate(query);\n\n \n } catch (Exception e) {\n // JOptionPane.showMessageDialog(null, e);\n\n }\n\n }",
"public void query(String sql) throws SQLException {\r\n Statement st = con.createStatement();\r\n ResultSet rs = st.executeQuery(sql);\r\n\r\n while (rs.next()){\r\n System.out.println(rs.getInt(\"id\")+\" \"+rs.getString(\"name\")+\" \"+rs.getString(\"surname\")+\" \"+rs.getFloat(\"grade\"));\r\n }\r\n\r\n }"
]
| [
"0.6283194",
"0.6263392",
"0.6100063",
"0.58083415",
"0.5781673",
"0.5712146",
"0.57063025",
"0.56490684",
"0.55968285",
"0.55541307",
"0.55086213",
"0.55086213",
"0.5492027",
"0.54339665",
"0.54052365",
"0.53662467",
"0.53554404",
"0.53213423",
"0.53099483",
"0.52804",
"0.52691275",
"0.52016425",
"0.5193392",
"0.5163365",
"0.5155207",
"0.5148946",
"0.5129566",
"0.5118247",
"0.51180685",
"0.5108976",
"0.51005185",
"0.50994545",
"0.50926536",
"0.50881654",
"0.50870156",
"0.5072344",
"0.5067732",
"0.504979",
"0.5029207",
"0.50218123",
"0.50099206",
"0.49920166",
"0.4980793",
"0.49770138",
"0.49770138",
"0.49739957",
"0.4965239",
"0.49613017",
"0.49577808",
"0.49458408",
"0.4936304",
"0.49360466",
"0.49301606",
"0.49281487",
"0.49254137",
"0.49200076",
"0.49104613",
"0.4910063",
"0.4899795",
"0.48980784",
"0.48979104",
"0.4891343",
"0.48881626",
"0.4887235",
"0.48860362",
"0.48852798",
"0.48748505",
"0.48668098",
"0.48662007",
"0.48614255",
"0.48520106",
"0.48505753",
"0.48493603",
"0.48448318",
"0.48428002",
"0.48426956",
"0.48368979",
"0.48275876",
"0.48210862",
"0.48205358",
"0.48143253",
"0.4813204",
"0.48069498",
"0.48020858",
"0.4800174",
"0.47977325",
"0.47951582",
"0.4788675",
"0.47875682",
"0.47867307",
"0.47846922",
"0.47794116",
"0.4772802",
"0.47713634",
"0.47666395",
"0.47638664",
"0.4758738",
"0.47511435",
"0.4748558",
"0.47383618"
]
| 0.52607566 | 21 |
Created by jrejaud on 3/16/16. | public interface TwilioService {
@GET("PhoneNumbers/{phoneNumber}?Type=carrier")
Call<TwilioLookupResponse> lookup(@Path("phoneNumber") String phoneNumber);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\n public void perish() {\n \n }",
"@Override\n\tpublic void grabar() {\n\t\t\n\t}",
"private stendhal() {\n\t}",
"@Override\n\tpublic void comer() {\n\t\t\n\t}",
"public final void mo51373a() {\n }",
"@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}",
"@Override\n public void func_104112_b() {\n \n }",
"@Override\n\tprotected void getExras() {\n\n\t}",
"@Override\r\n\tpublic void comer() \r\n\t{\n\t\t\r\n\t}",
"@Override\r\n\tpublic void tires() {\n\t\t\r\n\t}",
"@Override\n\tpublic void nadar() {\n\t\t\n\t}",
"@Override\n\tpublic void entrenar() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tprotected void interr() {\n\t}",
"@Override\n public void init() {\n\n }",
"@Override\r\n\tpublic void dormir() {\n\t\t\r\n\t}",
"@Override\n\tpublic void anular() {\n\n\t}",
"@Override\n\tpublic void sacrifier() {\n\t\t\n\t}",
"public void gored() {\n\t\t\n\t}",
"private void m50366E() {\n }",
"@Override\r\n\t\tpublic void init() {\n\t\t\t\r\n\t\t}",
"@Override\r\n\tpublic void rozmnozovat() {\n\t}",
"@Override\n\tpublic void gravarBd() {\n\t\t\n\t}",
"private static void cajas() {\n\t\t\n\t}",
"public void mo38117a() {\n }",
"protected boolean func_70814_o() { return true; }",
"private void poetries() {\n\n\t}",
"@Override\r\n\t\t\tpublic void annadir() {\n\r\n\t\t\t}",
"@Override\n public int retroceder() {\n return 0;\n }",
"@Override\n public void init() {\n }",
"@Override\n\tprotected void initialize() {\n\t\t\n\t}",
"@Override\n\tprotected void initialize() {\n\t\t\n\t}",
"@Override\n protected void initialize() {\n\n \n }",
"@Override\n protected void getExras() {\n }",
"public void mo4359a() {\n }",
"@Override\n void init() {\n }",
"@Override\n\tpublic int mettreAJour() {\n\t\treturn 0;\n\t}",
"@Override\n\tpublic void jugar() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\n\t}",
"@Override\n\tpublic void init() {\n\n\t}",
"@Override\n\tpublic void init() {\n\n\t}",
"@Override\n\tpublic void ligar() {\n\t\t\n\t}",
"private void init() {\n\n\t}",
"@Override\n\tpublic void one() {\n\t\t\n\t}",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void initialize() {\n }",
"@Override\n protected void init() {\n }",
"@Override\n public void init() {\n\n }",
"@Override\n public void init() {\n\n }",
"@Override\n public void init() {}",
"@Override\r\n\tpublic void init() {\n\r\n\t}",
"@Override\r\n\tpublic void init() {\n\r\n\t}",
"@Override\r\n\tpublic void init() {\n\r\n\t}",
"@Override\n protected void initialize() \n {\n \n }",
"@Override\n\tpublic void einkaufen() {\n\t}",
"@Override\r\n\tpublic void init() {}",
"@Override\n\tpublic void nghe() {\n\n\t}",
"@Override\r\n\tpublic void init() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void init() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void init() {\n\t\t\r\n\t}",
"@Override\n public int describeContents() { return 0; }",
"@Override\n\tprotected void initialize() {\n\n\t}",
"@Override\r\n\tprotected void initialize() {\r\n\t\t\r\n\t\t\r\n\t}",
"@Override\r\n\tpublic void anularFact() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void init()\r\n\t{\n\t}",
"@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}",
"private void kk12() {\n\n\t}",
"@Override\n\tpublic void init()\n\t{\n\n\t}",
"@Override\n\tpublic void init() {\n\t}",
"@Override\r\n\tprotected void doF4() {\n\t\t\r\n\t}",
"@Override\r\n\t\t\tpublic void ayuda() {\n\r\n\t\t\t}",
"@Override\n public void memoria() {\n \n }",
"private Rekenhulp()\n\t{\n\t}",
"@Override\n\tpublic void debite() {\n\t\t\n\t}",
"@Override\n public void initialize() { \n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"@Override\n public void inizializza() {\n\n super.inizializza();\n }",
"@Override\n\tpublic void afterInit() {\n\t\t\n\t}",
"@Override\n\tpublic void afterInit() {\n\t\t\n\t}",
"@Override\r\n\tprotected void initialize() {\n\r\n\t}",
"@Override\n\tprotected void initialize() {\n\t}",
"@Override\n\tprotected void initialize() {\n\t}",
"public void mo12628c() {\n }",
"@Override\n\tpublic void nefesAl() {\n\n\t}",
"@Override\n\t\tpublic void init() {\n\t\t}"
]
| [
"0.6112198",
"0.5941962",
"0.5929861",
"0.5915847",
"0.5870361",
"0.5839643",
"0.5839643",
"0.5815217",
"0.5793736",
"0.57685614",
"0.57440436",
"0.5727351",
"0.5720611",
"0.57066846",
"0.57066846",
"0.57066846",
"0.57066846",
"0.57066846",
"0.5705585",
"0.56970924",
"0.56900007",
"0.5685716",
"0.5684016",
"0.5667088",
"0.56648695",
"0.56457263",
"0.5634484",
"0.56338257",
"0.5631346",
"0.56260985",
"0.5622258",
"0.56137776",
"0.5609811",
"0.56054085",
"0.56048995",
"0.5602276",
"0.5602276",
"0.55916643",
"0.5588226",
"0.55778545",
"0.5563572",
"0.5559761",
"0.55533856",
"0.55524105",
"0.55524105",
"0.55524105",
"0.55477667",
"0.553889",
"0.5536482",
"0.55348474",
"0.55348474",
"0.55348474",
"0.55348474",
"0.55348474",
"0.55348474",
"0.55340326",
"0.55295175",
"0.55295175",
"0.55289257",
"0.55270934",
"0.55270934",
"0.55270934",
"0.55233467",
"0.5516601",
"0.5516116",
"0.5516035",
"0.5515411",
"0.5515411",
"0.5515411",
"0.550702",
"0.55020386",
"0.5487581",
"0.54845846",
"0.5482197",
"0.5481904",
"0.5481904",
"0.54817486",
"0.5480099",
"0.54792243",
"0.547168",
"0.5449644",
"0.54081476",
"0.540573",
"0.5404003",
"0.53989434",
"0.5385302",
"0.5385302",
"0.5385302",
"0.5385302",
"0.5385302",
"0.5385302",
"0.5385302",
"0.5385171",
"0.5381156",
"0.5381156",
"0.5379762",
"0.537448",
"0.537448",
"0.53696406",
"0.53645056",
"0.5363239"
]
| 0.0 | -1 |
/ renamed from: com.ss.android.ugc.aweme.shortvideo.sticker.ar.pixaloop.c.c | public interface C40453c {
/* renamed from: a */
void mo100442a(C40429b bVar);
/* renamed from: a */
void mo100443a(List<String> list);
/* renamed from: b */
void mo100444b(List<C40429b> list);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public interface C45630d {\n\n /* renamed from: com.tencent.mm.plugin.appbrand.jsapi.video.d$f */\n public interface C10555f {\n /* renamed from: es */\n void mo22049es(boolean z);\n }\n\n /* renamed from: com.tencent.mm.plugin.appbrand.jsapi.video.d$d */\n public interface C19512d {\n /* renamed from: dd */\n void mo34676dd(int i, int i2);\n }\n\n /* renamed from: com.tencent.mm.plugin.appbrand.jsapi.video.d$e */\n public interface C27129e {\n void onVisibilityChanged(boolean z);\n }\n\n /* renamed from: com.tencent.mm.plugin.appbrand.jsapi.video.d$g */\n public enum C27130g {\n DEFAULT,\n FILL,\n CONTAIN,\n COVER;\n\n static {\n AppMethodBeat.m2505o(126548);\n }\n }\n\n /* renamed from: com.tencent.mm.plugin.appbrand.jsapi.video.d$a */\n public interface C38399a {\n void aDF();\n\n void aEZ();\n\n boolean aFA();\n\n void aFD();\n\n void aFE();\n\n boolean aFF();\n\n void aFG();\n\n void aFH();\n\n boolean aFI();\n\n void aFN();\n\n void aFO();\n\n boolean aFR();\n\n void aFy();\n\n void hide();\n\n void onDestroy();\n\n void seek(int i);\n\n void setDanmakuBtnOnClickListener(C10555f c10555f);\n\n void setDanmakuBtnOpen(boolean z);\n\n void setExitFullScreenBtnOnClickListener(OnClickListener onClickListener);\n\n void setFullScreenBtnOnClickListener(OnClickListener onClickListener);\n\n void setIplaySeekCallback(C42594c c42594c);\n\n void setMuteBtnOnClickListener(OnClickListener onClickListener);\n\n void setMuteBtnState(boolean z);\n\n void setOnPlayButtonClickListener(OnClickListener onClickListener);\n\n void setOnUpdateProgressLenListener(C19512d c19512d);\n\n void setOnVisibilityChangedListener(C27129e c27129e);\n\n void setPlayBtnInCenterPosition(boolean z);\n\n void setShowControlProgress(boolean z);\n\n void setShowDanmakuBtn(boolean z);\n\n void setShowFullScreenBtn(boolean z);\n\n void setShowMuteBtn(boolean z);\n\n void setShowPlayBtn(boolean z);\n\n void setShowProgress(boolean z);\n\n void setStatePorter(C38400h c38400h);\n\n void setTitle(String str);\n }\n\n /* renamed from: com.tencent.mm.plugin.appbrand.jsapi.video.d$h */\n public interface C38400h {\n int aFg();\n\n int aFh();\n }\n\n /* renamed from: com.tencent.mm.plugin.appbrand.jsapi.video.d$b */\n public interface C42593b {\n /* renamed from: H */\n void mo34677H(String str, int i, int i2);\n\n void aFq();\n\n void aFr();\n\n void aFs();\n\n void aFt();\n\n void aFu();\n\n void aFv();\n\n /* renamed from: de */\n void mo34684de(int i, int i2);\n }\n\n /* renamed from: com.tencent.mm.plugin.appbrand.jsapi.video.d$c */\n public interface C42594c {\n void aFw();\n\n /* renamed from: oA */\n void mo22044oA(int i);\n }\n\n void aEX();\n\n void akV();\n\n void akW();\n\n /* renamed from: as */\n boolean mo61579as(float f);\n\n /* renamed from: c */\n void mo61580c(boolean z, String str, int i);\n\n /* renamed from: e */\n boolean mo61581e(double d, boolean z);\n\n int getCacheTimeSec();\n\n int getCurrPosMs();\n\n int getCurrPosSec();\n\n int getVideoDurationSec();\n\n boolean isLive();\n\n boolean isPlaying();\n\n boolean pause();\n\n /* renamed from: s */\n boolean mo61590s(double d);\n\n void setControlBar(C38399a c38399a);\n\n void setIMMVideoViewCallback(C42593b c42593b);\n\n void setMute(boolean z);\n\n void setScaleType(C27130g c27130g);\n\n void setVideoSource(int i);\n\n void start();\n\n void stop();\n}",
"public void mo5975l() {\n new C1292f(this.f5384D.getmImageView(), new int[]{R.drawable.iqoo_btn_play_15, R.drawable.iqoo_btn_play_14, R.drawable.iqoo_btn_play_13, R.drawable.iqoo_btn_play_12, R.drawable.iqoo_btn_play_11, R.drawable.iqoo_btn_play_10, R.drawable.iqoo_btn_play_9, R.drawable.iqoo_btn_play_8, R.drawable.iqoo_btn_play_7, R.drawable.iqoo_btn_play_6, R.drawable.iqoo_btn_play_5, R.drawable.iqoo_btn_play_4, R.drawable.iqoo_btn_play_3, R.drawable.iqoo_btn_play_2, R.drawable.iqoo_btn_play_1, R.drawable.iqoo_btn_play_0}, new int[]{3, 3, 3, 3, 3, 3, 3, 3, 3, 3, 3, 3, 3, 3, 3, 3});\n }",
"public interface C2368d {\n\n /* renamed from: com.google.android.exoplayer2.upstream.d$a */\n public interface C2367a {\n /* renamed from: a */\n C2368d mo1698a();\n }\n\n /* renamed from: a */\n int mo1684a(byte[] bArr, int i, int i2);\n\n /* renamed from: a */\n long mo1685a(C2369e c2369e);\n\n /* renamed from: a */\n Uri mo1686a();\n\n /* renamed from: b */\n void mo1687b();\n}",
"public interface C9715b {\n\n /* renamed from: com.tencent.mm.modelvideo.b$a */\n public interface C9714a {\n /* renamed from: ad */\n void mo9058ad(String str, int i);\n\n /* renamed from: h */\n void mo9075h(String str, int i, int i2);\n\n /* renamed from: ml */\n void mo21050ml(int i);\n\n void onDataAvailable(String str, int i, int i2);\n }\n\n /* renamed from: a */\n void mo8712a(C9714a c9714a);\n\n /* renamed from: dV */\n void mo8713dV(String str);\n\n boolean isVideoDataAvailable(String str, int i, int i2);\n\n /* renamed from: r */\n void mo8715r(String str, String str2, String str3);\n\n void requestVideoData(String str, int i, int i2);\n}",
"public interface C39682m {\n\n /* renamed from: com.ss.android.ugc.aweme.shortvideo.edit.m$a */\n public interface C39683a {\n /* renamed from: a */\n int mo98966a(C29296g gVar);\n\n /* renamed from: b */\n int mo98967b(C29296g gVar);\n\n /* renamed from: c */\n float mo98968c(C29296g gVar);\n }\n\n /* renamed from: com.ss.android.ugc.aweme.shortvideo.edit.m$b */\n public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }\n}",
"public final long mo86969a(com.p280ss.android.ugc.aweme.feed.model.Aweme r5, com.p280ss.android.ugc.playerkit.videoview.C44960f r6) {\n /*\n r4 = this;\n com.ss.android.ugc.aweme.newfollow.vh.CommercialFlowFeedViewHolder r6 = r4.f89242a\n com.ss.android.ugc.aweme.newfollow.util.d r6 = r6.f77592aR\n java.lang.String r0 = \"mPlayVideoHelper\"\n kotlin.jvm.internal.C7573i.m23582a(r6, r0)\n long r0 = r6.mo86937c()\n r2 = 0\n int r6 = (r0 > r2 ? 1 : (r0 == r2 ? 0 : -1))\n if (r6 <= 0) goto L_0x0014\n return r0\n L_0x0014:\n if (r5 == 0) goto L_0x0025\n com.ss.android.ugc.aweme.feed.model.Video r6 = r5.getVideo()\n if (r6 == 0) goto L_0x0025\n int r6 = r6.getDuration()\n java.lang.Integer r6 = java.lang.Integer.valueOf(r6)\n goto L_0x0026\n L_0x0025:\n r6 = 0\n L_0x0026:\n if (r6 == 0) goto L_0x0046\n com.ss.android.ugc.aweme.feed.model.Video r6 = r5.getVideo()\n java.lang.String r0 = \"aweme.video\"\n kotlin.jvm.internal.C7573i.m23582a(r6, r0)\n int r6 = r6.getDuration()\n if (r6 <= 0) goto L_0x0046\n com.ss.android.ugc.aweme.feed.model.Video r5 = r5.getVideo()\n java.lang.String r6 = \"aweme.video\"\n kotlin.jvm.internal.C7573i.m23582a(r5, r6)\n int r5 = r5.getDuration()\n long r5 = (long) r5\n return r5\n L_0x0046:\n r5 = 1\n return r5\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.p280ss.android.ugc.aweme.newfollow.p1424vh.CommercialFlowFeedViewHolder.C34218l.mo86969a(com.ss.android.ugc.aweme.feed.model.Aweme, com.ss.android.ugc.playerkit.videoview.f):long\");\n }",
"private final void m126208g() {\n int i;\n int i2;\n int i3;\n int i4;\n int i5;\n if (!this.f102568b.mIsFromDraft || !this.f102568b.hasStickers()) {\n boolean a = C39804em.m127437a(this.f102568b.videoWidth(), this.f102568b.videoHeight());\n if (a) {\n i = this.f102568b.videoWidth();\n } else {\n int[] k = C36964i.m118935k();\n if (k != null) {\n i3 = k[0];\n } else {\n i3 = 720;\n }\n i = m125903a(C7551d.m23567d(this.f102568b.videoWidth(), i3));\n }\n this.f102569c = i;\n if (a) {\n i2 = this.f102568b.videoHeight();\n } else {\n double d = (double) this.f102569c;\n Double.isNaN(d);\n i2 = (int) (Math.ceil(d / 9.0d) * 16.0d);\n }\n this.f102570d = i2;\n return;\n }\n if (this.f102568b.mVideoCanvasWidth > 0) {\n i4 = this.f102568b.mVideoCanvasWidth;\n } else {\n i4 = this.f102568b.videoWidth();\n }\n this.f102569c = i4;\n if (this.f102568b.mVideoCanvasHeight > 0) {\n i5 = this.f102568b.mVideoCanvasHeight;\n } else {\n i5 = this.f102568b.videoHeight();\n }\n this.f102570d = i5;\n }",
"private void mo71772t() {\n this.f74253i.mo60157b(R.id.ebb, new VideoPostTimeWidget());\n }",
"private void m6622a(boolean z) {\n if (C1413m.m6844f()) {\n if (z) {\n this.f5384D.mo6533a(getResources().getString(R.string.pause), (int) R.drawable.iqoo_btn_play_15, getResources().getDimensionPixelSize(R.dimen.middle_text_margin_diff));\n } else {\n this.f5384D.mo6533a(getResources().getString(R.string.manager_title), (int) R.drawable.iqoo_btn_play_0, getResources().getDimensionPixelSize(R.dimen.middle_text_margin_diff));\n }\n } else if (z) {\n this.f5384D.mo6533a(getResources().getString(R.string.pause), (int) R.drawable.btn_play_15, getResources().getDimensionPixelSize(R.dimen.middle_text_margin_diff));\n } else {\n this.f5384D.mo6533a(getResources().getString(R.string.manager_title), (int) R.drawable.btn_play_0, getResources().getDimensionPixelSize(R.dimen.middle_text_margin_diff));\n }\n }",
"public final void zza(com.google.android.gms.internal.cast.zzcn r9) {\n /*\n r8 = this;\n com.google.android.gms.cast.RemoteMediaPlayer r9 = r8.zzfd\n java.lang.Object r9 = \n // error: 0x0002: INVOKE (r9 I:java.lang.Object) = (r9 I:com.google.android.gms.cast.RemoteMediaPlayer) com.google.android.gms.cast.RemoteMediaPlayer.zze(com.google.android.gms.cast.RemoteMediaPlayer):java.lang.Object type: STATIC\n monitor-enter(r9)\n com.google.android.gms.cast.RemoteMediaPlayer r0 = r8.zzfd // Catch:{ all -> 0x0055 }\n com.google.android.gms.cast.RemoteMediaPlayer$zza r0 = r0.zzey // Catch:{ all -> 0x0055 }\n com.google.android.gms.common.api.GoogleApiClient r1 = r8.zzfe // Catch:{ all -> 0x0055 }\n r0.zza(r1) // Catch:{ all -> 0x0055 }\n r0 = 0\n com.google.android.gms.cast.RemoteMediaPlayer r1 = r8.zzfd // Catch:{ zzdk | IllegalStateException -> 0x0030 }\n com.google.android.gms.internal.cast.zzdh r2 = r1.zzex // Catch:{ zzdk | IllegalStateException -> 0x0030 }\n com.google.android.gms.internal.cast.zzdm r3 = r8.zzgd // Catch:{ zzdk | IllegalStateException -> 0x0030 }\n long r4 = r8.val$position // Catch:{ zzdk | IllegalStateException -> 0x0030 }\n int r6 = r8.zzfw // Catch:{ zzdk | IllegalStateException -> 0x0030 }\n org.json.JSONObject r7 = r8.zzfk // Catch:{ zzdk | IllegalStateException -> 0x0030 }\n r2.zza(r3, r4, r6, r7) // Catch:{ zzdk | IllegalStateException -> 0x0030 }\n com.google.android.gms.cast.RemoteMediaPlayer r1 = r8.zzfd // Catch:{ all -> 0x0055 }\n com.google.android.gms.cast.RemoteMediaPlayer$zza r1 = r1.zzey // Catch:{ all -> 0x0055 }\n r1.zza(r0) // Catch:{ all -> 0x0055 }\n goto L_0x0049\n L_0x002e:\n r1 = move-exception\n goto L_0x004b\n L_0x0030:\n com.google.android.gms.common.api.Status r1 = new com.google.android.gms.common.api.Status // Catch:{ all -> 0x002e }\n r2 = 2100(0x834, float:2.943E-42)\n r1.<init>(r2) // Catch:{ all -> 0x002e }\n com.google.android.gms.common.api.Result r1 = r8.createFailedResult(r1) // Catch:{ all -> 0x002e }\n com.google.android.gms.cast.RemoteMediaPlayer$MediaChannelResult r1 = (com.google.android.gms.cast.RemoteMediaPlayer.MediaChannelResult) r1 // Catch:{ all -> 0x002e }\n r8.setResult(r1) // Catch:{ all -> 0x002e }\n com.google.android.gms.cast.RemoteMediaPlayer r1 = r8.zzfd // Catch:{ all -> 0x0055 }\n com.google.android.gms.cast.RemoteMediaPlayer$zza r1 = r1.zzey // Catch:{ all -> 0x0055 }\n r1.zza(r0) // Catch:{ all -> 0x0055 }\n L_0x0049:\n monitor-exit(r9) // Catch:{ all -> 0x0055 }\n return\n L_0x004b:\n com.google.android.gms.cast.RemoteMediaPlayer r2 = r8.zzfd // Catch:{ all -> 0x0055 }\n com.google.android.gms.cast.RemoteMediaPlayer$zza r2 = r2.zzey // Catch:{ all -> 0x0055 }\n r2.zza(r0) // Catch:{ all -> 0x0055 }\n throw r1 // Catch:{ all -> 0x0055 }\n L_0x0055:\n r0 = move-exception\n monitor-exit(r9) // Catch:{ all -> 0x0055 }\n throw r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.gms.cast.zzbj.zza(com.google.android.gms.internal.cast.zzcn):void\");\n }",
"private void m128165h() {\n boolean z;\n Intent intent = getIntent();\n this.f104208R = System.currentTimeMillis();\n if (intent != null) {\n this.f104220j = (ShortVideoContext) intent.getParcelableExtra(\"key_short_video_context\");\n int i = 0;\n this.f104193C = intent.getIntExtra(\"key_photo_select_min_count\", 0);\n this.f104213c = intent.getIntExtra(\"key_photo_select_max_count\", 0);\n this.f104194D = intent.getIntExtra(\"key_video_select_min_count\", 0);\n this.f104214d = intent.getIntExtra(\"key_video_select_max_count\", 0);\n this.f104216f = intent.getIntExtra(\"upload_photo_min_height\", 0);\n this.f104215e = intent.getIntExtra(\"upload_photo_min_width\", 0);\n this.f104217g = intent.getStringExtra(\"key_mv_resource_zip_path\");\n this.f104201K = intent.getStringExtra(\"key_mv_hint_text\");\n this.f104197G = intent.getParcelableExtra(\"key_select_mv_data\");\n this.f104202L = intent.getLongExtra(\"Key_min_duration\", C39810eq.m127460a());\n this.f104203M = intent.getLongExtra(\"Key_max_duration\", -1);\n this.f104225o = intent.getIntExtra(\"key_choose_scene\", -1);\n this.f104195E = intent.getIntExtra(\"key_choose_request_code\", -1);\n this.f104196F = intent.getIntExtra(\"key_start_activity_request_code\", -1);\n if (this.f104225o == 2) {\n this.f104224n = 1;\n this.f104204N = new C40130d();\n String stringExtra = intent.getStringExtra(\"Key_challenge_id\");\n if (stringExtra != null) {\n Bundle bundle = new Bundle();\n bundle.putString(\"Key_challenge_id\", stringExtra);\n this.f104204N.mo99885a(bundle);\n }\n }\n if (this.f104225o == 3) {\n this.f104224n = 7;\n }\n if (this.f104225o == 4) {\n this.f104224n = 8;\n }\n this.f104198H = intent.getIntExtra(\"key_support_flag\", -1);\n this.f104199I = intent.getBooleanExtra(\"Key_enable_multi_video\", false);\n if ((this.f104198H & 2) != 0) {\n z = true;\n } else {\n z = false;\n }\n this.f104200J = z;\n if ((this.f104198H & 4) != 0) {\n this.f104222l = 0;\n this.f104221k++;\n }\n if (!((this.f104198H & 1) == 0 && (this.f104198H & 2) == 0)) {\n this.f104221k++;\n if (this.f104222l == 0) {\n i = 1;\n }\n this.f104223m = i;\n }\n String stringExtra2 = intent.getStringExtra(\"key_sdk_extra_data\");\n if (!TextUtils.isEmpty(stringExtra2)) {\n this.f104219i = (SdkExtraInfo) C35563c.f93239b.mo15974a(stringExtra2, SdkExtraInfo.class);\n this.f104219i.setMvAlgorithmHint(intent.getStringExtra(\"key_mv_algorithm_hint\"));\n }\n }\n }",
"public int getVideoJittcomp();",
"private void m128160c(List<String> list) {\n boolean z;\n this.f104230t = new C40170c();\n this.f104230t.mo99934a(findViewById(R.id.bzm));\n C40169b bVar = new C40169b();\n boolean z2 = false;\n if (list.size() > 0) {\n z = true;\n } else {\n z = false;\n }\n bVar.f104417d = z;\n if (this.f104224n == 1) {\n z2 = true;\n }\n bVar.f104416c = z2;\n bVar.f104419f = this.f104211a;\n bVar.f104418e = this.f104212b;\n bVar.f104420g = this.f104201K;\n bVar.f104421h = this.f104193C;\n bVar.f104422i = this.f104194D;\n bVar.mo99929a(list);\n bVar.f104415b = new C40142o(this);\n bVar.f104414a = new C40182c() {\n /* renamed from: a */\n public final void mo99830a(int i, int i2) {\n }\n\n /* renamed from: a */\n public final void mo99831a(MyMediaModel myMediaModel) {\n }\n\n /* renamed from: a */\n public final void mo99832a(MyMediaModel myMediaModel, View view) {\n if (myMediaModel != null && C7276d.m22812b(myMediaModel.f88156b)) {\n if (myMediaModel.mo86201c()) {\n MvChoosePhotoActivity.this.f104212b.mo99807a((MediaModel) myMediaModel, view);\n return;\n }\n Context context = view.getContext();\n StringBuilder sb = new StringBuilder(\"file://\");\n sb.append(myMediaModel.f88156b);\n String sb2 = sb.toString();\n C35563c.f93240c.mo83126a((Activity) context, view, (((float) C9738o.m28691a(context)) * 1.0f) / ((float) C9738o.m28709b(context)), sb2);\n }\n }\n };\n this.f104230t.mo99935a(bVar);\n this.f104199I = true;\n this.f104200J = true;\n this.f104211a.f104243o = null;\n if (this.f104220j != null) {\n C40177e.m128368a(this.f104220j.f99787w, this.f104220j.f99788x);\n }\n }",
"public interface C1590a {\n /* renamed from: a */\n Bitmap m7900a(Bitmap bitmap);\n}",
"public void mo71540w() {\n boolean z;\n VideoItemParams requestId = VideoItemParams.newBuilder().setFragment(this.f73947d).setAweme(this.f73950g).setAwemeFromPage(this.f73953m).setEventType(this.f73944a).setMyProfile(this.f73946c).setPageType(this.f73954n).setEnterMethodValue(this.f74254j).setRequestId(this.f73952l);\n if (this.f74252h != null) {\n this.f74252h.mo60134a(\"video_params\", (Object) requestId);\n }\n mo71773u();\n User author = this.f73950g.getAuthor();\n if (author != null) {\n this.mTitleView.setText(this.f73949f.getString(R.string.b5s, new Object[]{author.getNickname()}));\n this.mTitleView.getPaint().setFakeBoldText(true);\n } else {\n this.mTitleView.setText(\"\");\n }\n if (this.f73950g == null || this.f73950g.isCanPlay()) {\n this.mTitleView.setVisibility(0);\n } else {\n this.mTitleView.setVisibility(4);\n }\n this.tagLayout.setEventType(this.f73944a);\n List videoLabels = this.f73950g.getVideoLabels();\n m91744a(videoLabels);\n if (!RelationLabelHelper.hasDuoShanLabel(this.f73950g)) {\n if (C6319n.m19594a(this.f73944a, \"homepage_hot\")) {\n this.tagLayout.mo61051c(this.f73950g, videoLabels, new C23440a(7, 20));\n } else {\n this.tagLayout.mo61050b(this.f73950g, videoLabels, new C23440a(7, 20));\n }\n }\n if (TextUtils.isEmpty(this.f73950g.getExtra()) || !C6399b.m19928c()) {\n this.mTxtExtra.setVisibility(8);\n } else {\n this.mTxtExtra.setText(this.f73950g.getExtra());\n this.mTxtExtra.setVisibility(0);\n }\n if (this.f73950g.getUserDigg() == 1) {\n z = true;\n } else {\n z = false;\n }\n mo71770a(z);\n if (this.f73953m == 1) {\n mo71533d(m91740N());\n }\n AwemeStatus status = this.f73950g.getStatus();\n if (status == null) {\n this.mAwemeInCheckLayout.setVisibility(8);\n } else if (status.isInReviewing()) {\n this.mAwemeInCheckLayout.setVisibility(0);\n } else {\n this.mAwemeInCheckLayout.setVisibility(8);\n }\n }",
"public interface C31378a {\n /* renamed from: a */\n void mo80555a(MediaChooseResult mediaChooseResult);\n}",
"public final void mo61580c(boolean z, String str, int i) {\n boolean z2;\n int i2 = 1;\n AppMethodBeat.m2504i(131589);\n this.iad = i;\n this.bkJ = z;\n PString pString = new PString();\n pString.value = str;\n if (C5046bo.isNullOrNil(pString.value) || pString.value.indexOf(\"file://\") != 0) {\n z2 = false;\n } else {\n pString.value = pString.value.substring(7);\n z2 = true;\n }\n this.iae = z2;\n this.url = pString.value;\n if (this.hZY == null) {\n if (m81322a(this.bkJ, this.url, \"\")) {\n C4990ab.m7417i(\"MicroMsg.AppBrandVideoWrapper\", \"%d use common video view !\", Integer.valueOf(hashCode()));\n this.hZY = aFT();\n } else {\n C4990ab.m7417i(\"MicroMsg.AppBrandVideoWrapper\", \"%d use mm video view !\", Integer.valueOf(hashCode()));\n this.hZY = aFU();\n }\n } else if (m81322a(this.bkJ, this.url, \"\")) {\n if (this.hZY instanceof MMVideoView) {\n this.hZY.stop();\n this.hZY.cpU();\n removeView((View) this.hZY);\n C4990ab.m7417i(\"MicroMsg.AppBrandVideoWrapper\", \"%d use common video view !\", Integer.valueOf(hashCode()));\n this.hZY = aFT();\n } else {\n C4990ab.m7417i(\"MicroMsg.AppBrandVideoWrapper\", \"%d use last common video view !\", Integer.valueOf(hashCode()));\n this.hZY.stop();\n i2 = 0;\n }\n } else if (this.hZY instanceof CommonVideoView) {\n this.hZY.stop();\n this.hZY.cpU();\n removeView((View) this.hZY);\n C4990ab.m7417i(\"MicroMsg.AppBrandVideoWrapper\", \"%d use mm video view !\", Integer.valueOf(hashCode()));\n this.hZY = aFU();\n } else {\n C4990ab.m7417i(\"MicroMsg.AppBrandVideoWrapper\", \"%d use last mm video view !\", Integer.valueOf(hashCode()));\n this.hZY.stop();\n i2 = 0;\n }\n setScaleType(this.iab);\n mo61579as(this.iac);\n setMute(this.fdh);\n if (i2 != 0) {\n setVideoFooterView(this.iaa);\n addView((View) this.hZY, new LayoutParams(-1, -1));\n }\n this.hZY.mo9063c(this.bkJ, this.url, this.iad);\n C7305d.post(new C383972(), \"AppBrandVideo_checkVideoUrl\");\n AppMethodBeat.m2505o(131589);\n }",
"private static android.util.Pair<com.google.android.exoplayer2.Format, java.lang.Long> m26780a(com.google.android.exoplayer2.p366s0.p374y.C9043p.C9044a r20, java.lang.String r21) {\n /*\n r0 = r20\n byte[] r1 = r0.f19970d\n int r2 = r0.f19968b\n byte[] r1 = java.util.Arrays.copyOf(r1, r2)\n r2 = 4\n byte r3 = r1[r2]\n r3 = r3 & 255(0xff, float:3.57E-43)\n r4 = 5\n byte r5 = r1[r4]\n r5 = r5 & 255(0xff, float:3.57E-43)\n r6 = 6\n byte r6 = r1[r6]\n r6 = r6 & 255(0xff, float:3.57E-43)\n int r3 = r3 << r2\n int r7 = r5 >> 4\n r13 = r3 | r7\n r3 = r5 & 15\n int r3 = r3 << 8\n r14 = r3 | r6\n r3 = 7\n byte r5 = r1[r3]\n r5 = r5 & 240(0xf0, float:3.36E-43)\n int r5 = r5 >> r2\n r6 = 2\n if (r5 == r6) goto L_0x0043\n r6 = 3\n if (r5 == r6) goto L_0x003d\n if (r5 == r2) goto L_0x0037\n r2 = 1065353216(0x3f800000, float:1.0)\n r18 = 1065353216(0x3f800000, float:1.0)\n goto L_0x004c\n L_0x0037:\n int r2 = r14 * 121\n float r2 = (float) r2\n int r5 = r13 * 100\n goto L_0x0048\n L_0x003d:\n int r2 = r14 * 16\n float r2 = (float) r2\n int r5 = r13 * 9\n goto L_0x0048\n L_0x0043:\n int r2 = r14 * 4\n float r2 = (float) r2\n int r5 = r13 * 3\n L_0x0048:\n float r5 = (float) r5\n float r2 = r2 / r5\n r18 = r2\n L_0x004c:\n r10 = 0\n r11 = -1\n r12 = -1\n r15 = -1082130432(0xffffffffbf800000, float:-1.0)\n java.util.List r16 = java.util.Collections.singletonList(r1)\n r17 = -1\n r19 = 0\n java.lang.String r9 = \"video/mpeg2\"\n r8 = r21\n com.google.android.exoplayer2.Format r2 = com.google.android.exoplayer2.Format.m24871a(r8, r9, r10, r11, r12, r13, r14, r15, r16, r17, r18, r19)\n r5 = 0\n byte r3 = r1[r3]\n r3 = r3 & 15\n int r3 = r3 + -1\n if (r3 < 0) goto L_0x0092\n double[] r7 = f19949q\n int r8 = r7.length\n if (r3 >= r8) goto L_0x0092\n r5 = r7[r3]\n int r0 = r0.f19969c\n int r0 = r0 + 9\n byte r3 = r1[r0]\n r3 = r3 & 96\n int r3 = r3 >> r4\n byte r0 = r1[r0]\n r0 = r0 & 31\n if (r3 == r0) goto L_0x008b\n double r3 = (double) r3\n r7 = 4607182418800017408(0x3ff0000000000000, double:1.0)\n double r3 = r3 + r7\n int r0 = r0 + 1\n double r0 = (double) r0\n double r3 = r3 / r0\n double r5 = r5 * r3\n L_0x008b:\n r0 = 4696837146684686336(0x412e848000000000, double:1000000.0)\n double r0 = r0 / r5\n long r5 = (long) r0\n L_0x0092:\n java.lang.Long r0 = java.lang.Long.valueOf(r5)\n android.util.Pair r0 = android.util.Pair.create(r2, r0)\n return r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.exoplayer2.p366s0.p374y.C9043p.m26780a(com.google.android.exoplayer2.s0.y.p$a, java.lang.String):android.util.Pair\");\n }",
"private void m128166i() {\n boolean z;\n this.f104211a.f104243o = this.f104201K;\n this.f104211a.mo99796a(this.f104213c);\n this.f104211a.f104244p = this.f104200J;\n MvChoosePhotoFragment mvChoosePhotoFragment = this.f104211a;\n boolean z2 = false;\n if (this.f104224n == 1) {\n z = true;\n } else {\n z = false;\n }\n mvChoosePhotoFragment.f104144m = z;\n this.f104212b.mo99796a(this.f104214d);\n this.f104212b.f104151q = this.f104199I;\n this.f104212b.f104153s = this.f104202L;\n MvChoosePhotoFragment mvChoosePhotoFragment2 = this.f104211a;\n if (this.f104224n == 1) {\n z2 = true;\n }\n mvChoosePhotoFragment2.f104144m = z2;\n ArrayList arrayList = new ArrayList();\n if (this.f104195E == 2) {\n Intent intent = getIntent();\n if (intent != null) {\n arrayList.addAll(intent.getStringArrayListExtra(\"key_selected_video_path\"));\n }\n this.f104212b.mo99798a((List<String>) arrayList);\n this.f104211a.mo99798a((List<String>) arrayList);\n }\n this.f104233w.setText(getResources().getString(R.string.hs));\n Fragment a = getSupportFragmentManager().mo2644a(\"album_Fragment\");\n if (a == null) {\n this.f104235y = new MvChooseAlbumFragment();\n getSupportFragmentManager().mo2645a().mo2586a(R.id.aoy, this.f104235y, \"album_Fragment\").mo2604c();\n } else {\n this.f104235y = (MvChooseAlbumFragment) a;\n }\n Bundle bundle = new Bundle();\n bundle.putInt(\"key_support_flag\", this.f104198H);\n this.f104235y.setArguments(bundle);\n findViewById(R.id.us).setOnClickListener(new C40143p(this));\n this.f104235y.f104178g = new C40144q(this);\n m128167j();\n if (this.f104195E != 2) {\n this.f104212b.mo99803a((C40108b) new C40145r(this));\n }\n if (C40173d.f104443a.mo99939a(this.f104225o)) {\n m128160c((List<String>) arrayList);\n }\n }",
"public void mo5969f() {\n this.f5416fa.setVisibility(0);\n this.f5416fa.setImageBitmap(C1413m.f5711i);\n ObjectAnimator duration = ObjectAnimator.ofFloat(this.f5416fa, \"translationY\", new float[]{0.0f, -((float) C1413m.f5711i.getHeight())}).setDuration(350);\n ObjectAnimator duration2 = ObjectAnimator.ofFloat(this.f5416fa, \"alpha\", new float[]{1.0f, 0.9f, 0.8f, 0.7f, 0.55f, 0.35f, 0.2f, 0.1f, 0.0f, 0.0f, 0.0f, 0.0f, 0.0f}).setDuration(350);\n duration.start();\n duration2.start();\n long j = (long) 240;\n ObjectAnimator.ofFloat(this.f5386F, \"alpha\", new float[]{0.0f, 1.0f}).setDuration(j).start();\n ObjectAnimator.ofFloat(this.f5384D, \"alpha\", new float[]{0.0f, 1.0f}).setDuration(j).start();\n ObjectAnimator.ofFloat(this.f5385E, \"alpha\", new float[]{0.0f, 1.0f}).setDuration(j).start();\n this.f5384D.getTexView().setText(getResources().getString(R.string.pause));\n duration.addListener(new C1298Va(this));\n }",
"public void mo21809a(android.view.LayoutInflater r13, android.view.ViewGroup r14, android.os.Bundle r15, p256e.p258b.C6977a r16, android.view.SurfaceHolder r17) {\n /*\n r12 = this;\n r0 = r12\n r16.mo21761L_()\n int r1 = r16.mo21764b()\n r0.f24533e = r1\n int r1 = r16.mo21765c()\n r0.f24534f = r1\n float r1 = r16.mo21766d()\n r0.f24539k = r1\n r12.mo21870l()\n int r1 = r0.f24531c\n r2 = 0\n r3 = 1\n r4 = -1\n if (r1 != r4) goto L_0x0035\n boolean r1 = r0.f24519V\n if (r1 != 0) goto L_0x002c\n int r1 = r0.f24537i\n if (r1 == r4) goto L_0x002c\n int r1 = r0.f24538j\n if (r1 != r4) goto L_0x0042\n L_0x002c:\n int r1 = r0.f24533e\n r0.f24537i = r1\n int r1 = r0.f24534f\n r0.f24538j = r1\n goto L_0x0042\n L_0x0035:\n boolean r1 = r0.f24519V\n if (r1 != 0) goto L_0x0044\n int r1 = r0.f24537i\n if (r1 == r4) goto L_0x0044\n int r1 = r0.f24538j\n if (r1 != r4) goto L_0x0042\n goto L_0x0044\n L_0x0042:\n r8 = 0\n goto L_0x004b\n L_0x0044:\n r1 = 100\n r0.f24537i = r1\n r0.f24538j = r1\n r8 = 1\n L_0x004b:\n int r1 = r0.f24537i\n int r5 = r0.f24540l\n int r1 = r1 * r5\n r0.f24541m = r1\n int r1 = r0.f24538j\n int r5 = r0.f24540l\n int r1 = r1 * r5\n r0.f24542n = r1\n java.lang.String r1 = r12.mo21873o()\n int r5 = r0.f24537i\n int r6 = r0.f24538j\n e.c.c r1 = r12.mo21799a(r5, r6, r1, r3)\n r0.f24532d = r1\n e.c.c r1 = r0.f24532d\n r5 = r16\n r6 = r17\n e.c.i r1 = r1.mo21705a(r5, r6, r2)\n r0.f24530b = r1\n int r1 = r0.f24531c\n if (r1 != r4) goto L_0x0086\n r12.m36394W()\n e.c.i r1 = r0.f24530b\n int r4 = r0.f24537i\n int r5 = r0.f24538j\n r1.mo22056a(r4, r5)\n goto L_0x0092\n L_0x0086:\n e.c.i r5 = r0.f24530b\n int r6 = r0.f24537i\n int r7 = r0.f24538j\n r9 = r13\n r10 = r14\n r11 = r15\n r5.mo22057a(r6, r7, r8, r9, r10, r11)\n L_0x0092:\n r0.f24515R = r2\n r0.f24512O = r3\n r0.f24513P = r3\n e.c.i r1 = r0.f24530b\n java.io.File r1 = r1.mo22067h()\n java.lang.String r1 = r1.getAbsolutePath()\n r0.f24535g = r1\n e.c.i r1 = r0.f24530b\n r1.mo22069j()\n return\n */\n throw new UnsupportedOperationException(\"Method not decompiled: p256e.p259c.C6982a.mo21809a(android.view.LayoutInflater, android.view.ViewGroup, android.os.Bundle, e.b.a, android.view.SurfaceHolder):void\");\n }",
"public void mo8813a(int i, int i2) {\n if (i == 2) {\n C2331d.m10114a((Activity) C3720a.this, C2328a.ON_ERROR_SD_UNSET_MOVIE, (Bundle) null);\n } else if (i == 3) {\n C2331d.m10114a((Activity) C3720a.this, C2328a.ON_ERROR_SD_LOCK_MOVIE, (Bundle) null);\n } else if (i == 4) {\n C2331d.m10114a((Activity) C3720a.this, C2328a.ON_ERROR_SD_REPAIRED_MOVIE, (Bundle) null);\n } else if (i2 == 2) {\n C2331d.m10114a((Activity) C3720a.this, C2328a.ON_ERROR_SD_UNSET_PICTURE, (Bundle) null);\n } else if (i2 == 3) {\n C2331d.m10114a((Activity) C3720a.this, C2328a.ON_ERROR_SD_LOCK_PICTURE, (Bundle) null);\n } else if (i2 == 4) {\n C2331d.m10114a((Activity) C3720a.this, C2328a.ON_ERROR_SD_REPAIRED_PICTURE, (Bundle) null);\n } else if (i != 1 || i2 != 1) {\n } else {\n if (C2331d.m10125b((Activity) C3720a.this, C2328a.ON_ERROR_SD_UNSET_MOVIE) || C2331d.m10125b((Activity) C3720a.this, C2328a.ON_ERROR_SD_LOCK_MOVIE) || C2331d.m10125b((Activity) C3720a.this, C2328a.ON_ERROR_SD_REPAIRED_MOVIE) || C2331d.m10125b((Activity) C3720a.this, C2328a.ON_ERROR_SD_UNSET_PICTURE) || C2331d.m10125b((Activity) C3720a.this, C2328a.ON_ERROR_SD_LOCK_PICTURE) || C2331d.m10125b((Activity) C3720a.this, C2328a.ON_ERROR_SD_REPAIRED_PICTURE)) {\n C2331d.m10100a((Activity) C3720a.this);\n }\n }\n }",
"public final /* synthetic */ Object mo71541z() throws Exception {\n this.f74253i.mo60157b(R.id.a8y, new VideoDiggWidget(this.f73944a, new C28186n(this))).mo60157b(R.id.ec0, new VideoDescWidget()).mo60157b(R.id.ajl, C28677a.m94348b().mo71731a()).mo60157b(R.id.j3, new FeedAvatarWidget()).mo60157b(R.id.d5b, new VideoShareWidget()).mo60157b(R.id.ze, new VideoCommentWidget());\n mo71772t();\n return null;\n }",
"private void m110495a() {\n C19535g a = DownloaderManagerHolder.m75524a();\n String x = C25352e.m83241x(this.f89235a.f89233a.f77546j);\n Aweme aweme = this.f89235a.f89233a.f77546j;\n C7573i.m23582a((Object) aweme, \"mAweme\");\n AwemeRawAd awemeRawAd = aweme.getAwemeRawAd();\n if (awemeRawAd == null) {\n C7573i.m23580a();\n }\n C7573i.m23582a((Object) awemeRawAd, \"mAweme.awemeRawAd!!\");\n Long adId = awemeRawAd.getAdId();\n C7573i.m23582a((Object) adId, \"mAweme.awemeRawAd!!.adId\");\n long longValue = adId.longValue();\n Aweme aweme2 = this.f89235a.f89233a.f77546j;\n C7573i.m23582a((Object) aweme2, \"mAweme\");\n C19386b a2 = C22943b.m75511a(\"result_ad\", aweme2.getAwemeRawAd(), \"bg_download_button\");\n Aweme aweme3 = this.f89235a.f89233a.f77546j;\n C7573i.m23582a((Object) aweme3, \"mAweme\");\n AwemeRawAd awemeRawAd2 = aweme3.getAwemeRawAd();\n if (awemeRawAd2 == null) {\n C7573i.m23580a();\n }\n a.mo51670a(x, longValue, 2, a2, C22942a.m75508a(awemeRawAd2));\n }",
"public String mo1736b() {\n return \"video\";\n }",
"interface C1939a {\n /* renamed from: a */\n Bitmap mo1406a(Bitmap bitmap, float f);\n}",
"public AnonymousClass13V(java.lang.String r5, java.lang.String r6, android.media.MediaCodecInfo.CodecCapabilities r7, boolean r8, boolean r9, boolean r10) {\n /*\n r4 = this;\n r4.<init>()\n if (r5 == 0) goto L_0x005c\n r4.A02 = r5\n r4.A01 = r6\n r4.A00 = r7\n r4.A05 = r8\n r3 = 1\n if (r9 != 0) goto L_0x0021\n if (r7 == 0) goto L_0x0021\n int r1 = X.AnonymousClass0W2.A00\n r0 = 19\n if (r1 < r0) goto L_0x0021\n java.lang.String r0 = \"adaptive-playback\"\n boolean r1 = r7.isFeatureSupported(r0)\n r0 = 1\n if (r1 != 0) goto L_0x0022\n L_0x0021:\n r0 = 0\n L_0x0022:\n r4.A03 = r0\n r2 = 21\n if (r7 == 0) goto L_0x0036\n int r0 = X.AnonymousClass0W2.A00\n if (r0 < r2) goto L_0x0036\n java.lang.String r0 = \"tunneled-playback\"\n boolean r1 = r7.isFeatureSupported(r0)\n r0 = 1\n if (r1 != 0) goto L_0x0037\n L_0x0036:\n r0 = 0\n L_0x0037:\n r4.A07 = r0\n if (r10 != 0) goto L_0x004a\n if (r7 == 0) goto L_0x005a\n int r0 = X.AnonymousClass0W2.A00\n if (r0 < r2) goto L_0x005a\n java.lang.String r0 = \"secure-playback\"\n boolean r0 = r7.isFeatureSupported(r0)\n if (r0 == 0) goto L_0x005a\n L_0x004a:\n r4.A06 = r3\n java.lang.String r1 = X.C233415j.A02(r6)\n java.lang.String r0 = \"video\"\n boolean r0 = r0.equals(r1)\n r4.A04 = r0\n return\n L_0x005a:\n r3 = 0\n goto L_0x004a\n L_0x005c:\n r0 = 0\n throw r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: X.AnonymousClass13V.<init>(java.lang.String, java.lang.String, android.media.MediaCodecInfo$CodecCapabilities, boolean, boolean, boolean):void\");\n }",
"public void onFinishInflate() {\n super.onFinishInflate();\n this.o = getResources().getDimensionPixelSize(R.dimen.view_dimen_1000);\n this.p = getResources().getDimensionPixelSize(R.dimen.view_dimen_561);\n this.f5336c = (TextView) findViewById(R.id.title);\n this.f5337d = (TextView) findViewById(R.id.video_repeat);\n this.e = (RelativeLayout) findViewById(R.id.video_container);\n this.f = (ImageView) findViewById(R.id.banner);\n this.i = (ShowTextCountTextView) findViewById(R.id.content);\n this.m = (ImageView) findViewById(R.id.sounds_btn);\n this.i.setTexColor(getResources().getColor(R.color.color_black_trans_40));\n this.j = (DataNetVideoPlayBtn) findViewById(R.id.video_play_btn);\n this.n = (RelativeLayout) findViewById(R.id.jump_view);\n this.r = (PlayerView) findViewById(R.id.player_view);\n this.r.setControllerVisibilityListener(this);\n this.r.requestFocus();\n if (Build.VERSION.SDK_INT < 26) {\n ((SurfaceView) this.r.getVideoSurfaceView()).getHolder().setFormat(-3);\n }\n this.j.setOnClickListener(this);\n this.m.setOnClickListener(this);\n this.i.setOnClickListener(this);\n this.n.setOnClickListener(this);\n this.f5337d.setOnClickListener(this);\n this.s = a(true);\n this.v = new DefaultTrackSelector.ParametersBuilder().build();\n this.l = (ImageView) findViewById(R.id.loading);\n this.k = ObjectAnimator.ofFloat(this.l, AnimatedProperty.PROPERTY_NAME_ROTATION, new float[]{0.0f, 719.0f});\n this.k.setDuration(3000);\n this.k.setRepeatCount(-1);\n this.k.setInterpolator(new LinearInterpolator());\n }",
"public interface AbstractC1528b extends BaseView {\n /* renamed from: a */\n SurfaceTexture mo17015a();\n\n /* renamed from: a */\n void mo17016a(int i);\n\n /* renamed from: a */\n void mo17017a(int i, int i2);\n\n /* renamed from: a */\n void mo17018a(int i, int i2, int i3);\n\n /* renamed from: b */\n C1529a mo17019b();\n\n /* renamed from: b */\n void mo17020b(int i);\n\n /* renamed from: c */\n void mo17021c();\n\n /* renamed from: c */\n void mo17022c(int i);\n\n /* renamed from: d */\n void mo17023d();\n }",
"private void m8132a() {\n this.f6227a.setScaleType(ScaleType.FIT_XY);\n addView(this.f6227a, new LayoutParams(-2, -2));\n C2322j.m9044a(this.f6227a, C2322j.INTERNAL_AD_MEDIA);\n }",
"public void mo63047b(String str) {\n String str2;\n String str3;\n String str4;\n String str5;\n super.mo63047b(str);\n if (C25352e.m83221d(this.f77546j)) {\n this.f89203a.mo65916c();\n C24961b e = C24958f.m81905a().mo65273b(this.f77546j).mo65266a(\"result_ad\").mo65276b(\"play_over\").mo65283e(\"video\");\n Aweme aweme = this.f77546j;\n C7573i.m23582a((Object) aweme, \"mAweme\");\n Video video = aweme.getVideo();\n C7573i.m23582a((Object) video, \"mAweme.video\");\n e.mo65271b((long) video.getVideoLength()).mo65270a(mo75261ab());\n this.f89214bh++;\n C28418f a = C28418f.m93413a();\n C7573i.m23582a((Object) a, \"FeedSharePlayInfoHelper.inst()\");\n a.f74936f = this.f89214bh;\n if (this.f89214bh >= this.f89215bi) {\n C28418f a2 = C28418f.m93413a();\n C7573i.m23582a((Object) a2, \"FeedSharePlayInfoHelper.inst()\");\n if (!a2.f74934d) {\n Aweme aweme2 = this.f77546j;\n C7573i.m23582a((Object) aweme2, \"mAweme\");\n AwemeRawAd awemeRawAd = aweme2.getAwemeRawAd();\n if (awemeRawAd != null) {\n str3 = awemeRawAd.getWebUrl();\n } else {\n str3 = null;\n }\n if (TextUtils.isEmpty(str3)) {\n C24961b b = C24958f.m81905a().mo65273b(this.f77546j).mo65266a(\"result_ad\").mo65276b(\"play\");\n if (!C25352e.m83224g(this.f77546j) || !TextUtils.equals(mo75290r(), \"general_search\")) {\n str4 = \"\";\n } else {\n str4 = \"video\";\n }\n b.mo65283e(str4).mo65270a(mo75261ab());\n return;\n } else if (mo75314al()) {\n mo75311ai();\n return;\n } else {\n this.f89215bi++;\n C24961b b2 = C24958f.m81905a().mo65273b(this.f77546j).mo65266a(\"result_ad\").mo65276b(\"play\");\n if (!C25352e.m83224g(this.f77546j) || !TextUtils.equals(mo75290r(), \"general_search\")) {\n str5 = \"\";\n } else {\n str5 = \"video\";\n }\n b2.mo65283e(str5).mo65270a(mo75261ab());\n return;\n }\n }\n }\n C24961b b3 = C24958f.m81905a().mo65273b(this.f77546j).mo65266a(\"result_ad\").mo65276b(\"play\");\n if (!C25352e.m83224g(this.f77546j) || !TextUtils.equals(mo75290r(), \"general_search\")) {\n str2 = \"\";\n } else {\n str2 = \"video\";\n }\n b3.mo65283e(str2).mo65270a(mo75261ab());\n }\n }",
"private void m6669y() {\n long currentTimeMillis = System.currentTimeMillis();\n long j = this.f5381A;\n if (currentTimeMillis - j > 200 || j == 0) {\n this.f5381A = currentTimeMillis;\n AudioManager audioManager = this.f5405Y;\n if (audioManager != null) {\n if (this.f5414ea) {\n audioManager.setParameters(\"audio_recordaec_enable=0\");\n this.f5410ca.setImageResource(R.drawable.btn_aec_off_selector);\n this.f5414ea = false;\n C1492b.m7433a((Context) AppFeature.m6734b(), getResources().getString(R.string.aec_close), 0);\n } else {\n audioManager.setParameters(\"audio_recordaec_enable=1\");\n this.f5410ca.setImageResource(R.drawable.btn_aec_on_selector);\n this.f5414ea = true;\n C1492b.m7433a((Context) AppFeature.m6734b(), getResources().getString(R.string.aec_open), 0);\n }\n C1387D.m6763a(this.f5414ea);\n }\n }\n }",
"public final void cpk() {\n String gj;\n LayoutParams layoutParams;\n AppMethodBeat.m2504i(37315);\n View findViewById = this.contentView.findViewById(2131821333);\n findViewById.setBackgroundColor(WebView.NIGHT_MODE_COLOR);\n int i = this.ieu;\n int i2 = this.iev;\n if (((C3947z) this.qZo).qXw == 1) {\n if (((int) ((C3947z) this.qZo).width) > 0) {\n i2 = (i * ((int) ((C3947z) this.qZo).height)) / ((int) ((C3947z) this.qZo).width);\n }\n findViewById.setLayoutParams(new LayoutParams(i, i2));\n findViewById.setMinimumHeight(i2);\n this.raL = (AdLandingVideoWrapper) findViewById.findViewById(2131821402);\n this.raL.setIMMVideoViewCallback(this);\n this.raL.setOnClickListener(this.rbm);\n this.raL.mo9063c(false, ((C3947z) this.qZo).qWH, 0);\n this.raL.setIsShowBasicControls(true);\n this.gtI = (ProgressBar) findViewById.findViewById(2131821219);\n this.mOX = (ImageView) findViewById.findViewById(2131821511);\n gj = C13473h.m21625gj(\"adId\", ((C3947z) this.qZo).qXv);\n if (!C5730e.m8628ct(gj)) {\n this.rbb = false;\n }\n if (this.rbb) {\n C13473h.m21623c(\"adId\", ((C3947z) this.qZo).qXv, false, 1000000001, new C134585());\n } else {\n this.mOX.setImageBitmap(MMBitmapFactory.decodeFile(gj));\n }\n this.raQ = (TextView) findViewById.findViewById(2131827572);\n this.raQ.setText(this.context.getString(C25738R.string.b6p));\n this.iVh = findViewById.findViewById(2131827636);\n this.iVh.setVisibility(4);\n this.raM = new VideoPlayerSeekBar(this.context);\n this.raM.setVisibility(4);\n if (this.rbi != null) {\n this.rbi.mo15469lb(this.raM.getVisibility() == 0);\n }\n this.raM.setIplaySeekCallback(this);\n this.raM.setOnPlayButtonClickListener(this.rbj);\n layoutParams = new LayoutParams(i - C1338a.fromDPToPix(this.context, 30), -2);\n layoutParams.addRule(12);\n this.raM.setLayoutParams(layoutParams);\n this.raL.setVideoFooterView(this.raM);\n this.raN = (ImageView) findViewById.findViewById(2131827637);\n this.raN.setVisibility(4);\n this.raN.setOnClickListener(this.rbk);\n this.raN.setPadding(0, 0, C1338a.fromDPToPix(this.context, 8), 0);\n this.raP = (ImageView) findViewById.findViewById(2131820981);\n this.raP.setImageDrawable(C1338a.m2864g(this.context, C1318a.shortvideo_play_btn));\n this.raP.setVisibility(8);\n this.raP.setOnClickListener(this.rbl);\n ((ViewGroup) this.raM.getParent()).removeView(this.raM);\n layoutParams.bottomMargin = 0;\n ((ViewGroup) findViewById).addView(this.raM, layoutParams);\n this.raL.setVideoPlayCallback(new C134676());\n AppMethodBeat.m2505o(37315);\n }\n findViewById.setPadding((int) ((C3947z) this.qZo).qWS, (int) ((C3947z) this.qZo).qWQ, (int) ((C3947z) this.qZo).qWT, (int) ((C3947z) this.qZo).qWR);\n findViewById.setLayoutParams(new LayoutParams(i, i2));\n findViewById.setMinimumHeight(i2);\n this.raL = (AdLandingVideoWrapper) findViewById.findViewById(2131821402);\n this.raL.setIMMVideoViewCallback(this);\n this.raL.setOnClickListener(this.rbm);\n this.raL.mo9063c(false, ((C3947z) this.qZo).qWH, 0);\n this.raL.setIsShowBasicControls(true);\n this.gtI = (ProgressBar) findViewById.findViewById(2131821219);\n this.mOX = (ImageView) findViewById.findViewById(2131821511);\n gj = C13473h.m21625gj(\"adId\", ((C3947z) this.qZo).qXv);\n if (C5730e.m8628ct(gj)) {\n }\n if (this.rbb) {\n }\n this.raQ = (TextView) findViewById.findViewById(2131827572);\n this.raQ.setText(this.context.getString(C25738R.string.b6p));\n this.iVh = findViewById.findViewById(2131827636);\n this.iVh.setVisibility(4);\n this.raM = new VideoPlayerSeekBar(this.context);\n this.raM.setVisibility(4);\n if (this.rbi != null) {\n }\n this.raM.setIplaySeekCallback(this);\n this.raM.setOnPlayButtonClickListener(this.rbj);\n layoutParams = new LayoutParams(i - C1338a.fromDPToPix(this.context, 30), -2);\n layoutParams.addRule(12);\n this.raM.setLayoutParams(layoutParams);\n this.raL.setVideoFooterView(this.raM);\n this.raN = (ImageView) findViewById.findViewById(2131827637);\n this.raN.setVisibility(4);\n this.raN.setOnClickListener(this.rbk);\n this.raN.setPadding(0, 0, C1338a.fromDPToPix(this.context, 8), 0);\n this.raP = (ImageView) findViewById.findViewById(2131820981);\n this.raP.setImageDrawable(C1338a.m2864g(this.context, C1318a.shortvideo_play_btn));\n this.raP.setVisibility(8);\n this.raP.setOnClickListener(this.rbl);\n ((ViewGroup) this.raM.getParent()).removeView(this.raM);\n layoutParams.bottomMargin = 0;\n ((ViewGroup) findViewById).addView(this.raM, layoutParams);\n this.raL.setVideoPlayCallback(new C134676());\n AppMethodBeat.m2505o(37315);\n }",
"private void a(android.graphics.SurfaceTexture r18) {\n /*\n r17 = this;\n r1 = 1\n java.lang.Object[] r2 = new java.lang.Object[r1]\n r9 = 0\n r2[r9] = r18\n com.meituan.robust.ChangeQuickRedirect r4 = f53248e\n java.lang.Class[] r7 = new java.lang.Class[r1]\n java.lang.Class<android.graphics.SurfaceTexture> r3 = android.graphics.SurfaceTexture.class\n r7[r9] = r3\n java.lang.Class r8 = java.lang.Void.TYPE\n r5 = 0\n r6 = 55476(0xd8b4, float:7.7738E-41)\n r3 = r17\n boolean r2 = com.meituan.robust.PatchProxy.isSupport(r2, r3, r4, r5, r6, r7, r8)\n if (r2 == 0) goto L_0x0034\n java.lang.Object[] r10 = new java.lang.Object[r1]\n r10[r9] = r18\n com.meituan.robust.ChangeQuickRedirect r12 = f53248e\n r13 = 0\n r14 = 55476(0xd8b4, float:7.7738E-41)\n java.lang.Class[] r15 = new java.lang.Class[r1]\n java.lang.Class<android.graphics.SurfaceTexture> r0 = android.graphics.SurfaceTexture.class\n r15[r9] = r0\n java.lang.Class r16 = java.lang.Void.TYPE\n r11 = r17\n com.meituan.robust.PatchProxy.accessDispatch(r10, r11, r12, r13, r14, r15, r16)\n return\n L_0x0034:\n r2 = r17\n com.ss.android.ugc.aweme.live.alphaplayer.e$i r0 = r2.h\n java.lang.Object[] r10 = new java.lang.Object[r9]\n com.meituan.robust.ChangeQuickRedirect r12 = com.ss.android.ugc.aweme.live.alphaplayer.e.i.f53268a\n r13 = 0\n r14 = 55514(0xd8da, float:7.7792E-41)\n java.lang.Class[] r15 = new java.lang.Class[r9]\n java.lang.Class r16 = java.lang.Void.TYPE\n r11 = r0\n boolean r3 = com.meituan.robust.PatchProxy.isSupport(r10, r11, r12, r13, r14, r15, r16)\n if (r3 == 0) goto L_0x005c\n java.lang.Object[] r10 = new java.lang.Object[r9]\n com.meituan.robust.ChangeQuickRedirect r12 = com.ss.android.ugc.aweme.live.alphaplayer.e.i.f53268a\n r13 = 0\n r14 = 55514(0xd8da, float:7.7792E-41)\n java.lang.Class[] r15 = new java.lang.Class[r9]\n java.lang.Class r16 = java.lang.Void.TYPE\n r11 = r0\n com.meituan.robust.PatchProxy.accessDispatch(r10, r11, r12, r13, r14, r15, r16)\n return\n L_0x005c:\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r3 = g\n monitor-enter(r3)\n r0.f53272e = r1 // Catch:{ all -> 0x007e }\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r1 = g // Catch:{ all -> 0x007e }\n r1.notifyAll() // Catch:{ all -> 0x007e }\n L_0x0066:\n boolean r1 = r0.f53273f // Catch:{ all -> 0x007e }\n if (r1 == 0) goto L_0x007c\n boolean r1 = r0.f53269b // Catch:{ all -> 0x007e }\n if (r1 != 0) goto L_0x007c\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r1 = g // Catch:{ InterruptedException -> 0x0074 }\n r1.wait() // Catch:{ InterruptedException -> 0x0074 }\n goto L_0x0066\n L_0x0074:\n java.lang.Thread r1 = java.lang.Thread.currentThread() // Catch:{ all -> 0x007e }\n r1.interrupt() // Catch:{ all -> 0x007e }\n goto L_0x0066\n L_0x007c:\n monitor-exit(r3) // Catch:{ all -> 0x007e }\n return\n L_0x007e:\n r0 = move-exception\n monitor-exit(r3) // Catch:{ all -> 0x007e }\n throw r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.ss.android.ugc.aweme.live.alphaplayer.e.a(android.graphics.SurfaceTexture):void\");\n }",
"@Override\r\n\tpublic void onCreate(Bundle savedInstanceState) {\r\n\t\tsuper.onCreate(savedInstanceState);\r\n\t\tUtils.printLog(TAG, \"onCreate start 20160621\");\r\n\t\tresolver = getContentResolver();\r\n\t\tsetContentView(R.layout.video_player);\r\n\t\t\r\n\t\tmAmanager = (AudioManager) this.getSystemService(Context.AUDIO_SERVICE);\r\n\t\tsoundManager = TTvSoundManager.getInstance(this);\r\n\t\tmPicmanager = TTvPictureManager.getInstance(this);\r\n\t\tmTvmanager = TvManager.getInstance(this);\r\n\t\tmTTvmanager = TTvManager.getInstance(this);\r\n\t\tapplication = (MediaPlayerApplication) getApplication();\r\n\t\t\r\n\t\t\r\n\t\tmTTvmanager.addHandler(setSourceHandler, TTvUtils.TV_HANDLER_INDEX_TV_SET_SOURCE);\r\n\t\t\r\n\t\t// 切信源\r\n\t\tEnTCLInputSource curSource = TTvCommonManager.getInstance(this).getCurrentInputSource();\r\n\r\n\t\tUtils.printLog(TAG, \"onCreate curSource==\" + curSource);\r\n\t\tif (curSource != EnTCLInputSource.EN_TCL_STORAGE) {\r\n//\t\t\tTTvCommonManager.getInstance(this).setInputSource(EnTCLInputSource.EN_TCL_STORAGE);\r\n\t\t\tTTvCommonManager.getInstance(this).setInputSource(EnTCLInputSource.EN_TCL_STORAGE,true);\r\n\t\t\tUtils.printLog(TAG, \"setInputSource EN_TCL_STORAGE 1\");\r\n\t\t}else{\r\n\t\t\tisSourceChanged = true;\r\n\t\t\tUtils.printLog(TAG, \"InputSource EN_TCL_STORAGE 2\");\r\n\t\t}\r\n\t\t\r\n\t\t\r\n\r\n\t\tTDeviceInfo devinfo = TDeviceInfo.getInstance();\r\n\t\tclienttype = devinfo.getClientType(devinfo.getProjectID());\r\n\t\tUtils.printLog(TAG, \"clienttype is \" + clienttype);\r\n\t\tif (clienttype != null) {\r\n\t\t\tsplitArrayStrings = clienttype.split(\"-\");\r\n\t\t}\r\n\r\n\t\tif (!getPlayList(getIntent())) {\r\n\t\t\texitPlayforNoPlayList();\r\n\t\t\treturn;\r\n\t\t}\r\n\t\t/***先获取参数,确认是否启动极简播放器后,再show loading**/\r\n//\t\tshowWatingDialog(isSimple);\r\n\t\tif (mCurrIndex < 0) {\r\n\t\t\tmCurrIndex = 0;\r\n\t\t}\r\n\t\tUtils.printPlayList(mList);\r\n\t\tseekBarPopWindow = new SeekBarPopWindow(this, mMediaHanler);\r\n\t\tpopWindow = new NotePopupWindow(this, mMediaHanler);\r\n\t\tfindView();\r\n\t\tmVideoContrl = new IVideoPlayControlHandler(this);\r\n\t\tmVideoContrl.registerCallback(mCallback);\r\n\t\tapplication.setVideoContrl(mVideoContrl);\r\n\t\tmBookMark = new BookMarkDB(this);\r\n\t\tmSurfaceView = (SurfaceView) this.findViewById(R.id.surfaceView);\r\n\t\tholder = mSurfaceView.getHolder();\r\n\t\tholder.addCallback(mVideoContrl);\r\n\t\tholder.setType(SurfaceHolder.SURFACE_TYPE_PUSH_BUFFERS);\r\n\t\tmTime = new Timer();\r\n\t\tmTime.schedule(mTimerTask, 0, 1000);\r\n\t\t//startPlayEventTimer();\r\n\t\tIntentFilter intentFilter2 = new IntentFilter();\r\n\t\tintentFilter2.addAction(ConnectivityManager.CONNECTIVITY_ACTION);\r\n\t\tthis.registerReceiver(mConnectionChangeReceiver, intentFilter2);\r\n\r\n\t\tIntentFilter intentFilter3 = new IntentFilter();\r\n//\t\tintentFilter3.addAction(VideoPlayerUIConst.COLLECTION_OPERATE_DONE);\r\n\t\tintentFilter3.addAction(VideoPlayerUIConst.ATV_OSD_OPEN);\r\n\t\tintentFilter3.addAction(CommonConst.CLOSE_VIDEO_PLAY);\r\n\t\tintentFilter3.addAction(CommonConst.HOME_PRESSED);\r\n\t\tintentFilter3.addAction(CommonConst.STR_PORWER_CHANGE);\r\n\t\tintentFilter3.addAction(CommonConst.TV_PRESSED);\r\n\t\tintentFilter3.addAction(CommonConst.CHANGE_SOURCE_PRESSED);\r\n\t\tintentFilter3.addAction(Intent.ACTION_SHUTDOWN); \r\n\t\tintentFilter3.addAction(CommonConst.EXIT_3D);\r\n\t\tintentFilter3.addAction(CommonConst.HISTORYRECORD);\r\n\t\tintentFilter3.addAction(CommonConst.SOURCE_CHANGEandVOICEASS);\r\n\t\tintentFilter3.addAction(CommonConst.LanuageChange);\r\n\t\tintentFilter3.addAction(CommonConst.VIDEO_HDR_HLG_BROADCAST);\r\n\t\tthis.registerReceiver(myCollectionBroadcastReceiver, intentFilter3);\r\n\r\n\t\tIntentFilter intentFilter4 = new IntentFilter();\r\n\t\tintentFilter4.addAction(CommonConst.VOICE_CONTROL);\r\n\t\tthis.registerReceiver(mVoiceReceiver, intentFilter4);\r\n\t\tsendStopWidgetMusicBroadcast();\r\n\r\n\t\tif (isDMR) {\r\n\t\t\tmVideoContrl.setPlayType(VideoPlayerContrlConsts.MEDIA_SEQUENCE_PLAY);\r\n\t\t} else {\r\n\t\t\tmVideoContrl.setPlayType(getSavedPlayerType());\r\n\t\t}\r\n\r\n\t\tlistDialog = new VideoFileListDialog(this, mList, application);\r\n\t\tlistDialog.setCallback(this);\r\n\r\n\t\tmenuDialog = new VideoMenuSettingDialog(this, application);\r\n\t\tmenuDialog.setCallback(this);\r\n\t\t//设置屏幕保持唤醒\r\n\t\tPowerManager powerManager = (PowerManager) getSystemService(Context.POWER_SERVICE);\r\n\t\twakeLock = powerManager.newWakeLock(PowerManager.SCREEN_BRIGHT_WAKE_LOCK, \"VideoPlayer\");\r\n\t\t//退出屏保 \r\n\t\tint sysVersion = VERSION.SDK_INT; \r\n\t\tLog.v(TAG, \"onCreate sysVersion= \"+sysVersion);\r\n\t\tif (sysVersion>=17) {\r\n\t\t\t//退出屏保 minSdkVersion=\"17\"\r\n\t\t\tpowerManager.wakeUp(SystemClock.uptimeMillis());\r\n\t\t\tUtils.printLog(TAG, \"powerManager.wakeUp\");\r\n\t\t}\r\n\t\t\r\n\t\tint versionCode = Utils.getVersionCodeFromAPP(this);\r\n\t\tUtils.printLog(TAG, \"onCreate end ,versionCode=\"+versionCode);\r\n\t}",
"public C1442z5(int r10, java.lang.CharSequence r11, android.app.PendingIntent r12) {\n /*\n r9 = this;\n r0 = 0\n if (r10 != 0) goto L_0x0005\n r10 = r0\n goto L_0x000b\n L_0x0005:\n java.lang.String r1 = \"\"\n androidx.core.graphics.drawable.IconCompat r10 = androidx.core.graphics.drawable.IconCompat.m253b(r0, r1, r10)\n L_0x000b:\n android.os.Bundle r1 = new android.os.Bundle\n r1.<init>()\n r9.<init>()\n r2 = 1\n r9.f5266f = r2\n r9.f5262b = r10\n r3 = 0\n if (r10 == 0) goto L_0x0072\n int r4 = r10.f637a\n r5 = -1\n if (r4 != r5) goto L_0x0069\n int r6 = android.os.Build.VERSION.SDK_INT\n r7 = 23\n if (r6 < r7) goto L_0x0069\n java.lang.Object r4 = r10.f638b\n android.graphics.drawable.Icon r4 = (android.graphics.drawable.Icon) r4\n r7 = 28\n if (r6 < r7) goto L_0x0033\n int r4 = r4.getType()\n goto L_0x0069\n L_0x0033:\n java.lang.Class r6 = r4.getClass() // Catch:{ IllegalAccessException -> 0x0058, InvocationTargetException -> 0x0052, NoSuchMethodException -> 0x004c }\n java.lang.String r7 = \"getType\"\n java.lang.Class[] r8 = new java.lang.Class[r3] // Catch:{ IllegalAccessException -> 0x0058, InvocationTargetException -> 0x0052, NoSuchMethodException -> 0x004c }\n java.lang.reflect.Method r6 = r6.getMethod(r7, r8) // Catch:{ IllegalAccessException -> 0x0058, InvocationTargetException -> 0x0052, NoSuchMethodException -> 0x004c }\n java.lang.Object[] r7 = new java.lang.Object[r3] // Catch:{ IllegalAccessException -> 0x0058, InvocationTargetException -> 0x0052, NoSuchMethodException -> 0x004c }\n java.lang.Object r6 = r6.invoke(r4, r7) // Catch:{ IllegalAccessException -> 0x0058, InvocationTargetException -> 0x0052, NoSuchMethodException -> 0x004c }\n java.lang.Integer r6 = (java.lang.Integer) r6 // Catch:{ IllegalAccessException -> 0x0058, InvocationTargetException -> 0x0052, NoSuchMethodException -> 0x004c }\n int r4 = r6.intValue() // Catch:{ IllegalAccessException -> 0x0058, InvocationTargetException -> 0x0052, NoSuchMethodException -> 0x004c }\n goto L_0x0069\n L_0x004c:\n java.lang.StringBuilder r6 = new java.lang.StringBuilder\n r6.<init>()\n goto L_0x005d\n L_0x0052:\n java.lang.StringBuilder r6 = new java.lang.StringBuilder\n r6.<init>()\n goto L_0x005d\n L_0x0058:\n java.lang.StringBuilder r6 = new java.lang.StringBuilder\n r6.<init>()\n L_0x005d:\n java.lang.String r7 = \"Unable to get icon type \"\n r6.append(r7)\n r6.append(r4)\n r6.toString()\n r4 = -1\n L_0x0069:\n r5 = 2\n if (r4 != r5) goto L_0x0072\n int r10 = r10.mo739c()\n r9.f5269i = r10\n L_0x0072:\n java.lang.CharSequence r10 = p000.C0009a6.m17b(r11)\n r9.f5270j = r10\n r9.f5271k = r12\n r9.f5261a = r1\n r9.f5263c = r0\n r9.f5264d = r0\n r9.f5265e = r2\n r9.f5267g = r3\n r9.f5266f = r2\n r9.f5268h = r3\n return\n */\n throw new UnsupportedOperationException(\"Method not decompiled: p000.C1442z5.<init>(int, java.lang.CharSequence, android.app.PendingIntent):void\");\n }",
"Bitmap mo6659a(Context context, String str, C1492a aVar);",
"private static int convertLegacyAfMode(java.lang.String r1) {\n /*\n // Can't load method instructions: Load method exception: bogus opcode: 00e9 in method: android.hardware.camera2.legacy.LegacyResultMapper.convertLegacyAfMode(java.lang.String):int, dex: \n */\n throw new UnsupportedOperationException(\"Method not decompiled: android.hardware.camera2.legacy.LegacyResultMapper.convertLegacyAfMode(java.lang.String):int\");\n }",
"void mo21067a(Surface surface);",
"public interface C38399a {\n void aDF();\n\n void aEZ();\n\n boolean aFA();\n\n void aFD();\n\n void aFE();\n\n boolean aFF();\n\n void aFG();\n\n void aFH();\n\n boolean aFI();\n\n void aFN();\n\n void aFO();\n\n boolean aFR();\n\n void aFy();\n\n void hide();\n\n void onDestroy();\n\n void seek(int i);\n\n void setDanmakuBtnOnClickListener(C10555f c10555f);\n\n void setDanmakuBtnOpen(boolean z);\n\n void setExitFullScreenBtnOnClickListener(OnClickListener onClickListener);\n\n void setFullScreenBtnOnClickListener(OnClickListener onClickListener);\n\n void setIplaySeekCallback(C42594c c42594c);\n\n void setMuteBtnOnClickListener(OnClickListener onClickListener);\n\n void setMuteBtnState(boolean z);\n\n void setOnPlayButtonClickListener(OnClickListener onClickListener);\n\n void setOnUpdateProgressLenListener(C19512d c19512d);\n\n void setOnVisibilityChangedListener(C27129e c27129e);\n\n void setPlayBtnInCenterPosition(boolean z);\n\n void setShowControlProgress(boolean z);\n\n void setShowDanmakuBtn(boolean z);\n\n void setShowFullScreenBtn(boolean z);\n\n void setShowMuteBtn(boolean z);\n\n void setShowPlayBtn(boolean z);\n\n void setShowProgress(boolean z);\n\n void setStatePorter(C38400h c38400h);\n\n void setTitle(String str);\n }",
"public void mo5967d() {\n this.f5416fa.setVisibility(0);\n this.f5416fa.setImageBitmap(C1413m.f5711i);\n ObjectAnimator duration = ObjectAnimator.ofFloat(this.f5416fa, \"translationY\", new float[]{-((float) C1413m.f5711i.getHeight()), 0.0f}).setDuration(240);\n ObjectAnimator duration2 = ObjectAnimator.ofFloat(this.f5416fa, \"alpha\", new float[]{0.0f, 0.2f, 0.3f, 0.4f, 0.5f, 0.6f, 0.7f, 0.8f, 0.9f, 1.0f}).setDuration(240);\n duration.start();\n duration2.start();\n long j = (long) 240;\n ObjectAnimator.ofFloat(this.f5436pa, \"alpha\", new float[]{1.0f, 0.9f, 0.8f, 0.7f, 0.6f, 0.5f, 0.4f, 0.3f, 0.2f, 0.0f}).setDuration(j).start();\n LinearLayout linearLayout = this.f5438qa;\n ObjectAnimator.ofFloat(linearLayout, \"translationY\", new float[]{0.0f, (float) ((linearLayout.getMeasuredHeight() - this.f5384D.getmImageViewHeight()) - C1413m.m6828a(27, this.f5389I))}).setDuration(j).start();\n ObjectAnimator.ofFloat(this.f5438qa, \"alpha\", new float[]{1.0f, 0.0f}).setDuration(j).start();\n duration.addListener(new C1304Ya(this));\n }",
"private final boolean m123459c(Bundle bundle) {\n List list;\n Workspace workspace;\n AVChallenge aVChallenge;\n C38892aa aaVar = new C38892aa();\n CutVideoViewModel cutVideoViewModel = this.f100413c;\n if (cutVideoViewModel == null) {\n C7573i.m23583a(\"cutVideoViewModel\");\n }\n cutVideoViewModel.mo97154a(aaVar);\n ArrayList arrayList = new ArrayList();\n C33153d a = C33153d.m106972a();\n MicroAppModel microAppModel = null;\n if (a != null) {\n list = a.mo84910c();\n } else {\n list = null;\n }\n if (list != null) {\n C33153d a2 = C33153d.m106972a();\n C7573i.m23582a((Object) a2, \"MediaManager.instance()\");\n arrayList = (ArrayList) a2.mo84910c();\n }\n String stringExtra = getIntent().getStringExtra(\"file_path\");\n if (getIntent().hasExtra(\"open_sdk_import_media_list\")) {\n arrayList = getIntent().getParcelableArrayListExtra(\"open_sdk_import_media_list\");\n C7573i.m23582a((Object) arrayList, \"intent.getParcelableArra…PEN_SDK_IMPORT_MEDIALIST)\");\n }\n if (!TextUtils.isEmpty(stringExtra) || !arrayList.isEmpty()) {\n aaVar.mo97167a(arrayList);\n aaVar.f100998b = stringExtra;\n aaVar.f100999c = C42017d.m133561a(getIntent().getIntExtra(\"shoot_mode\", -1));\n aaVar.f101000d = getIntent().getLongExtra(\"min_duration\", C39810eq.m127460a());\n if (bundle == null) {\n workspace = Workspace.m122801a();\n } else {\n workspace = (Workspace) bundle.getParcelable(\"workspace\");\n }\n aaVar.f101006j = workspace;\n String stringExtra2 = getIntent().getStringExtra(\"path\");\n if (!TextUtils.isEmpty(stringExtra2)) {\n Workspace workspace2 = aaVar.f101006j;\n if (workspace2 != null) {\n workspace2.mo96312a(new File(stringExtra2));\n }\n }\n if (getIntent().getSerializableExtra(\"av_challenge\") == null) {\n aVChallenge = null;\n } else {\n Serializable serializableExtra = getIntent().getSerializableExtra(\"av_challenge\");\n if (serializableExtra != null) {\n aVChallenge = (AVChallenge) serializableExtra;\n } else {\n throw new TypeCastException(\"null cannot be cast to non-null type com.ss.android.ugc.aweme.shortvideo.AVChallenge\");\n }\n }\n aaVar.f101001e = aVChallenge;\n aaVar.f101002f = getIntent().getStringExtra(\"micro_app_id\");\n if (getIntent().getSerializableExtra(\"micro_app_info\") != null) {\n Serializable serializableExtra2 = getIntent().getSerializableExtra(\"micro_app_info\");\n if (serializableExtra2 != null) {\n microAppModel = (MicroAppModel) serializableExtra2;\n } else {\n throw new TypeCastException(\"null cannot be cast to non-null type com.ss.android.ugc.aweme.shortvideo.edit.MicroAppModel\");\n }\n }\n aaVar.f101003g = microAppModel;\n aaVar.f101004h = getIntent().getSerializableExtra(\"micro_app_class\");\n aaVar.f101005i = getIntent().getBooleanExtra(\"enter_record_from_other_platform\", false);\n aaVar.f101007k = (ShareContext) getIntent().getSerializableExtra(\"extra_share_context\");\n aaVar.f101008l = getIntent().getStringExtra(\"shoot_way\");\n aaVar.f101009m = getIntent().getBooleanExtra(\"from_background_video\", false);\n aaVar.f101010n = getIntent().getLongExtra(\"background_video_max_length\", C40413c.f105051b);\n aaVar.f101011o = getIntent().getStringExtra(\"creation_id\");\n return true;\n }\n finish();\n return false;\n }",
"public void mo8809a(int i, boolean z, String str) {\n this._lastLiveViewMode = i;\n this._isPictureRecMode = z;\n C1347a.m5304a(this._lastLiveViewMode);\n getWindow().addFlags(128);\n this._context = this;\n this._handler = new Handler();\n this.f12124a = new Bundle();\n this.f12127d = new C3722a();\n this.f12125b = (C3733b) C2316j.m10030a(\"LiveViewMoviePantilterBaseViewModel\");\n if (this.f12125b == null) {\n this.f12125b = new C3733b(this._context, this._handler);\n this.f12125b.mo8853a(this._context, this._handler, (C3787a) this.f12127d);\n C2316j.m10032a(\"LiveViewMoviePantilterBaseViewModel\", this.f12125b);\n this.f12125b.mo8859b(this._lastLiveViewMode);\n } else {\n this.f12125b.mo8853a(this._context, this._handler, (C3787a) this.f12127d);\n }\n C2028e a = C2253z.m9680a((Context) null, false);\n if (a != null) {\n C1846e i2 = a.mo5285i();\n this.f12129f = str;\n if (i2 != null && i2.mo4656E() != null && i2.mo4656E().equalsIgnoreCase(\"manual\") && str.equalsIgnoreCase(\"manual\")) {\n Intent intent = new Intent(this._context, LiveViewMoviePantilterManualMovieActivity.class);\n Activity activity = (Activity) this._context;\n activity.finish();\n activity.startActivity(intent);\n activity.overridePendingTransition(0, 0);\n } else if (!(i2 == null || i2.mo4656E() == null || ((!C2274o.m9901g(i2.mo4656E()) && !C2274o.m9904j(i2.mo4656E()) && !C2274o.m9911q(i2.mo4656E()) && !C2274o.m9918x(i2.mo4656E()) && !C2274o.m9881E(i2.mo4656E()) && !C2274o.m9882F(i2.mo4656E()) && !C2274o.m9903i(i2.mo4656E())) || !str.equalsIgnoreCase(\"manual\")))) {\n Intent intent2 = new Intent(this._context, LiveViewMoviePantilterPresetActivity.class);\n Activity activity2 = (Activity) this._context;\n activity2.finish();\n activity2.startActivity(intent2);\n activity2.overridePendingTransition(0, 0);\n }\n }\n this._optionMenuUtil = new C2308e();\n this._optionMenuUtil.mo6072a(this, this._handler, this);\n this._tabMenuUtil = new C2311f();\n this.f12128e = new C3732b();\n this._tabMenuUtil.mo6085a(1, this);\n this._tabMenuUtil.mo6078a(this.f12128e);\n SetupCameraWatching(false, C2328a.DMS_FILEUPLOADED_NOTIFY, C2328a.DMS_FILEUPLOADING_ERROR, C2328a.ON_SUBSCRIBE_UPDATE);\n }",
"private int m128366a() {\n String c = C40173d.m128358c();\n if (!new File(c).exists()) {\n new File(c).mkdirs();\n }\n for (MediaModel mediaModel : this.f104446a) {\n String str = mediaModel.f88156b;\n C7573i.m23582a((Object) str, \"model.filePath\");\n if (C40173d.m128357b(str)) {\n Bitmap a = C40168a.f104413a.mo99928a(mediaModel.f88156b, 720, 1280);\n if (a != null) {\n StringBuilder sb = new StringBuilder();\n sb.append(c);\n sb.append(C40173d.m128354a(\".png\"));\n String sb2 = sb.toString();\n C42341f.m134636a(a, new File(sb2), 50, CompressFormat.PNG);\n C40168a.m128334a(a);\n mediaModel.f88156b = sb2;\n }\n }\n }\n return 0;\n }",
"public interface AbstractC1527a extends BaseView {\n /* renamed from: a */\n SurfaceTexture mo17006a();\n\n /* renamed from: a */\n void mo17007a(int i);\n\n /* renamed from: a */\n void mo17008a(int i, int i2);\n\n /* renamed from: a */\n void mo17009a(int i, int i2, int i3);\n\n /* renamed from: b */\n C1529a mo17010b();\n\n /* renamed from: b */\n void mo17011b(int i, int i2);\n\n /* renamed from: c */\n void mo17012c();\n\n /* renamed from: d */\n void mo17013d();\n\n /* renamed from: e */\n int mo17014e();\n }",
"private android.graphics.Bitmap m14713a(com.clevertap.android.sdk.C3072b1 r18, com.clevertap.android.sdk.C3072b1 r19) {\n /*\n r17 = this;\n r0 = r17\n r1 = r18\n r2 = r19\n int[] r10 = r0.f10958m\n r11 = 0\n if (r2 != 0) goto L_0x000e\n java.util.Arrays.fill(r10, r11)\n L_0x000e:\n r12 = 3\n r13 = 2\n r14 = 1\n if (r2 == 0) goto L_0x005e\n int r3 = r2.f10976g\n if (r3 <= 0) goto L_0x005e\n if (r3 != r13) goto L_0x0037\n boolean r3 = r1.f10975f\n if (r3 != 0) goto L_0x002c\n com.clevertap.android.sdk.c1 r3 = r0.f10961p\n int r4 = r3.f11004l\n int[] r5 = r1.f10980k\n if (r5 == 0) goto L_0x0033\n int r3 = r3.f11002j\n int r5 = r1.f10977h\n if (r3 != r5) goto L_0x0033\n goto L_0x0032\n L_0x002c:\n int r3 = r0.f10959n\n if (r3 != 0) goto L_0x0032\n r0.f10969x = r14\n L_0x0032:\n r4 = 0\n L_0x0033:\n r0.m14716a(r10, r2, r4)\n goto L_0x005e\n L_0x0037:\n if (r3 != r12) goto L_0x005e\n android.graphics.Bitmap r3 = r0.f10963r\n if (r3 != 0) goto L_0x0041\n r0.m14716a(r10, r2, r11)\n goto L_0x005e\n L_0x0041:\n int r4 = r2.f10973d\n int r5 = r0.f10966u\n int r9 = r4 / r5\n int r4 = r2.f10971b\n int r7 = r4 / r5\n int r4 = r2.f10972c\n int r8 = r4 / r5\n int r2 = r2.f10970a\n int r6 = r2 / r5\n int r5 = r0.f10968w\n int r2 = r7 * r5\n int r4 = r2 + r6\n r2 = r3\n r3 = r10\n r2.getPixels(r3, r4, r5, r6, r7, r8, r9)\n L_0x005e:\n r17.m14715a(r18)\n int r2 = r1.f10973d\n int r3 = r0.f10966u\n int r2 = r2 / r3\n int r4 = r1.f10971b\n int r4 = r4 / r3\n int r5 = r1.f10972c\n int r5 = r5 / r3\n int r6 = r1.f10970a\n int r6 = r6 / r3\n r3 = 8\n int r7 = r0.f10959n\n if (r7 != 0) goto L_0x0077\n r7 = 1\n goto L_0x0078\n L_0x0077:\n r7 = 0\n L_0x0078:\n r3 = 0\n r8 = 1\n r9 = 8\n L_0x007c:\n if (r11 >= r2) goto L_0x0100\n boolean r15 = r1.f10974e\n if (r15 == 0) goto L_0x0098\n r15 = 4\n if (r3 < r2) goto L_0x0095\n int r8 = r8 + 1\n if (r8 == r13) goto L_0x0094\n if (r8 == r12) goto L_0x0091\n if (r8 == r15) goto L_0x008e\n goto L_0x0095\n L_0x008e:\n r3 = 1\n r9 = 2\n goto L_0x0095\n L_0x0091:\n r3 = 2\n r9 = 4\n goto L_0x0095\n L_0x0094:\n r3 = 4\n L_0x0095:\n int r15 = r3 + r9\n goto L_0x009a\n L_0x0098:\n r15 = r3\n r3 = r11\n L_0x009a:\n int r3 = r3 + r4\n int r12 = r0.f10967v\n if (r3 >= r12) goto L_0x00f0\n int r12 = r0.f10968w\n int r3 = r3 * r12\n int r16 = r3 + r6\n int r13 = r16 + r5\n int r14 = r3 + r12\n if (r14 >= r13) goto L_0x00ad\n int r13 = r3 + r12\n L_0x00ad:\n int r3 = r0.f10966u\n int r12 = r11 * r3\n int r14 = r1.f10972c\n int r12 = r12 * r14\n int r14 = r13 - r16\n int r14 = r14 * r3\n int r14 = r14 + r12\n r3 = r16\n L_0x00bc:\n if (r3 >= r13) goto L_0x00f0\n r19 = r2\n int r2 = r0.f10966u\n r16 = r4\n r4 = 1\n if (r2 != r4) goto L_0x00d2\n byte[] r2 = r0.f10957l\n byte r2 = r2[r12]\n r2 = r2 & 255(0xff, float:3.57E-43)\n int[] r4 = r0.f10946a\n r2 = r4[r2]\n goto L_0x00d8\n L_0x00d2:\n int r2 = r1.f10972c\n int r2 = r0.m14712a(r12, r14, r2)\n L_0x00d8:\n if (r2 == 0) goto L_0x00dd\n r10[r3] = r2\n goto L_0x00e6\n L_0x00dd:\n boolean r2 = r0.f10969x\n if (r2 != 0) goto L_0x00e6\n if (r7 == 0) goto L_0x00e6\n r2 = 1\n r0.f10969x = r2\n L_0x00e6:\n int r2 = r0.f10966u\n int r12 = r12 + r2\n int r3 = r3 + 1\n r2 = r19\n r4 = r16\n goto L_0x00bc\n L_0x00f0:\n r19 = r2\n r16 = r4\n int r11 = r11 + 1\n r2 = r19\n r3 = r15\n r4 = r16\n r12 = 3\n r13 = 2\n r14 = 1\n goto L_0x007c\n L_0x0100:\n boolean r2 = r0.f10964s\n if (r2 == 0) goto L_0x0123\n int r1 = r1.f10976g\n if (r1 == 0) goto L_0x010b\n r2 = 1\n if (r1 != r2) goto L_0x0123\n L_0x010b:\n android.graphics.Bitmap r1 = r0.f10963r\n if (r1 != 0) goto L_0x0115\n android.graphics.Bitmap r1 = r17.m14718q()\n r0.f10963r = r1\n L_0x0115:\n android.graphics.Bitmap r1 = r0.f10963r\n r3 = 0\n int r7 = r0.f10968w\n r5 = 0\n r6 = 0\n int r8 = r0.f10967v\n r2 = r10\n r4 = r7\n r1.setPixels(r2, r3, r4, r5, r6, r7, r8)\n L_0x0123:\n android.graphics.Bitmap r9 = r17.m14718q()\n r3 = 0\n int r7 = r0.f10968w\n r5 = 0\n r6 = 0\n int r8 = r0.f10967v\n r1 = r9\n r2 = r10\n r4 = r7\n r1.setPixels(r2, r3, r4, r5, r6, r7, r8)\n return r9\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.clevertap.android.sdk.C3068a1.m14713a(com.clevertap.android.sdk.b1, com.clevertap.android.sdk.b1):android.graphics.Bitmap\");\n }",
"private boolean aYV() {\n /*\n r4 = this;\n r3 = 1;\n r2 = 0;\n r0 = com.android.common.custom.C0421M.dC();\n r0 = r0.dD();\n r0 = r0.bU();\n if (r0 != 0) goto L_0x001d;\n L_0x0010:\n r0 = r4.aiG;\n r0 = r0.SY();\n r0 = r0.tx();\n if (r0 == 0) goto L_0x001d;\n L_0x001c:\n return r2;\n L_0x001d:\n r0 = r4.aIO;\n if (r0 == 0) goto L_0x0041;\n L_0x0021:\n r0 = r4.aiG;\n r0 = r0.Td();\n r0 = r0.NF();\n if (r0 != 0) goto L_0x0041;\n L_0x002d:\n r0 = r4.aiG;\n r0 = r0.TE();\n r0 = r0.Ll();\n if (r0 == 0) goto L_0x0041;\n L_0x0039:\n r0 = r4.asP();\n r1 = com.android.common.camerastate.UIState.CAMERA_FAMILY;\n if (r0 != r1) goto L_0x0042;\n L_0x0041:\n return r2;\n L_0x0042:\n r0 = r4.aiG;\n r0 = r0.Td();\n r0 = r0.NP();\n if (r0 != 0) goto L_0x0041;\n L_0x004e:\n r0 = r4.asJ();\n r1 = com.android.common.camerastate.DeviceState.SNAPSHOT_IN_PROGRESS;\n if (r0 == r1) goto L_0x0041;\n L_0x0056:\n r0 = r4.aiG;\n r0 = r0.SQ();\n r1 = com.android.common.cameradevice.C0384o.Jr();\n r1 = r1.Jt();\n if (r0 != r1) goto L_0x0067;\n L_0x0066:\n return r2;\n L_0x0067:\n r0 = r4.aiG;\n r0 = r0.To();\n switch(r0) {\n case 0: goto L_0x0073;\n case 90: goto L_0x0084;\n case 180: goto L_0x0073;\n case 270: goto L_0x0084;\n default: goto L_0x0070;\n };\n L_0x0070:\n r0 = r4.aID;\n return r0;\n L_0x0073:\n r0 = r4.aIK;\n r0 = java.lang.Math.abs(r0);\n r1 = r4.aIJ;\n r1 = java.lang.Math.abs(r1);\n if (r0 <= r1) goto L_0x0070;\n L_0x0081:\n r4.aID = r3;\n goto L_0x0070;\n L_0x0084:\n r0 = r4.aIJ;\n r0 = java.lang.Math.abs(r0);\n r1 = r4.aIK;\n r1 = java.lang.Math.abs(r1);\n if (r0 <= r1) goto L_0x0070;\n L_0x0092:\n r4.aID = r3;\n goto L_0x0070;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.android.camera.Camera.aYV():boolean\");\n }",
"private SoundUtils() {}",
"public interface C1481i {\n /* renamed from: a */\n Bitmap mo6659a(Context context, String str, C1492a aVar);\n\n /* renamed from: a */\n void mo6660a(Context context, String str, ImageView imageView, C1492a aVar);\n\n /* renamed from: a */\n void mo6661a(boolean z);\n}",
"void mo80555a(MediaChooseResult mediaChooseResult);",
"public void mo68520e() {\n super.mo68520e();\n C26780aa.m87959a(this.itemView, mo75290r(), this.f77546j);\n C24942al.m81837c(mo75261ab(), this.f89221bo);\n C24958f.m81905a().mo65273b(this.f77546j).mo65266a(\"result_ad\").mo65276b(\"otherclick\").mo65283e(\"video\").mo65270a(mo75261ab());\n }",
"public void mo7192B() {\n View m = mo23948m();\n if (m != null) {\n this.f15664t0.onEnterDiscoverMode();\n boolean z = this.f15653i0 > 0;\n int i = this.f15653i0;\n m.performHapticFeedback(0);\n ObjectAnimator ofFloat = ObjectAnimator.ofFloat(this.f15643Y, View.TRANSLATION_Y, new float[]{0.0f, (float) (-C3200e0.m10183a((Context) mo23920b(), -100))});\n ObjectAnimator ofFloat2 = ObjectAnimator.ofFloat(this.f15643Y, View.ALPHA, new float[]{1.0f, 0.0f});\n ObjectAnimator ofFloat3 = ObjectAnimator.ofFloat(this.f15637S, View.TRANSLATION_X, new float[]{0.0f, (float) C3200e0.m10183a((Context) mo23920b(), -100)});\n ObjectAnimator ofFloat4 = ObjectAnimator.ofFloat(this.f15637S, View.ALPHA, new float[]{1.0f, 0.0f});\n ObjectAnimator ofFloat5 = ObjectAnimator.ofFloat(this.f15641W, View.TRANSLATION_X, new float[]{0.0f, (float) C3200e0.m10183a((Context) mo23920b(), 100)});\n ObjectAnimator ofFloat6 = ObjectAnimator.ofFloat(this.f15641W, View.ALPHA, new float[]{1.0f, 0.0f});\n ofFloat6.addListener(new C6250b());\n float scaleX = this.f15639U.getScaleX();\n ObjectAnimator ofFloat7 = ObjectAnimator.ofFloat(this.f15639U, View.SCALE_X, new float[]{1.0f, 0.0f});\n ofFloat7.setDuration(200);\n ofFloat7.setInterpolator(C7657c.m18641a());\n float scaleY = this.f15639U.getScaleY();\n ObjectAnimator ofFloat8 = ObjectAnimator.ofFloat(this.f15639U, View.SCALE_Y, new float[]{1.0f, 0.0f});\n ofFloat8.setDuration(200);\n ofFloat8.setInterpolator(C7657c.m18641a());\n ofFloat8.addListener(new C6251c(scaleX, scaleY));\n ObjectAnimator ofFloat9 = ObjectAnimator.ofFloat(this.f15646b0, View.SCALE_X, new float[]{0.0f, 1.0f});\n ofFloat9.setStartDelay(200);\n ofFloat9.setInterpolator(C7657c.m18650f());\n ObjectAnimator ofFloat10 = ObjectAnimator.ofFloat(this.f15646b0, View.SCALE_Y, new float[]{0.0f, 1.0f});\n ofFloat10.setStartDelay(200);\n ofFloat10.setInterpolator(C7657c.m18650f());\n ofFloat10.addListener(new C6252d(z, i));\n AnimatorSet animatorSet = new AnimatorSet();\n animatorSet.playTogether(new Animator[]{ofFloat, ofFloat2, ofFloat3, ofFloat4, ofFloat5, ofFloat6, ofFloat7, ofFloat8, ofFloat9, ofFloat10});\n animatorSet.start();\n this.f15651g0 = true;\n ((MeUserManager) this.f15668x0.get()).mo8754a(true);\n if (this.f15648d0.getComposition() == null) {\n C8507d.m19679a((Context) mo9304A(), (int) R.raw.lottie_discover_globe).mo23032b(new C6210h(this));\n }\n }\n }",
"private void update(){\n\n//\t\tif(frameSupplier != null){\n//\n//\t\t\tBufferedImage frame = frameSupplier.getFrame();\n//\n//\t\t\tvideoContainer.setIcon(new ImageIcon(frame));\n//\t\t\tvideoContainer.setText(null);\n//\n//\t\t}\n\n\t\tBufferedImage frame = camera.getImage();\n\t\tvideoContainer.setIcon(new ImageIcon(frame));\n\t\tvideoContainer.setText(null);\n\n\t\tgpioManager.setStatusColour(Color.getHSBColor((System.currentTimeMillis() % 3000) / 3000f, 1, 1));\n\n\t\tgpioManager.setShutterLEDState(System.currentTimeMillis() % 1000 > 500);\n\n\t\tjFrame.repaint();\n\t}",
"public final void mo75312aj() {\n super.mo75312aj();\n if (this.f77593aS != null && this.f77546j != null && C25352e.m83221d(this.f77546j)) {\n C24961b e = C24958f.m81905a().mo65273b(this.f77546j).mo65266a(\"result_ad\").mo65276b(\"play_break\").mo65283e(\"video\");\n C43222g gVar = this.f77593aS;\n C7573i.m23582a((Object) gVar, \"mPlayer\");\n C24961b a = e.mo65255a(gVar.mo104915n());\n Aweme aweme = this.f77546j;\n C7573i.m23582a((Object) aweme, \"mAweme\");\n Video video = aweme.getVideo();\n C7573i.m23582a((Object) video, \"mAweme.video\");\n a.mo65271b((long) video.getVideoLength()).mo65270a(mo75261ab());\n }\n }",
"public interface C32454c<T extends C32454c> {\n\n /* renamed from: com.ss.android.ugc.aweme.live.alphaplayer.c$a */\n public static class C32455a {\n /* renamed from: a */\n public static C32454c m105172a() {\n return new C32449b();\n }\n }\n\n /* renamed from: com.ss.android.ugc.aweme.live.alphaplayer.c$b */\n public interface C32456b<T> {\n /* renamed from: a */\n void mo83696a(T t);\n }\n\n /* renamed from: com.ss.android.ugc.aweme.live.alphaplayer.c$c */\n public interface C32457c<T> {\n /* renamed from: a */\n void mo83699a(T t, int i, int i2, String str);\n }\n\n /* renamed from: com.ss.android.ugc.aweme.live.alphaplayer.c$d */\n public interface C32458d<T> {\n /* renamed from: a */\n void mo83695a(T t);\n }\n\n /* renamed from: com.ss.android.ugc.aweme.live.alphaplayer.c$e */\n public interface C32459e<T> {\n /* renamed from: a */\n void mo83698a(T t);\n }\n\n /* renamed from: a */\n void mo21067a(Surface surface);\n\n /* renamed from: a */\n void mo83703a(C32456b<T> bVar);\n\n /* renamed from: a */\n void mo83704a(C32457c<T> cVar);\n\n /* renamed from: a */\n void mo83705a(C32458d<T> dVar);\n\n /* renamed from: a */\n void mo83706a(C32459e<T> eVar);\n\n /* renamed from: a */\n void mo21068a(String str) throws IOException;\n\n /* renamed from: a */\n void mo21069a(boolean z);\n\n /* renamed from: b */\n void mo21070b();\n\n /* renamed from: b */\n void mo21071b(boolean z);\n\n /* renamed from: c */\n void mo21072c();\n\n /* renamed from: d */\n void mo21073d();\n\n /* renamed from: e */\n void mo21074e();\n\n /* renamed from: f */\n void mo21075f();\n\n /* renamed from: g */\n void mo21076g();\n\n /* renamed from: h */\n C32446a mo21077h() throws Exception;\n\n /* renamed from: i */\n String mo21078i();\n}",
"private static int convertLegacyAwbMode(java.lang.String r1) {\n /*\n // Can't load method instructions: Load method exception: bogus opcode: 00e9 in method: android.hardware.camera2.legacy.LegacyResultMapper.convertLegacyAwbMode(java.lang.String):int, dex: \n */\n throw new UnsupportedOperationException(\"Method not decompiled: android.hardware.camera2.legacy.LegacyResultMapper.convertLegacyAwbMode(java.lang.String):int\");\n }",
"private String m568a(Context context, int i) {\r\n Camera open;\r\n Throwable th;\r\n String str = \"%2$d*%3$d\";\r\n String str2 = bi_常量类.f6358b_空串;\r\n float o = C0163a.m590o(context.getApplicationContext());\r\n Camera camera = null;\r\n try {\r\n open = Camera.open(i);\r\n try {\r\n List<Size> supportedPreviewSizes = open.getParameters().getSupportedPreviewSizes();\r\n Collections.sort(supportedPreviewSizes, new C0162a());\r\n int i2 = 0;\r\n for (Size size : supportedPreviewSizes) {\r\n if (size.width >= 600) {\r\n if ((((double) Math.abs((((float) size.width) / ((float) size.height)) - o)) <= 0.03d ? 1 : null) != null) {\r\n break;\r\n }\r\n }\r\n i2++;\r\n }\r\n String format = ((Size) supportedPreviewSizes.get(i2 == supportedPreviewSizes.size() ? supportedPreviewSizes.size() - 1 : i2)) != null ? String.format(Locale.ENGLISH, str, new Object[]{Integer.valueOf(i), Integer.valueOf(((Size) supportedPreviewSizes.get(i2 == supportedPreviewSizes.size() ? supportedPreviewSizes.size() - 1 : i2)).width), Integer.valueOf(((Size) supportedPreviewSizes.get(i2 == supportedPreviewSizes.size() ? supportedPreviewSizes.size() - 1 : i2)).height)}) : str2;\r\n if (open == null) {\r\n return format;\r\n }\r\n open.release();\r\n return format;\r\n } catch (RuntimeException e) {\r\n camera = open;\r\n if (camera != null) {\r\n camera.release();\r\n return str2;\r\n }\r\n return str2;\r\n } catch (Exception e2) {\r\n if (open != null) {\r\n open.release();\r\n return str2;\r\n }\r\n return str2;\r\n } catch (Throwable th2) {\r\n th = th2;\r\n if (open != null) {\r\n open.release();\r\n }\r\n throw th;\r\n }\r\n } catch (RuntimeException e3) {\r\n if (camera != null) {\r\n camera.release();\r\n return str2;\r\n }\r\n return str2;\r\n } catch (Exception e4) {\r\n open = null;\r\n if (open != null) {\r\n open.release();\r\n return str2;\r\n }\r\n return str2;\r\n } catch (Throwable th3) {\r\n open = null;\r\n th = th3;\r\n if (open != null) {\r\n open.release();\r\n }\r\n throw th;\r\n }\r\n }",
"public void setVideoProvider(java.lang.String r1, com.android.internal.telecom.IVideoProvider r2) {\n /*\n // Can't load method instructions: Load method exception: bogus opcode: 00e8 in method: android.telecom.ConnectionServiceAdapterServant.2.setVideoProvider(java.lang.String, com.android.internal.telecom.IVideoProvider):void, dex: \n */\n throw new UnsupportedOperationException(\"Method not decompiled: android.telecom.ConnectionServiceAdapterServant.2.setVideoProvider(java.lang.String, com.android.internal.telecom.IVideoProvider):void\");\n }",
"@androidx.annotation.Nullable\n /* renamed from: a */\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public static com.inmobi.media.C2336dl m4847a(@androidx.annotation.NonNull java.lang.String r3, @androidx.annotation.Nullable com.inmobi.media.C2600j r4, @androidx.annotation.Nullable java.lang.String r5, boolean r6) {\n /*\n com.iab.omid.library.inmobi.adsession.AdSessionContext r4 = m4846a(r4, r5)\n int r5 = r3.hashCode()\n r0 = -284840886(0xffffffffef05ac4a, float:-4.136979E28)\n r1 = 3\n r2 = 2\n if (r5 == r0) goto L_0x002e\n r0 = 112202875(0x6b0147b, float:6.6233935E-35)\n if (r5 == r0) goto L_0x0024\n r0 = 1425678798(0x54fa21ce, float:8.5944718E12)\n if (r5 == r0) goto L_0x001a\n goto L_0x0038\n L_0x001a:\n java.lang.String r5 = \"nonvideo\"\n boolean r3 = r3.equals(r5)\n if (r3 == 0) goto L_0x0038\n r3 = 2\n goto L_0x0039\n L_0x0024:\n java.lang.String r5 = \"video\"\n boolean r3 = r3.equals(r5)\n if (r3 == 0) goto L_0x0038\n r3 = 3\n goto L_0x0039\n L_0x002e:\n java.lang.String r5 = \"unknown\"\n boolean r3 = r3.equals(r5)\n if (r3 == 0) goto L_0x0038\n r3 = 1\n goto L_0x0039\n L_0x0038:\n r3 = -1\n L_0x0039:\n if (r3 == r2) goto L_0x0047\n if (r3 == r1) goto L_0x003f\n r3 = 0\n goto L_0x004e\n L_0x003f:\n com.inmobi.media.dm r3 = new com.inmobi.media.dm\n java.lang.String r5 = \"html_video_ad\"\n r3.<init>(r5, r4, r6)\n goto L_0x004e\n L_0x0047:\n com.inmobi.media.dm r3 = new com.inmobi.media.dm\n java.lang.String r5 = \"html_display_ad\"\n r3.<init>(r5, r4)\n L_0x004e:\n return r3\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.inmobi.media.C2341dp.m4847a(java.lang.String, com.inmobi.media.j, java.lang.String, boolean):com.inmobi.media.dl\");\n }",
"@Override // com.google.android.exoplayer2.upstream.DataReader\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public int read(byte[] r9, int r10, int r11) throws java.io.IOException {\n /*\n r8 = this;\n int r0 = r8.e\n r1 = -1\n if (r0 != 0) goto L_0x004e\n com.google.android.exoplayer2.upstream.DataSource r0 = r8.a\n byte[] r2 = r8.d\n r3 = 1\n r4 = 0\n int r0 = r0.read(r2, r4, r3)\n if (r0 != r1) goto L_0x0013\n L_0x0011:\n r3 = 0\n goto L_0x0046\n L_0x0013:\n byte[] r0 = r8.d\n byte r0 = r0[r4]\n r0 = r0 & 255(0xff, float:3.57E-43)\n int r0 = r0 << 4\n if (r0 != 0) goto L_0x001e\n goto L_0x0046\n L_0x001e:\n byte[] r2 = new byte[r0]\n r5 = r0\n r6 = 0\n L_0x0022:\n if (r5 <= 0) goto L_0x0030\n com.google.android.exoplayer2.upstream.DataSource r7 = r8.a\n int r7 = r7.read(r2, r6, r5)\n if (r7 != r1) goto L_0x002d\n goto L_0x0011\n L_0x002d:\n int r6 = r6 + r7\n int r5 = r5 - r7\n goto L_0x0022\n L_0x0030:\n if (r0 <= 0) goto L_0x003a\n int r4 = r0 + -1\n byte r5 = r2[r4]\n if (r5 != 0) goto L_0x003a\n r0 = r4\n goto L_0x0030\n L_0x003a:\n if (r0 <= 0) goto L_0x0046\n com.google.android.exoplayer2.source.IcyDataSource$Listener r4 = r8.c\n com.google.android.exoplayer2.util.ParsableByteArray r5 = new com.google.android.exoplayer2.util.ParsableByteArray\n r5.<init>(r2, r0)\n r4.onIcyMetadata(r5)\n L_0x0046:\n if (r3 == 0) goto L_0x004d\n int r0 = r8.b\n r8.e = r0\n goto L_0x004e\n L_0x004d:\n return r1\n L_0x004e:\n com.google.android.exoplayer2.upstream.DataSource r0 = r8.a\n int r2 = r8.e\n int r11 = java.lang.Math.min(r2, r11)\n int r9 = r0.read(r9, r10, r11)\n if (r9 == r1) goto L_0x0061\n int r10 = r8.e\n int r10 = r10 - r9\n r8.e = r10\n L_0x0061:\n return r9\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.exoplayer2.source.IcyDataSource.read(byte[], int, int):int\");\n }",
"public void mo5968e() {\n this.f5416fa.setVisibility(0);\n this.f5416fa.setImageBitmap(C1413m.f5711i);\n ObjectAnimator duration = ObjectAnimator.ofFloat(this.f5416fa, \"translationY\", new float[]{-((float) C1413m.f5711i.getHeight()), 0.0f}).setDuration(240);\n ObjectAnimator duration2 = ObjectAnimator.ofFloat(this.f5416fa, \"alpha\", new float[]{0.0f, 0.2f, 0.3f, 0.4f, 0.5f, 0.6f, 0.7f, 0.8f, 0.9f, 1.0f}).setDuration(240);\n duration.start();\n duration2.start();\n long j = (long) 160;\n ObjectAnimator.ofFloat(this.f5436pa, \"alpha\", new float[]{1.0f, 0.9f, 0.8f, 0.7f, 0.6f, 0.5f, 0.4f, 0.3f, 0.2f, 0.0f}).setDuration(j).start();\n ObjectAnimator.ofFloat(this.f5438qa, \"alpha\", new float[]{1.0f, 0.0f}).setDuration(j).start();\n duration.addListener(new C1302Xa(this));\n }",
"private void m106722c() {\n if (this.f86017d != null) {\n this.f86018e = (AnimationImageView) this.f86017d.findViewById(R.id.b9t);\n try {\n if (C43127fh.m136806a(this.f86017d.getContext())) {\n ((TextView) this.f86017d.findViewById(R.id.avl)).setText(R.string.bei);\n this.f86018e.setScaleX(-1.0f);\n }\n } catch (Exception unused) {\n }\n if (this.f86018e != null && !f86014a) {\n this.f86018e.setRepeatCount(3);\n this.f86018e.setAnimation(\"right_pic.json\");\n this.f86018e.setProgress(0.0f);\n this.f86018e.mo7078b();\n f86014a = true;\n m106725f();\n }\n }\n }",
"@Override\n public boolean onTouch(View v, MotionEvent event)\n {\n Uri rawUri = Uri.parse(\"android.resource://\" + getPackageName() + \"/\" + R.raw.a_0);\n videoView.setVideoURI(rawUri);\n videoView.start();\n return false;\n }",
"public void a(android.view.View r8) {\n /*\n r7 = this;\n r6 = 1;\n r4 = 8;\n r5 = 0;\n r1 = com.whatsapp.camera.CameraActivity.I;\n r0 = r7.b;\n r2 = 2131755404; // 0x7f10018c float:1.9141686E38 double:1.0532271105E-314;\n r0 = r0.findViewById(r2);\n r0.setVisibility(r4);\n r0 = r7.b;\n r2 = 2131755369; // 0x7f100169 float:1.9141615E38 double:1.053227093E-314;\n r0 = r0.findViewById(r2);\n r0.setVisibility(r4);\n r0 = r7.b;\n r0 = com.whatsapp.camera.CameraActivity.f(r0);\n r0 = r0.getText();\n r0 = r0.toString();\n r2 = com.whatsapp.a28.a(r0);\n r0 = r7.b;\n r0 = com.whatsapp.camera.CameraActivity.g(r0);\n if (r0 != 0) goto L_0x00f6;\n L_0x0038:\n r0 = r7.c;\n L_0x003a:\n r0 = r0.buildUpon();\n r3 = android.text.TextUtils.isEmpty(r2);\n if (r3 != 0) goto L_0x0056;\n L_0x0044:\n r3 = z;\n r3 = r3[r6];\n r0.appendQueryParameter(r3, r2);\n r2 = r7.b;\n r2 = com.whatsapp.camera.CameraActivity.f(r2);\n r2.setEnabled(r5);\n if (r1 == 0) goto L_0x0062;\n L_0x0056:\n r2 = r7.b;\n r3 = 2131755402; // 0x7f10018a float:1.9141682E38 double:1.0532271095E-314;\n r2 = r2.findViewById(r3);\n r2.setVisibility(r4);\n L_0x0062:\n r2 = r7.b;\n r2 = com.whatsapp.camera.CameraActivity.s(r2);\n if (r2 == 0) goto L_0x007c;\n L_0x006a:\n r2 = z;\n r3 = 5;\n r2 = r2[r3];\n r3 = r7.b;\n r3 = com.whatsapp.camera.CameraActivity.s(r3);\n r3 = java.lang.Integer.toString(r3);\n r0.appendQueryParameter(r2, r3);\n L_0x007c:\n r2 = r7.c;\n r3 = z;\n r4 = 7;\n r3 = r3[r4];\n r2 = r2.getQueryParameter(r3);\n if (r2 == 0) goto L_0x0093;\n L_0x0089:\n r2 = z;\n r2 = r2[r5];\n r3 = \"1\";\n r0.appendQueryParameter(r2, r3);\n L_0x0093:\n r0 = r0.build();\n r2 = r7.b;\n r2 = com.whatsapp.camera.CameraActivity.e(r2);\n if (r2 == 0) goto L_0x00b7;\n L_0x009f:\n r2 = r7.b;\n r3 = 2131755410; // 0x7f100192 float:1.9141698E38 double:1.0532271134E-314;\n r2 = r2.findViewById(r3);\n r2.setVisibility(r5);\n r2 = new com.whatsapp.camera.at;\n r2.<init>(r7, r0);\n r3 = new java.lang.Void[r5];\n com.whatsapp.util.bq.a(r2, r3);\n if (r1 == 0) goto L_0x00e6;\n L_0x00b7:\n r2 = new android.content.Intent;\n r3 = r7.b;\n r3 = r3.getBaseContext();\n r4 = com.whatsapp.ContactPicker.class;\n r2.<init>(r3, r4);\n r3 = z;\n r4 = 4;\n r3 = r3[r4];\n r2.setType(r3);\n r3 = z;\n r4 = 2;\n r3 = r3[r4];\n r2.putExtra(r3, r0);\n r0 = z;\n r3 = 6;\n r0 = r0[r3];\n r2.putExtra(r0, r6);\n r0 = r7.b;\n r0.startActivity(r2);\n r0 = r7.b;\n r0.finish();\n L_0x00e6:\n r0 = r7.b;\n r2 = r7.c;\n com.whatsapp.util.ag.a(r0, r2);\n r0 = com.whatsapp.WAAppCompatActivity.c;\n if (r0 == 0) goto L_0x00f5;\n L_0x00f1:\n r0 = r1 + 1;\n com.whatsapp.camera.CameraActivity.I = r0;\n L_0x00f5:\n return;\n L_0x00f6:\n r0 = z;\n r3 = 3;\n r0 = r0[r3];\n r0 = com.whatsapp.App.j(r0);\n r0 = android.net.Uri.fromFile(r0);\n goto L_0x003a;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.whatsapp.camera.s.a(android.view.View):void\");\n }",
"private static void m148172a(EditPreviewInfo editPreviewInfo, String[] strArr, long[] jArr, long[] jArr2, float[] fArr, long[] jArr3) {\n for (int i = 0; i < editPreviewInfo.getVideoList().size(); i++) {\n EditVideoSegment editVideoSegment = (EditVideoSegment) editPreviewInfo.getVideoList().get(i);\n strArr[i] = editVideoSegment.getVideoPath();\n if (editVideoSegment.getVideoCutInfo() != null) {\n VideoCutInfo videoCutInfo = editVideoSegment.getVideoCutInfo();\n jArr[i] = videoCutInfo.getStart();\n jArr2[i] = videoCutInfo.getEnd();\n fArr[i] = videoCutInfo.getSpeed();\n } else {\n jArr[i] = -1;\n jArr2[i] = -1;\n fArr[i] = 1.0f;\n }\n }\n if (editPreviewInfo.getSceneIn() > 0 || editPreviewInfo.getSceneOut() > 0) {\n jArr3[0] = editPreviewInfo.getSceneIn();\n jArr3[1] = editPreviewInfo.getSceneOut();\n return;\n }\n jArr3[0] = -1;\n jArr3[1] = -1;\n }",
"static /* synthetic */ short m311-set4(android.location.GpsClock r1, short r2) {\n /*\n // Can't load method instructions: Load method exception: bogus opcode: 00ee in method: android.location.GpsClock.-set4(android.location.GpsClock, short):short, dex: \n */\n throw new UnsupportedOperationException(\"Method not decompiled: android.location.GpsClock.-set4(android.location.GpsClock, short):short\");\n }",
"private static String m128157b(int i) {\n StringBuilder sb = new StringBuilder(\"android:switcher:\");\n sb.append(R.id.edp);\n sb.append(\":\");\n sb.append(i);\n return sb.toString();\n }",
"public void m2261I() {\n try {\n if (this.f2513n != null) {\n this.f2513n.setImageDrawable(C5150d.m3784a(mo61159b().getResources(), \"iVBORw0KGgoAAAANSUhEUgAAACAAAAAgCAYAAABzenr0AAAAGXRFWHRTb2Z0d2FyZQBBZG9iZSBJbWFnZVJlYWR5ccllPAAAA39pVFh0WE1MOmNvbS5hZG9iZS54bXAAAAAAADw/eHBhY2tldCBiZWdpbj0i77u/IiBpZD0iVzVNME1wQ2VoaUh6cmVTek5UY3prYzlkIj8+IDx4OnhtcG1ldGEgeG1sbnM6eD0iYWRvYmU6bnM6bWV0YS8iIHg6eG1wdGs9IkFkb2JlIFhNUCBDb3JlIDUuNi1jMDY3IDc5LjE1Nzc0NywgMjAxNS8wMy8zMC0yMzo0MDo0MiAgICAgICAgIj4gPHJkZjpSREYgeG1sbnM6cmRmPSJodHRwOi8vd3d3LnczLm9yZy8xOTk5LzAyLzIyLXJkZi1zeW50YXgtbnMjIj4gPHJkZjpEZXNjcmlwdGlvbiByZGY6YWJvdXQ9IiIgeG1sbnM6eG1wTU09Imh0dHA6Ly9ucy5hZG9iZS5jb20veGFwLzEuMC9tbS8iIHhtbG5zOnN0UmVmPSJodHRwOi8vbnMuYWRvYmUuY29tL3hhcC8xLjAvc1R5cGUvUmVzb3VyY2VSZWYjIiB4bWxuczp4bXA9Imh0dHA6Ly9ucy5hZG9iZS5jb20veGFwLzEuMC8iIHhtcE1NOk9yaWdpbmFsRG9jdW1lbnRJRD0ieG1wLmRpZDozODRkZTAxYi00OWRkLWM4NDYtYThkNC0wZWRiMDMwYTZlODAiIHhtcE1NOkRvY3VtZW50SUQ9InhtcC5kaWQ6QkE0Q0U2MUY2QzA0MTFFNUE3MkJGQjQ1MTkzOEYxQUUiIHhtcE1NOkluc3RhbmNlSUQ9InhtcC5paWQ6QkE0Q0U2MUU2QzA0MTFFNUE3MkJGQjQ1MTkzOEYxQUUiIHhtcDpDcmVhdG9yVG9vbD0iQWRvYmUgUGhvdG9zaG9wIENDIChXaW5kb3dzKSI+IDx4bXBNTTpEZXJpdmVkRnJvbSBzdFJlZjppbnN0YW5jZUlEPSJ4bXAuaWlkOjlkZjAyMGU0LTNlYmUtZTY0ZC04YjRiLWM5ZWY4MTU4ZjFhYyIgc3RSZWY6ZG9jdW1lbnRJRD0iYWRvYmU6ZG9jaWQ6cGhvdG9zaG9wOmU1MzEzNDdlLTZjMDEtMTFlNS1hZGZlLThmMTBjZWYxMGRiZSIvPiA8L3JkZjpEZXNjcmlwdGlvbj4gPC9yZGY6UkRGPiA8L3g6eG1wbWV0YT4gPD94cGFja2V0IGVuZD0iciI/PngNsEEAAANeSURBVHjatFfNS1tBEH+pUZOQ0B4i3sTSxHMRFNQoFBEP7dHgvyDiKWgguQra9F+oxqNiwOTQ+oFI1ZM3jSf1YK5FL41ooaKZzu+x+4gv2bx9Rgd+JNn5zO7s7IzH0CQiCvLHZ8YnxkfGe8ZbwS4zSowTxi/GT4/Hc2u8BLHjCOM745b06VboRJpx7GN8ZfyDxUqlQgcHB5RMJmloaIg6Ozupra3NBL5jDTzIQFYQdDOw5db5B8YxLDw+PtLKygr19PQQWDqIRqOUzWZNXUHH2rvBgr2M39C6uLig/v5+bcd2QLdUKskgYLNX57yvIL2zs0OhUOjZziU6Ojro8PBQBnGl3Alm+BknkMI54mybdS4BW3t7ezKIInzVCwDJYm4Zon4p5xLYzfPzcxlEpl7S3SNpmjlznZwQiXn/5CjEnTUzt5GBsbExamlpUfLBg0wjG8vLy3IXlqTzEAoH7m4kElEqTk1Nmfd7bW2tbhBYAw8ykFXZgQ9RJ1CsQghgEr/29/eVStPT09XFhdbX18nr9Vr81tZWyuVyFh+yMzMzSnvwJWjyDS+MYic2NzeV17O7u9vg2m79jsfjBv9bg7PbxOrqqjExMWHxIdvV1aW0V+VrFDtwhFCGh4cbnl0mk6kp+BsbGybsBNlGtkZGRqToEQK4xjfUc6csXlhYcHyFFhcXHe3Al6BrQz427e3tWldpfn5e6Rw83cIkHyvXAUAZb4SdsKZbPe0BaB+Bz+cjTiDlDmxtbZkybo9AKwn9fj9tb2875gBkINvIFnzJJMQ1PMV9GBgYUF6bQCBgFAoFY3x8/Ml6KpUy0un0kzXIQBY6KqrydapViPL5fM0/Rfcj+fhuJw5CqxBpleJYLEY3NzeW8dnZ2RoZrEmCLHQcSvGdWYrFe7CEFTwUqqjR85XLZUokEkoZ8CADWe3HqKoTcnyOdW5KI5m+vj56eHiQz3G0bkNyeXn5ag3J2dmZ/PffVC1Z8bVast3d3eqWLKDVlAaDwaadh8Nhvaa0XluOHg7n9lzn0MWRarfltp0oysEErRqGDTeDCbK9ajApuh7TxGiWERlrjWZzc3M0ODhYM5phDTzbaHb/rNHMFkhUNK13LobTv6K2RJ3se1yO519s4/k7wf5jG89/6I7n/wUYAGo3YtcprD4sAAAAAElFTkSuQmCC\"));\n this.f2513n.setScaleType(ScaleType.FIT_CENTER);\n }\n } catch (Exception e) {\n C5017f.m3256a(mo61159b(), C5015d.EXCEPTION, \"MraidMode.showDefaultCloseButton\", e.getMessage(), \"\");\n }\n }",
"public static int a(String str) {\n char c2;\n switch (str.hashCode()) {\n case -1933413040:\n if (str.equals(\"commonVideo\")) {\n c2 = 2;\n break;\n }\n case -1890252483:\n if (str.equals(\"sticker\")) {\n c2 = 6;\n break;\n }\n case -35510913:\n if (str.equals(\"fastVideo\")) {\n c2 = 0;\n break;\n }\n case 3357525:\n if (str.equals(\"more\")) {\n c2 = 10;\n break;\n }\n case 103652300:\n if (str.equals(\"macro\")) {\n c2 = 9;\n break;\n }\n case 104817688:\n if (str.equals(\"night\")) {\n c2 = 7;\n break;\n }\n case 729267099:\n if (str.equals(CameraStatisticsUtil.EVENT_CAPTURE)) {\n c2 = 4;\n break;\n }\n case 764302074:\n if (str.equals(\"slowVideo\")) {\n c2 = 1;\n break;\n }\n case 875077159:\n if (str.equals(\"professional\")) {\n c2 = 5;\n break;\n }\n case 1069983349:\n if (str.equals(\"panorama\")) {\n c2 = 3;\n break;\n }\n case 1401705245:\n if (str.equals(\"highPictureSize\")) {\n c2 = 8;\n break;\n }\n default:\n c2 = 65535;\n break;\n }\n switch (c2) {\n case 0:\n return R.string.camera_mode_fast_video;\n case 1:\n return R.string.camera_mode_slow_video;\n case 2:\n return R.string.camera_mode_video;\n case 3:\n return R.string.camera_mode_panorama;\n case 4:\n return R.string.camera_mode_portrait;\n case 5:\n return R.string.camera_mode_professional;\n case 6:\n return R.string.camera_mode_sticker;\n case 7:\n return R.string.camera_mode_night;\n case 8:\n return d();\n case 9:\n return R.string.camera_mode_super_macro;\n case 10:\n return R.string.camera_mode_more;\n default:\n return R.string.camera_mode_common;\n }\n }",
"private void m2011d(@C0193h0 C0370g gVar) {\n View view;\n C0365d dVar;\n int i;\n int i2;\n int i3;\n LayoutInflater from = LayoutInflater.from(this.f1290b);\n C0369f fVar = new C0369f(gVar, from, this.f1279Q, f1272m0);\n if (!mo1515d() && this.f1296g0) {\n fVar.mo1542a(true);\n } else if (mo1515d()) {\n fVar.mo1542a(C0383l.m2175b(gVar));\n }\n int a = C0383l.m2173a(fVar, null, this.f1290b, this.f1276N);\n C0508h0 h = m2012h();\n h.mo2100a((ListAdapter) fVar);\n h.mo2611f(a);\n h.mo2613g(this.f1287Y);\n if (this.f1282T.size() > 0) {\n List<C0365d> list = this.f1282T;\n dVar = (C0365d) list.get(list.size() - 1);\n view = m2008a(dVar, gVar);\n } else {\n dVar = null;\n view = null;\n }\n if (view != null) {\n h.mo2666e(false);\n h.mo2664a((Object) null);\n int d = m2010d(a);\n boolean z = d == 1;\n this.f1291b0 = d;\n if (VERSION.SDK_INT >= 26) {\n h.mo2601b(view);\n i2 = 0;\n i = 0;\n } else {\n int[] iArr = new int[2];\n this.f1288Z.getLocationOnScreen(iArr);\n int[] iArr2 = new int[2];\n view.getLocationOnScreen(iArr2);\n if ((this.f1287Y & 7) == 5) {\n iArr[0] = iArr[0] + this.f1288Z.getWidth();\n iArr2[0] = iArr2[0] + view.getWidth();\n }\n i = iArr2[0] - iArr[0];\n i2 = iArr2[1] - iArr[1];\n }\n if ((this.f1287Y & 5) != 5) {\n if (z) {\n a = view.getWidth();\n }\n i3 = i - a;\n h.mo2591a(i3);\n h.mo2607d(true);\n h.mo2599b(i2);\n } else if (!z) {\n a = view.getWidth();\n i3 = i - a;\n h.mo2591a(i3);\n h.mo2607d(true);\n h.mo2599b(i2);\n }\n i3 = i + a;\n h.mo2591a(i3);\n h.mo2607d(true);\n h.mo2599b(i2);\n } else {\n if (this.f1292c0) {\n h.mo2591a(this.f1294e0);\n }\n if (this.f1293d0) {\n h.mo2599b(this.f1295f0);\n }\n h.mo2592a(mo1766g());\n }\n this.f1282T.add(new C0365d(h, gVar, this.f1291b0));\n h.mo1509b();\n ListView f = h.mo1518f();\n f.setOnKeyListener(this);\n if (dVar == null && this.f1297h0 && gVar.mo1608i() != null) {\n FrameLayout frameLayout = (FrameLayout) from.inflate(C0238R.layout.abc_popup_menu_header_item_layout, f, false);\n TextView textView = (TextView) frameLayout.findViewById(16908310);\n frameLayout.setEnabled(false);\n textView.setText(gVar.mo1608i());\n f.addHeaderView(frameLayout, null, false);\n h.mo1509b();\n }\n }",
"private void m34671b(String str, Intent intent) {\n int i;\n AppMethodBeat.m2504i(6294);\n C4990ab.m7416i(\"MicroMsg.JsApiChooseMedia\", \"chooseMediaFromCamera\");\n if (str.equals(\"front\")) {\n i = 16;\n } else {\n i = 256;\n }\n intent.putExtra(\"key_pick_local_pic_capture\", i);\n this.hwd.ifE = this.hvq;\n C25985d.m41453a(this.hwd, \"webview\", \".ui.tools.OpenFileChooserUI\", intent, CdnLogic.kBizGeneric & hashCode(), false);\n AppMethodBeat.m2505o(6294);\n }",
"@Override\r\npublic void surfaceChanged(SurfaceHolder holder, int format, int width, int height) {\n\t\r\n}",
"public interface C3210f extends C11871b<DeletedProgramBroadcastReceiver> {\n\n /* renamed from: com.bamtechmedia.dominguez.channels.tv.f$a */\n /* compiled from: FeatureChannelModule_ProvidesWatchNextProgramBroadcastReceiver */\n public interface C3211a extends C11872a<DeletedProgramBroadcastReceiver> {\n }\n}",
"public interface C15428f {\n\n /* renamed from: com.ss.android.ugc.asve.context.f$a */\n public static final class C15429a {\n /* renamed from: a */\n public static String m45146a(C15428f fVar) {\n return \"\";\n }\n\n /* renamed from: b */\n public static String m45147b(C15428f fVar) {\n return \"\";\n }\n }\n\n /* renamed from: a */\n boolean mo38970a();\n\n /* renamed from: b */\n String mo38971b();\n\n /* renamed from: c */\n String mo38972c();\n\n /* renamed from: d */\n int mo38973d();\n\n /* renamed from: e */\n int mo38974e();\n}",
"public final void mo88395b() {\n if (this.f90938h == null) {\n this.f90938h = new C29242a(this.f90931a, this.f90937g).mo74873a((C39376h) new C39376h() {\n /* renamed from: a */\n public final void mo74759a(C29296g gVar) {\n }\n\n /* renamed from: a */\n public final void mo74760a(C29296g gVar, int i) {\n }\n\n /* renamed from: d */\n public final void mo74763d(C29296g gVar) {\n }\n\n /* renamed from: b */\n public final void mo74761b(C29296g gVar) {\n C34867a.this.f90934d.setVisibility(0);\n if (!C39805en.m127445a()) {\n C23487o.m77136a((Activity) C34867a.this.f90931a);\n }\n C6907h.m21519a((Context) C34867a.this.f90931a, \"filter_confirm\", \"mid_page\", \"0\", 0, C34867a.this.f90936f);\n }\n\n /* renamed from: c */\n public final void mo74762c(C29296g gVar) {\n String str;\n C34867a.this.f90933c = gVar;\n C34867a.this.f90932b.mo88467a(gVar.f77273h);\n if (C34867a.this.f90935e != null) {\n C34867a.this.f90935e.mo98958a(gVar);\n }\n EffectCategoryResponse b = C35563c.m114837d().mo74825b(C34867a.this.f90933c);\n if (b == null) {\n str = \"\";\n } else {\n str = b.name;\n }\n C6907h.m21524a(\"select_filter\", (Map) C38511bc.m123103a().mo96485a(\"creation_id\", C34867a.this.f90932b.mo88460a().creationId).mo96485a(\"shoot_way\", C34867a.this.f90932b.mo88460a().mShootWay).mo96483a(\"draft_id\", C34867a.this.f90932b.mo88460a().draftId).mo96485a(\"enter_method\", \"click\").mo96485a(\"filter_name\", C34867a.this.f90933c.f77268c).mo96483a(\"filter_id\", C34867a.this.f90933c.f77266a).mo96485a(\"tab_name\", str).mo96485a(\"content_source\", C34867a.this.f90932b.mo88460a().getAvetParameter().getContentSource()).mo96485a(\"content_type\", C34867a.this.f90932b.mo88460a().getAvetParameter().getContentType()).mo96485a(\"enter_from\", \"video_edit_page\").f100112a);\n }\n }).mo74871a((C29240bc) new C39369c(C35563c.f93224F.mo70097l().mo74950c().mo74723f())).mo74874a(this.f90932b.mo88460a().getAvetParameter()).mo74876a();\n if (this.f90933c != null) {\n this.f90938h.mo74751a(this.f90933c);\n }\n }\n this.f90938h.mo74749a();\n this.f90934d.setVisibility(8);\n }",
"private void mo71773u() {\n List imageInfos = this.f73950g.getImageInfos();\n if (imageInfos != null && !imageInfos.isEmpty()) {\n ImageInfo imageInfo = (ImageInfo) imageInfos.get(0);\n if (imageInfo != null) {\n this.mCoverView.setVisibility(0);\n this.mLineProgressBar.mo74361a();\n C23323e.m76524b(this.mCoverView, imageInfo.getLabelLarge());\n C23323e.m76502a(imageInfo.getLabelLarge(), (C23328a) new C23328a() {\n /* renamed from: a */\n public final void mo60609a(C13346c<C13326a<C13645c>> cVar) {\n FeedImageViewHolder.this.mLineProgressBar.mo74362b();\n }\n\n /* renamed from: a */\n public final void mo60610a(Exception exc) {\n FeedImageViewHolder.this.mLineProgressBar.mo74362b();\n }\n });\n }\n }\n }",
"private void b(com.whatsapp.protocol.co r15) {\n /*\n r14 = this;\n r8 = com.whatsapp.DialogToastActivity.f;\n r0 = r15.Q;\n r0 = (com.whatsapp.MediaData) r0;\n r1 = com.whatsapp.App.z();\n r2 = z;\n r3 = 9;\n r2 = r2[r3];\n r3 = r15.c;\n r4 = r15.r;\n r5 = 1;\n r3 = com.whatsapp.util.ag.a(r1, r2, r3, r4, r5);\n r1 = new com.whatsapp.akr;\n r2 = r0.file;\n r4 = r0.trimFrom;\n r6 = r0.trimTo;\n r1.<init>(r2, r3, r4, r6);\n r2 = new com.whatsapp.n3;\n r2.<init>(r14, r15, r0);\n r1.a(r2);\n r0.transcoder = r1;\n r4 = 0;\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x01df }\n r2 = r2.createNewFile();\t Catch:{ Exception -> 0x01df }\n if (r2 != 0) goto L_0x0057;\n L_0x0037:\n r2 = new java.lang.StringBuilder;\t Catch:{ Exception -> 0x01df }\n r2.<init>();\t Catch:{ Exception -> 0x01df }\n r5 = z;\t Catch:{ Exception -> 0x01df }\n r6 = 14;\n r5 = r5[r6];\t Catch:{ Exception -> 0x01df }\n r2 = r2.append(r5);\t Catch:{ Exception -> 0x01df }\n r5 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x01df }\n r5 = r5.getAbsolutePath();\t Catch:{ Exception -> 0x01df }\n r2 = r2.append(r5);\t Catch:{ Exception -> 0x01df }\n r2 = r2.toString();\t Catch:{ Exception -> 0x01df }\n com.whatsapp.util.Log.w(r2);\t Catch:{ Exception -> 0x01df }\n L_0x0057:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x01e1 }\n r2 = r2.getAbsolutePath();\t Catch:{ Exception -> 0x01e1 }\n com.whatsapp.VideoFrameConverter.setLogFilePath(r2);\t Catch:{ Exception -> 0x01e1 }\n L_0x0060:\n r2 = r14.b;\t Catch:{ Exception -> 0x01ed }\n if (r2 == 0) goto L_0x0069;\n L_0x0064:\n r2 = r14.b;\t Catch:{ Exception -> 0x01ed }\n r2.acquire();\t Catch:{ Exception -> 0x01ed }\n L_0x0069:\n r2 = r0.file;\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n r2 = com.whatsapp.akr.d(r2);\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n if (r2 == 0) goto L_0x00f1;\n L_0x0071:\n r6 = new com.whatsapp.util.a4;\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n r2 = r0.file;\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n r6.<init>(r2);\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n r7 = r6.a();\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n r9 = r6.d();\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n if (r7 < r9) goto L_0x0089;\n L_0x0082:\n r5 = 640; // 0x280 float:8.97E-43 double:3.16E-321;\n r2 = r9 * r5;\n r2 = r2 / r7;\n if (r8 == 0) goto L_0x008e;\n L_0x0089:\n r2 = 640; // 0x280 float:8.97E-43 double:3.16E-321;\n r5 = r7 * r2;\n r5 = r5 / r9;\n L_0x008e:\n r10 = r0.trimFrom;\t Catch:{ Exception -> 0x022c }\n r12 = 0;\n r7 = (r10 > r12 ? 1 : (r10 == r12 ? 0 : -1));\n if (r7 < 0) goto L_0x00cb;\n L_0x0096:\n r10 = r0.trimTo;\t Catch:{ Exception -> 0x022c }\n r12 = 0;\n r7 = (r10 > r12 ? 1 : (r10 == r12 ? 0 : -1));\n if (r7 <= 0) goto L_0x00cb;\n L_0x009e:\n r7 = r6.b();\t Catch:{ Exception -> 0x022e }\n if (r7 != 0) goto L_0x00ba;\n L_0x00a4:\n r7 = r0.file;\t Catch:{ Exception -> 0x0230 }\n r7 = com.whatsapp.akr.a(r7);\t Catch:{ Exception -> 0x0230 }\n if (r7 == 0) goto L_0x00ba;\n L_0x00ac:\n r7 = z;\t Catch:{ Exception -> 0x0232 }\n r9 = 12;\n r7 = r7[r9];\t Catch:{ Exception -> 0x0232 }\n com.whatsapp.util.Log.i(r7);\t Catch:{ Exception -> 0x0232 }\n r1.a();\t Catch:{ Exception -> 0x0232 }\n if (r8 == 0) goto L_0x00ef;\n L_0x00ba:\n r10 = r0.trimTo;\t Catch:{ Exception -> 0x0234 }\n r12 = r0.trimFrom;\t Catch:{ Exception -> 0x0234 }\n r10 = r10 - r12;\n r7 = com.whatsapp.util.ag.a(r5, r2, r10);\t Catch:{ Exception -> 0x0234 }\n r1.a(r7);\t Catch:{ Exception -> 0x0234 }\n r1.c();\t Catch:{ Exception -> 0x0234 }\n if (r8 == 0) goto L_0x00ef;\n L_0x00cb:\n r7 = r6.b();\t Catch:{ Exception -> 0x0236 }\n if (r7 != 0) goto L_0x00e1;\n L_0x00d1:\n r7 = z;\t Catch:{ Exception -> 0x0238 }\n r9 = 15;\n r7 = r7[r9];\t Catch:{ Exception -> 0x0238 }\n com.whatsapp.util.Log.i(r7);\t Catch:{ Exception -> 0x0238 }\n r7 = r0.file;\t Catch:{ Exception -> 0x0238 }\n com.whatsapp.util.ag.a(r7, r3);\t Catch:{ Exception -> 0x0238 }\n if (r8 == 0) goto L_0x00ef;\n L_0x00e1:\n r6 = r6.c();\t Catch:{ Exception -> 0x023a }\n r2 = com.whatsapp.util.ag.a(r5, r2, r6);\t Catch:{ Exception -> 0x023a }\n r1.a(r2);\t Catch:{ Exception -> 0x023a }\n r1.c();\t Catch:{ Exception -> 0x023a }\n L_0x00ef:\n if (r8 == 0) goto L_0x02d6;\n L_0x00f1:\n r6 = r0.trimFrom;\t Catch:{ Exception -> 0x0279 }\n r10 = 0;\n r2 = (r6 > r10 ? 1 : (r6 == r10 ? 0 : -1));\n if (r2 < 0) goto L_0x0106;\n L_0x00f9:\n r6 = r0.trimTo;\t Catch:{ Exception -> 0x027b }\n r10 = 0;\n r2 = (r6 > r10 ? 1 : (r6 == r10 ? 0 : -1));\n if (r2 <= 0) goto L_0x0106;\n L_0x0101:\n r1.a();\t Catch:{ Exception -> 0x027d }\n if (r8 == 0) goto L_0x02d6;\n L_0x0106:\n r2 = r0.file;\t Catch:{ Exception -> 0x027f }\n r6 = r2.length();\t Catch:{ Exception -> 0x027f }\n r6 = (double) r6;\t Catch:{ Exception -> 0x027f }\n r2 = com.whatsapp.a59.e;\t Catch:{ Exception -> 0x027f }\n r10 = (long) r2;\n r12 = 1048576; // 0x100000 float:1.469368E-39 double:5.180654E-318;\n r10 = r10 * r12;\n r10 = (double) r10;\n r12 = 4609434218613702656; // 0x3ff8000000000000 float:0.0 double:1.5;\n r10 = r10 * r12;\n r2 = (r6 > r10 ? 1 : (r6 == r10 ? 0 : -1));\n if (r2 >= 0) goto L_0x012c;\n L_0x011c:\n r2 = z;\t Catch:{ Exception -> 0x0281 }\n r5 = 13;\n r2 = r2[r5];\t Catch:{ Exception -> 0x0281 }\n com.whatsapp.util.Log.i(r2);\t Catch:{ Exception -> 0x0281 }\n r2 = r0.file;\t Catch:{ Exception -> 0x0281 }\n com.whatsapp.util.ag.a(r2, r3);\t Catch:{ Exception -> 0x0281 }\n if (r8 == 0) goto L_0x02d6;\n L_0x012c:\n r2 = new java.lang.IllegalArgumentException;\t Catch:{ Exception -> 0x0132 }\n r2.<init>();\t Catch:{ Exception -> 0x0132 }\n throw r2;\t Catch:{ Exception -> 0x0132 }\n L_0x0132:\n r2 = move-exception;\n throw r2;\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n L_0x0134:\n r2 = move-exception;\n r5 = z;\t Catch:{ all -> 0x0332 }\n r6 = 17;\n r5 = r5[r6];\t Catch:{ all -> 0x0332 }\n com.whatsapp.util.Log.b(r5, r2);\t Catch:{ all -> 0x0332 }\n b(r2);\t Catch:{ all -> 0x0332 }\n r2 = r14.a;\t Catch:{ all -> 0x0332 }\n r5 = new com.whatsapp.jz;\t Catch:{ all -> 0x0332 }\n r5.<init>(r14);\t Catch:{ all -> 0x0332 }\n r2.post(r5);\t Catch:{ all -> 0x0332 }\n r2 = 0;\n com.whatsapp.VideoFrameConverter.setLogFilePath(r2);\n r2 = r14.b;\n if (r2 == 0) goto L_0x0160;\n L_0x0153:\n r2 = r14.b;\t Catch:{ Exception -> 0x0380 }\n r2 = r2.isHeld();\t Catch:{ Exception -> 0x0380 }\n if (r2 == 0) goto L_0x0160;\n L_0x015b:\n r2 = r14.b;\t Catch:{ Exception -> 0x0380 }\n r2.release();\t Catch:{ Exception -> 0x0380 }\n L_0x0160:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x0382 }\n r2 = r2.exists();\t Catch:{ Exception -> 0x0382 }\n if (r2 == 0) goto L_0x016d;\n L_0x0168:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x0382 }\n r2.delete();\t Catch:{ Exception -> 0x0382 }\n L_0x016d:\n if (r4 == 0) goto L_0x01c8;\n L_0x016f:\n r0.file = r3;\t Catch:{ Exception -> 0x0398 }\n r2 = 1;\n r0.transcoded = r2;\t Catch:{ Exception -> 0x0398 }\n r2 = r0.file;\t Catch:{ Exception -> 0x0398 }\n r2 = r2.length();\t Catch:{ Exception -> 0x0398 }\n r0.fileSize = r2;\t Catch:{ Exception -> 0x0398 }\n r2 = r0.file;\t Catch:{ Exception -> 0x0398 }\n r2 = r2.getName();\t Catch:{ Exception -> 0x0398 }\n r15.A = r2;\t Catch:{ Exception -> 0x0398 }\n r2 = r0.fileSize;\t Catch:{ Exception -> 0x0398 }\n r15.z = r2;\t Catch:{ Exception -> 0x0398 }\n r2 = r0.file;\t Catch:{ Exception -> 0x0398 }\n r2 = com.whatsapp.util.ag.c(r2);\t Catch:{ Exception -> 0x0398 }\n r15.H = r2;\t Catch:{ Exception -> 0x0398 }\n r2 = r0.trimFrom;\t Catch:{ Exception -> 0x0398 }\n r4 = 0;\n r2 = (r2 > r4 ? 1 : (r2 == r4 ? 0 : -1));\n if (r2 <= 0) goto L_0x01b5;\n L_0x0198:\n com.whatsapp.util.bd.b(r15);\n r2 = r0.file;\n r2 = r2.getAbsolutePath();\n r2 = com.whatsapp.util.ag.b(r2);\n if (r2 == 0) goto L_0x01ac;\n L_0x01a7:\n r15.a(r2);\t Catch:{ Exception -> 0x039a }\n if (r8 == 0) goto L_0x01b5;\n L_0x01ac:\n r2 = z;\t Catch:{ Exception -> 0x039a }\n r3 = 20;\n r2 = r2[r3];\t Catch:{ Exception -> 0x039a }\n com.whatsapp.util.Log.w(r2);\t Catch:{ Exception -> 0x039a }\n L_0x01b5:\n r2 = com.whatsapp.App.aK;\t Catch:{ Exception -> 0x039c }\n r3 = 1;\n r4 = -1;\n r2.a(r15, r3, r4);\t Catch:{ Exception -> 0x039c }\n r2 = r14.a;\t Catch:{ Exception -> 0x039c }\n r3 = new com.whatsapp.o9;\t Catch:{ Exception -> 0x039c }\n r3.<init>(r14, r15);\t Catch:{ Exception -> 0x039c }\n r2.post(r3);\t Catch:{ Exception -> 0x039c }\n if (r8 == 0) goto L_0x01de;\n L_0x01c8:\n r2 = 0;\n r0.transferring = r2;\t Catch:{ Exception -> 0x039e }\n r2 = 0;\n r15.d = r2;\t Catch:{ Exception -> 0x039e }\n r1 = r1.h();\t Catch:{ Exception -> 0x039e }\n if (r1 == 0) goto L_0x01d7;\n L_0x01d4:\n r1 = 0;\n r0.autodownloadRetryEnabled = r1;\t Catch:{ Exception -> 0x039e }\n L_0x01d7:\n r0 = com.whatsapp.App.aK;\n r1 = 1;\n r2 = -1;\n r0.a(r15, r1, r2);\n L_0x01de:\n return;\n L_0x01df:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x01e1 }\n L_0x01e1:\n r2 = move-exception;\n r5 = z;\n r6 = 11;\n r5 = r5[r6];\n com.whatsapp.util.Log.b(r5, r2);\n goto L_0x0060;\n L_0x01ed:\n r2 = move-exception;\n throw r2;\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n L_0x01ef:\n r2 = move-exception;\n r5 = z;\t Catch:{ all -> 0x0332 }\n r6 = 18;\n r5 = r5[r6];\t Catch:{ all -> 0x0332 }\n com.whatsapp.util.Log.e(r5);\t Catch:{ all -> 0x0332 }\n b(r2);\t Catch:{ all -> 0x0332 }\n r2 = r14.a;\t Catch:{ all -> 0x0332 }\n r5 = new com.whatsapp.gw;\t Catch:{ all -> 0x0332 }\n r5.<init>(r14);\t Catch:{ all -> 0x0332 }\n r2.post(r5);\t Catch:{ all -> 0x0332 }\n r2 = 0;\n com.whatsapp.VideoFrameConverter.setLogFilePath(r2);\n r2 = r14.b;\n if (r2 == 0) goto L_0x021b;\n L_0x020e:\n r2 = r14.b;\t Catch:{ Exception -> 0x0384 }\n r2 = r2.isHeld();\t Catch:{ Exception -> 0x0384 }\n if (r2 == 0) goto L_0x021b;\n L_0x0216:\n r2 = r14.b;\t Catch:{ Exception -> 0x0384 }\n r2.release();\t Catch:{ Exception -> 0x0384 }\n L_0x021b:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x022a }\n r2 = r2.exists();\t Catch:{ Exception -> 0x022a }\n if (r2 == 0) goto L_0x016d;\n L_0x0223:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x022a }\n r2.delete();\t Catch:{ Exception -> 0x022a }\n goto L_0x016d;\n L_0x022a:\n r0 = move-exception;\n throw r0;\n L_0x022c:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x022e }\n L_0x022e:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x0230 }\n L_0x0230:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x0232 }\n L_0x0232:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x0234 }\n L_0x0234:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x0236 }\n L_0x0236:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x0238 }\n L_0x0238:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x023a }\n L_0x023a:\n r2 = move-exception;\n throw r2;\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n L_0x023c:\n r2 = move-exception;\n r5 = z;\t Catch:{ all -> 0x0332 }\n r6 = 19;\n r5 = r5[r6];\t Catch:{ all -> 0x0332 }\n com.whatsapp.util.Log.b(r5, r2);\t Catch:{ all -> 0x0332 }\n b(r2);\t Catch:{ all -> 0x0332 }\n r2 = r14.a;\t Catch:{ all -> 0x0332 }\n r5 = new com.whatsapp.aie;\t Catch:{ all -> 0x0332 }\n r5.<init>(r14);\t Catch:{ all -> 0x0332 }\n r2.post(r5);\t Catch:{ all -> 0x0332 }\n r2 = 0;\n com.whatsapp.VideoFrameConverter.setLogFilePath(r2);\n r2 = r14.b;\n if (r2 == 0) goto L_0x0268;\n L_0x025b:\n r2 = r14.b;\t Catch:{ Exception -> 0x0386 }\n r2 = r2.isHeld();\t Catch:{ Exception -> 0x0386 }\n if (r2 == 0) goto L_0x0268;\n L_0x0263:\n r2 = r14.b;\t Catch:{ Exception -> 0x0386 }\n r2.release();\t Catch:{ Exception -> 0x0386 }\n L_0x0268:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x0277 }\n r2 = r2.exists();\t Catch:{ Exception -> 0x0277 }\n if (r2 == 0) goto L_0x016d;\n L_0x0270:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x0277 }\n r2.delete();\t Catch:{ Exception -> 0x0277 }\n goto L_0x016d;\n L_0x0277:\n r0 = move-exception;\n throw r0;\n L_0x0279:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x027b }\n L_0x027b:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x027d }\n L_0x027d:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x027f }\n L_0x027f:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x0281 }\n L_0x0281:\n r2 = move-exception;\n throw r2;\t Catch:{ Exception -> 0x0132 }\n L_0x0283:\n r2 = move-exception;\n r5 = z;\t Catch:{ Exception -> 0x0388 }\n r6 = 21;\n r5 = r5[r6];\t Catch:{ Exception -> 0x0388 }\n com.whatsapp.util.Log.b(r5, r2);\t Catch:{ Exception -> 0x0388 }\n b(r2);\t Catch:{ Exception -> 0x0388 }\n r5 = r2.getMessage();\t Catch:{ Exception -> 0x0388 }\n if (r5 == 0) goto L_0x02b0;\n L_0x0296:\n r2 = r2.getMessage();\t Catch:{ Exception -> 0x0388 }\n r5 = z;\t Catch:{ Exception -> 0x0388 }\n r6 = 8;\n r5 = r5[r6];\t Catch:{ Exception -> 0x0388 }\n r2 = r2.contains(r5);\t Catch:{ Exception -> 0x0388 }\n if (r2 == 0) goto L_0x02b0;\n L_0x02a6:\n r2 = r14.a;\t Catch:{ Exception -> 0x038a }\n r5 = new com.whatsapp.aun;\t Catch:{ Exception -> 0x038a }\n r5.<init>(r14);\t Catch:{ Exception -> 0x038a }\n r2.post(r5);\t Catch:{ Exception -> 0x038a }\n L_0x02b0:\n r2 = 0;\n com.whatsapp.VideoFrameConverter.setLogFilePath(r2);\t Catch:{ Exception -> 0x038c }\n r2 = r14.b;\t Catch:{ Exception -> 0x038c }\n if (r2 == 0) goto L_0x02c5;\n L_0x02b8:\n r2 = r14.b;\t Catch:{ Exception -> 0x038c }\n r2 = r2.isHeld();\t Catch:{ Exception -> 0x038c }\n if (r2 == 0) goto L_0x02c5;\n L_0x02c0:\n r2 = r14.b;\t Catch:{ Exception -> 0x038e }\n r2.release();\t Catch:{ Exception -> 0x038e }\n L_0x02c5:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x02d4 }\n r2 = r2.exists();\t Catch:{ Exception -> 0x02d4 }\n if (r2 == 0) goto L_0x016d;\n L_0x02cd:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x02d4 }\n r2.delete();\t Catch:{ Exception -> 0x02d4 }\n goto L_0x016d;\n L_0x02d4:\n r0 = move-exception;\n throw r0;\n L_0x02d6:\n r2 = r1.h();\t Catch:{ Exception -> 0x0330 }\n if (r2 != 0) goto L_0x0356;\n L_0x02dc:\n r2 = com.whatsapp.util.b.e(r3);\t Catch:{ Exception -> 0x0330 }\n if (r2 == 0) goto L_0x02e5;\n L_0x02e2:\n r4 = 1;\n if (r8 == 0) goto L_0x0356;\n L_0x02e5:\n r2 = new java.lang.IllegalStateException;\t Catch:{ Exception -> 0x02f1 }\n r5 = z;\t Catch:{ Exception -> 0x02f1 }\n r6 = 16;\n r5 = r5[r6];\t Catch:{ Exception -> 0x02f1 }\n r2.<init>(r5);\t Catch:{ Exception -> 0x02f1 }\n throw r2;\t Catch:{ Exception -> 0x02f1 }\n L_0x02f1:\n r2 = move-exception;\n throw r2;\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n L_0x02f3:\n r2 = move-exception;\n r5 = z;\t Catch:{ all -> 0x0332 }\n r6 = 10;\n r5 = r5[r6];\t Catch:{ all -> 0x0332 }\n com.whatsapp.util.Log.b(r5, r2);\t Catch:{ all -> 0x0332 }\n b(r2);\t Catch:{ all -> 0x0332 }\n r2 = r14.a;\t Catch:{ all -> 0x0332 }\n r5 = new com.whatsapp.on;\t Catch:{ all -> 0x0332 }\n r5.<init>(r14);\t Catch:{ all -> 0x0332 }\n r2.post(r5);\t Catch:{ all -> 0x0332 }\n r2 = 0;\n com.whatsapp.VideoFrameConverter.setLogFilePath(r2);\n r2 = r14.b;\n if (r2 == 0) goto L_0x031f;\n L_0x0312:\n r2 = r14.b;\t Catch:{ Exception -> 0x0390 }\n r2 = r2.isHeld();\t Catch:{ Exception -> 0x0390 }\n if (r2 == 0) goto L_0x031f;\n L_0x031a:\n r2 = r14.b;\t Catch:{ Exception -> 0x0390 }\n r2.release();\t Catch:{ Exception -> 0x0390 }\n L_0x031f:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x032e }\n r2 = r2.exists();\t Catch:{ Exception -> 0x032e }\n if (r2 == 0) goto L_0x016d;\n L_0x0327:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x032e }\n r2.delete();\t Catch:{ Exception -> 0x032e }\n goto L_0x016d;\n L_0x032e:\n r0 = move-exception;\n throw r0;\n L_0x0330:\n r2 = move-exception;\n throw r2;\t Catch:{ IllegalStateException -> 0x0134, cq -> 0x01ef, FileNotFoundException -> 0x023c, IOException -> 0x0283, at_ -> 0x02f3 }\n L_0x0332:\n r0 = move-exception;\n r1 = 0;\n com.whatsapp.VideoFrameConverter.setLogFilePath(r1);\t Catch:{ Exception -> 0x0392 }\n r1 = r14.b;\t Catch:{ Exception -> 0x0392 }\n if (r1 == 0) goto L_0x0348;\n L_0x033b:\n r1 = r14.b;\t Catch:{ Exception -> 0x0394 }\n r1 = r1.isHeld();\t Catch:{ Exception -> 0x0394 }\n if (r1 == 0) goto L_0x0348;\n L_0x0343:\n r1 = r14.b;\t Catch:{ Exception -> 0x0394 }\n r1.release();\t Catch:{ Exception -> 0x0394 }\n L_0x0348:\n r1 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x0396 }\n r1 = r1.exists();\t Catch:{ Exception -> 0x0396 }\n if (r1 == 0) goto L_0x0355;\n L_0x0350:\n r1 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x0396 }\n r1.delete();\t Catch:{ Exception -> 0x0396 }\n L_0x0355:\n throw r0;\n L_0x0356:\n r2 = 0;\n com.whatsapp.VideoFrameConverter.setLogFilePath(r2);\t Catch:{ Exception -> 0x037c }\n r2 = r14.b;\t Catch:{ Exception -> 0x037c }\n if (r2 == 0) goto L_0x036b;\n L_0x035e:\n r2 = r14.b;\t Catch:{ Exception -> 0x037c }\n r2 = r2.isHeld();\t Catch:{ Exception -> 0x037c }\n if (r2 == 0) goto L_0x036b;\n L_0x0366:\n r2 = r14.b;\t Catch:{ Exception -> 0x037e }\n r2.release();\t Catch:{ Exception -> 0x037e }\n L_0x036b:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x037a }\n r2 = r2.exists();\t Catch:{ Exception -> 0x037a }\n if (r2 == 0) goto L_0x016d;\n L_0x0373:\n r2 = com.whatsapp.App.a5;\t Catch:{ Exception -> 0x037a }\n r2.delete();\t Catch:{ Exception -> 0x037a }\n goto L_0x016d;\n L_0x037a:\n r0 = move-exception;\n throw r0;\n L_0x037c:\n r0 = move-exception;\n throw r0;\t Catch:{ Exception -> 0x037e }\n L_0x037e:\n r0 = move-exception;\n throw r0;\n L_0x0380:\n r0 = move-exception;\n throw r0;\n L_0x0382:\n r0 = move-exception;\n throw r0;\n L_0x0384:\n r0 = move-exception;\n throw r0;\n L_0x0386:\n r0 = move-exception;\n throw r0;\n L_0x0388:\n r0 = move-exception;\n throw r0;\t Catch:{ Exception -> 0x038a }\n L_0x038a:\n r0 = move-exception;\n throw r0;\t Catch:{ all -> 0x0332 }\n L_0x038c:\n r0 = move-exception;\n throw r0;\t Catch:{ Exception -> 0x038e }\n L_0x038e:\n r0 = move-exception;\n throw r0;\n L_0x0390:\n r0 = move-exception;\n throw r0;\n L_0x0392:\n r0 = move-exception;\n throw r0;\t Catch:{ Exception -> 0x0394 }\n L_0x0394:\n r0 = move-exception;\n throw r0;\n L_0x0396:\n r0 = move-exception;\n throw r0;\n L_0x0398:\n r0 = move-exception;\n throw r0;\n L_0x039a:\n r0 = move-exception;\n throw r0;\n L_0x039c:\n r0 = move-exception;\n throw r0;\t Catch:{ Exception -> 0x039e }\n L_0x039e:\n r0 = move-exception;\n throw r0;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.whatsapp.tw.b(com.whatsapp.protocol.co):void\");\n }",
"public static final java.lang.String m133282a(com.p280ss.android.ugc.aweme.draft.model.C27311c r1) {\n /*\n java.lang.String r0 = \"draft\"\n kotlin.jvm.internal.C7573i.m23587b(r1, r0)\n boolean r0 = r1.mo70215ad()\n if (r0 == 0) goto L_0x001a\n com.ss.android.ugc.aweme.shortvideo.edit.model.EditPreviewInfo r1 = r1.mo70214ac()\n if (r1 == 0) goto L_0x0017\n java.lang.String r1 = r1.getDraftDir()\n if (r1 != 0) goto L_0x0019\n L_0x0017:\n java.lang.String r1 = \"\"\n L_0x0019:\n return r1\n L_0x001a:\n com.ss.android.ugc.aweme.photomovie.PhotoMovieContext r0 = r1.f72034c\n boolean r0 = com.p280ss.android.ugc.aweme.storage.p1640b.C41902b.m133264a(r0)\n if (r0 == 0) goto L_0x002b\n com.ss.android.ugc.aweme.draft.model.b r1 = r1.f72031S\n java.lang.String r1 = r1.f71951O\n if (r1 != 0) goto L_0x002a\n java.lang.String r1 = \"\"\n L_0x002a:\n return r1\n L_0x002b:\n com.ss.android.ugc.aweme.draft.model.b r1 = r1.f72031S\n java.lang.String r1 = r1.f71951O\n java.lang.String r1 = com.p280ss.android.ugc.aweme.shortvideo.WorkSpace.Workspace.m122803a(r1)\n if (r1 != 0) goto L_0x0037\n java.lang.String r1 = \"\"\n L_0x0037:\n return r1\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.p280ss.android.ugc.aweme.storage.p1640b.C41911c.m133282a(com.ss.android.ugc.aweme.draft.model.c):java.lang.String\");\n }",
"public void mo3108c() {\n this.f2612h = Mode.valueOf(this.f2613i);\n int i = this.f2605a;\n if (i != -1) {\n if (i != 1) {\n if (i != 2) {\n if (i == 3) {\n this.f2606b = this.f2607c;\n return;\n } else if (i != 4) {\n if (i != 5) {\n return;\n }\n }\n }\n this.f2606b = new String(this.f2607c, Charset.forName(\"UTF-16\"));\n return;\n }\n Parcelable parcelable = this.f2608d;\n if (parcelable != null) {\n this.f2606b = parcelable;\n return;\n }\n byte[] bArr = this.f2607c;\n this.f2606b = bArr;\n this.f2605a = 3;\n this.f2609e = 0;\n this.f2610f = bArr.length;\n return;\n }\n Parcelable parcelable2 = this.f2608d;\n if (parcelable2 != null) {\n this.f2606b = parcelable2;\n return;\n }\n throw new IllegalArgumentException(\"Invalid icon\");\n }",
"public final String mo102948e() {\n return \"shoot-video\";\n }",
"public void mo5964b() {\n this.f5416fa.setVisibility(0);\n this.f5416fa.setImageBitmap(C1413m.f5711i);\n ObjectAnimator duration = ObjectAnimator.ofFloat(this.f5416fa, \"translationY\", new float[]{0.0f, -((float) C1413m.f5711i.getHeight())}).setDuration(350);\n ObjectAnimator duration2 = ObjectAnimator.ofFloat(this.f5416fa, \"alpha\", new float[]{1.0f, 0.9f, 0.8f, 0.7f, 0.55f, 0.35f, 0.2f, 0.1f, 0.0f, 0.0f, 0.0f, 0.0f, 0.0f}).setDuration(350);\n duration.start();\n duration2.start();\n long j = (long) 240;\n ObjectAnimator.ofFloat(this.f5436pa, \"alpha\", new float[]{0.0f, 0.3f, 0.5f, 0.7f, 0.9f, 1.0f}).setDuration(j).start();\n this.f5438qa.getMeasuredHeight();\n this.f5384D.getmImageViewHeight();\n C1413m.m6828a(27, this.f5389I);\n ObjectAnimator.ofFloat(this.f5386F, \"alpha\", new float[]{0.0f, 1.0f}).setDuration(j).start();\n ObjectAnimator.ofFloat(this.f5384D, \"alpha\", new float[]{0.0f, 1.0f}).setDuration(j).start();\n ObjectAnimator.ofFloat(this.f5385E, \"alpha\", new float[]{0.0f, 1.0f}).setDuration(j).start();\n this.f5384D.getTexView().setText(getResources().getString(R.string.pause));\n this.f5384D.getmImageView().setImageResource(R.drawable.iqoo_buttonanimation);\n this.f5393M = (AnimationDrawable) this.f5384D.getmImageView().getDrawable();\n this.f5393M.start();\n duration.addListener(new C1300Wa(this));\n }",
"public at(com.tencent.mm.bj.g r15) {\n /*\n r14 = this;\n r12 = 5000; // 0x1388 float:7.006E-42 double:2.4703E-320;\n r11 = 2;\n r1 = 1;\n r4 = 0;\n r6 = 0;\n r14.<init>();\n r14.gUz = r15;\n r7 = \"MediaDuplication\";\n r0 = r14.gUz;\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r2 = new java.lang.StringBuilder;\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r3 = \"PRAGMA table_info( \";\n r2.<init>(r3);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r2 = r2.append(r7);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r3 = \" )\";\n r2 = r2.append(r3);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r2 = r2.toString();\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r3 = 0;\n r5 = 2;\n r2 = r0.a(r2, r3, r5);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r0 = \"name\";\n r8 = r2.getColumnIndex(r0);\t Catch:{ Exception -> 0x0195 }\n r0 = r6;\n r3 = r6;\n r5 = r6;\n L_0x0037:\n r9 = r2.moveToNext();\t Catch:{ Exception -> 0x0195 }\n if (r9 == 0) goto L_0x0064;\n L_0x003d:\n if (r8 < 0) goto L_0x0037;\n L_0x003f:\n r9 = r2.getString(r8);\t Catch:{ Exception -> 0x0195 }\n r10 = \"remuxing\";\n r10 = r10.equalsIgnoreCase(r9);\t Catch:{ Exception -> 0x0195 }\n if (r10 == 0) goto L_0x004e;\n L_0x004c:\n r5 = r1;\n goto L_0x0037;\n L_0x004e:\n r10 = \"duration\";\n r10 = r10.equalsIgnoreCase(r9);\t Catch:{ Exception -> 0x0195 }\n if (r10 == 0) goto L_0x0059;\n L_0x0057:\n r3 = r1;\n goto L_0x0037;\n L_0x0059:\n r10 = \"status\";\n r9 = r10.equalsIgnoreCase(r9);\t Catch:{ Exception -> 0x0195 }\n if (r9 == 0) goto L_0x0037;\n L_0x0062:\n r0 = r1;\n goto L_0x0037;\n L_0x0064:\n r2.close();\t Catch:{ Exception -> 0x0195 }\n r2 = com.tencent.mm.kernel.h.vI();\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r2 = r2.gYg;\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r8 = java.lang.Thread.currentThread();\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r8 = r8.getId();\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r8 = r2.cs(r8);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n if (r5 != 0) goto L_0x008c;\n L_0x007b:\n r2 = \"MicroMsg.MediaCheckDuplicationStorage\";\n r5 = \"it had no [remuxing] column, alter table now\";\n com.tencent.mm.sdk.platformtools.w.i(r2, r5);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r2 = \"alter table MediaDuplication add remuxing text \";\n r5 = r14.gUz;\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r5.eE(r7, r2);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n L_0x008c:\n if (r3 != 0) goto L_0x009f;\n L_0x008e:\n r2 = \"MicroMsg.MediaCheckDuplicationStorage\";\n r3 = \"it had no [duration] column, alter table now\";\n com.tencent.mm.sdk.platformtools.w.i(r2, r3);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r2 = \"alter table MediaDuplication add duration int \";\n r3 = r14.gUz;\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r3.eE(r7, r2);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n L_0x009f:\n if (r0 != 0) goto L_0x00b2;\n L_0x00a1:\n r0 = \"MicroMsg.MediaCheckDuplicationStorage\";\n r2 = \"it had no [status] column, alter table now\";\n com.tencent.mm.sdk.platformtools.w.i(r0, r2);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r0 = \"alter table MediaDuplication add status int \";\n r2 = r14.gUz;\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r2.eE(r7, r0);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n L_0x00b2:\n r2 = 0;\n r0 = (r8 > r2 ? 1 : (r8 == r2 ? 0 : -1));\n if (r0 <= 0) goto L_0x00c1;\n L_0x00b8:\n r0 = com.tencent.mm.kernel.h.vI();\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r0 = r0.gYg;\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n r0.aD(r8);\t Catch:{ Exception -> 0x0116, all -> 0x0145 }\n L_0x00c1:\n r7 = \"MediaDuplication\";\n r2 = 0;\n r0 = r14.gUz;\t Catch:{ Exception -> 0x014c, all -> 0x017d }\n r5 = new java.lang.StringBuilder;\t Catch:{ Exception -> 0x014c, all -> 0x017d }\n r8 = \"SELECT count(*) from \";\n r5.<init>(r8);\t Catch:{ Exception -> 0x014c, all -> 0x017d }\n r5 = r5.append(r7);\t Catch:{ Exception -> 0x014c, all -> 0x017d }\n r5 = r5.toString();\t Catch:{ Exception -> 0x014c, all -> 0x017d }\n r8 = 0;\n r9 = 2;\n r5 = r0.a(r5, r8, r9);\t Catch:{ Exception -> 0x014c, all -> 0x017d }\n r0 = r5.moveToFirst();\t Catch:{ Exception -> 0x0187 }\n if (r0 == 0) goto L_0x0197;\n L_0x00e4:\n r0 = 0;\n r0 = r5.getInt(r0);\t Catch:{ Exception -> 0x0187 }\n L_0x00e9:\n r5.close();\t Catch:{ Exception -> 0x018b }\n if (r0 < r12) goto L_0x00f7;\n L_0x00ee:\n r5 = r14.gUz;\t Catch:{ Exception -> 0x018d, all -> 0x017d }\n r8 = 0;\n r9 = 0;\n r2 = r5.delete(r7, r8, r9);\t Catch:{ Exception -> 0x018d, all -> 0x017d }\n r2 = (long) r2;\n L_0x00f7:\n r4 = \"MicroMsg.MediaCheckDuplicationStorage\";\n r5 = \"MediaDuplication record[%d], max record[%d], deleteRecord[%d]\";\n r7 = 3;\n r7 = new java.lang.Object[r7];\n r0 = java.lang.Integer.valueOf(r0);\n r7[r6] = r0;\n r0 = java.lang.Integer.valueOf(r12);\n r7[r1] = r0;\n r0 = java.lang.Long.valueOf(r2);\n r7[r11] = r0;\n com.tencent.mm.sdk.platformtools.w.i(r4, r5, r7);\n return;\n L_0x0116:\n r0 = move-exception;\n r2 = r4;\n L_0x0118:\n r3 = \"MicroMsg.MediaCheckDuplicationStorage\";\n r5 = \"\";\n r7 = 0;\n r7 = new java.lang.Object[r7];\t Catch:{ all -> 0x0192 }\n com.tencent.mm.sdk.platformtools.w.printErrStackTrace(r3, r0, r5, r7);\t Catch:{ all -> 0x0192 }\n r3 = \"MicroMsg.MediaCheckDuplicationStorage\";\n r5 = new java.lang.StringBuilder;\t Catch:{ all -> 0x0192 }\n r7 = \"tryAddDBCol error: \";\n r5.<init>(r7);\t Catch:{ all -> 0x0192 }\n r0 = r0.toString();\t Catch:{ all -> 0x0192 }\n r0 = r5.append(r0);\t Catch:{ all -> 0x0192 }\n r0 = r0.toString();\t Catch:{ all -> 0x0192 }\n com.tencent.mm.sdk.platformtools.w.e(r3, r0);\t Catch:{ all -> 0x0192 }\n if (r2 == 0) goto L_0x00c1;\n L_0x0140:\n r2.close();\n goto L_0x00c1;\n L_0x0145:\n r0 = move-exception;\n L_0x0146:\n if (r4 == 0) goto L_0x014b;\n L_0x0148:\n r4.close();\n L_0x014b:\n throw r0;\n L_0x014c:\n r0 = move-exception;\n r5 = r4;\n r4 = r0;\n r0 = r6;\n L_0x0150:\n r7 = \"MicroMsg.MediaCheckDuplicationStorage\";\n r8 = \"\";\n r9 = 0;\n r9 = new java.lang.Object[r9];\t Catch:{ all -> 0x0185 }\n com.tencent.mm.sdk.platformtools.w.printErrStackTrace(r7, r4, r8, r9);\t Catch:{ all -> 0x0185 }\n r7 = \"MicroMsg.MediaCheckDuplicationStorage\";\n r8 = new java.lang.StringBuilder;\t Catch:{ all -> 0x0185 }\n r9 = \"check to delete MediaDuplication. error : \";\n r8.<init>(r9);\t Catch:{ all -> 0x0185 }\n r4 = r4.toString();\t Catch:{ all -> 0x0185 }\n r4 = r8.append(r4);\t Catch:{ all -> 0x0185 }\n r4 = r4.toString();\t Catch:{ all -> 0x0185 }\n com.tencent.mm.sdk.platformtools.w.e(r7, r4);\t Catch:{ all -> 0x0185 }\n if (r5 == 0) goto L_0x00f7;\n L_0x0178:\n r5.close();\n goto L_0x00f7;\n L_0x017d:\n r0 = move-exception;\n r5 = r4;\n L_0x017f:\n if (r5 == 0) goto L_0x0184;\n L_0x0181:\n r5.close();\n L_0x0184:\n throw r0;\n L_0x0185:\n r0 = move-exception;\n goto L_0x017f;\n L_0x0187:\n r0 = move-exception;\n r4 = r0;\n r0 = r6;\n goto L_0x0150;\n L_0x018b:\n r4 = move-exception;\n goto L_0x0150;\n L_0x018d:\n r5 = move-exception;\n r13 = r5;\n r5 = r4;\n r4 = r13;\n goto L_0x0150;\n L_0x0192:\n r0 = move-exception;\n r4 = r2;\n goto L_0x0146;\n L_0x0195:\n r0 = move-exception;\n goto L_0x0118;\n L_0x0197:\n r0 = r6;\n goto L_0x00e9;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.tencent.mm.storage.at.<init>(com.tencent.mm.bj.g):void\");\n }",
"private void m6588E() {\n C0938a.m5002a(\"SR/SoundRecorder\", \"<initResourceRefs>\");\n if (C1413m.m6844f()) {\n this.f5386F.mo6533a(getResources().getString(R.string.new_mark_name), (int) R.drawable.iqoo_btn_recorder_mark_selector, getResources().getDimensionPixelSize(R.dimen.side_text_margin_diff));\n this.f5385E.mo6533a(getResources().getString(R.string.done), (int) R.drawable.iqoo_btn_recorder_stop_selector, getResources().getDimensionPixelSize(R.dimen.side_text_margin_diff));\n } else {\n this.f5386F.mo6533a(getResources().getString(R.string.new_mark_name), (int) R.drawable.btn_recorder_mark_selector, getResources().getDimensionPixelSize(R.dimen.side_text_margin_diff_x50));\n this.f5385E.mo6533a(getResources().getString(R.string.done), (int) R.drawable.btn_recorder_stop_selector, getResources().getDimensionPixelSize(R.dimen.side_text_margin_diff_x50));\n }\n if (!C1413m.m6844f()) {\n this.f5384D.mo6533a(getResources().getString(R.string.manager_title), (int) R.drawable.btn_play_0, getResources().getDimensionPixelSize(R.dimen.middle_text_margin_diff));\n }\n if (C1413m.m6845g()) {\n this.f5386F.setTextSize(12.0f);\n } else {\n this.f5386F.setTextSize(14.0f);\n }\n if (C1413m.m6845g()) {\n this.f5384D.setTextSize(12.0f);\n } else {\n this.f5384D.setTextSize(14.0f);\n }\n if (C1411k.m6820b(this)) {\n TwoStateLayout twoStateLayout = this.f5384D;\n twoStateLayout.setContentDescription(getResources().getString(R.string.manager_title) + \",\" + getResources().getString(R.string.button_talkback));\n TwoStateLayout twoStateLayout2 = this.f5386F;\n twoStateLayout2.setContentDescription(getResources().getString(R.string.new_mark_name) + \",\" + getResources().getString(R.string.button_talkback));\n TwoStateLayout twoStateLayout3 = this.f5385E;\n twoStateLayout3.setContentDescription(getResources().getString(R.string.done) + \",\" + getResources().getString(R.string.button_talkback));\n }\n if (C1413m.m6845g()) {\n this.f5385E.setTextSize(12.0f);\n } else {\n this.f5385E.setTextSize(14.0f);\n }\n this.f5387G = (TimeView) findViewById(R.id.record_time_show);\n this.f5384D.setOnClickListener(this);\n this.f5385E.setOnClickListener(this);\n this.f5386F.setOnClickListener(this);\n this.f5384D.setClickable(false);\n this.f5385E.setClickable(false);\n if (C1413m.m6844f()) {\n this.f5392L = (RecordView) findViewById(R.id.record_wave1);\n } else if (m6595L()) {\n this.f5391K = (XRecordView) findViewById(R.id.record_wave1);\n } else {\n this.f5392L = (RecordView) findViewById(R.id.record_wave1);\n }\n m6605V();\n }",
"SurfaceTexture mo17015a();",
"private final void m123456a() {\n CutVideoViewModel cutVideoViewModel = this.f100413c;\n if (cutVideoViewModel == null) {\n C7573i.m23583a(\"cutVideoViewModel\");\n }\n Serializable q = cutVideoViewModel.mo97164q();\n if (q == null) {\n return;\n }\n if (q != null) {\n startActivity(new Intent(this, (Class) q));\n return;\n }\n throw new TypeCastException(\"null cannot be cast to non-null type java.lang.Class<*>\");\n }",
"SurfaceTexture mo17006a();",
"private static java.lang.String[] a(android.content.Context r3, com.xiaomi.xmpush.thrift.u r4) {\n /*\n java.lang.String r0 = r4.h()\n java.lang.String r1 = r4.j()\n java.util.Map r4 = r4.s()\n if (r4 == 0) goto L_0x0073\n android.content.res.Resources r2 = r3.getResources()\n android.util.DisplayMetrics r2 = r2.getDisplayMetrics()\n int r2 = r2.widthPixels\n android.content.res.Resources r3 = r3.getResources()\n android.util.DisplayMetrics r3 = r3.getDisplayMetrics()\n float r3 = r3.density\n float r2 = (float) r2\n float r2 = r2 / r3\n r3 = 1056964608(0x3f000000, float:0.5)\n float r2 = r2 + r3\n java.lang.Float r3 = java.lang.Float.valueOf(r2)\n int r3 = r3.intValue()\n r2 = 320(0x140, float:4.48E-43)\n if (r3 > r2) goto L_0x0051\n java.lang.String r3 = \"title_short\"\n java.lang.Object r3 = r4.get(r3)\n java.lang.String r3 = (java.lang.String) r3\n boolean r2 = android.text.TextUtils.isEmpty(r3)\n if (r2 != 0) goto L_0x0042\n r0 = r3\n L_0x0042:\n java.lang.String r3 = \"description_short\"\n java.lang.Object r3 = r4.get(r3)\n java.lang.String r3 = (java.lang.String) r3\n boolean r4 = android.text.TextUtils.isEmpty(r3)\n if (r4 != 0) goto L_0x0073\n goto L_0x0072\n L_0x0051:\n r2 = 360(0x168, float:5.04E-43)\n if (r3 <= r2) goto L_0x0073\n java.lang.String r3 = \"title_long\"\n java.lang.Object r3 = r4.get(r3)\n java.lang.String r3 = (java.lang.String) r3\n boolean r2 = android.text.TextUtils.isEmpty(r3)\n if (r2 != 0) goto L_0x0064\n r0 = r3\n L_0x0064:\n java.lang.String r3 = \"description_long\"\n java.lang.Object r3 = r4.get(r3)\n java.lang.String r3 = (java.lang.String) r3\n boolean r4 = android.text.TextUtils.isEmpty(r3)\n if (r4 != 0) goto L_0x0073\n L_0x0072:\n r1 = r3\n L_0x0073:\n r3 = 2\n java.lang.String[] r3 = new java.lang.String[r3]\n r4 = 0\n r3[r4] = r0\n r4 = 1\n r3[r4] = r1\n return r3\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.xiaomi.push.service.ah.a(android.content.Context, com.xiaomi.xmpush.thrift.u):java.lang.String[]\");\n }",
"private Bitmap m14718q() {\n Bitmap a = this.f10962q.mo12204a(this.f10968w, this.f10967v, this.f10969x ? Config.ARGB_8888 : Config.RGB_565);\n m14714a(a);\n return a;\n }",
"@Override\n\tvoid postarVideo() {\n\n\t}",
"public int getVideoDscp();",
"public void mo19868k() {\n ImageView imageView = (ImageView) mo19852a(R.id.iv_refresh);\n C8271i.m35382a((Object) imageView, \"iv_refresh\");\n ezy.p642a.View.m34750a(imageView, 0, new C3585b(this), 1, null);\n ((CenteredTitleBar) mo19852a(R.id.toolbar)).setNavigationOnClickListener(new C3586c(this));\n TextView textView = (TextView) mo19852a(R.id.tv_close);\n C8271i.m35382a((Object) textView, \"tv_close\");\n ezy.p642a.View.m34750a(textView, 0, new C3587d(this), 1, null);\n }",
"private void m128167j() {\n this.f104205O = new C40116b() {\n /* renamed from: a */\n public final boolean mo99836a() {\n if (C40173d.f104443a.mo99939a(MvChoosePhotoActivity.this.f104225o)) {\n if (MvChoosePhotoActivity.this.f104230t == null || C23477d.m77081a((Collection<T>) MvChoosePhotoActivity.this.f104230t.mo99933a()) || MvChoosePhotoActivity.this.f104230t.mo99933a().size() < MvChoosePhotoActivity.this.f104213c) {\n return false;\n }\n return true;\n } else if (MvChoosePhotoActivity.this.f104228r >= MvChoosePhotoActivity.this.f104213c) {\n return true;\n } else {\n return false;\n }\n }\n\n /* renamed from: a */\n public final void mo99834a(MediaModel mediaModel) {\n if (mediaModel.f88164j < MvChoosePhotoActivity.this.f104216f || mediaModel.f88163i < MvChoosePhotoActivity.this.f104215e) {\n C10761a.m31396b((Context) MvChoosePhotoActivity.this, MvChoosePhotoActivity.this.getResources().getString(R.string.cua), 0).mo25750a();\n return;\n }\n MvChoosePhotoActivity.this.mo99822b();\n if (MvChoosePhotoActivity.this.f104225o != 3 || C40173d.m128357b(mediaModel.f88156b)) {\n MvChoosePhotoActivity.this.f104218h.clear();\n MvChoosePhotoActivity.this.f104218h.add(mediaModel);\n MvChoosePhotoActivity.this.f104224n = 3;\n MvChoosePhotoActivity.this.mo99821a(true);\n return;\n }\n C10761a.m31396b((Context) MvChoosePhotoActivity.this, MvChoosePhotoActivity.this.getResources().getString(R.string.c8b), 0).mo25750a();\n }\n\n /* renamed from: a */\n public final void mo99835a(List<MyMediaModel> list) {\n int i;\n if (C23477d.m77081a((Collection<T>) list)) {\n i = 0;\n } else {\n i = list.size();\n }\n if (MvChoosePhotoActivity.this.f104228r < i) {\n MvChoosePhotoActivity.m128156a(\"choose_upload_content\");\n }\n MvChoosePhotoActivity.this.f104228r = i;\n MvChoosePhotoActivity.this.f104226p = list;\n MvChoosePhotoActivity.this.mo99820a(list);\n }\n\n /* renamed from: a */\n public final boolean mo99837a(String str) {\n if (MvChoosePhotoActivity.this.f104219i == null || !MvChoosePhotoActivity.this.f104219i.isLegal()) {\n return true;\n }\n AtomicBoolean atomicBoolean = new AtomicBoolean(true);\n MvChoosePhotoActivity.this.f104231u.mo108544a(MvChoosePhotoActivity.this.f104217g, str, MvChoosePhotoActivity.this.f104219i.getPl().getAlg(), (IDetectImageResultListener) new C40146s(atomicBoolean));\n if (!atomicBoolean.get()) {\n MvChoosePhotoActivity.this.mo99817a();\n }\n return atomicBoolean.get();\n }\n\n /* renamed from: a */\n public final int mo99833a(MyMediaModel myMediaModel, boolean z) {\n MvChoosePhotoActivity.this.mo99822b();\n if (C40173d.f104443a.mo99939a(MvChoosePhotoActivity.this.f104225o) && myMediaModel != null) {\n return MvChoosePhotoActivity.this.f104230t.mo99931a(myMediaModel, z, false);\n }\n if (C23477d.m77081a((Collection<T>) MvChoosePhotoActivity.this.f104226p)) {\n return 1;\n }\n return MvChoosePhotoActivity.this.f104226p.size();\n }\n };\n this.f104206P = new C40116b() {\n /* renamed from: a */\n public final boolean mo99837a(String str) {\n return true;\n }\n\n /* renamed from: a */\n public final boolean mo99836a() {\n if (C40173d.f104443a.mo99939a(MvChoosePhotoActivity.this.f104225o)) {\n if (MvChoosePhotoActivity.this.f104230t == null || C23477d.m77081a((Collection<T>) MvChoosePhotoActivity.this.f104230t.mo99933a()) || MvChoosePhotoActivity.this.f104230t.mo99933a().size() < MvChoosePhotoActivity.this.f104214d) {\n return false;\n }\n return true;\n } else if (MvChoosePhotoActivity.this.f104229s >= MvChoosePhotoActivity.this.f104214d) {\n return true;\n } else {\n return false;\n }\n }\n\n /* renamed from: a */\n public final void mo99834a(MediaModel mediaModel) {\n MvChoosePhotoActivity.this.f104218h.clear();\n MvChoosePhotoActivity.this.f104218h.add(mediaModel);\n MvChoosePhotoActivity.this.f104224n = 2;\n MvChoosePhotoActivity.this.mo99822b();\n MvChoosePhotoActivity.this.mo99821a(true);\n }\n\n /* renamed from: a */\n public final void mo99835a(List<MyMediaModel> list) {\n int i;\n if (C23477d.m77081a((Collection<T>) list)) {\n i = 0;\n } else {\n i = list.size();\n }\n if (MvChoosePhotoActivity.this.f104229s < i) {\n MvChoosePhotoActivity.m128158b(list);\n }\n MvChoosePhotoActivity.this.f104229s = i;\n MvChoosePhotoActivity.this.f104227q = list;\n MvChoosePhotoActivity.this.mo99820a(list);\n }\n\n /* renamed from: a */\n public final int mo99833a(MyMediaModel myMediaModel, boolean z) {\n MvChoosePhotoActivity.this.mo99822b();\n if (C40173d.f104443a.mo99939a(MvChoosePhotoActivity.this.f104225o) && myMediaModel != null) {\n return MvChoosePhotoActivity.this.f104230t.mo99931a(myMediaModel, z, true);\n }\n if (C23477d.m77081a((Collection<T>) MvChoosePhotoActivity.this.f104227q)) {\n return 1;\n }\n return MvChoosePhotoActivity.this.f104227q.size();\n }\n };\n this.f104211a.f104138g = this.f104205O;\n this.f104212b.mo99804a(this.f104206P);\n }",
"public final com.google.android.gms.measurement.internal.zzak zza(java.lang.String r26, java.lang.String r27) {\n /*\n r25 = this;\n r15 = r27\n com.google.android.gms.common.internal.Preconditions.checkNotEmpty(r26)\n com.google.android.gms.common.internal.Preconditions.checkNotEmpty(r27)\n r25.zzd()\n r25.zzak()\n java.util.ArrayList r0 = new java.util.ArrayList\n java.lang.String r1 = \"lifetime_count\"\n java.lang.String r2 = \"current_bundle_count\"\n java.lang.String r3 = \"last_fire_timestamp\"\n java.lang.String r4 = \"last_bundled_timestamp\"\n java.lang.String r5 = \"last_bundled_day\"\n java.lang.String r6 = \"last_sampled_complex_event_id\"\n java.lang.String r7 = \"last_sampling_rate\"\n java.lang.String r8 = \"last_exempt_from_sampling\"\n java.lang.String r9 = \"current_session_count\"\n java.lang.String[] r1 = new java.lang.String[]{r1, r2, r3, r4, r5, r6, r7, r8, r9}\n java.util.List r1 = java.util.Arrays.asList(r1)\n r0.<init>(r1)\n r18 = 0\n android.database.sqlite.SQLiteDatabase r1 = r25.mo40210c_() // Catch:{ SQLiteException -> 0x012b, all -> 0x0129 }\n java.lang.String r2 = \"events\"\n r9 = 0\n java.lang.String[] r3 = new java.lang.String[r9] // Catch:{ SQLiteException -> 0x012b, all -> 0x0129 }\n java.lang.Object[] r0 = r0.toArray(r3) // Catch:{ SQLiteException -> 0x012b, all -> 0x0129 }\n r3 = r0\n java.lang.String[] r3 = (java.lang.String[]) r3 // Catch:{ SQLiteException -> 0x012b, all -> 0x0129 }\n java.lang.String r4 = \"app_id=? and name=?\"\n r0 = 2\n java.lang.String[] r5 = new java.lang.String[r0] // Catch:{ SQLiteException -> 0x012b, all -> 0x0129 }\n r5[r9] = r26 // Catch:{ SQLiteException -> 0x012b, all -> 0x0129 }\n r10 = 1\n r5[r10] = r15 // Catch:{ SQLiteException -> 0x012b, all -> 0x0129 }\n r6 = 0\n r7 = 0\n r8 = 0\n android.database.Cursor r14 = r1.query(r2, r3, r4, r5, r6, r7, r8) // Catch:{ SQLiteException -> 0x012b, all -> 0x0129 }\n boolean r1 = r14.moveToFirst() // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n if (r1 != 0) goto L_0x005e\n if (r14 == 0) goto L_0x005d\n r14.close()\n L_0x005d:\n return r18\n L_0x005e:\n long r4 = r14.getLong(r9) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n long r6 = r14.getLong(r10) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n long r11 = r14.getLong(r0) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n r0 = 3\n boolean r1 = r14.isNull(r0) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n r2 = 0\n if (r1 == 0) goto L_0x0076\n r16 = r2\n goto L_0x007c\n L_0x0076:\n long r0 = r14.getLong(r0) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n r16 = r0\n L_0x007c:\n r0 = 4\n boolean r1 = r14.isNull(r0) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n if (r1 == 0) goto L_0x0086\n r0 = r18\n goto L_0x008e\n L_0x0086:\n long r0 = r14.getLong(r0) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n java.lang.Long r0 = java.lang.Long.valueOf(r0) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n L_0x008e:\n r1 = 5\n boolean r8 = r14.isNull(r1) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n if (r8 == 0) goto L_0x0098\n r19 = r18\n goto L_0x00a2\n L_0x0098:\n long r19 = r14.getLong(r1) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n java.lang.Long r1 = java.lang.Long.valueOf(r19) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n r19 = r1\n L_0x00a2:\n r1 = 6\n boolean r8 = r14.isNull(r1) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n if (r8 == 0) goto L_0x00ac\n r20 = r18\n goto L_0x00b6\n L_0x00ac:\n long r20 = r14.getLong(r1) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n java.lang.Long r1 = java.lang.Long.valueOf(r20) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n r20 = r1\n L_0x00b6:\n r1 = 7\n boolean r8 = r14.isNull(r1) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n if (r8 != 0) goto L_0x00d3\n long r21 = r14.getLong(r1) // Catch:{ SQLiteException -> 0x00d0 }\n r23 = 1\n int r1 = (r21 > r23 ? 1 : (r21 == r23 ? 0 : -1))\n if (r1 != 0) goto L_0x00c9\n r9 = r10\n L_0x00c9:\n java.lang.Boolean r1 = java.lang.Boolean.valueOf(r9) // Catch:{ SQLiteException -> 0x00d0 }\n r21 = r1\n goto L_0x00d5\n L_0x00d0:\n r0 = move-exception\n goto L_0x012e\n L_0x00d3:\n r21 = r18\n L_0x00d5:\n r1 = 8\n boolean r8 = r14.isNull(r1) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n if (r8 == 0) goto L_0x00df\n r8 = r2\n goto L_0x00e4\n L_0x00df:\n long r1 = r14.getLong(r1) // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n r8 = r1\n L_0x00e4:\n com.google.android.gms.measurement.internal.zzak r22 = new com.google.android.gms.measurement.internal.zzak // Catch:{ SQLiteException -> 0x0125, all -> 0x011f }\n r1 = r22\n r2 = r26\n r3 = r27\n r10 = r11\n r12 = r16\n r23 = r14\n r14 = r0\n r15 = r19\n r16 = r20\n r17 = r21\n r1.<init>(r2, r3, r4, r6, r8, r10, r12, r14, r15, r16, r17) // Catch:{ SQLiteException -> 0x011b, all -> 0x0119 }\n boolean r0 = r23.moveToNext() // Catch:{ SQLiteException -> 0x011b, all -> 0x0119 }\n if (r0 == 0) goto L_0x0112\n com.google.android.gms.measurement.internal.zzez r0 = r25.zzr() // Catch:{ SQLiteException -> 0x011b, all -> 0x0119 }\n com.google.android.gms.measurement.internal.zzfb r0 = r0.zzf() // Catch:{ SQLiteException -> 0x011b, all -> 0x0119 }\n java.lang.String r1 = \"Got multiple records for event aggregates, expected one. appId\"\n java.lang.Object r2 = com.google.android.gms.measurement.internal.zzez.zza((java.lang.String) r26) // Catch:{ SQLiteException -> 0x011b, all -> 0x0119 }\n r0.zza(r1, r2) // Catch:{ SQLiteException -> 0x011b, all -> 0x0119 }\n L_0x0112:\n if (r23 == 0) goto L_0x0118\n r23.close()\n L_0x0118:\n return r22\n L_0x0119:\n r0 = move-exception\n goto L_0x0122\n L_0x011b:\n r0 = move-exception\n r14 = r23\n goto L_0x012e\n L_0x011f:\n r0 = move-exception\n r23 = r14\n L_0x0122:\n r18 = r23\n goto L_0x0152\n L_0x0125:\n r0 = move-exception\n r23 = r14\n goto L_0x012e\n L_0x0129:\n r0 = move-exception\n goto L_0x0152\n L_0x012b:\n r0 = move-exception\n r14 = r18\n L_0x012e:\n com.google.android.gms.measurement.internal.zzez r1 = r25.zzr() // Catch:{ all -> 0x014f }\n com.google.android.gms.measurement.internal.zzfb r1 = r1.zzf() // Catch:{ all -> 0x014f }\n java.lang.String r2 = \"Error querying events. appId\"\n java.lang.Object r3 = com.google.android.gms.measurement.internal.zzez.zza((java.lang.String) r26) // Catch:{ all -> 0x014f }\n com.google.android.gms.measurement.internal.zzex r4 = r25.zzo() // Catch:{ all -> 0x014f }\n r5 = r27\n java.lang.String r4 = r4.zza((java.lang.String) r5) // Catch:{ all -> 0x014f }\n r1.zza(r2, r3, r4, r0) // Catch:{ all -> 0x014f }\n if (r14 == 0) goto L_0x014e\n r14.close()\n L_0x014e:\n return r18\n L_0x014f:\n r0 = move-exception\n r18 = r14\n L_0x0152:\n if (r18 == 0) goto L_0x0157\n r18.close()\n L_0x0157:\n throw r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.gms.measurement.internal.zzad.zza(java.lang.String, java.lang.String):com.google.android.gms.measurement.internal.zzak\");\n }",
"public SurfaceViewEncode(Activity context ) {\n super(context);\n\n this.mContext = context;\n\n /* File file = new File(\"/sdcard/a.264\");\n if (file.exists()) {\n file.delete();\n }\n try {\n file.createNewFile();\n fos = new FileOutputStream(file);\n } catch (FileNotFoundException e1) {\n // TODO Auto-generated catch block\n e1.printStackTrace();\n } catch (IOException e) {\n // TODO Auto-generated catch block\n e.printStackTrace();\n }*/\n\n\n }",
"private void m20376b() {\n if (this.c) {\n String str = cz.f23362a;\n this.b.startScan();\n this.f23492h = SystemClock.elapsedRealtime();\n C6019a c6019a = this.f23491g;\n c6019a.f24636f++;\n return;\n }\n str = cz.f23362a;\n }",
"static /* synthetic */ short m313-set6(android.location.GpsClock r1, short r2) {\n /*\n // Can't load method instructions: Load method exception: bogus opcode: 00ee in method: android.location.GpsClock.-set6(android.location.GpsClock, short):short, dex: \n */\n throw new UnsupportedOperationException(\"Method not decompiled: android.location.GpsClock.-set6(android.location.GpsClock, short):short\");\n }",
"public void mo63045a(C44921e eVar) {\n String str;\n super.mo63045a(eVar);\n C24942al.m81836b(mo75261ab(), this.f89221bo);\n if (C25352e.m83221d(this.f77546j)) {\n C24961b b = C24958f.m81905a().mo65273b(this.f77546j).mo65266a(\"result_ad\").mo65276b(\"play\");\n if (!C25352e.m83224g(this.f77546j) || !TextUtils.equals(mo75290r(), \"general_search\")) {\n str = \"\";\n } else {\n str = \"video\";\n }\n b.mo65283e(str).mo65270a(mo75261ab());\n }\n }",
"public interface Constant {\n\n String ACCESSIBILITY_SERVICE = \"github.hellocsl.smartmonitor/github.hellocsl.smartmonitor.VideoAccessibilityService\";\n\n String QQ_PKG = \"com.tencent.mobileqq\";\n\n String QQ_NUMBER = \"929371293\";\n\n String DIALER = \"com.google.android.dialer\";\n\n String MONITOR_CMD_VIDEO = \"monitor_cmd_video\";\n\n String MONITOR_TAG = \"WaterMonitor\";\n\n String MONITOR_CMD_RESET = \"110\";\n\n String MEIZU_IN_CALL_PKG = \"com.android.incallui\";\n\n //NEXUS 5\n String N5_MODEL = \"Nexus 5\";\n\n //MEIZU\n String MX_MODEL = \"mx\";\n\n\n}",
"public void mo14071a(int i, float f) {\n View m = mo23948m();\n if (m != null) {\n float f2 = i == 1 ? f : i == 2 ? 1.0f : 0.0f;\n this.f15642X.setRotation(9.0f * f2);\n float f3 = (f2 * 0.205f) + 1.0f;\n this.f15641W.setScaleX(f3);\n this.f15641W.setScaleY(f3);\n float f4 = i == 0 ? 1.0f - f : 0.0f;\n this.f15638T.setRotation(-9.0f * f4);\n float f5 = (f4 * 0.205f) + 1.0f;\n this.f15637S.setScaleX(f5);\n this.f15637S.setScaleY(f5);\n if (this.f15656l0) {\n if (f == 0.0f && (i == 0 || i == 2)) {\n this.f15656l0 = false;\n } else {\n return;\n }\n }\n if (i != 1) {\n f = 1.0f - f;\n }\n float f6 = 1.0f - f;\n float f7 = (0.205f * f6) + 1.0f;\n this.f15639U.setScaleX(f7);\n this.f15639U.setScaleY(f7);\n float f8 = (float) ((int) (((float) f15633z0) * f));\n this.f15643Y.setTranslationY(f8);\n this.f15643Y.setAlpha(f6);\n this.f15639U.setTranslationY(f8);\n int measuredWidth = (m.getMeasuredWidth() / 2) - f15630A0;\n int i2 = f15632y0;\n int i3 = (int) (((float) ((measuredWidth - i2) - (i2 / 2))) * f);\n this.f15637S.setTranslationX((float) i3);\n this.f15641W.setTranslationX((float) (-i3));\n this.f15664t0.onViewPagerScrolled(f, f15633z0);\n }\n }",
"@Override\n\tpublic void videoStart() {\n\t\t\n\t}",
"private static void m133350k() {\n C41940c c = C35574k.m114859a().mo70094i().mo102932c();\n String str = C39811er.f103468d;\n C7573i.m23582a((Object) str, \"ShortVideoConfig2.sDir\");\n File a = c.mo102928a(str);\n if (a.exists() && a.isDirectory()) {\n Set a2 = C41911c.m133283a();\n File[] listFiles = a.listFiles();\n C7573i.m23582a((Object) listFiles, \"filesRoot.listFiles()\");\n Iterable c2 = C7519g.m23444c((T[]) listFiles);\n Collection arrayList = new ArrayList();\n Iterator it = c2.iterator();\n while (true) {\n boolean z = false;\n if (!it.hasNext()) {\n break;\n }\n Object next = it.next();\n File file = (File) next;\n if (file.exists() && file.isFile()) {\n z = true;\n }\n if (z) {\n arrayList.add(next);\n }\n }\n for (File file2 : (List) arrayList) {\n String name = file2.getName();\n C7573i.m23582a((Object) name, \"filesToDelete.name\");\n if (!C7634n.m23723c(name, \"-concat-v\", false)) {\n String name2 = file2.getName();\n C7573i.m23582a((Object) name2, \"filesToDelete.name\");\n if (!C7634n.m23723c(name2, \"-concat-a\", false)) {\n String name3 = file2.getName();\n C7573i.m23582a((Object) name3, \"filesToDelete.name\");\n if (!C7634n.m23723c(name3, \"_synthetise\", false)) {\n }\n }\n }\n Iterator it2 = a2.iterator();\n int i = 0;\n while (true) {\n if (!it2.hasNext()) {\n i = -1;\n break;\n }\n Object next2 = it2.next();\n if (i < 0) {\n C7525m.m23465b();\n }\n String str2 = (String) next2;\n String path = file2.getPath();\n C7573i.m23582a((Object) path, \"filesToDelete.path\");\n if (C7634n.m23721b(path, str2, false)) {\n break;\n }\n i++;\n }\n if (-1 == i) {\n file2.delete();\n }\n }\n }\n }"
]
| [
"0.6423281",
"0.6419507",
"0.6381675",
"0.6079675",
"0.60379195",
"0.5839689",
"0.58242106",
"0.5803428",
"0.5782854",
"0.57111514",
"0.5705799",
"0.56870955",
"0.5639729",
"0.5575535",
"0.5568573",
"0.5566989",
"0.5559101",
"0.5542903",
"0.5532758",
"0.5512094",
"0.55096036",
"0.55041367",
"0.54945374",
"0.54906994",
"0.5465814",
"0.5455103",
"0.5430804",
"0.54119575",
"0.5401589",
"0.5400658",
"0.5387202",
"0.5382338",
"0.5379768",
"0.53744465",
"0.5370922",
"0.53699374",
"0.5364301",
"0.5360765",
"0.53565437",
"0.53540474",
"0.5351752",
"0.53509647",
"0.53485936",
"0.53403515",
"0.53334236",
"0.5301466",
"0.52946275",
"0.52915144",
"0.52851015",
"0.52819914",
"0.527949",
"0.527734",
"0.52601826",
"0.52583003",
"0.5255443",
"0.5253048",
"0.5247766",
"0.5242495",
"0.5241794",
"0.5237612",
"0.5234729",
"0.5228729",
"0.5224906",
"0.5213525",
"0.5210529",
"0.5209379",
"0.5199299",
"0.5195147",
"0.51939464",
"0.5190764",
"0.51873326",
"0.5186282",
"0.5184572",
"0.5182804",
"0.5180896",
"0.51776224",
"0.5177403",
"0.51627296",
"0.5159427",
"0.51550585",
"0.5152584",
"0.51516575",
"0.51424855",
"0.5136597",
"0.51363033",
"0.51329494",
"0.5129522",
"0.5124255",
"0.51210356",
"0.5119694",
"0.5118223",
"0.51172614",
"0.51171535",
"0.5106311",
"0.51058203",
"0.5103706",
"0.5102463",
"0.50997066",
"0.5097944",
"0.50979406",
"0.50954175"
]
| 0.0 | -1 |
/ renamed from: a | void mo100442a(C40429b bVar); | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public interface C4521a {\n /* renamed from: a */\n void mo12348a();\n }",
"public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }",
"interface bxc {\n /* renamed from: a */\n void mo2508a(bxb bxb);\n}",
"interface C33292a {\n /* renamed from: a */\n void mo85415a(String str);\n }",
"interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }",
"public interface C0779a {\n /* renamed from: a */\n void mo2311a();\n}",
"public interface C6788a {\n /* renamed from: a */\n void mo20141a();\n }",
"public interface C0237a {\n /* renamed from: a */\n void mo1791a(String str);\n }",
"public interface C35013b {\n /* renamed from: a */\n void mo88773a(int i);\n}",
"public interface C11112n {\n /* renamed from: a */\n void mo38026a();\n }",
"@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}",
"public interface C23407b {\n /* renamed from: a */\n void mo60892a();\n\n /* renamed from: b */\n void mo60893b();\n }",
"interface C0312e {\n /* renamed from: a */\n void mo4671a(View view, int i, int i2, int i3, int i4);\n }",
"public interface C34379a {\n /* renamed from: a */\n void mo46242a(bmc bmc);\n }",
"public interface C32456b<T> {\n /* renamed from: a */\n void mo83696a(T t);\n }",
"private String convertir(String a) {\n StringBuilder atributo = new StringBuilder(a);\n atributo.insert(0, Character.toUpperCase(atributo.charAt(0)));\n return atributo.deleteCharAt(1).toString();\n }",
"protected m a(String name) {\n/* 42 */ return this.a.get(name);\n/* */ }",
"public interface AbstractC23925a {\n /* renamed from: a */\n void mo105476a();\n }",
"private interface C0257a {\n /* renamed from: a */\n float mo196a(ViewGroup viewGroup, View view);\n\n /* renamed from: b */\n float mo195b(ViewGroup viewGroup, View view);\n }",
"public interface C3598a {\n /* renamed from: a */\n void mo11024a(int i, int i2, String str);\n }",
"public interface C2459d {\n /* renamed from: a */\n C2451d mo3408a(C2457e c2457e);\n}",
"public interface am extends ak {\r\n /* renamed from: a */\r\n void mo194a(int i) throws RemoteException;\r\n\r\n /* renamed from: a */\r\n void mo195a(List<LatLng> list) throws RemoteException;\r\n\r\n /* renamed from: b */\r\n void mo196b(float f) throws RemoteException;\r\n\r\n /* renamed from: b */\r\n void mo197b(boolean z);\r\n\r\n /* renamed from: c */\r\n void mo198c(boolean z) throws RemoteException;\r\n\r\n /* renamed from: g */\r\n float mo199g() throws RemoteException;\r\n\r\n /* renamed from: h */\r\n int mo200h() throws RemoteException;\r\n\r\n /* renamed from: i */\r\n List<LatLng> mo201i() throws RemoteException;\r\n\r\n /* renamed from: j */\r\n boolean mo202j();\r\n\r\n /* renamed from: k */\r\n boolean mo203k();\r\n}",
"public interface C32459e<T> {\n /* renamed from: a */\n void mo83698a(T t);\n }",
"public interface C32458d<T> {\n /* renamed from: a */\n void mo83695a(T t);\n }",
"public interface C5482b {\n /* renamed from: a */\n void mo27575a();\n\n /* renamed from: a */\n void mo27576a(int i);\n }",
"public interface C27084a {\n /* renamed from: a */\n void mo69874a();\n\n /* renamed from: a */\n void mo69875a(List<Aweme> list, boolean z);\n }",
"public void a() {\n ((a) this.a).a();\n }",
"public interface C1153a {\n /* renamed from: a */\n void mo4520a(byte[] bArr);\n }",
"public interface C13373b {\n /* renamed from: a */\n void mo32681a(String str, int i, boolean z);\n}",
"public interface C40453c {\n /* renamed from: a */\n void mo100442a(C40429b bVar);\n\n /* renamed from: a */\n void mo100443a(List<String> list);\n\n /* renamed from: b */\n void mo100444b(List<C40429b> list);\n}",
"public interface AbstractC17367b {\n /* renamed from: a */\n void mo84655a();\n }",
"@Override\r\n\tpublic void a() {\n\t\t\r\n\t}",
"public interface C43270a {\n /* renamed from: a */\n void mo64942a(String str, long j, long j2);\n}",
"public interface C18928d {\n /* renamed from: a */\n void mo50320a(C18924b bVar);\n\n /* renamed from: b */\n void mo50321b(C18924b bVar);\n}",
"public interface C0087c {\n /* renamed from: a */\n String mo150a(String str);\n}",
"public interface C1529m {\n /* renamed from: a */\n void mo3767a(int i);\n\n /* renamed from: a */\n void mo3768a(String str);\n}",
"interface C4483e {\n /* renamed from: a */\n boolean mo34114a();\n}",
"public interface C1234b {\r\n /* renamed from: a */\r\n void m8367a();\r\n\r\n /* renamed from: b */\r\n void m8368b();\r\n}",
"public interface C10965j<T> {\n /* renamed from: a */\n T mo26439a();\n}",
"public interface C28772a {\n /* renamed from: a */\n View mo73990a(View view);\n }",
"@Override\n\tpublic void a() {\n\t\t\n\t}",
"public interface C8326b {\n /* renamed from: a */\n C8325a mo21498a(String str);\n\n /* renamed from: a */\n void mo21499a(C8325a aVar);\n}",
"void metodo1(int a, int[] b) {\r\n\t\ta += 5;//Par\\u00e1metro con el mismo nombre que el campo de la clase.\r\n\t\tb[0] += 7;//se produce un env\\u00edo por referencia, apunta a una copia de un objeto, que se asigna aqu\\u00ed.\r\n\t}",
"public interface C2367a {\n /* renamed from: a */\n C2368d mo1698a();\n }",
"interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }",
"public interface C4211a {\n\n /* renamed from: com.iab.omid.library.oguryco.c.a$a */\n public interface C4212a {\n /* renamed from: a */\n void mo28760a(View view, C4211a aVar, JSONObject jSONObject);\n }\n\n /* renamed from: a */\n JSONObject mo28758a(View view);\n\n /* renamed from: a */\n void mo28759a(View view, JSONObject jSONObject, C4212a aVar, boolean z);\n}",
"public interface C4697a extends C5595at {\n /* renamed from: a */\n void mo12634a();\n\n /* renamed from: a */\n void mo12635a(String str);\n\n /* renamed from: a */\n void mo12636a(boolean z);\n\n /* renamed from: b */\n void mo12637b();\n\n /* renamed from: c */\n void mo12638c();\n }",
"public interface C4773c {\n /* renamed from: a */\n void m15858a(int i);\n\n /* renamed from: a */\n void m15859a(int i, int i2);\n\n /* renamed from: a */\n void m15860a(int i, int i2, int i3);\n\n /* renamed from: b */\n void m15861b(int i, int i2);\n}",
"public interface C4869f {\n /* renamed from: a */\n C4865b mo6249a();\n}",
"public interface C1799a {\n /* renamed from: b */\n void mo3314b(String str);\n }",
"public interface C43499b {\n /* renamed from: a */\n void mo8445a(int i, String str, int i2, byte[] bArr);\n}",
"public interface C0601aq {\n /* renamed from: a */\n void mo9148a(int i, ArrayList<C0889x> arrayList);\n}",
"public interface C45101e {\n /* renamed from: b */\n void mo3796b(int i);\n}",
"public interface AbstractC6461g {\n /* renamed from: a */\n String mo42332a();\n}",
"public interface AbstractC1645a {\n /* renamed from: a */\n String mo17375a();\n }",
"public interface C6178c {\n /* renamed from: a */\n Map<String, String> mo14888a();\n}",
"public interface C5101b {\n /* renamed from: a */\n void mo5289a(C5102c c5102c);\n\n /* renamed from: b */\n void mo5290b(C5102c c5102c);\n}",
"public interface C19045k {\n /* renamed from: a */\n void mo50368a(int i, Object obj);\n\n /* renamed from: b */\n void mo50369b(int i, Object obj);\n}",
"public b a()\r\n/* 12: */ {\r\n/* 13:13 */ return this.a;\r\n/* 14: */ }",
"public interface C7720a {\n /* renamed from: a */\n long mo20406a();\n}",
"public String a()\r\n/* 25: */ {\r\n/* 26:171 */ return \"dig.\" + this.a;\r\n/* 27: */ }",
"public interface ayt {\n /* renamed from: a */\n int mo1635a(long j, List list);\n\n /* renamed from: a */\n long mo1636a(long j, alb alb);\n\n /* renamed from: a */\n void mo1637a();\n\n /* renamed from: a */\n void mo1638a(long j, long j2, List list, ayp ayp);\n\n /* renamed from: a */\n void mo1639a(ayl ayl);\n\n /* renamed from: a */\n boolean mo1640a(ayl ayl, boolean z, Exception exc, long j);\n}",
"public interface C24221b extends C28343z<C28318an> {\n /* renamed from: a */\n void mo62991a(int i);\n\n String aw_();\n\n /* renamed from: e */\n Aweme mo62993e();\n}",
"public interface C4051c {\n /* renamed from: a */\n boolean mo23707a();\n}",
"public interface C45112b {\n /* renamed from: a */\n List<C45111a> mo107674a(Integer num);\n\n /* renamed from: a */\n List<C45111a> mo107675a(Integer num, Integer num2);\n\n /* renamed from: a */\n void mo107676a(C45111a aVar);\n\n /* renamed from: b */\n void mo107677b(Integer num);\n\n /* renamed from: c */\n long mo107678c(Integer num);\n}",
"public void acionou(int a){\n\t\t\tb=a;\n\t\t}",
"public interface C44963i {\n /* renamed from: a */\n void mo63037a(int i, int i2);\n\n void aA_();\n\n /* renamed from: b */\n void mo63039b(int i, int i2);\n}",
"public interface C32457c<T> {\n /* renamed from: a */\n void mo83699a(T t, int i, int i2, String str);\n }",
"public interface C5861g {\n /* renamed from: a */\n void mo18320a(C7251a aVar);\n\n @Deprecated\n /* renamed from: a */\n void mo18321a(C7251a aVar, String str);\n\n /* renamed from: a */\n void mo18322a(C7252b bVar);\n\n /* renamed from: a */\n void mo18323a(C7253c cVar);\n\n /* renamed from: a */\n void mo18324a(C7260j jVar);\n}",
"public interface C0937a {\n /* renamed from: a */\n void mo3807a(C0985po[] poVarArr);\n }",
"public interface C8466a {\n /* renamed from: a */\n void mo25956a(int i);\n\n /* renamed from: a */\n void mo25957a(long j, long j2);\n }",
"public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }",
"public interface C43470b {\n /* renamed from: a */\n void mo61496a(C43469a aVar, C43471c cVar);\n }",
"public interface AbstractC18255a {\n /* renamed from: a */\n void mo88521a();\n\n /* renamed from: a */\n void mo88522a(String str);\n\n /* renamed from: b */\n void mo88523b();\n\n /* renamed from: c */\n void mo88524c();\n }",
"public interface C1436d {\n /* renamed from: a */\n C1435c mo1754a(C1433a c1433a, C1434b c1434b);\n}",
"public interface C4150sl {\n /* renamed from: a */\n void mo15005a(C4143se seVar);\n}",
"public void a(nm paramnm)\r\n/* 28: */ {\r\n/* 29:45 */ paramnm.a(this);\r\n/* 30: */ }",
"public interface C19351a {\n /* renamed from: b */\n void mo30633b(int i, String str, byte[] bArr);\n }",
"public interface C11113o {\n /* renamed from: a */\n void mo37759a(String str);\n }",
"public interface C39504az {\n /* renamed from: a */\n int mo98207a();\n\n /* renamed from: a */\n void mo98208a(boolean z);\n\n /* renamed from: b */\n int mo98209b();\n\n /* renamed from: c */\n int mo98355c();\n\n /* renamed from: d */\n int mo98356d();\n\n /* renamed from: e */\n int mo98357e();\n\n /* renamed from: f */\n int mo98358f();\n}",
"protected a<T> a(Tag.e<T> var0) {\n/* 80 */ Tag.a var1 = b(var0);\n/* 81 */ return new a<>(var1, this.c, \"vanilla\");\n/* */ }",
"public interface C35565a {\n /* renamed from: a */\n C45321i mo90380a();\n }",
"public interface C21298a {\n /* renamed from: a */\n void mo57275a();\n\n /* renamed from: a */\n void mo57276a(Exception exc);\n\n /* renamed from: b */\n void mo57277b();\n\n /* renamed from: c */\n void mo57278c();\n }",
"public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }",
"public interface C0456a {\n /* renamed from: a */\n void mo2090a(C0455b bVar);\n\n /* renamed from: a */\n boolean mo2091a(C0455b bVar, Menu menu);\n\n /* renamed from: a */\n boolean mo2092a(C0455b bVar, MenuItem menuItem);\n\n /* renamed from: b */\n boolean mo2093b(C0455b bVar, Menu menu);\n }",
"public interface C4724o {\n /* renamed from: a */\n void mo4872a(int i, String str);\n\n /* renamed from: a */\n void mo4873a(C4718l c4718l);\n\n /* renamed from: b */\n void mo4874b(C4718l c4718l);\n}",
"public interface C7654b {\n /* renamed from: a */\n C7904c mo24084a();\n\n /* renamed from: b */\n C7716a mo24085b();\n }",
"public interface C2603a {\n /* renamed from: a */\n String mo1889a(String str, String str2, String str3, String str4);\n }",
"public interface afp {\n /* renamed from: a */\n C0512sx mo169a(C0497si siVar, afj afj, afr afr, Context context);\n}",
"public interface C0615ja extends b<HomeFragment> {\n\n /* renamed from: c.c.a.h.b.ja$a */\n /* compiled from: FragmentModule_HomeFragment$app_bazaarRelease */\n public static abstract class a extends b.a<HomeFragment> {\n }\n}",
"public interface a {\n\n /* renamed from: c.b.a.c.b.b.a$a reason: collision with other inner class name */\n /* compiled from: DiskCache */\n public interface C0054a {\n a build();\n }\n\n /* compiled from: DiskCache */\n public interface b {\n boolean a(File file);\n }\n\n File a(c cVar);\n\n void a(c cVar, b bVar);\n}",
"public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }",
"public interface AbstractC17368c {\n /* renamed from: a */\n void mo84656a(float f);\n }",
"interface C0932a {\n /* renamed from: a */\n void mo7438a(int i, int i2);\n\n /* renamed from: b */\n void mo7439b(C0933b bVar);\n\n /* renamed from: c */\n void mo7440c(int i, int i2, Object obj);\n\n /* renamed from: d */\n void mo7441d(C0933b bVar);\n\n /* renamed from: e */\n RecyclerView.ViewHolder mo7442e(int i);\n\n /* renamed from: f */\n void mo7443f(int i, int i2);\n\n /* renamed from: g */\n void mo7444g(int i, int i2);\n\n /* renamed from: h */\n void mo7445h(int i, int i2);\n }",
"public interface C10330c {\n /* renamed from: a */\n C7562b<C10403b, C10328a> mo25041a();\n}",
"public interface C3819a {\n /* renamed from: a */\n void mo23214a(Message message);\n }",
"private Proof atoAImpl(Expression a) {\n Proof where = axm2(a, arrow(a, a), a); //a->(a->a) -> (a->(a->a)->a) -> (a -> a)\n Proof one = axm1(a, a); //a->a->a\n Proof two = axm1(a, arrow(a, a)); //a->(a->a)->A\n return mpTwice(where, one, two);\n }",
"interface C1939a {\n /* renamed from: a */\n Bitmap mo1406a(Bitmap bitmap, float f);\n}",
"public interface a extends com.bankeen.d.b.b.a {\n void a();\n\n void b();\n }",
"public b[] a() {\n/* 95 */ return this.a;\n/* */ }",
"interface C8361a {\n /* renamed from: b */\n float mo18284b(ViewGroup viewGroup, View view);\n\n /* renamed from: c */\n float mo18281c(ViewGroup viewGroup, View view);\n }"
]
| [
"0.62497115",
"0.6242887",
"0.61394435",
"0.61176854",
"0.6114027",
"0.60893",
"0.6046901",
"0.6024682",
"0.60201293",
"0.5975212",
"0.59482527",
"0.59121317",
"0.5883635",
"0.587841",
"0.58703005",
"0.5868436",
"0.5864884",
"0.5857492",
"0.58306104",
"0.5827752",
"0.58272064",
"0.5794689",
"0.57890314",
"0.57838726",
"0.5775679",
"0.57694733",
"0.5769128",
"0.57526815",
"0.56907034",
"0.5677874",
"0.5670547",
"0.56666386",
"0.56592244",
"0.5658682",
"0.56574154",
"0.5654324",
"0.5644676",
"0.56399715",
"0.5638734",
"0.5630582",
"0.56183887",
"0.5615435",
"0.56069666",
"0.5605207",
"0.56005067",
"0.559501",
"0.55910283",
"0.5590222",
"0.55736613",
"0.5556682",
"0.5554544",
"0.5550076",
"0.55493855",
"0.55446684",
"0.5538079",
"0.5529058",
"0.5528109",
"0.552641",
"0.5525864",
"0.552186",
"0.5519972",
"0.5509587",
"0.5507195",
"0.54881203",
"0.5485328",
"0.54826045",
"0.5482066",
"0.5481586",
"0.5479751",
"0.54776895",
"0.54671466",
"0.5463307",
"0.54505056",
"0.54436916",
"0.5440517",
"0.5439747",
"0.5431944",
"0.5422869",
"0.54217863",
"0.5417556",
"0.5403905",
"0.5400223",
"0.53998446",
"0.5394735",
"0.5388649",
"0.5388258",
"0.5374842",
"0.5368887",
"0.53591394",
"0.5357029",
"0.5355688",
"0.535506",
"0.5355034",
"0.53494394",
"0.5341044",
"0.5326166",
"0.53236824",
"0.53199095",
"0.53177035",
"0.53112453",
"0.5298229"
]
| 0.0 | -1 |
/ renamed from: a | void mo100443a(List<String> list); | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public interface C4521a {\n /* renamed from: a */\n void mo12348a();\n }",
"public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }",
"interface bxc {\n /* renamed from: a */\n void mo2508a(bxb bxb);\n}",
"interface C33292a {\n /* renamed from: a */\n void mo85415a(String str);\n }",
"interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }",
"public interface C0779a {\n /* renamed from: a */\n void mo2311a();\n}",
"public interface C6788a {\n /* renamed from: a */\n void mo20141a();\n }",
"public interface C0237a {\n /* renamed from: a */\n void mo1791a(String str);\n }",
"public interface C35013b {\n /* renamed from: a */\n void mo88773a(int i);\n}",
"public interface C11112n {\n /* renamed from: a */\n void mo38026a();\n }",
"@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}",
"public interface C23407b {\n /* renamed from: a */\n void mo60892a();\n\n /* renamed from: b */\n void mo60893b();\n }",
"interface C0312e {\n /* renamed from: a */\n void mo4671a(View view, int i, int i2, int i3, int i4);\n }",
"public interface C34379a {\n /* renamed from: a */\n void mo46242a(bmc bmc);\n }",
"public interface C32456b<T> {\n /* renamed from: a */\n void mo83696a(T t);\n }",
"private String convertir(String a) {\n StringBuilder atributo = new StringBuilder(a);\n atributo.insert(0, Character.toUpperCase(atributo.charAt(0)));\n return atributo.deleteCharAt(1).toString();\n }",
"protected m a(String name) {\n/* 42 */ return this.a.get(name);\n/* */ }",
"public interface AbstractC23925a {\n /* renamed from: a */\n void mo105476a();\n }",
"private interface C0257a {\n /* renamed from: a */\n float mo196a(ViewGroup viewGroup, View view);\n\n /* renamed from: b */\n float mo195b(ViewGroup viewGroup, View view);\n }",
"public interface C3598a {\n /* renamed from: a */\n void mo11024a(int i, int i2, String str);\n }",
"public interface C2459d {\n /* renamed from: a */\n C2451d mo3408a(C2457e c2457e);\n}",
"public interface am extends ak {\r\n /* renamed from: a */\r\n void mo194a(int i) throws RemoteException;\r\n\r\n /* renamed from: a */\r\n void mo195a(List<LatLng> list) throws RemoteException;\r\n\r\n /* renamed from: b */\r\n void mo196b(float f) throws RemoteException;\r\n\r\n /* renamed from: b */\r\n void mo197b(boolean z);\r\n\r\n /* renamed from: c */\r\n void mo198c(boolean z) throws RemoteException;\r\n\r\n /* renamed from: g */\r\n float mo199g() throws RemoteException;\r\n\r\n /* renamed from: h */\r\n int mo200h() throws RemoteException;\r\n\r\n /* renamed from: i */\r\n List<LatLng> mo201i() throws RemoteException;\r\n\r\n /* renamed from: j */\r\n boolean mo202j();\r\n\r\n /* renamed from: k */\r\n boolean mo203k();\r\n}",
"public interface C32459e<T> {\n /* renamed from: a */\n void mo83698a(T t);\n }",
"public interface C32458d<T> {\n /* renamed from: a */\n void mo83695a(T t);\n }",
"public interface C5482b {\n /* renamed from: a */\n void mo27575a();\n\n /* renamed from: a */\n void mo27576a(int i);\n }",
"public interface C27084a {\n /* renamed from: a */\n void mo69874a();\n\n /* renamed from: a */\n void mo69875a(List<Aweme> list, boolean z);\n }",
"public void a() {\n ((a) this.a).a();\n }",
"public interface C1153a {\n /* renamed from: a */\n void mo4520a(byte[] bArr);\n }",
"public interface C13373b {\n /* renamed from: a */\n void mo32681a(String str, int i, boolean z);\n}",
"public interface C40453c {\n /* renamed from: a */\n void mo100442a(C40429b bVar);\n\n /* renamed from: a */\n void mo100443a(List<String> list);\n\n /* renamed from: b */\n void mo100444b(List<C40429b> list);\n}",
"public interface AbstractC17367b {\n /* renamed from: a */\n void mo84655a();\n }",
"@Override\r\n\tpublic void a() {\n\t\t\r\n\t}",
"public interface C43270a {\n /* renamed from: a */\n void mo64942a(String str, long j, long j2);\n}",
"public interface C18928d {\n /* renamed from: a */\n void mo50320a(C18924b bVar);\n\n /* renamed from: b */\n void mo50321b(C18924b bVar);\n}",
"public interface C0087c {\n /* renamed from: a */\n String mo150a(String str);\n}",
"public interface C1529m {\n /* renamed from: a */\n void mo3767a(int i);\n\n /* renamed from: a */\n void mo3768a(String str);\n}",
"interface C4483e {\n /* renamed from: a */\n boolean mo34114a();\n}",
"public interface C1234b {\r\n /* renamed from: a */\r\n void m8367a();\r\n\r\n /* renamed from: b */\r\n void m8368b();\r\n}",
"public interface C10965j<T> {\n /* renamed from: a */\n T mo26439a();\n}",
"public interface C28772a {\n /* renamed from: a */\n View mo73990a(View view);\n }",
"@Override\n\tpublic void a() {\n\t\t\n\t}",
"public interface C8326b {\n /* renamed from: a */\n C8325a mo21498a(String str);\n\n /* renamed from: a */\n void mo21499a(C8325a aVar);\n}",
"void metodo1(int a, int[] b) {\r\n\t\ta += 5;//Par\\u00e1metro con el mismo nombre que el campo de la clase.\r\n\t\tb[0] += 7;//se produce un env\\u00edo por referencia, apunta a una copia de un objeto, que se asigna aqu\\u00ed.\r\n\t}",
"public interface C2367a {\n /* renamed from: a */\n C2368d mo1698a();\n }",
"interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }",
"public interface C4211a {\n\n /* renamed from: com.iab.omid.library.oguryco.c.a$a */\n public interface C4212a {\n /* renamed from: a */\n void mo28760a(View view, C4211a aVar, JSONObject jSONObject);\n }\n\n /* renamed from: a */\n JSONObject mo28758a(View view);\n\n /* renamed from: a */\n void mo28759a(View view, JSONObject jSONObject, C4212a aVar, boolean z);\n}",
"public interface C4697a extends C5595at {\n /* renamed from: a */\n void mo12634a();\n\n /* renamed from: a */\n void mo12635a(String str);\n\n /* renamed from: a */\n void mo12636a(boolean z);\n\n /* renamed from: b */\n void mo12637b();\n\n /* renamed from: c */\n void mo12638c();\n }",
"public interface C4773c {\n /* renamed from: a */\n void m15858a(int i);\n\n /* renamed from: a */\n void m15859a(int i, int i2);\n\n /* renamed from: a */\n void m15860a(int i, int i2, int i3);\n\n /* renamed from: b */\n void m15861b(int i, int i2);\n}",
"public interface C4869f {\n /* renamed from: a */\n C4865b mo6249a();\n}",
"public interface C1799a {\n /* renamed from: b */\n void mo3314b(String str);\n }",
"public interface C43499b {\n /* renamed from: a */\n void mo8445a(int i, String str, int i2, byte[] bArr);\n}",
"public interface C0601aq {\n /* renamed from: a */\n void mo9148a(int i, ArrayList<C0889x> arrayList);\n}",
"public interface C45101e {\n /* renamed from: b */\n void mo3796b(int i);\n}",
"public interface AbstractC6461g {\n /* renamed from: a */\n String mo42332a();\n}",
"public interface AbstractC1645a {\n /* renamed from: a */\n String mo17375a();\n }",
"public interface C6178c {\n /* renamed from: a */\n Map<String, String> mo14888a();\n}",
"public interface C5101b {\n /* renamed from: a */\n void mo5289a(C5102c c5102c);\n\n /* renamed from: b */\n void mo5290b(C5102c c5102c);\n}",
"public interface C19045k {\n /* renamed from: a */\n void mo50368a(int i, Object obj);\n\n /* renamed from: b */\n void mo50369b(int i, Object obj);\n}",
"public b a()\r\n/* 12: */ {\r\n/* 13:13 */ return this.a;\r\n/* 14: */ }",
"public interface C7720a {\n /* renamed from: a */\n long mo20406a();\n}",
"public String a()\r\n/* 25: */ {\r\n/* 26:171 */ return \"dig.\" + this.a;\r\n/* 27: */ }",
"public interface ayt {\n /* renamed from: a */\n int mo1635a(long j, List list);\n\n /* renamed from: a */\n long mo1636a(long j, alb alb);\n\n /* renamed from: a */\n void mo1637a();\n\n /* renamed from: a */\n void mo1638a(long j, long j2, List list, ayp ayp);\n\n /* renamed from: a */\n void mo1639a(ayl ayl);\n\n /* renamed from: a */\n boolean mo1640a(ayl ayl, boolean z, Exception exc, long j);\n}",
"public interface C24221b extends C28343z<C28318an> {\n /* renamed from: a */\n void mo62991a(int i);\n\n String aw_();\n\n /* renamed from: e */\n Aweme mo62993e();\n}",
"public interface C4051c {\n /* renamed from: a */\n boolean mo23707a();\n}",
"public interface C45112b {\n /* renamed from: a */\n List<C45111a> mo107674a(Integer num);\n\n /* renamed from: a */\n List<C45111a> mo107675a(Integer num, Integer num2);\n\n /* renamed from: a */\n void mo107676a(C45111a aVar);\n\n /* renamed from: b */\n void mo107677b(Integer num);\n\n /* renamed from: c */\n long mo107678c(Integer num);\n}",
"public void acionou(int a){\n\t\t\tb=a;\n\t\t}",
"public interface C44963i {\n /* renamed from: a */\n void mo63037a(int i, int i2);\n\n void aA_();\n\n /* renamed from: b */\n void mo63039b(int i, int i2);\n}",
"public interface C32457c<T> {\n /* renamed from: a */\n void mo83699a(T t, int i, int i2, String str);\n }",
"public interface C5861g {\n /* renamed from: a */\n void mo18320a(C7251a aVar);\n\n @Deprecated\n /* renamed from: a */\n void mo18321a(C7251a aVar, String str);\n\n /* renamed from: a */\n void mo18322a(C7252b bVar);\n\n /* renamed from: a */\n void mo18323a(C7253c cVar);\n\n /* renamed from: a */\n void mo18324a(C7260j jVar);\n}",
"public interface C0937a {\n /* renamed from: a */\n void mo3807a(C0985po[] poVarArr);\n }",
"public interface C8466a {\n /* renamed from: a */\n void mo25956a(int i);\n\n /* renamed from: a */\n void mo25957a(long j, long j2);\n }",
"public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }",
"public interface C43470b {\n /* renamed from: a */\n void mo61496a(C43469a aVar, C43471c cVar);\n }",
"public interface AbstractC18255a {\n /* renamed from: a */\n void mo88521a();\n\n /* renamed from: a */\n void mo88522a(String str);\n\n /* renamed from: b */\n void mo88523b();\n\n /* renamed from: c */\n void mo88524c();\n }",
"public interface C1436d {\n /* renamed from: a */\n C1435c mo1754a(C1433a c1433a, C1434b c1434b);\n}",
"public interface C4150sl {\n /* renamed from: a */\n void mo15005a(C4143se seVar);\n}",
"public void a(nm paramnm)\r\n/* 28: */ {\r\n/* 29:45 */ paramnm.a(this);\r\n/* 30: */ }",
"public interface C19351a {\n /* renamed from: b */\n void mo30633b(int i, String str, byte[] bArr);\n }",
"public interface C11113o {\n /* renamed from: a */\n void mo37759a(String str);\n }",
"public interface C39504az {\n /* renamed from: a */\n int mo98207a();\n\n /* renamed from: a */\n void mo98208a(boolean z);\n\n /* renamed from: b */\n int mo98209b();\n\n /* renamed from: c */\n int mo98355c();\n\n /* renamed from: d */\n int mo98356d();\n\n /* renamed from: e */\n int mo98357e();\n\n /* renamed from: f */\n int mo98358f();\n}",
"protected a<T> a(Tag.e<T> var0) {\n/* 80 */ Tag.a var1 = b(var0);\n/* 81 */ return new a<>(var1, this.c, \"vanilla\");\n/* */ }",
"public interface C35565a {\n /* renamed from: a */\n C45321i mo90380a();\n }",
"public interface C21298a {\n /* renamed from: a */\n void mo57275a();\n\n /* renamed from: a */\n void mo57276a(Exception exc);\n\n /* renamed from: b */\n void mo57277b();\n\n /* renamed from: c */\n void mo57278c();\n }",
"public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }",
"public interface C0456a {\n /* renamed from: a */\n void mo2090a(C0455b bVar);\n\n /* renamed from: a */\n boolean mo2091a(C0455b bVar, Menu menu);\n\n /* renamed from: a */\n boolean mo2092a(C0455b bVar, MenuItem menuItem);\n\n /* renamed from: b */\n boolean mo2093b(C0455b bVar, Menu menu);\n }",
"public interface C4724o {\n /* renamed from: a */\n void mo4872a(int i, String str);\n\n /* renamed from: a */\n void mo4873a(C4718l c4718l);\n\n /* renamed from: b */\n void mo4874b(C4718l c4718l);\n}",
"public interface C7654b {\n /* renamed from: a */\n C7904c mo24084a();\n\n /* renamed from: b */\n C7716a mo24085b();\n }",
"public interface C2603a {\n /* renamed from: a */\n String mo1889a(String str, String str2, String str3, String str4);\n }",
"public interface afp {\n /* renamed from: a */\n C0512sx mo169a(C0497si siVar, afj afj, afr afr, Context context);\n}",
"public interface C0615ja extends b<HomeFragment> {\n\n /* renamed from: c.c.a.h.b.ja$a */\n /* compiled from: FragmentModule_HomeFragment$app_bazaarRelease */\n public static abstract class a extends b.a<HomeFragment> {\n }\n}",
"public interface a {\n\n /* renamed from: c.b.a.c.b.b.a$a reason: collision with other inner class name */\n /* compiled from: DiskCache */\n public interface C0054a {\n a build();\n }\n\n /* compiled from: DiskCache */\n public interface b {\n boolean a(File file);\n }\n\n File a(c cVar);\n\n void a(c cVar, b bVar);\n}",
"public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }",
"public interface AbstractC17368c {\n /* renamed from: a */\n void mo84656a(float f);\n }",
"interface C0932a {\n /* renamed from: a */\n void mo7438a(int i, int i2);\n\n /* renamed from: b */\n void mo7439b(C0933b bVar);\n\n /* renamed from: c */\n void mo7440c(int i, int i2, Object obj);\n\n /* renamed from: d */\n void mo7441d(C0933b bVar);\n\n /* renamed from: e */\n RecyclerView.ViewHolder mo7442e(int i);\n\n /* renamed from: f */\n void mo7443f(int i, int i2);\n\n /* renamed from: g */\n void mo7444g(int i, int i2);\n\n /* renamed from: h */\n void mo7445h(int i, int i2);\n }",
"public interface C10330c {\n /* renamed from: a */\n C7562b<C10403b, C10328a> mo25041a();\n}",
"public interface C3819a {\n /* renamed from: a */\n void mo23214a(Message message);\n }",
"private Proof atoAImpl(Expression a) {\n Proof where = axm2(a, arrow(a, a), a); //a->(a->a) -> (a->(a->a)->a) -> (a -> a)\n Proof one = axm1(a, a); //a->a->a\n Proof two = axm1(a, arrow(a, a)); //a->(a->a)->A\n return mpTwice(where, one, two);\n }",
"interface C1939a {\n /* renamed from: a */\n Bitmap mo1406a(Bitmap bitmap, float f);\n}",
"public interface a extends com.bankeen.d.b.b.a {\n void a();\n\n void b();\n }",
"public b[] a() {\n/* 95 */ return this.a;\n/* */ }",
"interface C8361a {\n /* renamed from: b */\n float mo18284b(ViewGroup viewGroup, View view);\n\n /* renamed from: c */\n float mo18281c(ViewGroup viewGroup, View view);\n }"
]
| [
"0.62497115",
"0.6242887",
"0.61394435",
"0.61176854",
"0.6114027",
"0.60893",
"0.6046901",
"0.6024682",
"0.60201293",
"0.5975212",
"0.59482527",
"0.59121317",
"0.5883635",
"0.587841",
"0.58703005",
"0.5868436",
"0.5864884",
"0.5857492",
"0.58306104",
"0.5827752",
"0.58272064",
"0.5794689",
"0.57890314",
"0.57838726",
"0.5775679",
"0.57694733",
"0.5769128",
"0.57526815",
"0.56907034",
"0.5677874",
"0.5670547",
"0.56666386",
"0.56592244",
"0.5658682",
"0.56574154",
"0.5654324",
"0.5644676",
"0.56399715",
"0.5638734",
"0.5630582",
"0.56183887",
"0.5615435",
"0.56069666",
"0.5605207",
"0.56005067",
"0.559501",
"0.55910283",
"0.5590222",
"0.55736613",
"0.5556682",
"0.5554544",
"0.5550076",
"0.55493855",
"0.55446684",
"0.5538079",
"0.5529058",
"0.5528109",
"0.552641",
"0.5525864",
"0.552186",
"0.5519972",
"0.5509587",
"0.5507195",
"0.54881203",
"0.5485328",
"0.54826045",
"0.5482066",
"0.5481586",
"0.5479751",
"0.54776895",
"0.54671466",
"0.5463307",
"0.54505056",
"0.54436916",
"0.5440517",
"0.5439747",
"0.5431944",
"0.5422869",
"0.54217863",
"0.5417556",
"0.5403905",
"0.5400223",
"0.53998446",
"0.5394735",
"0.5388649",
"0.5388258",
"0.5374842",
"0.5368887",
"0.53591394",
"0.5357029",
"0.5355688",
"0.535506",
"0.5355034",
"0.53494394",
"0.5341044",
"0.5326166",
"0.53236824",
"0.53199095",
"0.53177035",
"0.53112453",
"0.5298229"
]
| 0.0 | -1 |
/ renamed from: b | void mo100444b(List<C40429b> list); | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"void mo2508a(bxb bxb);",
"@Override\n public void func_104112_b() {\n \n }",
"@Override\n public void b() {\n }",
"public interface C19351a {\n /* renamed from: b */\n void mo30633b(int i, String str, byte[] bArr);\n }",
"@Override\n\tpublic void b2() {\n\t\t\n\t}",
"void metodo1(int a, int[] b) {\r\n\t\ta += 5;//Par\\u00e1metro con el mismo nombre que el campo de la clase.\r\n\t\tb[0] += 7;//se produce un env\\u00edo por referencia, apunta a una copia de un objeto, que se asigna aqu\\u00ed.\r\n\t}",
"interface bxc {\n /* renamed from: a */\n void mo2508a(bxb bxb);\n}",
"@Override\n\tpublic void b() {\n\n\t}",
"interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }",
"public bb b() {\n return a(this.a);\n }",
"@Override\n\tpublic void b1() {\n\t\t\n\t}",
"public void b() {\r\n }",
"@Override\n\tpublic void bbb() {\n\t\t\n\t}",
"public interface C34379a {\n /* renamed from: a */\n void mo46242a(bmc bmc);\n }",
"public abstract void b(StringBuilder sb);",
"public void b() {\n }",
"public void b() {\n }",
"protected b(int mb) {\n/* 87 */ this.b = mb;\n/* */ }",
"public u(b paramb)\r\n/* 7: */ {\r\n/* 8: 9 */ this.a = paramb;\r\n/* 9: */ }",
"public interface b {\n void H_();\n\n void I_();\n\n void J_();\n\n void a(C0063d dVar);\n\n void a(byte[] bArr);\n\n void b(boolean z);\n }",
"public b[] a() {\n/* 95 */ return this.a;\n/* */ }",
"public interface C7654b {\n /* renamed from: a */\n C7904c mo24084a();\n\n /* renamed from: b */\n C7716a mo24085b();\n }",
"public interface C1153a {\n /* renamed from: a */\n void mo4520a(byte[] bArr);\n }",
"public interface C43499b {\n /* renamed from: a */\n void mo8445a(int i, String str, int i2, byte[] bArr);\n}",
"public void b() {\n ((a) this.a).b();\n }",
"public np a()\r\n/* 33: */ {\r\n/* 34:49 */ return this.b;\r\n/* 35: */ }",
"b(a aVar) {\n super(0);\n this.this$0 = aVar;\n }",
"public t b() {\n return a(this.a);\n }",
"public interface C32456b<T> {\n /* renamed from: a */\n void mo83696a(T t);\n }",
"public static String a(int c) {\n/* 89 */ return b.a(c);\n/* */ }",
"private void m678b(byte b) {\n byte[] bArr = this.f523r;\n bArr[0] = b;\n this.f552g.mo502b(bArr);\n }",
"public interface C23407b {\n /* renamed from: a */\n void mo60892a();\n\n /* renamed from: b */\n void mo60893b();\n }",
"public abstract T zzm(B b);",
"public b a()\r\n/* 12: */ {\r\n/* 13:13 */ return this.a;\r\n/* 14: */ }",
"public void b(World paramaqu, BlockPosition paramdt, Block parambec)\r\n/* 27: */ {\r\n/* 28: 47 */ bcm localbcm = paramaqu.s(paramdt);\r\n/* 29: 48 */ if ((localbcm instanceof bdv)) {\r\n/* 30: 49 */ ((bdv)localbcm).h();\r\n/* 31: */ } else {\r\n/* 32: 51 */ super.b(paramaqu, paramdt, parambec);\r\n/* 33: */ }\r\n/* 34: */ }",
"public abstract void zzc(B b, int i, int i2);",
"public interface b {\n}",
"public interface b {\n}",
"private void m10263b(byte b) throws cf {\r\n this.f6483r[0] = b;\r\n this.g.m10347b(this.f6483r);\r\n }",
"BSubstitution createBSubstitution();",
"public void b(ahd paramahd) {}",
"void b();",
"public interface C18928d {\n /* renamed from: a */\n void mo50320a(C18924b bVar);\n\n /* renamed from: b */\n void mo50321b(C18924b bVar);\n}",
"B database(S database);",
"public interface C0615ja extends b<HomeFragment> {\n\n /* renamed from: c.c.a.h.b.ja$a */\n /* compiled from: FragmentModule_HomeFragment$app_bazaarRelease */\n public static abstract class a extends b.a<HomeFragment> {\n }\n}",
"public abstract C0631bt mo9227aB();",
"public an b() {\n return a(this.a);\n }",
"protected abstract void a(bru parambru);",
"static void go(Base b) {\n\t\tb.add(8);\n\t}",
"void mo46242a(bmc bmc);",
"public interface b extends c {\n void a(Float f);\n\n void a(Integer num);\n\n void b(Float f);\n\n void c(Float f);\n\n String d();\n\n void d(Float f);\n\n void d(String str);\n\n void e(Float f);\n\n void e(String str);\n\n void f(String str);\n\n void g(String str);\n\n Long j();\n\n LineChart k();\n }",
"public interface bca extends bbn {\n bca a();\n\n bca a(String str);\n\n bca b(String str);\n\n bca c(String str);\n}",
"public interface a extends com.bankeen.d.b.b.a {\n void a();\n\n void b();\n }",
"public abstract BoundType b();",
"public void b(amj paramamj)\r\n/* 538: */ {\r\n/* 539:579 */ this.f = paramamj;\r\n/* 540: */ }",
"b(a aVar, com.bytedance.jedi.model.h.a aVar2) {\n super(aVar2);\n this.f21531a = aVar;\n this.f21532b = new com.bytedance.jedi.model.h.f(aVar);\n }",
"private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }",
"public void b(ahb paramahb)\r\n/* 583: */ {\r\n/* 584:625 */ for (int i = 0; i < this.a.length; i++) {\r\n/* 585:626 */ this.a[i] = amj.b(paramahb.a[i]);\r\n/* 586: */ }\r\n/* 587:628 */ for (i = 0; i < this.b.length; i++) {\r\n/* 588:629 */ this.b[i] = amj.b(paramahb.b[i]);\r\n/* 589: */ }\r\n/* 590:631 */ this.c = paramahb.c;\r\n/* 591: */ }",
"interface b {\n\n /* compiled from: CreditAccountContract */\n public interface a extends com.bankeen.d.b.b.a {\n void a();\n\n void b();\n }\n\n /* compiled from: CreditAccountContract */\n public interface b extends c {\n void a(Float f);\n\n void a(Integer num);\n\n void b(Float f);\n\n void c(Float f);\n\n String d();\n\n void d(Float f);\n\n void d(String str);\n\n void e(Float f);\n\n void e(String str);\n\n void f(String str);\n\n void g(String str);\n\n Long j();\n\n LineChart k();\n }\n}",
"@Override\n\tpublic void visit(PartB partB) {\n\n\t}",
"public abstract void zzb(B b, int i, long j);",
"public abstract void zza(B b, int i, zzeh zzeh);",
"int metodo2(int a, int b) {\r\n\r\n\t\tthis.a += 5; // se modifica el campo del objeto, el uso de la palabra reservada this se utiliza para referenciar al campo.\r\n\t\tb += 7;\r\n\t\treturn a; // modifica en la asignaci\\u00f3n\r\n\t}",
"private void internalCopy(Board b) {\n for (int i = 0; i < SIDE * SIDE; i += 1) {\n set(i, b.get(i));\n }\n\n _directions = b._directions;\n _whoseMove = b._whoseMove;\n _history = b._history;\n }",
"public int b()\r\n/* 69: */ {\r\n/* 70:74 */ return this.b;\r\n/* 71: */ }",
"public void b(StringBuilder sb) {\n sb.append(this.a);\n sb.append(')');\n }",
"public void b() {\n e$a e$a;\n try {\n e$a = this.b;\n }\n catch (IOException iOException) {\n return;\n }\n Object object = this.c;\n e$a.b(object);\n }",
"public abstract void a(StringBuilder sb);",
"public interface C45101e {\n /* renamed from: b */\n void mo3796b(int i);\n}",
"public abstract void zzf(Object obj, B b);",
"public interface bdp {\n\n /* renamed from: a */\n public static final bdp f3422a = new bdo();\n\n /* renamed from: a */\n bdm mo1784a(akh akh);\n}",
"@Override\n\tpublic void parse(Buffer b) {\n\t\t\n\t}",
"@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}",
"public abstract void a(b paramb, int paramInt1, int paramInt2);",
"public void mo1945a(byte b) throws cf {\r\n m10263b(b);\r\n }",
"void mo83703a(C32456b<T> bVar);",
"public void a(String str) {\n ((b.b) this.b).d(str);\n }",
"public void selectB() { }",
"BOperation createBOperation();",
"void metodo1(int a, int b) {\r\n\t\ta += 5;//par\\u00e1metro con el mismo nombre que el campo.\r\n\t\tb += 7;\r\n\t}",
"private static void m2196a(StringBuffer stringBuffer, byte b) {\n stringBuffer.append(\"0123456789ABCDEF\".charAt((b >> 4) & 15)).append(\"0123456789ABCDEF\".charAt(b & 15));\n }",
"public interface C1799a {\n /* renamed from: b */\n void mo3314b(String str);\n }",
"public void b(fv paramfv)\r\n/* 408: */ {\r\n/* 409:423 */ this.a = new amj[36];\r\n/* 410:424 */ this.b = new amj[4];\r\n/* 411:425 */ for (int i = 0; i < paramfv.c(); i++)\r\n/* 412: */ {\r\n/* 413:426 */ fn localfn = paramfv.b(i);\r\n/* 414:427 */ int j = localfn.d(\"Slot\") & 0xFF;\r\n/* 415:428 */ amj localamj = amj.a(localfn);\r\n/* 416:429 */ if (localamj != null)\r\n/* 417: */ {\r\n/* 418:430 */ if ((j >= 0) && (j < this.a.length)) {\r\n/* 419:431 */ this.a[j] = localamj;\r\n/* 420: */ }\r\n/* 421:433 */ if ((j >= 100) && (j < this.b.length + 100)) {\r\n/* 422:434 */ this.b[(j - 100)] = localamj;\r\n/* 423: */ }\r\n/* 424: */ }\r\n/* 425: */ }\r\n/* 426: */ }",
"public void b(String str) {\n ((b.b) this.b).e(str);\n }",
"public String b()\r\n/* 35: */ {\r\n/* 36:179 */ return a();\r\n/* 37: */ }",
"public abstract void zza(B b, int i, T t);",
"public Item b(World paramaqu, BlockPosition paramdt)\r\n/* 189: */ {\r\n/* 190:220 */ return null;\r\n/* 191: */ }",
"public abstract void zza(B b, int i, long j);",
"public interface C5101b {\n /* renamed from: a */\n void mo5289a(C5102c c5102c);\n\n /* renamed from: b */\n void mo5290b(C5102c c5102c);\n}",
"private interface C0257a {\n /* renamed from: a */\n float mo196a(ViewGroup viewGroup, View view);\n\n /* renamed from: b */\n float mo195b(ViewGroup viewGroup, View view);\n }",
"public abstract void mo9798a(byte b);",
"public void mo9798a(byte b) {\n if (this.f9108f == this.f9107e) {\n mo9827i();\n }\n byte[] bArr = this.f9106d;\n int i = this.f9108f;\n this.f9108f = i + 1;\n bArr[i] = b;\n this.f9109g++;\n }",
"public interface C1234b {\r\n /* renamed from: a */\r\n void m8367a();\r\n\r\n /* renamed from: b */\r\n void m8368b();\r\n}",
"private void m676a(TField bkVar, byte b) {\n if (b == -1) {\n b = m687e(bkVar.f538b);\n }\n short s = bkVar.f539c;\n short s2 = this.f519n;\n if (s <= s2 || s - s2 > 15) {\n m678b(b);\n mo446a(bkVar.f539c);\n } else {\n m686d(b | ((s - s2) << 4));\n }\n this.f519n = bkVar.f539c;\n }",
"private static void m831a(C0741g<?> gVar, C0747b bVar) {\n gVar.mo9477a(C0743i.f718b, (C0739e<? super Object>) bVar);\n gVar.mo9476a(C0743i.f718b, (C0738d) bVar);\n gVar.mo9474a(C0743i.f718b, (C0736b) bVar);\n }",
"public interface C40453c {\n /* renamed from: a */\n void mo100442a(C40429b bVar);\n\n /* renamed from: a */\n void mo100443a(List<String> list);\n\n /* renamed from: b */\n void mo100444b(List<C40429b> list);\n}",
"private void j()\n/* */ {\n/* 223 */ c localc = this.b;\n/* 224 */ this.b = this.c;\n/* 225 */ this.c = localc;\n/* 226 */ this.c.b();\n/* */ }",
"public lj ar(byte b) {\n throw new Runtime(\"d2j fail translate: java.lang.RuntimeException: can not merge I and Z\\r\\n\\tat com.googlecode.dex2jar.ir.TypeClass.merge(TypeClass.java:100)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeRef.updateTypeClass(TypeTransformer.java:174)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeAnalyze.provideAs(TypeTransformer.java:780)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeAnalyze.e1expr(TypeTransformer.java:496)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeAnalyze.exExpr(TypeTransformer.java:713)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeAnalyze.exExpr(TypeTransformer.java:703)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeAnalyze.enexpr(TypeTransformer.java:698)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeAnalyze.exExpr(TypeTransformer.java:719)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeAnalyze.exExpr(TypeTransformer.java:703)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeAnalyze.s1stmt(TypeTransformer.java:810)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeAnalyze.sxStmt(TypeTransformer.java:840)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer$TypeAnalyze.analyze(TypeTransformer.java:206)\\r\\n\\tat com.googlecode.dex2jar.ir.ts.TypeTransformer.transform(TypeTransformer.java:44)\\r\\n\\tat com.googlecode.d2j.dex.Dex2jar$2.optimize(Dex2jar.java:162)\\r\\n\\tat com.googlecode.d2j.dex.Dex2Asm.convertCode(Dex2Asm.java:414)\\r\\n\\tat com.googlecode.d2j.dex.ExDex2Asm.convertCode(ExDex2Asm.java:42)\\r\\n\\tat com.googlecode.d2j.dex.Dex2jar$2.convertCode(Dex2jar.java:128)\\r\\n\\tat com.googlecode.d2j.dex.Dex2Asm.convertMethod(Dex2Asm.java:509)\\r\\n\\tat com.googlecode.d2j.dex.Dex2Asm.convertClass(Dex2Asm.java:406)\\r\\n\\tat com.googlecode.d2j.dex.Dex2Asm.convertDex(Dex2Asm.java:422)\\r\\n\\tat com.googlecode.d2j.dex.Dex2jar.doTranslate(Dex2jar.java:172)\\r\\n\\tat com.googlecode.d2j.dex.Dex2jar.to(Dex2jar.java:272)\\r\\n\\tat com.googlecode.dex2jar.tools.Dex2jarCmd.doCommandLine(Dex2jarCmd.java:108)\\r\\n\\tat com.googlecode.dex2jar.tools.BaseCmd.doMain(BaseCmd.java:288)\\r\\n\\tat com.googlecode.dex2jar.tools.Dex2jarCmd.main(Dex2jarCmd.java:32)\\r\\n\");\n }",
"public interface AbstractC10485b {\n /* renamed from: a */\n void mo64153a(boolean z);\n }",
"public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }",
"interface C8361a {\n /* renamed from: b */\n float mo18284b(ViewGroup viewGroup, View view);\n\n /* renamed from: c */\n float mo18281c(ViewGroup viewGroup, View view);\n }"
]
| [
"0.64558864",
"0.6283203",
"0.6252635",
"0.6250949",
"0.6244743",
"0.6216273",
"0.6194491",
"0.6193556",
"0.61641675",
"0.6140157",
"0.60993093",
"0.60974354",
"0.6077849",
"0.6001867",
"0.5997364",
"0.59737104",
"0.59737104",
"0.5905105",
"0.5904295",
"0.58908087",
"0.5886636",
"0.58828026",
"0.5855491",
"0.584618",
"0.5842517",
"0.5824137",
"0.5824071",
"0.58097327",
"0.5802052",
"0.58012927",
"0.579443",
"0.5792392",
"0.57902914",
"0.5785124",
"0.57718205",
"0.57589084",
"0.5735892",
"0.5735892",
"0.5734873",
"0.5727929",
"0.5720821",
"0.5712531",
"0.5706813",
"0.56896514",
"0.56543154",
"0.5651059",
"0.5649904",
"0.56496733",
"0.5647035",
"0.5640965",
"0.5640109",
"0.563993",
"0.5631903",
"0.5597427",
"0.55843794",
"0.5583287",
"0.557783",
"0.55734867",
"0.55733293",
"0.5572254",
"0.55683887",
"0.55624336",
"0.55540246",
"0.5553985",
"0.55480546",
"0.554261",
"0.5535739",
"0.5529958",
"0.5519634",
"0.5517503",
"0.55160624",
"0.5511545",
"0.5505353",
"0.5500533",
"0.5491741",
"0.5486198",
"0.5481978",
"0.547701",
"0.54725856",
"0.5471632",
"0.5463497",
"0.5460805",
"0.5454913",
"0.5454885",
"0.54519916",
"0.5441594",
"0.5436747",
"0.5432453",
"0.5425923",
"0.5424724",
"0.54189867",
"0.54162544",
"0.54051477",
"0.53998184",
"0.53945845",
"0.53887725",
"0.5388146",
"0.5387678",
"0.53858143",
"0.53850687",
"0.5384439"
]
| 0.0 | -1 |
This problem is similar to meeting rooms problem | public static void main(String[] args) {
Interval i1 = new Interval(5, 24);
Interval i2 = new Interval(15, 25);
Interval i3 = new Interval(27, 40);
Interval i4 = new Interval(50, 60);
Interval[] intervals = { i1, i2, i3, i4 };
// Problem 2 : Given an array of meetings time intervals consisting of start and
// end times. Determine number of conference rooms required.
int numMeetings = minMeetingRooms(intervals);
System.out.println(numMeetings);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void createRooms()//Method was given\n { \n \n // create the rooms, format is name = new Room(\"description of the situation\"); ex. desc = 'in a small house' would print 'you are in a small house.'\n outside = new Room(\"outside\", \"outside of a small building with a door straight ahead. There is a welcome mat, a mailbox, and a man standing in front of the door.\", false);\n kitchen = new Room(\"kitchen\", \"in what appears to be a kitchen. There is a sink and some counters with an easter egg on top of the counter. There is a locked door straight ahead, and a man standing next to a potted plant. There is also a delicious looking chocolate bar sitting on the counter... how tempting\", true);\n poolRoom = new Room(\"pool room\", \"in a new room that appears much larger than the first room.You see a table with a flashlight, towel, and scissors on it. There is also a large swimming pool with what looks like a snorkel deep in the bottom of the pool. Straight ahead of you stands the same man as before.\", true);\n library = new Room(\"library\", \"facing east in a new, much smaller room than before. There are endless rows of bookshelves filling the room. All of the books have a black cover excpet for two: one red book and one blue book. The man stands in front of you, next to the first row of bookshelves\", true);\n exitRoom = new Room(\"exit\", \"outside of the building again. You have successfully escaped, congratulations! Celebrate with a non-poisonous chocolate bar\",true);\n \n // initialise room exits, goes (north, east, south, west)\n outside.setExits(kitchen, null, null, null);\n kitchen.setExits(poolRoom, null, outside, null);\n poolRoom.setExits(null, library, kitchen, null);\n library.setExits(null, null, exitRoom, poolRoom);\n exitRoom.setExits(null, null, null, null); \n \n currentRoom = outside; // start game outside\n }",
"public void wallsAndGates(int[][] rooms) {\n if (rooms.length == 0 || rooms[0].length == 0) return;\n Queue<int[]> queue = new LinkedList<>();\n for (int i = 0; i < rooms.length; i++) {\n for (int j = 0; j < rooms[0].length; j++) {\n if (rooms[i][j] == 0) queue.add(new int[]{i, j});\n }\n }\n while (!queue.isEmpty()) {\n int[] top = queue.remove();\n int row = top[0], col = top[1];\n if (row > 0 && rooms[row - 1][col] == Integer.MAX_VALUE) {\n rooms[row - 1][col] = rooms[row][col] + 1;\n queue.add(new int[]{row - 1, col});\n }\n if (row < rooms.length - 1 && rooms[row + 1][col] == Integer.MAX_VALUE) {\n rooms[row + 1][col] = rooms[row][col] + 1;\n queue.add(new int[]{row + 1, col});\n }\n if (col > 0 && rooms[row][col - 1] == Integer.MAX_VALUE) {\n rooms[row][col - 1] = rooms[row][col] + 1;\n queue.add(new int[]{row, col - 1});\n }\n if (col < rooms[0].length - 1 && rooms[row][col + 1] == Integer.MAX_VALUE) {\n rooms[row][col + 1] = rooms[row][col] + 1;\n queue.add(new int[]{row, col + 1});\n }\n }\n }",
"@Test\n\tpublic void insideRoomTests() {\n\t\t//Tests middle of room\n\t\tSet<BoardCell> testList = board.getAdjList(3, 11);\n\t\tassertEquals(0, testList.size());\n\t\t//Tests a room space that is next to a walkway space\n\t\ttestList = board.getAdjList(16, 10);\n\t\tassertEquals(0, testList.size());\n\n\t}",
"public void wallsAndGates(int[][] rooms) {\n if (rooms == null || rooms.length == 0 || rooms[0] == null || rooms[0].length == 0)\n return;\n\n Queue<int[]> queue = new LinkedList<>();\n\n for (int i = 0; i < rooms.length; i++) {\n for (int j = 0; j < rooms[0].length; j++) {\n if (rooms[i][j] == 0)\n queue.add(new int[]{i,j});\n }\n }\n\n while (!queue.isEmpty()) {\n int[] top = queue.remove();\n int row = top[0];\n int col = top[1];\n if (row > 0 && rooms[row - 1][col] == Integer.MAX_VALUE) {\n rooms[row - 1][col] = rooms[row][col] + 1;\n queue.add(new int[]{row - 1, col});\n }\n if (row < rooms.length - 1 && rooms[row + 1][col] == Integer.MAX_VALUE) {\n rooms[row+1][col] = rooms[row][col] + 1;\n queue.add(new int[]{row + 1, col});\n }\n if (col > 0 && rooms[row][col - 1] == Integer.MAX_VALUE){\n rooms[row][col -1] = rooms[row][col] + 1;\n queue.add(new int[]{row, col - 1});\n }\n if (col < rooms[0].length - 1 && rooms[row][col + 1] == Integer.MAX_VALUE) {\n rooms[row][col +1] = rooms[row][col] + 1;\n queue.add(new int[]{row, col + 1});\n }\n }\n\n }",
"private void createRooms()\n {\n Room a1, a2, a3, b1, b2, b3, c1, c2, c3, bridge, outskirts;\n \n // create the rooms\n a1= new Room(\"see a strong river flowing south to the west. The trees seem to be letting up a little to the north.\");\n a2 = new Room(\" are still in a very dense forest. Maybe the trees are clearing up the the north?\");\n a3 = new Room(\"see a 30 foot cliff looming over the forest to the east. No way you could climb that. Every other direction is full of trees.\");\n b1 = new Room(\"see a strong river flowing to the west. Heavily wooded areas are in all other directions.\");\n b2 = new Room(\"see only trees around you.\");\n b3 = new Room(\"see a 30 foot cliff to the east. There might be one spot that is climbable. Trees surround you every other way.\");\n c1 = new Room(\" see the river cuts east here, but there seems to be a small wooden bridge to the south over it. The trees are less the direction that the river flows.\");\n c2 = new Room(\"are on a peaceful riverbank. If you weren't lost, this might be a nice spot for a picnic.\");\n c3 = new Room(\"see a 30 foot cliff to your east and a strong flowing river to the south. Your options are definitely limited.\");\n outskirts = new Room(\"make your way out of the trees and find yourself in an open field.\");\n cliff = new Room(\"managed to climb up the rocks to the top of the cliff. Going down, doesn't look as easy. You have to almost be out though now!\");\n bridge = new Room(\"cross the bridge and find a small trail heading south!\");\n win = new Room(\" manage to spot a road not too far off! Congratulations on finding your way out of the woods! Have a safe ride home! :)\" );\n fail = new Room(\" are entirely lost. It is pitch black out and there is no way that you are getting out of here tonight. I'm sorry, you LOSE.\");\n \n // initialise room exits\n a1.setExit(\"north\", outskirts);\n a1.setExit(\"east\", a2);\n a1.setExit(\"south\", b1);\n \n a2.setExit(\"east\", a3);\n a2.setExit(\"west\", a1);\n a2.setExit(\"south\", b2);\n a2.setExit(\"north\", outskirts);\n \n a3.setExit(\"north\", outskirts);\n a3.setExit(\"west\", a2);\n a3.setExit(\"south\", b3);\n \n b1.setExit(\"north\", a1);\n b1.setExit(\"east\", b2);\n b1.setExit(\"south\", c1);\n \n b2.setExit(\"east\", b3);\n b2.setExit(\"west\", b1);\n b2.setExit(\"south\", c2);\n b2.setExit(\"north\", a2);\n \n b3.setExit(\"north\", a3);\n b3.setExit(\"west\", b2);\n b3.setExit(\"south\", c3);\n b3.setExit(\"up\", cliff);\n \n c1.setExit(\"north\", b1);\n c1.setExit(\"east\", c2);\n c1.setExit(\"south\" , bridge);\n \n c2.setExit(\"east\", c3);\n c2.setExit(\"west\", c1);\n c2.setExit(\"north\", b2);\n \n c3.setExit(\"west\", c2);\n c3.setExit(\"north\", b3);\n \n outskirts.setExit(\"north\", win);\n outskirts.setExit(\"east\", a3);\n outskirts.setExit(\"west\", a1);\n outskirts.setExit(\"south\", a2);\n \n cliff.setExit(\"north\", outskirts);\n cliff.setExit(\"east\", win);\n \n bridge.setExit(\"north\", c1);\n bridge.setExit(\"south\", win);\n \n c3.addItem(new Item (\"shiny stone\", 0.1));\n a1.addItem(new Item (\"sturdy branch\", 2));\n a3.addItem(new Item(\"water bottle\" , 0.5));\n a3.addItem(new Item(\"ripped backpack\" , 1));\n currentRoom = b2; // start game outside\n }",
"protected static String scheduleRoom(ArrayList<Room> roomList) {\n if (roomList.size() > 0) {\n System.out.println(\"Schedule a room:\");\n String name = getRoomName();\n // if (findRoomIndex(roomList, name) != -1) {\n System.out.println(\"Start Date? (yyyy-mm-dd):\");\n String startDate = keyboard.next();\n System.out.println(\"Start Time?\");\n String startTime = keyboard.next();\n startTime = startTime + \":00.0\";\n \n String tStartDate = startDate + startTime;\n String avRooms = availableRooms(roomList,tStartDate);\n \n System.out.println(\"End Date? (yyyy-mm-dd):\");\n String endDate = keyboard.next();\n System.out.println(\"End Time?\");\n String endTime = keyboard.next();\n endTime = endTime + \":00.0\";\n Timestamp startTimestamp = Timestamp.valueOf(startDate + \" \"\n + startTime);\n Timestamp endTimestamp = Timestamp.valueOf(endDate + \" \" + endTime);\n\n System.out.println(\"Subject?\");\n String subject = keyboard.next();\n Room curRoom = getRoomFromName(roomList, name);\n Meeting meeting = new Meeting(startTimestamp, endTimestamp, subject);\n\n // check wheather time is already exists for timestamp\n curRoom.addMeeting(meeting);\n return \"Successfully scheduled meeting!\";\n\n } else {\n return \"No room is available for schedule\";\n }\n }",
"private ArrayList<Room> createRooms() {\n //Adding starting position, always rooms(index0)\n\n rooms.add(new Room(\n \"Du sidder på dit kontor. Du kigger på uret og opdager, at du er sent på den. WTF! FISKEDAG! Bare der er fiskefilet tilbage, når du når kantinen. Du må hellere finde en vej ud herfra og hen til kantinen.\",\n false,\n null,\n null\n ));\n\n //Adding offices to <>officerooms, randomly placed later \n officeRooms.add(new Room(\n \"Du bliver kort blændet af en kontorlampe, som peger lige mod døråbningen. Du ser en gammel dame.\",\n false,\n monsterList.getMonster(4),\n itemList.getItem(13)\n ));\n\n officeRooms.add(new Room(\n \"Der er ingen i rummet, men rodet afslører, at det nok er Phillipas kontor.\",\n false,\n null,\n itemList.getItem(15)\n ));\n\n officeRooms.add(new Room(\n \"Du vader ind i et lokale, som er dunkelt oplyst af små, blinkende lamper og har en stank, der siger så meget spar fem, at det kun kan være IT-lokalet. Du når lige at høre ordene \\\"Rick & Morty\\\".\",\n false,\n monsterList.getMonster(6),\n itemList.getItem(7)\n ));\n\n officeRooms.add(new Room(\n \"Det var ikke kantinen det her, men hvorfor er der så krummer på gulvet?\",\n false,\n null,\n itemList.getItem(1)\n ));\n\n officeRooms.add(new Room(\n \"Tine sidder ved sit skrivebord. Du kan se, at hun er ved at skrive en lang indkøbsseddel. Hun skal nok have gæster i aften.\",\n false,\n monsterList.getMonster(0),\n itemList.getItem(18)\n ));\n\n officeRooms.add(new Room(\n \"Du træder ind i det tekøkken, hvor Thomas plejer at opholde sig. Du ved, hvad det betyder!\",\n false,\n null,\n itemList.getItem(0)\n ));\n\n officeRooms.add(new Room(\n \"Du går ind i det nok mest intetsigende rum, som du nogensinde har set. Det er så intetsigende, at der faktisk ikke er mere at sige om det.\",\n false,\n monsterList.getMonster(1),\n itemList.getItem(9)\n ));\n\n //Adding copyrooms to <>copyrooms, randomly placed later \n copyRooms.add(new Room(\n \"Døren knirker, som du åbner den. Et kopirum! Det burde du have set komme. Især fordi det var en glasdør.\",\n false,\n null,\n itemList.getItem(19)\n ));\n\n copyRooms.add(new Room(\n \"Kopimaskinen summer stadig. Den er åbenbart lige blevet færdig. Du går nysgerrigt over og kigger på alle de udskrevne papirer.\",\n false,\n null,\n itemList.getItem(12)\n ));\n\n //Adding restrooms to <>restrooms, randomly placed later \n restRooms.add(new Room(\n \"Ups! Dametoilettet. Der hænger en klam stank i luften. Det må være Ruth, som har været i gang.\",\n false,\n null,\n itemList.getItem(5)\n ));\n\n restRooms.add(new Room(\n \"Pedersen er på vej ud fra toilettet. Han vasker ikke fingre! Slut med at give ham hånden.\",\n false,\n monsterList.getMonster(7),\n itemList.getItem(11)\n ));\n\n restRooms.add(new Room(\n \"Du kommer ind på herretoilettet. Du skal simpelthen tisse så meget, at fiskefileterne må vente lidt. Du åbner toiletdøren.\",\n false,\n monsterList.getMonster(2),\n null\n ));\n\n restRooms.add(new Room(\n \"Lisette står og pudrer næse på dametoilettet. Hvorfor gik du herud?\",\n false,\n monsterList.getMonster(8),\n itemList.getItem(14)\n ));\n\n //Adding meetingrooms to<>meetingrooms, randomly placed later\n meetingRooms.add(new Room(\n \"Du træder ind i et lokale, hvor et vigtigt møde med en potentiel kunde er i gang. Du bliver nødt til at lade som om, at du er en sekretær.\",\n false,\n monsterList.getMonster(9),\n itemList.getItem(6)\n ));\n\n meetingRooms.add(new Room(\n \"Mødelokalet er tomt, men der står kopper og service fra sidste møde. Sikke et rod!\",\n false,\n null,\n itemList.getItem(3)\n ));\n\n meetingRooms.add(new Room(\n \"Projektgruppen sidder i mødelokalet. Vil du forsøge at forsinke dem i at nå fiskefileterne i kantinen?\",\n false,\n monsterList.getMonster(10),\n itemList.getItem(2)\n ));\n\n //Adding specialrooms to<>specialrooms, randomly placed later\n specialRooms.add(new Room(\n \"Du vader ind på chefens kontor. På hans skrivebord sidder sekretæren Phillipa.\",\n false,\n monsterList.getMonster(5),\n itemList.getItem(8)\n ));\n\n specialRooms.add(new Room(\n \"Det her ligner øjensynligt det kosteskab, Harry Potter boede i.\",\n false,\n monsterList.getMonster(3),\n itemList.getItem(4)\n ));\n\n specialRooms.add(new Room(\n \"OMG! Hvad er det syn?! KANTINEN!! Du klarede det! Du skynder dig op i køen lige foran ham den arrogante fra din afdeling. Da du når frem til fadet er der kun 4 fiskefileter tilbage. Du snupper alle 4!\",\n true,\n null,\n null\n ));\n\n //Adding rooms(Inde1-5)\n addOfficeRoom();\n addRestRoom(rooms, restRooms);\n addMeetingRoom(rooms, meetingRooms);\n addOfficeRoom();\n addRestRoom(rooms, restRooms);\n\n //Adding rooms(Inde6-10)\n addMeetingRoom(rooms, meetingRooms);\n addCopyRoom(rooms, copyRooms);\n addRestRoom(rooms, restRooms);\n addOfficeRoom();\n addCopyRoom(rooms, copyRooms);\n\n //Adding rooms(Inde11-15)\n addOfficeRoom();\n addSpecialRoom(rooms, specialRooms);\n addOfficeRoom();\n addRestRoom(rooms, restRooms);\n addOfficeRoom();\n\n //Adding rooms(Inde16-19)\n addOfficeRoom();\n addSpecialRoom(rooms, specialRooms);\n addSpecialRoom(rooms, specialRooms);\n addMeetingRoom(rooms, meetingRooms);\n\n return rooms;\n }",
"private void createRooms()//refactored\n {\n currentRoom = RoomCreator.buildCurrentRooms();//new\n }",
"public static void main(String[] args) {\n MinimumMeetingRooms solution = new MinimumMeetingRooms();\n\n // [(30, 75), (0, 50), (60, 150)]\n // return 2\n int[][] intervals = new int[][] {{30, 75}, {0, 50}, {60, 150}};\n System.out.println(solution.numRooms(intervals));\n\n // [(30, 75), (0, 50), (60, 150), (40, 170)]\n // return 3\n intervals = new int[][] {{30, 75}, {0, 50}, {60, 150}, {40, 170}};\n System.out.println(solution.numRooms(intervals));\n\n // [(30, 55), (0, 20), (60, 150), (160, 170)]\n // return 1\n intervals = new int[][] {{30, 55}, {0, 20}, {60, 150}, {160, 170}};\n System.out.println(solution.numRooms(intervals));\n }",
"private void createRooms()\n {\n // create the rooms\n prison = new Room(\"Prison\", \"Prison. You awake in a cold, dark cell. Luckily, the wall next to you has been blown open. \\nUnaware of your current circumstances, you press on... \\n\");\n promenade = new Room(\"Promenade\",\"Promenade. After stumbling upon a ladder, you decided to climb up. \\n\" + \n \"You appear outside a sprawling promenade. There appears to be something shiny stuck in the ground... \\n\");\n sewers = new Room(\"Sewers\",\"Sewers. It smells... interesting. As you dive deeper, you hear something creak\");\n ramparts = new Room(\"Ramparts\", \"Ramparts. You feel queasy as you peer down below. \\nAs you make your way along, you're greated by a wounded soldier.\" +\n \"\\nIn clear agony, he slowly closes his eyes as he says, 'the king... ki.. kil... kill the king..' \\n\");\n depths = new Room(\"Depths\", \"Depths. You can hardly see as to where you're going...\" + \"\\n\");\n ossuary = new Room(\"Ossuary\", \"Ossuary. A chill runs down your spine as you examine the skulls... \\n\" +\n \"but wait... is.. is one of them... moving? \\n\" +\"\\n\" + \"\\n\" + \"There seems to be a chest in this room!\" + \"\\n\");\n bridge = new Room(\"Bridge\", \"Bridge. A LOUD SHREIK RINGS OUT BEHIND YOU!!! \\n\");\n crypt = new Room(\"Crypt\", \"Crypt. An eerire feeling begins to set in. Something about this place doesn't seem quite right...\" + \"\\n\");\n graveyard = new Room(\"Graveyard\", \"Graveyard. The soil looks rather soft. \\n\" +\n \"As you being to dive deeper, you begin to hear moans coming from behind you...\");\n forest = new Room(\"Forest\", \"Forest. It used to be gorgeous, and gleaming with life; that is, until the king came...\" + \"\\n\" +\n \"there's quite a tall tower in front of you... if only you had something to climb it.\" + \"\\n\");\n tower = new Room(\"Tower\", \"Tower. As you look over the land, you're astounded by the ruin and destruction the malice and king have left behind. \\n\");\n castle = new Room(\"Castle\", \"Castle. Used to be the most elegant and awe-inspiring building in the land. \\n\" +\n \"That is, before the king showed up... \\n\" +\n \"wait... is that... is that a chest? \\n\");\n throneRoomEntrance = new Room(\"Throne Entrance\", \"You have made it to the throne room entrance. Press on, if you dare.\");\n throne = new Room(\"Throne Room\", \"You have entered the throne room. As you enter, the door slams shut behind you! \\n\" +\n \"Before you stands, the king of all malice and destruction, Mr. Rusch\" + \"\\n\");\n deathRoom1 = new Room(\"Death Room\", \"THE DOOR SLAMS SHUT BEHIND YOU\");\n deathRoom2 = new Room(\"Death Room\", \"THE DOOR SLAMS SHUT BEHIND YOU\");\n deathRoom3 = new Room(\"Death Room\", \"THE DOOR SLAMS SHUT BEHIND YOU\");\n deathRoom4 = new Room(\"Death Room\", \"depths of the earth... well part of you at least.\" + \"\\n\" + \"You fell off the peaks of the castle to your untimely death\");\n \n // initialise room exits\n\n currentRoom = prison; // start game outside player.setRoom(currentRoom);\n player.setRoom(currentRoom);\n \n }",
"public void seekRooms () {\n\t\tint num = 0;//room number\n\t\tfor (int i=0; i<w; i++) {\n\t\t\tfor (int j=0; j<l; j++) {\n\t\t\t\tif (visited[i][j] == 0) {\n\t\t\t\t\tcnt = 0;\n\t\t\t\t\tnum++;//room number start from 1\n\t\t\t\t\tdfs(i,j,num);\n\t\t\t\t\n\t\t\t\t\t//update the number of rooms and max room size\t\t\t\n\t\t\t\t\tmax = Math.max(max, cnt); \n\t\t\t\t\ttotal = num;\n\t\t\t\t\tmap.put(num, cnt);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\t\t\n\t\tfindMaxComb();// find the max size after breaking a wall!!!\n\t\t\n\t}",
"public static int room_booking(int start, int end){\r\n\r\n\t\tint selected_room = -1;\r\n\t\t// booking_days list is to store all the days between start and end day\r\n\t\tList<Integer> booking_days = new ArrayList<>();\r\n\t\tfor(int i=start;i<=end; i++) {\r\n\t\t\tbooking_days.add(i);\r\n\t\t}\r\n\r\n\t\tfor(int roomNo : hotel_size) {\r\n\r\n\t\t\tif(room_bookings.keySet().contains(roomNo)) {\r\n\t\t\t\tfor (Map.Entry<Integer, Map<Integer,List<Integer>>> entry : room_bookings.entrySet()) {\r\n\r\n\t\t\t\t\tList<Integer> booked_days_for_a_room = new ArrayList<Integer>();\r\n\t\t\t\t\tif(roomNo == entry.getKey()) {\r\n\t\t\t\t\t\tentry.getValue().forEach((bookingId, dates)->{\r\n\t\t\t\t\t\t\tbooked_days_for_a_room.addAll(dates);\r\n\t\t\t\t\t\t});\r\n\t\t\t\t\t\tList<Integer> check_elements = new ArrayList<Integer>();\r\n\t\t\t\t\t\tfor(int element : booking_days) {\r\n\t\t\t\t\t\t\tif(booked_days_for_a_room.contains(element)) {\r\n\t\t\t\t\t\t\t\tstatus = false;\r\n\t\t\t\t\t\t\t\tbreak;\r\n\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\telse {\r\n\t\t\t\t\t\t\t\tcheck_elements.add(element);\r\n\t\t\t\t\t\t\t\tselected_room = roomNo;\r\n\t\t\t\t\t\t\t\tstatus = true;\r\n\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t\tif(status) {\r\n\t\t\t\t\t\t\tselected_room = roomNo;\r\n\t\t\t\t\t\t\treturn selected_room;\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\telse {\r\n\t\t\t\tselected_room = roomNo;\r\n\t\t\t\tstatus = true;\r\n\t\t\t\treturn selected_room;\r\n\t\t\t}\r\n\t\t}\r\n\t\treturn selected_room;\r\n\t}",
"private void createRooms()\n {\n Room outside, theatre, pub, lab, office , hallway, backyard,chickenshop;\n \n // create the rooms\n outside = new Room(\"outside the main entrance of the university\");\n theatre = new Room(\"in a lecture theatre\");\n pub = new Room(\"in the campus pub\");\n lab = new Room(\"in a computing lab\");\n office = new Room(\"in the computing admin office\");\n hallway=new Room (\"in the hallway of the university\");\n backyard= new Room( \"in the backyard of the university\");\n chickenshop= new Room(\"in the chicken shop\");\n \n \n \n // initialise room exits\n outside.setExit(\"east\", theatre);\n outside.setExit(\"south\", lab);\n outside.setExit(\"west\", pub);\n\n theatre.setExit(\"west\", outside);\n theatre.setExit(\"north\", backyard);\n\n pub.setExit(\"east\", outside);\n\n lab.setExit(\"north\", outside);\n lab.setExit(\"east\", office);\n \n office.setExit(\"south\", hallway);\n office.setExit(\"west\", lab);\n \n chickenshop.setExit(\"west\", lab);\n\n currentRoom = outside; // start game outside\n \n }",
"public static void wallsAndGates(int[][] rooms) {\n if (rooms.length == 0 || rooms[0].length == 0) {\n return;\n }\n\n int m = rooms.length;\n int n = rooms[0].length;\n\n Queue<int[]> queue = new LinkedList();\n boolean[][] visited = new boolean[m][n];\n for (int i = 0; i < m; i++) {\n for (int j = 0; j < n; j++) {\n if (rooms[i][j] == 0) {\n queue.add(new int[] {i, j});\n }\n }\n }\n\n int level = 1;\n while (!queue.isEmpty()) {\n int size = queue.size();\n for (int i = 0; i < size; i++) {\n int[] cur = queue.poll();\n int currow = cur[0];\n int curcol = cur[1];\n\n int row;\n int col;\n\n //up\n row = currow-1;\n col = curcol;\n if (row >= 0) {\n if (rooms[row][col] == Integer.MAX_VALUE && !visited[row][col]) {\n visited[row][col] = true;\n rooms[row][col] = level;\n queue.add(new int[] {row, col});\n }\n }\n\n //down\n row = currow+1;\n if (row < m) {\n if (rooms[row][col] == Integer.MAX_VALUE && !visited[row][col]) {\n visited[row][col] = true;\n rooms[row][col] = level;\n queue.add(new int[] {row, col});\n }\n }\n\n //left\n row = currow;\n col = curcol-1;\n if (col >= 0) {\n if (rooms[row][col] == Integer.MAX_VALUE && !visited[row][col]) {\n visited[row][col] = true;\n rooms[row][col] = level;\n queue.add(new int[] {row, col});\n }\n }\n\n //right\n row = currow;\n col = curcol + 1;\n if (col < n) {\n if (rooms[row][col] == Integer.MAX_VALUE && !visited[row][col]) {\n visited[row][col] = true;\n rooms[row][col] = level;\n queue.add(new int[] {row, col});\n }\n }\n }\n level++;\n }\n\n }",
"private static void createRooms() {\n// Room airport, beach, jungle, mountain, cave, camp, raft, seaBottom;\n\n airport = new Room(\"airport\");\n beach = new Room(\"beach\");\n jungle = new Room(\"jungle\");\n mountain = new Room(\"mountain\");\n cave = new Room(\"cave\");\n camp = new Room(\"camp\");\n seaBottom = new Room(\"seabottom\");\n\n //Setting the the exits in different rooms\n beach.setExit(\"north\", jungle);\n beach.setExit(\"south\", seaBottom);\n beach.setExit(\"west\", camp);\n\n jungle.setExit(\"north\", mountain);\n jungle.setExit(\"east\", cave);\n jungle.setExit(\"south\", beach);\n\n mountain.setExit(\"south\", jungle);\n\n cave.setExit(\"west\", jungle);\n\n camp.setExit(\"east\", beach);\n\n seaBottom.setExit(\"north\", beach);\n\n // Starting room\n currentRoom = airport;\n }",
"private static void performRoomManagement() {\n\t\t\r\n\t\t\r\n\r\n\t}",
"private void setupRooms() {\n\t\tthis.listOfCoordinates = new ArrayList<Coordinates>();\r\n\t\tthis.rooms = new HashMap<String,Room>();\r\n\t\t\r\n\t\tArrayList<Coordinates> spaEntrances = new ArrayList<Coordinates>();\r\n\t\tspaEntrances.add(grid[5][6].getCoord());\r\n\r\n\t\tArrayList<Coordinates> theatreEntrances = new ArrayList<Coordinates>();\r\n\t\ttheatreEntrances.add(grid[13][2].getCoord());\r\n\t\ttheatreEntrances.add(grid[10][8].getCoord());\r\n\r\n\t\tArrayList<Coordinates> livingRoomEntrances = new ArrayList<Coordinates>();\r\n\t\tlivingRoomEntrances.add(grid[13][5].getCoord());\r\n\t\tlivingRoomEntrances.add(grid[16][9].getCoord());\r\n\r\n\t\tArrayList<Coordinates> observatoryEntrances = new ArrayList<Coordinates>();\r\n\t\tobservatoryEntrances.add(grid[21][8].getCoord());\r\n\r\n\t\tArrayList<Coordinates> patioEntrances = new ArrayList<Coordinates>();\r\n\t\tpatioEntrances.add(grid[5][10].getCoord());\r\n\t\tpatioEntrances.add(grid[8][12].getCoord());\r\n\t\tpatioEntrances.add(grid[8][16].getCoord());\r\n\t\tpatioEntrances.add(grid[5][18].getCoord());\r\n\r\n\t\t// ...\r\n\t\tArrayList<Coordinates> poolEntrances = new ArrayList<Coordinates>();\r\n\t\tpoolEntrances.add(grid[10][17].getCoord());\r\n\t\tpoolEntrances.add(grid[17][17].getCoord());\r\n\t\tpoolEntrances.add(grid[14][10].getCoord());\r\n\r\n\t\tArrayList<Coordinates> hallEntrances = new ArrayList<Coordinates>();\r\n\t\thallEntrances.add(grid[22][10].getCoord());\r\n\t\thallEntrances.add(grid[18][13].getCoord());\r\n\t\thallEntrances.add(grid[18][14].getCoord());\r\n\r\n\t\tArrayList<Coordinates> kitchenEntrances = new ArrayList<Coordinates>();\r\n\t\tkitchenEntrances.add(grid[6][21].getCoord());\r\n\r\n\t\tArrayList<Coordinates> diningRoomEntrances = new ArrayList<Coordinates>();\r\n\t\tdiningRoomEntrances.add(grid[12][18].getCoord());\r\n\t\tdiningRoomEntrances.add(grid[16][21].getCoord());\r\n\r\n\t\tArrayList<Coordinates> guestHouseEntrances = new ArrayList<Coordinates>();\r\n\t\tguestHouseEntrances.add(grid[20][20].getCoord());\r\n\r\n\t\t// setup entrances map\r\n\t\tthis.roomEntrances = new HashMap<Coordinates, Room>();\r\n\t\tfor (LocationCard lc : this.listOfLocationCard) {\r\n\t\t\tString name = lc.getName();\r\n\t\t\tRoom r;\r\n\t\t\tif (name.equals(\"Spa\")) {\r\n\t\t\t\tr = new Room(name, lc, spaEntrances);\r\n\t\t\t\tthis.rooms.put(name, r);\r\n\t\t\t\tfor (Coordinates c : spaEntrances) {\r\n\t\t\t\t\tthis.roomEntrances.put(c, r);\r\n\t\t\t\t\tthis.listOfCoordinates.add(c);\r\n\t\t\t\t}\r\n\t\t\t} else if (name.equals(\"Theatre\")) {\r\n\t\t\t\tr = new Room(name, lc,theatreEntrances);\r\n\t\t\t\tthis.rooms.put(name, r);\r\n\t\t\t\tfor (Coordinates c : theatreEntrances) {\r\n\t\t\t\t\tthis.roomEntrances.put(c, r);\r\n\t\t\t\t\tthis.listOfCoordinates.add(c);\r\n\t\t\t\t}\r\n\t\t\t} else if (name.equals(\"LivingRoom\")) {\r\n\t\t\t\tr = new Room(name, lc,livingRoomEntrances);\r\n\t\t\t\tthis.rooms.put(name, r);\r\n\t\t\t\tfor (Coordinates c : livingRoomEntrances) {\r\n\t\t\t\t\tthis.roomEntrances.put(c, r);\r\n\t\t\t\t\tthis.listOfCoordinates.add(c);\r\n\t\t\t\t}\r\n\t\t\t} else if (name.equals(\"Observatory\")) {\r\n\t\t\t\tr = new Room(name, lc,observatoryEntrances);\r\n\t\t\t\tthis.rooms.put(name, r);\r\n\t\t\t\tfor (Coordinates c : observatoryEntrances) {\r\n\t\t\t\t\tthis.roomEntrances.put(c, r);\r\n\t\t\t\t\tthis.listOfCoordinates.add(c);\r\n\t\t\t\t}\r\n\t\t\t} else if (name.equals(\"Patio\")) {\r\n\t\t\t\tr = new Room(name,lc, patioEntrances);\r\n\t\t\t\tthis.rooms.put(name, r);\r\n\t\t\t\tfor (Coordinates c : patioEntrances) {\r\n\t\t\t\t\tthis.roomEntrances.put(c, r);\r\n\t\t\t\t\tthis.listOfCoordinates.add(c);\r\n\t\t\t\t}\r\n\t\t\t} else if (name.equals(\"Pool\")) {\r\n\t\t\t\tr = new Room(name,lc,poolEntrances);\r\n\t\t\t\tthis.rooms.put(name, r);\r\n\t\t\t\tfor (Coordinates c : poolEntrances) {\r\n\t\t\t\t\tthis.roomEntrances.put(c, r);\r\n\t\t\t\t\tthis.listOfCoordinates.add(c);\r\n\t\t\t\t}\r\n\t\t\t} else if (name.equals(\"Hall\")) {\r\n\t\t\t\tr = new Room(name, lc,hallEntrances);\r\n\t\t\t\tthis.rooms.put(name, r);\r\n\t\t\t\tfor (Coordinates c : hallEntrances) {\r\n\t\t\t\t\tthis.roomEntrances.put(c, r);\r\n\t\t\t\t\tthis.listOfCoordinates.add(c);\r\n\t\t\t\t}\r\n\t\t\t} else if (name.equals(\"Kitchen\")) {\r\n\t\t\t\tr = new Room(name, lc,kitchenEntrances);\r\n\t\t\t\tthis.rooms.put(name, r);\r\n\t\t\t\tfor (Coordinates c : kitchenEntrances) {\r\n\t\t\t\t\tthis.roomEntrances.put(c, r);\r\n\t\t\t\t\tthis.listOfCoordinates.add(c);\r\n\t\t\t\t}\r\n\t\t\t} else if (name.equals(\"DiningRoom\")) {\r\n\t\t\t\tr = new Room(name, lc,diningRoomEntrances);\r\n\t\t\t\tthis.rooms.put(name, r);\r\n\t\t\t\tfor (Coordinates c : diningRoomEntrances) {\r\n\t\t\t\t\tthis.roomEntrances.put(c, r);\r\n\t\t\t\t\tthis.listOfCoordinates.add(c);\r\n\t\t\t\t}\r\n\t\t\t} else if (name.equals(\"GuestHouse\")) {\r\n\t\t\t\tr = new Room(name, lc,guestHouseEntrances);\r\n\t\t\t\tthis.rooms.put(name, r);\r\n\t\t\t\tfor (Coordinates c : guestHouseEntrances) {\r\n\t\t\t\t\tthis.roomEntrances.put(c, r);\r\n\t\t\t\t\tthis.listOfCoordinates.add(c);\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"private void createRooms()\n {\n Room outside, garden, kitchen, frontyard, garage, livingroom,\n upperhallway, downhallway, bedroom1, bedroom2, toilet,teleporter;\n\n // create the rooms\n outside = new Room(\"outside the house\",\"Outside\");\n garden = new Room(\"in the Garden\", \"Garden\");\n kitchen = new Room(\"in the Kitchen\",\"Kitchen\");\n frontyard = new Room(\"in the Frontyard of the house\", \"Frontyard\");\n garage = new Room(\"in the Garage\", \"Garage\");\n livingroom = new Room(\"in the Living room\", \"Living Room\");\n upperhallway = new Room(\"in the Upstairs Hallway\",\"Upstairs Hallway\");\n downhallway = new Room(\"in the Downstairs Hallway\", \"Downstairs Hallway\");\n bedroom1 = new Room(\"in one of the Bedrooms\", \"Bedroom\");\n bedroom2 = new Room(\"in the other Bedroom\", \"Bedroom\");\n toilet = new Room(\"in the Toilet upstairs\",\"Toilet\");\n teleporter = new Room(\"in the Warp Pipe\", \"Warp Pipe\");\n\n // initialise room exits\n outside.setExit(\"north\", garden);\n outside.setExit(\"east\", frontyard);\n\n garden.setExit(\"south\", outside);\n garden.setExit(\"east\", kitchen);\n\n kitchen.setExit(\"west\", garden);\n kitchen.setExit(\"north\", livingroom);\n kitchen.setExit(\"south\", downhallway);\n\n frontyard.setExit(\"west\", outside);\n frontyard.setExit(\"north\", downhallway);\n frontyard.setExit(\"east\", garage);\n\n garage.setExit(\"west\", frontyard);\n garage.setExit(\"north\", downhallway);\n\n livingroom.setExit(\"west\", kitchen);\n\n downhallway.setExit(\"north\",kitchen);\n downhallway.setExit(\"west\",frontyard);\n downhallway.setExit(\"south\",garage);\n downhallway.setExit(\"east\",upperhallway);\n\n upperhallway.setExit(\"north\", bedroom2);\n upperhallway.setExit(\"east\", bedroom1);\n upperhallway.setExit(\"south\", toilet);\n upperhallway.setExit(\"west\", downhallway);\n\n toilet.setExit(\"north\", upperhallway);\n\n bedroom1.setExit(\"west\",upperhallway);\n\n bedroom2.setExit(\"south\", upperhallway);\n\n rooms.add(outside);\n rooms.add(garden);\n rooms.add(kitchen);\n rooms.add(frontyard);\n rooms.add(garage);\n rooms.add(livingroom);\n rooms.add(upperhallway);\n rooms.add(downhallway);\n rooms.add(bedroom1);\n rooms.add(bedroom2);\n rooms.add(toilet);\n }",
"public int checkRooms(LocalDate bookdate, int stay, int type, int req, ArrayList<Integer> array) {\n\t\t\t\r\n\t\t\tint i = 0;\r\n\t\t\tint k = 0;\r\n\t\t\tint j = 0;\r\n\t\t\tint count = 0;\r\n\t\t\tBooking bookChecker = null; //Saves the bookings of a hotel to be checked\r\n\t\t\tRooms roomChecker = null; //Saves the rooms of the hotel\r\n\t\t\tLocalDate endBook = bookdate.plusDays(stay); //booking start date + number of nights\r\n\t\t\tboolean booked = false;\r\n\r\n\t\t\tif(req == 0) return 0; //if theres no need for single/double/triple room\r\n\t\t\t\r\n\t\t\twhile(i < RoomDetails.size()) { //checking room-wise order\r\n\t\t\t\troomChecker = RoomDetails.get(i);\r\n\t\t\t\tif(type == roomChecker.getCapacity()) { //only check if its the same room type as needed\r\n\t\t\t\t\tk = 0;\r\n\t\t\t\t\twhile(k < Bookings.size()) { //check for bookings of a room\r\n\t\t\t\t\t\tbookChecker = Bookings.get(k);\r\n\t\t\t\t\t\tj=0;\r\n\t\t\t\t\t\tbooked = false;\r\n\t\t\t\t\t\twhile(j < bookChecker.getNumOfRoom()) { //To check if a booked room have clashing schedule with new booking\r\n\t\t\t\t\t\t\tif(roomChecker.getRoomNum() == bookChecker.getRoomNumber(j)) { //if there is a booking for the room\r\n\t\t\t\t\t\t\t\tif(bookdate.isEqual(bookChecker.endDate()) || endBook.isEqual(bookChecker.getStartDate())) {\r\n\t\t\t\t\t\t\t\t\t//New booking starts at the same day where another booking ends\r\n\t\t\t\t\t\t\t\t\tbooked = false; //No clash\r\n\t\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\t\telse if(bookdate.isAfter(bookChecker.endDate()) || endBook.isBefore(bookChecker.getStartDate())) {\r\n\t\t\t\t\t\t\t\t\t//New booking starts days after other booking ends, or new booking ends before other booking starts\r\n\t\t\t\t\t\t\t\t\tbooked = false; //no clash\r\n\t\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\t\telse { //Any other way means that it clashes and hence room cant be booked\r\n\t\t\t\t\t\t\t\t\tbooked = true;\r\n\t\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\r\n\t\t\t\t\t\t\tif(booked == true) break; //if booked and clash , break\r\n\t\t\t\t\t\t\tj++;\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t\tif(booked == true) break; //if booked and clash , break\r\n\t\t\t\t\t\tk++;\r\n\t\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\t\tif(booked == false) {\r\n\t\t\t\t\t\tarray.add(roomChecker.getRoomNum()); //if no clashing dates, book the room for new cust\r\n\t\t\t\t\t\tcount++;\r\n\t\t\t\t\t}\r\n\t\t\t\t\tif (count == req) break; //if there is enough room already, finish\r\n\t\t\t\t}\r\n\t\t\t\ti++;\r\n\t\t\t}\r\n\t\t\treturn count; //returns the number of available rooms acquired\r\n\t\t}",
"protected static String availableRooms(ArrayList<Room> roomList,String start_date){\n String stringList = \"\";\n for(Room room : roomList){\n System.out.println(room.getName());\n ArrayList<Meeting> meet = room.getMeetings();\n for(Meeting m : meet){\n stringList += m + \"\\t\";\n }\n System.out.println(\"RoomsList\"+stringList);\n }\n return \"\";\n }",
"@Test\n\t\t\tpublic void besidesRoomTests() {\n\t\t\t\t//Testing walkway space that is next to the kitchen with no door\n\t\t\t\tSet<BoardCell> testList = board.getAdjList(6, 1);\n\t\t\t\tassertEquals(3, testList.size());\n\t\t\t\tassertTrue(testList.contains(board.getCellAt(5, 1)));\n\t\t\t\tassertTrue(testList.contains(board.getCellAt(6, 0)));\n\t\t\t\tassertTrue(testList.contains(board.getCellAt(6, 2)));\n\t\t\t\t//Testing walkway space that is next to two kitchen spaces with no door\n\t\t\t\ttestList = board.getAdjList(6, 20);\n\t\t\t\tassertEquals(2, testList.size());\n\t\t\t\tassertTrue(testList.contains(board.getCellAt(5, 20)));\n\t\t\t\tassertTrue(testList.contains(board.getCellAt(6, 19)));\n\t\t\t\t//Testing walkway space that is between two room spaces and an edge\n\t\t\t\ttestList = board.getAdjList(20, 15);\n\t\t\t\tassertTrue(testList.contains(board.getCellAt(19, 15)));\n\t\t\t\tassertEquals(1, testList.size());\n\n\t\t\t}",
"public static void createGameRooms()\r\n\t{\r\n\t\tfor(int i = 0; i < MAX_FIREWORKS_ROOMS; i++)\r\n\t\t{\r\n\t\t\taddRoom(\"fireworks_\" + i, new VMKGameRoom(\"fireworks_\" + i, \"Fireworks Game \" + i, \"\"));\r\n\t\t}\r\n\t\t\r\n\t\tfor(int i = 0; i < MAX_PIRATES_ROOMS; i++)\r\n\t\t{\r\n\t\t\taddRoom(\"pirates_\" + i, new VMKGameRoom(\"pirates_\" + i, \"Pirates Game \" + i, \"\"));\r\n\t\t}\r\n\t}",
"void makeMoreRooms() {\n\t\twhile(rooms.size() < size.maxRooms) {\n\t\t\t\tRoom made;\n\t\t\t\tint height = baseHeight;\n\t\t\t\tint x = random.nextInt(size.width);\n\t\t\t\tint z = random.nextInt(size.width);\n\t\t\t\tint xdim = random.nextInt(size.maxRoomSize - 5) + 6;\n\t\t\t\tint zdim = random.nextInt(size.maxRoomSize - 5) + 6;\n\t\t\t\tif(bigRooms.use(random)) {\n\t\t\t\t\txdim += random.nextInt((size.maxRoomSize / 2)) + (size.maxRoomSize / 2);\n\t\t\t\t\tzdim += random.nextInt((size.maxRoomSize / 2)) + (size.maxRoomSize / 2);\n\t\t\t\t}\n\t\t\t\tint ymod = (xdim <= zdim) ? (int) Math.sqrt(xdim) : (int) Math.sqrt(zdim);\n\t\t\t\tint roomHeight = random.nextInt((verticle.value / 2) + ymod + 1) + 2;\n\t\t\t\tmade = new PlaceSeed(x, height, z).growRoom(xdim, zdim, roomHeight, this, null, null);\n\t\t\t}\t\t\n\t\t//DoomlikeDungeons.profiler.endTask(\"Adding Extra Rooms (old)\");\n\t\t}",
"@FXML\n private void fastMatch() {\n if (Client.getUser().getState() != Type.UserState.IDLE) {\n JOptionPane.showMessageDialog(null, \"您已经在房间中\");\n return;\n }\n Room match = null;\n for (Room room : Client.roomsMap.values()) {\n if (room.hasSeat()) {\n match = room;\n Client.getUser().setRoom(match.getId());\n Client.getUser().setState(Type.UserState.READY);\n Client.updateUser();\n match.setState(Type.RoomState.READY);\n if (match.getPlayer1() == null || match.getPlayer1().isEmpty()) {\n match.setPlayer1(Client.getUser().getAccount());\n Client.updateRoom(room, Type.UpdateRoom.PLAYER1IN);\n } else {\n match.setPlayer2(Client.getUser().getAccount());\n Client.updateRoom(room, Type.UpdateRoom.PLAYER2IN);\n }\n break;\n }\n }\n if (match != null) {\n client.gotoGame(match);\n } else {\n int res = JOptionPane.showConfirmDialog(null, \"暂时找不到匹配的房间哦,是否要自己创建一个呢?\", \"未找到匹配的房间\", JOptionPane.YES_NO_OPTION);\n if (res == JOptionPane.YES_OPTION) {\n client.gotoCreateRoom();\n }\n }\n }",
"public static void main(String[] args) {\n int[][] rooms = new int[4][4];\n int INF = Integer.MAX_VALUE;\n int[] p0 = {INF, -1, 0, INF};\n int[] p1 = {INF, INF, INF, -1};\n int[] p2 = {INF, -1, INF, -1};\n int[] p3 = {0, -1, INF, INF};\n rooms[0] = p0;\n rooms[1] = p1;\n rooms[2] = p2;\n rooms[3] = p3;\n wallsAndGates(rooms);\n\n\n }",
"public List<Room> initialiseRooms() {\n\n Room mainRoom = new Room(0, \"mainroom.tmx\", \"Main Foyer\");\n\n Room rch037 = new Room(1, \"rch037.tmx\", \"RCH/037 Lecture Theatre\");\n\n Room portersOffice = new Room(2, \"portersoffice.tmx\", \"Porters Office\");\n\n Room kitchen = new Room(3, \"kitchen.tmx\", \"Kitchen\");\n\n Room islandOfInteraction = new Room(4, \"islandofinteraction.tmx\", \"Island of Interaction\");\n\n Room toilet = new Room(5, \"toilet.tmx\", \"Toilet\");\n\n Room computerRoom = new Room(6, \"computerroom.tmx\", \"Computer Room\");\n\n Room lakeHouse = new Room(7, \"lakehouse.tmx\", \"Lakehouse\");\n\n Room outside = new Room(8, \"outside.tmx\", \"Outside Ron Cooke Hub\");\n\n Room pod = new Room(9, \"pod.tmx\", \"Pod\");\n\n\n mainRoom.addTransition(new Room.Transition().setFrom(17, 17).setTo(portersOffice, 1, 5, Direction.EAST)) //To Porters Office\n\n .addTransition(new Room.Transition().setFrom(27, 13).setTo(kitchen, 1, 3, Direction.EAST)) //To Kitchen\n\n .addTransition(new Room.Transition().setFrom(26, 29).setTo(islandOfInteraction, 11, 14, Direction.WEST)) //To Island of Interaction\n\n .addTransition(new Room.Transition().setFrom(18, 2).setTo(toilet, 1, 1, Direction.EAST)) //To Toilet\n\n .addTransition(new Room.Transition().setFrom(2, 8).setTo(computerRoom, 2, 2, Direction.EAST)) //To Computer Room\n\n .addTransition(new Room.Transition().setFrom(3, 5).setTo(outside, 19, 4, Direction.SOUTH)) //To Outside\n .addTransition(new Room.Transition().setFrom(4, 5).setTo(outside, 20, 4, Direction.SOUTH)) //To Outside\n\n .addTransition(new Room.Transition().setFrom(11, 1).setTo(rch037, 2, 5, Direction.SOUTH)) //To RCH/037\n .addTransition(new Room.Transition().setFrom(12, 1).setTo(rch037, 3, 5, Direction.SOUTH)); //To RCH/037\n\n rch037.addTransition(new Room.Transition().setFrom(2, 5).setTo(mainRoom, 11, 1, Direction.NORTH)) //To Main Room\n .addTransition(new Room.Transition().setFrom(3, 5).setTo(mainRoom, 12, 1, Direction.NORTH)) //To Main Room\n\n .addTransition(new Room.Transition().setFrom(11, 17).setTo(computerRoom, 7, 1, Direction.NORTH)) //To Computer Room\n .addTransition(new Room.Transition().setFrom(12, 17).setTo(computerRoom, 8, 1, Direction.NORTH)); //To Computer Room\n\n portersOffice.addTransition(new Room.Transition().setFrom(1, 5).setTo(mainRoom, 17, 17, Direction.WEST)); //To Main Room\n\n kitchen.addTransition(new Room.Transition().setFrom(1, 3).setTo(mainRoom, 27, 13, Direction.WEST)); //To Main Room\n\n islandOfInteraction.addTransition(new Room.Transition().setFrom(11, 14).setTo(mainRoom, 26, 29, Direction.WEST)); //To Main Room\n\n toilet.addTransition(new Room.Transition().setFrom(1, 1).setTo(mainRoom, 18, 2, Direction.WEST)); //To Main Room\n\n computerRoom.addTransition(new Room.Transition().setFrom(13, 11).setTo(lakeHouse, 11, 1, Direction.NORTH)) //To Lakehouse\n\n .addTransition(new Room.Transition().setFrom(7, 1).setTo(rch037, 11, 17, Direction.SOUTH)) //To RCH/037\n .addTransition(new Room.Transition().setFrom(8, 1).setTo(rch037, 12, 17, Direction.SOUTH)) //To RCH/037\n\n .addTransition(new Room.Transition().setFrom(2, 2).setTo(mainRoom, 2, 8, Direction.EAST)); //To Main Room\n\n lakeHouse.addTransition(new Room.Transition().setFrom(11, 1).setTo(computerRoom, 13, 11, Direction.WEST)); //To Computer Room\n\n outside.addTransition(new Room.Transition().setFrom(19, 4).setTo(mainRoom, 3, 5, Direction.NORTH)) //To Main Room\n .addTransition(new Room.Transition().setFrom(20, 4).setTo(mainRoom, 4, 5, Direction.NORTH)) //To Main Room\n\n .addTransition(new Room.Transition().setFrom(9, 11).setTo(pod, 18, 9, Direction.WEST)) //To Pod\n .addTransition(new Room.Transition().setFrom(9, 12).setTo(pod, 18, 10, Direction.WEST)); //To Pod\n\n pod.addTransition(new Room.Transition().setFrom(18, 9).setTo(outside, 9, 11, Direction.EAST)) //To Outside\n .addTransition(new Room.Transition().setFrom(18, 10).setTo(outside, 9, 12, Direction.EAST)); //To Outside\n\n List<Room> rooms = Arrays.asList(mainRoom, rch037, portersOffice, kitchen, islandOfInteraction, toilet, computerRoom, lakeHouse, outside, pod);\n\n /**\n * Assign the murder room\n */\n rooms.get(new Random().nextInt(rooms.size())).setMurderRoom();\n\n this.rooms = rooms;\n\n return rooms;\n }",
"private void createAccess(ArrayList<Room> rooms) {\n\n rooms.get(0).setNorth(rooms.get(1));\n\n rooms.get(1).setEast(rooms.get(2));\n rooms.get(1).setWest(rooms.get(4));\n rooms.get(1).setSouth(rooms.get(0));\n\n rooms.get(2).setWest(rooms.get(1));\n rooms.get(2).setNorth(rooms.get(10));\n rooms.get(2).setEast(rooms.get(3));\n\n rooms.get(3).setWest(rooms.get(2));\n\n rooms.get(4).setWest(rooms.get(5));\n rooms.get(4).setNorth(rooms.get(8));\n rooms.get(4).setEast(rooms.get(1));\n\n rooms.get(5).setNorth(rooms.get(7));\n rooms.get(5).setSouth(rooms.get(6));\n rooms.get(5).setEast(rooms.get(4));\n\n rooms.get(6).setNorth(rooms.get(5));\n\n rooms.get(7).setNorth(rooms.get(13));\n rooms.get(7).setSouth(rooms.get(5));\n\n rooms.get(8).setEast(rooms.get(9));\n rooms.get(8).setSouth(rooms.get(4));\n\n rooms.get(9).setWest(rooms.get(8));\n rooms.get(9).setNorth(rooms.get(15));\n rooms.get(9).setEast(rooms.get(10));\n\n rooms.get(10).setWest(rooms.get(9));\n rooms.get(10).setEast(rooms.get(11));\n rooms.get(10).setSouth(rooms.get(2));\n\n rooms.get(11).setWest(rooms.get(10));\n\n rooms.get(12).setEast(rooms.get(13));\n\n rooms.get(13).setWest(rooms.get(12));\n rooms.get(13).setEast(rooms.get(14));\n rooms.get(13).setSouth(rooms.get(7));\n\n rooms.get(14).setWest(rooms.get(13));\n rooms.get(14).setNorth(rooms.get(18));\n rooms.get(14).setEast(rooms.get(15));\n\n rooms.get(15).setWest(rooms.get(14));\n rooms.get(15).setNorth(rooms.get(19));\n rooms.get(15).setEast(rooms.get(16));\n rooms.get(15).setSouth(rooms.get(9));\n\n rooms.get(16).setWest(rooms.get(15));\n rooms.get(16).setEast(rooms.get(17));\n\n rooms.get(17).setWest(rooms.get(16));\n\n rooms.get(18).setSouth(rooms.get(14));\n\n rooms.get(19).setSouth(rooms.get(13));\n\n }",
"public static void main(String[] args) {\n\n Room woods = new Room(\"Woods\");\n woods.setStory(\"You are a ferocious wolf, hungry, and tired after a long excursion \" +\n \"out in the deep dark woods. You have just heard some rumors that there are three little \" +\n \"pigs who have recently done some construction in the neighborhood…\");\n woods.setDescription(\"These woods are dark and scary.\");\n\n Room house1 = new Room (\"The Straw House\");\n house1.setStory(\"You’ve trekked out of the woods and followed the rocky dirt road until you\" +\n \" find a neighborhood full of questionably constructed straw houses. Your nose twitches \" +\n \"and you realize the one right in front of you contains some tasty bacon named Billy\");\n house1.setDescription(\"This is the site of the straw house.\");\n\n Room house2 = new Room(\"The Stick House\");\n house2.setStory(\"You decide to look for some more food and continue on to the next neighborhood,\" +\n \" filled with stick houses. You sniff the air and know immediately that the house to your left\" +\n \"houses Reginald -- a chunky pig\");\n house2.setDescription(\"Here is the site of a stick house.\");\n house2.setAccessible(false);// must set accessible again after the first pig is eaten\n\n Room house3 = new Room(\"The Brick House\");\n house3.setStory(\"You decide to look for some more food and continue on to the next neighborhood, filled with \" +\n \"brick houses. You sniff the air and have a good feeling about a house up ahead, which is made of bricks \" +\n \"and has a lovely skylight.\");\n house3.setDescription(\"Here is the site of the brick house.\");\n house3.setAccessible(false);// must set accessible again after the second pig is eaten\n\n Room house3Interior = new Room(\"Inside the brick house.\");\n house3Interior.setStory(\"Aha! Here is the delicious pig -- Spike! Your stomach is rumbling . . . \");\n house3Interior.setDescription(\"This is a nice house made for a pig. Above the fireplace is a framed photo eat \" +\n \"of the pig who lives here and his two brothers.\");\n house3Interior.setAccessible(false);// must set accessible again after the window is broken\n\n Room woods2 = new Room(\"More Woods\");\n woods2.setStory(\"You're feeling pretty good now, having gobbled up some pigs and successfully stopped your stomach from growling.\" +\n \"You walk out of the pig neighborhood and back towards the forest. \" +\n \"But you have a feeling that you're not out of the woods yet-- literally. There's a pig cop here, and if you don't get out of here fast, \" +\n \"you might find yourself in trouble again.\");\n woods2.setDescription(\"A dark and ominous forest.\");\n woods2.setAccessible(false); // must set accessible again after the third pig is eaten\n\n Room river = new Room (\"River shore\");\n river.setStory(\"You've run from the pig cop into another section of woods, but there's a wide rushing river in front of you. Surely you won't be able \" +\n \"to cross it without some sort of bridge . . .\");\n river.setDescription(\"A river cuts through the forest, rushing by quickly.\" );\n\n Room home = new Room(\"Home\");\n home.setStory(\"You're home! After a long and harrowing trip through the woods and a neighborhood full of pigs, you've managed to evade the cops\" +\n \"and arrive home. Your family cheers when they see you and you swear to never trek into the woods without some extra provisions\" +\n \"ever again.\" );\n home.setDescription(\"\");\n home.setAccessible(false); //must set accessible again after the river is crossed\n\n //END OF GAME\n //now possible to add another story...\n\n\n //Characters and their related actions\n\n Character owl = new Character(\"Owl\", \"A wise elderly owl who might have some helpful advice\", null);\n owl.setFirstDialogue(\"I'm an owl, hoot hoot.\");\n owl.setGeneralGreeting(\"Hello again. Hoot hoot!\");\n owl.populateDialogueByTopics(\"advice\", \"That straw house over there looks pretty flimsy. Even a slight breeze could knock it down!\" +\n \"Hoot hoot!\");\n owl.populateDialogueByTopics(\"owl things\", \"I eat mice. Hoot hoot!\");\n owl.populateDialogueByTopics(\"the forest\", \"It sure is dark and scary in here. Hoot hoot!\");\n\n Character pig1 = new Character(\"Billy\", \"A fat, delicious-looking pig\", null);\n pig1.setFirstDialogue(\"Hi, I'm Billy, the pig! You're not a wolf, are you?\");\n pig1.setGeneralGreeting(\"It's Billy the pig again!\");\n pig1.populateDialogueByTopics(\"new house\", \"I've just built a new house out of straw! I think it looks great.\");\n// pig1.setIsEatable(true);\n\n Character pig2 = new Character(\"Reginald\", \"A fat, delicious-looking pig\", null);\n pig2.setFirstDialogue(\"Hi, I'm Reginald, the pig! Have you heard from my brothers?\");\n pig2.setGeneralGreeting(\"It's Reginald again. I'm a little worried about my brothers.\");\n pig2.populateDialogueByTopics(\"new house\", \"I just built a house out of sticks. I bet it can withstand anything!\");\n// pig2.setIsEatable(true);\n\n Character pig3 = new Character(\"Spike\", \"A fat, delicious-looking pig\", null);\n pig3.setFirstDialogue(\"What's up? I'm Spike, the pig! Have you seen a wolf around here? I think one is prowling around . . .\");\n pig3.setGeneralGreeting(\"It's Reginald again. You should stay away, there's a wolf on the loose!\");\n pig3.populateDialogueByTopics(\"the wolf\", \"I think my brothers were eaten by a wolf! Thankfully I \" +\n \"have my strong brick house to protect me.\");\n pig3.setIsEatable(true);\n\n Character cop = new Character(\"Officer Pig\", \"A pig cop looking to find the wolf who ate his friends\", null);\n cop.setFirstDialogue(\"I'm Officer Pig. Hey! You look like the wolf who ate my friends!\");\n cop.setGeneralGreeting(\"I'm Officer Pig.\");\n cop.populateDialogueByTopics(\"wolf\", \"A wolf has been terrorizing the neighborhood. And you look quite a lot like a wolf . . .\");\n\n //Items that are spread throughout the game + what can happen to them\n\n Item house1Item = new Item(\"straw house\", \"a flimsy straw house\", null);\n house1Item.setPickUpAble(false);\n Item house2Item = new Item(\"stick house\", \"a slightly sturdier stick house\", null);\n house2Item.setPickUpAble(false);\n Item house3Item = new Item(\"brick house\", \"a strong, well-built brick house\", null);\n house3Item.setPickUpAble(false);\n\n Item leafBlower = new Item(\"leaf blower\", \"a gardening tool that generates a lot of wind\", null);\n Item brick = new Item(\"brick\", \"looks like a leftover brick from building a house\", null);\n Item window = new Item (\"window\", \"a nice skylight on the roof of the brick house\", null);\n window.setPickUpAble(false);\n Item rock = new Item(\"rock\", \"a flat gray rock\", null);\n Item vine = new Item(\"vine\", \"a long green vine suspended from a tree branch\", null);\n vine.setPickUpAble(false);\n\n //Where the items are placed in the game\n woods.addCharacter(owl);\n house1.addCharacter(pig1);\n house1.addItemToRoom(house1Item);\n house2.addCharacter(pig2);\n house2.addItemToRoom(leafBlower);\n house2.addItemToRoom(house2Item);\n house3.addItemToRoom(brick);\n house3.addItemToRoom(window);\n house3.addItemToRoom(house3Item);\n house3Interior.addCharacter(pig3);\n woods2.addCharacter(cop);\n river.addItemToRoom(rock);\n river.addItemToRoom(vine);\n\n //What directions the user can move throughout the game\n //Order of directions : N , S, E, W, in, out\n woods.setConnections(new Room[] {null, null, house1, null, null, null});\n house1.setConnections(new Room[] {null, house2, null, woods, null, null});\n house2.setConnections(new Room[] {house1, null, house3, null, null, null});\n house3.setConnections(new Room[] {null, null, null, house2, house3Interior, null});\n house3Interior.setConnections(new Room[] {null, null, null, null, null, house3});\n woods2.setConnections(new Room[] {house3, null, null, null, null, null});\n //river\n //home\n\n //Commands possible\n ArrayList<String> commands = new ArrayList<>(List.of(\"go\", \"show inventory\", \"pick up\", \"drop\", \"open\", \"eat\", \"talk\"));\n //Existing rooms in game\n ArrayList<Room> rooms = new ArrayList<>((List.of(woods, house1, house2, house3, house3Interior, woods2, river, home)));\n threeLittlePigs = new TextAdventure(\"Three Little Pigs\", commands, rooms, woods);\n\n //Item + item interactions possible\n threeLittlePigs.addInteraction(leafBlower, house1Item, () ->{\n house1.removeItemFromRoom(house1Item);\n house2.setAccessible(true);\n threeLittlePigs.addPoints(10);\n pig1.setIsEatable(true);\n// System.out.println(\"You have destroyed the Straw House.\");\n return \"You have destroyed the Straw House.\";\n\n });\n threeLittlePigs.addInteraction(leafBlower, house2Item, () ->{\n house2.removeItemFromRoom(house2Item);\n house3.setAccessible(true);\n threeLittlePigs.addPoints(10);\n pig2.setIsEatable(true);\n// System.out.println(\"You have destroyed the Stick House.\");\n return \"You have destroyed the Stick House\";\n });\n threeLittlePigs.addInteraction(brick, window, () ->{\n house3Interior.setAccessible(true);\n woods2.setAccessible(true);\n river.setAccessible(true);\n threeLittlePigs.getCurrentRoom().removeItemFromRoom(window);\n threeLittlePigs.getCurrentRoom().removeItemFromRoom(brick);\n house3Interior.addItemToRoom(brick);\n// System.out.println(\"You broke the window with the brick!\");\n return \"You broke the window with the brick!\";\n });\n threeLittlePigs.addInteraction(vine, rock, () -> {\n river.setAccessible(false);\n home.setAccessible(true);\n// System.out.println(\"You move the rock so that you can reach the vine and you swing across the river! The \" +\n// \"vine snaps just as you hit the other shore. You walk forwards from the shore and see a familiar neighborhood. \" +\n// \"Congratulations, you've made it home!\");\n threeLittlePigs.moveUserTo(home);\n return \"You move the rock so that you can reach the vine and you swing across the river! The \" +\n \"vine snaps just as you hit the other shore. You walk forwards from the shore and see a familiar neighborhood. \" +\n \"Congratulations, you've made it home!\";\n });\n\n //OUTLINE FOR LITTLE RED RIDING HOOD TEXT ADVENTURE\n\n Room woods3 = new Room(\"More Woods\");\n woods3.setStory(\"Congrats! You made it through a day of pig-eating and law-evading! After a good nights rest you are ready to\" +\n \" venture back out into the woods and try your luck at finding breakfast. You've recently heard that Grandma Riding-Hood\" +\n \"has fallen ill...Perhaps this is a good opportunity...\");\n woods3.setDescription(\"A dark and ominous forest.\");\n woods2.setAccessible(false); //is this needed?\n\n Room clearing = new Room(\"Clearing\");\n clearing.setStory(\"You heard whistling so you followed the noise which led you to a clearing in the woods where a wee girl in a\" +\n \"red-hooded poncho cape was bending over to pick flowers. To her left is a basket filled with muffins.\");\n clearing.setDescription(\"A sunny clearing in the woods\");\n clearing.setAccessible(false); //is this needed?\n\n Room grandmaHouse = new Room(\"Grandma's House\");\n grandmaHouse.setStory(\"You trot along the path for a while until you get to a wee cabin on a hill. \" +\n \"You smell a human inside!!\");\n grandmaHouse.setDescription(\"A cabin on a hill\");\n grandmaHouse.setAccessible(false); //Unlock once you have 'gotten directions' from lil Red\n\n Room insideGhouse = new Room(\"Inside Grandma's House\");\n insideGhouse.setStory(\"Poor Grandma lying asleep in the bed, she looks very ill, and you are very hungry...\");\n insideGhouse.setDescription(\"A rustic cabin with a huge, four poster bed and many quilts\");\n insideGhouse.setAccessible(false);\n\n Room inBed = new Room(\"Lying in Bed\");\n inBed.setStory(\"After eating Grandma and disguising yourself with her clothes, you decide to take a wee nap before lil Red arrives...\");\n inBed.setDescription(\"Lying amongst the quilts in Grandma's bed\");\n inBed.setAccessible(false); //ONLY UNLOCK ONCE GRANDMA IS EATEN\n\n Room woods4 = new Room(\"More Woods\");\n woods4.setStory(\"Congrats! You feel very full after eating so much today, perhaps its time to return home and get a good nights sleep\");\n woods4.setDescription(\"A dark and ominous forest.\");\n woods4.setAccessible(false); ////ONLY UNLOCK ONCE GRANDMA and lil Red are eaten\n\n //Now make it possible to go back to the original Room -- \"Home??\"\n\n }",
"public String morningMeeting(){\n return \"accountants have meetings beginning at 9:15 AM and run until 8:45 AM\";\n }",
"void opponentInRoom();",
"public void createRoom(Rect room) {\n for(int x = room.x1 + 1; x < room.x2; x++) {\n for(int y = room.y1 + 1; y < room.y2; y++ ) {\n dungeon.map[x][y].blocked = false;\n dungeon.map[x][y].blockSight = false;\n }\n }\n }",
"@Test\n\tpublic void testAdjacenciesInsideRooms()\n\t{\n\t\t// Test a corner\n\t\tSet<BoardCell> testList = board.getAdjList(0, 0);\n\t\tassertEquals(0, testList.size());\n\t\t// Test one that has walkway above\n\t\ttestList = board.getAdjList(7, 19);\n\t\tassertEquals(0, testList.size());\n\t\t// Test one that is in middle of room\n\t\ttestList = board.getAdjList(20, 3);\n\t\tassertEquals(0, testList.size());\n\t\t// Test one beside a door\n\t\ttestList = board.getAdjList(18, 11);\n\t\tassertEquals(0, testList.size());\n\t\t// Test one in a edge of board\n\t\ttestList = board.getAdjList(11, 24);\n\t\tassertEquals(0, testList.size());\n\t}",
"private Room createRooms(){\n Room inicio, pasilloCeldas, celdaVacia1,celdaVacia2, pasilloExterior,vestuarioGuardias, \n comedorReclusos,enfermeria,ventanaAbierta,salidaEnfermeria,patioReclusos,tunelPatio,salidaPatio;\n\n Item mochila,medicamentos,comida,itemInutil,itemPesado;\n mochila = new Item(\"Mochila\",1,50,true,true);\n medicamentos = new Item(\"Medicamentos\",5,10,true,false);\n comida = new Item(\"Comida\",2,5,true,false);\n itemInutil = new Item(\"Inutil\",10,0,false,false);\n itemPesado = new Item(\"Pesas\",50,0,false,false);\n\n // create the rooms\n inicio = new Room(\"Tu celda de la prision\");\n pasilloCeldas = new Room(\"Pasillo donde se encuentan las celdas\");\n celdaVacia1 = new Room(\"Celda vacia enfrente de la tuya\");\n celdaVacia2 = new Room(\"Celda de tu compaņero, esta vacia\");\n pasilloExterior = new Room(\"Pasillo exterior separado de las celdas\");\n vestuarioGuardias = new Room(\"Vestuario de los guardias de la prision\");\n comedorReclusos = new Room(\"Comedor de reclusos\");\n enfermeria = new Room(\"Enfermeria de la prision\");\n ventanaAbierta = new Room(\"Saliente de ventana de la enfermeria\");\n salidaEnfermeria = new Room(\"Salida de la prision por la enfermeria\");\n patioReclusos = new Room(\"Patio exterior de los reclusos\");\n tunelPatio = new Room(\"Tunel escondido para escapar de la prision\");\n salidaPatio = new Room(\"Salida de la prision a traves del tunel del patio\");\n\n // initialise room items\n\n comedorReclusos.addItem(\"Comida\",comida);\n enfermeria.addItem(\"Medicamentos\",medicamentos);\n pasilloCeldas.addItem(\"Inutil\",itemInutil);\n patioReclusos.addItem(\"Pesas\",itemPesado);\n vestuarioGuardias.addItem(\"Mochila\",mochila);\n\n // initialise room exits\n\n inicio.setExits(\"east\", pasilloCeldas);\n pasilloCeldas.setExits(\"north\",pasilloExterior);\n pasilloCeldas.setExits(\"east\",celdaVacia1);\n pasilloCeldas.setExits(\"south\",patioReclusos);\n pasilloCeldas.setExits(\"west\",inicio);\n pasilloCeldas.setExits(\"suroeste\",celdaVacia2);\n celdaVacia1.setExits(\"west\", pasilloCeldas);\n pasilloExterior.setExits(\"north\",comedorReclusos);\n pasilloExterior.setExits(\"west\",enfermeria);\n pasilloExterior.setExits(\"east\",vestuarioGuardias);\n comedorReclusos.setExits(\"south\", pasilloExterior);\n enfermeria.setExits(\"east\",pasilloExterior);\n enfermeria.setExits(\"south\", ventanaAbierta);\n ventanaAbierta.setExits(\"north\",enfermeria);\n ventanaAbierta.setExits(\"south\", salidaEnfermeria);\n patioReclusos.setExits(\"north\", pasilloCeldas);\n patioReclusos.setExits(\"east\", tunelPatio);\n tunelPatio.setExits(\"east\",salidaPatio);\n tunelPatio.setExits(\"west\", patioReclusos);\n // casilla de salida\n\n return inicio;\n }",
"public static void main(String[] args) {\n\tArrayList<Item> hallInventory = new ArrayList<>();\n\tArrayList<Exit> hallExits = new ArrayList<>();\n\tRoom Hall = new Room(\"Entrance Hall\", \"It is an entrance hall of a very grand house\", hallInventory, hallExits);\n\n\t//kitchen\n\tArrayList<Item> kitchenInventory = new ArrayList<>();\n\tArrayList<Exit> kitchenExits = new ArrayList<>();\n\tRoom Kitchen = new Room(\"Kitchen\", \"This is a very large kitchen.\", kitchenInventory, kitchenExits);\n\n\t//dining room\n\tArrayList<Item> diningInventory = new ArrayList<>();\n\tArrayList<Exit> diningExits = new ArrayList<>();\n\tRoom Dining = new Room(\"Dining Room\", \"This dining room is set for 12 people\", diningInventory, diningExits);\n\n\t//lounge\n\tArrayList<Item> loungeInventory = new ArrayList<>();\n\tArrayList<Exit> loungeExits = new ArrayList<>();\n\tRoom Lounge = new Room(\"Lounge\", \"The Lounge is a mess, and there are blood spatters on the wall\", loungeInventory, loungeExits);\n\n\t//</editor-fold>\n\n\t//<editor-fold defaultstate=\"collapsed\" desc=\"Fill rooms with objects\">\n\thallInventory.add(new Item(\"a fruit bowl\", \"The fruit bowl contains some fruit\"));\n\thallInventory.add(new Item(\"a clock\", \"Tick Tock\"));\n\tkitchenInventory.add(new Item(\"a stove\", \"The stove is very hot\"));\n\tkitchenInventory.add(new Item(\"a knife\", \"The knife is blunt\"));\n\t//</editor-fold>\n\n\t//<editor-fold defaultstate=\"collapsed\" desc=\"add exits to rooms\">\n\thallExits.add(new Exit(1, Lounge));\n\thallExits.add(new Exit(4, Dining));\n\tloungeExits.add(new Exit(2, Hall));\n\tdiningExits.add(new Exit(3, Hall));\n\tdiningExits.add(new Exit(4, Kitchen));\n\tkitchenExits.add(new Exit(3, Dining));\n\t//</editor-fold>\n\n\t//create character : Avatar\n\t//<editor-fold defaultstate=\"collapsed\" desc=\"character creation\">\n\tArrayList<Item> invent = new ArrayList<>();\n\tCharacter Avatar = new Character(\"Tethys\", \"A tall elf dressed in armour\", 100, invent);\n\tinvent.add(new Item(\"armour\", \"leather armour\"));\n\t//</editor-fold>\n\t//begin\n\tRoom currentLoc = Hall;\n\tSystem.out.print(\"You are standing in the \" + currentLoc.getName() + \"\\n\" + currentLoc.getDesc() + \"\\n\");\n\tcurrentLoc.printInventory();\n\tcurrentLoc.printExits();\n\n\tBufferedReader command = new BufferedReader(new InputStreamReader(System.in));\n\tString orders = null;\n\twhile (true) {\n\t System.out.print(\"What do you want to do? \");\n\t try {\n\t\torders = command.readLine();\n\t } catch (IOException ioe) {\n\t\tSystem.out.println(\"I'm sorry, I didn't understand that!\");\n\t\tSystem.exit(1);\n\t }\n\n\t String[] orderWords = orders.split(\" \");\n\n//\t for (String s : orderWords){\n//\t\tSystem.out.print(s);\n\t switch (orderWords[0].toLowerCase()) {\n\t\tcase \"go\":\n\t\t int count = 0;\n\t\t for (Exit e : currentLoc.getExits()) {\n\t\t\tString direct = orderWords[1].toUpperCase();\n\t\t\tif (direct.equals(e.getDirectionName())) {\n\t\t\t currentLoc = e.getLeadsTo();\n\t\t\t count++;\n\t\t\t System.out.print(\"You are standing in the \" + currentLoc.getName() + \"\\n\" + currentLoc.getDesc() + \"\\n\");\n\t\t\t currentLoc.printInventory();\n\t\t\t currentLoc.printExits();\n\t\t\t break;\n\t\t\t}\n\t\t }\n\t\t if (count == 0) {\n\t\t\tSystem.out.print(\"I'm sorry, I can't go that way.\\n\");\n\t\t }\n\t\t break;\n\n\t\tcase \"pick\":\n\n\n\t\tcase \"put\":\n\n\n\t\tcase \"exit\":\n\t\t System.exit(0);\n\t\t break;\n\t }\n\n\t}\n\n\n }",
"public static void getRoomsHTML()\n\t{\n\t\t//get all the concept net entries that isa room\n\t\ttry\n\t\t{\n\t\t\tWebClient checkIP = new WebClient(\"http://conceptnet.io/c/en/room/n?rel=/r/IsA&limit=100000\");\n\t\t\tcheckIP.post(\"\");\n\t\t\tlong startIP = System.currentTimeMillis();\n\t\t\t\n\t\t\tfinal int OUTSIDE = 0;\n\t\t\tfinal int INEDGESTART = 1;\n\t\t\tfinal int INEDGEREL = 2;\n\t\t\tfinal int INEDGEEND = 3;\n\t\t\tint state = OUTSIDE;\n\t\t\t\n\t\t\tArrayList<ArrayList<String> > checkq = new ArrayList<ArrayList<String> >();\n\t\t\twhile(true)\n\t\t\t{\n\t\t\t\tcheckIP.getQueue(checkq);\n\t\t\t\tboolean processedsomething = false;\n\t\t\t\tfor (int i = 0; i < checkq.size(); i++) \n\t\t\t\t{\n\t\t\t\t\tArrayList<String> resultlines = checkq.remove(i);\n\t\t\t\t\t\n\t\t\t\t\tString x = null;\n\t\t\t\t\tString relation = null;\n\t\t\t\t\tString relationweight = null;\n\t\t\t\t\tString y = null;\n\n\t\t\t\t\tfor(int li=0;li<resultlines.size();li++)\n\t\t\t\t\t{\t\t\n\t\t\t\t\t\tprocessedsomething = true;\n\t\t\t\t\t\t\n\t\t\t\t\t\tString line = resultlines.get(li);\n\t\t\t\t\t\tline = line.trim();\n\t\t\t\t\t\t\n\t\t\t\t\t\tif(state==OUTSIDE)\n\t\t\t\t\t\t{\n\t\t\t\t\t\t\tif(line.startsWith(\"<td class=\\\"edge-start\\\">\"))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tstate = INEDGESTART;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\telse\n\t\t\t\t\t\tif(state==INEDGESTART)\n\t\t\t\t\t\t{\n\t\t\t\t\t\t\tif(line.startsWith(\"<a href=\\\"\"))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tline = line.substring(\"<a href=\\\"\".length());\n\t\t\t\t\t\t\t\tint ind = line.indexOf(\"\\\"\");\n\t\t\t\t\t\t\t\tline = line.substring(0,ind);\n\t\t\t\t\t\t\t\tx = line;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\telse\n\t\t\t\t\t\t\tif(line.startsWith(\"<td class=\\\"edge-rel\\\">\"))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tstate = INEDGEREL;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\telse\n\t\t\t\t\t\tif(state==INEDGEREL)\n\t\t\t\t\t\t{\n\t\t\t\t\t\t\tif(line.startsWith(\"― <span class=\\\"rel-label\\\">\"))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tline = line.substring(\"― <span class=\\\"rel-label\\\">\".length());\n\t\t\t\t\t\t\t\tint ind = line.indexOf(\"<\");\n\t\t\t\t\t\t\t\tline = line.substring(0,ind);\n\t\t\t\t\t\t\t\trelation = line;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\telse\n\t\t\t\t\t\t\tif(line.startsWith(\"Weight: \"))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tline = line.substring(\"Weight: \".length());\n\t\t\t\t\t\t\t\trelationweight = line;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\telse\n\t\t\t\t\t\t\tif(line.startsWith(\"<td class=\\\"edge-end\\\">\"))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tstate = INEDGEEND;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\telse\n\t\t\t\t\t\tif(state==INEDGEEND)\n\t\t\t\t\t\t{\n\t\t\t\t\t\t\t//if(line.startsWith(\"<a href=\\\"\"))\n\t\t\t\t\t\t\t//Grab the supplementary definition so we get the sense of the word i.e. a noun not a verb\n\t\t\t\t\t\t\tif(line.startsWith(\"(<a href=\\\"\"))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tline = line.substring(\"(<a href=\\\"\".length());\n\t\t\t\t\t\t\t\tint ind = line.indexOf(\"\\\"\");\n\t\t\t\t\t\t\t\tline = line.substring(0,ind);\n\t\t\t\t\t\t\t\ty = line;\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\t//can now process the edge information\n\t\t\t\t\t\t\t\t//we only want the things that are a room not things a room is\n\t\t\t\t\t\t\t\tif(y.equalsIgnoreCase(\"/c/en/room/n\"))\n\t\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\t\tSystem.out.println(x+\" \"+relation+\" \"+y);\n\t\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\telse\n\t\t\t\t\t\t\tif(line.startsWith(\"</sup>\"))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tstate = OUTSIDE;\n\t\t\t\t\t\t\t}\n\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t\tif(processedsomething)\n\t\t\t\t\tbreak;\n\t\t\t\t\n\t\t\t\tThread.sleep(16);\n\t\t\t\t\n\t\t\t\tlong time = System.currentTimeMillis();\n//\t\t\t\tif((time-startIP)>1000)\n//\t\t\t\t{\n//\t\t\t\t\t//timeout\n//\t\t\t\t\tbreak;\n//\t\t\t\t}\n\t\t\t}\t\n\t\t}\n\t\tcatch(Exception e)\n\t\t{\n\t\t\t\n\t\t}\n\t}",
"public void createRooms()\n {\n Room outside,bedroom, bathroom, hallway1, hallway2, spareroom, kitchen, fridge;\n\n // create the rooms\n bedroom = new Room(\"Bedroom\", \"your bedroom. A simple room with a little bit too much lego\");\n bathroom = new Room(\"Bathroom\", \"the bathroom where you take your business calls. Also plenty of toilet paper\");\n hallway1 = new Room(\"Hallway1\", \"the hallway outside your room, there is a dog here blocking your path. Youll need to USE something to distract him\");\n hallway2 = new Room(\"Hallway2\", \"the same hallway? This part leads to the spare room and kitchen\");\n spareroom = new Room(\"Spare room\", \"the spare room. This is for guests\");\n kitchen = new Room(\"Kitchen\", \"your kitchen. There is a bowl with cereal in it waiting for you,But its still missing some things\");\n fridge = new Room (\"Walk in Fridge\", \"a walkin fridge. Have you ever seen Ratatouille? Its like that\");\n outside = new Room(\"Outside\", \"the outside world, breathe it in\");\n \n \n Item toiletPaper, milk, spoon, poison;// creates the items and sets their room\n \n toiletPaper = new Item(\"Toilet-Paper\", hallway1);\n toiletPaper.setDescription(\"Just your standard bog roll. Dont let your dog get a hold of it\");\n bathroom.setItems(\"Toilet-Paper\",toiletPaper);\n \n milk = new Item(\"Milk\", kitchen);\n milk.setDescription(\"white and creamy, just like mama used to make\");\n fridge.setItems(\"Milk\", milk);\n \n spoon = new Item(\"Spoon\", kitchen);\n spoon.setDescription(\"Like a fork but for liquids\");\n spareroom.setItems(\"Spoon\", spoon);\n \n poison = new Item(\"Poison\", outside);\n poison.setDescription(\"This will probably drain all of your energy, dont USE it\");\n outside.setItems(\"Poison\", poison);\n \n // initialise room exits\n bedroom.setExit(\"east\", bathroom);\n bedroom.setExit(\"north\", hallway1);\n \n bathroom.setExit(\"west\", bedroom);\n \n hallway1.setExit(\"south\", bedroom);\n hallway1.setExit(\"north\", hallway2);\n \n hallway2.setExit(\"south\", hallway1);\n hallway2.setExit(\"west\", spareroom);\n hallway2.setExit(\"north\", kitchen);\n \n spareroom.setExit(\"east\", hallway2);\n \n kitchen.setExit(\"east\", outside);\n kitchen.setExit(\"west\", fridge);\n \n fridge.setExit(\"east\", kitchen);\n \n \n outside.setExit(\"west\", kitchen);\n \n\n this.currentRoom = bedroom; // start game in bedroom\n \n }",
"@Test\r\n\tpublic void testAdjacenciesInsideRooms()\r\n\t{\r\n\t\t// Test a corner\r\n\t\tSet<BoardCell> testList = board.getAdjList(0, 0);\r\n\t\tassertEquals(0, testList.size());\r\n\t\t// Test one that has walkway underneath\r\n\t\ttestList = board.getAdjList(7, 0);\r\n\t\tassertEquals(0, testList.size());\r\n\t\t// Test one that has walkway above\r\n\t\ttestList = board.getAdjList(13, 0);\r\n\t\tassertEquals(0, testList.size());\r\n\t\t// Test one that is in middle of room\r\n\t\ttestList = board.getAdjList(14, 17);\r\n\t\tassertEquals(0, testList.size());\r\n\t\t// Test one beside a door\r\n\t\ttestList = board.getAdjList(6, 16);\r\n\t\tassertEquals(0, testList.size());\r\n\t\t// Test one in a corner of room\r\n\t\ttestList = board.getAdjList(10, 15);\r\n\t\tassertEquals(0, testList.size());\r\n\t}",
"static private void inspectRoom() {\n ArrayList items = itemLocation.getItems(currentRoom);\n Item seeItem;\n String itemList = \"\";\n for (int i = 0; i < items.size(); i++) {\n\n seeItem = (Item) items.get(i);\n itemList += seeItem.getName();\n if (i < items.size() - 1) {\n itemList = itemList + \", \";\n }\n }\n System.out.println(itemList);\n int currentNPCsInRoom = 0;\n\n if (BSChristiansen.getCurrentRoom() == currentRoom) {\n System.out.println(\"There seems to be someone resting in the leaves\");\n currentNPCsInRoom++;\n }\n\n if (mysteriousCrab.getCurrentRoom() == currentRoom) {\n System.out.println(\"You sense somebody in the cave\");\n currentNPCsInRoom++;\n }\n\n if (josephSchnitzel.getCurrentRoom() == currentRoom) {\n System.out.println(\"There is an intense smell, somebody seems to be near!\");\n currentNPCsInRoom++;\n }\n if (currentNPCsInRoom == 0) {\n System.out.println(\"You are alone in the room\");\n }\n }",
"public static void getRoomsAPI()\n\t{\n\t\ttry\n\t\t{\n\t\t\tWebClient checkIP = new WebClient(\"http://api.conceptnet.io/c/en/room/n?offset=0&limit=1000\");\n\t\t\tcheckIP.post(\"\");\n\t\t\tlong startIP = System.currentTimeMillis();\n\t\t\t\n\t\t\tArrayList<ArrayList<String> > checkq = new ArrayList<ArrayList<String> >();\n\t\t\twhile(true)\n\t\t\t{\n\t\t\t\tcheckIP.getQueue(checkq);\n\t\t\t\tboolean processedsomething = false;\n\t\t\t\tfor (int i = 0; i < checkq.size(); i++) \n\t\t\t\t{\n\t\t\t\t\tArrayList<String> resultlines = checkq.remove(i);\n\t\t\t\t\t\n\t\t\t\t\tString x = null;\n\t\t\t\t\tString relation = null;\n\t\t\t\t\tString relationweight = null;\n\t\t\t\t\tString y = null;\n\n\t\t\t\t\tfor(int li=0;li<resultlines.size();li++)\n\t\t\t\t\t{\t\t\n\t\t\t\t\t\tprocessedsomething = true;\n\t\t\t\t\t\t\n\t\t\t\t\t\tString line = resultlines.get(li);\n\t\t\t\t\t\tline = line.trim();\t\t\t\n\t\t\t\t\t\t\n\t\t\t\t\t\tif(line.startsWith(\"\\\"@id\\\": \\\"/a/[\"))\n\t\t\t\t\t\t{\n\t\t\t\t\t\t\tline = line.substring(\"\\\"@id\\\": \\\"/a/[\".length());\n\t\t\t\t\t\t\tint ind = line.indexOf(\",\");\n\t\t\t\t\t\t\trelation = line.substring(0,ind);\n\t\t\t\t\t\t\tline = line.substring(ind+1);\n\t\t\t\t\t\t\tind = line.indexOf(\",\");\n\t\t\t\t\t\t\tx = line.substring(0,ind);\n\t\t\t\t\t\t\tline = line.substring(ind+1);\n\t\t\t\t\t\t\tind = line.indexOf(\"]\");\n\t\t\t\t\t\t\ty = line.substring(0,ind);\n\t\t\t\t\t\t}\n\t\t\t\t\t\tif(line.startsWith(\"\\\"weight\\\": \"))\n\t\t\t\t\t\t{\n\t\t\t\t\t\t\trelationweight = line.substring(\"\\\"weight\\\": \".length());\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t//can now process the edge information\n\t\t\t\t\t\t\t//we only want the things that are a room not things a room is\n\t\t\t\t\t\t\tif(y.equalsIgnoreCase(\"c/en/room/n\"))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tSystem.out.println(x+\" \"+relation+\" \"+y);\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t\tif(processedsomething)\n\t\t\t\t\tbreak;\n\t\t\t\t\n\t\t\t\tThread.sleep(16);\n\t\t\t\t\n\t\t\t\tlong time = System.currentTimeMillis();\n//\t\t\t\tif((time-startIP)>1000)\n//\t\t\t\t{\n//\t\t\t\t\t//timeout\n//\t\t\t\t\tbreak;\n//\t\t\t\t}\n\t\t\t}\t\n\t\t}\n\t\tcatch(Exception e)\n\t\t{\n\t\t\t\n\t\t}\n\t}",
"public void nextRoom() {\n room++;\n createRoom();\n }",
"public static int solution(String S) {\n S = \"Tue 00:00-03:00\\nTue 20:00-24:00\\nSun 10:00-20:00\\nFri 05:00-10:00\\nFri 16:30-23:50\\nSat 10:00-24:00\\nSun 01:00-04:00\\nSat 02:00-06:00\\nTue 03:30-18:15\\nTue 19:00-20:00\\nWed 04:25-15:14\\nWed 15:14-22:40\\nThu 00:00-23:59\\nMon 05:00-13:00\\nMon 15:00-21:00\";\n\n String lines[] = S.split(\"\\\\n\");\n\n List<Meeting> meetings = new ArrayList<>();\n for(String eachLine: lines){\n String cleanedMeeting = eachLine.replaceAll(\"\\\"\", \"\");\n System.out.println(cleanedMeeting+\"\\n\");\n\n Integer day = 0;\n String[] meetingParts = cleanedMeeting.split(\" \");\n String strDay = meetingParts[0];\n switch (strDay){\n case \"Mon\":\n day = 1;\n break;\n case \"Tue\":\n day = 2;\n break;\n case \"Wed\":\n day = 3;\n break;\n case \"Thu\":\n day = 4;\n break;\n case \"Fri\":\n day = 5;\n break;\n case \"Sat\":\n day = 6;\n break;\n case \"Sun\":\n day = 7;\n break;\n default:\n break;\n }\n\n Meeting meeting = new Meeting(day, meetingParts[1].split(\"-\")[0], meetingParts[1].split(\"-\")[1]);\n meetings.add(meeting);\n }\n\n Collections.sort(meetings);\n\n return calculateLongerSleepingTime(meetings);\n }",
"static private void npcPath() {\n\n if (Time.secondsPassed % 45 == 44) {\n Random picker = new Random();\n while (true) {\n if (josephSchnitzel.getCurrentRoom().equals(mountain)) {\n String[] newRoomString = {\"south\"};\n int index = picker.nextInt(newRoomString.length);\n Room next = josephSchnitzel.getCurrentRoom().getExit(newRoomString[index]);\n josephSchnitzel.setCurrentRoom(next);\n break;\n }\n\n if (josephSchnitzel.getCurrentRoom().equals(beach)) {\n String[] newRoomString = {\"north\"};\n int indexOfNewRoomString = picker.nextInt(newRoomString.length);\n Room nextRoom = josephSchnitzel.getCurrentRoom().getExit(newRoomString[indexOfNewRoomString]);\n josephSchnitzel.setCurrentRoom(nextRoom);\n break;\n }\n\n if (josephSchnitzel.getCurrentRoom().equals(jungle)) {\n String[] newRoomString = {\"north\", \"south\"};\n int indexOfNewRoomString = picker.nextInt(newRoomString.length);\n Room nextRoom = josephSchnitzel.getCurrentRoom().getExit(newRoomString[indexOfNewRoomString]);\n josephSchnitzel.setCurrentRoom(nextRoom);\n break;\n }\n }\n }\n }",
"private Room boxCreatorFromHallway(Hallway hallway) {\n int[] previous = hallway.bottomleft;\n int length = hallway.length;\n String pdirection = hallway.orientation;\n int width = r.nextInt(5) + 5;\n int height = r.nextInt(6) + 5;\n if (pdirection.equals(\"up\")) {\n int[] coordinates = new int[2];\n coordinates[0] = r.nextInt(width - 2) + previous[0] + 2 - width + 1;\n coordinates[1] = previous[1] + length;\n ArrayList<String> sidesavailable = arrayMaker(pdirection);\n String numberofrooms = \"Room \" + (this.numberofRooms + 1);\n String received = \"S\";\n Room room = new Room(1, width, height, coordinates,\n false, sidesavailable, numberofrooms, received);\n if (overlapRooms(room)) {\n return null;\n } else {\n this.numberofRooms += 1;\n boxCreator(coordinates, width, height);\n tiles[previous[0] + 1][previous[1] + length] = Tileset.FLOWER;\n this.rooms.put(this.numberofRooms, room);\n return room;\n }\n } else if (pdirection.equals(\"down\")) {\n int[] coordinates = new int[2];\n coordinates[0] = r.nextInt(width - 2) + previous[0] + 2 - width + 1;\n coordinates[1] = previous[1] - height;\n ArrayList<String> sidesavailable = arrayMaker(pdirection);\n String numberofrooms = \"Room \" + (this.numberofRooms + 1);\n String received = \"N\";\n Room room = new Room(1, width, height, coordinates,\n false, sidesavailable, numberofrooms, received);\n if (overlapRooms(room)) {\n return null;\n } else {\n this.numberofRooms += 1;\n boxCreator(coordinates, width, height);\n tiles[previous[0] + 1][previous[1]] = Tileset.FLOWER;\n this.rooms.put(this.numberofRooms, room);\n return room;\n }\n } else if (pdirection.equals(\"right\")) {\n int[] coordinates = new int[2];\n coordinates[0] = previous[0] + length;\n coordinates[1] = r.nextInt(height - 2) + previous[1] + 2 - height + 1;\n ArrayList<String> sidesavailable = arrayMaker(pdirection);\n String numberofrooms = \"Room\" + (this.numberofRooms + 1);\n String received = \"W\";\n Room room = new Room(1, width, height, coordinates,\n false, sidesavailable, numberofrooms, received);\n if (overlapRooms(room)) {\n return null;\n } else {\n this.numberofRooms += 1;\n boxCreator(coordinates, width, height);\n tiles[previous[0] + length][previous[1] + 1] = Tileset.FLOWER;\n this.rooms.put(numberofRooms, room);\n return room;\n }\n } else {\n int[] coordinates = new int[2];\n coordinates[0] = previous[0] - width;\n coordinates[1] = r.nextInt(height - 2) + previous[1] + 2 - height + 1;\n ArrayList<String> sidesavailable = arrayMaker(pdirection);\n String numberofrooms = \"Room\" + (this.numberofRooms + 1);\n String received = \"E\";\n Room room = new Room(1, width, height, coordinates,\n false, sidesavailable, numberofrooms, received);\n if (overlapRooms(room)) {\n return null;\n } else {\n this.numberofRooms += 1;\n boxCreator(coordinates, width, height);\n tiles[previous[0]][previous[1] + 1] = Tileset.FLOWER;\n this.rooms.put(this.numberofRooms, room);\n return room;\n }\n }\n }",
"private List<Room> addRooms() {\n List<Room> rooms = new ArrayList<>();\n int numRooms = RandomUtils.uniform(random, MINROOMNUM, MAXROOMNUM);\n int playerRoomNum = RandomUtils.uniform(random, 0, numRooms);\n for (int i = 0; i < numRooms; i++) {\n rooms.add(addRandomRoom(random));\n if (i == playerRoomNum) {\n setPlayerInitialPosition(rooms, playerRoomNum);\n }\n }\n return rooms;\n }",
"public void unbookRoom(int room) {\n availableRooms.add(availableRooms.size(), room);\n unavailableRooms.remove(unavailableRooms.indexOf(room));\n unavailableRooms = unavailableRooms.stream().sorted().collect(Collectors.toList());\n availableRooms = availableRooms.stream().sorted().collect(Collectors.toList());\n System.out.println(\"Thank you for staying! See you next time.\");\n }",
"private static void printRoom(Room currentRoom) {\n\t\t\n\t}",
"RoomInfo room(String name);",
"private ArrayList<Room> roomAvailability(LocalDate start, LocalDate end, int small, int medium, int large) {\n ArrayList<Room> availableRooms = new ArrayList<Room>();\n // Iterate for all rooms in the venue\n for (Room room : rooms) {\n // Search the venue's reservations that contain the specified room.\n ArrayList<Reservation> reservationsWithRoom = Reservation.searchReservation(reservations, room);\n // Try to find rooms that fulfil the request.\n switch(room.getSize()) {\n case \"small\":\n // Ignore if no small rooms are needed.\n if (small > 0) {\n // If there no reservations with the room or the reserved dates do not\n // overlap, then add the room sinced it is available.\n if(reservationsWithRoom.size() == 0 ||\n !Reservation.hasDateOverlap(reservationsWithRoom, start, end)) {\n\n availableRooms.add(room);\n small--;\n } \n }\n break;\n\n case \"medium\":\n // Ignore if no medium rooms are needed.\n if (medium > 0) {\n \n if (reservationsWithRoom.size() == 0 ||\n !Reservation.hasDateOverlap(reservationsWithRoom, start, end)) {\n \n availableRooms.add(room);\n medium--;\n }\n }\n break;\n\n case \"large\":\n // Ignore if no large rooms ar eneeded.\n if (large > 0) {\n if (reservationsWithRoom.size() == 0 ||\n !Reservation.hasDateOverlap(reservationsWithRoom, start, end)) {\n \n availableRooms.add(room);\n large--;\n }\n break;\n }\n }\n }\n // A request cannot be fulfilled if there are no rooms available in the venue\n if (small > 0 || medium > 0 || large > 0) {\n \n return null;\n } else {\n return availableRooms;\n }\n }",
"public void mergeRooms(Vector<Integer> roomThatWasMatched2) {\n\t\tint room = roomThatWasMatched2.get(0);\r\n\t\tfor (int m=1; m<roomThatWasMatched2.size(); m++) { //notice that index 0 is for the room we are using\r\n\t\t\tmaze.map.remove(roomsThatWereMatched.get(m));\r\n//\t\t\tstartPaths.remove(roomThatWasMatched2.get(m));\r\n//\t\t\tdestinationPaths.remove(roomThatWasMatched2.get(m));\r\n\t\t\tfor ( Map.Entry<Integer, Vector<Edge>> entry: startPaths.entrySet() ) {\r\n\t\t\t\tVector<Edge> vectorOfEdges = entry.getValue();\r\n\t\t\t\tfor (int test=0; test<vectorOfEdges.size(); test++) { \r\n\t\t\t\t\tif( roomThatWasMatched2.get(m) == vectorOfEdges.get(test).StartRoom ){\r\n\t\t\t\t\t\tlog.debug(\"room \"+roomThatWasMatched2.get(m)+\" merged with \"+room);\r\n\t\t\t\t\t\tvectorOfEdges.get(test).StartRoom = room;\r\n\t\t\t\t\t}\r\n\t\t\t\t\tif( roomThatWasMatched2.get(m) == vectorOfEdges.get(test).DestinationRoom ){\r\n\t\t\t\t\t\tlog.debug(\"room \"+roomThatWasMatched2.get(m)+\" merged with \"+room);\r\n\t\t\t\t\t\tvectorOfEdges.get(test).DestinationRoom = room;\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"public void fillPassengersWithRealPeople(){\r\n Passenger p1 = new Passenger(\"Jimmy\", \"Quaresmini\", 5100, 7, \"London\", 40);\r\n Passenger p2 = new Passenger(\"Masod\", \"Jalalian\", 5200, 9, \"London\", 60);\r\n Passenger p8 = new Passenger(\"Bardia\", \"Fathi\", 5300, 6, \"London\", 38);\r\n Passenger p9 = new Passenger(\"Sami\", \"Norola\", 5300, 8, \"London\", 37);\r\n Passenger p10 = new Passenger(\"Bardias\", \"Girlfriend\", 5200, 10, \"London\", 35);\r\n /*seats.add(6, new Seat(7,p1));//Jimmy\r\n seats.add(8, new Seat(9,p2));//Masod\r\n seats.add(5, new Seat(6,p8));//Bardia\r\n seats.add(7, new Seat(8,p9));//Sami\r\n seats.add(9, new Seat(10,p10));//Bardias Girlfriend*/\r\n\r\n Passenger p3 = new Passenger(\"Mattias\", \"Svensson-Nordell\", 22000, 1, \"London\", 29);\r\n //seats.add(0, new Seat(1,p3));\r\n Passenger p4 = new Passenger(\"Bita\", \"Jabbari\", 21000, 3, \"London\", 43);\r\n //seats.add(2, new Seat(3,p4));\r\n Passenger p5 = new Passenger(\"Marcus\", \"Lippert\", 24000, 2, \"London\", 45);\r\n //seats.add(1, new Seat(2,p5));\r\n Passenger p6 = new Passenger(\"Christer\", \"Barousen\", 21000, 4, \"London\", 44);\r\n //seats.add(3, new Seat(4,p6));\r\n Passenger p7 = new Passenger(\"Linda\", \"Hilding\", 21500, 5, \"London\", 42);\r\n //seats.add(4, new Seat(5,p7));\r\n\r\n passengers.add(p1);\r\n passengers.add(p2);\r\n passengers.add(p3);\r\n passengers.add(p4);\r\n passengers.add(p5);\r\n\r\n passengers.add(p6);\r\n passengers.add(p7);\r\n passengers.add(p8);\r\n passengers.add(p9);\r\n passengers.add(p10);\r\n\r\n seats.add(0, new Seat(1,p3));//Mattias\r\n seats.add(1, new Seat(2,p5));//Marcus\r\n seats.add(2, new Seat(3,p4));//Bita\r\n seats.add(3, new Seat(4,p6));//Christer\r\n seats.add(4, new Seat(5,p7));//Linda\r\n\r\n seats.add(5, new Seat(6,p8));//Bardia\r\n seats.add(6, new Seat(7,p1));//Jimmy\r\n seats.add(7, new Seat(8,p9));//Sami\r\n seats.add(8, new Seat(9,p2));//Masod\r\n seats.add(9, new Seat(10,p10));//Bardias Girlfriend\r\n }",
"public static void processLeaveRoomCommand(String leavePlayerName) throws IOException {\n\n Map<String, Socket> clientMap = Main.getClientMap();\n CopyOnWriteArrayList<Room> roomList = Main.getWaitRoomList();\n\n for (Room room : roomList) {\n //System.out.println(\"dd\"+Arrays.binarySearch(room.getPlayersName(), leavePlayerName));\n if (Arrays.binarySearch(room.getPlayersName(), leavePlayerName)==0) { //房間主人離開\n System.out.println(\"Host leave\");\n String[] roomPlayers = room.getPlayersName();\n\n Set<Map.Entry<String, Socket>> entrySet = clientMap.entrySet();\n\n for (int i = 1; i < roomPlayers.length; i++) { //找該房間其他人的socket,送roomDisbandCommand\n\n for (Map.Entry<String, Socket> stringSocketEntry : entrySet) {\n if (stringSocketEntry.getKey().equals(roomPlayers[i])) {\n\n Socket socket = stringSocketEntry.getValue();\n ObjectOutputStream otherClientOut = new ObjectOutputStream(socket.getOutputStream());\n RoomDisbandCommand roomDisbandCommand = new RoomDisbandCommand();\n otherClientOut.writeObject(roomDisbandCommand);\n }\n }\n }\n\n roomList.remove(room);\n Main.setWaitRoomList(roomList);\n break;\n } else if (Arrays.asList(room.getPlayersName()).contains(leavePlayerName)) { //非房間主人離開\n System.out.println(\"Not host leave\");\n\n ArrayList<String> list = new ArrayList<>(Arrays.asList(room.getPlayersName().clone()));\n //List<String> list = Arrays.asList(room.getPlayersName().clone());\n list.remove(leavePlayerName);\n //room.setPlayersName((String[]) list.toArray());\n room.setPlayersName((String[])list.toArray(new String[list.size()]));\n\n Main.setWaitRoomList(roomList);\n\n sendRoomPlayerCommand(room, leavePlayerName);\n break;\n }\n }\n\n }",
"Room mo12151c();",
"public void wallsAndGatesV0(int[][] rooms) {\n if (checkCornerCase(rooms)) {\n return;\n }\n for (int i = 0; i < rooms.length; i++) {\n for (int j = 0; j < rooms[0].length; j++) {\n if (rooms[i][j] >= 0) { // gate or room\n bfsHelper(rooms, i, j);\n }\n }\n }\n }",
"private void placeRooms() {\n if (roomList.size() == 0) {\n throw new IllegalArgumentException(\"roomList must have rooms\");\n }\n // This is a nice cool square\n map = new int[MAP_SIZE][MAP_SIZE];\n\n for (Room room : roomList) {\n assignPosition(room);\n }\n }",
"public static void main(String[] args)\n\t\t\tthrows CloneNotSupportedException, SQLException, ClassNotFoundException, DAOException, IOException, CustomException {\n\t\tif(GeneralDAO.getRooms().size()<2){\n\t\t\tTransactionStatus.setStatusMessage(\"There must be atleast 2 rooms !\");\n\t\t\tthrow new CustomException(\"\");\n\t\t}\n\t\tTimeTableEndSem TT = new TimeTableEndSem();\n\t\tSet<Integer> set = new HashSet<>();// stores batch numbers of\n\t\t\t\t\t\t\t\t\t\t\t// timeinterval2 of odd slots\n\t\t// Running main algorithm for all the slots.It creates timetable of all\n\t\t// the slots separately.\n\t\tfor (int h = 0; h < TT.getSlot().length; h++)//\n\t\t{\n\t\t\tSystem.out.println(\"**************************SLOT NO: \" + (h + 1) + \"****************************\");\n\t\t\t// System.out.println(\"Room No Course ID Course Name\");\n\n\t\t\t// if((h+1)%2==0)\n\t\t\t// {\n\t\t\t// set.removeAll(set);//clear set for reuse\n\t\t\t// }\n\t\t\t//\n\n\t\t\tTimeInterval time1 = new TimeInterval(1);\n\t\t\tTimeInterval time2 = new TimeInterval(2);\n\t\t\tint flag = 0;// a flag to use to forcibly exit loops or restarting\n\t\t\t\t\t\t\t// loops.\n\t\t\tTimeInterval[] array = { time1, time2 };\n\t\t\tint p = 0;\n\t\t\tSlot slot = TT.getSlot()[h];\n\n\t\t\tif (h == 0) {\n\n\t\t\t\tHashSet<Integer> set2 = new HashSet<>();\n\t\t\t\tfor (Course course : GeneralDAO.getCourses(2)) {\n\t\t\t\t\tset2.add(Integer.parseInt(course.getBatch()));\n\t\t\t\t}\n\t\t\t\tfor (Course course : slot.getCourses()) {\n\t\t\t\t\tif (set2.contains(Integer.parseInt(course.getBatch()))) {\n\t\t\t\t\t\tcourse.setSlot1priority(1);\n\t\t\t\t\t}\n\t\t\t\t//\tSystem.out.println(course + \" and priority: \" + course.getSlot1priority());\n\t\t\t\t}\n\n\t\t\t\t// System.out.println(\"set2\"+set2);\n\t\t\t\t// for(Course course:slot.getSlot2courses())\n\t\t\t\t// System.out.println(course);\n\t\t\t} else if (h != 0) {\n\t\t\t\tfor (Course course : slot.getCourses()) {\n\t\t\t\t\tif (set.contains(Integer.parseInt(course.getBatch()))) {\n\t\t\t\t\t\tcourse.setFlag_clash(1);\n\t\t\t\t\t\t// System.out.println(\"setting flag_clash=1:::\"+course);\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t\tset.removeAll(set);\n\t\t\tint k = 1;\n\t\t\t\n\t\t\tbuffer=new ArrayList<>();\n\t\t\twhile (slot.slotProcessed())// if all the courses are processed,\n\t\t\t\t\t\t\t\t\t\t// then loop breaks.\n\t\t\t{\n\t\t\t\t\n\t\t\t\tCourse tempCourse = slot.chosingCourse();// refer slot class for\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// details\n\t\t\t\tbuffer.add(new Course(tempCourse));//copy of new course so that initial state is always fresh even if \n\t\t\t\t//source ArrayList in slot class is updated(when course is processed=true).\n\t\t\t\tCollections.sort(buffer, new CourseComparatorByCapacity());//reassigning priorities in descending order.\n\t\t\t\tSystem.out.println(\"Buffer:\");\n\t\t\t\tfor(Course course:buffer)\n\t\t\t\t\tSystem.out.println(course);\n\t\t\t\t//System.out.println(\"Address of:\"+tempCourse.getCourse_name()+\"\"+tempCourse);\n\t\t\t\tTimeInterval[] array2=null;\n\t\t\t\t\n\t\t\t\tbuffer_copy=new ArrayList<>();\n//\t\t\t\tfor(Course course:buffer)\n//\t\t\t\t{\n//\t\t\t\t\tCourse course_copy=new Course(course);\n//\t\t\t\t\tbuffer_copy.add(course_copy);\n//\t\t\t\t}\n\t\t\t\tUtility1 utility=null;\n\t\t\t\tboolean flag_failed_verified=false;\n\t\t\t\t\n\t\t\t\tif(true)//Except slot 1,all the slots are getting processed through buffer concept.\n\t\t\t\t{\n\t\t\t\t\t\n\t\t\t\t\tfor(Course course:buffer)\n\t\t\t\t\t{//\tSystem.out.println(\"buffer size:\"+buffer.size());\n\t\t\t\t\t\t//Course course=buffer.get(i);\n\t\t\t\t\t\t//System.out.println(\"Going bhaiuiiiiiiiiiiiiiiiiiiiii\");\n\t\t\t\t\t\t//System.out.println(course.hashCode());\n\t\t\t\t\tutility=TT.dynamicAllot(array2, course, slot, TT, 1,0,\"buffer\");\n\t\t\t\t\t//System.out.println(course.hashCode());\n\t\t\t\t\t//System.out.println(course.getProcessed());\n\t\t\t\t\t//System.out.println(\"Going bhaiuiiiiiiiiiiiiiiiiiiiii55555555\");\n\t\t\t\t//\tk=utility.k;//useless in this case.\n\t\t\t\t\tarray2=utility.array;//restoring array and slot after processing in above function.\n\t\t\t\t\tslot=utility.slot;\n\t\t\t\t\t//System.out.println(\"********************\");\n\t\t\t\t\tbuffer_copy.add(utility.course);// Storing all the courses of this buffer. This buffer_copy contains\n\t\t\t\t\t//Courses when all the courses from buffer have been processed and this needs to be updated to chosingCourse()\n\t\t\t\t\t//so that it choses next prior course.\n//\t\t\t\t\tarray2[0].print();\n//\t\t\t\t\tarray2[1].print();\n\t\t\t\t\tSystem.out.println(utility.course.getUnallocated_strength());\n\t\t\t\t\t\tif(utility.flag_failed==1)\n\t\t\t\t\t\t{\n\t\t\t\t\t\t\tSystem.out.println(\"Flag Failed is verified\");\n\t\t\t\t\t\t\tflag_failed_verified=true;\n\t\t\t\t\t\t//\tbreak;\n\t\t\t\t\t\t}\n\t\t\t\t\t//\tSystem.out.println(course);\n\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t\t\n\t\t\t\t//For first slot, no buffer concept and if a course could not be processed or it lead to alter the existing ti 2\n\t\t\t\t//structure, undo it and reallocate it in normal case. below is normal case as for slot1. Check TimeTable class\n\t\t\t\t//for CourseIntact. \n\t\t\t\t//NORMAL ALLOTMENT OPTION\n\t\t\t\tif(!TT.courseIntact(array, array2) || flag_failed_verified==true) \n\t\t\t\t{\n\t\t\t\t\t\n\t\t\t\t\t//System.out.println(tempCourse+\"finally going to ti2\");\n//\t\t\t\t\tif(!TT.courseIntact(array, array2))\n//\t\t\t\t\t\tk=1;//always gives k=0 if slot is not 1. Basically, I have ruled out alternating k from slot >1\n\t\t\t\t\t//System.out.println(\"In normal case,\"+buffer.get(0).getUnallocated_strength());\n\t\t\t\tUtility1 utility2=TT.dynamicAllot(array, tempCourse, slot, TT, 1,1,\"normal\");// normal case.\n\t\t\t//\tk=utility2.k;\n\t\t\t\tarray=utility2.array;\n\t\t\t\tslot=utility2.slot;\n\t\t\t\t//pass on course\n\t\t\t\t//System.out.println(\"----------\"+utility2.course+\" \"+utility2.course.getProcessed());\n\t\t\t\t\t\n\t\t\t\t//updating course in the source ArrayList of Slot class which chosingCourse() uses.\n\t\t\t\tfor(int n=0;n<slot.getCourses().size();n++)\n\t\t\t\t\t{\n\t\t\t\t\t\tCourse course2=slot.getCourses().get(n);\n\t\t\t\t\t\t\tif(course2.getCourse_id().equals(utility2.course.getCourse_id()))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tslot.getCourses().set(n, utility2.course);\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{//if courseIntact is true, it means our buffer is successfully processed. Now, replace the existing \n\t\t\t\t\t//timeinterval with new one with updated data.\n\t\t\t\t\tarray=array2;\n\t\t\t\t\t\n\t\t\t\t\t//Further, update all the courses from buffer with modified state in buffer_copy to source arraylist\n\t\t\t\t\t//of slot class.\n\t\t\t\t\tfor(int n=0;n<slot.getCourses().size();n++)\n\t\t\t\t\t{\n\t\t\t\t\t\tCourse course2=slot.getCourses().get(n);\n\t\t\t\t\t\tfor(Course course3:buffer_copy)\n\t\t\t\t\t\t\tif(course2.getCourse_id().equals(course3.getCourse_id()))\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\t\tslot.getCourses().set(n, course3);\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tslot.updateProcessCount(); //One iteration of while loop processes one course \n\t\t\t\t//fully irrespective of the fact that it has been failed, allocated in one go or in different buffer.\n\t\t\t\t\n\t\t\t}\n\t\t\tarray[0].print();\n\t\t\tarray[1].print();\n\t\t\tTT.getStore().put(h + 1, new StoreTT(h + 1, array[0], array[1]));\n\t\t\t//System.out.println(\"It's really painful************\");\n//\t\t\tSet<Course> set1 = new HashSet<>();\n//\t\t\tfor (ArrayList<OccupationData> od : array[0].getMap().values()) {\n//\t\t\t\tfor (int hh = 0; hh < od.size(); hh++) {\n//\t\t\t\t\tset1.add(od.get(hh).getCourse());\n//\t\t\t\t}\n//\t\t\t}\n\t\t\t//System.out.println(\"set1\" + set1 + \"for k=\" + k);\n\t\t\t// System.out.println(set);\n\t\t\tif (!array[0].getMap().isEmpty())// if time2 has some courses\n\t\t\t\t\t\t\t\t\t\t\t\t// allocated\n\t\t\t{//System.out.println(\"Printingggg\"+array[0].getMap().size());\n\t\t\t\tfor (ArrayList<OccupationData> od : array[0].getMap().values())// stores\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// all\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// the\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// batches\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// of\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// time2\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// in\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// set\n\t\t\t\t{\n\t\t\t\t//\tSystem.out.println(\"Printing\"+od.size());\n\t\t\t\t \tfor (int hh = 0; hh < od.size(); hh++) {\n\t\t\t\t\t\tset.add(Integer.parseInt(od.get(hh).getCourse().getBatch()));\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t\t// System.out.println(set);\n\t\t}\n\t\t// It prints data in excel sheet and exports a .xlsx file\n\t\t// PrintExcel excel=new PrintExcel();\n\t\tPrintExcelEndSem excel = new PrintExcelEndSem();\n\n\t\tSystem.out.println(\"Following courses Failed\");\n\t\tfailedCourses = TT.getFailed();\n\t\tfor(Course course:failedCourses)\n\t\t{\n\t\t\tSystem.out.println(course.getCourse_name());\n\t\t}\n\t\texcel.createExcelSheet(TT);\n\t\t// Map<Course,Integer> map=GenerateTT.printUnallocatedStudents(TT);\n\t}",
"@Test\n\t\t\tpublic void testRoomEntry()\n\t\t\t{\n\t\t\t\t// two steps from a room two steps away\n\t\t\t\tboard.calcTargets(13, 10, 2);\n\t\t\t\tSet<BoardCell> targets= board.getTargets();\n\t\t\t\tboard.clearTargets();\n\t\t\t\tassertTrue(targets.contains(board.getCellAt(14, 9)));\n\t\t\t\t\n\t\t\t\t//Test entering a door when steps are greater than distance to room\n\t\t\t\tboard.calcTargets(8, 7, 8);\n\t\t\t\ttargets= board.getTargets();\n\t\t\t\tboard.clearTargets();\n\t\t\t\tassertTrue(targets.contains(board.getCellAt(12, 6)));\n\t\t\t\t\n\t\t\t\t\n\t\t\t\t\n\t\t\t}",
"void showCreatorWaitingRoom();",
"public void createRooms()\n { \n // create the rooms\n //RDC//\n hall = new Room(\"Hall\", \"..\\\\pictures\\\\Rooms\\\\hall.png\");\n banquetinghall = new Room (\"Banqueting hall\", \"..\\\\pictures\\\\Rooms\\\\banquet.png\");\n poolroom = new Room (\"PoolRoom\", \"..\\\\pictures\\\\Rooms\\\\billard.png\");\n dancingroom = new Room (\"Dancing Room\", \"..\\\\pictures\\\\Rooms\\\\bal.png\");\n kitchen = new Room(\"Kitchen\", null);\n garden = new Room(\"Garden\", null);\n well = new Room(\"Well\", null);\n gardenerhut = new Room(\"Gardener hut\", null);\n //Fin RDN //\n \n //-1//\n anteroom = new Room(\"Anteroom\", null);\n ritualroom = new Room(\"Ritual Room\", null);\n cellar = new Room(\"Cellar\", null);\n // FIN -1//\n // +1 //\n livingroom = new Room(\"Living Room\", null); \n library = new Room (\"Library\", null);\n laboratory = new Room(\"Laboratory\", null);\n corridor= new Room(\"Corridor\", null);\n bathroom = new Room(\"Bathroom\", null);\n bedroom = new Room(\"Bedroom\", null);\n guestbedroom = new Room(\"Guest Bedroom\", null); \n //FIN +1 //\n //+2//\n attic = new Room(\"Attic\", null);\n //Fin +2//\n //Fin create room // \n \n // initialise room exits\n //RDC\n hall.setExits(\"north\",garden, false, \"> You must explore the mansion before\");\n hall.setExits(\"south\",banquetinghall, true, null); \n banquetinghall.setExits(\"north\",hall, true, null);\n banquetinghall.setExits(\"south\",dancingroom, false, \"> The door is blocked by Bob's toys\");\n banquetinghall.setExits(\"east\",kitchen, true, null);\n banquetinghall.setExits(\"west\",poolroom, true, null);\n //poolroom.setExits(\"east\",banquetinghall, false, \"> You have not finished examining the crime scene\");\n poolroom.setExits(\"east\",banquetinghall, true, \"> You have not finished examining the crime scene\");\n dancingroom.setExits(\"north\",banquetinghall, true, null);\n dancingroom.setExits(\"up\",livingroom, true, null);\n kitchen.setExits(\"west\",banquetinghall, true, null);\n kitchen.setExits(\"down\",cellar, true, null);\n garden.setExits(\"south\",hall, true, null);\n garden.setExits(\"north\",well, true, null);\n garden.setExits(\"east\",gardenerhut, true, null);\n well.setExits(\"south\",garden, true, null);\n gardenerhut.setExits(\"west\",garden, true, null);\n //gardenerhut.setExits(\"down\",anteroom, false, null);\n //-1// \n anteroom.setExits(\"south\",ritualroom, true, null);\n anteroom.setExits(\"up\",gardenerhut, false, \"> The door is locked. You cannot go backward\");\n anteroom.setExits(\"west\",cellar, true, null);\n ritualroom.setExits(\"north\",anteroom, true, null);\n cellar.setExits(\"up\",kitchen, true, null);\n //cellar.setExits(\"east\", anteroom, false); To unlock\n //+1//\n livingroom.setExits(\"down\",dancingroom, true, null);\n livingroom.setExits(\"north\",library, true, null);\n livingroom.setExits(\"west\",corridor, true, null);\n library.setExits(\"south\",livingroom, true, null);\n //library.setExits(\"north\",laboratory, false); To unlock\n laboratory.setExits(\"south\",library, true, null);\n corridor.setExits(\"north\",bathroom, true, null);\n corridor.setExits(\"south\",bedroom, false, \"> The door is locked. A key may be mandatory\");\n corridor.setExits(\"east\",livingroom, true, null);\n corridor.setExits(\"west\",guestbedroom, true, null);\n corridor.setExits(\"up\",attic, false, \"> You see a weird lock in the ceiling\");\n bathroom.setExits(\"south\",corridor, true, null);\n bedroom.setExits(\"north\",corridor, true, null);\n guestbedroom.setExits(\"east\",corridor, true, null);\n attic.setExits(\"down\",corridor, true, null);\n \n //currentRoom = poolroom; // start game outside\n currentRoom = poolroom;\n }",
"private boolean checkRoomValid(String room) {\n\treturn true;\r\n}",
"public void fillRoom() {\n\t\tint doorCounter = 0;\r\n\t\tint doorSpot = pickDoorSpot();\r\n\t\t\r\n\t\tfor (int i = 0; i < getRoomWidth(); i++) {\r\n\t\t\tfor (int j = 0; j < getRoomLength(); j++) {\r\n\t\t\t\tif (i == 0 || j == 0) {\r\n\t\t\t\t\tdungeonRoom[i][j] = new Wall(false);\r\n\t\t\t\t\tdoorCounter++;\r\n\t\t\t\t\tif (doorCounter == doorSpot) {\r\n\t\t\t\t\t\tdungeonRoom[i][j] = new Door(\" | \", false, false);\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t\telse if (i == getRoomWidth() - 1 || j == getRoomLength() - 1) {\r\n\t\t\t\t\tdungeonRoom[i][j] = new Wall(false);\r\n\t\t\t\t\tdoorCounter++;\r\n\t\t\t\t\tif (doorCounter == doorSpot) {\r\n\t\t\t\t\t\tdungeonRoom[i][j] = new Door(\" | \", false, false);\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"private void printRoomInfo(Room room, List<String> retirevedInRoom, StringBuilder sb) {\n sb.append(room.getId());\n insertSpacing(sb, room.getId().toString());\n sb.append(room.getName());\n insertSpacing(sb, room.getName());\n if (CollectionUtils.isNotEmpty(retirevedInRoom)) {\n for (String obj : retirevedInRoom) {\n sb.append(obj);\n sb.append(\" \");\n }\n } else {\n sb.append(\"None\");\n }\n sb.append(NEWLINE);\n }",
"Room getRoom();",
"Room getRoom();",
"private boolean isMeetingInMeetingManager(String description){\n \tboolean inSide = false;\n \tfor(Meeting m : meetings){\n \t\tif(m.getDescription().equals(description)&&meetings.isEmpty() == false){\n \t\t\tinSide = true;\n \t\t}\n \t}\n \treturn inSide;\n }",
"RoomInfo room(int id);",
"public void createChatRoom(String name) throws RemoteException {\n\n\t\ttry {\n\t\t\tIChatServer chatStub;\n\t\t\t// make a new chatroom with supplied name\n\t\t\tIChatroom newRoom = new Chatroom(name);\n\t\t\tview.append(\"Make new ChatRoom: \" + newRoom.getName() + \"\\n\");\n\t\t\t// make a new chatserver stub for user in the newchatroom\n\t\t\tIChatServer newChatServer = new ChatServer(user, newRoom);\n\t\t\tview.append(\"Make new ChatServer: <User:\" + newChatServer.getUser().getName() + \", ChatServer: \"\n\t\t\t\t\t+ newChatServer.getChatroom().getName() + \">\\n\");\n\t\t\t//get a chatstub for new chatserver \n\t\t\tchatStub = (IChatServer) UnicastRemoteObject.exportObject(newChatServer, IChatServer.BOUND_PORT);\n\t\t\tregistry.rebind(IChatServer.BOUND_NAME + newRoom.hashCode(), chatStub);\n\t\t\tview.append(\"Make new ChatServer Stub for chatserver.\\n\");\n\t\t\t//add chatstub to newRoom\n\t\t\tnewRoom.addChatServer(chatStub);\n\t\t\tview.append(\"Add new ChatServer Stub to newRoom.\\n\");\n\t\t\t//add newchatroom to the user chatroom lists\n\t\t\tuser.addRoom(newRoom);\n\t\t\tview.append(\"Add new chatroom <\" + newRoom.getName() + \"> to user <\" + user.getName() + \">\\n\");\n\t\t\t//add all chatservers in that room to hashset\n\t\t\tHashSet<IChatServer> proxy = new HashSet<IChatServer>();\n\t\t\tfor (IChatServer item : newChatServer.getChatroom().getChatServers()) {\n\t\t\t\tIChatServer proxyChatServer = new ProxyIChatServer(item);\n\t\t\t\tproxy.add(proxyChatServer);\n\t\t\t}\n\t\t\tIMain2MiniAdpt miniMVCAdpt = view.makeMini(newChatServer, proxy);\n\t\t\tminiMVCAdpts.put(newRoom, miniMVCAdpt);\n\t\t\tcountRoom++;\n\t\t} catch (Exception e) {\n\t\t\tview.append(\"Error creating chatroom!\");\n\t\t}\n\n\t}",
"private void fillWeek(Boolean canRepeatPoint) {\n Map<Long, List<Long>> workerPointMap = new LinkedHashMap<>();\n for (DayDTO day : week.getDays()) {\n // Generamos una lista con los trabajadores que ya han sido ocupados para este dia.\n List<Long> busyWorkersToday = checkBusyBreaks(day);\n for (TouristPointDTO touristPoint : touristPoints) {\n // Comprobamos que no existen turnos para este dia en este punto establecido ya.\n if (checkPointNotAssignedDay(day, touristPoint)) {\n // Comprobamos que existena algun trabajador con horas disponibles del equipo que necesitamos.\n if (haveAvailableHours(touristPoint)) {\n Iterator<Map.Entry<TouristInformerDTO, Double>> iterator = availableWorkersHours.entrySet().iterator();\n Map.Entry<TouristInformerDTO, Double> entry = iterator.next();\n // Si el trabajador no es correcto, busca el siguiente trabajador (si hay mas).\n while (iterator.hasNext()\n && !isCorrectWorker(workerPointMap, busyWorkersToday, touristPoint, entry, day,\n canRepeatPoint)) {\n entry = iterator.next();\n }\n // Si el trabajador es correcto lo asocia al punto ese dia.\n if (isCorrectWorker(workerPointMap, busyWorkersToday, touristPoint, entry, day,\n canRepeatPoint)) {\n associateShift(day, touristPoint, entry.getKey(), workerPointMap);\n // Actualizamos la lista de trabajadores ocupados para hoy\n busyWorkersToday.add(entry.getKey().getId());\n // Actualizamos las horas disponibles de esta semana para el trabajador\n entry.setValue(entry.getValue() - touristPoint.getTime());\n } else {\n errorPoints.add(new TouristPointDayProblemDTO(touristPoint, day));\n }\n } else {\n errorPoints.add(new TouristPointDayProblemDTO(touristPoint, day));\n }\n }\n }\n orderByAvailableHours();\n }\n }",
"public Reservation requestRoom(String guestName){\n\t\tfor (int i = 0; i<rooms.length; i++){\n\t\tif (rooms[i] == null){\n\t\t//then create a reservation for an empty room for the specified guest\n\t\t//and return the new Reservation;\n\t\t\trooms[i] = new Reservation(guestName, i);\n\t\t\treturn rooms[i];\n\t\t}\n\t\t}\n\t\t//Otherwise, add the guest into the end of waitList and return null\n\t\twaitList.add(guestName);\n\t\treturn null;\n\t}",
"@Override\n\tpublic boolean bookRoom(String month, int day, String type, int lengthOfStay) {\n\t\treturn false;\n\t}",
"public void doBehaviour( Object sessionContext ) {\n \n // The sessionContext is here a PlayerImpl.\n PlayerImpl player = (PlayerImpl) sessionContext;\n WotlasLocation location = player.getLocation();\n\n // 0 - We check the length of the chat room name\n if( name.length() > ChatRoom.MAXIMUM_NAME_SIZE )\n name = name.substring(0,ChatRoom.MAXIMUM_NAME_SIZE-1);\n\n // 1 - We get the message router\n MessageRouter mRouter = player.getMessageRouter();\n\n if( mRouter==null ) {\n Debug.signal( Debug.ERROR, this, \"No Message Router !\" );\n player.sendMessage( new WarningMessage(\"Error #ChCreMsgRtr while performing creation !\\nPlease report the bug !\") );\n return; // rare internal error occured !\n }\n\n // 2 - Do we have to delete the previous chatroom ?\n if( !player.getCurrentChatPrimaryKey().equals(ChatRoom.DEFAULT_CHAT) ) {\n // The following message behaviour does this job...\n RemPlayerFromChatRoomMsgBehaviour remPlayerFromChat =\n new RemPlayerFromChatRoomMsgBehaviour( player.getPrimaryKey(),\n player.getCurrentChatPrimaryKey() );\n\n try{\n remPlayerFromChat.doBehaviour( player );\n }catch( Exception e ) {\n Debug.signal( Debug.ERROR, this, e );\n player.setCurrentChatPrimaryKey(ChatRoom.DEFAULT_CHAT);\n }\n }\n\n // 3 - We try to create the new chatroom\n ChatRoom chatRoom = new ChatRoom();\n chatRoom.setPrimaryKey( ChatRoom.getNewChatPrimaryKey() );\n chatRoom.setName(name);\n chatRoom.setCreatorPrimaryKey(creatorPrimaryKey);\n chatRoom.addPlayer(player);\n\n synchronized( mRouter.getPlayers() ) {\n ChatList chatList = player.getChatList();\n \n if(chatList==null) {\n \tchatList = (ChatList) new ChatListImpl();\n \t\n // We set the chatList to all the players in the chat room...\n \tIterator it = mRouter.getPlayers().values().iterator();\n \n \twhile( it.hasNext() ) {\n \t PlayerImpl p = (PlayerImpl) it.next();\n \t p.setChatList( chatList );\n \t}\n }\n\n if( chatList.getNumberOfChatRooms() > ChatRoom.MAXIMUM_CHATROOMS_PER_ROOM \n && !isBotChatRoom )\n return; // can't add ChatRoom : too many already !\n\n chatList.addChatRoom( chatRoom );\n }\n\n player.setCurrentChatPrimaryKey( chatRoom.getPrimaryKey() );\n player.setIsChatMember(true);\n\n // 4 - We advertise the newly created chatroom\n // We send the information to all players of the same room or town or world\n mRouter.sendMessage( new ChatRoomCreatedMessage( chatRoom.getPrimaryKey(),\n name, creatorPrimaryKey ) );\n }",
"public void bookRoom(int hotelId, String roomNumber, int people){\n\n\n\n }",
"private void goRoom(Command command) \n {\n if(!command.hasSecondWord()) {\n // if there is no second word, we don't know where to go...\n System.out.println(\"Go where?\");\n return;\n }\n\n String direction = command.getSecondWord();\n\n // Try to leave current room.\n Room nextRoom = currentRoom.getExit(direction);\n \n if (nextRoom == null) {\n System.out.println(\"That way is blocked!\");\n }\n else {\n lastRoom = currentRoom;\n multiLastRooms.push (lastRoom);\n currentRoom = nextRoom;\n timer = timer + 1;\n System.out.println(currentRoom.getLongDescription());\n }\n }",
"public void allBookings() {\n\t\t\tint i = 0;\r\n\t\t\tint k = 0;\r\n\t\t\tint j = 0;\r\n\t\t\tint roomNum; //Room number\r\n\t\t\tint buffNum; //buff room number\r\n\t\t\tint index = 0; //saves the index of the date stored in the arraylist dateArray\r\n\t\t\tBooking buff; //Booking buffer to use\r\n\t\t\tRooms roomCheck;\r\n\t\t\tArrayList<LocalDate> dateArray = new ArrayList<LocalDate>(); //Saves the booking dates of a room\r\n\t\t\tArrayList<Integer> nights = new ArrayList<Integer>(); //Saves the number of nights a room is booked for\r\n\t\t\t\r\n\t\t\twhile(i < RoomDetails.size()) { //Looping Room Number-wise\r\n\t\t\t\troomCheck = RoomDetails.get(i);\r\n\t\t\t\troomNum = roomCheck.getRoomNum();\r\n\t\t\t\tSystem.out.print(this.Name + \" \" + roomNum);\r\n\t\t\t\twhile(k < Bookings.size()) { //across all bookings\r\n\t\t\t\t\tbuff = Bookings.get(k);\r\n\t\t\t\t\twhile(j < buff.getNumOfRoom()) { //check each booked room\r\n\t\t\t\t\t\tbuffNum = buff.getRoomNumber(j);\r\n\t\t\t\t\t\tif(buffNum == roomNum) { //If a booking is found for a specific room (roomNum)\r\n\t\t\t\t\t\t\tdateArray.add(buff.getStartDate()); //add the date to the dateArray\r\n\t\t\t\t\t\t\tCollections.sort(dateArray); //sort the dateArray\r\n\t\t\t\t\t\t\tindex = dateArray.indexOf(buff.getStartDate()); //get the index of the newly add date\r\n\t\t\t\t\t\t\tnights.add(index, buff.getDays()); //add the number of nights to the same index as the date\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t\tj++;\r\n\t\t\t\t\t}\r\n\t\t\t\t\tk++;\r\n\t\t\t\t\tj=0;\r\n\t\t\t\t}\r\n\t\t\t\ti++;\r\n\t\t\t\tprintOccupancy(dateArray, nights); //print the occupancy of the room\r\n\t\t\t\tk=0;\r\n\t\t\t\tdateArray.clear(); //cleared to be used again\r\n\t\t\t\tnights.clear(); //cleared to be used again\r\n\t\t\t}\r\n\t\t}",
"public void talkToCharacter(Room room)//Made by Lexi\n {\n if (currentRoom.getTitle().equals(\"outside\")) {\n System.out.println(\"All you need to do is unlock the door...\");\n System.out.println(\"Hint: use INSPECT to examine an item in detail.\");\n if (player.inventoryContains(key))\n {\n kitchen.setLocked(false);\n System.out.println(\"The door makes a loud click.\");\n }\n }\n \n \n else if (currentRoom.getTitle().equals(\"kitchen\")) {\n System.out.println(\"In order to move on to the next room, you must first find an item which can be found by solving this riddle: \");\n System.out.println(\"A box without hinges, key, or lid, yet golden treasure inside is hid.\");\n System.out.println(\"The answer is an item in this room that will help you escape and move on to the next room.\");\n if (player.inventoryContains(egg))\n {\n poolRoom.setLocked(false);\n System.out.println(\"The door makes a loud click.\");\n }\n }\n else if (currentRoom.getTitle().equals(\"pool room\")) {\n System.out.println(\"In order to escape this room you must solve this next riddle: \");\n System.out.println(\"Wash me and I am not clean. Don't wash me and then I'm clean. What I Am?\"); //water\n System.out.println(\"The answer to the riddle is where you'll find the object needed to escape this room... \");\n if (player.inventoryContains(snorkel))\n {\n library.setLocked(false);\n System.out.println(\"The door makes a loud click.\");\n }\n }\n else if (currentRoom.getTitle().equals(\"library\")) {\n System.out.println(\"In order to escape this room you must solve this next riddle: \");\n System.out.println(\"The objects, or people, have been removed from their previous localities through the power of a naturally moving phenomenon.\");\n System.out.println(\"Once you have figured out what item belongs to the answer of this riddle you will have escaped the building!\");\n if (player.inventoryContains(blueBook))\n {\n \n exitRoom.setLocked(false);\n System.out.println(\"The door makes a loud click.\");\n }\n }\n else {\n System.out.println(\"There is nobody here, so you talk to yourself...\");\n }\n }",
"private void twoDateOccupancyQuery(String startDate, String endDate){\n List<String> emptyRooms = findEmptyRoomsInRange(startDate, endDate);\n List<String> fullyOccupiedRooms = findOccupiedRoomsInRange(startDate, endDate, emptyRooms);\n List<String> partiallyOccupiedRooms = \n (generateListOfAllRoomIDS().removeAll(emptyRooms)).removeAll(fullyOccupiedRooms);\n\n occupancyColumns = new Vector<String>();\n occupancyData = new Vector<Vector<String>>();\n occupancyColumns.addElement(\"RoomId\");\n occupancyColumns.addElement(\"Occupancy Status\");\n\n for(String room: emptyRooms) {\n Vector<String> row = new Vector<String>();\n row.addElement(room);\n row.addElement(\"Empty\");\n occupancyData.addElement(row);\n }\n for(String room: fullyOccupiedRooms) {\n Vector<String> row = new Vector<String>();\n row.addElement(room);\n row.addElement(\"Fully Occupied\");\n occupancyData.addElement(row);\n }\n for(String room: partiallyOccupiedRooms) {\n Vector<String> row = new Vector<String>();\n row.addElement(room);\n row.addElement(\"Partially Occupied\");\n occupancyData.addElement(row);\n }\n return;\n}",
"public void create2(){\n\t\t//creating board to keep track of player postion with 1 or 0. 0 if not there 1 if they are there\n\t\tfor(int i = 0; i <this.position.length; i++){\n\t\t\tfor(int p = 0; p < this.position.length; p++){\n\t\t\t\tthis.position[i][p] = 0;//filling with zero\n\t\t\t}\n\t\t}//end of position making board\n\n\n\t\t//creating door in the rooms\n\t\tfor(int i = 0; i <this.Door.length; i++){\n\t\t\tfor(int p = 0; p < this.Door.length; p++){\n\t\t\t\tthis.Door[i][p] = 0;//filling with zero\n\t\t\t}\n\t\t}//end of Door making board\n\t\tthis.Door[1][1] = 1;\n\n\t\t//creating stairs to transport to room3\n\t\tfor(int i = 0; i <this.Stairs.length; i++){\n\t\t\tfor(int p = 0; p < this.Stairs.length; p++){\n\t\t\t\tthis.Stairs[i][p] = 0;//filling with zero\n\t\t\t}\n\t\t}//end of Door making board\n\t\tthis.Stairs[18][18] = 1;\n\n\t\t//creating board to keep track of ari\n\t\tfor(int i = 0; i <this.Ari.length; i++){\n\t\t\tfor(int p = 0; p < this.Ari.length; p++){\n\t\t\t\tthis.Ari[i][p] = 0;//filling with zero\n\t\t\t}\n\t\t}\n\t\tthis.Ari[7][11] = 1;//putts ari there\n\n\t\t//makes board that tells if item is there\n\t\tfor(int i = 0; i <this.Items.length; i++){\n\t\t\tfor(int p = 0; p < this.Items.length; p++){\n\t\t\t\tthis.Items[i][p] = null;//filling with null\n\t\t\t}\n\t\t}//end of filling board that has items\n\n\t\t//makes border of room\n\t\tfor(int i = 0; i < this.area.length; i++){\n\t\t\tfor(int p = 0; p<this.area.length; p++){\n\t\t\t\tif(i==0){\n\t\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t\t}\n\t\t\t\telse if (p==0 || p==19){\n\t\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t\t}\n\t\t\t\telse if(i==19){\n\t\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t\t}\n\t\t\t\telse{\n\t\t\t\t\tthis.area[i][p] = \" \";\n\t\t\t\t}\n\t\t\t}//end of innner for\n\t\t}//end of outter for\n\t\tfor(int i = 3; i< 4 ; i++){\n\t\t\tfor(int p = 1; p < 18; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 6; i< 7 ; i++){\n\t\t\tfor(int p = 19; p > 1; p--){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 9; i< 10 ; i++){\n\t\t\tfor(int p = 1; p < 18; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 12; i< 13 ; i++){\n\t\t\tfor(int p = 19; p > 1; p--){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 15; i< 16 ; i++){\n\t\t\tfor(int p = 1; p < 18; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\n\t\t\tSystem.out.println(\" \");\n\t\t}//end of for that creates walls\n\n\t\t//for loop that distributes items\n\t\tint y = 0;\n\t\tint x = 0;\n\t\tfor(int i = 0;i<10;i++){\n\t\t\tItem thing = ItemGenerator.generate();//making an item\n\t\t\tboolean good = false;\n\t\t\twhile(!good){//makes coordates until there is nothing in the way\n\t\t\t\ty = fate.nextInt(20);//getting coordiantaes\n\t\t\t\tx = fate.nextInt(20);\n\t\t\t\tif(this.Items[y][x]==null && this.area[y][x] != \"[ ]\"){\n\t\t\t\t\tgood = true;\n\t\t\t\t}//end of if\n\t\t\t\telse{\n\t\t\t\t\tgood = false;\n\t\t\t\t}\n\t\t\t}//end of while\n\t\t\tItems[y][x] = thing;\n\t\t}//end of for that distributes items on board\n\n\t}",
"private static void connectRooms(int[][] board, Array<Room> rooms, float[] filled, Random random) {\n // no need to connect rooms if there's less than 2 rooms\n if (rooms.size < 2)\n return;\n\n // for warshall algorithm\n // set the connection matrices\n boolean[][] roomConnections = new boolean[rooms.size][rooms.size];\n boolean[][] closure = new boolean[rooms.size][rooms.size];\n float[][] distanceMatrix = new float[rooms.size][rooms.size];\n int[][][][] closestMatrix = new int[rooms.size][rooms.size][2][2];\n\n for (int i = 0; i < rooms.size; i++) {\n Arrays.fill(distanceMatrix[i], Integer.MAX_VALUE);\n }\n\n // go through all rooms to find which ones are closest\n for (int a = 0; a < rooms.size; a++) {\n Room roomA = rooms.get(a);\n for (int b = 0; b < rooms.size; b++) {\n if (a == b)\n continue;\n\n Room roomB = rooms.get(b);\n\n // go around the border of each room to find the smallest\n // distance\n int[] cellA = new int[2];\n int[] cellB = new int[2];\n int[][] closestCells = { new int[2], new int[2] };\n\n for (int aX = roomA.left(); aX <= roomA.right(); aX++) {\n for (int aY = roomA.bottom(); aY <= roomA.top(); aY++) {\n\n cellA[X] = aX;\n cellA[Y] = aY;\n for (int bX = roomB.left(); bX <= roomB.right(); bX++) {\n for (int bY = roomB.bottom(); bY <= roomB.top(); bY++) {\n cellB[X] = bX;\n cellB[Y] = bY;\n\n // find the smallest distance between any cell\n // relation with CellA\n float distance = Vector2.dst(cellA[X], cellA[Y], cellB[X], cellB[Y]);\n if (distance < distanceMatrix[a][b] || distance == distanceMatrix[a][b]\n && random.nextBoolean()) {\n distanceMatrix[a][b] = distance;\n\n // make sure to mark which cells it is that\n // are the closest\n closestCells[0] = cellA;\n closestCells[1] = cellB;\n }\n }\n }\n }\n }\n // persist the relationship\n closestMatrix[a][b] = closestCells;\n }\n }\n\n // now go through the generated list of closest cells and connect the\n // rooms that have the shortest distances\n for (int a = 0; a < rooms.size; a++) {\n // find true closest room relative to roomA\n float min = Float.MAX_VALUE;\n int closest = 0;\n for (int b = 0; b < rooms.size; b++) {\n if (a == b)\n continue;\n\n float dist = distanceMatrix[a][b];\n if (dist < min) {\n min = dist;\n closest = b;\n }\n }\n // get the connecting cells\n int[] from = closestMatrix[a][closest][0];\n int[] to = closestMatrix[a][closest][1];\n\n // create the tunnel to that closest room\n if (!roomConnections[a][closest] && makeHallway(board, from, to, filled, random)) {\n // flag the rooms as connected both ways\n roomConnections[a][closest] = true;\n roomConnections[closest][a] = true;\n }\n }\n\n // even though closest rooms may have been connected, we still need to\n // make sure all rooms are connected\n // in a singular weighted path\n\n for (int conA = 0; conA != -1;) {\n int conB;\n\n // make sure the transitive closure is marked between already\n // connected rooms\n for (int a = 0; a < rooms.size; a++)\n for (int b = 0; b < rooms.size; b++)\n closure[a][b] = roomConnections[a][b];\n\n // we do this every loop to make sure any new changes in connection\n // from the previous loop\n // are carried over to the rest of the graph\n for (int a = 0; a < rooms.size; a++) {\n for (int b = 0; b < rooms.size; b++) {\n if (closure[a][b] && a != b) {\n // carry connections through (transitively)\n for (int c = 0; c < rooms.size; c++) {\n if (closure[b][c]) {\n closure[a][c] = true;\n closure[c][a] = true;\n }\n }\n }\n }\n }\n\n // check if all rooms are connected\n conA = -1;\n for (int a = 0; a < rooms.size && conA == -1; a++) {\n for (int b = 0; b < rooms.size && conA == -1; b++) {\n // mark if a isn't connected to the graph at some point\n if (a != b && !closure[a][b]) {\n conA = a;\n }\n }\n }\n\n // if one wasn't connected, we need to fix it\n if (conA != -1) {\n // for now distance doesn't matter, so we just connect a random\n // one\n do {\n conB = random.nextInt(rooms.size);\n }\n while (conA == conB);\n\n int[] from = closestMatrix[conA][conB][0];\n int[] to = closestMatrix[conA][conB][1];\n\n makeHallway(board, from, to, filled, random);\n\n roomConnections[conA][conB] = true;\n roomConnections[conB][conA] = true;\n }\n }\n\n }",
"public void createMap (int nRooms, Player player) {\n\t\t// Flag representing if the room has been created successfully or not\n\t\tboolean failed = false;\n\t\t// Clear the room array to make a hole new map\n\t\trooms = new ArrayList<Room>();\n\t\t\n\t\t// Set all the positions to be a wall\n\t\tfor(int y = 0; y < SIZE_Y; y++) {\n\t\t\tfor(int x = 0; x < SIZE_X; x++) {\n\t\t\t\tthis.cell[y][x].setReference(\"WALL\"); \n\t\t\t}\n\t\t}\n\n\t\t// Creates rooms with the max number given\n\t\tfor(int i = 0; i < nRooms; i++) {\n\t\t\tfailed = false;\n\t\t\tRoom room = new Room();\n\t\t\troom.setSizeX(rand.nextInt(10) + 3);\n\t\t\troom.setSizeY(rand.nextInt(8) + 3);\n\t\t\troom.setCenterX(rand.nextInt(SIZE_X - room.getSizeX()) + 1);\n\t\t\troom.setCenterY(rand.nextInt(SIZE_Y - room.getSizeY()) + 1);\n\t\t\t\n\t\t\tfor(Room roomTested : rooms) {\n\t\t\t\tif(room.intersects(roomTested)) {\n\t\t\t\t\tfailed = true;\n\t\t\t\t\tbreak;\n\t\t\t\t}\n\t\t\t}\n\t\t\t\n\t\t\tif(!failed) {\n\t\t\t\trooms.add(room);\n\t\t\t\tfor(int y = room.getCenterY(); y < room.getCenterY() + room.getSizeY() && y < SIZE_Y - 1; y++) {\n\t\t\t\t\tfor(int x = room.getCenterX(); x < room.getCenterX() + room.getSizeX() && x < SIZE_X - 1; x++) {\n\t\t\t\t\t\tthis.cell[y][x].setReference(\"FLOOR\"); \n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t// Makes the connections between rooms\n\t\tfor(int j = 0; j < rooms.size() - 1; j++ ) {\n\t\t\tthis.makeCorridor(rooms.get(j), rooms.get(j+1));\n\t\t}\n\t\t\n\t\tplayer.Spawn(rooms, this.getMap());\n\t}",
"public void boardPassenger(int floor){\n _passengersOnboard +=1;\n switch(floor){\n case 1: Floor.FIRST.makeDestinationRequest();\n Floor.FIRST.addQueuedPassenger();\n break;\n case 2: Floor.SECOND.makeDestinationRequest();\n Floor.SECOND.addQueuedPassenger();\n break;\n case 3: Floor.THIRD.makeDestinationRequest();\n Floor.THIRD.addQueuedPassenger();\n break;\n case 4: Floor.FOURTH.makeDestinationRequest();\n Floor.FOURTH.addQueuedPassenger();\n break;\n case 5: Floor.FIFTH.makeDestinationRequest();\n Floor.FIFTH.addQueuedPassenger();\n break;\n case 6: Floor.SIXTH.makeDestinationRequest();\n Floor.SIXTH.addQueuedPassenger();\n break;\n case 7: Floor.SEVENTH.makeDestinationRequest();\n Floor.SEVENTH.addQueuedPassenger();\n break;\n }\n }",
"private static void randomSim(PriorityQueue roomQueue, int totalTime, int roomNum) {\r\n\t\t//this will run a test with the user specified number of rooms\r\n\t\t//and random patient visits\r\n\t\t\r\n\t\tint currentTime = 0; //the current time in minutes - the number of minutes that have passed\r\n\t\tPriorityQueue arrivalQueue = new PriorityQueue<>(); // a queue to hold arriving patients\r\n\t\tPriorityQueue departureQueue = new PriorityQueue<>(); // a queue to hold departing patients\r\n\t\tArrayList<PatientVisit> treatedPatients = new ArrayList<PatientVisit>(); // a list to store the treated patients (will actually be deep copies of patients as their fields existed when they were moved to rooms)\t\t\r\n\t\tArrayList<ExamRoom> roomsInUse = new ArrayList<ExamRoom>(); // a list to hold rooms while they are in use\r\n\t\t\r\n\t\t//THE DATA WE WANT TO KEEP TRACK OF\r\n\t\tint totalPatients = 0;\r\n\t\tint highPriorityPatients = 0;\r\n\t\tint lowPriorityPatients = 0;\r\n\t\tdouble totalTreatmentTime = 0;\r\n\t\tdouble avgTreatmentTime;\r\n\t\tdouble highPriorityWaitTime = 0;\r\n\t\tdouble avgHighPriorityWaitTime;\r\n\t\tdouble lowPriorityWaitTime = 0;\r\n\t\tdouble avgLowPriorityWaitTime;\r\n\t\tdouble totalWaitTime = 0;\r\n\t\tdouble avgWaitTime;\r\n\t\t\r\n\t\twhile (currentTime < totalTime || departureQueue.size() > 0) { //until the time has elapsed AND all patients have finished treatment\r\n\t\t\t\r\n\t\t\tif (currentTime < totalTime) { // if the time specified by the user has not yet elapsed\r\n\t\t\t\tPatientVisit newPatient = PatientVisitGenerator.getNextRandomArrival(currentTime); //generate an arrival event\r\n\t\t\t\tarrivalQueue.insert(newPatient); //add that patient to the arrival queue\t\t\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\telse if (!arrivalQueue.isEmpty()) {\r\n\t\t\t\tarrivalQueue = new PriorityQueue<>(); // clear any future events when user specified time has elapsed\r\n\t\t\t}\r\n\t\t\t//PUT PATIENT IN ROOM IF POSSIBLE\r\n\t\t\t// if there is an available room AND there are waiting patients (who have already arrived)\r\n\t\t\twhile (!roomQueue.isEmpty() && !arrivalQueue.isEmpty() && ((PatientVisit) arrivalQueue.front()).getArrivalTime() <= currentTime) { \r\n\t\t\t\t\r\n\t\t\t\t//GRAB THE NEXT ROOM AND PATIENT IN THEIR RESPECTIVE QUEUES\r\n\t\t\t\t\r\n\t\t\t\tExamRoom room = (ExamRoom) roomQueue.remove(); // take the first room from the room list\r\n\t\t\t\tPatientVisit patient = (PatientVisit) arrivalQueue.remove(); // take the first patient from the patient list\r\n\t\t\t\t\r\n\t\t\t\t//MODIFY THE ROOM AND PATIENT AND CAPTURE SOME DATA\r\n\t\t\t\t//PATIENTS\r\n\t\t\t\tpatient.setWaitTime(currentTime - patient.getArrivalTime()); // set the time the patient waited\r\n\t\t\t\tpatient.setDepartureTime(currentTime + patient.getDuration()); // set the departure time of the patient equal to arrival time + duration of appointment\r\n\t\t\t\ttreatedPatients.add(patient.deepCopy()); // add a copy of this patient to a queue for treated patients to preserve its wait time and urgency (for data collection purposes)\r\n\t\t\t\tpatient.setUrgency(10); // set each patient to lowest priority once in treatment room (allows them to be compared based on departure time)\r\n\t\t\t\tpatient.setArrivalTime(0); // set each arrival time to 0 once in treatment room (allows them to be compared based on departure time)\r\n\t\t\t\tdepartureQueue.insert(patient); // add patient to departure queue to be sorted by departure time\r\n\t\t\t\t\r\n\t\t\t\t//ROOMS\r\n\t\t\t\troom.setInUseTime(room.getInUseTime() + patient.getDuration()); // add the duration of the patient's treatment to the in-use time of the room\r\n\t\t\t\troom.setPatientNum(room.getPatientNum() + 1); // increase the number of patients treated in the room by 1\r\n\t\t\t\troom.setDepartureTime(patient.getDepartureTime()); // set departure time of room to that of patient\r\n\t\t\t\troomsInUse.add(room); // put the rooms in a list for rooms in use\r\n\t\t\t\t\r\n\t\t\t\t//GENERAL DATA\r\n\t\t\t\ttotalPatients ++; //increment number of patients treated\t\t\t\t\r\n\t\t\t\ttotalTreatmentTime += patient.getDuration(); // add the patient's treatment time to the total\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\t//GO THROUGH ROOMS AND PATIENTS TO FIND THOSE WHICH ARE DONE\r\n\t\t\t//ROOMS\r\n\t\t\tfor (int i=0; i<roomsInUse.size(); i++) { // look through rooms currently in use\r\n\t\t\t\tExamRoom room = roomsInUse.get(i); // for each room\r\n\t\t\t\tif (room.getDepartureTime() <= currentTime) { // if the departure time is now or has passed\r\n\t\t\t\t\troomsInUse.remove(i); //remove that room from the list of in-use rooms\r\n\t\t\t\t\troomQueue.insert(room); // add it back to the room queue where it will be sorted according to its new in-use time\r\n\t\t\t\t\ti--; // go back one index as the list is now shorter\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\t//PATIENTS\t\t\r\n\t\t\twhile (!departureQueue.isEmpty() && ((PatientVisit) departureQueue.front()).getDepartureTime() <= currentTime) { // while the next patient to depart is ready to depart\r\n\t\t\t\tdepartureQueue.remove(); // remove that patient from the departure queue\r\n\t\t\t}\r\n\t\t\tcurrentTime += 1; // increment time 1 minute\r\n\t\t}\r\n\t\t\r\n\t\t//CALCULATE THE AVERAGE WAIT TIMES\r\n\t\tIterator<PatientVisit> treatedPatientsIter = treatedPatients.iterator(); //attach an iterator to the list of treated patients\r\n\t\twhile (treatedPatientsIter.hasNext()) {\r\n\t\t\tPatientVisit currentPatient = treatedPatientsIter.next(); // go through all treated patients\r\n\t\t\tif (currentPatient.getUrgency() >= 1 && currentPatient.getUrgency() <= 4) { // if the patient was high priority\r\n\t\t\t\thighPriorityPatients += 1; // add 1 to total of high priority patients\r\n\t\t\t\thighPriorityWaitTime += currentPatient.getWaitTime(); // add patient's wait time to high priority wait-time total\t\t\t\t\r\n\t\t\t}\r\n\t\t\telse if (currentPatient.getUrgency() >= 9) { //if patient was low priority\r\n\t\t\t\tlowPriorityPatients += 1; //add 1 to total of low priority patients\r\n\t\t\t\tlowPriorityWaitTime += currentPatient.getWaitTime(); // add patient's wait time to low priority wait-time total\t\r\n\t\t\t}\r\n\t\t\ttotalWaitTime += currentPatient.getWaitTime();\r\n\t\t}\r\n\t\tavgHighPriorityWaitTime = highPriorityWaitTime/highPriorityPatients; // calculate the average for high priority patients\r\n\t\tavgLowPriorityWaitTime = lowPriorityWaitTime/lowPriorityPatients; // calculate the average for low priority patients\r\n\t\tavgWaitTime = totalWaitTime/totalPatients;\r\n\t\tavgTreatmentTime = totalTreatmentTime/totalPatients; // calculate overall average treatment time\t\r\n\t\t\r\n\t\t// PRINT THE DATA FOR THE USER\r\n\t\tSystem.out.println();\r\n\t\t//System.out.println(\"total treatment time: \" + totalTreatmentTime);\r\n\t\tSystem.out.println(\"There are \" + roomNum + \" rooms in the system.\");\r\n\t\tSystem.out.println(\"The simulation ran for \" + currentTime/60 + \" hours and \" + currentTime%60 + \" minutes.\");\r\n\t\tSystem.out.println(totalPatients + \" patients were treated in total.\");\r\n\t\tSystem.out.printf(\"The average wait time for treatment was: \" + \"%.2f\" + \" minutes.\\n\", avgWaitTime);\r\n\t\tif (highPriorityPatients > 0) {\r\n\t\t\tSystem.out.printf(\"There were \" + highPriorityPatients + \" patients with urgency 1 to 4 and their average wait time was: \" + \"%.2f\" + \" minutes.\\n\", avgHighPriorityWaitTime);\r\n\t\t}\r\n\t\telse {\r\n\t\t\tSystem.out.printf(\"There were \" + highPriorityPatients + \" patients with urgency 1 to 4 and their average wait time cannot be calculated.\");\r\n\t\t}\r\n\t\tif (lowPriorityPatients > 0) {\r\n\t\t\tSystem.out.printf(\"There were \" + lowPriorityPatients + \" patients with urgency 9 to 10 and their average wait time was: \" + \"%.2f\" + \" minutes.\\n\", avgLowPriorityWaitTime);\r\n\t\t}\r\n\t\telse {\r\n\t\t\tSystem.out.printf(\"There were \" + lowPriorityPatients + \" patients with urgency 9 to 10 and their average wait cannot be calculated.\\n\");\r\n\t\t}\r\n\t\tSystem.out.printf(\"The average duration of treatment was: \" + \"%.2f\" + \" minutes.\\n\", avgTreatmentTime);\r\n\t\tfor (int i=0; i<roomNum; i++) {\r\n\t\t\tExamRoom room = (ExamRoom) roomQueue.remove();\r\n\t\t\tint patientNum = room.getPatientNum();\r\n\t\t\tdouble busyTime = room.getInUseTime();\r\n\t\t\tSystem.out.println(patientNum + \" patients were treated in room \" + room.getIdent() + \".\");\r\n\t\t\tSystem.out.printf(\"Room \" + room.getIdent() + \" was busy \" + \"%.2f\" + \" percent of the time.\\n\", (busyTime/currentTime)*100);\r\n\t\t}\r\n\t\tSystem.out.println();\t\r\n\t\t\r\n\t}",
"public void seekWalls() {\n\t\t for (int j=0; j<visited[0].length; j++){\n\t\t\tfor (int i=visited.length-1; i>=0; i--) {\t\t\t\n\t\t\t\tif (i!=0 && j!= visited[0].length-1) {//general position\n\t\t\t\t\tif (map.get(visited[i][j]) + map.get(visited[i-1][j]) == maxComb && !isFree(i,j,2)) {\n\t\t\t\t\t\twallRow = i+1;\n\t\t\t\t\t\twallCol = j+1;\n\t\t\t\t\t\twallSide = 'N';\n\t\t\t\t\t\treturn;//not break!!!!! return to exit !\n\t\t\t\t\t}\n\n\t\t\t\t\tif (map.get(visited[i][j]) + map.get(visited[i][j+1]) == maxComb && !isFree(i,j,4)) {\n\t\t\t\t\t\twallRow = i+1;\n\t\t\t\t\t\twallCol = j+1;\n\t\t\t\t\t\twallSide = 'E';\t\n\t\t\t\t\t\treturn;\t\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\t\n\t\t\t\telse if (i==0 && j!= visited[0].length-1) {\n\t\t\t\t\tif (map.get(visited[i][j]) + map.get(visited[i][j+1]) == maxComb && !isFree(i,j,4)) {\n\t\t\t\t\t\twallRow = i+1;\n\t\t\t\t\t\twallCol = j+1;\n\t\t\t\t\t\twallSide = 'E';\t\n\t\t\t\t\t\treturn;\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t\telse if (i!=0 && j== visited[0].length-1) {\n\t\t\t\t\tif (map.get(visited[i][j]) + map.get(visited[i-1][j]) == maxComb && !isFree(i,j,2)) {\n\t\t\t\t\t\twallRow = i+1;\n\t\t\t\t\t\twallCol = j+1;\n\t\t\t\t\t\twallSide = 'N';\n\t\t\t\t\t\treturn;\n\t\t\t\t\t}\n\n\t\t\t\t}\n\t\t\t\telse {//if (i==0 && j== visited[0].length-1) {\n\t\t\t\t\t//no solution\n\t\t\t\t\treturn;\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t}",
"public void joinChatRoom(IChatroom room) {\n\t\tview.append(\"Join ChatRoom\" + room.getName());\n\t\tcountRoom++;\n\t\tIChatroom chatroom = new Chatroom(\"Chatroom\" + countRoom);\n\t\tIChatServer chatServer = new ChatServer(user, chatroom);\n\t\ttry {\n\t\t\tview.append(\"Start joining..\");\n\t\t\tIChatServer chatStub = (IChatServer) UnicastRemoteObject.exportObject(chatServer,\n\t\t\t\t\tIChatServer.BOUND_PORT + countRoom);\n\t\t\tfor (IChatServer members : room.getChatServers()) {\n\t\t\t\tchatroom.addChatServer(members);\n\t\t\t\tmembers.joinChatroom(chatStub);\n\t\t\t}\n\t\t\tchatroom.addChatServer(chatStub);\n\t\t\tuser.addRoom(chatroom);\n\t\t\tregistry.rebind(IChatServer.BOUND_NAME + chatroom.hashCode(), chatStub);\n\t\t\tHashSet<IChatServer> proxyChatServers = new HashSet<IChatServer>();\n\t\t\tfor (IChatServer stub : chatroom.getChatServers()) {\n\t\t\t\tProxyIChatServer proxyChatServer = new ProxyIChatServer(stub);\n\t\t\t\tproxyChatServers.add(proxyChatServer);\n\t\t\t}\n\t\t\tIMain2MiniAdpt miniMVCAdpt = view.makeMini(chatServer, proxyChatServers);\n\t\t\tminiMVCAdpts.put(chatroom, miniMVCAdpt);\n\t\t\tcountRoom++;\n\t\t\tview.append(\"Success!\");\n\t\t\t//\t\t\tminiMVCAdpt.refresh();\n\t\t} catch (Exception e) {\n\t\t\tview.append(\"Fail to join the room!\");\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"private Rooms getRooms(boolean sociallyDistanced, LocalDateTime time, LocalDateTime endTime, Modules module) {\n // Get viable rooms\n Session s = HibernateUtil.getSessionFactory().openSession();\n CriteriaBuilder cb = s.getCriteriaBuilder();\n CriteriaQuery<Rooms> cq = cb.createQuery(Rooms.class);\n Root<Rooms> root = cq.from(Rooms.class);\n ParameterExpression<Integer> spacesNeeded = cb.parameter(Integer.class);\n if (sociallyDistanced) {\n cq.select(root).where(cb.greaterThanOrEqualTo(root.get(\"socialDistancingCapacity\"), spacesNeeded));\n } else {\n cq.select(root).where(cb.greaterThanOrEqualTo(root.get(\"maxCapacity\"), spacesNeeded));\n }\n\n root.join(\"bookings\", JoinType.LEFT);\n root.fetch(\"bookings\", JoinType.LEFT);\n\n Query<Rooms> query = s.createQuery(cq);\n query.setParameter(spacesNeeded, module.getStudents().size());\n\n List<Rooms> results = query.getResultList();\n\n s.close();\n\n\n Map<String, Rooms> possibleRooms = new HashMap<>();\n\n for (Rooms room : results) {\n if (room.isAvailable(time, endTime) && !possibleRooms.containsKey(room.getRoomID())) {\n System.out.println(\" \" + room.getRoomID() + \" of type \" + room.getType() + \" is available and meets your capacity needs.\");\n possibleRooms.put(room.getRoomID(), room);\n }\n }\n\n System.out.println(\"Please enter the room ID you would like to book.\");\n String roomKey = sc.next();\n while (!possibleRooms.containsKey(roomKey)) {\n System.out.println(\"That is not a correct ID for a room. Look at the list above.)\");\n roomKey = sc.next();\n }\n sc.nextLine();\n\n return possibleRooms.get(roomKey);\n }",
"protected static String listSchedule(ArrayList<Room> roomList) {\n String roomName = getRoomName();\n System.out.println(roomName + \" Schedule\");\n System.out.println(\"------------\");\n\n for (Meeting m : getRoomFromName(roomList, roomName).getMeetings()) {\n System.out.println(m.toString());\n }\n\n return \"\";\n }",
"static private void TalkTo() {\n if (BSChristiansen.getCurrentRoom() == currentRoom) {\n System.out.println(BSChristiansen.getDescription() + \", yet he still gives you good advice:\\n\");\n System.out.println(BSChristiansen.getDialog(0));\n System.out.println(\"\");\n woundedSurvivor();\n } else if (mysteriousCrab.getCurrentRoom() == currentRoom && inventory.getInventory().containsKey(\"Shroom\")) {\n System.out.println(mysteriousCrab.getDescription() + \"\\n\" + mysteriousCrab.getDialog(0));\n } else {\n System.out.println(\"There is nobody to communicate with in this Room\");\n }\n\n }",
"public void create(){\n\t\t//creating board to keep track of player postion with 1 or 0. 0 if not there 1 if they are there\n\t\tfor(int i = 0; i <this.position.length; i++){\n\t\t\tfor(int p = 0; p < this.position.length; p++){\n\t\t\t\tthis.position[i][p] = 0;//filling with zero\n\t\t\t}\n\t\t}//end of position making board\n\t\tthis.position[1][1] = 1;//putting player in this position\n\n\t\t//creating door in the rooms\n\t\tfor(int i = 0; i <this.Door.length; i++){\n\t\t\tfor(int p = 0; p < this.Door.length; p++){\n\t\t\t\tthis.Door[i][p] = 0;//filling with zero\n\t\t\t}\n\t\t}//end of Door making board\n\t\tthis.Door[9][13] = 1;//puts the door here \n\n\t\t//makes board that tells if item is there\n\t\tfor(int i = 0; i <this.Items.length; i++){\n\t\t\tfor(int p = 0; p < this.Items.length; p++){\n\t\t\t\tthis.Items[i][p] = null;//filling with null\n\t\t\t}\n\t\t}//end of filling board that has items\n\n\t\t//makes border of room\n\t\tfor(int i = 0; i < this.area.length; i++){\n\t\t\tfor(int p = 0; p<this.area.length; p++){\n\t\t\t\tif(i==0){\n\t\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t\t}\n\t\t\t\telse if (p==0 || p==19){\n\t\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t\t}\n\t\t\t\telse if(i==19){\n\t\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t\t}\n\t\t\t\telse{\n\t\t\t\t\tthis.area[i][p] = \" \";\n\t\t\t\t}\n\t\t\t}//end of innner for\n\t\t}//end of outter for\n\t\tfor(int i = 4; i< 5 ; i++){\n\t\t\tfor(int p = 4; p < 7; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 4; i< 5 ; i++){\n\t\t\tfor(int p = 4; p < 7; p++){\n\t\t\t\tthis.area[p][i] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 7; i< 8 ; i++){\n\t\t\tfor(int p = 2; p < 7; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 17; i< 18 ; i++){\n\t\t\tfor(int p = 13; p < 17; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\t\n\t\t}\n\t\tfor(int i = 14; i< 15 ; i++){\n\t\t\tfor(int p = 13; p < 17; p++){\n\t\t\t\tthis.area[p][i] = \"[ ]\";\n\t\t\t}\t\n\t\t}\t\n\t\tfor(int i = 11; i< 12 ; i++){\n\t\t\tfor(int p = 10; p < 17; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 15; i< 16 ; i++){\n\t\t\tfor(int p = 3; p < 6; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 16; i< 17 ; i++){\n\t\t\tfor(int p = 6; p < 13; p++){\n\t\t\t\tthis.area[p][i] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 12; i< 13 ; i++){\n\t\t\tfor(int p = 5; p < 10; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t\tSystem.out.println(\" \");\n\t\t}//end of for that creates walls\t\n\n\t\t//for loop that distributes items\n\t\tint y = 0;\n\t\tint x = 0;\n\t\tfor(int i = 0;i<10;i++){\n\t\t\tItem thing = ItemGenerator.generate();//making an item\n\t\t\tboolean good = false;\n\t\t\twhile(!good){//makes coordates until there is nothing in the way\n\t\t\t\ty = fate.nextInt(20);//getting coordiantaes \n\t\t\t\tx = fate.nextInt(20);\n\t\t\t\tif(this.Items[y][x]==null && this.area[y][x] != \"[ ]\"){\n\t\t\t\t\tgood = true;\n\t\t\t\t}//end of if\n\t\t\t\telse{ \n\t\t\t\t\tgood = false;\n\t\t\t\t}\n\t\t\t}//end of while\n\t\t\tItems[y][x] = thing;\n\t\t}//end of for that distributes items on board\n\n\t}",
"private CreateRoomRequest toCreateRoomRequest(OffsetDateTime validFrom, OffsetDateTime validUntil,\n Iterable<RoomParticipant> participants) {\n CreateRoomRequest createRoomRequest = new CreateRoomRequest();\n if (validFrom != null) {\n createRoomRequest.setValidFrom(validFrom);\n }\n\n if (validUntil != null) {\n createRoomRequest.setValidUntil(validUntil);\n }\n\n Map<String, ParticipantProperties> roomParticipants = new HashMap<>();\n\n if (participants != null) {\n roomParticipants = convertRoomParticipantsToMapForAddOrUpdate(participants);\n }\n\n if (participants != null) {\n createRoomRequest.setParticipants(roomParticipants);\n }\n\n return createRoomRequest;\n }",
"private static void SetRoomUnavailable(){\n \n boolean roomUnavailableLoop = true;\n \n //loop for setting room unavailable\n while (roomUnavailableLoop == true) {\n \n //if no rooms can be made unavailable, exit loop\n if (HotelRoom.roomList.isEmpty() || HotelRoom.AllRoomsOccupied() == true){\n System.out.println(\"There are no available rooms\");\n break;\n }\n \n //printing available rooms to the user\n System.out.println(\"Here is a list of all rooms:\");\n HotelRoom.DisplayAvailableRooms();\n System.out.println(\"--------------------------------------\");\n \n //try/catch for room number input\n try {\n System.out.print(\"Enter room number: \");\n \n //asking user for room number input\n int roomMod = RecInput.nextInt();\n \n //used to check if user input matches room\n boolean roomExists = false;\n \n //looping list of room and checking if input matches valid roomnumber\n for (int i = 0; i < HotelRoom.roomList.size(); i++){\n if (roomMod == HotelRoom.roomList.get(i).roomNumber && \n HotelRoom.roomList.get(i).occupied == false && \n HotelRoom.roomList.get(i).unavailable == false){\n //setting room as unavailable\n HotelRoom.roomList.get(i).unavailable = true;\n System.out.println(\"Room number \" + HotelRoom.roomList.get(i).roomNumber + \n \" has been made unavailable until further notice.\");\n //breaking loop and exiting\n roomUnavailableLoop = false;\n\n }\n\n }\n \n //checking if input is valid\n if (roomExists == false) {\n System.out.println(\"The room you entered is invalid\");\n System.out.println(\"-----------------------------\");\n }\n }\n catch (Exception InputMismatchException) {\n //handling if user input is not integer\n System.out.println(\"Please enter a number\");\n System.out.println(\"-----------------------------\");\n\n //Cleaning scanner\n RecInput.next();\n }\n }\n }",
"@Override\n\tpublic void onGetMatchedRoomsDone(MatchedRoomsEvent arg0) {\n\t\t\n\t}",
"public Room(int id, int roomNumber, int persons, int days){\n this.id = id;\n this.roomNumber = roomNumber;\n this.persons = persons;\n this.days = days;\n available = false; //default value, assignment not necessary\n }",
"static void goRoom(Command command) throws InterruptedException {\n if (currentRoom == airport) {\n lockRoom(command);\n }\n if (!command.hasSecondWord()) {\n System.out.println(\"Go where?\");\n return;\n }\n\n String direction = command.getSecondWord();\n\n Room nextRoom = currentRoom.getExit(direction);\n player.setCurrentRoom(nextRoom);\n /* loop that when next room is equel to null it print a message that says \"there is no door\" \n but if nextRoom is not equel null set currentRoom to nextRoom and print the description of the new room*/\n if (nextRoom == null) {\n System.out.println(\"There is no path!\");\n } else {\n currentRoom = nextRoom;\n System.out.println(player.getCurrentRoom().getLongDescription());\n\n }\n\n forceDialog();\n }",
"public static String meeting(String s) {\n\n String[] fullName = s.split(\";\");\n String[] firstName = new String[fullName.length];\n String[] lastName = new String[fullName.length];\n\n for (int i = 0; i < fullName.length; i++) {\n String[] nameSplit = fullName[i].split(\":\");\n firstName[i] = nameSplit[0];\n lastName[i] = nameSplit[1];\n }\n\n for (int i = 1; i < lastName.length; i++) {\n for (int j = i; j > 0; j--) {\n int order = lastName[j].toLowerCase().compareTo(lastName[j - 1].toLowerCase());\n if (order < 0) {\n String temp = lastName[j-1];\n lastName[j-1] = lastName[j];\n lastName[j] = temp;\n\n temp = firstName[j-1];\n firstName[j-1] = firstName[j];\n firstName[j] = temp;\n }\n else if (order == 0) {\n if (firstName[j].toLowerCase().compareTo(firstName[j-1].toLowerCase()) < 0) {\n String temp = lastName[j-1];\n lastName[j-1] = lastName[j];\n lastName[j] = temp;\n\n temp = firstName[j-1];\n firstName[j-1] = firstName[j];\n firstName[j] = temp;\n }\n }\n else {\n break;\n }\n }\n }\n String outputString = \"\";\n for (int i = 0; i < lastName.length; i++) {\n outputString += \"(\" + lastName[i].toUpperCase() + \", \" + firstName[i].toUpperCase() + \")\";\n }\n return outputString;\n }",
"public static void main(String[] ar){\n Room living = new Room(\"Living\");\n Room kitchen = new Room(\"Kitchen\");\n Room bathroom = new Room(\"Bathroom\");\n Room garage = new Room(\"Garage\");\n \n Room bedroom1 = new Room(\"Bedroom1\");\n Room bedroom2 = new Room(\"Bedroom2\");\n Room bathroom1stf=new Room(\"Bathroom\");\n \n \n //Living\n living.addDevice(new Device(\"Aire acondicionado\", \"LG\", \"pm07sp\", true));\n living.addDevice(new Device(\"Luces\", \"Philips\", \"Hue\", true));\n //Kitchen\n kitchen.addDevice(new Device(\"luces\",\"Ahorradoras\",\"34234\", true));\n //Bathroom\n bathroom.addDevice(new Device(\"luce\",\"simple\",\"354676\", true));\n //Garage\n garage.addDevice(new Device(\"lightbulb\",\"the best\",\"X3000\",true));\n \n //Bedroom 1\n bedroom1.addDevice(new Device(\"Aire acondicionado\", \"Mabe\" , \"Mmt12cdbs3\", true));\n bedroom1.addDevice(new Device(\"Luces\",\"Philips\",\"EcoVantage\",true));\n \n //Bedroom 2\n bedroom2.addDevice(new Device(\"Aire acondicionado\", \"Hisense\" , \"AS-12CR5FVETD/1TR\", true));\n bedroom2.addDevice(new Device(\"Luces\",\"Ho Iluminacion\",\"A19 60W Claro\",true));\n \n //baño primer piso\n bathroom1stf.addDevice(new Device(\"Luces\",\"Alefco\",\"lw100\",true));\n \n \n \n Level groundFloor = new Level(\"Ground Floor\");\n Level firstFloor = new Level(\"First Floor\");\n \n \n groundFloor.addRoom(living);\n groundFloor.addRoom(kitchen);\n groundFloor.addRoom(bathroom);\n groundFloor.addRoom(garage);\n \n firstFloor.addRoom(bedroom1);\n firstFloor.addRoom(bedroom2);\n firstFloor.addRoom(bathroom1stf);\n \n\n House myhouse = new House(\"MyHome\");\n \n myhouse.addLevel(groundFloor);\n myhouse.addLevel(firstFloor);\n \n System.out.println(myhouse);\n \n \n /*\n room.addDevice(new Device(\"Reynaldo\", \"LG\", \"123456\", true));\n room.addDevice(new Device(\"Andrea\", \"Nokia\", \"Lumia-520\", true));\n room.addDevice(new Device(\"Karina\",\"Panasonic\",\"465464\", true));\n room.addDevice(new Device(\"Martin\", \"ZTE\", \"V7\",true));\n room.addDevice(new Device(\"Antonio\",\"Samsung\",\"J5\",true));\n room.addDevice(new Device(\"Roberto\",\"HP\",\"SpectreX360\",true));\n room.addDevice(new Device(\"Gabriel\",\"Linu\",\"Ilium_S106\",true));\n room.addDevice(new Device (\"Limberth\",\"LG\", \"lg-206\",true));\n room.addDevice(new Device(\"jesus\", \"hp\",\"2997\", true));\n room.addDevice(new Device(\"Rich\", \"Asus\",\"Zenfone_4_Max\",true));\n room.addDevice(new Device(\"Adrian\",\"Apple\",\"SE\",true));\n room.addDevice(new Device (\"Jonatan\",\"samsung\",\"J5\",true));\n room.addDevice(new Device(\"Jessica\", \"Huaweii\", \"P9LITE\", true));\n */\n \n \n \n \n \n }",
"@Test\n\tpublic void testAdjacencyRoomExit()\n\t{\n\t\t// TEST DOORWAY RIGHT \n\t\tSet<BoardCell> testList = board.getAdjList(18, 17);\n\t\tassertEquals(1, testList.size());\n\t\tassertTrue(testList.contains(board.getCellAt(18, 18)));\n\t\t// TEST DOORWAY LEFT \n\t\ttestList = board.getAdjList(4, 14);\n\t\tassertEquals(1, testList.size());\n\t\tassertTrue(testList.contains(board.getCellAt(4, 13)));\n\t\t//TEST DOORWAY DOWN\n\t\ttestList = board.getAdjList(5, 3);\n\t\tassertEquals(1, testList.size());\n\t\tassertTrue(testList.contains(board.getCellAt(6, 3)));\n\t\t//TEST DOORWAY UP\n\t\ttestList = board.getAdjList(18, 12);\n\t\tassertEquals(1, testList.size());\n\t\tassertTrue(testList.contains(board.getCellAt(17, 12)));\n\t}",
"private static void viewRooms() \n {\n String option, roomCode;\n\n displayMyRooms(\" \");\n\n Scanner input = new Scanner(System.in);\n\n System.out.print(\"Type (v)iew [room code] or \"\n + \"(r)eservations [room code], or (q)uit to exit: \");\n \n option = input.next().toLowerCase();\n \n while (!option.equals(\"q\"))\n {\n if (option.equals(\"v\") || option.equals(\"r\"))\n {\n System.out.print(\"Enter a room code: \");\n roomCode = \" '\" + input.next().toUpperCase() + \"'\";\n\n if(option.equals(\"v\"))\n displayDetailedRooms(roomCode);\n else\n displayDetailedReservations(\"WHERE ro.RoomId = \" + roomCode);\n }\n\n System.out.print(\"Type (v)iew [room code] or \"\n + \"(r)eservations [room code], or (q)uit to exit: \");\n \n option = input.next().toLowerCase();\n }\n \n }",
"private String goRoom(Command command)//refactored\n {\n if(!command.hasSecondWord()) {\n // if there is no second word, we don't know where to go...\n return \"Go where?\";\n }\n\n String direction = command.getSecondWord();\n\n // Try to leave current room.\n Room nextRoom = currentRoom.getExit(direction);//new\n \n String result = \"\";\n if (nextRoom == null) {\n result += \"There is no door!\";\n }\n else {\n currentRoom = nextRoom;\n result += currentRoom.getDescription()+\"\\n\";//refactored\n \n result += \"Exits: \" + currentRoom.getExitString()+\"\\n\";//taken from class Room \n \n return result;\n }\n result += \"\\n\";\n\n return result;\n }",
"private void generateDefaultTimeSlots() {\n\t\tLocalTime startTime = LocalTime.of(9, 0); // 9AM start time\n\t\tLocalTime endTime = LocalTime.of(19, 0); // 5PM end time\n\n\t\tfor (int i = 1; i <= 7; i++) {\n\t\t\tList<Timeslot> timeSlots = new ArrayList<>();\n\t\t\tLocalTime currentTime = startTime.plusMinutes(15);\n\t\t\twhile (currentTime.isBefore(endTime) && currentTime.isAfter(startTime)) {\n\t\t\t\tTimeslot newSlot = new Timeslot();\n\t\t\t\tnewSlot.setTime(currentTime);\n\t\t\t\tnewSlot = timeslotRepository.save(newSlot);\n\t\t\t\ttimeSlots.add(newSlot);\n\t\t\t\tcurrentTime = currentTime.plusHours(1); // new slot after one hour\n\t\t\t}\n\t\t\tDay newDay = new Day();\n\t\t\tnewDay.setTs(timeSlots);\n\t\t\tnewDay.setDayOfWeek(DayOfWeek.of(i));\n\t\t\tdayRepository.save(newDay);\n\t\t}\n\t}",
"public static SendResult checkRoomList(LinkedHashMap param) {\n\t\tSendResult sr=new SendResult(\"0\", \"\", \"\");\r\n\t\tif(param.containsKey(\"rlist\")) {\r\n\t\t\ttry {\r\n\t\t\t\tList<Room> powlist=(List<Room>) param.get(\"rlist\");\r\n\t\t\t\tif(powlist!=null && powlist.size()>0) {\r\n\t\t\t\t\tfor(Room pow : powlist) {\r\n\t\t\t\t\t\tif(pow==null) {\r\n\t\t\t\t\t\t\treturn new SendResult(\"100001\",\"参数错误\", \"\");\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t\tif(pow.getGatewaycode()==null||pow.getGatewaycode().equals(\"\")||pow.getGatewaycode().equals(\"null\")) {\r\n\t\t\t\t\t\t\tsr.setResultCode(\"-10001\");\r\n\t\t\t\t\t\t\tsr.setResultMsg(\"网关通讯ID不能为空\");\r\n\t\t\t\t\t\t\treturn sr;\r\n\t\t\t\t\t\t}else if(pow.getGatewaycode().length()!=10||pow.getGatewaycode().toUpperCase().matches(\".*[G-Z].*\")) {\r\n\t\t\t\t\t\t\tsr.setResultCode(\"-10002\");\r\n\t\t\t\t\t\t\tsr.setResultMsg(\"网关通讯ID必须为10位十六进制字符串\");\r\n\t\t\t\t\t\t\treturn sr;\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t\tif(pow==null||\"\".equals(pow.getGatewaycode2())||pow.getGatewaycode2().equals(\"null\")) {\r\n\t\t\t\t\t\t\tsr.setResultCode(\"-10003\");\r\n\t\t\t\t\t\t\tsr.setResultMsg(\"网关唯一ID不能为空\");\r\n\t\t\t\t\t\t\treturn sr;\r\n\t\t\t\t\t\t}else if(pow.getGatewaycode2().length()!=10||pow.getGatewaycode2().toUpperCase().matches(\".*[G-Z].*\")) {\r\n\t\t\t\t\t\t\tsr.setResultCode(\"-10004\");\r\n\t\t\t\t\t\t\tsr.setResultMsg(\"网关唯一ID必须为10位十六进制字符串\");\r\n\t\t\t\t\t\t\treturn sr;\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t\tif(pow.getRoomcode()==null||pow.getRoomcode().equals(\"\")||pow.getRoomcode().equals(\"null\")) {\r\n\t\t\t\t\t\t\tsr.setResultCode(\"-10005\");\r\n\t\t\t\t\t\t\tsr.setResultMsg(\"门锁编号不能为空\");\r\n\t\t\t\t\t\t\treturn sr;\r\n\t\t\t\t\t\t}else if(pow.getRoomcode().length()!=4||pow.getRoomcode().toUpperCase().matches(\".*[G-Z].*\")) {\r\n\t\t\t\t\t\t\tsr.setResultCode(\"-10006\");\r\n\t\t\t\t\t\t\tsr.setResultMsg(\"门锁编号必须为4位十六进制字符串\");\r\n\t\t\t\t\t\t\treturn sr;\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t}\r\n\t\t\t\t}else {\r\n\t\t\t\t\treturn new SendResult(\"100001\",\"参数错误\", \"\");\r\n\t\t\t\t}\r\n\t\t\t} catch (Exception e) {\r\n\t\t\t\t// TODO: handle exception\r\n\t\t\t\treturn new SendResult(\"10008\",\"类型转换错误\",\"\");\r\n\t\t\t}\r\n\t\t}else {\r\n\t\t\t\treturn new SendResult(\"100001\",\"参数错误\", \"\");\r\n\t\t}\r\n\t\treturn sr;\r\n\t}",
"@Override\n\tpublic boolean fnCreateRoom(String adminId, String date, String roomNumber,\n\t\t\tString timeSlots) {\n\t\tfnTracelog(\"entry admmin\" + adminId.substring(0, 4));\n\t\tHashMap<String, HashMap<String, HashMap<String, String>>> roomDetails = null;\n\t\tString campus = adminId.substring(0, 4);\n\n\t\tswitch (campus.toUpperCase()) {\n\t\tcase \"DVLA\":\n\t\t\troomDetails = hmDorvalRoomDetails;\n\t\t\tbreak;\n\n\t\tcase \"KKLA\":\n\t\t\troomDetails = hmKirklandRoomDetails;\n\t\t\tbreak;\n\n\t\tcase \"WSTA\":\n\t\t\troomDetails = hmWestmountRoomDetails;\n\t\t\tbreak;\n\n\t\tdefault:\n\t\t\treturn false;\n\t\t}\n\n\t\tHashMap<String, HashMap<String, String>> allRoomDetailsOfADay = roomDetails\n\t\t\t\t.get(date);\n\t\tif (allRoomDetailsOfADay == null) {\n\t\t\tallRoomDetailsOfADay = new HashMap<>();\n\t\t\troomDetails.put(date, allRoomDetailsOfADay);\n\t\t}\n\t\tHashMap<String, String> timeSlotsOfRoom = allRoomDetailsOfADay\n\t\t\t\t.get(roomNumber);\n\t\tif (timeSlotsOfRoom == null) {\n\t\t\ttimeSlotsOfRoom = new HashMap<>();\n\t\t\tallRoomDetailsOfADay.put(roomNumber, timeSlotsOfRoom);\n\t\t}\n\t\tfor (String timeSlot : timeSlots.split(\",\")) {\n\t\t\tif (!timeSlotsOfRoom.containsKey(timeSlot))\n\t\t\t\ttimeSlotsOfRoom.put(timeSlot, null);\n\t\t}\n\t\tfnTracelog(\"successful\");\n\t\treturn true;\n\n\t}",
"public static Room newRoom(int random){\n String nameRoom = \"\";\n int monsterAmount = 0;\n\t\tMonster monster;\n MonsterFactory monsterFac = new MonsterFactory();\n\t\tmonster= monsterFac.buildMonster((int)(Math.random() * 3) + 1);\n boolean createHealingPot = false;\n boolean createPitRoom = false;\n boolean createPillar = false;\n boolean createEntrance = false;\n boolean createExit = false;\n boolean createVisionPot = false;\n\n switch (random){\n case 1:\n \tnameRoom = \"The Entrance room\";\n \tmonsterAmount = 0;\n createEntrance = true;\n break;\n\n case 2:\n \tnameRoom = \"The Exit room\";\n \tmonsterAmount = 0;\n createExit = true;\n break;\n\n case 3:\n \tnameRoom = \"The room\";\n \tmonsterAmount = 1; //THIS ROOM WILL HAVE 1 MONSTER\n break;\n \n case 4:\n \tnameRoom = \"The Healing Potion room\";\n \tmonsterAmount=(int)(Math.random() * 1) + 0;\n createHealingPot = true;\n break;\n \n case 5:\n \tnameRoom = \"The Pit room\";\n \tmonsterAmount = 0;\n createPitRoom = true;\n break;\n\n case 6:\n \tnameRoom = \"The Pillar room\";\n \tmonsterAmount=(int)(Math.random() * 1) + 0;\n \tcreatePillar = true;\n break;\n \n case 7:\n \tnameRoom = \"The Vision Potion room\";\n \tmonsterAmount=0;\n createVisionPot=true;\n break;\n }\n \n if(monsterAmount <= 0 ) \n return new Room(nameRoom,createHealingPot, createPitRoom, createEntrance, createExit, createPillar, monsterAmount,createVisionPot);\n else\n return new Room(nameRoom,createHealingPot, createPitRoom, createEntrance, createExit, createPillar, monster, monsterAmount,createVisionPot);\n\n }"
]
| [
"0.61687356",
"0.60371315",
"0.60368204",
"0.5999019",
"0.5979966",
"0.5969285",
"0.59537166",
"0.59533066",
"0.5884757",
"0.5840068",
"0.5837474",
"0.58374345",
"0.58340335",
"0.5813822",
"0.578472",
"0.57835513",
"0.5747012",
"0.5736094",
"0.5723488",
"0.5704799",
"0.56794226",
"0.5677469",
"0.56675893",
"0.56583494",
"0.5657599",
"0.5547806",
"0.5546902",
"0.55351555",
"0.5525554",
"0.55209184",
"0.5504237",
"0.54938024",
"0.54799014",
"0.5478892",
"0.5467903",
"0.54391116",
"0.54234827",
"0.54219216",
"0.5414729",
"0.540201",
"0.5395054",
"0.5380379",
"0.5370678",
"0.5369686",
"0.5365412",
"0.536469",
"0.53559315",
"0.5346083",
"0.5338533",
"0.5338529",
"0.5337548",
"0.53237194",
"0.53197366",
"0.5318146",
"0.531475",
"0.53102905",
"0.5306957",
"0.52959335",
"0.5291319",
"0.52873725",
"0.5283179",
"0.5276198",
"0.5276198",
"0.52742326",
"0.5272973",
"0.52660614",
"0.52615184",
"0.5240836",
"0.5227984",
"0.5223066",
"0.5212976",
"0.52076036",
"0.5203605",
"0.5201356",
"0.5193868",
"0.5193797",
"0.5192406",
"0.5184569",
"0.5182866",
"0.5181054",
"0.51672834",
"0.51631224",
"0.51609737",
"0.51545763",
"0.51533866",
"0.51503927",
"0.5144082",
"0.5141179",
"0.5137841",
"0.5133011",
"0.5126685",
"0.51199013",
"0.51182646",
"0.5109215",
"0.51091987",
"0.5107976",
"0.5096799",
"0.5093289",
"0.5093288",
"0.50882167"
]
| 0.5539666 | 27 |
Constructs a new axis. | public NumberAxis3D(String label) {
super(label);
setAxisLineVisible(false);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"AxisType createAxisType();",
"public Vector(float[] axis){ this.axis = axis;}",
"Axis (Timeline timeline) {\n\n// assigns a Timeline to the Axis\n this.timeline = timeline;\n\n// creates a common y value for all Elements of the Axis\n// also used by all Markers on this Axis\n y = (axes.size() + 1) * 120;\n\n// places and styles the Axis\n this.setText(timeline.name.toUpperCase());\n this.setLayoutY(y - 12);\n this.setStyle(stylesheet.toString());\n this.getStyleClass().add(\"marker\");\n\n// places and styles the persistentLabel\n persistentLabel = new Label(timeline.name.toUpperCase());\n persistentLabel.setLayoutY(y - 13);\n persistentLabel.setStyle(stylesheet.toString());\n persistentLabel.getStyleClass().add(\"marker\");\n persistentLabel.setStyle(\"-fx-text-fill: #cccccc\");\n persistentLabel.setLayoutX(20);\n persistentLabel.setVisible(false);\n\n// sets start as the startDate of the first Event\n start = timeline.events.peekFirst().startDate[2];\n\n// sets right click on the Label and persistentLabel to expand Timeline\n this.setOnMouseClicked(mouseEvent -> {\n if (mouseEvent.getButton() == MouseButton.SECONDARY)\n expandElement(timeline);\n });\n persistentLabel.setOnMouseClicked(mouseEvent -> {\n if (mouseEvent.getButton() == MouseButton.SECONDARY)\n expandElement(timeline);\n });\n }",
"public DateAxis() { this(null); }",
"protected NumberAxis createVAxis() {\n NumberAxis yAxis = new NumberAxis(0, 55, 5);\n //yAxis.setLabel(\"Price\");\n yAxis.setSide(Side.RIGHT);\n yAxis.setTickMarkVisible(false);\n yAxis.setMinorTickVisible(false);\n return yAxis;\n }",
"public TypesAxis() {\r\n\t\tsuper(AxisTypes.class);\r\n\t}",
"public AxesTransform() {\n\n\t}",
"public net.opengis.gml.x32.CoordinateSystemAxisPropertyType addNewAxis()\n {\n synchronized (monitor())\n {\n check_orphaned();\n net.opengis.gml.x32.CoordinateSystemAxisPropertyType target = null;\n target = (net.opengis.gml.x32.CoordinateSystemAxisPropertyType)get_store().add_element_user(AXIS$0);\n return target;\n }\n }",
"public net.opengis.gml.x32.CoordinateSystemAxisPropertyType insertNewAxis(int i)\n {\n synchronized (monitor())\n {\n check_orphaned();\n net.opengis.gml.x32.CoordinateSystemAxisPropertyType target = null;\n target = (net.opengis.gml.x32.CoordinateSystemAxisPropertyType)get_store().insert_element_user(AXIS$1, AXIS$0, i);\n return target;\n }\n }",
"public InfLinearAxis() {\n }",
"public JXGraph() {\r\n this(0.0, 0.0, -1.0, 1.0, -1.0, 1.0, 0.2, 4, 0.2, 4);\r\n }",
"public JoystickAxis(IInput input, int joystick, int joystickAxis) {\n\t\tthis(input, joystick, new int[] { joystickAxis });\n\t}",
"protected NumberAxis createHAxis() {\n final NumberAxis xAxis = new NumberAxis();\n //xAxis.setLabel(\"Time\");\n xAxis.setTickMarkVisible(false);\n xAxis.setMinorTickVisible(false);\n xAxis.setMinorTickCount(0);\n xAxis.setTickLabelFormatter(new StringConverter<Number>() {\n @Override\n public String toString(Number number) {\n Date d = new Date(number.longValue());\n return d.getMinutes() + \":\" + d.getSeconds();\n }\n\n @Override\n public Number fromString(String s) {\n return null;\n }\n });\n return xAxis;\n }",
"public void setAxis(String axis)\n {\n this.axis = axis;\n }",
"public abstract AxisInfo getAxis( int dimension );",
"public DateAxis(String label) { this(label, TimeZone.getDefault()); }",
"public AbstractPlot(Axis<T1> xAxis, Axis<T2> yAxis){\n\t\tthis.xAxis = xAxis;\n\t\tthis.yAxis = yAxis;\n\t\tthis.init();\n\t}",
"private void initAxis(Axis axis, int position) {\n if (null == axis) {\n return;\n }\n initAxisAttributes(axis, position);\n initAxisMargin(axis, position);\n initAxisMeasurements(axis, position);\n }",
"public Shape() {\n\t\tthis(DEFAULT_X_POS, DEFAULT_Y_POS, DEFAULT_DELTA_X, DEFAULT_DELTA_Y, DEFAULT_WIDTH, DEFAULT_HEIGHT);\n\t}",
"Dimension createDimension();",
"public Graph()\r\n {\r\n this( \"x\", \"y\" );\r\n }",
"public BasicOrderedSeries()\n\t{\n\t\tsuper();\n\t}",
"public Shape() { this(X_DEFAULT, Y_DEFAULT); }",
"public NewShape() {\r\n\t\tsuper();\r\n\t}",
"public void a(Axis<?, ?> axis) {\n ArrayList arrayList = new ArrayList();\n arrayList.add(axis);\n a(arrayList, axis);\n this.a = new Axis[0];\n this.a = (Axis[]) arrayList.toArray(this.a);\n }",
"public DraggableBehavior setAxis(AxisEnum axis)\n\t{\n\t\tthis.options.putLiteral(\"axis\", axis.toString().toLowerCase());\n\t\treturn this;\n\t}",
"public AxisAngle(float angle, Vector3 axis) {\n this.angle = angle;\n this.axis = axis;\n }",
"@Model\r\n\tpublic Vector() {\r\n\t\tthis(50,50);\r\n\t}",
"public void setAxis(String name,String frame,float x,float y, float z){\r\n\t\tthis.addChild(new DirectionVector(name,frame,x,y,z));\r\n\t}",
"void addAxis(final CalibratedAxis axis, final long value);",
"public InfLinearAxis(Axis axis) {\n super(axis);\n }",
"public void c(Axis<?, ?> axis) {\n ArrayList arrayList = new ArrayList();\n a(arrayList, axis);\n this.a = new Axis[0];\n this.a = (Axis[]) arrayList.toArray(this.a);\n }",
"AngleAdd createAngleAdd();",
"public AntelopePanel() {\n this( null, null, true );\n }",
"private static IModelSpace initializeModelSpace() {\n String modelSpaceName = \"Default Trace-Time Space\";\n String yAxisName = \"Time\";\n Unit yUnit = UnitPreferences.getInstance().getTimeUnit();\n IAxis xAxis = new TraceAxis(new AxisRange(1, 10));\n ILabel yAxisLabel = new Label(yAxisName, Orientation.VERTICAL, Alignment.CENTER, true);\n IAxis yAxis = new Axis(yAxisLabel, yUnit, new AxisRange(0, 1000), Orientation.VERTICAL, AxisDirection.TOP_TO_BOTTOM);\n return new ModelSpace(modelSpaceName, xAxis, yAxis);\n }",
"public Horizontal() {\r\n }",
"Dimension_Dimension createDimension_Dimension();",
"public GanttChart(Axis<X> X, Axis<Y> Y) {\n this(X, Y, FXCollections.observableArrayList());\n }",
"private void createChart() {\n\t\tchartSpace = CTChartSpace.Factory.newInstance();\n\t\tchart = chartSpace.addNewChart();\n\t\tCTPlotArea plotArea = chart.addNewPlotArea();\n\n\t\tplotArea.addNewLayout();\n\t\tchart.addNewPlotVisOnly().setVal(true);\n\n\t\tCTPrintSettings printSettings = chartSpace.addNewPrintSettings();\n\t\tprintSettings.addNewHeaderFooter();\n\n\t\tCTPageMargins pageMargins = printSettings.addNewPageMargins();\n\t\tpageMargins.setB(0.75);\n\t\tpageMargins.setL(0.70);\n\t\tpageMargins.setR(0.70);\n\t\tpageMargins.setT(0.75);\n\t\tpageMargins.setHeader(0.30);\n\t\tpageMargins.setFooter(0.30);\n\t\tprintSettings.addNewPageSetup();\n\t}",
"public JoystickAxis(IInput input, int joystick, int[] joystickAxes) {\n\t\tthis.input = input;\n\t\tthis.joystick = joystick;\n\t\tthis.joystickAxes = joystickAxes;\n\t}",
"public static LUTCoordAxis createAxis(String filename) throws IOException\r\n {\r\n if (!lutAxes.containsKey(filename))\r\n {\r\n InputStream in = null;\r\n File file = new File(filename);\r\n File parentFile = file.getParentFile();\r\n if (parentFile == null)\r\n {\r\n throw new FileNotFoundException(filename);\r\n }\r\n else if (parentFile.getPath().endsWith(\".zip\"))\r\n {\r\n InputStream zipIn = in = Thread.currentThread()\r\n .getContextClassLoader().getResourceAsStream(parentFile.getPath());\r\n in = new ZipInputStream(zipIn);\r\n // Skip to the required entry\r\n while (true)\r\n {\r\n ZipEntry entry = ((ZipInputStream)in).getNextEntry();\r\n if (entry == null)\r\n {\r\n // We have gone past the last entry\r\n throw new FileNotFoundException(file.getName() +\r\n \" not found in zip file \" + parentFile.getPath());\r\n }\r\n else if (entry.getName().equals(file.getName()))\r\n {\r\n break; // exit the loop\r\n }\r\n }\r\n }\r\n else\r\n {\r\n // This is a regular, uncompressed file\r\n in = Thread.currentThread().getContextClassLoader()\r\n .getResourceAsStream(filename);\r\n }\r\n lutAxes.put(filename, createAxis(in, filename));\r\n }\r\n return lutAxes.get(filename);\r\n }",
"public AxisAngle(float angle, float x, float y, float z) {\n this(angle, new Vector3(x,y,z));\n }",
"public Vector() {\n construct();\n }",
"public interface AxisAngleBasics extends AxisAngleReadOnly, Orientation3DBasics, Clearable\n{\n /**\n * Gets the reference to the axis part of this axis-angle.\n *\n * @return the reference to the axis vector.\n */\n @Override\n UnitVector3DBasics getAxis();\n\n /**\n * Sets a new angle to this axis-angle.\n *\n * @param angle the new angle.\n */\n void setAngle(double angle);\n\n /**\n * Sets a new x-component for the axis of this axis-angle.\n *\n * @param x the new axis x-component.\n */\n default void setX(double x)\n {\n getAxis().setX(x);\n }\n\n /**\n * Sets a new y-component for the axis of this axis-angle.\n *\n * @param y the new axis y-component.\n */\n default void setY(double y)\n {\n getAxis().setY(y);\n }\n\n /**\n * Sets a new z-component for the axis of this axis-angle.\n *\n * @param z the new axis z-component.\n */\n default void setZ(double z)\n {\n getAxis().setZ(z);\n }\n\n /**\n * Sets the components of this axis-angle to represent a \"zero\" rotation. After calling the axis is\n * equal to {@link Axis3D#X} and the angle to 0.\n */\n @Override\n default void setToZero()\n {\n getAxis().set(Axis3D.X);\n setAngle(0.0);\n }\n\n /**\n * Sets the components of this axis-angle to {@link Double#NaN}.\n */\n @Override\n default void setToNaN()\n {\n getAxis().setToNaN();\n setAngle(Double.NaN);\n }\n\n /**\n * Tests if this axis-angle contains a {@link Double#NaN}.\n *\n * @return {@code true} if this axis-angle contains a {@link Double#NaN}, {@code false} otherwise.\n */\n @Override\n default boolean containsNaN()\n {\n return AxisAngleReadOnly.super.containsNaN();\n }\n\n /**\n * Sets each component of this axis-angle to its absolute value.\n */\n default void absolute()\n {\n getAxis().absolute();\n setAngle(Math.abs(getAngle()));\n }\n\n /**\n * Negates each component of this axis-angle.\n */\n default void negate()\n {\n getAxis().negate();\n setAngle(-getAngle());\n }\n\n /** {@inheritDoc} */\n @Override\n default void invert()\n {\n setAngle(-getAngle());\n }\n\n /**\n * Normalizes the axis of this axis-angle such that its norm is equal to 1 after calling this method\n * and its direction remains unchanged.\n * <p>\n * Edge cases:\n * <ul>\n * <li>if this axis-angle contains {@link Double#NaN}, this method is ineffective.\n * </ul>\n * </p>\n */\n @Override\n default void normalize()\n {\n getAxis().normalize();\n }\n\n /**\n * Multiplies the angle of this axis-angle by the given {@code scale}.\n *\n * @param scale the scaling factor to apply to the angle of this axis-angle.\n */\n default void scaleAngle(double scale)\n {\n setAngle(scale * getAngle());\n }\n\n /**\n * Sets this axis-angle to represent a new rotation of axis ({@code x}, {@code y}, {@code z}) and\n * angle of {@code angle}.\n *\n * @param x x-component of the new axis.\n * @param y y-component of the new axis.\n * @param z z-component of the new axis.\n * @param angle the new angle.\n */\n default void set(double x, double y, double z, double angle)\n {\n getAxis().set(x, y, z);\n setAngle(angle);\n }\n\n /** {@inheritDoc} */\n @Override\n default void set(Orientation3DReadOnly orientation3DReadOnly)\n {\n if (orientation3DReadOnly instanceof AxisAngleReadOnly)\n set((AxisAngleReadOnly) orientation3DReadOnly);\n else\n orientation3DReadOnly.get(this);\n }\n\n /**\n * Sets the axis and the angle of this axis-angle.\n *\n * @param axis the new axis. Not modified.\n * @param angle the new angle.\n */\n default void set(Vector3DReadOnly axis, double angle)\n {\n getAxis().set(axis);\n setAngle(angle);\n }\n\n /**\n * Sets this axis-angle to the same value as the given axis-angle {@code other}.\n *\n * @param other the other axis-angle. Not modified.\n */\n default void set(AxisAngleReadOnly other)\n {\n getAxis().set(other.getAxis());\n setAngle(other.getAngle());\n }\n\n /**\n * Sets this axis-angle to {@code other} and then calls {@link #negate()}.\n *\n * @param other the other axis-angle to copy the values from. Not modified.\n */\n default void setAndNegate(AxisAngleReadOnly other)\n {\n set(other);\n negate();\n }\n\n /**\n * Copies the values in the given array into this axis-angle as follows:\n * <ul>\n * <li>{@code this.setX(axisAngleArray[0]);}\n * <li>{@code this.setY(axisAngleArray[1]);}\n * <li>{@code this.setZ(axisAngleArray[2]);}\n * <li>{@code this.setAngle(axisAngleArray[3]);}\n * </ul>\n *\n * @param axisAngleArray the array containing the new values for this axis-angle. Not modified.\n */\n default void set(double[] axisAngleArray)\n {\n set(0, axisAngleArray);\n }\n\n /**\n * Copies the values in the given array into this axis-angle as follows:\n * <ul>\n * <li>{@code this.setX(axisAngleArray[startIndex + 0]);}\n * <li>{@code this.setY(axisAngleArray[startIndex + 1]);}\n * <li>{@code this.setZ(axisAngleArray[startIndex + 2]);}\n * <li>{@code this.setAngle(axisAngleArray[startIndex + 3]);}\n * </ul>\n *\n * @param startIndex the first index to start reading from in the array.\n * @param axisAngleArray the array containing the new values for this axis-angle. Not modified.\n */\n default void set(int startIndex, double[] axisAngleArray)\n {\n setX(axisAngleArray[startIndex++]);\n setY(axisAngleArray[startIndex++]);\n setZ(axisAngleArray[startIndex++]);\n setAngle(axisAngleArray[startIndex]);\n }\n\n /**\n * Copies the values in the given array into this axis-angle as follows:\n * <ul>\n * <li>{@code this.setX(axisAngleArray[0]);}\n * <li>{@code this.setY(axisAngleArray[1]);}\n * <li>{@code this.setZ(axisAngleArray[2]);}\n * <li>{@code this.setAngle(axisAngleArray[3]);}\n * </ul>\n *\n * @param axisAngleArray the array containing the new values for this axis-angle. Not modified.\n */\n default void set(float[] axisAngleArray)\n {\n set(0, axisAngleArray);\n }\n\n /**\n * Copies the values in the given array into this axis-angle as follows:\n * <ul>\n * <li>{@code this.setX(axisAngleArray[startIndex + 0]);}\n * <li>{@code this.setY(axisAngleArray[startIndex + 1]);}\n * <li>{@code this.setZ(axisAngleArray[startIndex + 2]);}\n * <li>{@code this.setAngle(axisAngleArray[startIndex + 3]);}\n * </ul>\n *\n * @param startIndex the first index to start reading from in the array.\n * @param axisAngleArray the array containing the new values for this axis-angle. Not modified.\n */\n default void set(int startIndex, float[] axisAngleArray)\n {\n setX(axisAngleArray[startIndex++]);\n setY(axisAngleArray[startIndex++]);\n setZ(axisAngleArray[startIndex++]);\n setAngle(axisAngleArray[startIndex]);\n }\n\n /** {@inheritDoc} */\n @Override\n default void setAxisAngle(double x, double y, double z, double angle)\n {\n set(x, y, z, angle);\n }\n\n /** {@inheritDoc} */\n @Override\n default void setQuaternion(double x, double y, double z, double s)\n {\n AxisAngleConversion.convertQuaternionToAxisAngle(x, y, z, s, this);\n }\n\n /** {@inheritDoc} */\n @Override\n default void setRotationVector(double x, double y, double z)\n {\n AxisAngleConversion.convertRotationVectorToAxisAngle(x, y, z, this);\n }\n\n /** {@inheritDoc} */\n @Override\n default void setYawPitchRoll(double yaw, double pitch, double roll)\n {\n AxisAngleConversion.convertYawPitchRollToAxisAngle(yaw, pitch, roll, this);\n }\n\n /** {@inheritDoc} */\n @Override\n default void setRotationMatrix(double m00, double m01, double m02, double m10, double m11, double m12, double m20, double m21, double m22)\n {\n AxisAngleConversion.convertMatrixToAxisAngle(m00, m01, m02, m10, m11, m12, m20, m21, m22, this);\n }\n\n @Override\n default void setToYawOrientation(double yaw)\n {\n getAxis().set(Axis3D.Z);\n setAngle(yaw);\n }\n\n @Override\n default void setToPitchOrientation(double pitch)\n {\n getAxis().set(Axis3D.Y);\n setAngle(pitch);\n }\n\n @Override\n default void setToRollOrientation(double roll)\n {\n getAxis().set(Axis3D.X);\n setAngle(roll);\n }\n\n /**\n * Selects a component of this axis-angle based on {@code index} and sets it to {@code value}.\n * <p>\n * For {@code index} values of 0, 1, and 2, the corresponding components are x, y, and z,\n * respectively, while 3 corresponds to the angle.\n * </p>\n *\n * @param index the index of the component to set.\n * @param value the new value of the selected component.\n * @throws IndexOutOfBoundsException if {@code index} ∉ [0, 3].\n */\n default void setElement(int index, double value)\n {\n switch (index)\n {\n case 0:\n setX(value);\n break;\n case 1:\n setY(value);\n break;\n case 2:\n setZ(value);\n break;\n case 3:\n setAngle(value);\n break;\n default:\n throw new IndexOutOfBoundsException(Integer.toString(index));\n }\n }\n\n /**\n * Multiplies this axis-angle by {@code other}.\n * <p>\n * this = this * other\n * </p>\n *\n * @param other the other axis-angle to multiply this. Not modified.\n */\n default void multiply(AxisAngleReadOnly other)\n {\n AxisAngleTools.multiply(this, other, this);\n }\n\n /** {@inheritDoc} */\n @Override\n default void append(Orientation3DReadOnly other)\n {\n AxisAngleTools.multiply(this, false, other, false, this);\n }\n\n /**\n * Sets this axis-angle to the multiplication of {@code aa1} and {@code aa2}.\n * <p>\n * this = aa1 * aa2\n * </p>\n *\n * @param aa1 the first axis-angle in the multiplication. Not modified.\n * @param aa2 the second axis-angle in the multiplication. Not modified.\n */\n default void multiply(AxisAngleReadOnly aa1, AxisAngleReadOnly aa2)\n {\n AxisAngleTools.multiply(aa1, aa2, this);\n }\n\n /**\n * Multiplies this axis-angle by the inverse of {@code other}.\n * <p>\n * this = this * other<sup>-1</sup>\n * </p>\n *\n * @param other the other axis-angle to multiply this. Not modified.\n */\n default void multiplyInvertOther(AxisAngleReadOnly other)\n {\n AxisAngleTools.multiplyInvertRight(this, other, this);\n }\n\n /** {@inheritDoc} */\n @Override\n default void appendInvertOther(Orientation3DReadOnly orientation)\n {\n AxisAngleTools.multiply(this, false, orientation, true, this);\n }\n\n /**\n * Sets this axis-angle to the multiplication of the inverse of {@code this} and {@code other}.\n * <p>\n * this = this<sup>-1</sup> * other\n * </p>\n *\n * @param other the other axis-angle to multiply this. Not modified.\n */\n default void multiplyInvertThis(AxisAngleReadOnly other)\n {\n AxisAngleTools.multiplyInvertLeft(this, other, this);\n }\n\n /**\n * Sets this axis-angle to the multiplication of the inverse of {@code this} and the inverse of\n * {@code other}.\n * <p>\n * this = this<sup>-1</sup> * other<sup>-1</sup>\n * </p>\n *\n * @param other the other axis-angle to multiply this. Not modified.\n */\n default void multiplyInvertBoth(AxisAngleReadOnly other)\n {\n AxisAngleTools.multiplyInvertBoth(this, other, this);\n }\n\n /**\n * Appends a rotation about the z-axis to this axis-angle.\n *\n * <pre>\n * / ux = 0 \\\n * this = this * | uy = 0 |\n * | uz = 1 |\n * \\ angle = yaw /\n * </pre>\n *\n * @param yaw the angle to rotate about the z-axis.\n */\n @Override\n default void appendYawRotation(double yaw)\n {\n AxisAngleTools.appendYawRotation(this, yaw, this);\n }\n\n /**\n * Appends a rotation about the y-axis to this axis-angle.\n *\n * <pre>\n * / ux = 0 \\\n * this = this * | uy = 1 |\n * | uz = 0 |\n * \\ angle = pitch /\n * </pre>\n *\n * @param pitch the angle to rotate about the y-axis.\n */\n @Override\n default void appendPitchRotation(double pitch)\n {\n AxisAngleTools.appendPitchRotation(this, pitch, this);\n }\n\n /**\n * Appends a rotation about the x-axis to this axis-angle.\n *\n * <pre>\n * / ux = 1 \\\n * this = this * | uy = 0 |\n * | uz = 0 |\n * \\ angle = roll /\n * </pre>\n *\n * @param roll the angle to rotate about the x-axis.\n */\n @Override\n default void appendRollRotation(double roll)\n {\n AxisAngleTools.appendRollRotation(this, roll, this);\n }\n\n /**\n * Pre-multiplies this axis-angle by {@code other}.\n * <p>\n * this = other * other\n * </p>\n *\n * @param other the other axis-angle to multiply this. Not modified.\n */\n default void preMultiply(AxisAngleReadOnly other)\n {\n AxisAngleTools.multiply(other, this, this);\n }\n\n /** {@inheritDoc} */\n @Override\n default void prepend(Orientation3DReadOnly orientation)\n {\n AxisAngleTools.multiply(orientation, false, this, false, this);\n }\n\n /**\n * Sets this axis-angle to the multiplication of the inverse of {@code other} and {@code this}.\n * <p>\n * this = other<sup>-1</sup> * this\n * </p>\n *\n * @param other the other axis-angle to multiply this. Not modified.\n */\n default void preMultiplyInvertOther(AxisAngleReadOnly other)\n {\n AxisAngleTools.multiplyInvertLeft(other, this, this);\n }\n\n /** {@inheritDoc} */\n @Override\n default void prependInvertOther(Orientation3DReadOnly orientation)\n {\n AxisAngleTools.multiply(orientation, true, this, false, this);\n }\n\n /**\n * Sets this axis-angle to the multiplication of {@code other} and the inverse of {@code this}.\n * <p>\n * this = other * this<sup>-1</sup>\n * </p>\n *\n * @param other the other axis-angle to multiply this. Not modified.\n */\n default void preMultiplyInvertThis(AxisAngleReadOnly other)\n {\n AxisAngleTools.multiplyInvertRight(other, this, this);\n }\n\n /**\n * Sets this axis-angle to the multiplication of the inverse of {@code other} and the inverse of\n * {@code this}.\n * <p>\n * this = other<sup>-1</sup> * this<sup>-1</sup>\n * </p>\n *\n * @param other the other axis-angle to multiply this. Not modified.\n */\n default void preMultiplyInvertBoth(AxisAngleReadOnly other)\n {\n AxisAngleTools.multiplyInvertBoth(other, this, this);\n }\n\n /**\n * Prepends a rotation about the z-axis to this axis-angle.\n *\n * <pre>\n * / ux = 0 \\\n * this = | uy = 0 | * this\n * | uz = 1 |\n * \\ angle = yaw /\n * </pre>\n *\n * @param yaw the angle to rotate about the z-axis.\n */\n @Override\n default void prependYawRotation(double yaw)\n {\n AxisAngleTools.prependYawRotation(yaw, this, this);\n }\n\n /**\n * Prepends a rotation about the y-axis to this axis-angle.\n *\n * <pre>\n * / ux = 0 \\\n * this = | uy = 1 | * this\n * | uz = 0 |\n * \\ angle = pitch /\n * </pre>\n *\n * @param pitch the angle to rotate about the y-axis.\n */\n @Override\n default void prependPitchRotation(double pitch)\n {\n AxisAngleTools.prependPitchRotation(pitch, this, this);\n }\n\n /**\n * Prepends a rotation about the x-axis to this axis-angle.\n *\n * <pre>\n * / ux = 1 \\\n * this = | uy = 0 | * this\n * | uz = 0 |\n * \\ angle = roll /\n * </pre>\n *\n * @param roll the angle to rotate about the x-axis.\n */\n @Override\n default void prependRollRotation(double roll)\n {\n AxisAngleTools.prependRollRotation(roll, this, this);\n }\n}",
"public CwmDimensionedObject createCwmDimensionedObject();",
"public static TimeAxis<Unit, CopticCalendar> axis() {\n\n return ENGINE;\n\n }",
"public Line()\n\t{\n\t\tthis(1.0f, 1.0f, 0.0f);\n\t}",
"public Plot() {\r\n }",
"public Cell(String name, int x_axis, int y_axis) {\n this.x_axis = x_axis;\n this.y_axis = y_axis;\n this.name = name;\n }",
"private D3() {\n super(3);\n }",
"public Shape(int x, int y) {\n\t\tthis(x, y, DEFAULT_DELTA_X, DEFAULT_DELTA_Y, DEFAULT_WIDTH, DEFAULT_HEIGHT);\n\t}",
"public LinesDimension1() {\n \n }",
"private Chart(){}",
"public MultiArrayDimension() {\n\t\tthis(\"\", 0, 0);\n\t}",
"private XMath()\n {\n \n }",
"public InfLinearAxis(int size) {\n super(size);\n }",
"CalibratedAxis getAxis(AxisType axisType);",
"public Translation() {\n\n this(0, 0, 0);\n }",
"public ScatterChart(@NamedArg(\"xAxis\") Axis<X> xAxis, @NamedArg(\"yAxis\") Axis<Y> yAxis) {\n this(xAxis, yAxis, FXCollections.<Series<X, Y>>observableArrayList());\n }",
"public Heart() {\n super();\n }",
"public Trigger( XboxController controller, int axisID )\n {\n this.controller = controller;\n this.axisID = axisID;\n }",
"public GanttChart(@NamedArg(\"xAxis\") Axis<X> xAxis, @NamedArg(\"yAxis\") Axis<Y> yAxis) {\n this(xAxis, yAxis, FXCollections.<Series<X, Y>>observableArrayList());\n }",
"VisualizationAttribute createVisualizationAttribute();",
"private XYSeries createSeries() {\r\n return createSeries(0);\r\n }",
"public JTensor() {\n this(TH.THTensor_(new)());\n }",
"public void addAxisModel() {\n\t\taddAxisModel(analysisModel.getGraphModel().newGraphData());\n\t}",
"public AxisRenderer2D( final AxisConfig<Q> conf )\r\n\t{\r\n\t\tthis.config = conf;\r\n\t}",
"public interface AxisInformation {\n double getMaxSpeed();\n double getTargetValue();\n\n String getIdentifier();\n\n double getMaxValue();\n double getMinValue();\n double getCurrentTargetValue();\n double getCurrentValue();\n boolean isMoving();\n double getSpeed();\n boolean isEnabled();\n int getJointType();\n}",
"public void setAxes(int xPos, int yPos, int axisLength, String xLabel, String yLabel)\n {\n this.xPos= xPos;\n this.yPos= yPos;\n this.xLabel= xLabel;\n this.yLabel= yLabel;\n this.axisLength=axisLength;\n }",
"private static JFreeChart createChart(String xaxisName) {\n JFreeChart chart = MimsChartFactory.createMimsXYLineChart(\"\", xaxisName, \"\", null, PlotOrientation.VERTICAL, true, true, false);\n chart.setBackgroundPaint(Color.white);\n // Get a reference to the plot.\n MimsXYPlot plot = (MimsXYPlot) chart.getPlot();\n\n // Create integer x-axis.\n plot.getDomainAxis().setStandardTickUnits(NumberAxis.createIntegerTickUnits());\n\n // Set colors.\n plot.setBackgroundPaint(Color.lightGray);\n plot.setDomainGridlinePaint(Color.white);\n plot.setRangeGridlinePaint(Color.white);\n\n // Movable range and domain.\n plot.setDomainPannable(true);\n plot.setRangePannable(true);\n\n // Allow crosshairs to 'focus' in on a given point.\n plot.setDomainCrosshairVisible(true);\n plot.setRangeCrosshairVisible(true);\n\n return chart;\n }",
"@Override\n UnitVector3DBasics getAxis();",
"public void b(Axis<?, ?> axis) {\n ArrayList arrayList = new ArrayList();\n a(arrayList, axis);\n arrayList.add(axis);\n this.a = new Axis[0];\n this.a = (Axis[]) arrayList.toArray(this.a);\n }",
"private Vector(double x, double y){\n this.x = x;\n this.y = y;\n }",
"public CommandBar(String[] towerNames, double ax, \r\n double awidth, double aheight)\r\n {\r\n towerTypes = towerNames;\r\n initX = ax;\r\n width = awidth;\r\n height = aheight;\r\n \r\n //initialize \"buttons\" and dummy list\r\n dummyList = new ArrayList<Unit>();\r\n towerButtons = new Rectangle2D.Double[towerTypes.length];\r\n for (int i = 0; i < towerButtons.length; i++)\r\n {\r\n double x = initX + GAP;\r\n double y = (3*GAP + FONT_SIZE)*i + GAP;\r\n towerButtons[i] = new Rectangle2D.Double(x, y,\r\n width - 2*GAP, \r\n 2*GAP + FONT_SIZE);\r\n dummyList.add(generateDummy(towerTypes[i]));\r\n }\r\n \r\n display = new UnitDisplay();\r\n selectedIndex = -1;\r\n }",
"public CrlSeries()\n {\n super();\n }",
"public XDimension Xdimension() throws java.io.IOException {\n return new XDimension(u16(),u16());\n }",
"public XYScatterGrapher()\n {\n\n }",
"public HorizontalCoords() {\n }",
"public Shape()\n {\n this(Anchor.CENTER.anchoredAt(Anchor.CENTER.ofView()).sized(100, 100));\n }",
"public Vector(double x, double y, double z, double w) {\n super(new double[][] {\n { x },\n { y },\n { z },\n { w }\n });\n }",
"public VariableGridLayout() {\n\t\tthis(FIXED_NUM_ROWS, 1, 0, 0);\n\t}",
"public LogicUnit(int width) {\n super(\"LogicUnit\", width);\n }",
"@DISPID(1611005952) //= 0x60060000. The runtime will prefer the VTID if present\n @VTID(28)\n void newWithAxisSystem(\n boolean oAxisSystemCreated);",
"public Property() {\n this(0, 0, 0, 0);\n }",
"public LineChart() {\n init();\n }",
"public AdaDelta() {\n this(0.95,1e-6);\n }",
"public ToolBarLayout()\n {\n this(LEFT, 5, 5);\n }",
"Angle createAngle();",
"public QuadCurve () {\n }",
"public CoordinateAxes(GL2 gl, GLUT glut) {\n\t\tthis.gl = gl;\n\t\tthis.glut = glut;\n\t}",
"private void createGUI() {\r\n\r\n cgRect modelSpace = new cgRect(0, 0, 11, 11);\r\n cgRect deviceSpace = new cgRect(0, 0, 600, 600);\r\n\r\n cgTransformation tr = new cgTransformation(modelSpace, deviceSpace, false, false);\r\n\r\n /**\r\n *\r\n */\r\n // The formatter of axis' labels will use default locale and pattern\r\n NumberFormat nf = NumberFormat.getInstance();\r\n\r\n // We will use \"fixed size\" axis renderer for all axes\r\n \r\n // 参数一:标签刻度长度大小 参数二:标签数字长度大小 参数三:数字和刻度之间的距离大小,长度为像素\r\n cgAxisRenderer ar = new cgFixedSizeAxisRenderer(5, 15, 50, nf);\r\n\r\n // ----------------------------------------------------\r\n // First axis - values match the model coordinates,\r\n // model origin is at 0.0\r\n // ----------------------------------------------------\r\n \r\n // 第三个参数为显示的数字数\r\n cgRect bbox1 = new cgRect(0, 0, 11, 1);\r\n TickGenerator tg1 = new NumericTickGenerator(1.0);\r\n cgAxisShape axis1 = new cgAxisShape(cgAxisShape.NORTH, bbox1, tg1, ar);\r\n\r\n cgShapeListLayer layer = new cgShapeListLayer();\r\n\r\n layer.addShape(axis1);\r\n\r\n /**\r\n *\r\n */\r\n // ----------------------------------------------------\r\n // Create grid using regular grid renderer\r\n // ----------------------------------------------------\r\n cgRect bbox = new cgRect(0, 0, 10, 10);\r\n TickGenerator htg = new NumericTickGenerator(1.0);\r\n TickGenerator vtg = new NumericTickGenerator(1.0);\r\n cgGridRenderer gr = new cgRegularGridRenderer();\r\n cgGridShape grid = new cgGridShape(bbox, htg, vtg, gr);\r\n\r\n // ----------------------------------------------------\r\n // Create view\r\n // ----------------------------------------------------\r\n// cgShapeListLayer layer = new cgShapeListLayer();\r\n// layer.addShape( grid );\r\n cgContainerModel model = new cgContainerModel();\r\n model.setBoundingBox(modelSpace);\r\n model.addLayer(layer);\r\n\r\n cgPlotView view = new cgPlotView(model, tr);\r\n\r\n // ----------------------------------------------------\r\n // Create plot\r\n // ----------------------------------------------------\r\n cgPlot plot = new cgPlot(view);\r\n\r\n plot.addScrollbar(cgGenericPlotLayout.SOUTH);\r\n plot.addScrollbar(cgGenericPlotLayout.EAST);\r\n\r\n getContentPane().add(plot);\r\n\r\n // ----------------------------------------------------\r\n // Set up listeners\r\n // ----------------------------------------------------\r\n // Set window listener\r\n addWindowListener(new WindowAdapter() {\r\n public void windowClosing(WindowEvent e) {\r\n System.exit(0);\r\n }\r\n });\r\n }",
"public WeatherGridSlice() {\n super();\n }",
"public ScaleControl() {\n super();\n }",
"public LabelFactory() {\n this(0);\n }",
"void setAxisTypes(AxisType... axisTypes);",
"public UIXChart()\n {\n super(\"org.apache.myfaces.trinidad.Chart\");\n }",
"public Button(float x, float y, float width, float height){\n super(x,y,width,height);\n }",
"public Property(int xLength, int yWidth, int xLeft, int yTop) {\n this(xLength, yWidth, xLeft, yTop, DEFAULT_REGNUM);\n }",
"public GenericDynamicArray() {this(11);}",
"public DateAxis(String label, TimeZone zone, Locale locale) {\n/* 402 */ super(label, createStandardDateTickUnits(zone, locale));\n/* 403 */ this.tickUnit = new DateTickUnit(DateTickUnitType.DAY, true, new SimpleDateFormat());\n/* */ \n/* 405 */ setAutoRangeMinimumSize(2.0D);\n/* */ \n/* 407 */ setRange(DEFAULT_DATE_RANGE, false, false);\n/* 408 */ this.dateFormatOverride = null;\n/* 409 */ this.timeZone = zone;\n/* 410 */ this.locale = locale;\n/* 411 */ this.timeline = DEFAULT_TIMELINE;\n/* */ }"
]
| [
"0.6423999",
"0.62586415",
"0.62350637",
"0.6019104",
"0.5996241",
"0.58300865",
"0.5821339",
"0.58150744",
"0.5610956",
"0.5581847",
"0.55641955",
"0.5511965",
"0.55026674",
"0.54917026",
"0.5401326",
"0.53852326",
"0.5362097",
"0.53453326",
"0.53380567",
"0.5324247",
"0.5299687",
"0.5290405",
"0.5287916",
"0.5281413",
"0.527855",
"0.5266628",
"0.5262481",
"0.5206374",
"0.52043104",
"0.5199589",
"0.51852363",
"0.5152772",
"0.51374614",
"0.5122283",
"0.5116945",
"0.5115969",
"0.50959146",
"0.50943196",
"0.5093027",
"0.5089843",
"0.5080326",
"0.50798196",
"0.5063341",
"0.5038154",
"0.5037096",
"0.50338477",
"0.5032762",
"0.5031535",
"0.5023827",
"0.50117147",
"0.5010892",
"0.5002968",
"0.49853814",
"0.4976653",
"0.49765852",
"0.49671954",
"0.49661887",
"0.4935067",
"0.49267474",
"0.4926153",
"0.49231404",
"0.49202454",
"0.49143413",
"0.49122804",
"0.49104396",
"0.49006554",
"0.48943672",
"0.48811632",
"0.48785377",
"0.4878209",
"0.4874721",
"0.48709476",
"0.4859562",
"0.48585644",
"0.48548394",
"0.4848419",
"0.48387086",
"0.48372534",
"0.48334518",
"0.48245764",
"0.4821506",
"0.48118255",
"0.48104715",
"0.480537",
"0.48005646",
"0.4798874",
"0.47892696",
"0.4785944",
"0.47727194",
"0.47657868",
"0.4762907",
"0.476176",
"0.47584096",
"0.4751129",
"0.4751047",
"0.47508305",
"0.47494555",
"0.47393614",
"0.47384787",
"0.47322905"
]
| 0.47611362 | 92 |
Draws the axis on a Java 2D graphics device (such as the screen or a printer). | public AxisState draw(Graphics2D g2, double cursor, Rectangle2D plotArea,
Rectangle2D dataArea, RectangleEdge edge,
PlotRenderingInfo plotState) {
// if the axis is not visible, don't draw it...
if (!isVisible()) {
AxisState state = new AxisState(cursor);
// even though the axis is not visible, we need ticks for the
// gridlines...
List ticks = refreshTicks(g2, state, dataArea, edge);
state.setTicks(ticks);
return state;
}
// calculate the adjusted data area taking into account the 3D effect...
double xOffset = 0.0;
double yOffset = 0.0;
Plot plot = getPlot();
if (plot instanceof CategoryPlot) {
CategoryPlot cp = (CategoryPlot) plot;
CategoryItemRenderer r = cp.getRenderer();
if (r instanceof Effect3D) {
Effect3D e3D = (Effect3D) r;
xOffset = e3D.getXOffset();
yOffset = e3D.getYOffset();
}
}
double adjustedX = dataArea.getMinX();
double adjustedY = dataArea.getMinY();
double adjustedW = dataArea.getWidth() - xOffset;
double adjustedH = dataArea.getHeight() - yOffset;
if (edge == RectangleEdge.LEFT || edge == RectangleEdge.BOTTOM) {
adjustedY += yOffset;
}
else if (edge == RectangleEdge.RIGHT || edge == RectangleEdge.TOP) {
adjustedX += xOffset;
}
Rectangle2D adjustedDataArea = new Rectangle2D.Double(adjustedX,
adjustedY, adjustedW, adjustedH);
// draw the tick marks and labels...
AxisState info = drawTickMarksAndLabels(g2, cursor, plotArea,
adjustedDataArea, edge);
// draw the axis label...
info = drawLabel(getLabel(), g2, plotArea, dataArea, edge, info);
return info;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void drawAxis(Graphics2D g2d) {\n g2d.setColor(Color.red);\n drawEdge(g2d,new Point(0, -100), new Point(0, 100));\n g2d.setColor(Color.green);\n drawEdge(g2d,new Point(-100, 0), new Point(100, 0));\n }",
"private void drawAxis(Graphics2D g2) {\r\n if (!isAxisPainted()) {\r\n return;\r\n }\r\n \r\n double axisH = yPositionToPixel(originY);\r\n double axisV = xPositionToPixel(originX);\r\n \r\n Rectangle clip = g2.getClipBounds();\r\n \r\n g2.setColor(getAxisColor());\r\n Stroke stroke = g2.getStroke();\r\n g2.setStroke(new BasicStroke(STROKE_AXIS));\r\n\r\n if (axisH >= clip.y && axisH <= clip.y + clip.height) {\r\n g2.drawLine(clip.x, (int) axisH, clip.x + clip.width, (int) axisH);\r\n }\r\n if (axisV >= clip.x && axisV <= clip.x + clip.width) {\r\n g2.drawLine((int) axisV, clip.y, (int) axisV, clip.y + clip.height);\r\n }\r\n\r\n g2.setStroke(stroke);\r\n }",
"public void display (Graphics2D g, double x, double y);",
"@Override\r\n\tpublic void drawUnit(float xaxis, float yaxis) {\r\n\t\tdraelicImage.draw(xaxis,yaxis,1.5f);\r\n\t\t\r\n\t}",
"private void drawAxes()\r\n {\r\n Rectangle rectangle = this.getBounds();\r\n rectangle.setBounds(0,0,300,300);\r\n \r\n xOrigin_ = (int)(rectangle.x);\r\n yOrigin_ = (int)(rectangle.y);\r\n \r\n // Draw x axis\r\n graphics_.drawLine(xOrigin_ + OFFSET,\r\n yOrigin_ + OFFSET,\r\n MAX_AXIS_LENGTH + OFFSET,\r\n yOrigin_ + OFFSET);\r\n \r\n // Draw y axis\r\n graphics_.drawLine(xOrigin_ + OFFSET,\r\n yOrigin_ + OFFSET,\r\n xOrigin_ + OFFSET,\r\n MAX_AXIS_LENGTH + OFFSET);\r\n \r\n // Put labels on Axes\r\n graphics_.drawString(xLabel_, \r\n MAX_AXIS_LENGTH, \r\n (yOrigin_+ X_LABEL_OFFSET));\r\n \r\n graphics_.drawString(yLabel_, \r\n (xOrigin_ + X_LABEL_OFFSET), \r\n (MAX_AXIS_LENGTH + Y_LABEL_OFFSET));\r\n \r\n // Write description of plot below graph\r\n graphics_.drawString(\"PLOT OF \" + xLabel_ + \" VS \" + yLabel_, \r\n PLOT_DESCRIP_X,\r\n PLOT_DESCRIP_Y);\r\n \r\n // Draw tick marks on x axis\r\n final int axisMarkerDist = MAX_AXIS_LENGTH/NUM_MARKERS;\r\n \r\n // Temporary variable representing location where tick marks \r\n // should be drawn\r\n int axisTemp;\r\n \r\n for (int i=1; i<=NUM_MARKERS; i++)\r\n {\r\n axisTemp = i*axisMarkerDist;\r\n \r\n // Draw tick mark\r\n graphics_.drawLine(OFFSET + (axisTemp),\r\n OFFSET,\r\n OFFSET + (axisTemp),\r\n OFFSET - 5 );\r\n \r\n // Draw value above tick mark\r\n graphics_.drawString(String.valueOf( (maxX_/NUM_MARKERS)*i ),\r\n (OFFSET + (axisTemp)),\r\n OFFSET - 20);\r\n }\r\n \r\n // Draw tick marks on y axis\r\n for (int i=1; i<=NUM_MARKERS; i++)\r\n {\r\n axisTemp = i*axisMarkerDist;\r\n // Draw tick mark\r\n graphics_.drawLine( OFFSET - 5,\r\n (OFFSET + (axisTemp)),\r\n OFFSET,\r\n (OFFSET + (axisTemp)));\r\n \r\n // Draw value above tick mark\r\n graphics_.drawString(String.valueOf((maxY_/NUM_MARKERS)*i),\r\n xOrigin_ + X_LABEL_OFFSET,\r\n (OFFSET + (axisTemp)));\r\n }\r\n\r\n\r\n }",
"@Override\n public void paintComponent(Graphics g) {\n super.paintComponent(g);\n\n Graphics2D g2d = (Graphics2D) g;\n drawAxis(g2d);\n \n drawCurve(g2d);\n \n drawPoints(g2d);\n \n // drawObject(g2d); **\n // El panel, por defecto no es \"focusable\". \n // Hay que incluir estas líneas para que el panel pueda\n // agregarse como KeyListsener.\n this.setFocusable(true);\n this.requestFocusInWindow();\n }",
"void draw (Graphics2D g);",
"private void drawAxisLines() {\n\t\t//Draw axis lines\n\t\tgl.glLineWidth(2.0f);\n\t\tgl.glBegin(GL2.GL_LINES);\n\t\t\n\t\t//Line Positive X - Red\n\t\tgl.glColor3d(1, 0, 0);\n\t\tgl.glVertex3d(0, 0, 0);\n\t\tgl.glVertex3d(1, 0, 0);\n\t\t//Line Negative X - Red\n\t\tgl.glColor3d(1, 0, 0);\n\t\tgl.glVertex3d(0, 0, 0);\n\t\tgl.glVertex3d(-1, 0, 0);\n\t\t//Line Positive Y - Green\n\t\tgl.glColor3d(0, 1, 0);\n\t\tgl.glVertex3d(0, 0, 0);\n\t\tgl.glVertex3d(0, 1, 0);\n\t\t//Line Negative Y - Green\n\t\tgl.glColor3d(0, 1, 0);\n\t\tgl.glVertex3d(0, 0, 0);\n\t\tgl.glVertex3d(0, -1, 0);\n\t\t//Line Positive Z - Blue\n\t\tgl.glColor3d(0, 0, 1);\n\t\tgl.glVertex3d(0, 0, 0);\n\t\tgl.glVertex3d(0, 0, 1);\n\t\t//Line Negative Z - Blue\n\t\tgl.glColor3d(0, 0, 1);\n\t\tgl.glVertex3d(0, 0, 0);\n\t\tgl.glVertex3d(0, 0, -1);\n\n\t\tgl.glEnd();\n\t}",
"abstract public void draw(Graphics2D g);",
"public void drawAxis(boolean x) {\n\n\t\tint stepPixels;\n\t\tfloat scale;\n\t\tif(x)\n\t\t{\n\t\t\tscale=this.drawnPlot.getScale().x;\n\t\t\tg.setColor(Color.green);\n\t\t\tGraphics2D g2 = (Graphics2D) g;\n\t\t\tg2.setStroke(new BasicStroke(2));\n\t\t\tg.drawLine((int)drawnPlot.getOffset().x-maxStepPixels*10, (int)drawnPlot.getOffset().y,(int)drawnPlot.getOffset().x+maxStepPixels*10,(int) drawnPlot.getOffset().y);\n\t\t}\n\t\telse\n\t\t{\n\t\t\tg.setColor(Color.green);\n\t\t\tGraphics2D g2 = (Graphics2D) g;\n\t\t\tg2.setStroke(new BasicStroke(2));\n\t\t\tg.drawLine((int)drawnPlot.getOffset().x, (int)drawnPlot.getOffset().y-maxStepPixels*10,(int)drawnPlot.getOffset().x,(int) drawnPlot.getOffset().y+maxStepPixels*10);\n\n\t\t\tscale=this.drawnPlot.getScale().y;\n\t\t}\n\t\t\n\t\tfloat actualStepSize = maxStepPixels /scale;//calc how much is the maximum step size in pixels in actual units\n\t\tint scaleOrder=(int)Math.floor(Math.log10(actualStepSize));//see the order of magnitude the actual step size is in; no loss from casting to int with floor\n\t\tfloat divisor=(float) Math.pow(10, scaleOrder);//convert the order of magnitude to the lowest number of that order (2-->100, 1-->10...)\n\t\tdouble correctedStepSize=actualStepSize-(actualStepSize%divisor);//round the actual step size down based on its order of magnitude (0.253-->0.2, 101-->100, 1523-->1000)\n\t\tstepPixels=(int)(correctedStepSize*scale);\n\t\t//System.out.println(\"stepPixels: \"+stepPixels);\n\t\t\n\t\t\n\t\tfor(int i=-10;i<10;i++)\n\t\t{\n\t\t\tint xCommon=(int) (stepPixels *i + drawnPlot\n\t\t\t\t\t.getOffset().x);\n\t\t\tint x1 = xCommon;\n\t\t\tint y1 = (int) (drawnPlot\n\t\t\t\t\t.getOffset().y);\n\t\t\tint x2 = xCommon;\n\t\t\t\n\t\t\tint y2 = (int) ( drawnPlot\n\t\t\t\t\t.getOffset().y+tickSize);\n\t\t\tGraphics2D g2 = (Graphics2D) g;\n\t\t\tg2.setStroke(new BasicStroke(1));\n\t\t\t\n\t\t\tString markTxt=Double.toString(correctedStepSize*i);\n\t\t\tmarkTxt=markTxt.substring(0, Math.min(markTxt.length(), 5));\n\t\t\tmarkTxt=markTxt.replaceAll(\"(.*?\\\\..*?)0+$\", \"$1\");\n\t\t\tchar[] markTxtCa=markTxt.toCharArray();\n\t\t\t//System.out.println(\"test: \"+\"30.0200\".replaceAll(\"(.*?\\\\..*?)0+$\", \"$1\"));\n\t\t\t\n\t\t\tif(x)\n\t\t\t{\n\t\t\t\t\tg.drawLine(x1, y1, x2, y2);\n\t\t\t\t\tg.drawChars(markTxtCa, 0, markTxtCa.length, xCommon, (int) (drawnPlot\n\t\t\t\t\t.getOffset().y+tickSize*2));\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\tg.drawLine((int)drawnPlot\n\t\t\t\t\t\t.getOffset().x, stepPixels*-i+(int)(int)drawnPlot\n\t\t\t\t\t\t.getOffset().y, (int)drawnPlot\n\t\t\t\t\t\t.getOffset().x+tickSize, (int)drawnPlot\n\t\t\t\t\t\t.getOffset().y+stepPixels*-i);\n\t\t\t\tg.drawChars(markTxtCa, 0, markTxtCa.length, \n\t\t\t\t\t\t(int)drawnPlot\n\t\t\t\t\t\t.getOffset().x+tickSize*2, stepPixels*-i+(int)(int)drawnPlot\n\t\t\t\t\t\t.getOffset().y\n\t\t\t\t\t\t\n\t\t\t\t\t\t);\n\t\t\t}\n\t\t\t\n\t\t\t//System.out.println(markTxt);\n\t\t\t\n\t\t}\n\t\t\n\t\t\n\t\t\n\t\t\n\t\t\n\t\t\n\t\t\n\t\t\n\t\t\n\t\t\n\t\t\n\t}",
"public void draw() {\r\n /* DO NOT MODIFY */\r\n StdDraw.point(x, y);\r\n }",
"public abstract void paint(Graphics2D graphics, float scale);",
"public abstract void draw(Graphics2D graphics);",
"public void paintComponent(Graphics g)\r\n {\r\n super.paintComponent(g); // Call JPanel's paintComponent method\r\n // to paint the background\r\n \r\n g.setColor(Color.black); \r\n \r\n width = getWidth() - leftSpace - rightSpace;\r\n height = getHeight() - upSpace - downSpace;\r\n \r\n Graphics2D g2 = (Graphics2D)g;\r\n \r\n //make 0,0 bottom left corner\r\n g2.translate(leftSpace, upSpace + height);\r\n\r\n fm = g2.getFontMetrics();\r\n \r\n drawXaxis(g2);\r\n drawYaxis(g2);\r\n \r\n //flip y axis\r\n g2.scale( 1, -1 );\r\n drawInside(g2);\r\n \r\n }",
"public void draw() {\n /* DO NOT MODIFY */\n StdDraw.point(x, y);\n }",
"public void draw() {\n /* DO NOT MODIFY */\n StdDraw.point(x, y);\n }",
"public void draw() {\n /* DO NOT MODIFY */\n StdDraw.point(x, y);\n }",
"public void draw() {\n /* DO NOT MODIFY */\n StdDraw.point(x, y);\n }",
"public abstract void draw( Graphics2D gtx );",
"public abstract void Draw(Graphics2D g, double zoomFactor);",
"public abstract void Draw(Graphics2D g, double zoomFactor);",
"public void draw(Graphics2D g, Dimension area);",
"@Override\n\tpublic void draw(Graphics2D g, int x, int y,int width,int height) {\n\n\t}",
"@Override\n\tpublic void draw(Graphics2D g2d) {\n\t\t\n\t}",
"public void drawOnCanvas(Graphics2D g2d, int x, int y){ \n FontMetrics fm = g2d.getFontMetrics(this.axisFont);\n g2d.setColor(Color.BLACK);\n g2d.setFont(axisFont);\n if(this.isAxisVertical==false){\n g2d.drawLine(x, y, x + this.axisLength, y);\n for(int loop = 0; loop < this.axisMarks.size(); loop++){\n double pos = this.getPosition( this.axisMarks.get(loop));\n g2d.drawLine((int) (x+pos), y-this.axisTickMarkLength, (int) (x+pos), y);\n int fw = fm.stringWidth(this.axisMarksString.get(loop));\n int fh = fm.getHeight();\n g2d.drawString(this.axisMarksString.get(loop), (int) (x+pos-fw*0.5), y + (int) (fh )); \n //System.out.println(\"drawing tick mark on \" + (int) pos);\n }\n int titleOffset = fm.getHeight();\n Rectangle2D rect = this.axisTitle.getBounds(g2d);\n //this.axisTitle.setFontSize(24);\n g2d.drawString(this.axisTitle.getText().getIterator(), \n (int) (x + this.axisLength*0.5 - rect.getWidth()*0.5),\n y + titleOffset + fm.getHeight());\n } else{\n \n int maxStringLength = 0; \n g2d.drawLine(x, y, x, y-this.axisLength);\n for(int loop = 0; loop < this.axisMarks.size();loop++){\n double pos = this.getPosition(this.axisMarks.get(loop));\n g2d.drawLine(x, (int) (y-pos), x+this.axisTickMarkLength, (int) (y-pos));\n int fw = fm.stringWidth(this.axisMarksString.get(loop));\n int fh = fm.getHeight();\n int fww = (int) (fw - fh*0.2);\n if(fww> maxStringLength){\n maxStringLength = fww;\n }\n g2d.drawString(this.axisMarksString.get(loop), (int) (x - fw - fh*0.2), (int) (y-pos+fh*0.35));\n }\n AffineTransform orig = g2d.getTransform();\n// g2d.rotate(-Math.PI/2);\n g2d.rotate(-Math.PI/2);\n //int yoffset = \n Rectangle2D rect = this.axisTitle.getBounds( g2d);\n int xt = (int) -(y-this.axisLength*0.5+rect.getWidth()*0.5);\n \n //System.out.println(\"Drawing Y - title \"); \n g2d.drawString(this.axisTitle.getText().getIterator(), xt, (int) (x - maxStringLength - fm.getHeight()));\n g2d.setTransform(orig);\n }\n }",
"public void Draw(Graphics2D g2d, Point mousePosition)\n {\n \n }",
"public void render (Graphics2D g);",
"@Override\n\tpublic void draw(Graphics2D g) {\n\t\t\n\t}",
"abstract void draw(Graphics g, int xoff, int yoff,\n int x, int y, int width, int height);",
"public abstract void render(Graphics2D graphics);",
"@Override\n\tpublic void draw() {\n\t\tSystem.out.println(\"绘制矩形\");\n\t\t\n\t}",
"public abstract void paint(Graphics2D g2d);",
"public void draw(Graphics2D g2, GregorianCalendar calendar);",
"void render(GraphicsContext gc, double xOffSet, double yOffSet);",
"private void drawAxes() {\n float margin = 90;\n\n //TODO tony va a hacer que el eje aparezca abajo\n //X rojo\n text(\"+X\",margin,-2,0);\n text(\"-X\",-margin,-2,0);\n stroke(210, 0, 0);\n line(-size,0,0,size,0,0);\n\n //Y verde\n text(\"-Z\",2,margin,0);\n text(\"+Z\",2,-margin,0);\n stroke(0, 210, 0);\n line(0,-size,0,0,size,0);\n\n //Z azul\n text(\"+Y\",5,0,margin);\n text(\"-Y\",5,0,-margin);\n stroke(0, 0, 210);\n line(0, 0, -size,0,0, size);\n }",
"void draw(Graphics g, int xoff, int yoff) {\n this.draw(g, xoff, yoff, 0, 0, this.getWidth(), this.getHeight());\n }",
"public void paint( VisualGraphComponent component, Graphics2D g2d );",
"@Override\n public void paintComponent(Graphics g) {\n super.paintComponent(g);\n\n Graphics2D g2 = (Graphics2D) g;\n g2.scale(2, 2);\n g2.setRenderingHint(RenderingHints.KEY_ANTIALIASING, RenderingHints.VALUE_ANTIALIAS_ON);\n g2.setColor(Color.WHITE);\n\n Application.grid.draw(g2);\n ui.draw(g2);\n }",
"public final void draw2D()\n {\n if ( GameLevel.current() != null )\n {\n //draw player's wearpon or gadget\n GameLevel.currentPlayer().drawWearponOrGadget();\n }\n\n //draw avatar message ( if active )\n AvatarMessage.drawMessage();\n\n //draw all hud messages\n HUDMessage.drawAllMessages();\n\n //draw fullscreen hud effects\n HUDFx.drawHUDEffects();\n\n //draw frames per second last\n Fps.draw();\n\n //draw ammo if the wearpon uses ammo\n if ( GameLevel.currentPlayer().showAmmoInHUD() )\n {\n drawAmmo();\n }\n\n //draw health\n drawHealth();\n\n //draw debug logs\n //Level.currentPlayer().drawDebugLog( g );\n }",
"protected void drawPlot()\n\t{\n \t\tfill(255);\n \t\tbeginShape();\n \t\tvertex(m_ViewCoords[0] - 1, m_ViewCoords[1] - 1);\n \t\tvertex(m_ViewCoords[2] + 1, m_ViewCoords[1] - 1);\n \t\tvertex(m_ViewCoords[2] + 1, m_ViewCoords[3] + 1);\n \t\tvertex(m_ViewCoords[0] - 1, m_ViewCoords[3] + 1);\n \t\tendShape(CLOSE);\n\t}",
"public void draw(Graphics2D g2) {\n super.draw(g2);\n }",
"@Override\n protected void drawAxisLine(final GraphicsContext gc, final double axisLength, final double axisWidth,\n final double axisHeight) {\n final double paddingX = getSide().isHorizontal() ? getAxisPadding() : 0.0;\n final double paddingY = getSide().isVertical() ? getAxisPadding() : 0.0;\n // for relative positioning of axes drawn on top of the main canvas\n final double axisCentre = getCenterAxisPosition();\n\n final double gradientWidth = getGradientWidth();\n\n // save css-styled line parameters\n final Path tickStyle = getMajorTickStyle();\n gc.save();\n gc.setStroke(tickStyle.getStroke());\n gc.setLineWidth(tickStyle.getStrokeWidth());\n\n if (getSide().isHorizontal()) {\n gc.setFill(new LinearGradient(0, 0, axisLength, 0, false, NO_CYCLE, getColorGradient().getStops()));\n } else {\n gc.setFill(new LinearGradient(0, axisLength, 0, 0, false, NO_CYCLE, getColorGradient().getStops()));\n }\n\n // N.B. important: translate by padding ie. canvas is +padding larger on\n // all size compared to region\n gc.translate(paddingX, paddingY);\n\n switch (getSide()) {\n case LEFT:\n // axis line on right side of canvas\n gc.fillRect(snap(axisWidth - gradientWidth), snap(0), snap(axisWidth), snap(axisLength));\n gc.strokeRect(snap(axisWidth - gradientWidth), snap(0), snap(axisWidth), snap(axisLength));\n break;\n case RIGHT:\n // axis line on left side of canvas\n gc.fillRect(snap(0), snap(0), snap(gradientWidth), snap(axisLength));\n gc.strokeRect(snap(0), snap(0), snap(gradientWidth), snap(axisLength));\n break;\n case TOP:\n // line on bottom side of canvas (N.B. (0,0) is top left corner)\n gc.fillRect(snap(0), snap(axisHeight - gradientWidth), snap(axisLength), snap(axisHeight));\n gc.strokeRect(snap(0), snap(axisHeight - gradientWidth), snap(axisLength), snap(axisHeight));\n break;\n case BOTTOM:\n // line on top side of canvas (N.B. (0,0) is top left corner)\n gc.rect(snap(0), snap(0), snap(axisLength), snap(gradientWidth));\n break;\n case CENTER_HOR:\n // axis line at the centre of the canvas\n gc.fillRect(snap(0), axisCentre * axisHeight - 0.5 * gradientWidth, snap(axisLength),\n snap(axisCentre * axisHeight + 0.5 * gradientWidth));\n gc.strokeRect(snap(0), axisCentre * axisHeight - 0.5 * gradientWidth, snap(axisLength),\n snap(axisCentre * axisHeight + 0.5 * gradientWidth));\n break;\n case CENTER_VER:\n // axis line at the centre of the canvas\n gc.fillRect(snap(axisCentre * axisWidth - 0.5 * gradientWidth), snap(0),\n snap(axisCentre * axisWidth + 0.5 * gradientWidth), snap(axisLength));\n gc.strokeRect(snap(axisCentre * axisWidth - 0.5 * gradientWidth), snap(0),\n snap(axisCentre * axisWidth + 0.5 * gradientWidth), snap(axisLength));\n break;\n default:\n break;\n }\n gc.restore();\n }",
"@Override\n\tpublic void draw(Graphics2D g) {\n\t\tImage pic = Toolkit.getDefaultToolkit().getImage(\"Space.png\");\n g.drawImage(pic, x, y, width, height, null);\n\t\t\n\t}",
"public void draw(Graphics g, int x0, int y0, int scale){\r\n\t\tif(!this.visible){\r\n\t\t\treturn;\r\n\t\t}\r\n\t\tg.setColor(Color.cyan);\r\n\t\tg.fillOval(x0 + this.getX() * scale, y0 + this.getY() * scale, 20, 20);\r\n\t}",
"public void Draw(Graphics2D g2d)\n {\n this.Update();\n \n for (int i = 0; i < xPositions.length; i++)\n {\n g2d.drawImage(image, (int)xPositions[i], yPosition, null);\n }\n }",
"public void drawXaxis(Graphics2D g)\r\n { \r\n //draw x axis\r\n g.drawLine(0, 0, width, 0);\r\n \r\n //scale x axis\r\n for (double i = 0; i <= xRange; i += xScale)\r\n {\r\n int xPix = xPixScale(i);\r\n g.drawLine( xPix, -dWidth, xPix, dWidth );\r\n String numLabel = Fun.round(i + xStart, scaleSigFig) + \"\";\r\n drawStringX( numLabel, xPix, dWidth + 1, g);\r\n }\r\n \r\n //label x axis\r\n drawStringX(xName, width/2 - 5, dWidth + 12, g);\r\n \r\n }",
"public abstract void paint(Graphics2D g);",
"@Override\n\tpublic void draw(Graphics2D g2d, int cx1, int cy1, int cx2, int cy2) {\n\t\tthis.drawX = this.x - cx1;\n\t\tthis.drawY = this.y - cy1;\n\t\t\n\t\t//System.out.println(\" x: \"+x+\" y: \"+y+\" drawx : \"+this.drawX +\" drawY: \"+this.drawY);\n\t\ts.setDrawX(drawX);\n\t\ts.setDrawY(drawY);\n\t\t\n\t\ts.draw(g2d);\n\t\t\n\t}",
"void draw(GraphicsContext context);",
"private void drawAxis(final Graphics g, final boolean drawX) {\r\n final int h = getHeight();\r\n final int w = getWidth();\r\n g.setColor(GUIConstants.color1);\r\n \r\n final int novalue = noValueSize();\r\n final int textH = g.getFontMetrics().getHeight();\r\n // the painting space provided for items which lack no value\r\n final int pWidth = plotWidth - novalue;\r\n final int pHeight = plotHeight - novalue;\r\n \r\n final ScatterAxis axis = drawX ? scatterData.xAxis : scatterData.yAxis;\r\n // drawing horizontal axis line\r\n if(drawX) {\r\n g.drawLine(MARGIN[1], h - MARGIN[2], w - MARGIN[3], h - MARGIN[2]);\r\n if(plotChanged) axis.calcCaption(pWidth);\r\n } else {\r\n // drawing vertical axis line\r\n g.drawLine(MARGIN[1], MARGIN[0], MARGIN[1], getHeight() - MARGIN[2]);\r\n if(plotChanged) axis.calcCaption(pHeight);\r\n }\r\n \r\n final boolean numeric = axis.numeric;\r\n final int nrCaptions = axis.nrCaptions;\r\n final double step = axis.captionStep;\r\n final double range = 1.0d / (nrCaptions - 1);\r\n final int fs = GUIProp.fontsize;\r\n \r\n g.setFont(GUIConstants.font);\r\n for(int i = 0; i < nrCaptions; i++) {\r\n String caption = \"\";\r\n if(numeric) {\r\n final double min = axis.min;\r\n final double captionValue = i == nrCaptions - 1 ? axis.max : \r\n min + (i * step);\r\n \r\n caption = formatString(captionValue, drawX);\r\n \r\n // category data, each category is displayed as a caption \r\n } else {\r\n caption = string(axis.cats[i]);\r\n }\r\n \r\n // if assignment consists of more than 10 characters the caption string\r\n // is chopped to the length 10 to avoid layout issues\r\n if(caption.length() > 10) {\r\n caption = caption.substring(0, 10);\r\n caption += \"...\";\r\n }\r\n \r\n // caption labels are rotated, for both x and y axis. first a buffered\r\n // image is created which displays the rotated label ...\r\n final int imgW = BaseXLayout.width(g, caption) + fs;\r\n final int imgH = 160;\r\n final BufferedImage img = new BufferedImage(imgW, imgH, \r\n Transparency.BITMASK);\r\n Graphics2D g2d = img.createGraphics();\r\n g2d.setRenderingHint(RenderingHints.KEY_ANTIALIASING, \r\n RenderingHints.VALUE_ANTIALIAS_ON);\r\n g2d.rotate(ROTATE, imgW, 0 + textH);\r\n g2d.setFont(GUIConstants.font);\r\n g2d.setColor(Color.black);\r\n g2d.drawString(caption, fs, fs);\r\n \r\n // ... after that\r\n // the image is drawn beside x / y axis\r\n g.setColor(GUIConstants.color1);\r\n if(drawX) {\r\n final int x = MARGIN[1] + novalue + (int) (i * range * pWidth);\r\n final int y = h - MARGIN[2];\r\n g.drawImage(img, x - imgW + textH - fs, y + fs / 4, this);\r\n g.drawLine(x, MARGIN[0], x, y + fs / 2);\r\n } else {\r\n final int y = h - MARGIN[2] - novalue - (int) (i * range * pHeight);\r\n g.drawImage(img, MARGIN[1] - imgW - fs, y - fs, this);\r\n g.drawLine(MARGIN[1] - fs / 2, y, w - MARGIN[3], y);\r\n }\r\n }\r\n }",
"@Override\n\tpublic void paintComponent(Graphics g) {\n\t\tsuper.paintComponent(g);\n\n\t\tg.setColor(Color.BLACK);\n\n\t\tg.setFont(numFont);\n\n\t\tif (param.showaxis) {\n\t\t\t// pixels\n\t\t\tint actualcenterx = (int) math.Math.scale(0, param.minx, param.maxx, 0, getWidth());\n\t\t\tint actualcentery = (int) math.Math.scale(0, param.miny, param.maxy, getHeight(), 0);\n\n\t\t\tg.drawLine(actualcenterx, 0, actualcenterx, getHeight());\n\t\t\tg.drawLine(0, actualcentery, getWidth(), actualcentery);\n\t\t\tg.drawString(0 + \"\", actualcenterx - xoffset, actualcentery + yoffset);\n\n\t\t\tg.drawString(param.maxx + \"\", getWidth() - xoffset * (param.maxx + \"\").length(), actualcentery + yoffset);\n\t\t\tg.drawString(param.minx + \"\", 0, actualcentery + yoffset);\n\t\t\tg.drawString(param.maxy + \"\", actualcenterx - xoffset * (param.maxy + \"\").length(), yoffset);\n\t\t\tg.drawString(param.miny + \"\", actualcenterx - xoffset * (param.miny + \"\").length(), getHeight() - yoffset);\n\t\t}\n\n\t\tfor (UIPointSet pointSet : pointSets) {\n\n\t\t\tint prevpx = 0, prevpy = 0;\n\t\t\tfor (int i = 0; i < pointSet.getPoints().length; i++) {\n\n\t\t\t\tdouble[] point = pointSet.getPoints()[i];\n\t\t\t\t// pixels\n\t\t\t\tint px = (int) math.Math.scale(point[0], param.minx, param.maxx, 0, getWidth());\n\t\t\t\tint py = (int) math.Math.scale(point[1], param.miny, param.maxy, getHeight(), 0);\n\n\t\t\t\tif (pointSet.getPointColor() != null) {\n\t\t\t\t\tint pointWidth = 10;\n\t\t\t\t\tg.setColor(pointSet.getPointColor());\n\t\t\t\t\tg.fillOval(px - pointWidth / 2, py - pointWidth / 2, pointWidth, pointWidth);\n\t\t\t\t}\n\n\t\t\t\tif (pointSet.getLineColor() != null && i > 0) {// if (Math.abs(y2 - y) < (getHeight())) {\n\t\t\t\t\tg.setColor(pointSet.getLineColor());\n\t\t\t\t\tg.drawLine(prevpx, prevpy, px, py);\n\t\t\t\t\tfor (int ii = 1; ii < 2; ii++) {\n\t\t\t\t\t\tg.drawLine(prevpx, prevpy - ii, px, py - ii);\n\t\t\t\t\t\tg.drawLine(prevpx, prevpy + ii, px, py + ii);\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tprevpx = px;\n\t\t\t\tprevpy = py;\n\n\t\t\t}\n\t\t}\n\n\t\tfor (PointBox bx : savedBoxes) {\n\t\t\tbx.updatePixCoordinate();\n\t\t\tg.setColor(bx.pointSet.getPointColor());\n\t\t\tbx.paint(g, clickingmBox && mBox.equals(bx), false);\n\t\t}\n\t\tif (showmBox) {\n\t\t\tint index = savedBoxes.indexOf(mBox);\n\t\t\tg.setColor(mBox.pointSet.getPointColor());\n\t\t\tif (index < 0) {\n\t\t\t\tmBox.paint(g, clickingmBox, false);\n\t\t\t} else {\n\t\t\t\tsavedBoxes.get(index).paint(g, clickingmBox, true);\n\t\t\t}\n\t\t\t// now draw the box (top left)\n\t\t\tint corneroffset = 10;\n\t\t\tString eqS = \"y = \" + mBox.pointSet.getTitle();\n\t\t\tString fnumS = pointSets.indexOf(mBox.pointSet) + \"\";\n\n\t\t\tint boxx = corneroffset + 10;\n\t\t\tint boxy = corneroffset;\n\t\t\tint boxw = eqS.length() * (xoffset - 4) + 8 + corneroffset;\n\t\t\tint boxh = yoffset + corneroffset;\n\n\t\t\tg.clearRect(boxx, boxy, boxw, boxh);\n\n\t\t\tg.drawString(eqS, xoffset + corneroffset, yoffset + corneroffset);\n\n\t\t\tg.setFont(subFont);\n\t\t\tg.drawString(fnumS, xoffset * 2 + corneroffset, (yoffset * 4 / 3) + corneroffset);\n\n\t\t\tg.drawRect(boxx, boxy, boxw, boxh);\n\n\t\t}\n\t}",
"private void setup2DGraphics() {\n\n\t\tGL11.glMatrixMode(GL11.GL_PROJECTION);\n\t\tGL11.glLoadIdentity();\n\t\tGL11.glOrtho(0, width, 0, height, 1, -1);\n\t\tGL11.glMatrixMode(GL11.GL_MODELVIEW);\n\t\tGL11.glLoadIdentity();\n\t}",
"public void draw(Graphics window);",
"protected abstract void plot2d( int px, int py, double z, int istyle );",
"public void draw(Graphics g);",
"public void draw(Graphics g);",
"public void draw(Graphics2D g2){\n g2.setColor(color);\n g2.fillOval(x,y, w, w);\n }",
"public void draw (Graphics g, int x, int y)\r\n {\r\n\tmakeRGBImage().draw (g, x, y);\r\n }",
"public abstract void draw(java.awt.Graphics canvas);",
"@Override\r\n public void paintComponent(Graphics g)\r\n {\n Graphics2D g2 = (Graphics2D) g;\r\n \r\n Ellipse2D.Double ellipse = new Ellipse2D.Double(10, 50, 10, 10);\r\n \r\n g2.draw(ellipse);\r\n \r\n ellipse.x += 20;\r\n g2.draw(ellipse);\r\n \r\n ellipse.x += 20;\r\n g2.draw(ellipse);\r\n \r\n ellipse.x += 20;\r\n g2.draw(ellipse);\r\n }",
"public void drawYaxis(Graphics2D g)\r\n { \r\n //draw y axis\r\n g.drawLine( 0, 0, 0, -height );\r\n \r\n //scale y axis\r\n for (double i = 0; i <= yRange; i += yScale)\r\n {\r\n int yP = -yPixScale(i);\r\n g.drawLine(-dWidth, yP, dWidth, yP);\r\n String numLabel = Fun.round( (i + yStart), scaleSigFig ) + \"\";\r\n drawStringY( numLabel, -dWidth - 1, yP, g );\r\n }\r\n \r\n //label y axis, and the label has to be sideways\r\n \r\n //orig = the way g is oriented right now\r\n AffineTransform orig = g.getTransform();\r\n \r\n //move g and display the label\r\n g.translate( -leftSpace/2 - 10, -height/2 );\r\n g.rotate(-Math.PI / 2); //-90 degrees\r\n drawStringX(yName, 0, 0, g);\r\n\r\n //move g back\r\n g.setTransform(orig);\r\n }",
"public void draw(Graphics2D g){\r\n g.setColor(Color.WHITE);\r\n g.setStroke(new BasicStroke(1));\r\n g.draw(new Line2D.Float(p1, p2));\r\n }",
"public void paintComponent(Graphics g) {\n\n super.paintComponent(g); //Paint background\n Graphics2D g2 = (Graphics2D) g; //Cast Graphics object to Graphics2D\n\n g2.setRenderingHint(RenderingHints.KEY_ANTIALIASING,\n RenderingHints.VALUE_ANTIALIAS_ON);\n Dimension d = getSize();\n\n //Defines the corners of the plot area in pixels\n int iMin = (int) (PA_XO * d.width);\n int iMax = (int) ((PA_XO + PA_XS) * d.width);\n int jMin = (int) (PA_YO * d.height);\n int jMax = (int) ((PA_YO + PA_YS) * d.height);\n\n //Define the scaling between the plot area in x-y and the plot area in pixels\n double xScale = (double) (iMax - iMin) / (xMax - xMin);\n double yScale = (double) (jMax - jMin) / (yMax - yMin);\n\n //Draws x-axis and y-axis\n g2.setColor(Color.black); //Sets color of axes to black\n g2.draw(new Rectangle2D.Double(PA_XO * d.width, PA_YO * d.height,\n PA_XS * d.width, PA_YS * d.height));\n\n double ix;\n double iy;\n for (int i = 0; i < nPts; i++) {\n //Draws the points (JPanel y starts at TOP of the panel)\n ix = iMin + ((x[i] - xMin) * xScale);\n iy = jMax - ((y[i] - yMin) * yScale);\n g2.setColor(Color.red); //Sets color of data points to red\n g2.fill(new Ellipse2D.Double(ix - dotSize / 2., iy - dotSize / 2.,\n dotSize, dotSize));\n\n }\n\n // Adds labels of xMin, xMax, yMin, yMax to drawing and positions them on the screen\n // String.valueOf(xMin) turns the number xMin into a String that you can draw.\n g2.setColor(Color.black);\n g2.drawString(\"Input Size (n)\", (float) (PA_XO * d.width + 150),\n (float) ((PA_YO + PA_YS) * d.height + 20));\n g2.drawString(\"Time (ms)\", (float) (PA_XO * d.width - 70),\n (float) ((PA_YO + PA_YS) * d.height - 200));\n g2.drawString(String.valueOf(xMin), (float) (PA_XO * d.width - 10.),\n (float) ((PA_YO + PA_YS) * d.height + 15.));\n g2.drawString(String.valueOf(xMax),\n (float) ((PA_XO + PA_XS) * d.width - 20.),\n (float) ((PA_YO + PA_YS) * d.height + 15.));\n g2.drawString(String.valueOf(yMin), (float) (PA_XO * d.width - 50.),\n (float) ((PA_YO + PA_YS) * d.height + 5.));\n g2.drawString(String.valueOf(yMax), (float) (PA_XO * d.width - 50.),\n (float) (PA_YO * d.height + 5.));\n }",
"public void draw() {\n StdDraw.clear();\n StdDraw.setPenColor(StdDraw.BLACK);\n StdDraw.setXscale(-drawLength * 0.1, drawLength * 1.2);\n StdDraw.setYscale(-drawLength * 0.65, drawLength * 0.65);\n StdDraw.line(0, 0, drawLength, 0);\n StdDraw.text(-drawLength * 0.05, 0, \"0\");\n StdDraw.text(drawLength * 1.1, 0, Integer.toString(size()));\n }",
"public void draw(Graphics g) {\r\n\t\t\r\n\t}",
"final void drawobj(java.awt.Graphics g) {\n\t\tdraw(g, Engine.scaleX(x), Engine.scaleY(y));\n\t}",
"public void draw(Graphics g) {\n\t\t\n\t}",
"public void draw() {\n drawBox();\n if (root == null) {\n return;\n }\n\n draw(root, ORIENTATION_VERTICAL);\n }",
"public void draw(Graphics graphics);",
"@Override\n\tpublic void draw() {\n\t\tSystem.out.println(\"绘制三角形\");\t\n\t}",
"void draw(Graphics g, float interp) {\n float x = (float)(Math.sin(angle.x) * amplitude.x);\n //Oscillating on the y-axis\n float y = (float) (Math.sin(angle.y) * amplitude.y);\n \n // Translate (x + width/2)\n x += 250; \n y += 250;\n \n //Drawing the Oscillator as a line connecting a circle \n// g.setColor(Color.BLACK);\n// g.drawLine(250,250, (int)x + 8,(int) y + 8);\n g.setColor(bobColor);\n g.fillOval((int)x,(int) y, 20, 20);\n g.setColor(Color.black);\n g.drawOval((int)x,(int) y, 20, 20);\n }",
"@Override\n\tvoid draw(Graphics2D g2) {\n\t\t// TODO Auto-generated method stub\n\t\tg2.setColor(color);\n\t\tPoint2D.Double from = new Point2D.Double(this.getXPos(), this.getYPos());\n\t\tPoint2D.Double to = new Point2D.Double(x2, y2);\n\t\tsegment = new Line2D.Double(from, to);\n\t\tg2.drawLine((int) this.getXPos() - 8, (int) this.getYPos() - 96, (int) x2 - 8, (int) y2 - 96);\n\n\t}",
"@Override\n\tpublic void draw(Graphics2D g2d) {\n\t\ts.draw(g2d);\n\t}",
"public void draw() {\n StdDraw.setPenColor(StdDraw.BLACK);\n StdDraw.setPenRadius(0.01);\n for (Point2D point : points) {\n StdDraw.point(point.x(), point.y());\n }\n StdDraw.setPenRadius();\n }",
"public void draw(Graphics g) {\n\t\t\r\n\t}",
"public void draw(Graphics g){\n\t}",
"protected abstract void paintCoordinates(Graphics2D g);",
"public AxisRenderer2D( final AxisConfig<Q> conf )\r\n\t{\r\n\t\tthis.config = conf;\r\n\t}",
"public void paint(Graphics g)\n\t{\n\t\tg.drawString(mouse.mouse.toString(), 500, 20);\n\t\t\n\t\tg.setColor(Color.black);\n\t\tPosition.drawAxis(g, 1);\n\t\tg.drawString(\"FPS: \"+thread.Engine.fps,10,20);\n\t\tg.drawString(\"FPSSCR: \"+fpsscr,10,40);\n\t\t\n\t\tEngine.ball1.drawFill(g);\n\t\t//Engine.ball1.drawVelocity(g);\n\t\tEngine.ball2.draw(g);\n\t\t//Engine.ball2.drawVelocity(g);\n\t\tEngine.plane1.draw(g, 1000);\n\t\tEngine.plane2.draw(g, 1000);\n\t\tEngine.plane3.draw(g, 1000);\n\t\tEngine.plane4.draw(g, 1000);\n\t\t\n\t\tmouse.mouse.draw(g, 1);\n\t\t\n\t\tupdatefps();\n\t}",
"private void drawVerticalAxisLabels(Graphics2D g2) {\r\n double axisV = xPositionToPixel(originX);\r\n\r\n// double startY = Math.floor((minY - originY) / majorY) * majorY;\r\n double startY = Math.floor(minY / majorY) * majorY;\r\n for (double y = startY; y < maxY + majorY; y += majorY) {\r\n if (((y - majorY / 2.0) < originY) &&\r\n ((y + majorY / 2.0) > originY)) {\r\n continue;\r\n }\r\n \r\n int position = (int) yPositionToPixel(y);\r\n g2.drawString(format(y), (int) axisV + 5, position);\r\n }\r\n }",
"public void draw(Graphics g) {\n sprite.draw(g, (int) x, (int) y);\n }",
"@Override\n public void draw(GraphicsContext gc, int sides){}",
"abstract public void draw(Graphics g);",
"@Override\n public void draw(Graphics g) {\n g.setColor(this.getColor());\n g.drawLine(left, axisY, right, axisY);\n\n // Draw string to the left of the plot labeling the height of this axis\n g.setColor(LABEL_COLOR);\n g.setFont(LABEL_FONT);\n FontMetrics metric = g.getFontMetrics(LABEL_FONT);\n int width = metric.stringWidth(label);\n int height = metric.getAscent();\n int x = left - 8 - width;\n int y = axisY + (height / 2) - 1;\n g.drawString(label, x, y);\n }",
"public void draw(Graphics g) {\n\t\tGraphics2D g2d = (Graphics2D) g;\n\t\tg2d.setRenderingHint(RenderingHints.KEY_ANTIALIASING,\n\t\t\t\tRenderingHints.VALUE_ANTIALIAS_ON);\n\n\t\tg2d.setColor(Color.WHITE);\n\t\tg2d.fillOval(this.x1 - 5, this.y1 - 10, 40, 30);\n\t\tg2d.setColor(Color.BLACK);\n\t\tg2d.drawOval(this.x1 - 5, this.y1 - 10, 40, 30);\n\t\t/*\n\t\t * drawXiaBiao(g, this.x1 + 5, this.y1 + this.y2 / 2 -\n\t\t * img.getHeight(observer) + 12, this.getNumber());\n\t\t */\n\n\t\tdrawXiaBiao(g, this.x1, this.y1 + this.y2 / 4, this.getNumber());\n\t}",
"public void draw() {\n\t\tif (fill) {\n\t\t\tapplet.noStroke();\n\t\t\tapplet.fill(color);\n\t\t} else {\n\t\t\tapplet.noFill();\n\t\t\tapplet.stroke(color);\n\t\t}\n\t\tapplet.rect(position.x, position.y, size.x, size.y);\n\t\tsliderButton.draw(new PVector(-10,0));\n\t}",
"public void draw(Graphics2D g2) {\r\n\tif (!bustedWall) {\r\n\t\tg2.setColor(new Color(0, 0, 0)); \r\n\t\tSystem.out.println(\"black\"); // for testing purposes\r\n\t}else {\r\n\t\tg2.setColor(new Color(255,255,255)); \r\n\t\tSystem.out.println(\"white\"); // for testing purposes\r\n\t}\r\n\tg2.drawLine(x1, y1, x2, y2); \r\n\t// print the untranslated coordinates for testing purposes\r\n\tSystem.out.println(String.format(\"%d,%d,%d,%d\",x1 - TRANSLATION ,y1 - TRANSLATION,x2 - TRANSLATION,y2 - TRANSLATION));\r\n}",
"public void draw(Graphics g) {\r\n\t\tg.setColor(Color.RED);\r\n\t\tg.fillRect(xcoord * width, ycoord * height, width, height);\r\n\t}",
"public abstract void draw(Graphics g);",
"public abstract void draw(Graphics g);",
"public abstract void draw(Graphics g);",
"public abstract void draw(Graphics g);",
"public void draw() {\n \n // TODO\n }",
"protected abstract void paintVectors(Graphics2D g);",
"public void draw() {\n\t\tp.pushStyle();\n\t\t{\n\t\t\tp.rectMode(PConstants.CORNER);\n\t\t\tp.fill(360, 0, 70, 180);\n\t\t\tp.rect(60f, 50f, p.width - 110f, p.height * 2f * 0.33f - 50f);\n\t\t\tp.rect(60f, p.height * 2f * 0.33f + 50f, p.width - 110f, p.height * 0.33f - 130f);\n\t\t}\n\t\tp.popStyle();\n\n\t\tlineChart.draw(40f, 40f, p.width - 80f, p.height * 2f * 0.33f - 30f);\n\t\tlineChart2.draw(40f, p.height * 2f * 0.33f + 45f, p.width - 80f, p.height * 0.33f - 110f);\n\t\t//p.line(x1, y1, x2, y2);\n\n\t}",
"private void drawBox(Graphics2D g)\n\t{\n\t\t// Resize values with magic numbers\n\t\tLine2D.Double line = new Line2D.Double();\n\t\tStroke drawingStroke = new BasicStroke(3, BasicStroke.CAP_ROUND, BasicStroke.JOIN_ROUND);\t\t\n\t\tg.setStroke(drawingStroke);\n\t\tmidBoxWidth = super.getWidth() - 234;\n\t\tmidBoxHeight = super.getHeight() - 55;\n\t\tORIGIN_X = MID_BOX_X + AXIS_X_GAP;\n\t\tORIGIN_Y = MID_BOX_Y + midBoxHeight - AXIS_X_GAP;\n\n\t\t/**\n\t\t * Super hard coded for now \n\t\t */\n\n\t\t// White background\n\t\tRectangle2D middle = new Rectangle2D.Double(MID_BOX_X, MID_BOX_Y, midBoxWidth, midBoxHeight);\t\t\n\t\tg.setColor(Color.white);\n\t\tg.fill(middle);\n\t\t// Drawing borders\n\t\tg.setColor(Color.black);\n\t\t// Top\n\t\tline.setLine(MID_BOX_X, MID_BOX_Y, MID_BOX_X + midBoxWidth, MID_BOX_Y);\n\t\tg.draw(line);\n\t\t// Left\n\t\tline.setLine(MID_BOX_X, MID_BOX_Y, MID_BOX_X, MID_BOX_Y + midBoxHeight);\n\t\tg.draw(line);\n\t\t// Bottom\n\t\tline.setLine(MID_BOX_X, MID_BOX_Y + midBoxHeight, MID_BOX_X + midBoxWidth, MID_BOX_Y + midBoxHeight);\n\t\tg.draw(line);\n\t\t// Right\n\t\tline.setLine(MID_BOX_X + midBoxWidth, MID_BOX_Y, MID_BOX_X + midBoxWidth, MID_BOX_Y + midBoxHeight);\n\t\tg.draw(line);\n\n\t\t// Drawing Axes\n\t\tdrawingStroke = new BasicStroke(2, BasicStroke.CAP_BUTT, BasicStroke.JOIN_ROUND);\n\t\tg.setStroke(drawingStroke);\n\t\t// Y-axis\n\t\tline.setLine(MID_BOX_X + AXIS_X_GAP, MID_BOX_Y + AXIS_Y_GAP/2, MID_BOX_X + AXIS_X_GAP, MID_BOX_Y + midBoxHeight - AXIS_Y_GAP/2);\n\t\tg.draw(line);\t\n\n\t\t// Arrow Tip\n\t\tline.setLine(MID_BOX_X + AXIS_X_GAP, MID_BOX_Y + AXIS_Y_GAP/2, MID_BOX_X + AXIS_X_GAP + 10, MID_BOX_Y + AXIS_Y_GAP/2 + 15);\n\t\tg.draw(line);\t\t\t\n\t\tline.setLine(MID_BOX_X + AXIS_X_GAP, MID_BOX_Y + AXIS_Y_GAP/2, MID_BOX_X + AXIS_X_GAP - 10, MID_BOX_Y + AXIS_Y_GAP/2 + 15);\n\t\tg.draw(line);\t\n\n\t\t// X-axis\n\t\tline.setLine(MID_BOX_X + AXIS_Y_GAP/2, MID_BOX_Y + midBoxHeight - AXIS_X_GAP, MID_BOX_X + midBoxWidth - AXIS_Y_GAP/2, MID_BOX_Y + midBoxHeight - AXIS_X_GAP);\n\t\tg.draw(line);\n\t\t// Arrow tip\n\t\tline.setLine(MID_BOX_X + midBoxWidth - AXIS_Y_GAP/2, MID_BOX_Y + midBoxHeight - AXIS_X_GAP, MID_BOX_X + midBoxWidth - AXIS_Y_GAP/2 - 15, MID_BOX_Y + midBoxHeight - AXIS_X_GAP + 10);\n\t\tg.draw(line);\t\t\t\n\t\tline.setLine(MID_BOX_X + midBoxWidth - AXIS_Y_GAP/2, MID_BOX_Y + midBoxHeight - AXIS_X_GAP, MID_BOX_X + midBoxWidth - AXIS_Y_GAP/2 - 15, MID_BOX_Y + midBoxHeight - AXIS_X_GAP - 10);\n\t\tg.draw(line);\t\n\n\t\tnew BasicStroke(2, BasicStroke.CAP_ROUND, BasicStroke.JOIN_ROUND);\n\t\tg.setStroke(drawingStroke);\n\n\t\t// Axis labels\n\t\tg.setColor(Color.black);\n\t\tg.rotate(Math.toRadians(-90));\n\n\t\t// Magic numbers - even I don't know what they are but they somehow centres the text\n\t\tswitch (graph) {\n\t\tcase ARRIVAL: {\n\t\t\tg.drawString(\"Total arrivals per interval (cars)\", -midBoxHeight/2 - 80, MID_BOX_X + 16);\n\t\t\tbreak;\n\t\t}\n\t\tcase MAX_QUEUE_TIME: {\n\t\t\tg.drawString(\"Max Queue Time (seconds)\", -midBoxHeight/2 - 70, MID_BOX_X + 16);\n\t\t\tbreak;\n\t\t}\n\t\tcase AVG_QUEUE_TIME: {\n\t\t\tg.drawString(\"Average Queue Time (seconds)\", -midBoxHeight/2 - 80, MID_BOX_X + 16);\n\t\t\tbreak;\n\t\t}\n\t\tdefault:\n\t\t\tbreak;\n\t\t}\n\t\tg.rotate(Math.toRadians(90));\n\t\tg.drawString(\"Time Interval (minutes)\", MID_BOX_X + midBoxWidth/2 - 50, MID_BOX_Y + midBoxHeight - AXIS_Y_GAP/2 + 18);\n\t}",
"public void draw(Graphics g) {\n g.setColor(Color.red);\r\n //g2d.rotate(Math.toRadians(degree), restX-X_SIZE/2 , restY-Y_SIZE/2 );\r\n g.fillOval(deltaX-xSize/2, deltaY-ySize/2, xSize, ySize);\r\n //g2d.setTransform(old);\r\n }",
"public AxisState draw(Graphics2D g2, double cursor, Rectangle2D plotArea, Rectangle2D dataArea, RectangleEdge edge, PlotRenderingInfo plotState) {\n/* 1855 */ if (!isVisible()) {\n/* 1856 */ AxisState state = new AxisState(cursor);\n/* */ \n/* */ \n/* 1859 */ List ticks = refreshTicks(g2, state, dataArea, edge);\n/* 1860 */ state.setTicks(ticks);\n/* 1861 */ return state;\n/* */ } \n/* */ \n/* */ \n/* 1865 */ AxisState state = drawTickMarksAndLabels(g2, cursor, plotArea, dataArea, edge);\n/* */ \n/* */ \n/* */ \n/* */ \n/* 1870 */ if (getAttributedLabel() != null) {\n/* 1871 */ state = drawAttributedLabel(getAttributedLabel(), g2, plotArea, dataArea, edge, state);\n/* */ }\n/* */ else {\n/* */ \n/* 1875 */ state = drawLabel(getLabel(), g2, plotArea, dataArea, edge, state);\n/* */ } \n/* 1877 */ createAndAddEntity(cursor, state, dataArea, edge, plotState);\n/* 1878 */ return state;\n/* */ }",
"@Override\r\n\tpublic void draw() {\n\t\tPoint p = this.getP();\r\n\t\tint start_point = p.getX();\r\n\t\tint end_point = p.getY();\r\n\t\t\r\n\t\tint width = this.getWidth();\r\n\t\tint height = this.getHeight();\r\n\t\t\r\n\t\tSystem.out.println(\"�l�p�`��`�� �_(\" + start_point +\",\"+ end_point + \")����Ƃ��āA��\"+ width +\"����\"+ height +\"�̎l�p�`\");\r\n\t}",
"private void drawPlot(Graphics2D g2, Plot equation) {\r\n float x = 0.0f;\r\n float y = (float) yPositionToPixel(equation.compute(xPixelToPosition(0.0)));\r\n \r\n GeneralPath path = new GeneralPath();\r\n path.moveTo(x, y);\r\n \r\n float width = getWidth();\r\n for (x = 0.0f; x < width; x += 1.0f) {\r\n double position = xPixelToPosition(x);\r\n y = (float) yPositionToPixel(equation.compute(position));\r\n path.lineTo(x, y);\r\n }\r\n \r\n g2.draw(path);\r\n }",
"protected void setupGraphics(Graphics2D g2) {\r\n g2.setRenderingHint(RenderingHints.KEY_ANTIALIASING,\r\n RenderingHints.VALUE_ANTIALIAS_ON);\r\n }"
]
| [
"0.7340089",
"0.72833765",
"0.6485567",
"0.6459479",
"0.64534444",
"0.6433714",
"0.6375832",
"0.63129705",
"0.63039994",
"0.62715155",
"0.62271774",
"0.622516",
"0.6219698",
"0.62154984",
"0.6203003",
"0.6203003",
"0.6203003",
"0.6203003",
"0.6202943",
"0.6167947",
"0.6167947",
"0.61426926",
"0.61164576",
"0.611625",
"0.6028336",
"0.60283023",
"0.6013157",
"0.60006267",
"0.5989151",
"0.58610857",
"0.5851925",
"0.5841851",
"0.5820058",
"0.58045006",
"0.5802218",
"0.58006513",
"0.5787886",
"0.57618797",
"0.5759058",
"0.5748813",
"0.5747574",
"0.5713259",
"0.5708237",
"0.5704902",
"0.5702851",
"0.5701747",
"0.56819427",
"0.5681535",
"0.5673768",
"0.56692046",
"0.5663911",
"0.566299",
"0.5661818",
"0.5652752",
"0.56174946",
"0.56174946",
"0.5595068",
"0.5593755",
"0.5593742",
"0.55885816",
"0.5587656",
"0.55813015",
"0.55793166",
"0.55792576",
"0.55769944",
"0.5572157",
"0.55684704",
"0.5566619",
"0.5558656",
"0.5535776",
"0.55325335",
"0.55229956",
"0.55179614",
"0.5508355",
"0.55058914",
"0.5504191",
"0.5499687",
"0.5494374",
"0.5492587",
"0.54772854",
"0.5476393",
"0.54735297",
"0.54676646",
"0.54643476",
"0.5459815",
"0.5458074",
"0.54494494",
"0.5449144",
"0.54442436",
"0.54442436",
"0.54442436",
"0.54442436",
"0.5436821",
"0.54347676",
"0.54312265",
"0.5428118",
"0.5413032",
"0.54095393",
"0.54087335",
"0.54036355",
"0.539335"
]
| 0.0 | -1 |
/ JADX WARNING: inconsistent code. / Code decompiled incorrectly, please refer to instructions dump. | public org.jivesoftware.smackx.xdata.packet.DataForm parse(org.xmlpull.v1.XmlPullParser r6, int r7) {
/*
r5 = this;
r0 = "";
r1 = "type";
r0 = r6.getAttributeValue(r0, r1);
r0 = org.jivesoftware.smackx.xdata.packet.DataForm.Type.fromString(r0);
r1 = new org.jivesoftware.smackx.xdata.packet.DataForm;
r1.<init>(r0);
L_0x0011:
r0 = r6.next();
switch(r0) {
case 2: goto L_0x0021;
case 3: goto L_0x0019;
default: goto L_0x0018;
};
L_0x0018:
goto L_0x0011;
L_0x0019:
r0 = r6.getDepth();
if (r0 == r7) goto L_0x0020;
L_0x001f:
goto L_0x0011;
L_0x0020:
return r1;
L_0x0021:
r0 = r6.getName();
r2 = r6.getNamespace();
r3 = -1;
r4 = r0.hashCode();
switch(r4) {
case -427039533: goto L_0x006e;
case 3242771: goto L_0x0064;
case 3433103: goto L_0x005a;
case 97427706: goto L_0x0050;
case 107944136: goto L_0x0046;
case 110371416: goto L_0x003c;
case 757376421: goto L_0x0032;
default: goto L_0x0031;
};
L_0x0031:
goto L_0x0077;
L_0x0032:
r4 = "instructions";
r0 = r0.equals(r4);
if (r0 == 0) goto L_0x0077;
L_0x003a:
r3 = 0;
goto L_0x0077;
L_0x003c:
r4 = "title";
r0 = r0.equals(r4);
if (r0 == 0) goto L_0x0077;
L_0x0044:
r3 = 1;
goto L_0x0077;
L_0x0046:
r4 = "query";
r0 = r0.equals(r4);
if (r0 == 0) goto L_0x0077;
L_0x004e:
r3 = 5;
goto L_0x0077;
L_0x0050:
r4 = "field";
r0 = r0.equals(r4);
if (r0 == 0) goto L_0x0077;
L_0x0058:
r3 = 2;
goto L_0x0077;
L_0x005a:
r4 = "page";
r0 = r0.equals(r4);
if (r0 == 0) goto L_0x0077;
L_0x0062:
r3 = 6;
goto L_0x0077;
L_0x0064:
r4 = "item";
r0 = r0.equals(r4);
if (r0 == 0) goto L_0x0077;
L_0x006c:
r3 = 3;
goto L_0x0077;
L_0x006e:
r4 = "reported";
r0 = r0.equals(r4);
if (r0 == 0) goto L_0x0077;
L_0x0076:
r3 = 4;
L_0x0077:
switch(r3) {
case 0: goto L_0x00bf;
case 1: goto L_0x00b6;
case 2: goto L_0x00ad;
case 3: goto L_0x00a4;
case 4: goto L_0x009b;
case 5: goto L_0x0088;
case 6: goto L_0x007b;
default: goto L_0x007a;
};
L_0x007a:
goto L_0x0011;
L_0x007b:
r0 = "http://jabber.org/protocol/xdata-layout";
r0 = r2.equals(r0);
if (r0 == 0) goto L_0x0011;
L_0x0083:
r0 = org.jivesoftware.smackx.xdatalayout.provider.DataLayoutProvider.parse(r6);
goto L_0x0096;
L_0x0088:
r0 = "jabber:iq:roster";
r0 = r2.equals(r0);
if (r0 == 0) goto L_0x0011;
L_0x0090:
r0 = org.jivesoftware.smack.roster.provider.RosterPacketProvider.INSTANCE;
r0 = r0.parse(r6);
L_0x0096:
r1.addExtensionElement(r0);
goto L_0x0011;
L_0x009b:
r0 = parseReported(r6);
r1.setReportedData(r0);
goto L_0x0011;
L_0x00a4:
r0 = parseItem(r6);
r1.addItem(r0);
goto L_0x0011;
L_0x00ad:
r0 = parseField(r6);
r1.addField(r0);
goto L_0x0011;
L_0x00b6:
r0 = r6.nextText();
r1.setTitle(r0);
goto L_0x0011;
L_0x00bf:
r0 = r6.nextText();
r1.addInstruction(r0);
goto L_0x0011;
*/
throw new UnsupportedOperationException("Method not decompiled: org.jivesoftware.smackx.xdata.provider.DataFormProvider.parse(org.xmlpull.v1.XmlPullParser, int):org.jivesoftware.smackx.xdata.packet.DataForm");
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"protected void method_2241() {\r\n // $FF: Couldn't be decompiled\r\n }",
"private void method_7083() {\r\n // $FF: Couldn't be decompiled\r\n }",
"protected void method_2145() {\r\n // $FF: Couldn't be decompiled\r\n }",
"protected void method_2247() {\r\n // $FF: Couldn't be decompiled\r\n }",
"static void method_1148() {\r\n // $FF: Couldn't be decompiled\r\n }",
"protected void method_2141() {\r\n // $FF: Couldn't be decompiled\r\n }",
"static void method_2537() {\r\n // $FF: Couldn't be decompiled\r\n }",
"static void method_2537() {\r\n // $FF: Couldn't be decompiled\r\n }",
"public void method_7081() {\r\n // $FF: Couldn't be decompiled\r\n }",
"public void method_2113() {\r\n // $FF: Couldn't be decompiled\r\n }",
"public void method_2139() {\r\n // $FF: Couldn't be decompiled\r\n }",
"static void method_6338() {\r\n // $FF: Couldn't be decompiled\r\n }",
"static void m13383b() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/79094208.run(Unknown Source)\n*/\n /*\n r0 = com.foursquare.internal.data.db.C1916a.getDatabase();\t Catch:{ Exception -> 0x000a }\n r1 = \"battery_watcher\";\t Catch:{ Exception -> 0x000a }\n r2 = 0;\t Catch:{ Exception -> 0x000a }\n r0.delete(r1, r2, r2);\t Catch:{ Exception -> 0x000a }\n L_0x000a:\n return;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.foursquare.pilgrim.e.b():void\");\n }",
"static void method_2226() {\r\n // $FF: Couldn't be decompiled\r\n }",
"private void m14210a(java.io.IOException r4, java.io.IOException r5) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/509891820.run(Unknown Source)\n*/\n /*\n r3 = this;\n r0 = f12370a;\n if (r0 == 0) goto L_0x000f;\n L_0x0004:\n r0 = f12370a;\t Catch:{ InvocationTargetException -> 0x000f, InvocationTargetException -> 0x000f }\n r1 = 1;\t Catch:{ InvocationTargetException -> 0x000f, InvocationTargetException -> 0x000f }\n r1 = new java.lang.Object[r1];\t Catch:{ InvocationTargetException -> 0x000f, InvocationTargetException -> 0x000f }\n r2 = 0;\t Catch:{ InvocationTargetException -> 0x000f, InvocationTargetException -> 0x000f }\n r1[r2] = r5;\t Catch:{ InvocationTargetException -> 0x000f, InvocationTargetException -> 0x000f }\n r0.invoke(r4, r1);\t Catch:{ InvocationTargetException -> 0x000f, InvocationTargetException -> 0x000f }\n L_0x000f:\n return;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: okhttp3.internal.connection.RouteException.a(java.io.IOException, java.io.IOException):void\");\n }",
"public void method_2046() {\r\n // $FF: Couldn't be decompiled\r\n }",
"public void method_2197() {\r\n // $FF: Couldn't be decompiled\r\n }",
"static void method_7086() {\r\n // $FF: Couldn't be decompiled\r\n }",
"public void method_2250() {\r\n // $FF: Couldn't be decompiled\r\n }",
"static void method_28() {\r\n // $FF: Couldn't be decompiled\r\n }",
"private boolean method_2253(class_1033 param1) {\r\n // $FF: Couldn't be decompiled\r\n }",
"public long mo915b() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:14)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/509891820.run(Unknown Source)\n*/\n /*\n r4 = this;\n r0 = -1;\n r2 = r4.f18088d;\t Catch:{ NumberFormatException -> 0x000e }\n if (r2 == 0) goto L_0x000d;\t Catch:{ NumberFormatException -> 0x000e }\n L_0x0006:\n r2 = r4.f18088d;\t Catch:{ NumberFormatException -> 0x000e }\n r2 = java.lang.Long.parseLong(r2);\t Catch:{ NumberFormatException -> 0x000e }\n r0 = r2;\n L_0x000d:\n return r0;\n L_0x000e:\n return r0;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: okhttp3.c.b.b():long\");\n }",
"private void m25427g() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n*/\n /*\n r2 = this;\n r0 = r2.f19111m;\n if (r0 == 0) goto L_0x000f;\n L_0x0004:\n r0 = r2.f19104f;\t Catch:{ Exception -> 0x000f }\n r0 = android.support.v4.content.C0396d.m1465a(r0);\t Catch:{ Exception -> 0x000f }\n r1 = r2.f19111m;\t Catch:{ Exception -> 0x000f }\n r0.m1468a(r1);\t Catch:{ Exception -> 0x000f }\n L_0x000f:\n return;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.facebook.ads.internal.adapters.w.g():void\");\n }",
"public void mo2485a() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/79094208.run(Unknown Source)\n*/\n /*\n r2 = this;\n r0 = r2.f11863a;\n monitor-enter(r0);\n r1 = r2.f11873l;\t Catch:{ all -> 0x002a }\n if (r1 != 0) goto L_0x0028;\t Catch:{ all -> 0x002a }\n L_0x0007:\n r1 = r2.f11872k;\t Catch:{ all -> 0x002a }\n if (r1 == 0) goto L_0x000c;\t Catch:{ all -> 0x002a }\n L_0x000b:\n goto L_0x0028;\t Catch:{ all -> 0x002a }\n L_0x000c:\n r1 = r2.f11875n;\t Catch:{ all -> 0x002a }\n if (r1 == 0) goto L_0x0015;\n L_0x0010:\n r1 = r2.f11875n;\t Catch:{ RemoteException -> 0x0015 }\n r1.cancel();\t Catch:{ RemoteException -> 0x0015 }\n L_0x0015:\n r1 = r2.f11870i;\t Catch:{ all -> 0x002a }\n m14216b(r1);\t Catch:{ all -> 0x002a }\n r1 = 1;\t Catch:{ all -> 0x002a }\n r2.f11873l = r1;\t Catch:{ all -> 0x002a }\n r1 = com.google.android.gms.common.api.Status.zzfnm;\t Catch:{ all -> 0x002a }\n r1 = r2.mo3568a(r1);\t Catch:{ all -> 0x002a }\n r2.m14217c(r1);\t Catch:{ all -> 0x002a }\n monitor-exit(r0);\t Catch:{ all -> 0x002a }\n return;\t Catch:{ all -> 0x002a }\n L_0x0028:\n monitor-exit(r0);\t Catch:{ all -> 0x002a }\n return;\t Catch:{ all -> 0x002a }\n L_0x002a:\n r1 = move-exception;\t Catch:{ all -> 0x002a }\n monitor-exit(r0);\t Catch:{ all -> 0x002a }\n throw r1;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.gms.common.api.internal.BasePendingResult.a():void\");\n }",
"private void method_7082(class_1293 param1) {\r\n // $FF: Couldn't be decompiled\r\n }",
"public void mo3613a() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:14)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/509891820.run(Unknown Source)\n*/\n /*\n r4 = this;\n r0 = r4.f18081b;\n monitor-enter(r0);\n r1 = r4.f18080a;\t Catch:{ all -> 0x001f }\n if (r1 == 0) goto L_0x0009;\t Catch:{ all -> 0x001f }\n L_0x0007:\n monitor-exit(r0);\t Catch:{ all -> 0x001f }\n return;\t Catch:{ all -> 0x001f }\n L_0x0009:\n r1 = 1;\t Catch:{ all -> 0x001f }\n r4.f18080a = r1;\t Catch:{ all -> 0x001f }\n r2 = r4.f18081b;\t Catch:{ all -> 0x001f }\n r3 = r2.f12200d;\t Catch:{ all -> 0x001f }\n r3 = r3 + r1;\t Catch:{ all -> 0x001f }\n r2.f12200d = r3;\t Catch:{ all -> 0x001f }\n monitor-exit(r0);\t Catch:{ all -> 0x001f }\n r0 = r4.f18083d;\n okhttp3.internal.C2933c.m14194a(r0);\n r0 = r4.f18082c;\t Catch:{ IOException -> 0x001e }\n r0.m14100c();\t Catch:{ IOException -> 0x001e }\n L_0x001e:\n return;\n L_0x001f:\n r1 = move-exception;\n monitor-exit(r0);\t Catch:{ all -> 0x001f }\n throw r1;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: okhttp3.c.a.a():void\");\n }",
"private static void m13385d() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/79094208.run(Unknown Source)\n*/\n /*\n r0 = java.lang.System.currentTimeMillis();\t Catch:{ Exception -> 0x0024 }\n r2 = java.util.concurrent.TimeUnit.DAYS;\t Catch:{ Exception -> 0x0024 }\n r3 = 1;\t Catch:{ Exception -> 0x0024 }\n r2 = r2.toMillis(r3);\t Catch:{ Exception -> 0x0024 }\n r4 = 0;\t Catch:{ Exception -> 0x0024 }\n r4 = r0 - r2;\t Catch:{ Exception -> 0x0024 }\n r0 = com.foursquare.internal.data.db.C1916a.getDatabase();\t Catch:{ Exception -> 0x0024 }\n r1 = \"battery_watcher\";\t Catch:{ Exception -> 0x0024 }\n r2 = \"timestamp < ?\";\t Catch:{ Exception -> 0x0024 }\n r3 = 1;\t Catch:{ Exception -> 0x0024 }\n r3 = new java.lang.String[r3];\t Catch:{ Exception -> 0x0024 }\n r6 = 0;\t Catch:{ Exception -> 0x0024 }\n r4 = java.lang.String.valueOf(r4);\t Catch:{ Exception -> 0x0024 }\n r3[r6] = r4;\t Catch:{ Exception -> 0x0024 }\n r0.delete(r1, r2, r3);\t Catch:{ Exception -> 0x0024 }\n L_0x0024:\n return;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.foursquare.pilgrim.e.d():void\");\n }",
"private boolean m2248a(java.lang.String r3, com.onesignal.La.C0596a r4) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/318857719.run(Unknown Source)\n*/\n /*\n r2 = this;\n r0 = 0;\n r1 = 1;\n java.lang.Float.parseFloat(r3);\t Catch:{ Throwable -> 0x0007 }\n r3 = 1;\n goto L_0x0008;\n L_0x0007:\n r3 = 0;\n L_0x0008:\n if (r3 != 0) goto L_0x0017;\n L_0x000a:\n r3 = com.onesignal.sa.C0650i.ERROR;\n r1 = \"Missing Google Project number!\\nPlease enter a Google Project number / Sender ID on under App Settings > Android > Configuration on the OneSignal dashboard.\";\n com.onesignal.sa.m1656a(r3, r1);\n r3 = 0;\n r1 = -6;\n r4.mo1392a(r3, r1);\n return r0;\n L_0x0017:\n return r1;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.onesignal.Pa.a(java.lang.String, com.onesignal.La$a):boolean\");\n }",
"public static boolean m19464a(java.lang.String r3, int[] r4) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/79094208.run(Unknown Source)\n*/\n /*\n r0 = android.text.TextUtils.isEmpty(r3);\n r1 = 0;\n if (r0 == 0) goto L_0x0008;\n L_0x0007:\n return r1;\n L_0x0008:\n r0 = r4.length;\n r2 = 2;\n if (r0 == r2) goto L_0x000d;\n L_0x000c:\n return r1;\n L_0x000d:\n r0 = \"x\";\n r3 = r3.split(r0);\n r0 = r3.length;\n if (r0 == r2) goto L_0x0017;\n L_0x0016:\n return r1;\n L_0x0017:\n r0 = r3[r1];\t Catch:{ NumberFormatException -> 0x0029 }\n r0 = java.lang.Integer.parseInt(r0);\t Catch:{ NumberFormatException -> 0x0029 }\n r4[r1] = r0;\t Catch:{ NumberFormatException -> 0x0029 }\n r0 = 1;\t Catch:{ NumberFormatException -> 0x0029 }\n r3 = r3[r0];\t Catch:{ NumberFormatException -> 0x0029 }\n r3 = java.lang.Integer.parseInt(r3);\t Catch:{ NumberFormatException -> 0x0029 }\n r4[r0] = r3;\t Catch:{ NumberFormatException -> 0x0029 }\n return r0;\n L_0x0029:\n return r1;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.gms.internal.arp.a(java.lang.String, int[]):boolean\");\n }",
"public boolean mo3969a() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/509891820.run(Unknown Source)\n*/\n /*\n r4 = this;\n r0 = r4.f19005h;\n if (r0 != 0) goto L_0x0011;\n L_0x0004:\n r0 = r4.f19004g;\n if (r0 == 0) goto L_0x000f;\n L_0x0008:\n r0 = r4.f19004g;\n r1 = com.facebook.ads.C1700b.f5123e;\n r0.mo1313a(r4, r1);\n L_0x000f:\n r0 = 0;\n return r0;\n L_0x0011:\n r0 = new android.content.Intent;\n r1 = r4.f19002e;\n r2 = com.facebook.ads.AudienceNetworkActivity.class;\n r0.<init>(r1, r2);\n r1 = \"predefinedOrientationKey\";\n r2 = r4.m25306b();\n r0.putExtra(r1, r2);\n r1 = \"uniqueId\";\n r2 = r4.f18999b;\n r0.putExtra(r1, r2);\n r1 = \"placementId\";\n r2 = r4.f19000c;\n r0.putExtra(r1, r2);\n r1 = \"requestTime\";\n r2 = r4.f19001d;\n r0.putExtra(r1, r2);\n r1 = \"viewType\";\n r2 = r4.f19009l;\n r0.putExtra(r1, r2);\n r1 = \"useCache\";\n r2 = r4.f19010m;\n r0.putExtra(r1, r2);\n r1 = r4.f19008k;\n if (r1 == 0) goto L_0x0052;\n L_0x004a:\n r1 = \"ad_data_bundle\";\n r2 = r4.f19008k;\n r0.putExtra(r1, r2);\n goto L_0x005b;\n L_0x0052:\n r1 = r4.f19006i;\n if (r1 == 0) goto L_0x005b;\n L_0x0056:\n r1 = r4.f19006i;\n r1.m18953a(r0);\n L_0x005b:\n r1 = 268435456; // 0x10000000 float:2.5243549E-29 double:1.32624737E-315;\n r0.addFlags(r1);\n r1 = r4.f19002e;\t Catch:{ ActivityNotFoundException -> 0x0066 }\n r1.startActivity(r0);\t Catch:{ ActivityNotFoundException -> 0x0066 }\n goto L_0x0072;\n L_0x0066:\n r1 = r4.f19002e;\n r2 = com.facebook.ads.InterstitialAdActivity.class;\n r0.setClass(r1, r2);\n r1 = r4.f19002e;\n r1.startActivity(r0);\n L_0x0072:\n r0 = 1;\n return r0;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.facebook.ads.internal.adapters.k.a():boolean\");\n }",
"protected void method_2045(class_1045 param1) {\r\n // $FF: Couldn't be decompiled\r\n }",
"protected void method_2246(class_1045 param1) {\r\n // $FF: Couldn't be decompiled\r\n }",
"private final java.util.Map<java.lang.String, java.lang.String> m11967c() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/509891820.run(Unknown Source)\n*/\n /*\n r7 = this;\n r0 = new java.util.HashMap;\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n r0.<init>();\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n r1 = r7.f10169c;\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n r2 = r7.f10170d;\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n r3 = f10168i;\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n r4 = 0;\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n r5 = 0;\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n r6 = 0;\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n r1 = r1.query(r2, r3, r4, r5, r6);\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n if (r1 == 0) goto L_0x0031;\n L_0x0014:\n r2 = r1.moveToNext();\t Catch:{ all -> 0x002c }\n if (r2 == 0) goto L_0x0028;\t Catch:{ all -> 0x002c }\n L_0x001a:\n r2 = 0;\t Catch:{ all -> 0x002c }\n r2 = r1.getString(r2);\t Catch:{ all -> 0x002c }\n r3 = 1;\t Catch:{ all -> 0x002c }\n r3 = r1.getString(r3);\t Catch:{ all -> 0x002c }\n r0.put(r2, r3);\t Catch:{ all -> 0x002c }\n goto L_0x0014;\n L_0x0028:\n r1.close();\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n goto L_0x0031;\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n L_0x002c:\n r0 = move-exception;\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n r1.close();\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n throw r0;\t Catch:{ SecurityException -> 0x0032, SecurityException -> 0x0032 }\n L_0x0031:\n return r0;\n L_0x0032:\n r0 = \"ConfigurationContentLoader\";\n r1 = \"PhenotypeFlag unable to load ContentProvider, using default values\";\n android.util.Log.e(r0, r1);\n r0 = 0;\n return r0;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.gms.internal.measurement.zzsi.c():java.util.Map<java.lang.String, java.lang.String>\");\n }",
"private void m50366E() {\n }",
"public int method_7084(String param1) {\r\n // $FF: Couldn't be decompiled\r\n }",
"private p000a.p001a.p002a.p003a.C0916s m1655b(p000a.p001a.p002a.p003a.p022i.p024b.C0112x r7, p000a.p001a.p002a.p003a.p034n.C0157e r8) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/293907205.run(Unknown Source)\n*/\n /*\n r6 = this;\n r0 = r7.m321a();\n r7 = r7.m322b();\n r1 = 0;\n r2 = r1;\n L_0x000a:\n r3 = r6.f1533u;\n r3 = r3 + 1;\n r6.f1533u = r3;\n r0.m2803e();\n r3 = r0.mo2010a();\n if (r3 != 0) goto L_0x0032;\n L_0x0019:\n r7 = r6.f1513a;\n r8 = \"Cannot retry non-repeatable request\";\n r7.m260a(r8);\n if (r2 == 0) goto L_0x002a;\n L_0x0022:\n r7 = new a.a.a.a.b.m;\n r8 = \"Cannot retry request with a non-repeatable request entity. The cause lists the reason the original request failed.\";\n r7.<init>(r8, r2);\n throw r7;\n L_0x002a:\n r7 = new a.a.a.a.b.m;\n r8 = \"Cannot retry request with a non-repeatable request entity.\";\n r7.<init>(r8);\n throw r7;\n L_0x0032:\n r2 = r6.f1529q;\t Catch:{ IOException -> 0x0086 }\n r2 = r2.mo1932c();\t Catch:{ IOException -> 0x0086 }\n if (r2 != 0) goto L_0x0057;\t Catch:{ IOException -> 0x0086 }\n L_0x003a:\n r2 = r7.mo15e();\t Catch:{ IOException -> 0x0086 }\n if (r2 != 0) goto L_0x004f;\t Catch:{ IOException -> 0x0086 }\n L_0x0040:\n r2 = r6.f1513a;\t Catch:{ IOException -> 0x0086 }\n r3 = \"Reopening the direct connection.\";\t Catch:{ IOException -> 0x0086 }\n r2.m260a(r3);\t Catch:{ IOException -> 0x0086 }\n r2 = r6.f1529q;\t Catch:{ IOException -> 0x0086 }\n r3 = r6.f1528p;\t Catch:{ IOException -> 0x0086 }\n r2.mo2023a(r7, r8, r3);\t Catch:{ IOException -> 0x0086 }\n goto L_0x0057;\t Catch:{ IOException -> 0x0086 }\n L_0x004f:\n r2 = r6.f1513a;\t Catch:{ IOException -> 0x0086 }\n r3 = \"Proxied connection. Need to start over.\";\t Catch:{ IOException -> 0x0086 }\n r2.m260a(r3);\t Catch:{ IOException -> 0x0086 }\n goto L_0x0085;\t Catch:{ IOException -> 0x0086 }\n L_0x0057:\n r2 = r6.f1513a;\t Catch:{ IOException -> 0x0086 }\n r2 = r2.m262a();\t Catch:{ IOException -> 0x0086 }\n if (r2 == 0) goto L_0x007c;\t Catch:{ IOException -> 0x0086 }\n L_0x005f:\n r2 = r6.f1513a;\t Catch:{ IOException -> 0x0086 }\n r3 = new java.lang.StringBuilder;\t Catch:{ IOException -> 0x0086 }\n r3.<init>();\t Catch:{ IOException -> 0x0086 }\n r4 = \"Attempt \";\t Catch:{ IOException -> 0x0086 }\n r3.append(r4);\t Catch:{ IOException -> 0x0086 }\n r4 = r6.f1533u;\t Catch:{ IOException -> 0x0086 }\n r3.append(r4);\t Catch:{ IOException -> 0x0086 }\n r4 = \" to execute request\";\t Catch:{ IOException -> 0x0086 }\n r3.append(r4);\t Catch:{ IOException -> 0x0086 }\n r3 = r3.toString();\t Catch:{ IOException -> 0x0086 }\n r2.m260a(r3);\t Catch:{ IOException -> 0x0086 }\n L_0x007c:\n r2 = r6.f1518f;\t Catch:{ IOException -> 0x0086 }\n r3 = r6.f1529q;\t Catch:{ IOException -> 0x0086 }\n r2 = r2.m464a(r0, r3, r8);\t Catch:{ IOException -> 0x0086 }\n r1 = r2;\n L_0x0085:\n return r1;\n L_0x0086:\n r2 = move-exception;\n r3 = r6.f1513a;\n r4 = \"Closing the connection.\";\n r3.m260a(r4);\n r3 = r6.f1529q;\t Catch:{ IOException -> 0x0093 }\n r3.close();\t Catch:{ IOException -> 0x0093 }\n L_0x0093:\n r3 = r6.f1520h;\n r4 = r0.m2802d();\n r3 = r3.retryRequest(r2, r4, r8);\n if (r3 == 0) goto L_0x010a;\n L_0x009f:\n r3 = r6.f1513a;\n r3 = r3.m270d();\n if (r3 == 0) goto L_0x00d9;\n L_0x00a7:\n r3 = r6.f1513a;\n r4 = new java.lang.StringBuilder;\n r4.<init>();\n r5 = \"I/O exception (\";\n r4.append(r5);\n r5 = r2.getClass();\n r5 = r5.getName();\n r4.append(r5);\n r5 = \") caught when processing request to \";\n r4.append(r5);\n r4.append(r7);\n r5 = \": \";\n r4.append(r5);\n r5 = r2.getMessage();\n r4.append(r5);\n r4 = r4.toString();\n r3.m269d(r4);\n L_0x00d9:\n r3 = r6.f1513a;\n r3 = r3.m262a();\n if (r3 == 0) goto L_0x00ea;\n L_0x00e1:\n r3 = r6.f1513a;\n r4 = r2.getMessage();\n r3.m261a(r4, r2);\n L_0x00ea:\n r3 = r6.f1513a;\n r3 = r3.m270d();\n if (r3 == 0) goto L_0x000a;\n L_0x00f2:\n r3 = r6.f1513a;\n r4 = new java.lang.StringBuilder;\n r4.<init>();\n r5 = \"Retrying request to \";\n r4.append(r5);\n r4.append(r7);\n r4 = r4.toString();\n r3.m269d(r4);\n goto L_0x000a;\n L_0x010a:\n r8 = r2 instanceof p000a.p001a.p002a.p003a.C0176z;\n if (r8 == 0) goto L_0x0134;\n L_0x010e:\n r8 = new a.a.a.a.z;\n r0 = new java.lang.StringBuilder;\n r0.<init>();\n r7 = r7.mo10a();\n r7 = r7.m474e();\n r0.append(r7);\n r7 = \" failed to respond\";\n r0.append(r7);\n r7 = r0.toString();\n r8.<init>(r7);\n r7 = r2.getStackTrace();\n r8.setStackTrace(r7);\n throw r8;\n L_0x0134:\n throw r2;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: a.a.a.a.i.b.p.b(a.a.a.a.i.b.x, a.a.a.a.n.e):a.a.a.a.s\");\n }",
"void m5768b() throws C0841b;",
"void m1864a() {\r\n }",
"public boolean method_2088(class_689 param1) {\r\n // $FF: Couldn't be decompiled\r\n }",
"void m5770d() throws C0841b;",
"public static void m5820b(java.lang.String r3, java.lang.String r4, java.lang.String r5) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/509891820.run(Unknown Source)\n*/\n /*\n r0 = new com.crashlytics.android.answers.StartCheckoutEvent;\n r0.<init>();\n r1 = java.util.Locale.getDefault();\n r1 = java.util.Currency.getInstance(r1);\n r0.putCurrency(r1);\n r1 = 1;\n r0.putItemCount(r1);\n r1 = java.lang.Long.parseLong(r3);\t Catch:{ Exception -> 0x001f }\n r3 = java.math.BigDecimal.valueOf(r1);\t Catch:{ Exception -> 0x001f }\n r0.putTotalPrice(r3);\t Catch:{ Exception -> 0x001f }\n L_0x001f:\n r3 = \"type\";\n r0.putCustomAttribute(r3, r4);\n r3 = \"cta\";\n r0.putCustomAttribute(r3, r5);\n r3 = com.crashlytics.android.answers.Answers.getInstance();\n r3.logStartCheckout(r0);\n return;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.cuvora.carinfo.helpers.d.b(java.lang.String, java.lang.String, java.lang.String):void\");\n }",
"public static void m5812a(java.lang.String r0, java.lang.String r1, java.lang.String r2) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/509891820.run(Unknown Source)\n*/\n /*\n r2 = new com.crashlytics.android.answers.AddToCartEvent;\n r2.<init>();\n r2.putItemType(r0);\n r0 = java.lang.Long.parseLong(r1);\t Catch:{ Exception -> 0x0013 }\n r0 = java.math.BigDecimal.valueOf(r0);\t Catch:{ Exception -> 0x0013 }\n r2.putItemPrice(r0);\t Catch:{ Exception -> 0x0013 }\n L_0x0013:\n r0 = java.util.Locale.getDefault();\n r0 = java.util.Currency.getInstance(r0);\n r2.putCurrency(r0);\n r0 = com.crashlytics.android.answers.Answers.getInstance();\n r0.logAddToCart(r2);\n return;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.cuvora.carinfo.helpers.d.a(java.lang.String, java.lang.String, java.lang.String):void\");\n }",
"public final void mo91715d() {\n }",
"public void method_4270() {}",
"private static void m13381a(long r3, float r5) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/79094208.run(Unknown Source)\n*/\n /*\n r0 = com.foursquare.internal.data.db.C1916a.getDatabase();\n r0.beginTransaction();\t Catch:{ Exception -> 0x001f }\n r1 = \"INSERT INTO battery_watcher (timestamp, level) VALUES (?, ?)\";\t Catch:{ Exception -> 0x001f }\n r1 = r0.compileStatement(r1);\t Catch:{ Exception -> 0x001f }\n r2 = 1;\t Catch:{ Exception -> 0x001f }\n r1.bindLong(r2, r3);\t Catch:{ Exception -> 0x001f }\n r3 = 2;\t Catch:{ Exception -> 0x001f }\n r4 = (double) r5;\t Catch:{ Exception -> 0x001f }\n r1.bindDouble(r3, r4);\t Catch:{ Exception -> 0x001f }\n r1.execute();\t Catch:{ Exception -> 0x001f }\n r0.setTransactionSuccessful();\t Catch:{ Exception -> 0x001f }\n goto L_0x0026;\n L_0x001d:\n r3 = move-exception;\n goto L_0x002a;\n L_0x001f:\n r3 = f10646a;\t Catch:{ all -> 0x001d }\n r4 = \"Issue adding location to battery history\";\t Catch:{ all -> 0x001d }\n com.foursquare.internal.util.FsLog.m6807d(r3, r4);\t Catch:{ all -> 0x001d }\n L_0x0026:\n r0.endTransaction();\n return;\n L_0x002a:\n r0.endTransaction();\n throw r3;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.foursquare.pilgrim.e.a(long, float):void\");\n }",
"static void method_461() {\r\n // $FF: Couldn't be decompiled\r\n }",
"private static class_1205 method_6442(String param0, int param1) {\r\n // $FF: Couldn't be decompiled\r\n }",
"public void method_2112(int param1, int param2, int param3, aji param4, int param5, int param6) {\r\n // $FF: Couldn't be decompiled\r\n }",
"void m5769c() throws C0841b;",
"void m5771e() throws C0841b;",
"@Override // X.AnonymousClass0PN\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public void A0D() {\n /*\n r5 = this;\n super.A0D()\n X.08d r0 = r5.A05\n X.0OQ r4 = r0.A04()\n X.0Rk r3 = r4.A00() // Catch:{ all -> 0x003d }\n X.0BK r2 = r4.A04 // Catch:{ all -> 0x0036 }\n java.lang.String r1 = \"DELETE FROM receipt_device\"\n java.lang.String r0 = \"CLEAR_TABLE_RECEIPT_DEVICE\"\n r2.A0C(r1, r0) // Catch:{ all -> 0x0036 }\n X.08m r1 = r5.A03 // Catch:{ all -> 0x0036 }\n java.lang.String r0 = \"receipt_device_migration_complete\"\n r1.A02(r0) // Catch:{ all -> 0x0036 }\n java.lang.String r0 = \"migration_receipt_device_index\"\n r1.A02(r0) // Catch:{ all -> 0x0036 }\n java.lang.String r0 = \"migration_receipt_device_retry\"\n r1.A02(r0) // Catch:{ all -> 0x0036 }\n r3.A00() // Catch:{ all -> 0x0036 }\n r3.close()\n r4.close()\n java.lang.String r0 = \"ReceiptDeviceStore/ReceiptDeviceDatabaseMigration/resetMigration/done\"\n com.whatsapp.util.Log.i(r0)\n return\n L_0x0036:\n r0 = move-exception\n throw r0 // Catch:{ all -> 0x0038 }\n L_0x0038:\n r0 = move-exception\n r3.close() // Catch:{ all -> 0x003c }\n L_0x003c:\n throw r0\n L_0x003d:\n r0 = move-exception\n throw r0 // Catch:{ all -> 0x003f }\n L_0x003f:\n r0 = move-exception\n r4.close() // Catch:{ all -> 0x0043 }\n L_0x0043:\n throw r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: X.C43661yk.A0D():void\");\n }",
"public static void m5813a(java.lang.String r2, java.lang.String r3, java.lang.String r4, boolean r5) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/509891820.run(Unknown Source)\n*/\n /*\n r0 = new com.crashlytics.android.answers.PurchaseEvent;\n r0.<init>();\n r1 = java.util.Locale.getDefault();\n r1 = java.util.Currency.getInstance(r1);\n r0.putCurrency(r1);\n r0.putItemId(r2);\n r0.putItemType(r3);\n r2 = java.lang.Long.parseLong(r4);\t Catch:{ Exception -> 0x0021 }\n r2 = java.math.BigDecimal.valueOf(r2);\t Catch:{ Exception -> 0x0021 }\n r0.putItemPrice(r2);\t Catch:{ Exception -> 0x0021 }\n L_0x0021:\n r0.putSuccess(r5);\n r2 = com.crashlytics.android.answers.Answers.getInstance();\n r2.logPurchase(r0);\n return;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.cuvora.carinfo.helpers.d.a(java.lang.String, java.lang.String, java.lang.String, boolean):void\");\n }",
"public void method_2111(int param1, int param2, int param3, aji param4, int param5, int param6) {\r\n // $FF: Couldn't be decompiled\r\n }",
"@androidx.annotation.Nullable\n /* renamed from: j */\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public final p005b.p096l.p097a.p151d.p152a.p154b.C3474b mo14822j(java.lang.String r9) {\n /*\n r8 = this;\n java.io.File r0 = new java.io.File\n java.io.File r1 = r8.mo14820g()\n r0.<init>(r1, r9)\n boolean r1 = r0.exists()\n r2 = 3\n r3 = 6\n r4 = 1\n r5 = 0\n r6 = 0\n if (r1 != 0) goto L_0x0022\n b.l.a.d.a.e.f r0 = f6563c\n java.lang.Object[] r1 = new java.lang.Object[r4]\n r1[r5] = r9\n java.lang.String r9 = \"Pack not found with pack name: %s\"\n r0.mo14884b(r2, r9, r1)\n L_0x001f:\n r9 = r6\n goto L_0x0093\n L_0x0022:\n java.io.File r1 = new java.io.File\n b.l.a.d.a.b.o1 r7 = r8.f6567b\n int r7 = r7.mo14797a()\n java.lang.String r7 = java.lang.String.valueOf(r7)\n r1.<init>(r0, r7)\n boolean r0 = r1.exists()\n r7 = 2\n if (r0 != 0) goto L_0x0050\n b.l.a.d.a.e.f r0 = f6563c\n java.lang.Object[] r1 = new java.lang.Object[r7]\n r1[r5] = r9\n b.l.a.d.a.b.o1 r9 = r8.f6567b\n int r9 = r9.mo14797a()\n java.lang.Integer r9 = java.lang.Integer.valueOf(r9)\n r1[r4] = r9\n java.lang.String r9 = \"Pack not found with pack name: %s app version: %s\"\n r0.mo14884b(r2, r9, r1)\n goto L_0x001f\n L_0x0050:\n java.io.File[] r0 = r1.listFiles()\n if (r0 == 0) goto L_0x007b\n int r1 = r0.length\n if (r1 != 0) goto L_0x005a\n goto L_0x007b\n L_0x005a:\n if (r1 <= r4) goto L_0x0074\n b.l.a.d.a.e.f r0 = f6563c\n java.lang.Object[] r1 = new java.lang.Object[r7]\n r1[r5] = r9\n b.l.a.d.a.b.o1 r9 = r8.f6567b\n int r9 = r9.mo14797a()\n java.lang.Integer r9 = java.lang.Integer.valueOf(r9)\n r1[r4] = r9\n java.lang.String r9 = \"Multiple pack versions found for pack name: %s app version: %s\"\n r0.mo14884b(r3, r9, r1)\n goto L_0x001f\n L_0x0074:\n r9 = r0[r5]\n java.lang.String r9 = r9.getCanonicalPath()\n goto L_0x0093\n L_0x007b:\n b.l.a.d.a.e.f r0 = f6563c\n java.lang.Object[] r1 = new java.lang.Object[r7]\n r1[r5] = r9\n b.l.a.d.a.b.o1 r9 = r8.f6567b\n int r9 = r9.mo14797a()\n java.lang.Integer r9 = java.lang.Integer.valueOf(r9)\n r1[r4] = r9\n java.lang.String r9 = \"No pack version found for pack name: %s app version: %s\"\n r0.mo14884b(r2, r9, r1)\n goto L_0x001f\n L_0x0093:\n if (r9 != 0) goto L_0x0096\n return r6\n L_0x0096:\n java.io.File r0 = new java.io.File\n java.lang.String r1 = \"assets\"\n r0.<init>(r9, r1)\n boolean r1 = r0.isDirectory()\n if (r1 != 0) goto L_0x00af\n b.l.a.d.a.e.f r9 = f6563c\n java.lang.Object[] r1 = new java.lang.Object[r4]\n r1[r5] = r0\n java.lang.String r0 = \"Failed to find assets directory: %s\"\n r9.mo14884b(r3, r0, r1)\n return r6\n L_0x00af:\n java.lang.String r0 = r0.getCanonicalPath()\n b.l.a.d.a.b.w r1 = new b.l.a.d.a.b.w\n r1.<init>(r5, r9, r0)\n return r1\n */\n throw new UnsupportedOperationException(\"Method not decompiled: p005b.p096l.p097a.p151d.p152a.p154b.C3544t.mo14822j(java.lang.String):b.l.a.d.a.b.b\");\n }",
"public boolean method_2243() {\r\n // $FF: Couldn't be decompiled\r\n }",
"private final void asx() {\n /*\n r12 = this;\n r0 = r12.cFE;\n if (r0 == 0) goto L_0x0073;\n L_0x0004:\n r1 = r12.cxs;\n if (r1 == 0) goto L_0x0073;\n L_0x0008:\n r1 = r12.ayL;\n if (r1 != 0) goto L_0x000d;\n L_0x000c:\n goto L_0x0073;\n L_0x000d:\n r2 = 0;\n if (r1 == 0) goto L_0x0027;\n L_0x0010:\n r1 = r1.Km();\n if (r1 == 0) goto L_0x0027;\n L_0x0016:\n r1 = r1.aar();\n if (r1 == 0) goto L_0x0027;\n L_0x001c:\n r3 = r0.getName();\n r1 = r1.get(r3);\n r1 = (java.util.ArrayList) r1;\n goto L_0x0028;\n L_0x0027:\n r1 = r2;\n L_0x0028:\n if (r1 == 0) goto L_0x0051;\n L_0x002a:\n r1 = (java.lang.Iterable) r1;\n r1 = kotlin.collections.u.Z(r1);\n if (r1 == 0) goto L_0x0051;\n L_0x0032:\n r3 = new com.iqoption.deposit.light.perform.DepositPerformLightFragment$setPresets$items$1;\n r3.<init>(r12);\n r3 = (kotlin.jvm.a.b) r3;\n r1 = kotlin.sequences.n.b(r1, r3);\n if (r1 == 0) goto L_0x0051;\n L_0x003f:\n r3 = new com.iqoption.deposit.light.perform.DepositPerformLightFragment$setPresets$items$2;\n r3.<init>(r0);\n r3 = (kotlin.jvm.a.b) r3;\n r1 = kotlin.sequences.n.f(r1, r3);\n if (r1 == 0) goto L_0x0051;\n L_0x004c:\n r1 = kotlin.sequences.n.f(r1);\n goto L_0x0052;\n L_0x0051:\n r1 = r2;\n L_0x0052:\n r3 = r12.asr();\n if (r1 == 0) goto L_0x0059;\n L_0x0058:\n goto L_0x005d;\n L_0x0059:\n r1 = kotlin.collections.m.emptyList();\n L_0x005d:\n r4 = r12.bub;\n if (r4 == 0) goto L_0x006d;\n L_0x0061:\n r5 = 0;\n r6 = 0;\n r7 = 1;\n r8 = 0;\n r9 = 0;\n r10 = 19;\n r11 = 0;\n r2 = com.iqoption.core.util.e.a(r4, r5, r6, r7, r8, r9, r10, r11);\n L_0x006d:\n r3.c(r1, r2);\n r12.d(r0);\n L_0x0073:\n return;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.iqoption.deposit.light.perform.c.asx():void\");\n }",
"private void m1654a(p000a.p001a.p002a.p003a.p022i.p024b.C0112x r7, p000a.p001a.p002a.p003a.p034n.C0157e r8) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/293907205.run(Unknown Source)\n*/\n /*\n r6 = this;\n r0 = r7.m322b();\n r7 = r7.m321a();\n r1 = 0;\n L_0x0009:\n r2 = \"http.request\";\n r8.mo160a(r2, r7);\n r1 = r1 + 1;\n r2 = r6.f1529q;\t Catch:{ IOException -> 0x002f }\n r2 = r2.mo1932c();\t Catch:{ IOException -> 0x002f }\n if (r2 != 0) goto L_0x0020;\t Catch:{ IOException -> 0x002f }\n L_0x0018:\n r2 = r6.f1529q;\t Catch:{ IOException -> 0x002f }\n r3 = r6.f1528p;\t Catch:{ IOException -> 0x002f }\n r2.mo2023a(r0, r8, r3);\t Catch:{ IOException -> 0x002f }\n goto L_0x002b;\t Catch:{ IOException -> 0x002f }\n L_0x0020:\n r2 = r6.f1529q;\t Catch:{ IOException -> 0x002f }\n r3 = r6.f1528p;\t Catch:{ IOException -> 0x002f }\n r3 = p000a.p001a.p002a.p003a.p032l.C0150c.m428a(r3);\t Catch:{ IOException -> 0x002f }\n r2.mo1931b(r3);\t Catch:{ IOException -> 0x002f }\n L_0x002b:\n r6.m1660a(r0, r8);\t Catch:{ IOException -> 0x002f }\n return;\n L_0x002f:\n r2 = move-exception;\n r3 = r6.f1529q;\t Catch:{ IOException -> 0x0035 }\n r3.close();\t Catch:{ IOException -> 0x0035 }\n L_0x0035:\n r3 = r6.f1520h;\n r3 = r3.retryRequest(r2, r1, r8);\n if (r3 == 0) goto L_0x00a0;\n L_0x003d:\n r3 = r6.f1513a;\n r3 = r3.m270d();\n if (r3 == 0) goto L_0x0009;\n L_0x0045:\n r3 = r6.f1513a;\n r4 = new java.lang.StringBuilder;\n r4.<init>();\n r5 = \"I/O exception (\";\n r4.append(r5);\n r5 = r2.getClass();\n r5 = r5.getName();\n r4.append(r5);\n r5 = \") caught when connecting to \";\n r4.append(r5);\n r4.append(r0);\n r5 = \": \";\n r4.append(r5);\n r5 = r2.getMessage();\n r4.append(r5);\n r4 = r4.toString();\n r3.m269d(r4);\n r3 = r6.f1513a;\n r3 = r3.m262a();\n if (r3 == 0) goto L_0x0088;\n L_0x007f:\n r3 = r6.f1513a;\n r4 = r2.getMessage();\n r3.m261a(r4, r2);\n L_0x0088:\n r2 = r6.f1513a;\n r3 = new java.lang.StringBuilder;\n r3.<init>();\n r4 = \"Retrying connect to \";\n r3.append(r4);\n r3.append(r0);\n r3 = r3.toString();\n r2.m269d(r3);\n goto L_0x0009;\n L_0x00a0:\n throw r2;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: a.a.a.a.i.b.p.a(a.a.a.a.i.b.x, a.a.a.a.n.e):void\");\n }",
"public void method_2116(class_689 param1, boolean param2) {\r\n // $FF: Couldn't be decompiled\r\n }",
"private static int m69982c() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n*/\n /*\n r0 = \"android.os.Build$VERSION\";\t Catch:{ Exception -> 0x0018 }\n r0 = java.lang.Class.forName(r0);\t Catch:{ Exception -> 0x0018 }\n r1 = \"SDK_INT\";\t Catch:{ Exception -> 0x0018 }\n r0 = r0.getField(r1);\t Catch:{ Exception -> 0x0018 }\n r1 = 0;\t Catch:{ Exception -> 0x0018 }\n r0 = r0.get(r1);\t Catch:{ Exception -> 0x0018 }\n r0 = (java.lang.Integer) r0;\t Catch:{ Exception -> 0x0018 }\n r0 = r0.intValue();\t Catch:{ Exception -> 0x0018 }\n return r0;\n L_0x0018:\n r0 = 0;\n return r0;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: rx.internal.util.f.c():int\");\n }",
"static void m7753b() {\n f8029a = false;\n }",
"public final synchronized com.google.android.m4b.maps.bu.C4910a m21843a(java.lang.String r10) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/79094208.run(Unknown Source)\n*/\n /*\n r9 = this;\n monitor-enter(r9);\n r0 = r9.f17909e;\t Catch:{ all -> 0x0056 }\n r1 = 0;\n if (r0 != 0) goto L_0x0008;\n L_0x0006:\n monitor-exit(r9);\n return r1;\n L_0x0008:\n r0 = r9.f17907c;\t Catch:{ all -> 0x0056 }\n r2 = com.google.android.m4b.maps.az.C4733b.m21060a(r10);\t Catch:{ all -> 0x0056 }\n r0 = r0.m21933a(r2, r1);\t Catch:{ all -> 0x0056 }\n if (r0 == 0) goto L_0x0054;\t Catch:{ all -> 0x0056 }\n L_0x0014:\n r2 = r0.length;\t Catch:{ all -> 0x0056 }\n r3 = 9;\t Catch:{ all -> 0x0056 }\n if (r2 <= r3) goto L_0x0054;\t Catch:{ all -> 0x0056 }\n L_0x0019:\n r2 = 0;\t Catch:{ all -> 0x0056 }\n r2 = r0[r2];\t Catch:{ all -> 0x0056 }\n r4 = 1;\t Catch:{ all -> 0x0056 }\n if (r2 == r4) goto L_0x0020;\t Catch:{ all -> 0x0056 }\n L_0x001f:\n goto L_0x0054;\t Catch:{ all -> 0x0056 }\n L_0x0020:\n r5 = com.google.android.m4b.maps.bs.C4891e.m21914c(r0, r4);\t Catch:{ all -> 0x0056 }\n r2 = new com.google.android.m4b.maps.ar.a;\t Catch:{ all -> 0x0056 }\n r7 = com.google.android.m4b.maps.de.C5350x.f20104b;\t Catch:{ all -> 0x0056 }\n r2.<init>(r7);\t Catch:{ all -> 0x0056 }\n r7 = new java.io.ByteArrayInputStream;\t Catch:{ IOException -> 0x0052 }\n r8 = r0.length;\t Catch:{ IOException -> 0x0052 }\n r8 = r8 - r3;\t Catch:{ IOException -> 0x0052 }\n r7.<init>(r0, r3, r8);\t Catch:{ IOException -> 0x0052 }\n r2.m20818a(r7);\t Catch:{ IOException -> 0x0052 }\n r0 = 2;\n r0 = r2.m20843h(r0);\t Catch:{ all -> 0x0056 }\n r10 = r10.equals(r0);\t Catch:{ all -> 0x0056 }\n if (r10 != 0) goto L_0x0042;\n L_0x0040:\n monitor-exit(r9);\n return r1;\n L_0x0042:\n r10 = new com.google.android.m4b.maps.bu.a;\t Catch:{ all -> 0x0056 }\n r10.<init>();\t Catch:{ all -> 0x0056 }\n r10.m22018a(r4);\t Catch:{ all -> 0x0056 }\n r10.m22020a(r2);\t Catch:{ all -> 0x0056 }\n r10.m22016a(r5);\t Catch:{ all -> 0x0056 }\n monitor-exit(r9);\n return r10;\n L_0x0052:\n monitor-exit(r9);\n return r1;\n L_0x0054:\n monitor-exit(r9);\n return r1;\n L_0x0056:\n r10 = move-exception;\n monitor-exit(r9);\n throw r10;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.m4b.maps.bs.b.a(java.lang.String):com.google.android.m4b.maps.bu.a\");\n }",
"public static int m22557b(java.lang.String r1) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/509891820.run(Unknown Source)\n*/\n /*\n r0 = com.google.android.gms.internal.measurement.dr.m11788a(r1);\t Catch:{ zzyn -> 0x0005 }\n goto L_0x000c;\n L_0x0005:\n r0 = com.google.android.gms.internal.measurement.zzvo.f10281a;\n r1 = r1.getBytes(r0);\n r0 = r1.length;\n L_0x000c:\n r1 = m22576g(r0);\n r1 = r1 + r0;\n return r1;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.gms.internal.measurement.zzut.b(java.lang.String):int\");\n }",
"public void method_7080(String param1, class_1293 param2) {\r\n // $FF: Couldn't be decompiled\r\n }",
"public void m9741j() throws cf {\r\n }",
"private static void check(java.lang.String r1) {\n /*\n // Can't load method instructions: Load method exception: bogus opcode: 00e9 in method: java.security.Signer.check(java.lang.String):void, dex: \n */\n throw new UnsupportedOperationException(\"Method not decompiled: java.security.Signer.check(java.lang.String):void\");\n }",
"public boolean method_2153(boolean param1) {\r\n // $FF: Couldn't be decompiled\r\n }",
"public void method_2259(String param1, double param2, double param4, double param6, int param8, double param9, double param11, double param13, double param15) {\r\n // $FF: Couldn't be decompiled\r\n }",
"private void m50367F() {\n }",
"public void mo21779D() {\n }",
"public final synchronized void mo5320b() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n*/\n /*\n r6 = this;\n monitor-enter(r6);\n r0 = r6.f24853c;\t Catch:{ all -> 0x004c }\n r1 = 0;\t Catch:{ all -> 0x004c }\n r2 = 0;\t Catch:{ all -> 0x004c }\n if (r0 == 0) goto L_0x0046;\t Catch:{ all -> 0x004c }\n L_0x0007:\n r0 = r6.f24851a;\t Catch:{ all -> 0x004c }\n if (r0 != 0) goto L_0x0013;\t Catch:{ all -> 0x004c }\n L_0x000b:\n r0 = r6.f24854d;\t Catch:{ all -> 0x004c }\n r3 = r6.f24853c;\t Catch:{ all -> 0x004c }\n r0.deleteFile(r3);\t Catch:{ all -> 0x004c }\n goto L_0x0046;\t Catch:{ all -> 0x004c }\n L_0x0013:\n r0 = com.google.android.m4b.maps.cg.bx.m23058b();\t Catch:{ all -> 0x004c }\n r3 = r6.f24854d;\t Catch:{ IOException -> 0x0032, all -> 0x002f }\n r4 = r6.f24853c;\t Catch:{ IOException -> 0x0032, all -> 0x002f }\n r3 = r3.openFileOutput(r4, r1);\t Catch:{ IOException -> 0x0032, all -> 0x002f }\n r4 = r6.f24851a;\t Catch:{ IOException -> 0x0033 }\n r4 = r4.m20837d();\t Catch:{ IOException -> 0x0033 }\n r3.write(r4);\t Catch:{ IOException -> 0x0033 }\n com.google.android.m4b.maps.cg.bx.m23057a(r0);\t Catch:{ all -> 0x004c }\n L_0x002b:\n com.google.android.m4b.maps.ap.C4655c.m20770a(r3);\t Catch:{ all -> 0x004c }\n goto L_0x0046;\n L_0x002f:\n r1 = move-exception;\n r3 = r2;\n goto L_0x003f;\n L_0x0032:\n r3 = r2;\n L_0x0033:\n r4 = r6.f24854d;\t Catch:{ all -> 0x003e }\n r5 = r6.f24853c;\t Catch:{ all -> 0x003e }\n r4.deleteFile(r5);\t Catch:{ all -> 0x003e }\n com.google.android.m4b.maps.cg.bx.m23057a(r0);\t Catch:{ all -> 0x004c }\n goto L_0x002b;\t Catch:{ all -> 0x004c }\n L_0x003e:\n r1 = move-exception;\t Catch:{ all -> 0x004c }\n L_0x003f:\n com.google.android.m4b.maps.cg.bx.m23057a(r0);\t Catch:{ all -> 0x004c }\n com.google.android.m4b.maps.ap.C4655c.m20770a(r3);\t Catch:{ all -> 0x004c }\n throw r1;\t Catch:{ all -> 0x004c }\n L_0x0046:\n r6.f24851a = r2;\t Catch:{ all -> 0x004c }\n r6.f24852b = r1;\t Catch:{ all -> 0x004c }\n monitor-exit(r6);\n return;\n L_0x004c:\n r0 = move-exception;\n monitor-exit(r6);\n throw r0;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.m4b.maps.cg.q.b():void\");\n }",
"private synchronized void m29549c() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n*/\n /*\n r6 = this;\n monitor-enter(r6);\n r0 = r6.f24853c;\t Catch:{ all -> 0x0050 }\n if (r0 == 0) goto L_0x004b;\t Catch:{ all -> 0x0050 }\n L_0x0005:\n r0 = com.google.android.m4b.maps.cg.bx.m23056a();\t Catch:{ all -> 0x0050 }\n r1 = 0;\n r2 = r6.f24854d;\t Catch:{ IOException -> 0x0035, all -> 0x0030 }\n r3 = r6.f24853c;\t Catch:{ IOException -> 0x0035, all -> 0x0030 }\n r2 = r2.openFileInput(r3);\t Catch:{ IOException -> 0x0035, all -> 0x0030 }\n if (r2 == 0) goto L_0x0027;\n L_0x0014:\n r3 = new com.google.android.m4b.maps.ar.a;\t Catch:{ IOException -> 0x0036 }\n r4 = com.google.android.m4b.maps.de.af.f19891a;\t Catch:{ IOException -> 0x0036 }\n r3.<init>(r4);\t Catch:{ IOException -> 0x0036 }\n r6.f24851a = r3;\t Catch:{ IOException -> 0x0036 }\n r3 = r6.f24851a;\t Catch:{ IOException -> 0x0036 }\n r4 = com.google.android.m4b.maps.ap.C4655c.m20771a(r2);\t Catch:{ IOException -> 0x0036 }\n r3.m20819a(r4);\t Catch:{ IOException -> 0x0036 }\n goto L_0x0029;\t Catch:{ IOException -> 0x0036 }\n L_0x0027:\n r6.f24851a = r1;\t Catch:{ IOException -> 0x0036 }\n L_0x0029:\n com.google.android.m4b.maps.cg.bx.m23057a(r0);\t Catch:{ all -> 0x0050 }\n L_0x002c:\n com.google.android.m4b.maps.ap.C4655c.m20773b(r2);\t Catch:{ all -> 0x0050 }\n goto L_0x004b;\n L_0x0030:\n r2 = move-exception;\n r5 = r2;\n r2 = r1;\n r1 = r5;\n goto L_0x0044;\n L_0x0035:\n r2 = r1;\n L_0x0036:\n r6.f24851a = r1;\t Catch:{ all -> 0x0043 }\n r1 = r6.f24854d;\t Catch:{ all -> 0x0043 }\n r3 = r6.f24853c;\t Catch:{ all -> 0x0043 }\n r1.deleteFile(r3);\t Catch:{ all -> 0x0043 }\n com.google.android.m4b.maps.cg.bx.m23057a(r0);\t Catch:{ all -> 0x0050 }\n goto L_0x002c;\t Catch:{ all -> 0x0050 }\n L_0x0043:\n r1 = move-exception;\t Catch:{ all -> 0x0050 }\n L_0x0044:\n com.google.android.m4b.maps.cg.bx.m23057a(r0);\t Catch:{ all -> 0x0050 }\n com.google.android.m4b.maps.ap.C4655c.m20773b(r2);\t Catch:{ all -> 0x0050 }\n throw r1;\t Catch:{ all -> 0x0050 }\n L_0x004b:\n r0 = 1;\t Catch:{ all -> 0x0050 }\n r6.f24852b = r0;\t Catch:{ all -> 0x0050 }\n monitor-exit(r6);\n return;\n L_0x0050:\n r0 = move-exception;\n monitor-exit(r6);\n throw r0;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.m4b.maps.cg.q.c():void\");\n }",
"public void method_2249(boolean param1, class_81 param2) {\r\n // $FF: Couldn't be decompiled\r\n }",
"public void mo115190b() {\n }",
"public final void mo1285b() {\n }",
"public boolean method_208() {\r\n return false;\r\n }",
"public void mo23813b() {\n }",
"public final void mo11687c() {\n }",
"public static com.facebook.ads.internal.p081a.C1714d m6464a(java.lang.String r1) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:75)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/509891820.run(Unknown Source)\n*/\n /*\n r0 = android.text.TextUtils.isEmpty(r1);\n if (r0 == 0) goto L_0x0009;\n L_0x0006:\n r1 = NONE;\n return r1;\n L_0x0009:\n r0 = java.util.Locale.US;\t Catch:{ IllegalArgumentException -> 0x0014 }\n r1 = r1.toUpperCase(r0);\t Catch:{ IllegalArgumentException -> 0x0014 }\n r1 = com.facebook.ads.internal.p081a.C1714d.valueOf(r1);\t Catch:{ IllegalArgumentException -> 0x0014 }\n return r1;\n L_0x0014:\n r1 = NONE;\n return r1;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.facebook.ads.internal.a.d.a(java.lang.String):com.facebook.ads.internal.a.d\");\n }",
"public final void mo51373a() {\n }",
"void mo72113b();",
"public boolean method_2434() {\r\n return false;\r\n }",
"boolean m25333a(java.lang.String r1) {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n*/\n /*\n r0 = this;\n java.lang.Class.forName(r1);\t Catch:{ ClassNotFoundException -> 0x0005 }\n r1 = 1;\n return r1;\n L_0x0005:\n r1 = 0;\n return r1;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.mapbox.android.core.location.c.a(java.lang.String):boolean\");\n }",
"public void mo21787L() {\n }",
"private void kk12() {\n\n\t}",
"void mo80457c();",
"@org.jetbrains.annotations.NotNull\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public static /* synthetic */ com.bitcoin.mwallet.core.models.p009tx.slputxo.SlpUtxoSelection copy$default(com.bitcoin.mwallet.core.models.p009tx.slputxo.SlpUtxoSelection r4, com.bitcoin.mwallet.core.models.slp.Slp r5, java.util.List<kotlin.ULong> r6, com.bitcoin.bitcoink.p008tx.Satoshis r7, com.bitcoin.bitcoink.p008tx.Satoshis r8, java.util.List<com.bitcoin.mwallet.core.models.p009tx.utxo.Utxo> r9, com.bitcoin.mwallet.core.models.p009tx.slputxo.SlpUtxoSelection.Error r10, int r11, java.lang.Object r12) {\n /*\n r12 = r11 & 1\n if (r12 == 0) goto L_0x0006\n com.bitcoin.mwallet.core.models.slp.Slp r5 = r4.token\n L_0x0006:\n r12 = r11 & 2\n if (r12 == 0) goto L_0x000c\n java.util.List<kotlin.ULong> r6 = r4.quantities\n L_0x000c:\n r12 = r6\n r6 = r11 & 4\n if (r6 == 0) goto L_0x0013\n com.bitcoin.bitcoink.tx.Satoshis r7 = r4.fee\n L_0x0013:\n r0 = r7\n r6 = r11 & 8\n if (r6 == 0) goto L_0x001a\n com.bitcoin.bitcoink.tx.Satoshis r8 = r4.change\n L_0x001a:\n r1 = r8\n r6 = r11 & 16\n if (r6 == 0) goto L_0x0021\n java.util.List<com.bitcoin.mwallet.core.models.tx.utxo.Utxo> r9 = r4.utxos\n L_0x0021:\n r2 = r9\n r6 = r11 & 32\n if (r6 == 0) goto L_0x0028\n com.bitcoin.mwallet.core.models.tx.slputxo.SlpUtxoSelection$Error r10 = r4.error\n L_0x0028:\n r3 = r10\n r6 = r4\n r7 = r5\n r8 = r12\n r9 = r0\n r10 = r1\n r11 = r2\n r12 = r3\n com.bitcoin.mwallet.core.models.tx.slputxo.SlpUtxoSelection r4 = r6.copy(r7, r8, r9, r10, r11, r12)\n return r4\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.bitcoin.mwallet.core.models.p009tx.slputxo.SlpUtxoSelection.copy$default(com.bitcoin.mwallet.core.models.tx.slputxo.SlpUtxoSelection, com.bitcoin.mwallet.core.models.slp.Slp, java.util.List, com.bitcoin.bitcoink.tx.Satoshis, com.bitcoin.bitcoink.tx.Satoshis, java.util.List, com.bitcoin.mwallet.core.models.tx.slputxo.SlpUtxoSelection$Error, int, java.lang.Object):com.bitcoin.mwallet.core.models.tx.slputxo.SlpUtxoSelection\");\n }",
"public boolean A_()\r\n/* 21: */ {\r\n/* 22:138 */ return true;\r\n/* 23: */ }",
"private final boolean e() {\n /*\n r15 = this;\n r2 = 0\n r1 = 0\n dtd r0 = r15.m // Catch:{ all -> 0x008e }\n if (r0 != 0) goto L_0x000d\n dtd r0 = new dtd // Catch:{ all -> 0x008e }\n r0.<init>() // Catch:{ all -> 0x008e }\n r15.m = r0 // Catch:{ all -> 0x008e }\n L_0x000d:\n int r0 = r15.k // Catch:{ all -> 0x008e }\n dtd r3 = r15.m // Catch:{ all -> 0x008e }\n int r3 = r3.a // Catch:{ all -> 0x008e }\n int r0 = r0 - r3\n if (r0 <= 0) goto L_0x039e\n dvk r3 = r15.g // Catch:{ all -> 0x008e }\n if (r3 == 0) goto L_0x0356\n byte[] r3 = r15.h // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r3 == 0) goto L_0x0025\n int r3 = r15.i // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n byte[] r4 = r15.h // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r4 = r4.length // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r3 != r4) goto L_0x0032\n L_0x0025:\n r3 = 2097152(0x200000, float:2.938736E-39)\n int r3 = java.lang.Math.min(r0, r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n byte[] r3 = new byte[r3] // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r15.h = r3 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 0\n r15.i = r3 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n L_0x0032:\n byte[] r3 = r15.h // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r3.length // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r4 = r15.i // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r3 - r4\n int r6 = java.lang.Math.min(r0, r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r7 = r15.g // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n byte[] r8 = r15.h // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r9 = r15.i // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n boolean r0 = r7.i // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r0 != 0) goto L_0x00ac\n r0 = 1\n L_0x0047:\n java.lang.String r3 = \"GzipInflatingBuffer is closed\"\n defpackage.cld.b(r0, r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 0\n r0 = 1\n r5 = r3\n L_0x004f:\n if (r0 == 0) goto L_0x02ef\n int r3 = r6 - r5\n if (r3 <= 0) goto L_0x02ef\n dvm r0 = r7.h // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.ordinal() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n switch(r0) {\n case 0: goto L_0x00ae;\n case 1: goto L_0x0148;\n case 2: goto L_0x0171;\n case 3: goto L_0x01d7;\n case 4: goto L_0x01fc;\n case 5: goto L_0x0221;\n case 6: goto L_0x0256;\n case 7: goto L_0x0289;\n case 8: goto L_0x02a2;\n case 9: goto L_0x02e9;\n default: goto L_0x005e;\n } // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n L_0x005e:\n java.lang.AssertionError r0 = new java.lang.AssertionError // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvm r3 = r7.h // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.lang.String r3 = java.lang.String.valueOf(r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.lang.String r4 = java.lang.String.valueOf(r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r4 = r4.length() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r4 = r4 + 15\n java.lang.StringBuilder r5 = new java.lang.StringBuilder // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r5.<init>(r4) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.lang.String r4 = \"Invalid state: \"\n java.lang.StringBuilder r4 = r5.append(r4) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.lang.StringBuilder r3 = r4.append(r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.lang.String r3 = r3.toString() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0.<init>(r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n throw r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n L_0x0087:\n r0 = move-exception\n java.lang.RuntimeException r3 = new java.lang.RuntimeException // Catch:{ all -> 0x008e }\n r3.<init>(r0) // Catch:{ all -> 0x008e }\n throw r3 // Catch:{ all -> 0x008e }\n L_0x008e:\n r0 = move-exception\n if (r2 <= 0) goto L_0x00ab\n dxe r3 = r15.a\n r3.a(r2)\n dxh r3 = r15.j\n dxh r4 = defpackage.dxh.BODY\n if (r3 != r4) goto L_0x00ab\n dvk r3 = r15.g\n if (r3 == 0) goto L_0x03c9\n dzo r2 = r15.d\n long r4 = (long) r1\n r2.d(r4)\n int r2 = r15.r\n int r1 = r1 + r2\n r15.r = r1\n L_0x00ab:\n throw r0\n L_0x00ac:\n r0 = 0\n goto L_0x0047\n L_0x00ae:\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.b() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 10\n if (r0 >= r3) goto L_0x00ba\n r0 = 0\n goto L_0x004f\n L_0x00ba:\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.c() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 35615(0x8b1f, float:4.9907E-41)\n if (r0 == r3) goto L_0x00d4\n java.util.zip.ZipException r0 = new java.util.zip.ZipException // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.lang.String r3 = \"Not in GZIP format\"\n r0.<init>(r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n throw r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n L_0x00cd:\n r0 = move-exception\n java.lang.RuntimeException r3 = new java.lang.RuntimeException // Catch:{ all -> 0x008e }\n r3.<init>(r0) // Catch:{ all -> 0x008e }\n throw r3 // Catch:{ all -> 0x008e }\n L_0x00d4:\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.a() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 8\n if (r0 == r3) goto L_0x00e6\n java.util.zip.ZipException r0 = new java.util.zip.ZipException // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.lang.String r3 = \"Unsupported compression method\"\n r0.<init>(r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n throw r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n L_0x00e6:\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.a() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.j = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvl r4 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 6\n dvk r3 = r4.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r3.f // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r10 = r4.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r10 = r10.e // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r3 - r10\n if (r3 <= 0) goto L_0x03d9\n r0 = 6\n int r0 = java.lang.Math.min(r3, r0) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r3 = r4.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.util.zip.CRC32 r3 = r3.b // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r10 = r4.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n byte[] r10 = r10.d // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r11 = r4.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r11 = r11.e // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3.update(r10, r11, r0) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r3 = r4.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n defpackage.dvk.a(r3, r0) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = 6 - r0\n r3 = r0\n L_0x0118:\n if (r3 <= 0) goto L_0x013b\n r0 = 512(0x200, float:7.175E-43)\n byte[] r10 = new byte[r0] // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 0\n L_0x011f:\n if (r0 >= r3) goto L_0x013b\n int r11 = r3 - r0\n r12 = 512(0x200, float:7.175E-43)\n int r11 = java.lang.Math.min(r11, r12) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r12 = r4.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dtd r12 = r12.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r13 = 0\n r12.a(r10, r13, r11) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r12 = r4.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.util.zip.CRC32 r12 = r12.b // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r13 = 0\n r12.update(r10, r13, r11) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0 + r11\n goto L_0x011f\n L_0x013b:\n dvk r0 = r4.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 6\n defpackage.dvk.b(r0, r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvm r0 = defpackage.dvm.HEADER_EXTRA_LEN // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.h = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 1\n goto L_0x004f\n L_0x0148:\n int r0 = r7.j // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = r0 & 4\n r3 = 4\n if (r0 == r3) goto L_0x0156\n dvm r0 = defpackage.dvm.HEADER_NAME // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.h = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 1\n goto L_0x004f\n L_0x0156:\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.b() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 2\n if (r0 >= r3) goto L_0x0162\n r0 = 0\n goto L_0x004f\n L_0x0162:\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.c() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.k = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvm r0 = defpackage.dvm.HEADER_EXTRA // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.h = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 1\n goto L_0x004f\n L_0x0171:\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.b() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r7.k // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r0 >= r3) goto L_0x017e\n r0 = 0\n goto L_0x004f\n L_0x017e:\n dvl r10 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r4 = r7.k // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r0 = r10.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.f // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r3 = r10.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r3.e // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0 - r3\n if (r0 <= 0) goto L_0x03d6\n int r0 = java.lang.Math.min(r0, r4) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r3 = r10.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.util.zip.CRC32 r3 = r3.b // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r11 = r10.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n byte[] r11 = r11.d // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r12 = r10.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r12 = r12.e // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3.update(r11, r12, r0) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r3 = r10.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n defpackage.dvk.a(r3, r0) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r4 - r0\n r3 = r0\n L_0x01a8:\n if (r3 <= 0) goto L_0x01cb\n r0 = 512(0x200, float:7.175E-43)\n byte[] r11 = new byte[r0] // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 0\n L_0x01af:\n if (r0 >= r3) goto L_0x01cb\n int r12 = r3 - r0\n r13 = 512(0x200, float:7.175E-43)\n int r12 = java.lang.Math.min(r12, r13) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r13 = r10.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dtd r13 = r13.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r14 = 0\n r13.a(r11, r14, r12) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r13 = r10.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.util.zip.CRC32 r13 = r13.b // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r14 = 0\n r13.update(r11, r14, r12) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0 + r12\n goto L_0x01af\n L_0x01cb:\n dvk r0 = r10.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n defpackage.dvk.b(r0, r4) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvm r0 = defpackage.dvm.HEADER_NAME // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.h = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 1\n goto L_0x004f\n L_0x01d7:\n int r0 = r7.j // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = r0 & 8\n r3 = 8\n if (r0 != r3) goto L_0x01f5\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n L_0x01e1:\n int r3 = r0.b() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r3 <= 0) goto L_0x01f3\n int r3 = r0.a() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r3 != 0) goto L_0x01e1\n r0 = 1\n L_0x01ee:\n if (r0 != 0) goto L_0x01f5\n r0 = 0\n goto L_0x004f\n L_0x01f3:\n r0 = 0\n goto L_0x01ee\n L_0x01f5:\n dvm r0 = defpackage.dvm.HEADER_COMMENT // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.h = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 1\n goto L_0x004f\n L_0x01fc:\n int r0 = r7.j // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = r0 & 16\n r3 = 16\n if (r0 != r3) goto L_0x021a\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n L_0x0206:\n int r3 = r0.b() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r3 <= 0) goto L_0x0218\n int r3 = r0.a() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r3 != 0) goto L_0x0206\n r0 = 1\n L_0x0213:\n if (r0 != 0) goto L_0x021a\n r0 = 0\n goto L_0x004f\n L_0x0218:\n r0 = 0\n goto L_0x0213\n L_0x021a:\n dvm r0 = defpackage.dvm.HEADER_CRC // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.h = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 1\n goto L_0x004f\n L_0x0221:\n int r0 = r7.j // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = r0 & 2\n r3 = 2\n if (r0 != r3) goto L_0x024f\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.b() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 2\n if (r0 >= r3) goto L_0x0234\n r0 = 0\n goto L_0x004f\n L_0x0234:\n java.util.zip.CRC32 r0 = r7.b // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n long r10 = r0.getValue() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = (int) r10 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 65535(0xffff, float:9.1834E-41)\n r0 = r0 & r3\n dvl r3 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r3.c() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r0 == r3) goto L_0x024f\n java.util.zip.ZipException r0 = new java.util.zip.ZipException // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.lang.String r3 = \"Corrupt GZIP header\"\n r0.<init>(r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n throw r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n L_0x024f:\n dvm r0 = defpackage.dvm.INITIALIZE_INFLATER // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.h = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 1\n goto L_0x004f\n L_0x0256:\n java.util.zip.Inflater r0 = r7.g // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r0 != 0) goto L_0x027e\n java.util.zip.Inflater r0 = new java.util.zip.Inflater // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 1\n r0.<init>(r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.g = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n L_0x0262:\n java.util.zip.CRC32 r0 = r7.b // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0.reset() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r7.f // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r7.e // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0 - r3\n if (r0 <= 0) goto L_0x0284\n java.util.zip.Inflater r3 = r7.g // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n byte[] r4 = r7.d // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r10 = r7.e // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3.setInput(r4, r10, r0) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvm r0 = defpackage.dvm.INFLATING // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.h = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n L_0x027b:\n r0 = 1\n goto L_0x004f\n L_0x027e:\n java.util.zip.Inflater r0 = r7.g // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0.reset() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n goto L_0x0262\n L_0x0284:\n dvm r0 = defpackage.dvm.INFLATER_NEEDS_INPUT // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.h = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n goto L_0x027b\n L_0x0289:\n int r0 = r9 + r5\n int r0 = r7.a(r8, r0, r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r5 + r0\n dvm r0 = r7.h // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvm r4 = defpackage.dvm.TRAILER // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r0 != r4) goto L_0x029e\n boolean r0 = r7.a() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r5 = r3\n goto L_0x004f\n L_0x029e:\n r0 = 1\n r5 = r3\n goto L_0x004f\n L_0x02a2:\n java.util.zip.Inflater r0 = r7.g // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r0 == 0) goto L_0x02c7\n r0 = 1\n L_0x02a7:\n java.lang.String r3 = \"inflater is null\"\n defpackage.cld.b(r0, r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r7.e // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r7.f // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r0 != r3) goto L_0x02c9\n r0 = 1\n L_0x02b3:\n java.lang.String r3 = \"inflaterInput has unconsumed bytes\"\n defpackage.cld.b(r0, r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dtd r0 = r7.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 512(0x200, float:7.175E-43)\n int r0 = java.lang.Math.min(r0, r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r0 != 0) goto L_0x02cb\n r0 = 0\n goto L_0x004f\n L_0x02c7:\n r0 = 0\n goto L_0x02a7\n L_0x02c9:\n r0 = 0\n goto L_0x02b3\n L_0x02cb:\n r3 = 0\n r7.e = r3 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.f = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dtd r3 = r7.a // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n byte[] r4 = r7.d // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r10 = r7.e // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3.a(r4, r10, r0) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n java.util.zip.Inflater r3 = r7.g // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n byte[] r4 = r7.d // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r10 = r7.e // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3.setInput(r4, r10, r0) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvm r0 = defpackage.dvm.INFLATING // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r7.h = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0 = 1\n goto L_0x004f\n L_0x02e9:\n boolean r0 = r7.a() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n goto L_0x004f\n L_0x02ef:\n if (r0 == 0) goto L_0x0301\n dvm r0 = r7.h // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvm r3 = defpackage.dvm.HEADER // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n if (r0 != r3) goto L_0x0334\n dvl r0 = r7.c // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0.b() // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r3 = 10\n if (r0 >= r3) goto L_0x0334\n L_0x0301:\n r0 = 1\n L_0x0302:\n r7.n = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dvk r0 = r15.g // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r0.l // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r4 = 0\n r0.l = r4 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r2 = r2 + r3\n dvk r0 = r15.g // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r3 = r0.m // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r4 = 0\n r0.m = r4 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r1 = r1 + r3\n if (r5 != 0) goto L_0x0342\n if (r2 <= 0) goto L_0x0332\n dxe r0 = r15.a\n r0.a(r2)\n dxh r0 = r15.j\n dxh r3 = defpackage.dxh.BODY\n if (r0 != r3) goto L_0x0332\n dvk r0 = r15.g\n if (r0 == 0) goto L_0x0336\n dzo r0 = r15.d\n long r2 = (long) r1\n r0.d(r2)\n int r0 = r15.r\n int r0 = r0 + r1\n r15.r = r0\n L_0x0332:\n r0 = 0\n L_0x0333:\n return r0\n L_0x0334:\n r0 = 0\n goto L_0x0302\n L_0x0336:\n dzo r0 = r15.d\n long r4 = (long) r2\n r0.d(r4)\n int r0 = r15.r\n int r0 = r0 + r2\n r15.r = r0\n goto L_0x0332\n L_0x0342:\n dtd r0 = r15.m // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n byte[] r3 = r15.h // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r4 = r15.i // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n dxv r3 = defpackage.dxw.a(r3, r4, r5) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n r0.a(r3) // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r15.i // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n int r0 = r0 + r5\n r15.i = r0 // Catch:{ IOException -> 0x0087, DataFormatException -> 0x00cd }\n goto L_0x000d\n L_0x0356:\n dtd r3 = r15.n // Catch:{ all -> 0x008e }\n int r3 = r3.a // Catch:{ all -> 0x008e }\n if (r3 != 0) goto L_0x0386\n if (r2 <= 0) goto L_0x0378\n dxe r0 = r15.a\n r0.a(r2)\n dxh r0 = r15.j\n dxh r3 = defpackage.dxh.BODY\n if (r0 != r3) goto L_0x0378\n dvk r0 = r15.g\n if (r0 == 0) goto L_0x037a\n dzo r0 = r15.d\n long r2 = (long) r1\n r0.d(r2)\n int r0 = r15.r\n int r0 = r0 + r1\n r15.r = r0\n L_0x0378:\n r0 = 0\n goto L_0x0333\n L_0x037a:\n dzo r0 = r15.d\n long r4 = (long) r2\n r0.d(r4)\n int r0 = r15.r\n int r0 = r0 + r2\n r15.r = r0\n goto L_0x0378\n L_0x0386:\n dtd r3 = r15.n // Catch:{ all -> 0x008e }\n int r3 = r3.a // Catch:{ all -> 0x008e }\n int r0 = java.lang.Math.min(r0, r3) // Catch:{ all -> 0x008e }\n int r2 = r2 + r0\n dtd r3 = r15.m // Catch:{ all -> 0x008e }\n dtd r4 = r15.n // Catch:{ all -> 0x008e }\n dxv r0 = r4.a(r0) // Catch:{ all -> 0x008e }\n dtd r0 = (defpackage.dtd) r0 // Catch:{ all -> 0x008e }\n r3.a(r0) // Catch:{ all -> 0x008e }\n goto L_0x000d\n L_0x039e:\n if (r2 <= 0) goto L_0x03ba\n dxe r0 = r15.a\n r0.a(r2)\n dxh r0 = r15.j\n dxh r3 = defpackage.dxh.BODY\n if (r0 != r3) goto L_0x03ba\n dvk r0 = r15.g\n if (r0 == 0) goto L_0x03bd\n dzo r0 = r15.d\n long r2 = (long) r1\n r0.d(r2)\n int r0 = r15.r\n int r0 = r0 + r1\n r15.r = r0\n L_0x03ba:\n r0 = 1\n goto L_0x0333\n L_0x03bd:\n dzo r0 = r15.d\n long r4 = (long) r2\n r0.d(r4)\n int r0 = r15.r\n int r0 = r0 + r2\n r15.r = r0\n goto L_0x03ba\n L_0x03c9:\n dzo r1 = r15.d\n long r4 = (long) r2\n r1.d(r4)\n int r1 = r15.r\n int r1 = r1 + r2\n r15.r = r1\n goto L_0x00ab\n L_0x03d6:\n r3 = r4\n goto L_0x01a8\n L_0x03d9:\n r3 = r0\n goto L_0x0118\n */\n throw new UnsupportedOperationException(\"Method not decompiled: defpackage.dxd.e():boolean\");\n }",
"public void m23075a() {\n }",
"void mo80452a();",
"public final int mo11683a(com.google.android.gms.internal.ads.bci r11, com.google.android.gms.internal.ads.bcn r12) {\n /*\n r10 = this;\n L_0x0000:\n int r12 = r10.f3925e\n r0 = -1\n r1 = 1\n r2 = 0\n switch(r12) {\n case 0: goto L_0x00b2;\n case 1: goto L_0x0044;\n case 2: goto L_0x000e;\n default: goto L_0x0008;\n }\n L_0x0008:\n java.lang.IllegalStateException r11 = new java.lang.IllegalStateException\n r11.<init>()\n throw r11\n L_0x000e:\n int r12 = r10.f3928h\n if (r12 <= 0) goto L_0x0031\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n r12.mo12047a()\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n byte[] r12 = r12.f4559a\n r0 = 3\n r11.mo11675b(r12, r2, r0)\n com.google.android.gms.internal.ads.bcq r12 = r10.f3924d\n com.google.android.gms.internal.ads.bkh r3 = r10.f3923c\n r12.mo11681a(r3, r0)\n int r12 = r10.f3929i\n int r12 = r12 + r0\n r10.f3929i = r12\n int r12 = r10.f3928h\n int r12 = r12 - r1\n r10.f3928h = r12\n goto L_0x000e\n L_0x0031:\n int r11 = r10.f3929i\n if (r11 <= 0) goto L_0x0041\n com.google.android.gms.internal.ads.bcq r3 = r10.f3924d\n long r4 = r10.f3927g\n r6 = 1\n int r7 = r10.f3929i\n r8 = 0\n r9 = 0\n r3.mo11680a(r4, r6, r7, r8, r9)\n L_0x0041:\n r10.f3925e = r1\n return r2\n L_0x0044:\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n r12.mo12047a()\n int r12 = r10.f3926f\n if (r12 != 0) goto L_0x006a\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n byte[] r12 = r12.f4559a\n r3 = 5\n boolean r12 = r11.mo11672a(r12, r2, r3, r1)\n if (r12 != 0) goto L_0x005a\n L_0x0058:\n r1 = 0\n goto L_0x008d\n L_0x005a:\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n long r3 = r12.mo12063j()\n r5 = 1000(0x3e8, double:4.94E-321)\n long r3 = r3 * r5\n r5 = 45\n long r3 = r3 / r5\n r10.f3927g = r3\n goto L_0x0083\n L_0x006a:\n int r12 = r10.f3926f\n if (r12 != r1) goto L_0x0097\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n byte[] r12 = r12.f4559a\n r3 = 9\n boolean r12 = r11.mo11672a(r12, r2, r3, r1)\n if (r12 != 0) goto L_0x007b\n goto L_0x0058\n L_0x007b:\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n long r3 = r12.mo12066m()\n r10.f3927g = r3\n L_0x0083:\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n int r12 = r12.mo12059f()\n r10.f3928h = r12\n r10.f3929i = r2\n L_0x008d:\n if (r1 == 0) goto L_0x0094\n r12 = 2\n r10.f3925e = r12\n goto L_0x0000\n L_0x0094:\n r10.f3925e = r2\n return r0\n L_0x0097:\n com.google.android.gms.internal.ads.bad r11 = new com.google.android.gms.internal.ads.bad\n int r12 = r10.f3926f\n r0 = 39\n java.lang.StringBuilder r1 = new java.lang.StringBuilder\n r1.<init>(r0)\n java.lang.String r0 = \"Unsupported version number: \"\n r1.append(r0)\n r1.append(r12)\n java.lang.String r12 = r1.toString()\n r11.<init>((java.lang.String) r12)\n throw r11\n L_0x00b2:\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n r12.mo12047a()\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n byte[] r12 = r12.f4559a\n r3 = 8\n boolean r12 = r11.mo11672a(r12, r2, r3, r1)\n if (r12 == 0) goto L_0x00df\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n int r12 = r12.mo12065l()\n int r2 = f3921a\n if (r12 != r2) goto L_0x00d7\n com.google.android.gms.internal.ads.bkh r12 = r10.f3923c\n int r12 = r12.mo12059f()\n r10.f3926f = r12\n r2 = 1\n goto L_0x00df\n L_0x00d7:\n java.io.IOException r11 = new java.io.IOException\n java.lang.String r12 = \"Input not RawCC\"\n r11.<init>(r12)\n throw r11\n L_0x00df:\n if (r2 == 0) goto L_0x00e5\n r10.f3925e = r1\n goto L_0x0000\n L_0x00e5:\n return r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.gms.internal.ads.bef.mo11683a(com.google.android.gms.internal.ads.bci, com.google.android.gms.internal.ads.bcn):int\");\n }",
"public void mo12628c() {\n }",
"public synchronized void m6495a(int r6, int r7) throws fr.pcsoft.wdjava.geo.C0918i {\n /* JADX: method processing error */\n/*\nError: jadx.core.utils.exceptions.JadxRuntimeException: Exception block dominator not found, method:fr.pcsoft.wdjava.geo.a.b.a(int, int):void. bs: [B:13:0x001d, B:18:0x0027, B:23:0x0031, B:28:0x003a, B:44:0x005d, B:55:0x006c, B:64:0x0079]\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.searchTryCatchDominators(ProcessTryCatchRegions.java:86)\n\tat jadx.core.dex.visitors.regions.ProcessTryCatchRegions.process(ProcessTryCatchRegions.java:45)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.postProcessRegions(RegionMakerVisitor.java:63)\n\tat jadx.core.dex.visitors.regions.RegionMakerVisitor.visit(RegionMakerVisitor.java:58)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:31)\n\tat jadx.core.dex.visitors.DepthTraversal.visit(DepthTraversal.java:17)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:34)\n\tat jadx.core.ProcessClass.processDependencies(ProcessClass.java:56)\n\tat jadx.core.ProcessClass.process(ProcessClass.java:39)\n\tat jadx.api.JadxDecompiler.processClass(JadxDecompiler.java:282)\n\tat jadx.api.JavaClass.decompile(JavaClass.java:62)\n\tat jadx.api.JadxDecompiler.lambda$appendSourcesSave$0(JadxDecompiler.java:200)\n\tat jadx.api.JadxDecompiler$$Lambda$8/70807318.run(Unknown Source)\n*/\n /*\n r5 = this;\n r4 = 2;\n r1 = 0;\n r0 = 1;\n monitor-enter(r5);\n r5.m6487e();\t Catch:{ all -> 0x0053 }\n switch(r6) {\n case 2: goto L_0x0089;\n case 3: goto L_0x000a;\n case 4: goto L_0x0013;\n default: goto L_0x000a;\n };\t Catch:{ all -> 0x0053 }\n L_0x000a:\n r0 = f2486z;\t Catch:{ all -> 0x0053 }\n r1 = 3;\t Catch:{ all -> 0x0053 }\n r0 = r0[r1];\t Catch:{ all -> 0x0053 }\n r5.f2488b = r0;\t Catch:{ all -> 0x0053 }\n L_0x0011:\n monitor-exit(r5);\n return;\n L_0x0013:\n r3 = new android.location.Criteria;\t Catch:{ all -> 0x0053 }\n r3.<init>();\t Catch:{ all -> 0x0053 }\n r2 = r7 & 2;\n if (r2 != r4) goto L_0x0058;\n L_0x001c:\n r2 = 1;\n r3.setAccuracy(r2);\t Catch:{ i -> 0x0056 }\n L_0x0020:\n r2 = r7 & 128;\n r4 = 128; // 0x80 float:1.794E-43 double:6.32E-322;\n if (r2 != r4) goto L_0x0065;\n L_0x0026:\n r2 = 3;\n r3.setPowerRequirement(r2);\t Catch:{ i -> 0x0063 }\n L_0x002a:\n r2 = r7 & 8;\n r4 = 8;\n if (r2 != r4) goto L_0x007f;\n L_0x0030:\n r2 = r0;\n L_0x0031:\n r3.setAltitudeRequired(r2);\t Catch:{ i -> 0x0081 }\n r2 = r7 & 4;\n r4 = 4;\n if (r2 != r4) goto L_0x0083;\n L_0x0039:\n r2 = r0;\n L_0x003a:\n r3.setAltitudeRequired(r2);\t Catch:{ i -> 0x0085 }\n r2 = r7 & 16;\n r4 = 16;\n if (r2 != r4) goto L_0x0087;\n L_0x0043:\n r3.setAltitudeRequired(r0);\t Catch:{ all -> 0x0053 }\n r0 = 0;\t Catch:{ all -> 0x0053 }\n r0 = r5.m6485a(r0);\t Catch:{ all -> 0x0053 }\n r1 = 1;\t Catch:{ all -> 0x0053 }\n r0 = r0.getBestProvider(r3, r1);\t Catch:{ all -> 0x0053 }\n r5.f2488b = r0;\t Catch:{ all -> 0x0053 }\n goto L_0x0011;\n L_0x0053:\n r0 = move-exception;\n monitor-exit(r5);\n throw r0;\n L_0x0056:\n r0 = move-exception;\n throw r0;\t Catch:{ all -> 0x0053 }\n L_0x0058:\n r2 = r7 & 1;\n if (r2 != r0) goto L_0x0020;\n L_0x005c:\n r2 = 2;\n r3.setAccuracy(r2);\t Catch:{ i -> 0x0061 }\n goto L_0x0020;\n L_0x0061:\n r0 = move-exception;\n throw r0;\t Catch:{ all -> 0x0053 }\n L_0x0063:\n r0 = move-exception;\t Catch:{ all -> 0x0053 }\n throw r0;\t Catch:{ all -> 0x0053 }\n L_0x0065:\n r2 = r7 & 64;\n r4 = 64;\n if (r2 != r4) goto L_0x0072;\n L_0x006b:\n r2 = 2;\n r3.setPowerRequirement(r2);\t Catch:{ i -> 0x0070 }\n goto L_0x002a;\n L_0x0070:\n r0 = move-exception;\n throw r0;\t Catch:{ all -> 0x0053 }\n L_0x0072:\n r2 = r7 & 32;\n r4 = 32;\n if (r2 != r4) goto L_0x002a;\n L_0x0078:\n r2 = 1;\n r3.setPowerRequirement(r2);\t Catch:{ i -> 0x007d }\n goto L_0x002a;\n L_0x007d:\n r0 = move-exception;\n throw r0;\t Catch:{ all -> 0x0053 }\n L_0x007f:\n r2 = r1;\t Catch:{ all -> 0x0053 }\n goto L_0x0031;\t Catch:{ all -> 0x0053 }\n L_0x0081:\n r0 = move-exception;\t Catch:{ all -> 0x0053 }\n throw r0;\t Catch:{ all -> 0x0053 }\n L_0x0083:\n r2 = r1;\t Catch:{ all -> 0x0053 }\n goto L_0x003a;\t Catch:{ all -> 0x0053 }\n L_0x0085:\n r0 = move-exception;\t Catch:{ all -> 0x0053 }\n throw r0;\t Catch:{ all -> 0x0053 }\n L_0x0087:\n r0 = r1;\t Catch:{ all -> 0x0053 }\n goto L_0x0043;\t Catch:{ all -> 0x0053 }\n L_0x0089:\n r0 = f2486z;\t Catch:{ all -> 0x0053 }\n r1 = 2;\t Catch:{ all -> 0x0053 }\n r0 = r0[r1];\t Catch:{ all -> 0x0053 }\n r5.f2488b = r0;\t Catch:{ all -> 0x0053 }\n goto L_0x0011;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: fr.pcsoft.wdjava.geo.a.b.a(int, int):void\");\n }",
"void mo41086b();",
"private synchronized void m3985g() {\n /*\n r8 = this;\n monitor-enter(r8);\n r2 = java.lang.Thread.currentThread();\t Catch:{ all -> 0x0063 }\n r3 = r8.f2114f;\t Catch:{ all -> 0x0063 }\n r3 = r3.mo1186c();\t Catch:{ all -> 0x0063 }\n r2 = r2.equals(r3);\t Catch:{ all -> 0x0063 }\n if (r2 != 0) goto L_0x0021;\n L_0x0011:\n r2 = r8.f2114f;\t Catch:{ all -> 0x0063 }\n r2 = r2.mo1185b();\t Catch:{ all -> 0x0063 }\n r3 = new com.google.analytics.tracking.android.aa;\t Catch:{ all -> 0x0063 }\n r3.<init>(r8);\t Catch:{ all -> 0x0063 }\n r2.add(r3);\t Catch:{ all -> 0x0063 }\n L_0x001f:\n monitor-exit(r8);\n return;\n L_0x0021:\n r2 = r8.f2122n;\t Catch:{ all -> 0x0063 }\n if (r2 == 0) goto L_0x0028;\n L_0x0025:\n r8.m3999d();\t Catch:{ all -> 0x0063 }\n L_0x0028:\n r2 = com.google.analytics.tracking.android.ab.f1966a;\t Catch:{ all -> 0x0063 }\n r3 = r8.f2110b;\t Catch:{ all -> 0x0063 }\n r3 = r3.ordinal();\t Catch:{ all -> 0x0063 }\n r2 = r2[r3];\t Catch:{ all -> 0x0063 }\n switch(r2) {\n case 1: goto L_0x0036;\n case 2: goto L_0x006e;\n case 3: goto L_0x00aa;\n default: goto L_0x0035;\n };\t Catch:{ all -> 0x0063 }\n L_0x0035:\n goto L_0x001f;\n L_0x0036:\n r2 = r8.f2116h;\t Catch:{ all -> 0x0063 }\n r2 = r2.isEmpty();\t Catch:{ all -> 0x0063 }\n if (r2 != 0) goto L_0x0066;\n L_0x003e:\n r2 = r8.f2116h;\t Catch:{ all -> 0x0063 }\n r2 = r2.poll();\t Catch:{ all -> 0x0063 }\n r0 = r2;\n r0 = (com.google.analytics.tracking.android.af) r0;\t Catch:{ all -> 0x0063 }\n r7 = r0;\n r2 = \"Sending hit to store\";\n com.google.analytics.tracking.android.av.m3818e(r2);\t Catch:{ all -> 0x0063 }\n r2 = r8.f2112d;\t Catch:{ all -> 0x0063 }\n r3 = r7.m3743a();\t Catch:{ all -> 0x0063 }\n r4 = r7.m3744b();\t Catch:{ all -> 0x0063 }\n r6 = r7.m3745c();\t Catch:{ all -> 0x0063 }\n r7 = r7.m3746d();\t Catch:{ all -> 0x0063 }\n r2.mo1197a(r3, r4, r6, r7);\t Catch:{ all -> 0x0063 }\n goto L_0x0036;\n L_0x0063:\n r2 = move-exception;\n monitor-exit(r8);\n throw r2;\n L_0x0066:\n r2 = r8.f2121m;\t Catch:{ all -> 0x0063 }\n if (r2 == 0) goto L_0x001f;\n L_0x006a:\n r8.m3987h();\t Catch:{ all -> 0x0063 }\n goto L_0x001f;\n L_0x006e:\n r2 = r8.f2116h;\t Catch:{ all -> 0x0063 }\n r2 = r2.isEmpty();\t Catch:{ all -> 0x0063 }\n if (r2 != 0) goto L_0x00a0;\n L_0x0076:\n r2 = r8.f2116h;\t Catch:{ all -> 0x0063 }\n r2 = r2.peek();\t Catch:{ all -> 0x0063 }\n r0 = r2;\n r0 = (com.google.analytics.tracking.android.af) r0;\t Catch:{ all -> 0x0063 }\n r7 = r0;\n r2 = \"Sending hit to service\";\n com.google.analytics.tracking.android.av.m3818e(r2);\t Catch:{ all -> 0x0063 }\n r2 = r8.f2111c;\t Catch:{ all -> 0x0063 }\n r3 = r7.m3743a();\t Catch:{ all -> 0x0063 }\n r4 = r7.m3744b();\t Catch:{ all -> 0x0063 }\n r6 = r7.m3745c();\t Catch:{ all -> 0x0063 }\n r7 = r7.m3746d();\t Catch:{ all -> 0x0063 }\n r2.mo1204a(r3, r4, r6, r7);\t Catch:{ all -> 0x0063 }\n r2 = r8.f2116h;\t Catch:{ all -> 0x0063 }\n r2.poll();\t Catch:{ all -> 0x0063 }\n goto L_0x006e;\n L_0x00a0:\n r2 = r8.f2123o;\t Catch:{ all -> 0x0063 }\n r2 = r2.mo1198a();\t Catch:{ all -> 0x0063 }\n r8.f2109a = r2;\t Catch:{ all -> 0x0063 }\n goto L_0x001f;\n L_0x00aa:\n r2 = \"Need to reconnect\";\n com.google.analytics.tracking.android.av.m3818e(r2);\t Catch:{ all -> 0x0063 }\n r2 = r8.f2116h;\t Catch:{ all -> 0x0063 }\n r2 = r2.isEmpty();\t Catch:{ all -> 0x0063 }\n if (r2 != 0) goto L_0x001f;\n L_0x00b7:\n r8.m3991j();\t Catch:{ all -> 0x0063 }\n goto L_0x001f;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.analytics.tracking.android.y.g():void\");\n }",
"private final void m710e() {\n /*\n r12 = this;\n akn r0 = r12.f531p\n akl r0 = r0.f601d\n if (r0 == 0) goto L_0x0155\n boolean r1 = r0.f580d\n r2 = -9223372036854775807(0x8000000000000001, double:-4.9E-324)\n if (r1 == 0) goto L_0x0017\n aws r1 = r0.f577a\n long r4 = r1.mo1486c()\n r8 = r4\n goto L_0x0019\n L_0x0017:\n r8 = r2\n L_0x0019:\n int r1 = (r8 > r2 ? 1 : (r8 == r2 ? 0 : -1))\n if (r1 != 0) goto L_0x0122\n ajf r1 = r12.f528m\n akn r2 = r12.f531p\n akl r2 = r2.f602e\n akx r3 = r1.f445c\n r4 = 0\n if (r3 == 0) goto L_0x008a\n boolean r3 = r3.mo486w()\n if (r3 != 0) goto L_0x008a\n akx r3 = r1.f445c\n boolean r3 = r3.mo485v()\n if (r3 == 0) goto L_0x0037\n goto L_0x0042\n L_0x0037:\n if (r0 != r2) goto L_0x008a\n akx r2 = r1.f445c\n boolean r2 = r2.mo359g()\n if (r2 == 0) goto L_0x0042\n goto L_0x008a\n L_0x0042:\n bkr r2 = r1.f446d\n long r2 = r2.mo379b()\n boolean r5 = r1.f447e\n if (r5 == 0) goto L_0x0068\n blf r5 = r1.f443a\n long r5 = r5.mo379b()\n int r7 = (r2 > r5 ? 1 : (r2 == r5 ? 0 : -1))\n if (r7 >= 0) goto L_0x005c\n blf r2 = r1.f443a\n r2.mo2109d()\n goto L_0x0096\n L_0x005c:\n r1.f447e = r4\n boolean r5 = r1.f448f\n if (r5 == 0) goto L_0x0068\n blf r5 = r1.f443a\n r5.mo2107a()\n L_0x0068:\n blf r5 = r1.f443a\n r5.mo2108a(r2)\n bkr r2 = r1.f446d\n akq r2 = r2.mo376Q()\n blf r3 = r1.f443a\n akq r3 = r3.f4280a\n boolean r3 = r2.equals(r3)\n if (r3 != 0) goto L_0x0096\n blf r3 = r1.f443a\n r3.mo378a(r2)\n aje r3 = r1.f444b\n ake r3 = (p000.ake) r3\n r3.m694a(r2, r4)\n goto L_0x0096\n L_0x008a:\n r2 = 1\n r1.f447e = r2\n boolean r2 = r1.f448f\n if (r2 == 0) goto L_0x0096\n blf r2 = r1.f443a\n r2.mo2107a()\n L_0x0096:\n long r1 = r1.mo379b()\n r12.f513D = r1\n long r0 = r0.mo440b(r1)\n akp r2 = r12.f533r\n long r2 = r2.f623m\n java.util.ArrayList r5 = r12.f530o\n boolean r5 = r5.isEmpty()\n if (r5 != 0) goto L_0x011d\n akp r5 = r12.f533r\n awt r5 = r5.f612b\n boolean r5 = r5.mo1504a()\n if (r5 != 0) goto L_0x011d\n akp r5 = r12.f533r\n long r6 = r5.f613c\n int r8 = (r6 > r2 ? 1 : (r6 == r2 ? 0 : -1))\n if (r8 != 0) goto L_0x00c5\n boolean r6 = r12.f515F\n if (r6 == 0) goto L_0x00c5\n r6 = -1\n long r2 = r2 + r6\n L_0x00c5:\n r12.f515F = r4\n alh r4 = r5.f611a\n awt r5 = r5.f612b\n java.lang.Object r5 = r5.f2566a\n int r4 = r4.mo525a(r5)\n int r5 = r12.f514E\n r6 = 0\n if (r5 <= 0) goto L_0x00e1\n java.util.ArrayList r7 = r12.f530o\n int r5 = r5 + -1\n java.lang.Object r5 = r7.get(r5)\n akb r5 = (p000.akb) r5\n goto L_0x00e3\n L_0x00e1:\n L_0x00e2:\n r5 = r6\n L_0x00e3:\n if (r5 != 0) goto L_0x00e6\n goto L_0x0109\n L_0x00e6:\n int r5 = r5.f502a\n if (r4 >= 0) goto L_0x00eb\n L_0x00ea:\n goto L_0x00f4\n L_0x00eb:\n if (r4 != 0) goto L_0x0109\n r7 = 0\n int r5 = (r2 > r7 ? 1 : (r2 == r7 ? 0 : -1))\n if (r5 >= 0) goto L_0x0109\n goto L_0x00ea\n L_0x00f4:\n int r5 = r12.f514E\n int r5 = r5 + -1\n r12.f514E = r5\n if (r5 <= 0) goto L_0x0108\n java.util.ArrayList r7 = r12.f530o\n int r5 = r5 + -1\n java.lang.Object r5 = r7.get(r5)\n akb r5 = (p000.akb) r5\n goto L_0x00e3\n L_0x0108:\n goto L_0x00e2\n L_0x0109:\n int r2 = r12.f514E\n java.util.ArrayList r3 = r12.f530o\n int r3 = r3.size()\n if (r2 >= r3) goto L_0x011d\n java.util.ArrayList r2 = r12.f530o\n int r3 = r12.f514E\n java.lang.Object r2 = r2.get(r3)\n akb r2 = (p000.akb) r2\n L_0x011d:\n akp r2 = r12.f533r\n r2.f623m = r0\n goto L_0x0140\n L_0x0122:\n r12.m691a(r8)\n akp r0 = r12.f533r\n long r0 = r0.f623m\n int r2 = (r8 > r0 ? 1 : (r8 == r0 ? 0 : -1))\n if (r2 == 0) goto L_0x0140\n akp r0 = r12.f533r\n awt r7 = r0.f612b\n long r10 = r0.f614d\n r6 = r12\n akp r0 = r6.m686a(r7, r8, r10)\n r12.f533r = r0\n akc r0 = r12.f529n\n r1 = 4\n r0.mo409b(r1)\n L_0x0140:\n akn r0 = r12.f531p\n akl r0 = r0.f603f\n akp r1 = r12.f533r\n long r2 = r0.mo442c()\n r1.f621k = r2\n akp r0 = r12.f533r\n long r1 = r12.m719n()\n r0.f622l = r1\n return\n L_0x0155:\n return\n */\n throw new UnsupportedOperationException(\"Method not decompiled: p000.ake.m710e():void\");\n }",
"public void mo21785J() {\n }",
"public final com.google.android.gms.internal.ads.zzafx mo4170d() {\n /* JADX: method processing error */\n/*\nError: java.lang.NullPointerException\n*/\n /*\n r2 = this;\n r0 = r2.f19705f;\n monitor-enter(r0);\n r1 = r2.f19706g;\t Catch:{ IllegalStateException -> 0x000d, IllegalStateException -> 0x000d }\n r1 = r1.m26175a();\t Catch:{ IllegalStateException -> 0x000d, IllegalStateException -> 0x000d }\n monitor-exit(r0);\t Catch:{ all -> 0x000b }\n return r1;\t Catch:{ all -> 0x000b }\n L_0x000b:\n r1 = move-exception;\t Catch:{ all -> 0x000b }\n goto L_0x0010;\t Catch:{ all -> 0x000b }\n L_0x000d:\n r1 = 0;\t Catch:{ all -> 0x000b }\n monitor-exit(r0);\t Catch:{ all -> 0x000b }\n return r1;\t Catch:{ all -> 0x000b }\n L_0x0010:\n monitor-exit(r0);\t Catch:{ all -> 0x000b }\n throw r1;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.android.gms.internal.ads.zzafn.d():com.google.android.gms.internal.ads.zzafx\");\n }",
"protected boolean func_70041_e_() { return false; }",
"static /* synthetic */ void m204-wrap8(com.mediatek.internal.telephony.worldphone.WorldPhoneOp01 r1) {\n /*\n // Can't load method instructions: Load method exception: bogus opcode: 0073 in method: com.mediatek.internal.telephony.worldphone.WorldPhoneOp01.-wrap8(com.mediatek.internal.telephony.worldphone.WorldPhoneOp01):void, dex: \n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.mediatek.internal.telephony.worldphone.WorldPhoneOp01.-wrap8(com.mediatek.internal.telephony.worldphone.WorldPhoneOp01):void\");\n }",
"public int g()\r\n/* 173: */ {\r\n/* 174:198 */ return 0;\r\n/* 175: */ }"
]
| [
"0.7617368",
"0.75731146",
"0.7526079",
"0.74510103",
"0.74507606",
"0.74379754",
"0.7381942",
"0.7381942",
"0.7366686",
"0.73540616",
"0.7342512",
"0.73152924",
"0.73081094",
"0.7306009",
"0.72736716",
"0.7252477",
"0.7222176",
"0.7197466",
"0.7177622",
"0.7137001",
"0.7107047",
"0.7040754",
"0.7023144",
"0.7018473",
"0.69918704",
"0.69600767",
"0.694023",
"0.69067305",
"0.6889334",
"0.6851382",
"0.6828617",
"0.6795615",
"0.67838943",
"0.67759657",
"0.67730355",
"0.6770894",
"0.67684746",
"0.67659336",
"0.67438585",
"0.6706952",
"0.6700593",
"0.6697876",
"0.6697547",
"0.6696307",
"0.666848",
"0.6668202",
"0.66551846",
"0.66126966",
"0.6612239",
"0.66091967",
"0.65934443",
"0.6568111",
"0.65657073",
"0.6539817",
"0.6514583",
"0.65086555",
"0.65085125",
"0.6490832",
"0.6436284",
"0.64321554",
"0.64301836",
"0.64032114",
"0.6401742",
"0.6371303",
"0.6369596",
"0.6369299",
"0.63572145",
"0.632797",
"0.63244724",
"0.6324235",
"0.6316696",
"0.6305784",
"0.63014865",
"0.6297093",
"0.6280461",
"0.62797946",
"0.6240313",
"0.6226832",
"0.6225488",
"0.62251925",
"0.62248766",
"0.62177604",
"0.6217017",
"0.6202365",
"0.6195975",
"0.6195193",
"0.6179659",
"0.61704963",
"0.61658776",
"0.616265",
"0.61617863",
"0.61600417",
"0.615632",
"0.61531675",
"0.6151516",
"0.6140329",
"0.61244255",
"0.6114391",
"0.61106676",
"0.61017233",
"0.60954833"
]
| 0.0 | -1 |
/private Integer insightId; private String insightName; private String projectName; private String type; private String lastEdited; private List projects; | public String getTitle() {
return title;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public abstract List<ProjectBean> getProjectList();",
"@Override\n\t@Cacheable(value=\"searchCache\",key=\"#idProject\")\n\tpublic List<InsightDetailsDto> getInsightForProject(Integer idProject)\n\t\t\tthrows Exception {\n\t\t//InsightProject Entity Obtained from DB\n\t\tList<InsightProject> insightDetails = (List<InsightProject>) this.getHibernateTemplate().findByNamedQueryAndNamedParam(\"Project.getInsightForProject\", \"projectId\", idProject);\n\t\t\n\t\t//InsightList to be populated from InsightProject Entity\n\t\tList<InsightDetail> insightList = new ArrayList<InsightDetail>();\n\t\t\n\t\tfor(InsightProject insightProject : insightDetails){//Adding Insight to list from Persistence Object\n\t\t\tinsightList.add(insightProject.getInsightDetail());\n\t\t}\n\t\t\n\t\tList<InsightDetailsDto> insightDtoList = CommonUtils.copyProperties(insightList);\n\t\tthis.getHibernateTemplate().clear();//clearing session\n\t\t\n\t\treturn insightDtoList;\n\t}",
"public interface InstitutePlayGroundInfoRepository extends JpaRepository<InstitutePlayGroundInfo,Long> {\n\n}",
"public interface ProjectMilestoneRepository extends MongoRepository<ProjectMilestone,String> {\n\n}",
"java.util.List<hr.domain.ResumeDBOuterClass.Experience> \n getExperiencesList();",
"public interface InterviewRepository extends CrudRepository<Interview, String>{\n}",
"@Projection(name = \"experiencetaskinfo\", types = {ExperienceTask.class})\npublic interface ExperienceTaskProjection {\n\n int getId();\n\n String getName();\n\n int getExperience();\n\n String getDescription();\n\n int getLimitPeriod();\n\n int getLimitTimes();\n}",
"public interface UniversityDetail {\n public int getId();\n public String getUniversityName();\n public String getLetterRecipient();\n public String getSalutation();\n}",
"List<Stash> getStashList(List<Project> projects);",
"@Mapper\npublic interface ProjectAchievementsMapper {\n\n int deleteByPrimaryKey(String projectNum);\n int insert(ProjectAchievements record);\n int insertSelective(ProjectAchievements record);\n ProjectAchievements selectByPrimaryKey(String projectNum);\n int updateByPrimaryKeySelective(ProjectAchievements record);\n int updateByPrimaryKey(ProjectAchievements record);\n void delete();\n List<ProjectAchievements> selectProject(ProjectAchievements projectAchievements, RowBounds row);\n int selectCountProject(ProjectAchievements projectAchievements);\n List<ProjectAchievements> selectProject(ProjectAchievements projectAchievements);\n}",
"void getAllProjectList(int id);",
"void getAllProjectList(int id, UserType userType);",
"public Integer getProjectId() {\n return projectId;\n }",
"@Override\n\tpublic String getInsightKeyWordForProject(Integer insightIds) throws Exception {\n\t\tString tagName = null;\n\t\tList<InsightProject> insightDetails = (List<InsightProject>) this.getHibernateTemplate().findByNamedQueryAndNamedParam(\"Project.getInsightForProject\", \"projectId\", insightIds);\n\t\tfor(InsightProject insightProject : insightDetails){//Adding Insight to list from Persistence Object\n\t\t\ttagName = insightProject.getProject().getName();\n\t\t}\n\n\t\treturn tagName;\n\t}",
"public Integer getProjectID() { return projectID; }",
"public interface PlanItemSet extends HasId, TypeStateEntity {\r\n\r\n /**\r\n * A description of the Learning Plan\r\n * @name Description\r\n */\r\n\r\n public RichText getDescr();\r\n\r\n /**\r\n * List of plan items that make up the set\r\n * @name\r\n */\r\n public List<String> getPlanItemIds();\r\n\r\n /**\r\n * N (number) of Items in the set that the student is planning for\r\n * @return\r\n */\r\n public Integer getInterestedInItemsCount();\r\n\r\n /**\r\n * True if student is interested in all of the items in the set\r\n * @return\r\n */\r\n public boolean isInterestedInAllItems();\r\n}",
"@SqlQuery(\"SELECT attrdetail.project_id, attrdetail.attribute_id,project_attribute.Name, attrdetail.sub_attribute_name, attrdetail.sub_attribute_value from project_attribute_details as attrdetail INNER JOIN project_attribute on attrdetail.attribute_id=project_attribute.id AND attrdetail.project_id= :Project_ID;\")\n\t@Mapper(ProjectMapper.class)\n\tList<ProjectDetails> getProjectDetails(@Bind(\"Project_ID\")long projectKey);",
"public interface PlanTeamHistoryModel extends BaseModel<PlanTeamHistory> {\n public Long getPrimaryKey();\n\n public void setPrimaryKey(Long pk);\n\n public Long getId();\n\n public void setId(Long id);\n\n public Long getPlanId();\n\n public void setPlanId(Long planId);\n\n public Long getUserId();\n\n public void setUserId(Long userId);\n\n public String getAction();\n\n public void setAction(String action);\n\n public String getPayload();\n\n public void setPayload(String payload);\n\n public Date getCreated();\n\n public void setCreated(Date created);\n\n public Long getUpdateAuthorId();\n\n public void setUpdateAuthorId(Long updateAuthorId);\n\n public PlanTeamHistory toEscapedModel();\n}",
"public interface ProjectResearchRepository extends JpaRepository<ProjectResearch, Integer> {\n\n\n public List<ProjectResearch> findByProjectIdAndPreResearchId(Integer projectId, Integer preResearchId);\n\n public List<ProjectResearch> findByProjectId(Integer projectId);\n\n\n}",
"public List<Project> getAllProjects();",
"@SuppressWarnings(\"unused\")\n@Repository\npublic interface ProjectHistoryRepository extends JpaRepository<ProjectHistory, Long> {\n\n}",
"public interface StudioRepository extends CrudRepository<Studio, Long> {\n}",
"public interface InductionMapper extends BaseMapper<Induction>{\n int addInduction(Induction Induction);\n int updateInduction(Induction Induction);\n List<Induction> getInductioneByPage(@Param(\"start\") Integer start, @Param(\"size\") Integer size, @Param(\"name\")String name, @Param(\"hr_id\")int hr_id);\n Long getCountByName(@Param(\"name\") String name,@Param(\"hr_id\")Integer hr_id);\n List<Induction> getByIds(@Param(\"ids\")String[] id);\n}",
"public interface SupervisorDao {\n public Collection<Project> getProjectListBySupervisorId(int supervisorId);\n}",
"public interface InspectAcceptanceRepository {\n /**\n * 按条件检索工程检查列表\n *\n * @param map\n * @param webPage\n * @return\n */\n List<ProjectExamineEntity> searchInspectAcceptanceList(Map map, WebPage webPage,String staffId);\n /**\n * 按条件检索工程检查列表\n *\n * @param map\n * @param webPage\n * @return\n */\n List<ProjectExamineEntity> searchInspectAcceptanceList(Map map, WebPage webPage);\n /**\n * 工程检查列表\n *\n * @return\n */\n List<ProjectExamineEntity> searchInspectAcceptanceAllList();\n\n /**\n * 按条件检索工程检查列表(不带分页)\n *\n * @return\n */\n List<ProjectExamineEntity> searchInspectAcceptanceAllList(Map map);\n\n /**\n * 新增工程检查信息\n *\n * @param inspectAcceptanceEntity\n * @return\n */\n boolean addProjectExamineInfo(ProjectExamineEntity inspectAcceptanceEntity);\n\n /**\n * 检索已进行的工程检查信息\n *\n * @param projectNum\n * @return\n */\n int searchHasBeenGetOnByProjectNum(String projectNum);\n\n /**\n * 检索合格的工程检查信息\n *\n * @param projectNum\n * @return\n */\n int searchQualifiedByProjectNum(String projectNum);\n\n /**\n * 检索不合格的工程检查信息\n *\n * @param projectNum\n * @return\n */\n int searchUnqualifiedByProjectNum(String projectNum);\n\n /**\n * 检索不合格的工程检查信息\n *\n * @param projectNum\n * @return\n */\n int searchOnePassByProjectNum(String projectNum);\n\n /**\n * 统计工程检查信息(前台)\n *\n * @param projectNum\n * @return\n */\n List<Object[]> searchAcceptanceListByProjectNum(String projectNum);\n\n /**\n * 根据楼栋检索工程检查批次列表\n *\n * @param buildingId\n * @param projectCategoryName\n * @return\n */\n List<Object[]> searchAcceptanceBatchList(String buildingId, String projectCategoryName);\n\n /**\n * 检索工程检查批次详情\n *\n * @param batchId\n * @return\n */\n ProjectExamineEntity searchAcceptanceBatchInfo(String batchId);\n\n /**\n * 修改工程检查批次\n *\n * @param projectExamineEntity\n * @return\n */\n boolean modifyAcceptanceBatchInfo(ProjectExamineEntity projectExamineEntity);\n\n /**\n * 检查工程验收是否有更新\n *\n * @param id\n * @param beginDateNew\n * @param projectNum\n * @return\n */\n boolean searchToUpdateForAcceptance(String id, String beginDateNew, String projectNum,String creatBy,String type,String day7Ago);\n\n /**\n * 下载更新数据\n *\n * @param id\n * @param timeStamp\n * @param projectNum\n * @return\n */\n List<ProjectExamineEntity> getAllProjectAcceptanceQuestion(String id, String timeStamp, String projectNum,String day7Ago);\n\n /**\n * 查询工程抄送人\n *\n * @param batchId\n * @return\n */\n List<ProjectCopyEntity> getProjectCopyList(String batchId);\n\n /**\n * 查询工程抄送详情\n *\n * @param copyId\n * @return\n */\n List<ProjectCopyDetailsEntity> getProjectCopyDetailsList(String copyId);\n\n /**\n * 保存抄送\n */\n boolean saveProjectCopy(ProjectCopyEntity projectCopy);\n\n /**\n * 删除抄送\n * id: 外键id\n */\n boolean deleteProjectCopy(String id);\n\n /**\n * 保存抄送人员\n */\n boolean saveProjectCopyDetails(ProjectCopyDetailsEntity projectCopyDetails);\n\n /**\n * 删除抄送人员\n * id: 外键id\n * type:模块\n */\n boolean deleteProjectCopyDetails(String id);\n\n /**\n * 统计\n *\n * @param map\n * @param webPage\n * @return\n */\n List<ProjectExamineEntity> searchInspectAcceptanceCountList(Map map, WebPage webPage);\n\n /**\n * 统计\n *\n * @param map\n * @return\n */\n List<Object[]> searchAcceptanceCountList(Map map, WebPage webPage,String staffId);\n\n /**\n * 统计\n *\n * @param map\n * @return\n */\n List<Object[]> searchAcceptanceCountList(Map map, WebPage webPage);\n /**\n * 统计\n *\n * @param map\n * @return\n */\n List<Object[]> searchAcceptanceCountList(Map map);\n /**\n * 统计\n *\n * @param map\n * @return\n */\n List<Object[]> searchAcceptanceCountList(Map map,String staffId);\n /**\n * 统计\n *\n * @param map\n * @return\n */\n int searchInspectAcceptanceCount(Map map);\n\n /**\n * 统计\n *\n * @param map\n * @return\n */\n int getCount(Map map,String staffId);\n /**\n * 统计\n *\n * @param map\n * @return\n */\n int getCount(Map map);\n /**\n * 查询自己的批次\n *\n * @param batchId\n * @param staffId\n * @return\n */\n ProjectExamineEntity searchAcceptanceBatchInfoByStaffId(String batchId, String staffId);\n\n /**\n * 根据APPID检索批次信息\n *\n * @param id\n * @return\n */\n ProjectExamineEntity getProjectExamineByAppId(String id);\n\n /**\n * 整改中的总数(当前登录人)\n *\n * @param staffId\n * @return\n */\n int getRectificationCount(String staffId);\n\n List<Object[]> getAllProjectAcceptanceQuestion(String id, String timeStamp, String projectNum, String day7Ago, String staffId, String type);\n\n List<Object[]> getAllProjectAcceptanceQuestion(String id, String timeStamp, String projectNum, String staffId, String type);\n}",
"public ArrayList<Project> getProjects(){\n return this.projects;\n }",
"public interface GoalRepository extends JpaRepository<Goal,Long> {\n\n}",
"public interface CopilotProjectDAO extends GenericDAO<CopilotProject> {\r\n\r\n /**\r\n * <p>Retrieves the copilot projects for the copilot with the specified profile ID. Returns an empty list if the\r\n * copilot has no associated projects.</p>\r\n *\r\n * @param copilotProfileId the ID of the copilot profile\r\n *\r\n * @return the copilot projects for the specified copilot (not null, doesn't contain null)\r\n *\r\n * @throws IllegalArgumentException if copilotProfileId <= 0\r\n * @throws CopilotDAOException if some other error occurred\r\n */\r\n List<CopilotProject> getCopilotProjects(long copilotProfileId) throws CopilotDAOException;\r\n}",
"@ApiMethod(\n name = \"getProjects\",\n path = \"getProjects\",\n httpMethod = HttpMethod.POST\n )\n public List<Project> getProjects(){\n \tQuery<Project> query = ofy().load().type(Project.class);\n \treturn query.list();\n }",
"List<Project> findProjectsOfAccount(String username);",
"public void setProjectId(Integer projectId) {\n this.projectId = projectId;\n }",
"public interface TestCaseRepository extends JpaRepository<TestCase,Integer>{\n\n List<TestCase> getByProjectId(Integer projectId) ;\n\n}",
"List<CliStaffProject> selectByExample(CliStaffProjectExample example);",
"public IProject [] getProjects(){\n\t\treturn projects;\n\t}",
"public interface IProjectInfoService extends IGenericService<ProjectInfo> {\n\t\n\tpublic List<String> getProjectDetailUrls();\n}",
"public interface ProjectDAO {\n Project insert(Project project);\n void delete(Project project);\n Project findById(int id);\n List<Project> findByUserId(int id);\n}",
"List<Project> getProjectsWithChanges(List<Project> projects);",
"@IdObjectEntitySettings(defaultPageSize = 5, defaultSortField = \"description\", defaultSortAscending = true,\n singular = \"Class\", plural = \"Classes\",\n viewFieldOrder = {\"description\", \"lastObservationTimestamp\", \"modificationTimestamp\", \"archived\"},\n editFieldOrder = {\"description\"})\npublic interface ClassList extends Observable {\n\n public final static String CLASS_LIST_DESCRIPTION_CANNOT_BE_BLANK_OR_NULL_ERROR = \"ClassList.description\" + CANNOT_BE_BLANK_OR_NULL_ERROR;\n public final static String CLASS_LIST_DESCRIPTION_SIZE_ERROR = \"ClassList.description\" + MAX_DESCRIPTION_SIZE;\n\n @NotEmpty(message = CLASS_LIST_DESCRIPTION_CANNOT_BE_BLANK_OR_NULL_ERROR)\n @Size(max = MAX_DESCRIPTION_SIZE, message = CLASS_LIST_DESCRIPTION_SIZE_ERROR)\n @IdObjectFieldSettings(label = \"Description\", width = 40, alignment = IdObjectFieldSettings.DisplayAlignment.LEFT, fieldType = IdObjectFieldSettings.DisplayFieldType.TEXT)\n String getDescription();\n\n void setDescription(final String description);\n\n}",
"public void setProjectID(Integer projectID) { this.projectID = projectID; }",
"public interface ProjectTeamMemberEducationService {\n void save(ProjectTeamMemberEducation projectTeamMemberEducation);\n\n void deleteAll(Integer memberId);\n\n void delete(ProjectTeamMemberEducation projectTeamMemberEducation);\n\n int insertList(List<ProjectTeamMemberEducation> projectTeamMemberEducationList);\n\n List<ProjectTeamMemberEducation> select(ProjectTeamMemberEducation projectTeamMemberEducation);\n}",
"Project findProjectById(String projectId);",
"public interface TEndProjectCommentDAO extends BaseDao<TEndProjectComment> {\n //获取一个教师可以评审的结题\n List<TEndProjectComment> findMyReviewEndPros(String teaCode, PageBean pageBean);\n\n int findMyReviewEndProsCount(String teaCode);\n\n List findByEndprojectcommentAdvise(Object endprojectcommentAdvise);\n\n List findByEndprojectcommentContent(Object endprojectcommentContent);\n\n List findByIsdeleted(Object isdeleted);\n}",
"@Projection(name = \"reportProjection\", types = ItemEntity.class)\npublic interface ReportProjection {\n Integer getRecordNumber();\n\n String getFileName();\n\n String getType();\n\n Date getCreatedDate();\n\n String getInstitutionName();\n\n List<ReportDataEntity> getReportDataEntities();\n}",
"public Project getProject(Long projectId);",
"List<Project> selectAll();",
"@Override\r\n\tpublic List<Project> findProject() {\n\t\treturn iSearchSaleRecordDao.findProject();\r\n\t}",
"public interface DAOProject {\n\n void create(Project project);\n boolean update (int projectId, Project project);\n Project read(int projectId);\n boolean delete(int projectId);\n\n}",
"List <ProjectAssignment> findAssignmentsByProject (int projectId);",
"public interface BoardService {\n class Post{\n int id;\n int user;\n String title;\n String text;\n String post_date;\n }\n class Comment{\n int id;\n int post;\n int user;\n String text;\n String post_date;\n }\n\n}",
"public interface BugPlatformMapper {\n\n\n @Select(\"SELECT js.pname as bugResolutionStatus, COUNT(js.pname) as bugNum FROM jiraissue ji INNER JOIN project pr ON pr.ID = ji.PROJECT LEFT JOIN issuestatus js ON ji.issuestatus = js.ID where pr.ID in (#{2}) and issuetype = 1 AND CREATED between #{0} and #{1} group by js.pname\")\n List<BugPlatformObject> getList(String startDate,String endDate,String project);\n}",
"Project findProjectByIdAndConvert(String projectId);",
"public interface ICMakeProject extends IUnaryComparator<ICMakeProject>, IJsonSerialization {\n /**\n * Gets the name of the project.\n */\n String getName();\n\n /**\n * Gets the path of the root of the project.\n */\n Path getRootPath();\n\n /**\n * Gets the list of the modules.\n */\n List<ICMakeModule> getModules();\n}",
"public interface TProjectChangeContentDAO extends BaseDao<TProjectChangeContent> {\n List findByProjectchangecontentField(Object projectchangecontentField);\n\n List findByProjectchangecontentFieldname(\n Object projectchangecontentFieldname);\n\n List findByProjectchangecontentOvalue(\n Object projectchangecontentOvalue);\n\n List findByProjectchangecontentNvalue(\n Object projectchangecontentNvalue);\n\n List findByIsdeleted(Object isdeleted);\n}",
"public List<GLJournalApprovalVO> getProject(String OrgId, String ClientId, String projectId) {\n String sqlQuery = \"\";\n PreparedStatement st = null;\n ResultSet rs = null;\n List<GLJournalApprovalVO> list = null;\n try {\n list = new ArrayList<GLJournalApprovalVO>();\n sqlQuery = \" SELECT C_PROJECT.C_PROJECT_ID AS ID,C_PROJECT.NAME FROM C_PROJECT WHERE AD_ORG_ID IN (\"\n + OrgId + \") \" + \" AND AD_CLIENT_ID IN (\" + ClientId + \") AND C_PROJECT_ID IN (\"\n + projectId + \") \";\n st = conn.prepareStatement(sqlQuery);\n rs = st.executeQuery();\n while (rs.next()) {\n GLJournalApprovalVO VO = new GLJournalApprovalVO();\n VO.setId(rs.getString(1));\n VO.setName(rs.getString(2));\n list.add(VO);\n\n }\n } catch (Exception e) {\n log4j.error(\"Exception in getOrgs()\", e);\n }\n return list;\n }",
"public interface DailyPatrolInspectionRepository {\n /**\n * 按项目判断是否有数据更新\n */\n boolean checkInspectionByApp(String id, String timeStamp, String projectId, String creaBy, String type);\n\n /**\n * 查询所有日常巡检的整改单\n */\n List<Object[]> getInspectionListByApp(String id, String timeStamp, String projectId, String creaid, String type);\n\n /**\n * 查询所有日常巡检的整改单\n */\n List<Object[]> getInspectionList(Map map, WebPage webPage);\n\n /**\n * 导出所有日常巡检的整改单\n */\n List<Object[]> getexportExcelList(Map map);\n\n DailyPatrolInspectionEntity getInspectionEntityById(String id);\n\n /**\n * 根据appid存入\n */\n DailyPatrolInspectionEntity getInspectionEntityByAppId(String id);\n\n /**\n * 保存日常巡检的整改单\n */\n void saveInspection(DailyPatrolInspectionEntity dailyPatrolInspection);\n\n /**\n * 保存日常巡检的整改单\n */\n void updateInspection(DailyPatrolInspectionEntity dailyPatrolInspection);\n\n /**\n * 保存图片\n */\n void saveProjectImages(ProjectImagesEntity projectImages);\n\n\n /**\n * 删除不包含的图片\n */\n void deleteByNotIds(List<String> id);\n\n /**\n * 保存图片\n */\n List<ProjectImagesEntity> getProjectImages(String id);\n\n /**\n * 删除图片\n * *id: 外键id\n * type:模块\n */\n void deleteProjectImages(String id, String type);\n\n /**\n * 保存抄送\n */\n void saveProjectCopy(ProjectCopyEntity projectCopy);\n\n /**\n * 删除抄送\n * id: 外键id\n * type:模块\n */\n void deleteProjectCopy(String id, String type);\n\n /**\n * 保存抄送人员\n */\n void saveProjectCopyDetails(ProjectCopyDetailsEntity ProjectCopyDetails);\n\n /**\n * 删除抄送人员\n * id: 外键id\n * type:模块\n */\n void deleteProjectCopyDetails(String id);\n\n /**\n * 查询抄送人员\n * id: 外键id\n * type:模块\n */\n List<Object[]> getProjectCopy(String id);\n\n /**\n * 查询整改记录\n */\n\n List<DailyPatrolInspectionDetailsEntity> getDailyPatrolInspectionDetails(String id);\n\n /**\n * 按项目查询统计信息\n */\n List<Object[]> searchInspection(String projectId);\n\n\n /**\n * 查询日常巡检代办理事项\n */\n List<Object[]> getInspectionListByAppTodo(String id, String timeStamp, String creaid);\n\n\n /**\n * 查询日常巡检待办事项是否有新数据更心\n */\n boolean checkInspectionTodo(String id, String timeStamp, String creaBy);\n\n /**\n * 保存巡检详情\n *\n * @param dailyPatrolInspectionDetailsEntity\n */\n void saveInspectionDetais(DailyPatrolInspectionDetailsEntity dailyPatrolInspectionDetailsEntity);\n\n\n /**\n * 批量删除图片\n * *id: 外键id\n * type:模块\n */\n void deleteProjectImagesList(List id, String type);\n\n /**\n * 日常巡检统计列表(后端)\n *\n * @param map\n * @return\n */\n List<Object[]> searchInspectionCount(Map map, WebPage webPage);\n\n /**\n * 日常巡检统计列表(后端)\n *\n * @param map\n * @return\n */\n List<Object[]> searchInspectionCount(Map map);\n\n int searchDailyPatrolInspectionCount(Map map);\n\n int getCount(Map map);\n\n /**\n * 统计项目\n */\n int getProjectCount(Map map);\n\n /**\n * 统计区域\n */\n int getOperatCount(Map map);\n\n /**\n * 查询日常巡检详情\n */\n Object[] getInspectionListByAdmin(String id);\n\n\n DailyPatrolInspectionEntity getDailyPatrolInspection(String id);\n\n /**\n * 日常巡检 按照当前登录人的员工id 查询整改中本人所负责人数据\n */\n int inspectionCount(String userId);\n\n\n List<DailyPatrolInspectionEntity> getDailyPatrolInspectionByInspectionId(String inspectionId);\n\n\n /**\n * 日常巡检统计(项目)\n *\n * @param map\n * @return\n */\n List<Object[]> searchInspectionProjecrCount(Map map, WebPage webPage);\n\n /**\n * 日常巡检统计(区域)\n *\n * @param map\n * @return\n */\n List<Object[]> searchInspectionOperaCount(Map map, WebPage webPage);\n\n /**\n * 日常巡检统计(项目)去掉分页\n *\n * @param map\n * @return\n */\n List<Object[]> searchInspectionProjecrCount(Map map);\n\n /**\n * 日常巡检统计(区域)去掉分页\n *\n * @param map\n * @return\n */\n List<Object[]> searchInspectionOperaCount(Map map);\n}",
"@Repository\npublic interface CollectParamConfigMapper {\n\n int insert(CollectParamConfigEntity record);\n\n CollectParamConfigEntity selectById(@Param(\"id\") Integer id);\n\n int selectCollectParamConfigCount(@Param(\"applicationName\") String applicationName);\n\n List<CollectParamConfigEntity> selectCollectParamConfigList(@Param(\"rowBegin\") int rowBegin, @Param(\"rowNum\") int rowNum, @Param(\"applicationName\") String applicationName);\n\n\n void deleteById(@Param(\"id\")Integer id);\n\n List<CollectParamConfigEntity> selectCollectParamConfigListWithDetail();\n\n}",
"void getHighlightedProjectList(int id, UserType userType);",
"public interface StudyTypeRepository extends JpaRepository<StudyType,Long>{\n\n}",
"List<UserOperateProject> selectByExample(UserOperateProjectExample example);",
"public List<DefectEntity> getDefectEntity();",
"@SuppressWarnings(\"unused\")\npublic interface HitPredictRepository extends JpaRepository<HitPredict,Long> {\n\n}",
"public interface MaintenanceDao extends JpaRepository<Maintenance, Long> {\n}",
"hr.domain.ResumeDBOuterClass.Experience getExperiences(int index);",
"public interface HospitaledInfoMapper {\r\n List<HospitaledInfo> listByPatientInfo(int id);\r\n int addEntry(HospitaledInfo hospitaledInfo);\r\n int updateEntry(HospitaledInfo hospitaledInfo);\r\n int deleteByIds(@Param(\"ids\") List<Integer> ids);\r\n}",
"@SuppressWarnings(\"unused\")\npublic interface DeveloperRepository extends JpaRepository<Developer,Long> {\n\n}",
"public interface SurveyRepository extends JpaRepository<Survey,Integer>{\n}",
"@GetMapping(\"\")\n\t@CrossOrigin(origins = \"http://localhost:3000\")\n\tpublic List<Project> getProjects()\n\t{\n\t\treturn projectService.findAll();\n\t}",
"public interface ProjectUserDao {\n public void addProjectUser(ProjectUser projectUser);\n\n public List<ProjectUser> listMyProject();\n\n public List<ProjectUser> listAsignedProject();\n\n public ProjectUser getProjectUser(long projectId);\n\n public void deleteProjectUser(ProjectUser projectUser);\n\n public ProjectUser findById(long projectId);\n\n public void update(long projectId);\n}",
"public interface IdentifiableObject {\n\n\n public String getSubtitle();\n\n public String getTitle();\n\n public int getIdentifier();\n\n public int getRecourseId();\n}",
"@Override\n\tpublic List<ProjectInfo> findAllProject() {\n\t\treturn sqlSession.selectList(\"cn.sep.samp2.project.findAllProject\");\n\t}",
"public interface IdeaCommentDao extends GenericDao<IdeaComment, Long>{\n\n\tList<IdeaComment> findIdeaCommentList(String ideaId);\n\n}",
"public interface InventoryUserLoginHistoryRepository extends JpaRepository<InventoryUserLoginHistory,Serializable> {\n}",
"public interface VisitRepository extends CrudRepository<Visit, Long> {\n}",
"public abstract Collection<RepositoryUser> getProjectMembers(KenaiProject kp) throws IOException;",
"@Repository\npublic interface ICommonMapper extends BaseMapper {\n /**\n * 查询审批中的项目\n * @param type 项目类型\n * @param id 项目ID\n * @return List<HashMap<String, Object>>\n */\n List<HashMap<String, Object>> selectApprovalProjects(@Param(\"type\") String type, @Param(\"id\")String id);\n /**\n * 查询评审中的项目\n * @param type 项目类型\n * @param id 项目ID\n * @return List<HashMap<String, Object>>\n */\n List<HashMap<String, Object>> selectReviewProjects(@Param(\"type\")String type, @Param(\"id\")String id);\n}",
"public interface ProjectDao {\n\n /**\n * Method to insert project to database\n * @param project project object\n * @return true for successful project creation else false.\n * @throws CreateFailException \n * @throws EmployeeManagementException \n */\n public boolean insertProject(Project project) throws EmployeeManagementException; \n \n /**\n * Method to get project object based on project id\n * @param projectId id of project which need to display\n * @return project object\n * @throws FetchFailException \n * @throws EmployeeManagementException \n */\n public Project getProject(int projectId) throws EmployeeManagementException;\n\n /**\n * Method to get specified projects list\n * @param projectIdList\n * @return project objects list\n * @throws FetchFailException \n * @throws EmployeeManagementException \n */\n public List<Project> getSpecifiedProjects(List<Integer> projectIdList) \n \t\tthrows EmployeeManagementException; \n\n /**\n * Method to get project object with employee object list based on project id\n * @param projectId id of project which need to display\n * @return project object\n * @throws FetchFailException \n * @throws EmployeeManagementException \n */\n public Project getProjectWithEmployee(int projectId) throws EmployeeManagementException;\n\n /**\n * Method to display all project present in database\n * @param isDeleted indicating the project is deleted or not\n * @return list of project objects \n * @throws FetchFailException \n * @throws EmployeeManagementException \n */\n public List<Project> getAllProject(boolean isDeleted) throws EmployeeManagementException;\n\n /**\n * Method to delete project based on projectId\n * @param project project object for delete project\n * @return true for successful deletion else false\n */\n public boolean updateProject(Project project);\n\n /**\n * Method to check the id is present in database or not\n * @param projectId project id\n * @return true if id present in database else false\n * @throws EmployeeManagementException \n */\n\tpublic boolean isIdExist(int projectId) throws EmployeeManagementException;\n}",
"public interface VersionDeployDAO {\n\n List<VersionDeployDO> getVersionDeploy();\n}",
"List<Comment> getCommentsOfProject(int projectId) throws SQLException;",
"@Override\n\tpublic List<ProjectInfo> findProject(ProjectInfo project) {\n\t\treturn sqlSession.selectList(\"cn.sep.samp2.project.findProject\",project);\n\t}",
"List<Issue> listUserIssues( ModelObject modelObject );",
"public interface IOnlineRecordDao extends PagingAndSortingRepository<OnlineRecord, String> {\n\n}",
"public interface IAvis {\n String getCommentaire();\n\n void setCommentaire(String commentaire);\n\n int getNote();\n\n void setNote(int note);\n\n @ManyToOne\n Person getPerson();\n\n void setPerson(Person person);\n}",
"public interface HospitalisationRepository extends JpaRepository<Hospitalisation,Long> {\n\n}",
"public interface ParticipatorDao extends CrudRepository<Participator,Integer>{\n public Collection<Participator> findByAdmissionnum(int admissionnum);\n}",
"public interface TBizProjectDocService extends BaseService<TBizProjectDoc,TBizProjectDocExample>{\n\n PageParams<TBizProjectDoc> list(PageParams<TBizProjectDoc> pageParams);\n\n List<TBizProjectDoc> listAll();\n\n TBizProjectDoc findById(@NotNull Long id);\n\n Boolean del(List<Long> ids);\n\n Boolean saveOrUpdate(TBizProjectDoc bean);\n\n\n void saveOrUpdate(Long projectId,List<Long> docIds);\n\n\n List<Long> getDocIdsByProjectId(Long projectId);\n\n}",
"public List<ProjectEntity> getProjectByName() {\n\t\treturn null;\n\t}",
"public Project getProject(int projectId) throws EmployeeManagementException;",
"public interface IInterviewDAO {\n void insertInterview(Interview interview) throws SQLException;\n List<Interview> getAllInterviews() throws SQLException;\n Interview getInterviewById(int id) throws SQLException;\n void updateInterview(Interview interview) throws SQLException;\n void deleteInterview(int interviewId) throws SQLException;\n List<Interview> getPastInterviews() throws SQLException;\n List<Interview> getFutureInterviews() throws SQLException;\n List<Interview> getFutureInterviewsByDirectionId(int directionId) throws SQLException;\n}",
"List<CopilotProject> getCopilotProjects(long copilotProfileId) throws CopilotDAOException;",
"public interface AdCreativeRespository extends JpaRepository<AdCreative,Long> {\n\n}",
"@Repository\r\npublic interface TInStockDetailMapper {\r\n\r\n TInStockDetail get(String id);\r\n\r\n List<TInStockDetail> findList(TInStockDetail tInStockDetail);\r\n\r\n List<TInStockDetail> findAllList();\r\n\r\n int insert(TInStockDetail tInStockDetail);\r\n\r\n int insertBatch(List<TInStockDetail> tInStockDetails);\r\n\r\n int update(TInStockDetail tInStockDetail);\r\n\r\n int delete(TInStockDetail tInStockDetail);\r\n\r\n}",
"public List<String> getWorkingProject(String id, String string) {\n\t\tList<String> list = new ArrayList<String>();\n\t\tString query=null;\n\t\tjdbc JDBC=new jdbc();\n\t\t\n\t\tif(string.equals(\"projects\"))\n\t\t query=\"select P_id from Team where emp_id1=\"+id+\" OR emp_id2=\"+id+\" OR emp_id2=\"+id;\n\t\telse if(string.equals(\"startdate\"))\n\t\t query=\"select startDate from Team where emp_id1=\"+id+\" OR emp_id2=\"+id+\" OR emp_id2=\"+id;\n\t\telse if(string.equals(\"duedate\"))\n\t\t query=\"select DueDate from Team where emp_id1=\"+id+\" OR emp_id2=\"+id+\" OR emp_id2=\"+id;\n\t\telse if(string.equals(\"supervisor\"))\n\t\t query=\"select emp_id from Team where emp_id1=\"+id+\" OR emp_id2=\"+id+\" OR emp_id2=\"+id;\n\t\ttry {\n\t\t\tSystem.out.println(query);\n\t\t\tResultSet rs=JDBC.stat.executeQuery(query);\n\t\t\twhile (rs.next())\n\t\t\t{\n\t\t\t\tlist.add(rs.getString(1));\n\t\t\t}\n\t\t} catch (SQLException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t\treturn list;\n\t}",
"public interface AnalysisUnsharingRequest {\n void setUser(String user);\n\n @AutoBean.PropertyName(\"analyses\")\n void setAnalyses(List<String> analyses);\n\n String getUser();\n\n @AutoBean.PropertyName(\"analyses\")\n List<String> getAnalyses();\n}",
"ChangeData getChangeData(Project.NameKey projectName, Change.Id changeId);",
"public interface Repo {\n /**\n * Gets the url property: The url to access the repository.\n *\n * @return the url value.\n */\n String url();\n\n /**\n * Gets the fullName property: The name of the repository.\n *\n * @return the fullName value.\n */\n String fullName();\n\n /**\n * Gets the branches property: Array of branches.\n *\n * @return the branches value.\n */\n List<String> branches();\n\n /**\n * Gets the inner com.azure.resourcemanager.securityinsights.fluent.models.RepoInner object.\n *\n * @return the inner object.\n */\n RepoInner innerModel();\n}",
"public int getStoryId();",
"@GetMapping(value=\"/getProjectDetails/completed\")\n\tpublic List<Project> getAllProjectDetails()\n\t{\n\t\treturn integrationClient.getProjectDetiails();\n\t}",
"public interface DataBasePresent {\n void setDistrict(List<Name_Id> list);\n\n void setLocalBodyType(List<Name_Id> list);\n\n void setLocalBodyName(List<LocalBody> list);\n\n List<Name_Id> getDistrict();\n\n List<Name_Id> getLocalBodyType();\n\n List<LocalBody> getLocalBodyName(String districId ,String locatType);\n}",
"public interface ProjectRepository extends BasePagingAndSortingRepository<ProjectEntity, Long> {\n\n boolean changeStatus(ProjectEntity project, StatusEnum newStatus);\n\n List<ProjectEntity> findByOwner(String client);\n\n List<ProjectEntity> findForUser(String client);\n\n List<ProjectEntity> findForMember(Long memberId, String client);\n\n\n}",
"public interface RepoModule {\n void saveModule(Module module) throws Exception;\n void saveLocalObj(Collection<Module> modules) throws Exception;\n void updateFinalStatus(String vehicleNo) throws Exception;\n void updateFlag(String vehicleNo, String checkPointName) throws Exception;\n void deleteTableData()throws Exception;\n void deleteTableData(String vehicleNo) throws Exception;\n Set<Module> uploadModuleData(String userId) throws Exception;\n Integer checkDataInspections() throws Exception;\n List<String> getLocalVehicleList()throws Exception;\n List<Module> uploadData(String userId)throws Exception;\n Set<Module> selectAll()throws Exception;\n}",
"@Query(\"SELECT * FROM Project WHERE id = :projectId\")\n LiveData<Project> getProject(long projectId);"
]
| [
"0.6104706",
"0.58918846",
"0.57684916",
"0.56797916",
"0.5569438",
"0.55389166",
"0.5501219",
"0.5486785",
"0.5480288",
"0.54460424",
"0.541958",
"0.54138714",
"0.5401079",
"0.5398677",
"0.5397162",
"0.5392705",
"0.53816134",
"0.5362581",
"0.5358303",
"0.5350937",
"0.53453666",
"0.5340587",
"0.53400284",
"0.53005815",
"0.52920896",
"0.5291504",
"0.52848095",
"0.5258824",
"0.5247036",
"0.52431476",
"0.5239356",
"0.5236514",
"0.5232715",
"0.5221352",
"0.5217435",
"0.52135146",
"0.5210883",
"0.519811",
"0.51896405",
"0.5172817",
"0.5167771",
"0.5165582",
"0.51646066",
"0.515206",
"0.5143175",
"0.5142103",
"0.5138991",
"0.513047",
"0.5127531",
"0.5124724",
"0.5122905",
"0.5111285",
"0.5110498",
"0.51102304",
"0.5109196",
"0.5104987",
"0.50979495",
"0.50839335",
"0.5082844",
"0.5081796",
"0.50707114",
"0.50667906",
"0.5052667",
"0.50494593",
"0.50480336",
"0.5039838",
"0.5036533",
"0.503486",
"0.50329655",
"0.50293326",
"0.50282377",
"0.50210214",
"0.50172555",
"0.50135446",
"0.501115",
"0.5010058",
"0.50090957",
"0.5005862",
"0.5002434",
"0.49968678",
"0.4987312",
"0.49866784",
"0.4984615",
"0.49836963",
"0.4976039",
"0.49652827",
"0.49636656",
"0.49627537",
"0.49614236",
"0.49587074",
"0.49552357",
"0.4948879",
"0.4947556",
"0.49463582",
"0.49373823",
"0.4933469",
"0.49329478",
"0.4931436",
"0.49310964",
"0.4929587",
"0.49288648"
]
| 0.0 | -1 |
/ Draw a rectangle. | public static void drawRecentage(Canvas canvas, int x1, int y1, int x2, int y2)
{
DrawLineCmd.drawLine(canvas, x1, y1, x1, y2);
DrawLineCmd.drawLine(canvas, x1, y1, x2, y1);
DrawLineCmd.drawLine(canvas, x1, y2, x2, y2);
DrawLineCmd.drawLine(canvas, x2, y1, x2, y2);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void drawRect(int x, int y, int width, int height);",
"public void drawRect(int x, int y, int width, int height, int color);",
"public void drawRectangle(int x, int y, int width, int height, Color color) {\n implementation.devDrawRectangle(x, y, width, height, color);\n }",
"public void drawRect(float x, float y, float width, float height) {\n float x1 = margins.computeX(x), y1 = margins.computeY(y);\n float x2 = margins.computeX(x + width), y2 = margins.computeY(y + height);\n buffer(() -> {\n GL15.glBufferData(GL15.GL_ARRAY_BUFFER, new float[]{\n x1, y1, 0F, 0F,\n x2, y1, 1F, 0F,\n x2, y2, 1F, 1F,\n x1, y2, 0F, 1F\n }, GL15.GL_STREAM_DRAW);\n GL11.glDrawArrays(GL11.GL_QUADS, 0, 4);\n });\n }",
"public void drawRect(int x, int y, int width, int height, int color){\n hline(x, x + width - 1, y, color);\n hline(x, x + width - 1, y + height - 1, color);\n vline(y, y + height - 1, x, color);\n vline(y, y + height - 1, x + width - 1, color);\n }",
"public void drawRectangle(Rectangle rectangle) {\n implementation.devDrawRectangle(\n (int) rectangle.getMinX(),\n (int) rectangle.getMinY(),\n (int) rectangle.getWidth(),\n (int) rectangle.getHeight(),\n rectangle.getColor()\n );\n }",
"public static void drawRectangle(int x, int y,int width, int height){\n for (int i = 0; i < y; i++) {\n System.out.println();\n }\n for (int i = 1; i < width; i++) {\n System.out.print(\"*\");\n }\n System.out.println(\"*\");\n for (int i = 0; i < height; i++) {\n System.out.print(\"*\");\n for (int j = 2; j < width; j++) {\n System.out.print(\" \");\n }\n System.out.println(\"*\");\n }\n for (int i = 0; i < width; i++) {\n System.out.print(\"*\");\n }\n\n }",
"@Override\n\tpublic void draw() {\n\t\tSystem.out.println(\"Here is the method to draw a Rectangle\");\n\t}",
"public void strokeRectangle(int x, int y, int width, int height);",
"private void drawRectangle(GraphicsContext gc, double x, double y) {\r\n GraphicsContext gc2 = myCanvas.getGraphicsContext2D();\r\n gc2.setFill(randomColor());\r\n gc2.fillRect(x - 20, y - 20, 40, 40);\r\n }",
"public void drawRect(int left, int top, int right, int i, Paint p) {\n\t\t\n\t}",
"public static void drawRectangle(double width, double height) {\n gl.glPushMatrix();\n gl.glScaled(width, height, 1);\n gl.glBegin(GL.GL_TRIANGLE_FAN);\n gl.glVertex3d(-0.5, -0.5, 0);\n gl.glVertex3d(0.5, -0.5, 0);\n gl.glVertex3d(0.5, 0.5, 0);\n gl.glVertex3d(-0.5, 0.5, 0);\n gl.glEnd();\n gl.glPopMatrix();\n }",
"public static void drawRectangle(Canvas c, int x, int y, int w, int h) {\n CanvasTools.drawRectangle(c, x, y, w, h, HTMLColors.RED, HTMLColors.YELLOW);\n }",
"public GLGraphics drawRect(float x, float y, float w, float h) {\n\t\treturn renderRect(false, x, y, w, h);\n\t}",
"public void drawRect(int x, int y, Graphics2D g) {\n rect = new Rectangle2D.Double(x * 10, y * 10, 10, 10);\n g.fillRoundRect(2, 2, x * 10, y * 10, 10, 10);\n g.setColor(Color.orange);\n g.draw(rect);\n }",
"protected void drawRectangle(Graphics2D g2, final Color c, final double x, final double y, final double width, final double height) {\r\n\r\n g2.setColor(c);\r\n\r\n g2.fillRect(floor(x), floor(y), floor(width), floor(height));\r\n }",
"@Override\n\tpublic void draw() {\n\t\tSystem.out.println(\"You are drawing a RECTANGLE\");\n\t}",
"public void drawRect(int offX, int offY, int width, int height, int colour) {\n\tif (offX + width - camX < 0)\r\n\t return;\r\n\tif (offY + height - camY < 0)\r\n\t return;\r\n\tif (offX - camX > pW)\r\n\t return;\r\n\tif (offY - camY > pH)\r\n\t return;\r\n\r\n\tfor (int y = 0; y < height; y++) {\r\n\t setPixel(offX, y + offY, colour);\r\n\t setPixel(offX + width - 1, y + offY, colour);\r\n\t}\r\n\r\n\tfor (int x = 0; x < width; x++) {\r\n\t setPixel(x + offX, offY, colour);\r\n\t setPixel(x + offX, offY + height - 1, colour);\r\n\t}\r\n }",
"public void drawRectangle(int RGB, int startX, int startY, int width,\n\t\t\tint height) {\n\n\t\tfor (int x = startX; x < (startX + width + 1); x++) {\n\t\t\tdrawPixel(RGB, x, startY);\n\t\t\tdrawPixel(RGB, x, startY + height);\n\t\t}\n\t\tfor (int y = startY; y < (startY + height + 1); y++) {\n\t\t\tdrawPixel(RGB, startX, y);\n\t\t\tdrawPixel(RGB, startX + width, y);\n\t\t}\n\t\t\n\t}",
"public void drawRectangle(){\n\t height = height + 1;\n\t width = width + 1;\n\t //This loop draws the rectangle.\n\t for(int p = 1; p < height; p++){\n\t\tfor (int q = 1; q < width; q++){\n\t\t System.out.print(appearance);\n\t\t}\n\t\tSystem.out.println(\"\");\n\t }\n\t System.out.println(\"\");\n\n\t}",
"public void fillRectangle(int x, int y, int width, int height);",
"@Override\n public void rect(double x, double y, double width, double height) {\n graphicsEnvironmentImpl.rect(canvas, x, y, width, height);\n }",
"private void drawRect(double x0, double y0, double width, double height, int lWidth, Color color){\n \n lWidth = Math.min(lWidth, max_width);\n \n x0 += 0.5 * lWidth;\n y0 += 0.5 * lWidth;\n width -= lWidth;\n height -= lWidth;\n \n x0 /= this.width;\n y0 /= this.height;\n width /= this.width;\n height /= this.height;\n \n x0 -= 0.5;\n y0 -= 0.5;\n \n glLineWidth(lWidth);\n \n glBegin(GL_LINES);\n glEnable(GL_LINE_WIDTH);\n glColor3f(color.getRed(), color.getGreen(), color.getBlue());\n \n //left side\n glVertex3d(x0, y0 + height, 0);\n glVertex3d(x0, y0, 0);\n \n //Right side\n glVertex3d(x0 + width, y0, 0);\n glVertex3d(x0 + width, y0 + height, 0);\n \n x0 -= (double)lWidth / (double)this.width / 2d;\n width += (double)lWidth / (double)this.width;\n \n //bottom\n glVertex3d(x0, y0, 0);\n glVertex3d(x0 + width, y0, 0);\n \n //top\n glVertex3d(x0, y0 + height, 0);\n glVertex3d(x0 + width, y0 + height, 0);\n \n \n glEnd();\n }",
"public void draw(){\n\t\t int startRX = 100;\r\n\t\t int startRY = 100;\r\n\t\t int widthR = 300;\r\n\t\t int hightR = 300;\r\n\t\t \r\n\t\t \r\n\t\t // start points on Rectangle, from the startRX and startRY\r\n\t\t int x1 = 0;\r\n\t\t int y1 = 100;\r\n\t\t int x2 = 200;\r\n\t\t int y2 = hightR;\r\n\t\t \r\n //direction L - false or R - true\r\n\t\t \r\n\t\t boolean direction = true;\r\n\t\t \t\r\n\t\t\r\n\t\t //size of shape\r\n\t\t int dotD = 15;\r\n\t\t //distance between shapes\r\n\t int distance = 30;\r\n\t\t \r\n\t rect(startRX, startRY, widthR, hightR);\r\n\t \r\n\t drawStripesInRectangle ( startRX, startRY, widthR, hightR,\r\n\t \t\t x1, y1, x2, y2, dotD, distance, direction) ;\r\n\t\t \r\n\t\t super.draw();\r\n\t\t}",
"public void fillRectangle(RectangleShape rectangle);",
"public static void renderRectangle(double x , double y , double width , double height) {\n\t\t//Find out what rendering mode to use\n\t\tif (! Settings.Android && Settings.Video.OpenGL)\n\t\t\t//Render an unfilled rectangle using OpenGL\n\t\t\tBasicRendererOpenGL.renderRectangle(x , y , width , height);\n\t\telse if (! Settings.Android && ! Settings.Video.OpenGL)\n\t\t\t//Render an unfilled rectangle using Java\n\t\t\tBasicRendererJava.renderRectangle(x , y , width , height);\n\t\telse if (Settings.Android && ! Settings.Video.OpenGL) {\n\t\t\t//Render an unfilled rectangle using Android\n\t\t\tBasicRendererAndroid.renderRectangle(x , y , width , height);\n\t\t}\n\t}",
"void drawAt(DrawSurface d, Rectangle rect);",
"public void createRectangle(double x, double y, double width, double height) {\r\n GRect rectangle = new GRect(x, y, width, height);\r\n rectangle.setFilled(true);\r\n rectangle.setFillColor(Color.GRAY);\r\n rectangle.setColor(Color.WHITE);\r\n add(rectangle);\r\n }",
"@Override\n\tpublic void draw() {\n\t\tSystem.out.println(\"Rectangle.draw()\");\n\t}",
"public void fillRect(int x, int y, int width, int height);",
"public void drawRect(float x, float y, float width, float height, float u, float v, float texW, float texH) {\n float a = TextureManager.getBound().w, b = TextureManager.getBound().h;\n float u1 = u / a, v1 = v / a;\n float u2 = (u + texW) / a, v2 = (v + texH) / b;\n float x1 = margins.computeX(x), y1 = margins.computeY(y);\n float x2 = margins.computeX(x + width), y2 = margins.computeY(y + height);\n buffer(() -> {\n GL15.glBufferData(GL15.GL_ARRAY_BUFFER, new float[]{\n x2, y1, u2, v1,\n x1, y1, u1, v1,\n x2, y2, u2, v2,\n x1, y2, u1, v2\n }, GL15.GL_STREAM_DRAW);\n GL11.glDrawArrays(GL11.GL_QUADS, 0, 4);\n });\n }",
"void draw_rect(int x, int y, int w, int h, char[][] _display, char c) {\n for (int i = 0; i < w; i++) {\n draw_char(x + i, y, _display, c);\n }\n for (int i = 0; i < h; i++) {\n draw_char(x + w, y + i, _display, c);\n }\n for (int i = w; i > 0; i--) {\n draw_char(x + i, y + h, _display, c);\n }\n for (int i = h; i > 0; i--) {\n draw_char(x, y + i, _display, c);\n }\n }",
"public void strokeRectangle(RectangleShape rectangle);",
"public void drawRect(float[] rect) {\n\t\trect(rect[0], rect[1], rect[2], rect[3]);\n\t}",
"public static void renderFilledRectangle(double x , double y , double width , double height) {\n\t\t//Find out what rendering mode to use\n\t\tif (! Settings.Android && Settings.Video.OpenGL)\n\t\t\t//Render a filled rectangle using OpenGL\n\t\t\tBasicRendererOpenGL.renderFilledRectangle(x , y , width , height);\n\t\telse if (! Settings.Android && ! Settings.Video.OpenGL)\n\t\t\t//Render a filled rectangle using Java\n\t\t\tBasicRendererJava.renderFilledRectangle(x , y , width , height);\n\t\telse if (Settings.Android && ! Settings.Video.OpenGL)\n\t\t\t//Render a filled rectangle using android\n\t\t\tBasicRendererAndroid.renderFilledRectangle(x , y , width , height);\n\t}",
"public void draw(Graphics2D g, Dimension area);",
"public static void drawRectangle(int a, int b) {\n for(int i = 0; i < a; i++) {\n if(i == 0 || i == (a - 1)) {\n for (int o = 0; o < b; o++) {\n System.out.print(\"*\");\n }\n System.out.print(\"\\n\");\n } else {\n System.out.print(\"*\");\n for (int o = 0; o < (b - 2); o++) {\n System.out.print(\" \");\n }\n System.out.print(\"*\\n\");\n }\n }\n }",
"static void rectangle(int width, int height, Turtle turtle)\r\n {\r\n turtle.turnRight();\r\n turtle.forward(width);\r\n turtle.turnRight();\r\n turtle.forward(height);\r\n turtle.turnRight();\r\n turtle.forward(width);\r\n turtle.turnRight();\r\n turtle.forward(height);\r\n }",
"public void drawStrokeRectangle(int x, int y, int width, int height, Color color) {\n implementation.devDrawStrokeRectangle(x, y, width, height, color);\n }",
"public void drawRect(float[] rect) {\n\t\tparent.rect(rect[0], rect[1], rect[2], rect[3]);\n\t}",
"public void renderRectangle(int x, int y, float width, float height, int color)\n {\n int xStart = x;\n int yStart = y;\n float xEnd = xStart + width;\n float yEnd = yStart + height;\n if (xStart >= this.width || yStart >= this.height || xEnd < 0 || yEnd < 0) return;\n if (xStart < 0) xStart = 0;\n if (yStart < 0) yStart = 0;\n if (xEnd > this.width) xEnd = this.width;\n if (yEnd > this.height) yEnd = this.height;\n\n for (int xPos = xStart; xPos < xEnd; xPos++)\n {\n for (int yPos = yStart; yPos < yEnd; yPos++)\n {\n int index = yPos * this.width + xPos;\n if (index < 0 || index > data.length - 1) continue;\n if (xPos == xStart || xPos == xEnd - 1 || yPos == yStart || yPos == yEnd - 1)\n {\n if (((color >> 24) & 0xFF) == 255)\n {\n data[index] = color;\n } else if (((color >> 24) & 0xFF) > 0)\n {\n data[index] = Color.tint(data[index], color);\n }\n }\n }\n }\n }",
"private void drawIntoRect(Graphics2D g2, BufferedImage image, Rectangle rect) {\r\n\t\tfor (int j = rect.y; j < rect.y + rect.height; j++) {\r\n\t\t\tfor (int k = rect.x; k < rect.x + rect.width; k++) {\r\n\t\t\t\tint x = xoff + Tile.toScreenX(k, j); \r\n\t\t\t\tint y = yoff + Tile.toScreenY(k, j); \r\n\t\t\t\tg2.drawImage(image, x - 1, y - image.getHeight(), null);\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"public void draw(Graphics g, Rectangle bounds)\n\t{\n\t\t\n\t}",
"public void fillRect(Color c, Rectangle2D rect2d);",
"abstract void draw(Graphics g, int xoff, int yoff,\n int x, int y, int width, int height);",
"void draw() {\n\t\tSystem.out.println(\"Drawing the Rectange...\");\n\t\t}",
"public void DasherDrawRectangle(long iLeft, long iMinY, long iRight, long iMaxY, int Color, int iOutlineColour, int iThickness) {\r\n\t\t\r\n\t\ttemp1.init(iLeft, iMinY);\r\n\t\tDasher2Screen(temp1);\r\n\t\t\r\n\t\ttemp2.init(iRight, iMaxY);\r\n\t\tDasher2Screen(temp2);\r\n\t\t\r\n\t\tScreen().DrawRectangle((int)temp1.x, (int)temp1.y, (int)temp2.x, (int)temp2.y, Color, iOutlineColour, iThickness);\r\n\t}",
"protected abstract void fillRect(final float x, final float y,\n final float width, final float height);",
"public void drawRoundRect(int x, int y, int width, int height, int arcWidth,\r\n\t\t\tint arcHeight)\r\n\t{\r\n\t\t// System.out.println(\"drawRoundRect\");\r\n\t}",
"@Override\n\tpublic void draw(Graphics g) {\n\t\tg.setColor(Color.ORANGE);\n\t\tg.fillRect(x, y, WIDTH, HEIGHT);\n\t}",
"public static void writeRectangle(Model model, int x1, int y1, int x2, int y2, char colour) {\n int xLength = model.getWidth();\n int yLength = model.getHeight();\n\n if (x1 > xLength || x2 > xLength || y1 > yLength || y2 > yLength) {\n System.out.println(String.format(\"Couldn't create rectangle inside current simpleCanvas width: %d, height: %d\", xLength, yLength));\n return;\n }\n\n writeLine(model, x1, y1, x1, y2, colour);\n writeLine(model, x1, y2, x2, y2, colour);\n writeLine(model, x2, y2, x2, y1, colour);\n writeLine(model, x2, y1, x1, y1, colour);\n }",
"void createRectangles();",
"void createRectangle(Rect r, int[] color){\n noStroke();\n fill(color[0],color[1],color[2]);\n rect(r.x,r.y,r.width,r.height);\n }",
"void render(Rectangle borders);",
"private void rectangle(final Graphics2D theG2d, final double theX, \r\n final double theY, final double theWidth, \r\n final double theHeight, final String theString) { \r\n final Rectangle2D rect = \r\n new Rectangle2D.Double(theX, theY, theWidth, theHeight); \r\n if (DRAW.equals(theString)) { \r\n theG2d.draw(rect); \r\n } else { \r\n theG2d.fill(rect); \r\n } \r\n }",
"public void paint(SelectionRect rectangle, Graphics graphics){\r\n\t\tif(rectangle.isActive()){\r\n\t\t\tgraphics.setColor(Color.green);\r\n\t\t\tgraphics.drawRect(rectangle.getX(), rectangle.getY(), rectangle.getW(), rectangle.getH());\r\n\t\t}\r\n\t}",
"public void renderRectangle(int x, int y, int width, int height, float scale, int color)\n {\n renderRectangle(x, y, width * scale, height * scale, color);\n }",
"public void fillRect(int x, int y, int width, int height, int color){\n int x2 = x + width - 1;\n int y2 = y + height - 1;\n\n if(x >= this.width) return;\n if(y >= this.height) return;\n if(x2 < 0) return;\n if(y2 < 0) return;\n if(x < 0) x = 0;\n if(y < 0) y = 0;\n if(x2 >= this.width) x2 = this.width - 1;\n if(y2 >= this.height) y2 = this.height - 1;\n\n y2++;\n while(y != y2){\n hline(x, x2, y, color);\n y++;\n }\n }",
"public void renderFilledRectangle(float x, float y, float width, float height, int color)\n {\n float xStart = x;\n float yStart = y;\n float xEnd = xStart + width;\n float yEnd = yStart + height;\n\n if (xStart < 0) xStart = 0;\n if (yStart < 0) yStart = 0;\n if (xEnd > this.width) xEnd = this.width;\n if (yEnd > this.height) yEnd = this.height;\n if (xStart >= this.width || yStart >= this.height || xEnd < 0 || yEnd < 0) return;\n\n for (int xPos = (int) xStart; xPos < xEnd; xPos++)\n {\n for (int yPos = (int) yStart; yPos < yEnd; yPos++)\n {\n int index = yPos * this.width + xPos;\n if (index < 0 || index > data.length - 1) continue;\n if (((color >> 24) & 0xFF) == 255)\n {\n data[index] = color;\n } else if (((color >> 24) & 0xFF) > 0)\n {\n data[index] = Color.tint(data[index], color);\n }\n }\n }\n }",
"public void renderFilledRectangle(int x, int y, int width, int height, int color)\n {\n int xStart = x;\n int yStart = y;\n int xEnd = xStart + width;\n int yEnd = yStart + height;\n\n if (xStart < 0) xStart = 0;\n if (yStart < 0) yStart = 0;\n if (xEnd > this.width) xEnd = this.width;\n if (yEnd > this.height) yEnd = this.height;\n if (xStart >= this.width || yStart >= this.height || xEnd < 0 || yEnd < 0) return;\n\n for (int xPos = xStart; xPos < xEnd; xPos++)\n {\n for (int yPos = yStart; yPos < yEnd; yPos++)\n {\n int index = yPos * this.width + xPos;\n if (index < 0 || index > data.length - 1) continue;\n if (((color >> 24) & 0xFF) == 255)\n {\n data[index] = color;\n } else if (((color >> 24) & 0xFF) > 0)\n {\n data[index] = Color.tint(data[index], color);\n }\n }\n }\n }",
"public void draw(Polygon poly, float x, float y, float width, float height) {\n draw(poly, x, y, width, height, x, y, 0, 1, 1, 1, 1);\n }",
"public GLGraphics fillRect(float x, float y, float w, float h) {\n\t\treturn renderRect(true, x, y, w, h);\n\t}",
"@Override\n\tpublic void draw(Graphics g) {\n\t\tg.setColor(Color.orange);\n\t\tg.fillRect(getX(), getY(), getW(), getH());\n\t}",
"protected void renderFilledRect(Graphics g, int x1, int y1, int x2, int y2)\n {\n\tg.fillRect(x1,y1,x2,y2);\n\tig.fillRect(x1,y1,x2,y2);\n }",
"public void drawStrokeRectangle(Rectangle rectangle) {\n implementation.devDrawStrokeRectangle(\n (int) rectangle.getMinX(),\n (int) rectangle.getMinY(),\n (int) rectangle.getWidth(),\n (int) rectangle.getHeight(),\n rectangle.getColor()\n );\n }",
"void drawRectangle(int index,int[] color){\n Rect r;\n background(255);\n for(int i=0;i<arr.length;i++){\n if(i!=index) {\n noStroke();\n r=new Rect(40 + i * 80, 400, 75, -arr[i] * 20, color1);\n createRectangle(r, color1);\n }else{\n noStroke();\n r=new Rect(40 + i* 80, 400, 75, -arr[i] * 20, color);\n createRectangle(r, color);\n }\n }\n }",
"protected void createRect()\r\n\t{\r\n\t\trect = new Rectangle(getX(),getY(),width,height);\r\n\t}",
"private static void addRectangle(String[] input) throws NumberFormatException, IncorrectParametersException{\n if (input.length == 5){\n try{\n int x1 = Integer.parseInt(input[1]); \n int y1 = Integer.parseInt(input[2]);\n int x2 = Integer.parseInt(input[3]); \n int y2 = Integer.parseInt(input[4]);\n try{\n canvas.createRectangle(x1, y1, x2, y2);\n System.out.println(canvas.render());\n } catch (NullPointerException ex) {\n System.out.println(\"Initialise a new canvas first!\");\n }\n } catch (NumberFormatException ex) {\n System.out.println(\"HELP: to create a new rectangle enter `R x1 y1 x2 y2`, with (x1,y1) being the upper left corner and (x2,y2) the lower right one.\");\n }\n } else {\n System.out.println(\"HELP: to create a new rectangle enter `R x1 y1 x2 y2`, with (x1,y1) being the upper left corner and (x2,y2) the lower right one.\");\n throw new IncorrectParametersException(\"\");\n }\n }",
"public Shapes draw ( );",
"void draw (Graphics2D g);",
"@Override\n public void fillRect(double x, double y, double width, double height) {\n graphicsEnvironmentImpl.fillRect(canvas, x, y, width, height);\n }",
"@Override\n\tpublic void display() {\n\t\tSystem.out.println(\"This is rectangle\");\n\t}",
"public void draw(Graphics2D g_)\n {\n // put your code here\n g_.setColor(col);\n g_.fillRect(rX, rY, x, y);\n }",
"@Override\r\n\tpublic void draw(Graphics g) {\n\t\tg.setColor(Color.green);\r\n\t\tg.fillRect(getX(), getY(), getWidth(), getHeight());\r\n\t}",
"public abstract void clearRect(int x, int y, int width, int height);",
"public void draw(Graphics window)\n {\n window.setColor(color);\n window.fillRect(getX(), getY(), getWidth(), getHeight());\n }",
"private Geometry createRectangle(double x, double y, double w, double h) {\n Coordinate[] coords = {\n new Coordinate(x, y), new Coordinate(x, y + h),\n new Coordinate(x + w, y + h), new Coordinate(x + w, y),\n new Coordinate(x, y)\n };\n LinearRing lr = geometry.getFactory().createLinearRing(coords);\n\n return geometry.getFactory().createPolygon(lr, null);\n }",
"public void draw(Graphics g) {\n g.setColor(color);\n g.fillRect(x, y, width, height);\n }",
"@Override\n public void draw(Graphics graphics){\n graphics.fillRect(referencePoint.getX() + width / 3, referencePoint.getY() + height / 3, width / 3, height / 3);\n }",
"public RectangleShape(int xCoord, int yCoord, int widthOfRect, int heightOfRect)\n {\n System.out.println(\"setting x to: \"+ xCoord+\" & setting y to: \"+ yCoord);\n x = xCoord;\n y = yCoord;\n width = widthOfRect;\n height = heightOfRect;\n }",
"public void repaint(Rectangle r) {}",
"public static void drawTexturedRectangle(int textureId, double width, double height) {\n gl.glColor3f(1.0f, 1.0f, 1.0f); // remove color before applying texture \n textures.get(textureId).enable(gl);\n textures.get(textureId).bind(gl); // set texture to use\n gl.glPushMatrix();\n gl.glScaled(width, height, 1);\n TexturedShapes.square(gl, 1, true);\n gl.glPopMatrix();\n textures.get(textureId).disable(gl);\n }",
"@Override\n public void draw(ModernComponent c, Graphics2D g2, IntRect rect, Props props) {\n\n g2.setColor(FILL);\n\n fill(c, g2, rect, props);\n\n g2.setColor(BORDER);\n outline(c, g2, rect, props);\n }",
"private void drawSquare(int x, int y, Color color) {\r\n\t\t// sets the color to the passed in color.\r\n\t\tg.setColor(color);\r\n\t\t// draws a rectangle based on the given properties.\r\n\t\tg.fillRect(x * TetrisGame.SQUARE_LENGTH, y * TetrisGame.SQUARE_LENGTH,\r\n\t\t\t\t TetrisGame.SQUARE_LENGTH - 1,\r\n\t\t\t\t TetrisGame.SQUARE_LENGTH - 1);\r\n\t}",
"public void strokeRoundRectangle(int x, int y, int width, int height, int radius);",
"public void draw(Graphics g);",
"public void draw(Graphics g);",
"@Override\r\n\tpublic void render(Graphics g) {\n\t\tg.setColor(Color.yellow);\r\n\t\tg.fillRect((int) getX(), (int) getY(), 5, 10);\r\n\t}",
"@Override\n public void strokeRect(double x, double y, double width, double height) {\n graphicsEnvironmentImpl.strokeRect(canvas, x, y, width, height);\n }",
"void draw(GraphicsContext context);",
"public void clearRect(int x, int y, float width, float height);",
"public void draw(Graphics window);",
"Rectangle(int l, int w)\n {\n\tlength = l;\n\twidth = w;\n }",
"public static void mainDraw(Graphics graphics){\n\n int centerX = WIDTH / 3 ;\n int centerY = HEIGHT / 3;\n int rectA2 = 20 / 2;\n\n graphics.setColor(Color.GREEN);\n graphics.drawRect(centerX - rectA2, centerY - rectA2, rectA2 * 2, rectA2 * 2);\n\n centerX = WIDTH /5 ;\n centerY = HEIGHT / 2;\n rectA2 = 40 / 2;\n\n graphics.setColor(Color.YELLOW);\n graphics.drawRect(centerX - rectA2, centerY - rectA2, rectA2 * 2, rectA2 * 2);\n\n centerX = WIDTH / 2 ;\n centerY = HEIGHT / 6;\n rectA2 = 70 / 2;\n\n graphics.setColor(Color.BLUE);\n graphics.drawRect(centerX - rectA2, centerY - rectA2, rectA2 * 2, rectA2 * 2);\n\n centerX = WIDTH / 2 ;\n centerY = HEIGHT / 2;\n rectA2 = 100 / 2;\n\n graphics.setColor(Color.RED);\n graphics.drawRect(centerX - rectA2, centerY - rectA2, rectA2 * 2, rectA2 * 2);\n\n }",
"public void fillRectangle(int RGB, int startX, int startY, int width,\n\t\t\tint height) {\n\t\tfor (int y = startY; y < (startY + height); y++) {\n\t\t\tdrawHorizontalLine(RGB, startX, y, width);\n\t\t}\n\t}",
"public void draw() {\n if (r.isVisible()) {\n Canvas canvas = Canvas.getCanvas();\n canvas.draw(r, new java.awt.Rectangle(r.getX(), r.getY(), \n width, height));\n canvas.wait(10);\n }\n }",
"public void addRectangle(Rectangle rectangle){\n rectangles.add(rectangle);\n }",
"@Override\n\tvoid draw(Graphics g) {\n\t\tg.setColor(needsHighlight() ? selectColor : Color.GRAY);\n\t\tsetBbox(x, y, x2, y2);\n\t\tif (x < x2 && y < y2)\n\t\t\tg.fillRect(x, y, x2 - x, y2 - y);\n\t\telse if (x > x2 && y < y2)\n\t\t\tg.fillRect(x2, y, x - x2, y2 - y);\n\t\telse if (x < x2 && y > y2)\n\t\t\tg.fillRect(x, y2, x2 - x, y - y2);\n\t\telse\n\t\t\tg.fillRect(x2, y2, x - x2, y - y2);\n\t}",
"@Override\n\tpublic void draw(Graphics2D g, int x, int y,int width,int height) {\n\n\t}",
"public void drawSelection(int x, int y, int width, int height) {\n implementation.devDrawStrokeRectangle(x, y, width, height, Color.BLUE);\n }",
"@Override\n public void fillRectangle(int x, int y, int width, int height) {\n Rectangle2D rect = new Rectangle2D.Float(x + transX, y + transY, width - 1, height - 1);\n\n checkState();\n getGraphics2D().setPaint(getColor(getSWTGraphics().getBackgroundColor()));\n getGraphics2D().fill(rect);\n }"
]
| [
"0.8481154",
"0.845408",
"0.8043277",
"0.79105747",
"0.78564423",
"0.7757253",
"0.77297014",
"0.7722108",
"0.7687808",
"0.7664041",
"0.76591426",
"0.7658207",
"0.7644127",
"0.7609862",
"0.75770664",
"0.75451326",
"0.7543305",
"0.7387476",
"0.73622847",
"0.7332273",
"0.7308455",
"0.7299466",
"0.72808486",
"0.7275035",
"0.7271346",
"0.7225445",
"0.7208681",
"0.71785134",
"0.7142768",
"0.71389246",
"0.7136137",
"0.7134669",
"0.7083845",
"0.7018207",
"0.7007884",
"0.6911336",
"0.6879896",
"0.68760216",
"0.687367",
"0.68418235",
"0.6810576",
"0.68050265",
"0.6799041",
"0.6796608",
"0.6776923",
"0.67647904",
"0.6742711",
"0.67426604",
"0.66971576",
"0.6674878",
"0.66723627",
"0.66461813",
"0.66290414",
"0.65910375",
"0.6590811",
"0.65844536",
"0.65587133",
"0.6555602",
"0.6553613",
"0.6550472",
"0.6535426",
"0.6531965",
"0.65140015",
"0.64838594",
"0.6474534",
"0.64638984",
"0.64557296",
"0.64272344",
"0.6424505",
"0.6380904",
"0.6360713",
"0.63499933",
"0.6348228",
"0.63462776",
"0.6345282",
"0.63383317",
"0.63357586",
"0.6332506",
"0.6325033",
"0.6323438",
"0.62867045",
"0.62617517",
"0.6257773",
"0.62572217",
"0.62439525",
"0.6223726",
"0.6223726",
"0.62195706",
"0.6217367",
"0.6211369",
"0.6208767",
"0.6203456",
"0.6203427",
"0.6188493",
"0.61739296",
"0.61689687",
"0.6163006",
"0.6151643",
"0.6149971",
"0.61272466",
"0.6124268"
]
| 0.0 | -1 |
/ renamed from: X.0uP reason: invalid class name and case insensitive filesystem | public interface AbstractC19090uP {
void ADh(C07020Vp v);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private String fixClassName(String strClassName) {\r\n\t\tstrClassName = strClassName.replace('\\\\', '.');\r\n\t\tstrClassName = strClassName.replace('/', '.');\r\n\t\tstrClassName = strClassName.substring(0, strClassName.length() - 6);\r\n\t\t// remove \".class\"\r\n\t\treturn strClassName;\r\n\t}",
"public void testClassName() {\n\t\tClassName name = this.compiler.createClassName(\"test.Example\");\n\t\tassertEquals(\"Incorrect package\", \"generated.officefloor.test\", name.getPackageName());\n\t\tassertTrue(\"Incorrect class\", name.getClassName().startsWith(\"Example\"));\n\t\tassertEquals(\"Incorrect qualified name\", name.getPackageName() + \".\" + name.getClassName(), name.getName());\n\t}",
"private String checkName(String filename,int start_off){\n String name=FilenameUtil.setForwardSlash(filename);\n\n // check that it is a possibility\n if(name==null || name.length()<=0) return null;\n if(name.indexOf(matchname)<0) \n if( name.indexOf( matchname1) < 0) return null;\n if(! name.endsWith(\".class\") ) return null;\n if(name.indexOf(\"$\")>name.lastIndexOf(\"/\")) return null;\n \n // chop off the class part\n name=name.substring(start_off,name.length()-6);\n name=name.replace('/','.');\n \n return name;\n }",
"protected JBuilderRenameClassRefactoring()\n\t{\n\t\tsuper();\n\t}",
"public void testRenameToNonJava() throws JavaModelException {\n\t\tIPath projectPath = env.addProject(\"Project\"); //$NON-NLS-1$\n\t\tenv.addExternalJars(projectPath, Util.getJavaClassLibs());\n\t\t\n\t\t// remove old package fragment root so that names don't collide\n\t\tenv.removePackageFragmentRoot(projectPath,\"\"); //$NON-NLS-1$\n\t\t\n\t\tIPath root = env.addPackageFragmentRoot(projectPath, \"src\"); //$NON-NLS-1$\n\t\tenv.setOutputFolder(projectPath, \"bin\"); //$NON-NLS-1$\n\t\t\n\t\tIPath cuPath = env.addClass(root, \"p1\", \"X\", //$NON-NLS-1$ //$NON-NLS-2$\n\t\t\t\"package p1;\\n\"+ //$NON-NLS-1$\n\t\t\t\"public class X extends Y {\\n\"+ //$NON-NLS-1$\n\t\t\t\"}\\n\" //$NON-NLS-1$\n\t\t\t);\n\t\t\t\n\t\tfullBuild(projectPath);\n\t\texpectingOnlyProblemsFor(cuPath);\n\t\texpectingOnlySpecificProblemFor(cuPath, new Problem(\"X\", \"Y cannot be resolved to a type\", cuPath, 35, 36, CategorizedProblem.CAT_TYPE)); //$NON-NLS-1$ //$NON-NLS-2$\n\t\t\n\t\t\n\t\tenv.renameCU(root.append(\"p1\"), \"X.java\", \"X.txt\"); //$NON-NLS-1$ //$NON-NLS-2$ //$NON-NLS-3$\n\t\tincrementalBuild(projectPath);\n\t\texpectingNoProblems();\n\t}",
"public static Class<?> lenientClassForName(String className) throws ClassNotFoundException {\n try {\n return loadClass(className);\n } catch (ClassNotFoundException ignored) {\n // try replacing the last dot with a $, in case that helps\n // example: tutorial.Tutorial.Benchmark1 becomes tutorial.Tutorial$Benchmark1\n // amusingly, the $ character means three different things in this one line alone\n String newName = className.replaceFirst(\"\\\\.([^.]+)$\", \"\\\\$$1\");\n return loadClass(newName);\n }\n }",
"@Override\n\tpublic void rename(String newName) {\n\t\tint lastDot = newName.lastIndexOf('.');\n\t\tif (lastDot == -1) {\n\t\t\tclsInfo.changeShortName(newName);\n\t\t\treturn;\n\t\t}\n\t\tif (isInner()) {\n\t\t\taddWarn(\"Can't change package for inner class: \" + this + \" to \" + newName);\n\t\t\treturn;\n\t\t}\n\t\t// change class package\n\t\tString newPkg = newName.substring(0, lastDot);\n\t\tString newShortName = newName.substring(lastDot + 1);\n\t\tif (changeClassNodePackage(newPkg)) {\n\t\t\tclsInfo.changePkgAndName(newPkg, newShortName);\n\t\t} else {\n\t\t\tclsInfo.changeShortName(newShortName);\n\t\t}\n\t}",
"public static final String toInternalClass( String className ) {\n if ( className.endsWith( \".class\" ) ) {\n className = className.substring( 0, className.length() - 6 );\n }\n return className.replace( '.', '/' );\n }",
"public void setClassName(String name) {\n\t\tlines.append(\".class public l2j/generated/\");\n\t\tlines.append(name);\n\t\tclassName = \"l2j/generated/\" + name;\n\t\tlines.append(\"\\n\");\n\n\t\t// stupid check\n\t\tif (dest.indexOf(name) == -1)\n\t\t\tthrow new IllegalStateException(\"Bad class name\");\n\t}",
"public void setClassName(CharSequence className) {\n/* 1441 */ throw new RuntimeException(\"Stub!\");\n/* */ }",
"private String getClassName(String fileName){\n String className = FilenameUtils.getBaseName(fileName);\n return className;\n }",
"private String filePathToClassname(File file) {\n return file.getPath().replace(\".class\", \"\")\n .replace(\"/\", \".\")\n .replace(\"\\\\\", \".\");\n }",
"private static Class<?> tryName(String name) throws ClassNotFoundException {\n return Class.forName(name);\r\n }",
"private static String getClassNameForClassFile(WebFile aFile)\n {\n String filePath = aFile.getPath();\n String filePathNoExtension = filePath.substring(1, filePath.length() - 6);\n String className = filePathNoExtension.replace('/', '.');\n return className;\n }",
"private static String getSimpleClassName(String className) {\n\n\n\t\tString[] names = className.split(\"\\\\.\");\n\n\t\tfor (int i = 0; i < names.length; i++) {\n\t\t\tLog.d(\"\", \"names =\" + names[i]);\n\t\t}\n\n\t\treturn names[names.length - 1];\n\t}",
"abstract String getClassName();",
"private void checkClassName(String className) throws ClassNotFoundException {\n StringTokenizer tokenizer = new StringTokenizer(className, \".\");\n boolean first = true;\n while (tokenizer.hasMoreTokens()) {\n String token = tokenizer.nextToken();\n // Each dot-separated piece must be a valid identifier\n // and the first token can also be \"*\". (Note that\n // numeric class ids are not permitted. They must\n // match a loaded class.)\n if (!Utils.isJavaIdentifier(token) && !(first && token.equals(\"*\"))) {\n throw new ClassNotFoundException();\n }\n first = false;\n }\n }",
"private static String getFQClassName(final String root, final String path) {\r\n\t\t//Remove root from front of path and \".class\" from end of path\r\n\t\tString trimmed = path.substring(path.indexOf(root) + root.length(), path.indexOf(\".class\"));\r\n\t\t\r\n\t\t//Replace backslashes with periods\r\n\t\treturn trimmed.replaceAll(Matcher.quoteReplacement(\"\\\\\"), \".\");\r\n\t}",
"public static String formatNameForClassLoading(String name) {\n if (name == null) {\n return \"java.lang.Object;\";\n }\n\n if (name.equals(\"int\")\n || name.equals(\"long\")\n || name.equals(\"short\")\n || name.equals(\"float\")\n || name.equals(\"double\")\n || name.equals(\"byte\")\n || name.equals(\"char\")\n || name.equals(\"boolean\")\n || name.equals(\"void\")\n ) {\n return name;\n }\n\n if (name.startsWith(\"[\")) {\n return name.replace('/', '.');\n }\n\n if (name.startsWith(\"L\")) {\n name = name.substring(1);\n if (name.endsWith(\";\")) {\n name = name.substring(0, name.length() - 1);\n }\n return name.replace('/', '.');\n }\n\n String prefix = \"\";\n if (name.endsWith(\"[]\")) { // todo need process multi\n prefix = \"[\";\n name = name.substring(0, name.length() - 2);\n if (name.equals(\"int\")) {\n return prefix + \"I\";\n } else if (name.equals(\"long\")) {\n return prefix + \"J\";\n } else if (name.equals(\"short\")) {\n return prefix + \"S\";\n } else if (name.equals(\"float\")) {\n return prefix + \"F\";\n } else if (name.equals(\"double\")) {\n return prefix + \"D\";\n } else if (name.equals(\"byte\")) {\n return prefix + \"B\";\n } else if (name.equals(\"char\")) {\n return prefix + \"C\";\n } else if (name.equals(\"boolean\")) {\n return prefix + \"Z\";\n } else {\n return prefix + \"L\" + name.replace('/', '.') + \";\";\n }\n }\n return name.replace('/', '.');\n\n }",
"public InvalidFileNameException(String pName, String pMessage)\n/* */ {\n/* 49 */ super(pMessage);\n/* 50 */ this.name = pName;\n/* */ }",
"protected String getFullyQualifiedClassName(String classname)\n {\n return classname.contains(\".\") ? classname : \"org.apache.cassandra.hadoop.\" + classname;\n }",
"public ClassNameRenamer(String oldClassName, String newClassName) {\n\t\t\tsuper();\n\t\t\tthis.oldClassName = oldClassName;\n\t\t\tthis.newClassName = newClassName;\n\t\t}",
"private String getClassName( Class c ) {\n\treturn c.getName().substring(c.getName().lastIndexOf('.')+1);\n }",
"private String getClassname() {\r\n\t\tString classname = this.getClass().getName();\r\n\t\tint index = classname.lastIndexOf('.');\r\n\t\tif (index >= 0)\r\n\t\t\tclassname = classname.substring(index + 1);\r\n\t\treturn classname;\r\n\t}",
"public static String convertInternalFormToQualifiedClassName(final String classInternalName) {\n String out = classInternalName.replaceAll(\"/\", \"\\\\.\");\n // Doesn't attempt to deal with inner classes etc yet...\n return out;\n }",
"java.lang.String getClass_();",
"java.lang.String getClass_();",
"@Override\r\n\tprotected void fixInstanceClass(EClassifier eClassifier) {\r\n\t\tif (eClassifier.getInstanceClassName() == null) {\r\n\t\t\teClassifier.setInstanceClassName(\"org.bimserver.models.store.\"\r\n\t\t\t\t\t+ eClassifier.getName());\r\n\t\t\tsetGeneratedClassName(eClassifier);\r\n\t\t}\r\n\t}",
"@Override\n public byte[] getClassBytes(String name) {\n return null;\n }",
"@Override\n public Class<?> loadClassBytes(String name, ClassLoader cl) {\n return dexFile.loadClass(name.replace('.', '/'), cl);\n }",
"protected static String getResourceName(final String classname) {\n return classname.replace('.', '/') + \".class\";\n }",
"@Override\n public JavaClass loadClass(String className) throws ClassNotFoundException {\n if ((className == null) || className.isEmpty()) {\n throw new IllegalArgumentException(\"Invalid class name \" + className);\n }\n className = className.replace('/', '.'); // Just in case, canonical form\n final JavaClass clazz = findClass(className);\n if (clazz != null) {\n return clazz;\n }\n\n IOException e = new IOException(\"Couldn't find: \" + className + \".class\");\n throw new ClassNotFoundException(\"Exception while looking for class \" +\n className + \": \" + e, e);\n }",
"public CharSequence getClassName() {\n/* 1426 */ throw new RuntimeException(\"Stub!\");\n/* */ }",
"public String getBaseName() {\n/* 323 */ throw new RuntimeException(\"Stub!\");\n/* */ }",
"@Override\n\tprotected Class<?> findClass(String name) throws ClassNotFoundException {\n\t\tFile file = new File(getSimpleName(name) + \".class\");\n FileInputStream fis = null;\n Class<?> clazz = null;\n try {\n fis = new FileInputStream(file);\n int content = 0;\n int i = 0;\n byte[] data = new byte[fis.available()];\n while ((content = fis.read()) != -1) {\n // convert to char and display it\n data[i] = (byte) content;\n i++;\n }\n clazz = defineClass(name, data, 0, data.length);\n } catch (IOException e) {\n e.printStackTrace();\n } finally {\n try {\n if (fis != null)\n fis.close();\n } catch (IOException ex) {\n \t\tex.printStackTrace();\n \t}\n }\n return clazz;\n\t}",
"protected String getClassName() {\r\n return newName.getText();\r\n }",
"public static final String getUnqualifiedClassName(ClassFile cf, short cpIndex) {\n ClassInfo ci = (ClassInfo) cf.getCpInfo(cpIndex);\n short nameIndex = ci.nameIndex;\n String className = getUtf8(cf, nameIndex);\n /*if (className != null) {\n int i = className.lastIndexOf('.');\n return i != -1 ? className.substring(i + 1) : className;\n } else {\n return null;\n }*/\n int i;\n return className != null && (i = className.lastIndexOf('/')) >= 0 ? className.substring(i + 1) : className;\n }",
"private static String convertToQualifiedName(final String fileName) {\n final String replacedSeparators = fileName.replace(File.separatorChar, '.');\n return replacedSeparators.substring(0, replacedSeparators.length() - \".class\".length());\n }",
"private NameUtil() {\n }",
"public void testCtorStr() throws Exception {\n ConfigManager.getInstance()\n .add(\"test_files\" + File.separator\n + \"RenameConverter.xml\");\n\n RenameConverter converter = new RenameConverter(DEFAULT_NAMESPACE);\n assertNotNull(\"Unable to create RenameConverter instance.\", converter);\n\n Field fdMaps = converter.getClass().getDeclaredField(\"toRenameNames\");\n fdMaps.setAccessible(true);\n\n Map map = (Map) fdMaps.get(converter);\n assertEquals(\"The UML2:TypedElement.type should be renamed to UML:StructuralFeature.type\",\n \"UML:StructuralFeature.type\", map.get(\"UML2:TypedElement.type\"));\n assertEquals(\"The UML:Class should be renamed to UML:Classifier\",\n \"UML:Classifier\", map.get(\"UML:Class\"));\n assertEquals(\"The UML:DateType should be renamed to UML:Class\",\n \"UML:Classifier\", map.get(\"UML:DateType\"));\n }",
"public void renameClass(String oldName, String newName) \n\t{\n\t\tstoreViewState();\n\t\tproject.renameClass(oldName, newName);\n\t\tcheckStatus();\n\t}",
"@Override\n protected Class \n findClass\n (\n String cname\n ) \n throws ClassNotFoundException\n {\n byte bs[] = pContents.get(cname);\n if(bs == null) \n throw new ClassNotFoundException\n\t(\"Unable to find class (\" + cname + \")!\");\n\n return defineClass(cname, bs, 0, bs.length);\n }",
"@DISPID(-2147417111)\n @PropGet\n java.lang.String className();",
"@Test\n\tpublic void testGuardRenaming() throws Exception {\n\t\ttestRenaming(IGuard.ELEMENT_TYPE);\n\t}",
"private String m56637b(Class cls) {\n return cls.getName();\n }",
"private static String p(Class n) {\n return n.getName().replace('.','/');\n }",
"static public String sanitizeName(String origName) {\n char c[] = origName.toCharArray();\n StringBuffer buffer = new StringBuffer();\n\n // can't lead with a digit, so start with an underscore\n if ((c[0] >= '0') && (c[0] <= '9')) {\n buffer.append('_');\n }\n for (int i = 0; i < c.length; i++) {\n if (((c[i] >= '0') && (c[i] <= '9')) ||\n ((c[i] >= 'a') && (c[i] <= 'z')) ||\n ((c[i] >= 'A') && (c[i] <= 'Z')) ||\n ((i > 0) && (c[i] == '-')) ||\n ((i > 0) && (c[i] == '.'))) {\n buffer.append(c[i]);\n } else {\n buffer.append('_');\n }\n }\n // let's not be ridiculous about the length of filenames.\n // in fact, Mac OS 9 can handle 255 chars, though it can't really\n // deal with filenames longer than 31 chars in the Finder.\n // but limiting to that for sketches would mean setting the\n // upper-bound on the character limit here to 25 characters\n // (to handle the base name + \".class\")\n if (buffer.length() > 63) {\n buffer.setLength(63);\n }\n return buffer.toString();\n }",
"public abstract String getClassName();",
"@Override\n\tprotected void fixInstanceClass(EClassifier eClassifier) {\n\t\tif (eClassifier.getInstanceClassName() == null) {\n\t\t\teClassifier.setInstanceClassName(\"net.certware.measurement.spm.\" + eClassifier.getName()); //$NON-NLS-1$\n\t\t\tsetGeneratedClassName(eClassifier);\n\t\t}\n\t}",
"@Override\n public boolean isRename() {\n return false;\n }",
"private static boolean matchesPackage(Class<?> param2Class, String param2String) {\n/* 654 */ String str = param2Class.getName();\n/* 655 */ return (str.startsWith(param2String) && str.lastIndexOf('.') == param2String.length() - 1);\n/* */ }",
"public void remCamelCaseName(){\n ((MvwDefinitionDMO) core).remCamelCaseName();\n }",
"private void verifyClassName() {\n\t\t\n\t\tif (classNameTF.getText().isEmpty()) {\n\t\t\tJOptionPane.showMessageDialog(this,\"Blank Field: Class Name\",\"Error\",JOptionPane.ERROR_MESSAGE);\n\t\t\treturn;\n\t\t}\n\t\telse {\n\t\t\tClass newClass = new Class(classNameTF.getText());\n\t\t\tteacher.addClass(newClass);\n\t\t\ttAddClassWindow.dispose();\n\t\t\ttPortalWindow.dispose();\n\t\t\tteacherPortalScreen();\n\t\t}\n\t}",
"private ClassUtil() {}",
"public String getClassName(String path);",
"private static String toNormalizedIconNameClass(String string) {\n return Icon.toNormalizedIconNameClass(string);\n }",
"private static boolean matchesPackage(Class<?> param2Class, String param2String) {\n/* 656 */ String str = param2Class.getName();\n/* 657 */ return (str.startsWith(param2String) && str.lastIndexOf('.') == param2String.length() - 1);\n/* */ }",
"private String validateKeyClassName (String keyClassName) \n\t\t\t\tthrows ModelValidationException\n\t\t\t{\n\t\t\t\tString pcClassName = getClassName();\n\t\t\t\tModel model = getModel();\n\t\t\t\tboolean hasKeyClassName = !StringHelper.isEmpty(keyClassName);\n\t\t\t\tboolean hasPrefix;\n\t\t\t\tString nameSuffix;\n\t\t\t\tboolean isOIDNameSuffix;\n\n\t\t\t\t// check for existence of key class name\n\t\t\t\tif (!hasKeyClassName)\n\t\t\t\t{\n\t\t\t\t\tthrow new ModelValidationException(\n\t\t\t\t\t\tModelValidationException.WARNING,\n\t\t\t\t\t\tmodel.getClass(pcClassName),\n\t\t\t\t\t\tI18NHelper.getMessage(getMessages(), \n\t\t\t\t\t\t\"util.validation.key_class_unset\", //NOI18N\n\t\t\t\t\t\tpcClassName));\n\t\t\t\t}\n\n\t\t\t\tkeyClassName = keyClassName.trim();\n\t\t\t\thasPrefix = keyClassName.startsWith(pcClassName);\n\t\t\t\tnameSuffix = (hasPrefix ? \n\t\t\t\t keyClassName.substring(pcClassName.length()) : keyClassName);\n\t\t\t\tisOIDNameSuffix = \n\t\t\t\t\t(nameSuffix.equalsIgnoreCase(\".OID\") || // NOI18N\n\t\t\t\t\t nameSuffix.equalsIgnoreCase(\"$OID\")); // NOI18N\n\n\t\t\t\tif (!hasPrefix || \n\t\t\t\t\t(!nameSuffix.equalsIgnoreCase(\"Key\") && \t// NOI18N\n\t\t\t\t\t !isOIDNameSuffix))\n\t\t\t\t{\n\t\t\t\t\tObject pcClass = getModel().getClass(pcClassName);\n\t\t\t\t\tthrow new ModelValidationException(pcClass,\n\t\t\t\t\t\tI18NHelper.getMessage(getMessages(),\n\t\t\t\t\t\t\"util.validation.key_class_invalid\", //NOI18N\n\t\t\t\t\t\tkeyClassName, pcClassName));\n\t\t\t\t}\n\t\t\t\tif (isOIDNameSuffix)\n\t\t\t\t{\n\t\t\t\t\tStringBuffer buf = new StringBuffer(keyClassName);\n\t\t\t\t\tbuf.setCharAt(keyClassName.length() - 4, '$');\n\t\t\t\t\treturn buf.toString(); \n\t\t\t\t}\n\t\t\t\treturn keyClassName;\n\t\t\t}",
"public static String removeJavaPackageName(String className) {\n int idx = className.lastIndexOf('.');\n if (idx >= 0) {\n return className.substring(idx + 1);\n } else {\n return className;\n }\n }",
"private String trimClassPaths (String s) {\n int idx = 0;\n for (int i = s.length() - 1; i >= 0; i--) {\n if (s.charAt(i) == '.') {\n idx = i;\n break;\n }\n }\n String trimmed = s.substring(idx + 1);\n return trimmed;\n }",
"public static void loadClass(String name) {\n\n }",
"private boolean isInternal(String name) {\n return name.startsWith(\"java.\")\n || name.startsWith(\"javax.\")\n || name.startsWith(\"com.sun.\")\n || name.startsWith(\"javax.\")\n || name.startsWith(\"oracle.\");\n }",
"private String cleanLine(String line) {\n line = line.replace(\"class\", \"class\");\n line = line.replace(\"abstract class\", \"abstract class\");\n line = line.replace(\"enum\", \"enum\");\n return line;\n }",
"private Class m16122a(String str) {\n try {\n return Class.forName(str);\n } catch (ClassNotFoundException unused) {\n return null;\n }\n }",
"@Override\r\n\tpublic boolean renameFile(String oldFileName, String newFileName) throws FileSystemUtilException {\r\n\t\tthrow new FileSystemUtilException(\"000000\",null,Level.ERROR,null);\r\n\r\n\t}",
"protected void rename(String oldname, String newname) throws IOException { //TODO map this to the FileSystem\n\t\tthrow new IOException( \"not implemented\" ); //TODO map this to the FileSystem\n\t}",
"public ClassNotFoundException (String s) {\n\t\tsuper(s, null); // Disallow initCause\n\t}",
"public String prepareClassName(String className)\n {\n return camelCaseName(className, true);\n }",
"public void setClassName(String className) { this.className=className; }",
"public java.lang.String shortName () { throw new RuntimeException(); }",
"public static final String toJavaClass( String className ) {\n if ( className.endsWith( \".class\" ) ) {\n className = className.substring( 0, className.length() - 6 );\n }\n return className.replace( '/', '.' );\n }",
"private static String resolveName(@Nonnull final Class<?> clazz) {\n\t\tfinal String n = clazz.getName();\n\t\tfinal int i = n.lastIndexOf('.');\n\t\treturn i > 0 ? n.substring(i + 1) : n;\n\t}",
"@Test\n public void testClassForName() throws Exception {\n Class<?> mainClass = MainClassForNameSubClass.class;\n runTest(\n mainClass,\n ImmutableList.of(mainClass, SuperClass.class, SubClass.class),\n // Prevent SuperClass from being merged into SubClass.\n keepMainProguardConfiguration(mainClass, ImmutableList.of(\"-keep class **.SuperClass\")),\n this::checkAllClassesPresentWithDefaultConstructor);\n }",
"@java.lang.Deprecated\n public A withNewStorageClassName(java.lang.String original);",
"private static void Demo8() {\n\t\tClass<?> class1 = null;\r\n\t\ttry {\r\n\t\t\tclass1 = Class.forName(\"CH16.SuperMan\");\r\n\t\t\tString nameString = class1.getClassLoader().getClass().getName();\r\n\t\t\tSystem.out.println(\"Demo8: 类加载器类名: \" + nameString);\r\n\t\t} catch (ClassNotFoundException e) {\r\n\t\t\t// TODO Auto-generated catch block\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\r\n\t}",
"public void testTrashInClassDef() throws ParseException {\n SourceFile s = _parseString(\"fdsa public sad static class A {\\n\"+\n \"}\");\n assertEquals(\"Number of classes\",1,s.getClasses().length);\n assertEquals(\"the class name is A\", \"A\", s.getClasses()[0].getName().getText());\n assertEquals(\"the class has 2 modifiers\", 1, s.getClasses()[0].getMav().getModifiers().length);\n }",
"private String jarName(){\n // determine the name of this class\n String className=\"/\"+this.getClass().getName().replace('.','/')+\".class\";\n // find out where the class is on the filesystem\n String classFile=this.getClass().getResource(className).toString();\n\n if( (classFile==null) || !(classFile.startsWith(\"jar:\")) ) return null;\n \n // trim out parts and set this to be forwardslash\n classFile=classFile.substring(5,classFile.indexOf(className));\n classFile=FilenameUtil.setForwardSlash(classFile);\n\n // chop off a little bit more\n classFile=classFile.substring(4,classFile.length()-1);\n \n return FilenameUtil.URLSpacetoSpace(classFile);\n }",
"boolean isProperClass(String str)\n {\n File f = new File(MutationSystem.MUTANT_HOME, str);\n File[] dirs = f.listFiles(new DirFileFilter());\n if ((dirs == null) || (dirs.length == 0)) \n return false;\n \n String[] names = {\"\", \"original\"};\n switch(getMutantType())\n {\n case MutationSystem.TM: names[0] = \"mutants\";\n break;\n case MutationSystem.EM: names[0] = \"exceptional_mutants\";\n break;\n }\n \n for (int i=0; i<names.length; i++)\n {\n boolean found = false;\n for (int j=0; j<dirs.length; j++)\n {\n if (dirs[j].getName().equals(names[i]))\n {\n found = true;\n break;\n }\n }\n if (!found) \n return false;\n }\n return true;\n }",
"public StringFileManager(String name) throws Exception {\r\n\t\tsuper(name);\r\n\t\t// TODO Auto-generated constructor stub\r\n\t}",
"@Override\r\n\t\tpublic void setClassName(String className)\r\n\t\t\t{\n\t\t\t\t\r\n\t\t\t}",
"@DSComment(\"Package priviledge\")\n @DSBan(DSCat.DEFAULT_MODIFIER)\n @DSGenerator(tool_name = \"Doppelganger\", tool_version = \"2.0\", generated_on = \"2013-12-30 12:56:28.372 -0500\", hash_original_method = \"E4C63287FA81E5CD749A3DF00B7871AE\", hash_generated_method = \"A395ADC766F313790DA998F5853068A3\")\n \n void nameChanged(String newName){\n \t//Formerly a native method\n \taddTaint(newName.getTaint());\n }",
"@Override\n\tprotected void fixInstanceClass(EClassifier eClassifier) {\n\t\tif (eClassifier.getInstanceClassName() == null) {\n\t\t\teClassifier.setInstanceClassName(\"COSEM.InterfaceClasses.\" + eClassifier.getName());\n\t\t\tsetGeneratedClassName(eClassifier);\n\t\t}\n\t}",
"private void ensureCorrectJavaFormat(File javaFile) throws FileNotFoundException, IOException\n\t{\n\t\tFile temp = new File(\"action.temp\");\n\t\tPrintWriter printer = new PrintWriter(new BufferedWriter(new FileWriter(temp)));\n\t\tString fileName = javaFile.getName();\n\t\tString directoryName = javaFile.getParentFile().getName();\n\t\ttry(BufferedReader buffyTheFileSlayer = new BufferedReader(new FileReader(javaFile)))\n\t\t{\n\t\t\tboolean foundPackage = false;\n\t\t\tboolean foundClass = false;\n\t\t\tString line;\n\t\t\twhile((line = buffyTheFileSlayer.readLine()) != null)\n\t\t\t{\n\t\t\t\tif(!foundPackage && line.matches(\"package .+\"))\n\t\t\t\t{\n\t\t\t\t\tfoundPackage = true;\n\t\t\t\t\tif(!line.matches(\".*\" + directoryName + \".*\"))\n\t\t\t\t\t{\n\t\t\t\t\t\tline = \"package \" + directoryName + \";\";\n\t\t\t\t\t}\n\t\t\t\t} else if(!foundClass && line.matches(\"public class .+ implements ActionNode\"))\n\t\t\t\t{\n\t\t\t\t\tfoundClass = true;\n\t\t\t\t\tif(!line.matches(\".*\" + fileName + \".*\"))\n\t\t\t\t\t{\n\t\t\t\t\t\tline = \"public class \" + fileName + \" extends ActionNode\";\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tprinter.println(line);\n\t\t\t}\n\t\t\tprinter.close();\n\t\t\tjavaFile.delete();\n\t\t\ttemp.renameTo(javaFile);\n\t\t}\n\t}",
"String getClassName() {\n final StringBuilder builder = new StringBuilder();\n final String shortName = getShortName();\n boolean upperCaseNextChar = true;\n for (final char c : shortName.toCharArray()) {\n if (c == '_' || c == '-') {\n upperCaseNextChar = true;\n continue;\n }\n\n if (upperCaseNextChar) {\n builder.append(Character.toUpperCase(c));\n upperCaseNextChar = false;\n } else {\n builder.append(c);\n }\n }\n builder.append(\"Messages\");\n return builder.toString();\n }",
"public static String convertQualifiedClassNameToInternalForm(final String qualifiedClassName) {\n String out = qualifiedClassName.replaceAll(\"\\\\.\", \"/\");\n // Doesn't attempt to deal with inner classes etc yet...\n return out;\n }",
"private FSUtils() {\n }",
"private Class<?> defineClass(String paramString, URL paramURL) throws IOException {\n/* 364 */ byte[] arrayOfByte = getBytes(paramURL);\n/* 365 */ CodeSource codeSource = new CodeSource(null, (Certificate[])null);\n/* 366 */ if (!paramString.equals(\"sun.reflect.misc.Trampoline\")) {\n/* 367 */ throw new IOException(\"MethodUtil: bad name \" + paramString);\n/* */ }\n/* 369 */ return defineClass(paramString, arrayOfByte, 0, arrayOfByte.length, codeSource);\n/* */ }",
"@Override\n public String resolve(String path)\n {\n\n // strip classname\n path = path.substring(path.lastIndexOf(\"/\") + 1);\n\n return path;\n }",
"public static Name parseJavaName(String text) {\n // Remove the underscore prefixes and suffixes, as they only make sense to avoid conflicts with Java reserved\n // words and they aren't needed in the model:\n while (text.startsWith(\"_\")) {\n text = text.substring(1);\n }\n while (text.endsWith(\"_\")) {\n text = text.substring(0, text.length() - 1);\n }\n\n // Once the name is clean it can be parsed:\n return NameParser.parseUsingCase(text);\n }",
"public void testJavaClassRepository865() throws Exception {\n\t\tJavaClassRepository var2720 = new JavaClassRepository(\n\t\t\t\tnew DirectoryClassPath(new File(\"classes-for-test\")));\n\t\tvar2720.getClass(\"invalidByteCode\");\n\t\tString var2722 = \"java.util.Map.Entry\";\n\t\tvar2720.getClass(var2722);\n\t}",
"public void testJavaClassRepository866() throws Exception {\n\t\tClassPath var2724 = new ClassPathFactory().createFromPaths(var2725,\n\t\t\t\t\"core/\" + var2725);\n\t\tJavaClassRepository var2726 = new JavaClassRepository(var2724);\n\t\tString var2727 = \"com.google.test.metric.JavaClassRepositoryTest.MyClass.MyInnerClass\";\n\t\tvar2726.getClass(var2727);\n\t\tvar2726.getClass(var2727);\n\t}",
"public ClassFile getClassFile(String name) throws IOException {\n if (name.indexOf('.') > 0) {\n int i = name.lastIndexOf('.');\n String pathname = name.replace('.', File.separatorChar) + \".class\";\n if (baseFileName.equals(pathname) ||\n baseFileName.equals(pathname.substring(0, i) + \"$\" +\n pathname.substring(i+1, pathname.length()))) {\n return readClassFile(path);\n }\n } else {\n if (baseFileName.equals(name.replace('/', File.separatorChar) + \".class\")) {\n return readClassFile(path);\n }\n }\n return null;\n }",
"private ShifuFileUtils() {\n }",
"public void createClass(String className)\r\n\t{\r\n\t\tString longName;\r\n\t\tif(className.contains(\"#\"))\r\n\t\t\tlongName = className;\r\n\t\tif(className.contains(\":\"))\r\n\t\t\tlongName= ONT_MODEL.expandPrefix(className);\r\n\t\telse\r\n\t\t\tlongName = BASE_NS + className;\r\n\t\t\r\n\t\tONT_MODEL.createClass(longName);\r\n\t}",
"@DISPID(-2147417111)\n @PropPut\n void className(\n java.lang.String rhs);",
"protected Class<?> findClass(String paramString) throws ClassNotFoundException {\n/* 343 */ if (!paramString.startsWith(\"sun.reflect.misc.\")) {\n/* 344 */ throw new ClassNotFoundException(paramString);\n/* */ }\n/* 346 */ String str = paramString.replace('.', '/').concat(\".class\");\n/* 347 */ URL uRL = getResource(str);\n/* 348 */ if (uRL != null) {\n/* */ try {\n/* 350 */ return defineClass(paramString, uRL);\n/* 351 */ } catch (IOException iOException) {\n/* 352 */ throw new ClassNotFoundException(paramString, iOException);\n/* */ } \n/* */ }\n/* 355 */ throw new ClassNotFoundException(paramString);\n/* */ }",
"private String getFileName(String eingabe) {\n\t\tString[] words = eingabe.split(\" \");\n\t\tfor (int i = 0; i < words.length; i++) {\n\t\t\tif (words[i].equals(\"public\") && i <= words.length) {\n\t\t\t\tif (words[i+1].equals(\"class\") && i+1 <= words.length) {\n\t\t\t\t\treturn words[i+2];\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn null;\n\t}",
"public void test08() throws RefactoringException {\r\n RenameFieldRefactoring rfr = new RenameFieldRefactoring();\r\n rfr.setClass(\"field\", \"RenameFieldTest\");\r\n rfr.setField(\"childObject\");\r\n rfr.setNewName(\"myChild\");\r\n\r\n rfr.run();\r\n\r\n // Check things out\r\n File check = new File(this.check + \"\\\\ut2\\\\step16\");\r\n\r\n FileCompare.assertEquals(\"RenameFieldTest is incorrect\",\r\n new File(check, \"RenameFieldTest.java\"),\r\n new File(dest, \"RenameFieldTest.java\"));\r\n FileCompare.assertEquals(\"UsesFieldTest is incorrect\",\r\n new File(check, \"UsesFieldTest.java\"),\r\n new File(dest, \"UsesFieldTest.java\"));\r\n FileCompare.assertEquals(\"InheritFieldTest is incorrect\",\r\n new File(check, \"InheritFieldTest.java\"),\r\n new File(dest, \"InheritFieldTest.java\"));\r\n }",
"public final Class<?> mo7499a(String str) throws ClassNotFoundException {\n Class<?> cls = Class.forName(str);\n Intrinsics.checkReturnedValueIsNotNull((Object) cls, \"Class.forName(className)\");\n return cls;\n }",
"protected abstract String getDriverClassName();",
"private SourcecodePackage() {}"
]
| [
"0.69580334",
"0.65591484",
"0.6465869",
"0.63529456",
"0.6234606",
"0.61833435",
"0.6003512",
"0.5995756",
"0.59085345",
"0.58766615",
"0.585853",
"0.5846555",
"0.58362347",
"0.5803154",
"0.57615",
"0.57524157",
"0.5737394",
"0.57080626",
"0.5704123",
"0.5700173",
"0.56549406",
"0.56542474",
"0.5626838",
"0.56238484",
"0.5618405",
"0.5614514",
"0.5614514",
"0.5597886",
"0.55879146",
"0.5585691",
"0.5583362",
"0.55790067",
"0.5568047",
"0.55637616",
"0.55618644",
"0.5552705",
"0.5545041",
"0.55293345",
"0.552558",
"0.5510312",
"0.5493688",
"0.5483542",
"0.54761904",
"0.5473658",
"0.5471343",
"0.5469062",
"0.54519105",
"0.54476506",
"0.54387504",
"0.5434583",
"0.5433691",
"0.5429635",
"0.542733",
"0.5426016",
"0.54142535",
"0.5405754",
"0.5403363",
"0.5403129",
"0.5400466",
"0.53882325",
"0.53855616",
"0.53804237",
"0.5378609",
"0.53771895",
"0.5374612",
"0.5352719",
"0.53522146",
"0.53384966",
"0.5337428",
"0.53358084",
"0.53280026",
"0.53260666",
"0.5313031",
"0.5307807",
"0.5296184",
"0.52911705",
"0.52851325",
"0.52839077",
"0.5277124",
"0.5270592",
"0.5269496",
"0.5254227",
"0.5254058",
"0.5250523",
"0.5249571",
"0.52288693",
"0.5227016",
"0.52254236",
"0.5217635",
"0.52116525",
"0.5199927",
"0.5191931",
"0.51872134",
"0.51835316",
"0.51833665",
"0.5182665",
"0.5181198",
"0.51809037",
"0.5179625",
"0.5178823",
"0.5177401"
]
| 0.0 | -1 |
Scale the View based on current slide offset | @Override
public void onDrawerSlide(View drawerView, float slideOffset) {
final float diffScaledOffset = slideOffset * (1 - END_SCALE);
final float offsetScale = 1 - diffScaledOffset;
contentView.setScaleX(offsetScale);
contentView.setScaleY(offsetScale);
// Translate the View, accounting for the scaled width
final float xOffset = drawerView.getWidth() * slideOffset;
final float xOffsetDiff = contentView.getWidth() * diffScaledOffset / 2;
final float xTranslation = xOffset - xOffsetDiff;
contentView.setTranslationX(xTranslation);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\n public void onDrawerSlide(View drawerView, float slideOffset) {\n final float diffScaledOffset = slideOffset * (1 - 0.7f);\n final float offsetScale = 1 - diffScaledOffset;\n binding.contentView.setScaleX(offsetScale);\n// contentView.setScaleY(offsetScale);\n\n // Translate the View, accounting for the scaled width\n final float xOffset = drawerView.getWidth() * slideOffset;\n final float xOffsetDiff = binding.contentView.getWidth() * diffScaledOffset / 2;\n final float xTranslation = xOffset - xOffsetDiff;\n binding.contentView.setTranslationX(xTranslation);\n }",
"@Override\n public void onDrawerSlide(View drawerView, float slideOffset) {\n final float diffScaledOffset = slideOffset * (1 - END_SCALE);\n final float offsetScale = 1 - diffScaledOffset;\n contentView.setScaleX(offsetScale);\n contentView.setScaleY(offsetScale);\n\n //Translate the View,accounting for the scaled width\n final float xOffset = drawerView.getWidth() * slideOffset;\n final float xOffsetDiff = contentView.getWidth() * diffScaledOffset / 2;\n final float xTranslation = xOffset - xOffsetDiff;\n contentView.setTranslationX(xTranslation);\n\n }",
"private void scaleImagePanel(float scale){\n float oldZoom = imagePanel.getScale();\n float newZoom = oldZoom+scale;\n Rectangle oldView = scrollPane.getViewport().getViewRect();\n // resize the panel for the new zoom\n imagePanel.setScale(newZoom);\n // calculate the new view position\n Point newViewPos = new Point();\n newViewPos.x = (int)(Math.max(0, (oldView.x + oldView.width / 2) * newZoom / oldZoom - oldView.width / 2));\n newViewPos.y = (int)(Math.max(0, (oldView.y + oldView.height / 2) * newZoom / oldZoom - oldView.height / 2));\n scrollPane.getViewport().setViewPosition(newViewPos);\n }",
"private void updateScale() {\n target.setScaleX(scaleValue);\n target.setScaleY(scaleValue);\n }",
"public void zoomIn() {\n if (scale < 0.8) {\n double scaleFactor = (scale + 0.03) / scale;\n currentXOffset = scaleFactor * (currentXOffset - viewPortWidth / 2) + viewPortWidth / 2;\n currentYOffset = scaleFactor * (currentYOffset - viewPortHeight / 2) + viewPortHeight / 2;\n scale += 0.03;\n\n selectionChanged = true;\n gameChanged = true;\n }\n\n }",
"@Override\n public void transformPage(View view, float position) {\n view.setTranslationX(view.getWidth()* -position);\n //Active the vertical slide\n float yPosition = position * view.getHeight();\n view.setTranslationY(yPosition);\n }",
"private void onScaleClick() {\n PropertyValuesHolder scaleXHolder = PropertyValuesHolder.ofFloat(\"scaleX\", 1.5f);\r\n PropertyValuesHolder scaleYHolder = PropertyValuesHolder.ofFloat(\"scaleY\", 1.5f);\r\n Animator scaleAnimator = ObjectAnimator.ofPropertyValuesHolder(\r\n animatedView, scaleXHolder, scaleYHolder);\r\n scaleAnimator.setDuration(animationDuration);\r\n scaleAnimator.setInterpolator(new AccelerateDecelerateInterpolator());\r\n scaleAnimator.start();\r\n }",
"@Override\n public void onSlide(@NonNull View view, float v)\n {\n }",
"@Override\n\tpublic void handleScale(float scale, int moveYDistance) {\n\t\t scale = 0.6f + 0.4f * scale;\n//\t ViewCompat.setScaleX(mMoocRefreshView, scale);\n//\t ViewCompat.setScaleY(mMoocRefreshView, scale);\n\t}",
"public void scanningThumbScale() {\n stopAnimationHandler();\n scanningBlurValueBar.setProgress(100);\n ScaleAnimation scaleAnimation = new ScaleAnimation(0f, 1f, 0f, 1f, Animation.RELATIVE_TO_SELF, 0.5f, Animation.RELATIVE_TO_SELF, 0.5f);\n scaleAnimation.setFillAfter(false);\n scaleAnimation.setInterpolator(new BounceInterpolator());\n scaleAnimation.setDuration(600);\n scanningThumb.setVisibility(VISIBLE);\n scanningThumb.startAnimation(scaleAnimation);\n }",
"@Override\n\tpublic void anim(float pos) {\n\t\tif (isReadyAnim(pos)) {\n\t\t\tfloat value = interpolator(pos);\n\t\t\tview.setScaleX(value);\n\t\t\tview.setScaleY(value);\n\t\t}\n\t}",
"protected void updateScales() {\n hscale = 1f;\n vscale = 1f;\n viewData.setHscale(hscale);\n viewData.setVscale(vscale);\n }",
"public void updateScale()\n {\n // get scale from world presenter\n s2 = (cam.getScale());\n //Convert to English Miles if appropriate\n if( !SettingsScreen.getUnits() ) s2 *= 0.60934;\n s1 = s2/2;\n repaint();\n }",
"private void setScale() {\n this.particleScale = (1 - ((float) slowTime / 50)) * (1.5f * (float) offset);\n }",
"public void zoomOut() {\n if (scale > 0.05) {\n double scaleFactor = (scale - 0.03) / scale;\n currentXOffset = scaleFactor * (currentXOffset - viewPortWidth / 2) + viewPortWidth / 2;\n currentYOffset = scaleFactor * (currentYOffset - viewPortHeight / 2) + viewPortHeight / 2;\n scale -= 0.03;\n\n selectionChanged = true;\n gameChanged = true;\n }\n }",
"protected void slideTo(int offset) {\n\t\tsd.quickSlide(offset);\n\t}",
"private void setScaleToBoardViewPanes(double scale) {\n boardController.getDrawedBoard().setScaleX(scale);\n boardController.getDrawedBoard().setScaleY(scale);\n boardController.getCanvas().setScaleX(scale);\n boardController.getCanvas().setScaleY(scale);\n boardController.getDartBoard().setScaleX(scale);\n boardController.getDartBoard().setScaleY(scale);\n boardController.getPointsAreaPane().setScaleX(scale);\n boardController.getPointsAreaPane().setScaleY(scale);\n }",
"private void updateSlide() {\n\t\tfloat slideHideX = mSlideLeft.getSlideHideX();\n\t\tfloat paddingLeftAndRight = mSlideRight.getPaddingLeft() + mSlideRight.getPaddingRight();\n\n\t\tif (mSlide < 0) {\n\t\t\tmSlideRight.setRevealPercent(-mSlide);\n\t\t\tmSlideRight.setTranslationX(0);\n\t\t\tmSlideLeft.setRevealPercent(0);\n\t\t\tmSlideLeft.setTranslationX(slideHideX + mSlideRight.getSlideRevealX() - paddingLeftAndRight);\n\t\t}\n\t\telse if (mSlide == 0) {\n\t\t\tmSlideRight.setRevealPercent(0);\n\t\t\tmSlideRight.setTranslationX(0);\n\t\t\tmSlideLeft.setRevealPercent(0);\n\t\t\tmSlideLeft.setTranslationX(slideHideX - paddingLeftAndRight);\n\t\t}\n\t\telse {\n\t\t\tmSlideLeft.setRevealPercent(mSlide);\n\t\t\tmSlideLeft.setTranslationX((1 - mSlide) * slideHideX - (1 - mSlide) * paddingLeftAndRight);\n\t\t\tmSlideRight.setRevealPercent(0);\n\t\t\tmSlideRight.setTranslationX(-mSlideLeft.getSlideRevealX());\n\t\t}\n\t}",
"void onScaleChange(float scaleFactor, float focusX, float focusY);",
"private void fixView(final float newX, final float newY) {\n final float x = this.worldView.getX();\n final float y = this.worldView.getY();\n final float scale = this.worldView.getScale();\n final int width = this.worldView.getMasterImage().getWidth();\n final int height = this.worldView.getMasterImage().getHeight();\n\n float updatedX = Math.max(0, newX);\n float updatedY = Math.max(0, newY);\n\n\n if (width * scale + x > width) {\n updatedX = width - (width * scale);\n }\n if (height * scale + y > height) {\n updatedY = height - (height * scale);\n }\n\n this.worldView.setX(updatedX);\n this.worldView.setY(updatedY);\n\n }",
"public void zoomIn() {\n if (currentViewableRange.getLength() > 1) {\n zoomToLength(currentViewableRange.getLength() / 2);\n }\n }",
"public void panView() {\n double xDistance = currentXOffset - targetXOffset;\n double yDistance = currentYOffset - targetYOffset;\n\n xDistance *= -0.5;\n yDistance *= -0.5;\n\n boolean clearX = Math.abs(xDistance) < 2;\n if (clearX) {\n currentXOffset = targetXOffset;\n } else {\n currentXOffset += xDistance;\n }\n\n boolean clearY = Math.abs(xDistance) < 2;\n if (clearY) {\n currentYOffset = targetYOffset;\n } else {\n currentYOffset += yDistance;\n }\n\n doPan = !clearX || !clearY;\n\n gameChanged = true;\n\n }",
"public void rescale()\r\n\t{\n\t}",
"@Override\n public void onClick(View view) {\n try {\n ScaleView oldView = layout.findViewById(R.id.scale_view_id);\n layout.removeView(oldView);\n } catch (Exception e) {\n Log.w(\"YOYOYO\", \"Exception: \" + e.getMessage());\n }\n\n scalePreview = new ScaleView(c, scales.get(magnificationValue.getSelectedItemPosition()));\n scalePreview.setId(R.id.scale_view_id);\n scalePreview.setZOrderOnTop(true);\n\n layout.addView(scalePreview);\n }",
"public interface SlidePainter {\n\tabstract public Rectangle draw(SlideItem item, Rectangle location);\n\t\n\tpublic float getScale();\n\t\n\t/**\n\t * Apply the scale on a given number\n\t * \n\t * @return int The scaled number\n\t */\n\tpublic int scale(int original);\n}",
"public void onResizeUniformUpperLeft(FPointType fptPos, float xOffsetScale, float yOffsetScale) {\n float xNewSizeOffset = fptPos.x - fptStart.x;\n float yNewSizeOffset = fptPos.y - fptStart.y;\n \n if (fRectBound.getWidth() != 0.0){\n xScale = 1.0f + xOffsetScale + (xNewSizeOffset / (float)fRectBound.getWidth());\n yScale = xScale;\n } else if (fRectBound.getHeight() != 0.0) {\n yScale = 1.0f + yOffsetScale + (yNewSizeOffset / (float)fRectBound.getHeight());\n xScale = yScale;\n }\n \n resize(xScale, yScale);\n }",
"public void onResizeUniform(FPointType fptPos, float xOffsetScale, float yOffsetScale) {\n float xNewSizeOffset = fptPos.x - fptStart.x;\n float yNewSizeOffset = fptPos.y - fptStart.y;\n \n if (fRectBound.getWidth() != 0.0){\n float radiusWidth = (float)fRectBound.getWidth() / 2.0f;\n xScale = 1.0f + xOffsetScale + (xNewSizeOffset / radiusWidth);\n yScale = xScale;\n } else if (fRectBound.getHeight() != 0.0) {\n float radiusHeight = (float)fRectBound.getHeight() / 2.0f;\n yScale = 1.0f + yOffsetScale + (yNewSizeOffset / radiusHeight);\n xScale = yScale;\n }\n \n resize(xScale, yScale);\n }",
"@Override public void update(float dt)\n\t{\n\t\tthis.setScale((this.getScale().getX() + 0.1f) * 0.99f, (this.getScale().getY() + 0.1f) * 0.99f);\n\n\n\t}",
"@Override\n public void onPanelSlide(View panel, float slideOffset) {\n }",
"public void go_to_scale_position() {\n stop_hold_arm();\n Dispatcher.get_instance().add_job(new JMoveArm(RobotMap.Arm.pot_value_scale, 0.9, 0.7, 0.7, 0.2, 0.8, false, false));\n hold_arm();\n }",
"void rootViewSizeChange()\n {\n int rootW = (int) Math.ceil(_rootView.getWidth());\n int rootH = (int) Math.ceil(_rootView.getHeight());\n _canvas.setWidth(rootW*_scale); _canvas.setHeight(rootH*_scale);\n }",
"public void flingInsideZoomView(float velocityX, float velocityY) {\n if (inZoomView()) {\n final ViewItem current = FilmstripView.this.mViewItem[2];\n if (current != null) {\n float translationX = current.getTranslationX() * FilmstripView.this.mScale;\n float translationY = current.getTranslationY() * FilmstripView.this.mScale;\n final ValueAnimator decelerationX = ValueAnimator.ofFloat(new float[]{translationX, ((((float) (0.05000000074505806d * Math.pow((double) Math.max(Math.abs(velocityX), Math.abs(velocityY)), 0.3333333432674408d))) / 4.0f) * velocityX) + translationX});\n final ValueAnimator decelerationY = ValueAnimator.ofFloat(new float[]{translationY, ((duration / 4.0f) * velocityY) + translationY});\n decelerationY.addUpdateListener(new AnimatorUpdateListener() {\n public void onAnimationUpdate(ValueAnimator animation) {\n float transX = ((Float) decelerationX.getAnimatedValue()).floatValue();\n float transY = ((Float) decelerationY.getAnimatedValue()).floatValue();\n current.updateTransform(transX, transY, FilmstripView.this.mScale, FilmstripView.this.mScale, FilmstripView.this.mDrawArea.width(), FilmstripView.this.mDrawArea.height());\n }\n });\n this.mFlingAnimator = new AnimatorSet();\n this.mFlingAnimator.play(decelerationX).with(decelerationY);\n this.mFlingAnimator.setDuration((long) ((int) (1000.0f * duration)));\n this.mFlingAnimator.setInterpolator(new TimeInterpolator() {\n public float getInterpolation(float input) {\n return (float) (1.0d - Math.pow((double) (1.0f - input), 4.0d));\n }\n });\n this.mFlingAnimator.addListener(new AnimatorListener() {\n private boolean mCancelled = false;\n\n public void onAnimationStart(Animator animation) {\n }\n\n public void onAnimationEnd(Animator animation) {\n if (!this.mCancelled) {\n MyController.this.loadZoomedImage();\n }\n MyController.this.mFlingAnimator = null;\n }\n\n public void onAnimationCancel(Animator animation) {\n this.mCancelled = true;\n }\n\n public void onAnimationRepeat(Animator animation) {\n }\n });\n this.mFlingAnimator.start();\n }\n }\n }",
"private void rescale() {\n this.affineTransform = AffineTransform.getScaleInstance(this.zoom,\n this.zoom);\n int width = (int) ((this.board.getWidth() * 32) * this.zoom);\n int height = (int) ((this.board.getHeight() * 32) * this.zoom);\n this.setPreferredSize(new Dimension(width, height));\n this.repaint();\n }",
"public void zoomScaleIn() {\n \t\tzoomScale(SCALE_DELTA_IN);\n \t}",
"public void handle(ActionEvent ae) {\n scaleFactor += 0.1; \n if(scaleFactor > 2.0) scaleFactor = 0.4; \n \n scale.setX(scaleFactor); \n scale.setY(scaleFactor); \n \n }",
"@Override\r\n\tpublic boolean onTouch(View v, MotionEvent event) {\n\t\tLog.i(\"lyc\", \"touched---------------\");\r\n\t\tswitch (event.getAction() & MotionEvent.ACTION_MASK) {\r\n\t\tcase MotionEvent.ACTION_POINTER_DOWN:\r\n\t\t\tbeforeLenght = spacing(event);\r\n\t\t\tif (beforeLenght > 5f) {\r\n\t\t\t\tisScale = true;\r\n\t\t\t}\r\n\t\t\tbreak;\r\n\t\tcase MotionEvent.ACTION_MOVE:\r\n\t\t\t/* 处理拖动 */\r\n\t\t\t// if (isScale) {\r\n\t\t\t// afterLenght = spacing(event);\r\n\t\t\t// if (afterLenght < 5f)\r\n\t\t\t// break;\r\n\t\t\t// float gapLenght = afterLenght - beforeLenght;\r\n\t\t\t// if (gapLenght == 0) {\r\n\t\t\t// break;\r\n\t\t\t// } else if (Math.abs(gapLenght) > 5f) {\r\n\t\t\t// float scaleRate = gapLenght / 854;\r\n\t\t\t// Animation myAnimation_Scale = new ScaleAnimation(\r\n\t\t\t// currentScale, currentScale + scaleRate,\r\n\t\t\t// currentScale, currentScale + scaleRate,\r\n\t\t\t// Animation.RELATIVE_TO_SELF, 0.5f,\r\n\t\t\t// Animation.RELATIVE_TO_SELF, 0.5f);\r\n\t\t\t// myAnimation_Scale.setDuration(100);\r\n\t\t\t// myAnimation_Scale.setFillAfter(true);\r\n\t\t\t// myAnimation_Scale.setFillEnabled(true);\r\n\t\t\t// currentScale = currentScale + scaleRate;\r\n\t\t\t// gallery.getSelectedView().setLayoutParams(\r\n\t\t\t// new Gallery.LayoutParams(\r\n\t\t\t// (int) (480 * (currentScale)),\r\n\t\t\t// (int) (854 * (currentScale))));\r\n\t\t\t// beforeLenght = afterLenght;\r\n\t\t\t// }\r\n\t\t\t// return true;\r\n\t\t\t// }\r\n\t\t\tbreak;\r\n\t\tcase MotionEvent.ACTION_POINTER_UP:\r\n\t\t\tisScale = false;\r\n\t\t\tbreak;\r\n\t\t}\r\n\r\n\t\treturn false;\r\n\t}",
"private void dragZoom() {\n\n\t\tint width = this.getWidth();\n\n\t\tint start = cont.getStart();\n\t\tdouble amount = cont.getLength();\n\n\t\tint newStart = (int) DrawingTools.calculatePixelPosition(x ,width,amount,start);\n\t\tint newStop = (int) DrawingTools.calculatePixelPosition(x2,width,amount,start);\n\t\tx = x2 = 0;\n\n\t\tint temp;\n\t\tif (newStop < newStart){\n\t\t\ttemp = newStart;\n\t\t\tnewStart = newStop;\n\t\t\tnewStop = temp;\n\t\t}\n\n\t\tcont.changeSize(newStart,newStop);\n\n\t}",
"@Override\n public void onClick(View v) {\n\n\n float x = ivImage.getScaleX();\n float y = ivImage.getScaleY();\n\n ivImage.setScaleX((float) (x - 1));\n ivImage.setScaleY((float) (y - 1));\n }",
"private void previewXY() {\n Viewport tempViewport = new Viewport(chart.getMaximumViewport());\n // Make temp viewport smaller.\n float dx = tempViewport.width() / 4;\n float dy = tempViewport.height() / 4;\n tempViewport.inset(dx, dy);\n previewChart.setCurrentViewportWithAnimation(tempViewport);\n }",
"public void setTrackScale(float scale7div, float offset, int line0){\n scale.yScale = scale7div;\n scale.yOffset = offset;\n scale.y0Line = line0;\n }",
"public void scale(Point P, int scaleFactor) {\n\n\n }",
"@NonNull\n private Size applyPreviewScale(@NonNull Size referenceSize, @NonNull PointF referencePoint) {\n Size previewStreamSize = this.previewStreamSize;\n referencePoint.x *= (float) previewStreamSize.getWidth() / referenceSize.getWidth();\n referencePoint.y *= (float) previewStreamSize.getHeight() / referenceSize.getHeight();\n return previewStreamSize;\n }",
"@Override\n public void onSlideChanged() {\n }",
"@Override\n\tprotected void setupAnimation(View view) {\n\t\tgetAnimatorSet().playTogether(\n\t\t\t\tObjectAnimator.ofFloat(view, \"scaleX\", 0.0f, 0.8f, 1.0f).setDuration(mDuration),\n\t\t\t\tObjectAnimator.ofFloat(view, \"scaleY\", 0.0f, 0.4f, 1.0f).setDuration(mDuration),\n\t\t\t\tObjectAnimator.ofFloat(view, \"alpha\", 0.0f, 1.0f).setDuration(mDuration),\n\t\t\t\tObjectAnimator.ofFloat(view, \"ratation\", 180.0f, 90.0f, 0.0f).setDuration(mDuration*3/2)\n\t\t\t\t);\n\t}",
"private void zoomImageFromThumb(final View thumbView, int imageResId) {\n if (mCurrentAnimator != null) {\n mCurrentAnimator.cancel();\n }\n\n // Load the high-resolution \"zoomed-in\" image.\n final ImageView expandedImageView = (ImageView) findViewById(\n R.id.expanded_image);\n expandedImageView.setImageResource(imageResId);\n\n // Calculate the starting and ending bounds for the zoomed-in image.\n // This step involves lots of math. Yay, math.\n final Rect startBounds = new Rect();\n final Rect finalBounds = new Rect();\n final Point globalOffset = new Point();\n\n // The start bounds are the global visible rectangle of the thumbnail,\n // and the final bounds are the global visible rectangle of the container\n // view. Also set the container view's offset as the origin for the\n // bounds, since that's the origin for the positioning animation\n // properties (X, Y).\n thumbView.getGlobalVisibleRect(startBounds);\n findViewById(R.id.cxw)\n .getGlobalVisibleRect(finalBounds, globalOffset);\n startBounds.offset(-globalOffset.x, -globalOffset.y);\n finalBounds.offset(-globalOffset.x, -globalOffset.y);\n\n // Adjust the start bounds to be the same aspect ratio as the final\n // bounds using the \"center crop\" technique. This prevents undesirable\n // stretching during the animation. Also calculate the start scaling\n // factor (the end scaling factor is always 1.0).\n float startScale;\n if ((float) finalBounds.width() / finalBounds.height()\n > (float) startBounds.width() / startBounds.height()) {\n // Extend start bounds horizontally\n startScale = (float) startBounds.height() / finalBounds.height();\n float startWidth = startScale * finalBounds.width();\n float deltaWidth = (startWidth - startBounds.width()) / 2;\n startBounds.left -= deltaWidth;\n startBounds.right += deltaWidth;\n } else {\n // Extend start bounds vertically\n startScale = (float) startBounds.width() / finalBounds.width();\n float startHeight = startScale * finalBounds.height();\n float deltaHeight = (startHeight - startBounds.height()) / 2;\n startBounds.top -= deltaHeight;\n startBounds.bottom += deltaHeight;\n }\n\n // Hide the thumbnail and show the zoomed-in view. When the animation\n // begins, it will position the zoomed-in view in the place of the\n // thumbnail.\n thumbView.setAlpha(0f);\n expandedImageView.setVisibility(View.VISIBLE);\n\n // Set the pivot point for SCALE_X and SCALE_Y transformations\n // to the top-left corner of the zoomed-in view (the default\n // is the center of the view).\n expandedImageView.setPivotX(0f);\n expandedImageView.setPivotY(0f);\n\n // Construct and run the parallel animation of the four translation and\n // scale properties (X, Y, SCALE_X, and SCALE_Y).\n AnimatorSet set = new AnimatorSet();\n set\n .play(ObjectAnimator.ofFloat(expandedImageView, View.X,\n startBounds.left, finalBounds.left))\n .with(ObjectAnimator.ofFloat(expandedImageView, View.Y,\n startBounds.top, finalBounds.top))\n .with(ObjectAnimator.ofFloat(expandedImageView, View.SCALE_X,\n startScale, 1f)).with(ObjectAnimator.ofFloat(expandedImageView,\n View.SCALE_Y, startScale, 1f));\n set.setDuration(mShortAnimationDuration);\n set.setInterpolator(new DecelerateInterpolator());\n set.addListener(new AnimatorListenerAdapter() {\n @Override\n public void onAnimationEnd(Animator animation) {\n mCurrentAnimator = null;\n }\n\n @Override\n public void onAnimationCancel(Animator animation) {\n mCurrentAnimator = null;\n }\n });\n set.start();\n mCurrentAnimator = set;\n\n // Upon clicking the zoomed-in image, it should zoom back down\n // to the original bounds and show the thumbnail instead of\n // the expanded image.\n final float startScaleFinal = startScale;\n expandedImageView.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n if (mCurrentAnimator != null) {\n mCurrentAnimator.cancel();\n }\n\n // Animate the four positioning/sizing properties in parallel,\n // back to their original values.\n AnimatorSet set = new AnimatorSet();\n set.play(ObjectAnimator\n .ofFloat(expandedImageView, View.X, startBounds.left))\n .with(ObjectAnimator\n .ofFloat(expandedImageView,\n View.Y,startBounds.top))\n .with(ObjectAnimator\n .ofFloat(expandedImageView,\n View.SCALE_X, startScaleFinal))\n .with(ObjectAnimator\n .ofFloat(expandedImageView,\n View.SCALE_Y, startScaleFinal));\n set.setDuration(mShortAnimationDuration);\n set.setInterpolator(new DecelerateInterpolator());\n set.addListener(new AnimatorListenerAdapter() {\n @Override\n public void onAnimationEnd(Animator animation) {\n thumbView.setAlpha(1f);\n expandedImageView.setVisibility(View.GONE);\n mCurrentAnimator = null;\n }\n\n @Override\n public void onAnimationCancel(Animator animation) {\n thumbView.setAlpha(1f);\n expandedImageView.setVisibility(View.GONE);\n mCurrentAnimator = null;\n }\n });\n set.start();\n mCurrentAnimator = set;\n }\n });\n }",
"public abstract void onPull(float scaleOfLayout);",
"public void setProperty(View view, float f2) {\n view.setScaleX(f2);\n }",
"@Override\n public void onClick(View v) {\n\n float x = ivImage.getScaleX();\n float y = ivImage.getScaleY();\n\n ivImage.setScaleX((float) (x + 1));\n ivImage.setScaleY((float) (y + 1));\n }",
"@Override\n public boolean onScale(ScaleGestureDetector scaleGestureDetector) {\n zoom *= scaleGestureDetector.getScaleFactor();\n recalculateView();\n return true;\n }",
"@Override\n public void onAnimationEnd(Animator animation) {\n ViewGroup.LayoutParams lp = LifeLabActivity.this.anim_view.getLayoutParams();\n lp.width = view.getWidth();\n lp.height = view.getHeight();\n LifeLabActivity.this.anim_view.setLayoutParams(lp);\n LifeLabActivity.this.anim_view.setX(view.getX());\n LifeLabActivity.this.anim_view.setY(view.getY());\n LifeLabActivity.this.anim_view.setVisibility(View.VISIBLE);\n LifeLabActivity.this.anim_view.post(new Runnable() {\n @Override\n public void run() {\n AnimatorSet as = new AnimatorSet();\n ValueAnimator x = ObjectAnimator.ofFloat(LifeLabActivity.this.anim_view, \"x\", LifeLabActivity.this.anim_view.getX(), 0);\n ValueAnimator y = ObjectAnimator.ofFloat(LifeLabActivity.this.anim_view, \"y\", LifeLabActivity.this.anim_view.getY(), 0);\n float x0 = LifeLabActivity.this.anim_view.getScaleX();\n float y0 = LifeLabActivity.this.anim_view.getScaleY();\n float sx = (float) Utils.getScreenWidthPx(LifeLabActivity.this) / (float) LifeLabActivity.this.anim_view.getWidth();\n ValueAnimator scalex = ObjectAnimator.ofFloat(LifeLabActivity.this.anim_view, \"scaleX\", x0, x0 * sx * 2);\n //Log.d(TAG, String.format(\"run X: %f, %f\", x0, x0 * sx));\n float sy = (float) Utils.getScreenHeightPx(LifeLabActivity.this) / (float) LifeLabActivity.this.anim_view.getHeight();\n //Log.d(TAG, String.format(\"screenH: %d, viewH:%d\", Utils.getScreenHeightPx(LifeLabActivity.this), LifeLabActivity.this.anim_view.getHeight()));\n //Log.d(TAG, String.format(\"y0: %f, sy: %f, y1: %f\", y0, sy, y0 * sy));\n ValueAnimator scaley = ObjectAnimator.ofFloat(LifeLabActivity.this.anim_view, \"scaleY\", y0, y0 * sy * 6);\n //Log.d(TAG, String.format(\"run Y: %f, %f\", x0, y0 * sy));\n as.play(x).with(scalex).with(y).with(scaley);\n //as.play(x).with(y);\n as.setDuration(300);\n as.addListener(new Animator.AnimatorListener() {\n @Override\n public void onAnimationStart(Animator animation) {\n\n }\n\n @Override\n public void onAnimationEnd(Animator animation) {\n View x = LifeLabActivity.this.anim_view;\n //Log.d(TAG, String.format(\"onAnimationEnd: %f %f %d %d\", x.getX(), x.getY(), x.getWidth(), x.getHeight()));\n Intent intent = new Intent(LifeLabActivity.this, LifeLabItemActivity.class);\n intent.putExtra(LifeLabItemActivity.LIFELAB_COLLECTION, lc);\n LifeLabActivity.this.startActivityForResult(intent, 0);\n }\n\n @Override\n public void onAnimationCancel(Animator animation) {\n\n }\n\n @Override\n public void onAnimationRepeat(Animator animation) {\n\n }\n });\n as.start();\n\n }\n });\n }",
"public void beginScaling() {\n xScale = 1.0f;\n yScale = 1.0f;\n }",
"public void onResizeAnyDirectionUpperLeft(FPointType fptPos, float xOffsetScale, float yOffsetScale) {\n float xNewSizeOffset = fptPos.x - fptStart.x;\n float yNewSizeOffset = fptPos.y - fptStart.y;\n \n \n if (fRectBound.getWidth() == 0.0)\n xScale = 1.0f;\n else {\n xScale = 1.0f + xOffsetScale + (xNewSizeOffset / (float)fRectBound.getWidth());\n }\n \n if (fRectBound.getHeight() == 0.0)\n yScale = 1.0f;\n else {\n yScale = 1.0f + yOffsetScale + (yNewSizeOffset / (float)fRectBound.getHeight());\n }\n \n resize(xScale, yScale);\n }",
"@Override\n public void onDrawerSlide(View drawerView, float slideOffset) {\n float moveFactor = (drawerView.getWidth() * slideOffset) * -1;\n if (Build.VERSION.SDK_INT >= Build.VERSION_CODES.HONEYCOMB)\n {\n frame.setTranslationX(moveFactor);\n }\n else\n {\n TranslateAnimation anim = new TranslateAnimation(lastTranslate, moveFactor, 0.0f, 0.0f);\n anim.setDuration(0);\n anim.setFillAfter(true);\n frame.startAnimation(anim);\n\n lastTranslate = moveFactor;\n }\n }",
"public void onResizeAnyDirection(FPointType fptPos, float xOffsetScale, float yOffsetScale) {\n float xNewSizeOffset = fptPos.x - fptStart.x;\n float yNewSizeOffset = fptPos.y - fptStart.y;\n \n \n if (fRectBound.getWidth() == 0.0)\n xScale = 1.0f;\n else {\n float radiusWidth = (float)fRectBound.getWidth() / 2.0f;\n xScale = 1.0f + xOffsetScale + (xNewSizeOffset / radiusWidth);\n }\n \n if (fRectBound.getHeight() == 0.0)\n yScale = 1.0f;\n else {\n float radiusHeight = (float)fRectBound.getHeight() / 2.0f;\n yScale = 1.0f + yOffsetScale + (yNewSizeOffset / radiusHeight);\n }\n \n resize(xScale, yScale);\n }",
"void transformPage(View page, float position);",
"private void zoomImageFromThumb(final View thumbView, Bitmap imageRes) {\n if (mCurrentAnimator != null) {\n mCurrentAnimator.cancel();\n }\n\n // Load the high-resolution \"zoomed-in\" image.\n final ImageView expandedImageView = (ImageView) getView().findViewById(\n R.id.expanded_image);\n expandedImageView.setImageBitmap(imageRes);\n\n // Calculate the starting and ending bounds for the zoomed-in image.\n // This step involves lots of math. Yay, math.\n final Rect startBounds = new Rect();\n final Rect finalBounds = new Rect();\n final Point globalOffset = new Point();\n\n // The start bounds are the global visible rectangle of the thumbnail,\n // and the final bounds are the global visible rectangle of the container\n // view. Also set the container view's offset as the origin for the\n // bounds, since that's the origin for the positioning animation\n // properties (X, Y).\n thumbView.getGlobalVisibleRect(startBounds);\n getView().findViewById(R.id.containerLin)\n .getGlobalVisibleRect(finalBounds, globalOffset);\n startBounds.offset(-globalOffset.x, -globalOffset.y);\n finalBounds.offset(-globalOffset.x, -globalOffset.y);\n\n // Adjust the start bounds to be the same aspect ratio as the final\n // bounds using the \"center crop\" technique. This prevents undesirable\n // stretching during the animation. Also calculate the start scaling\n // factor (the end scaling factor is always 1.0).\n float startScale;\n if ((float) finalBounds.width() / finalBounds.height()\n > (float) startBounds.width() / startBounds.height()) {\n // Extend start bounds horizontally\n startScale = (float) startBounds.height() / finalBounds.height();\n float startWidth = startScale * finalBounds.width();\n float deltaWidth = (startWidth - startBounds.width()) / 2;\n startBounds.left -= deltaWidth;\n startBounds.right += deltaWidth;\n } else {\n // Extend start bounds vertically\n startScale = (float) startBounds.width() / finalBounds.width();\n float startHeight = startScale * finalBounds.height();\n float deltaHeight = (startHeight - startBounds.height()) / 2;\n startBounds.top -= deltaHeight;\n startBounds.bottom += deltaHeight;\n }\n\n // Hide the thumbnail and show the zoomed-in view. When the animation\n // begins, it will position the zoomed-in view in the place of the\n // thumbnail.\n thumbView.setAlpha(0f);\n expandedImageView.setVisibility(View.VISIBLE);\n\n // Set the pivot point for SCALE_X and SCALE_Y transformations\n // to the top-left corner of the zoomed-in view (the default\n // is the center of the view).\n expandedImageView.setPivotX(0f);\n expandedImageView.setPivotY(0f);\n\n // Construct and run the parallel animation of the four translation and\n // scale properties (X, Y, SCALE_X, and SCALE_Y).\n AnimatorSet set = new AnimatorSet();\n set\n .play(ObjectAnimator.ofFloat(expandedImageView, View.X,\n startBounds.left, finalBounds.left))\n .with(ObjectAnimator.ofFloat(expandedImageView, View.Y,\n startBounds.top, finalBounds.top))\n .with(ObjectAnimator.ofFloat(expandedImageView, View.SCALE_X,\n startScale, 1f))\n .with(ObjectAnimator.ofFloat(expandedImageView,\n View.SCALE_Y, startScale, 1f));\n set.setDuration(mShortAnimationDuration);\n set.setInterpolator(new DecelerateInterpolator());\n set.addListener(new AnimatorListenerAdapter() {\n @Override\n public void onAnimationEnd(Animator animation) {\n mCurrentAnimator = null;\n }\n\n @Override\n public void onAnimationCancel(Animator animation) {\n mCurrentAnimator = null;\n }\n });\n set.start();\n mCurrentAnimator = set;\n\n // Upon clicking the zoomed-in image, it should zoom back down\n // to the original bounds and show the thumbnail instead of\n // the expanded image.\n final float startScaleFinal = startScale;\n expandedImageView.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n if (mCurrentAnimator != null) {\n mCurrentAnimator.cancel();\n }\n\n // Animate the four positioning/sizing properties in parallel,\n // back to their original values.\n AnimatorSet set = new AnimatorSet();\n set.play(ObjectAnimator\n .ofFloat(expandedImageView, View.X, startBounds.left))\n .with(ObjectAnimator\n .ofFloat(expandedImageView,\n View.Y,startBounds.top))\n .with(ObjectAnimator\n .ofFloat(expandedImageView,\n View.SCALE_X, startScaleFinal))\n .with(ObjectAnimator\n .ofFloat(expandedImageView,\n View.SCALE_Y, startScaleFinal));\n set.setDuration(mShortAnimationDuration);\n set.setInterpolator(new DecelerateInterpolator());\n set.addListener(new AnimatorListenerAdapter() {\n @Override\n public void onAnimationEnd(Animator animation) {\n thumbView.setAlpha(1f);\n expandedImageView.setVisibility(View.GONE);\n mCurrentAnimator = null;\n }\n\n @Override\n public void onAnimationCancel(Animator animation) {\n thumbView.setAlpha(1f);\n expandedImageView.setVisibility(View.GONE);\n mCurrentAnimator = null;\n }\n });\n set.start();\n mCurrentAnimator = set;\n }\n });\n }",
"public void setScaleX(double aValue)\n{\n if(aValue==getScaleX()) return;\n repaint();\n firePropertyChange(\"ScaleX\", getRSS().scaleX, getRSS().scaleX = aValue, -1);\n}",
"PlayerPrince(ImageView view) {\n this.view = view;\n this.size = view.getHeight();\n }",
"public void setScaleY(double aValue)\n{\n if(aValue==getScaleY()) return;\n repaint();\n firePropertyChange(\"ScaleY\", getRSS().scaleY, getRSS().scaleY = aValue, -1);\n}",
"public void setScaleX(double d) {\n\t\tpointTransform.translate(pivotPoint.getX(),pivotPoint.getY());\n\t\tpointTransform.scale(1.0/this.scaleX, 1.0);\n\t\tthis.scaleX = d;\n\t\tpointTransform.scale(d, 1.0);\n\t\tpointTransform.translate(-pivotPoint.getX(),-pivotPoint.getY());\n\t}",
"private void applyZoomRatio(float ratio) {\n\t\tzoom = zoom * ratio;\n\t}",
"@Override\n\tpublic void mouseDragged(MouseEvent e) {\n\t\tif(scale != 1.0) {\n\t\t\tPoint2D.Double view = new Point2D.Double(e.getX(), e.getY());\n\t\t\tPoint2D.Double worldPoint = new Point2D.Double();\n\t\t\tAffineTransform viewToWorld = new AffineTransform(1.0 / scale, 0, 0, 1.0 / scale, worldUpperLeft.getX(), worldUpperLeft.getY());\n\t\t\tviewToWorld.transform(view, worldPoint);\n\t\t\t\n\t\t\twX = worldPoint.getX();\n\t\t\twY = worldPoint.getY();\n\t\n\t\t\tdouble diffX = wDragStartX - wX;\n\t\t\tdouble diffY = wDragStartY - wY;\n\t\t\tdouble wulX = worldUpperLeft.getX();\n\t\t\tdouble wulY = worldUpperLeft.getY();\n\t\t\tdouble newUpX = diffX + wulX;\n\t\t\tdouble newUpY = diffY + wulY;\n\t\t\t\n\t\t\tif(newUpX < 0)\n\t\t\t\tnewUpX = 0;\n\t\t\tif(newUpY < 0)\n\t\t\t\tnewUpY = 0;\n\t\t\tif(scale == 2.0 && newUpX > 512)\n\t\t\t\tnewUpX = 512;\n\t\t\tif(scale == 2.0 && newUpY > 512)\n\t\t\t\tnewUpY = 512;\n\t\t\tif(scale == 4.0 && newUpX > 768)\n\t\t\t\tnewUpX = 768;\n\t\t\tif(scale == 4.0 && newUpY > 768)\n\t\t\t\tnewUpY = 768;\n\t\t\t\n\t\t\tworldUpperLeft = new Point2D.Double(newUpX, newUpY);\n\t\t\t\n\t\t\tif(worldUpperLeft.getX() + scrollbarSize > MAXSCROLLBARSIZE) \n\t\t\t\tGUIFunctions.setHScrollBarPosit(MAXSCROLLBARSIZE - scrollbarSize);\n\t\t\telse \n\t\t\t\tGUIFunctions.setHScrollBarPosit((int) worldUpperLeft.getX());\n\t\t\t\n\t\t\tif(worldUpperLeft.getY() + scrollbarSize > MAXSCROLLBARSIZE) \n\t\t\t\tGUIFunctions.setVScrollBarPosit(MAXSCROLLBARSIZE - scrollbarSize);\n\t\t\telse \n\t\t\t\tGUIFunctions.setVScrollBarPosit((int) worldUpperLeft.getY());\n\t\t\tGUIFunctions.refresh();\n\t\t}\n\t}",
"private void moveViewToScreenCenter( View view )\n\t{\n\t DisplayMetrics dm = new DisplayMetrics();\n\t this.getWindowManager().getDefaultDisplay().getMetrics( dm );\n\t \n\t int originalPos[] = new int[2];\n\t view.getLocationOnScreen( originalPos );\n\t int xDest = dm.widthPixels/2 - dm.widthPixels/4;\n\t TranslateAnimation anim = new TranslateAnimation(dm.widthPixels,xDest , 0, 0 );\n\t anim.setDuration(16000);\n\t anim.setFillAfter( true );\n\t view.startAnimation(anim);\n\t}",
"public void calculatePanScale(float distanceX, float distanceY, float newScaleFactor){\n //Log.d(LOG_TAG, \"input = \" + distanceX + \":\" + distanceY + \":\" + newScaleFactor);\n int width = getWidth();\n int height = getHeight();\n //Log.d(LOG_TAG, \"view size = \" + width + \" x \" + height);\n\n scaleFactor *= newScaleFactor;\n // Don't let the object get too small or too large.\n scaleFactor = Math.max(minScale, Math.min(scaleFactor, maxScale));\n //Log.d(LOG_TAG, \"calculatePanScale: scale factor = \" + scaleFactor);\n\n scaledRightBound = rightBound * scaleFactor;\n scaledBottomBound = bottomBound * scaleFactor;\n //Log.d(LOG_TAG, \"calculatePanScale: scaledBounds \" + scaledRightBound + \":\" + scaledBottomBound);\n\n float maxPanX = -(scaledRightBound- width);\n float maxPanY = -(scaledBottomBound- height);\n //Log.d(LOG_TAG, \"calculatePanScale: maxPan \" + maxPanX + \":\" + maxPanY);\n\n panX = Math.min(0, Math.max(maxPanX,(panX - distanceX)));\n panY = Math.min(0, Math.max(maxPanY,(panY - distanceY)));\n //Log.d(LOG_TAG, \"calculatePanScale: Pan \" + panX + \":\" + panY);\n\n mainMatrix.setScale(scaleFactor, scaleFactor);\n mainMatrix.postTranslate(panX, panY);\n columnHeaderMatrix.setScale(scaleFactor, scaleFactor);\n columnHeaderMatrix.postTranslate(panX, 0);\n rowHeaderMatrix.setScale(scaleFactor, scaleFactor);\n rowHeaderMatrix.postTranslate(0, panY);\n cornerMatrix.setScale(scaleFactor, scaleFactor);\n\n invalidate();\n }",
"protected void zoomToScale(float scale) {\n \t\tif (tweening) {\n \t\t\tscaleIntegrator.target(scale);\n \t\t} else {\n \t\t\tmapDisplay.sc = scale;\n \t\t\t// Also update Integrator to support correct tweening after switch\n \t\t\tscaleIntegrator.target(scale);\n \t\t\tscaleIntegrator.set(scale);\n \t\t}\n \t}",
"public void scaleAffine(){\n //Get the monitors size.\n Dimension screenSize = Toolkit.getDefaultToolkit().getScreenSize();\n transform = new AffineTransform();\n double width = screenSize.getWidth();\n double height = screenSize.getHeight();\n\n //Set up the scale amount for our Affinetransform\n double xscale = width / model.getBbox().getWidth();\n double yscale = height / model.getBbox().getHeight();\n\n double scale = max(xscale, yscale);\n\n adjustZoomLvl(scale);\n transform.translate(-model.getBbox().getMinX(), -model.getBbox().getMaxY());\n\n bounds = new CanvasBounds(getBounds(), transform);\n adjustZoomFactor();\n }",
"protected abstract void onScalePercentChange(int zoom);",
"public void displayScaled(float scaleFactor) {\n pushMatrix();\n scale(scaleFactor);\n shape(fullCar);\n popMatrix();\n }",
"private void updateViewBounds() \r\n {\r\n assert !sim.getMap().isEmpty() : \"Visualiser needs simulator whose a map has at least one node\"; \r\n \r\n \r\n viewMinX = minX * zoomFactor;\r\n viewMinY = minY * zoomFactor;\r\n \r\n viewMaxX = maxX * zoomFactor;\r\n viewMaxY = maxY * zoomFactor;\r\n \r\n \r\n double marginLength = zoomFactor * maxCommRange;\r\n \r\n \r\n // Set the size of the component\r\n int prefWidth = (int)Math.ceil( (viewMaxX - viewMinX) + (marginLength * 2) );\r\n int prefHeight = (int)Math.ceil( (viewMaxY - viewMinY) + (marginLength * 2) );\r\n setPreferredSize( new Dimension( prefWidth, prefHeight ) );\r\n \r\n \r\n // Adjust for margin lengths \r\n viewMinX -= marginLength;\r\n viewMinY -= marginLength;\r\n \r\n viewMaxX += marginLength;\r\n viewMaxY += marginLength;\r\n }",
"private Float scale(Float datapoint){\n\n float range = (float)(20 * (max / Math.log(max)));\n range-=min;\n float scalar = DisplayImage.IMAGE_SIZE_SCALAR / range;\n\n if(nightMode){\n datapoint = (float) (100 * (datapoint / Math.log(datapoint)));\n datapoint *= scalar*5;\n }else {\n datapoint = (float) (20* (datapoint / Math.log(datapoint)));\n datapoint *= scalar;\n }\n\n return datapoint;\n }",
"public void zoom(final double factor) {\n\t\tdouble oldScale = scene.getScalingFactor();\n\t\tdouble newScale = oldScale * (1 + factor);\n\t\tscene.setScalingFactor(newScale);\n\t\tif (orientation == Orientation.VERTICAL) {\n\t\t\tdouble before = -offset.getY() / oldScale + getSize().getHeight() / 2 / oldScale;\n\t\t\tdouble after = -offset.getY() / newScale + getSize().getHeight() / 2 / newScale;\n\t\t\toffset.translate(0, (int) Math.round((after - before) * newScale));\n\t\t} else {\n\t\t\tdouble before = -offset.getX() / oldScale + getSize().getWidth() / 2 / oldScale;\n\t\t\tdouble after = -offset.getX() / newScale + getSize().getWidth() / 2 / newScale;\n\t\t\toffset.translate((int) Math.round((after - before) * newScale), 0);\n\t\t}\n\t\trepaint();\n\t}",
"public void setScale(float scale);",
"@Override\n public void onScale(float ratio){\n isReady = true;\n mRatio = ratio;\n }",
"public void resetTransform() {\n this.mView.setScaleX(1.0f);\n this.mView.setScaleY(1.0f);\n this.mView.setTranslationX(0.0f);\n this.mView.setTranslationY(0.0f);\n }",
"public void updateZoom() {\n camera.zoom = zoomLevel;\n }",
"public void zoomIn() {\n if (zoom > 0) {\n zoom--;\n spielPanel.setZoom(zoom);\n }\n }",
"Controls () {\n \n barX = 40;\n barWidth = 15;\n \n minY = 40;\n maxY = minY + height/3 - sliderHeight/2;\n \n minZoomValue = height - height;\n maxZoomValue = height; // 300 percent\n valuePerY = (maxZoomValue - minZoomValue) / (maxY - minY);\n \n sliderWidth = 25;\n sliderHeight = 10;\n sliderX = (barX + (barWidth/2)) - (sliderWidth/2); \n sliderValue = minZoomValue; \n sliderY = minY; \n }",
"private float getNewScale() {\n int width = getWidth() - (padding[0] + padding[2]);\n float scaleWidth = (float) width / (cropRect.right - cropRect.left);\n\n int height = getHeight() - (padding[1] + padding[3]);\n float scaleHeight = (float) height / (cropRect.bottom - cropRect.top);\n if (getHeight() > getWidth()) {\n return scaleWidth < scaleHeight ? scaleWidth : scaleHeight;\n }\n return scaleWidth < scaleHeight ? scaleWidth : scaleHeight;\n }",
"void scaleArea(float scaleFactor) {\n\t\t// for more advanced (more than 4 points), use this algorithm:\n\t\t// http://stackoverflow.com/questions/1109536/an-algorithm-for-inflating-deflating-offsetting-buffering-polygons\n\t\tfor (int i = 0; i < amount; i++) {\n\t\t\tPVector tmp = PVector.sub(point[i].position, anchor);\n\t\t\ttmp.mult(scaleFactor);\n\t\t\tpoint[i].position.set(PVector.add(anchor, tmp));\n\t\t}\n\t}",
"private void onScroll(double wheelDelta, Point2D mousePoint) {\n double zoomFactor = Math.exp(wheelDelta * zoomIntensity);\n\n Bounds innerBounds = zoomNode.getLayoutBounds();\n Bounds viewportBounds = getViewportBounds();\n\n // calculate pixel offsets from [0, 1] range\n double valX = this.getHvalue() * (innerBounds.getWidth() - viewportBounds.getWidth());\n double valY = this.getVvalue() * (innerBounds.getHeight() - viewportBounds.getHeight());\n scaleValue = scaleValue * zoomFactor;\n \n // calculate minimum zoom\n if(Math.max(target.getLayoutBounds().getWidth()*scaleValue, target.getLayoutBounds().getHeight()*scaleValue) < minViewPortSize) {\n\n \tscaleValue = minViewPortSize / Math.max(target.getLayoutBounds().getWidth(), target.getLayoutBounds().getHeight());\n updateScale();\n this.layout();\n \n } else if(scaleValue > zoom_max) {\n \tscaleValue = zoom_max;\n \tupdateScale();\n this.layout();\n }else {\n \tupdateScale();\n this.layout();\n\n // convert target coordinates to zoomTarget coordinates\n Point2D posInZoomTarget = target.parentToLocal(zoomNode.parentToLocal(mousePoint));\n\n // calculate adjustment of scroll position\n Point2D adjustment = target.getLocalToParentTransform().deltaTransform(posInZoomTarget.multiply(zoomFactor - 1));\n\n // convert back to [0, 1] range\n Bounds updatedInnerBounds = zoomNode.getBoundsInLocal();\n this.setHvalue((valX + adjustment.getX()) / (updatedInnerBounds.getWidth() - viewportBounds.getWidth()));\n this.setVvalue((valY + adjustment.getY()) / (updatedInnerBounds.getHeight() - viewportBounds.getHeight()));\n }\n }",
"@Override\r\n\t\t\tpublic void handle(ScrollEvent e) {\n\t\t\t\tif (e.isControlDown() && getSkinnable().isScalableOnScroll()) {\r\n\t\t\t\t\tdouble delta = e.getDeltaY();\r\n\t\t\t\t\tdouble newValue = localScaleFactor.get();\r\n\t\t\t\t\tif (delta > 0) { // Increasing the zoom.\r\n\t\t\t\t\t\tnewValue = newValue + ZOOM_DELTA;\r\n\t\t\t\t\t\tif (newValue > ZOOM_MAX) {\r\n\t\t\t\t\t\t\tnewValue = ZOOM_MAX;\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t} else if (delta < 0) { // Decreasing the zoom.\r\n\t\t\t\t\t\tnewValue = newValue - ZOOM_DELTA;\r\n\t\t\t\t\t\tif (newValue < ZOOM_MIN) {\r\n\t\t\t\t\t\t\tnewValue = ZOOM_MIN;\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t}\r\n\t\t\t\t\tlocalScaleFactor.set(newValue);\r\n\t\t\t\t\ttakeSnap(prevX.get(), prevY.get());\r\n\t\t\t\t}\r\n\t\t\t\t// If scrolled with ALT key press\r\n\t\t\t\telse if (e.isAltDown() && getSkinnable().isResizableOnScroll()) {\r\n\t\t\t\t\tfinal double delta = e.getDeltaY();\r\n\t\t\t\t\tif (delta > 0) { // Increasing the size.\r\n\t\t\t\t\t\tlocalRadius.set(localRadius.get() + RADIUS_DELTA);\r\n\t\t\t\t\t\tshiftViewerContent(prevX.get(), prevY.get(), localRadius.get(), localScaleFactor.get());\r\n\t\t\t\t\t} else if (delta < 0) { // Decreasing the size.\r\n\t\t\t\t\t\tif (localRadius.get() > MIN_RADIUS) {\r\n\t\t\t\t\t\t\tlocalRadius.set(localRadius.get() - RADIUS_DELTA);\r\n\t\t\t\t\t\t\tshiftViewerContent(prevX.get(), prevY.get(), localRadius.get(), localScaleFactor.get());\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t}",
"public float getProperty(View view) {\n return view.getScaleX();\n }",
"public PointF modelToView(PointF p){\n\t\tPointF q = new PointF(p.x/zoom,height-p.y/zoom);\n\t\treturn q;\t\t\n\t}",
"public void zoomToAreaOfInterest() {\n Envelope aoe = context.getViewport().getBounds();\n if (aoe.getWidth() == 0) {\n aoe.expandBy(.001, 0);\n }\n\n if (aoe.getHeight() == 0) {\n aoe.expandBy(0, .001);\n }\n Rectangle2D rect = new Rectangle2D.Double(aoe.getMinX(), aoe.getMinY(),\n aoe.getWidth(), aoe.getHeight());\n getCamera().animateViewToCenterBounds(rect, true, 0);\n }",
"private void Scale()\n {\n Song scale = new Song();\n scale.add(new Note(noteA1,WHOLE_NOTE/2));\n scale.add(new Note(noteBB1,WHOLE_NOTE/2));\n scale.add(new Note(noteB1,WHOLE_NOTE/2));\n scale.add(new Note(noteC1,WHOLE_NOTE/2));\n scale.add(new Note(noteCS1,WHOLE_NOTE/2));\n scale.add(new Note(noteD1,WHOLE_NOTE/2));\n scale.add(new Note(noteDS1,WHOLE_NOTE/2));\n scale.add(new Note(noteE1,WHOLE_NOTE/2));\n scale.add(new Note(noteF1,WHOLE_NOTE/2));\n scale.add(new Note(noteFS1,WHOLE_NOTE/2));\n scale.add(new Note(noteG1,WHOLE_NOTE/2));\n scale.add(new Note(noteGS1,WHOLE_NOTE/2));\n\n\n playSong(scale);\n }",
"public void scale(float scale) {\n if (scale != 1.0f) {\n left = (int) (left * scale + 0.5f);\n top = (int) (top * scale + 0.5f);\n right = (int) (right * scale + 0.5f);\n bottom = (int) (bottom * scale + 0.5f);\n }\n }",
"public void zoom() {\n\t\tdisp.zoom();\n\t\texactZoom.setText(disp.getScale() + \"\");\n\t\tresize();\n\t\trepaint();\n\t}",
"public void moveViewTo(int newX, int newY) {\n int scaledWidth = (int) (TileDataRegister.TILE_WIDTH * scale);\n int scaledHeight = (int) (TileDataRegister.TILE_HEIGHT * scale);\n int baseX = (int) (map.getWidth() * TileDataRegister.TILE_WIDTH * scale) / 2;\n\n int x = baseX + (newY - newX) * scaledWidth / 2;\n x -= viewPortWidth * 0.5;\n\n int y = (newY + newX) * scaledHeight / 2;\n y -= viewPortHeight * 0.5;\n\n targetXOffset = -1 * x;\n targetYOffset = -1 * y;\n\n doPan = true;\n\n gameChanged = true;\n }",
"public void gridPaneScaled (GridPaneScaledEvent e);",
"@Override\n\tpublic void setScaleX(final float pScaleX) {\n\t\tsuper.setScaleX(1f); //scale not allowed on Layout Object\n\t}",
"public Action scaleCurrentDuration(float scale) {\n mDuration = (long) (mDuration * scale);\n mStartOffset = (long) (mStartOffset * scale);\n return this;\n }",
"private int adjustInsetForScale(int inset, float dipScale) {\n return (int) Math.ceil(inset / dipScale);\n }",
"private void updateShapeOffset() {\n int offsetX = scroller.getOffsetX();\n int offsetY = scroller.getOffsetY();\n shape.setOffset(offsetX, offsetY);\n }",
"public DoubleVec modelToSmallView(DoubleVec pos) {\n DoubleVec p = pos.sub(delta);\n return smallMiddle.sub(p).mult(smallZoomFactor).add(smallMiddle);\n }",
"@Override\n public void transformCanvas(Canvas canvas, float percentOpen) {\n float scale = (float) (1 - percentOpen * 0.25);\n canvas.scale(scale, scale, 0, canvas.getHeight() / 2);\n }",
"@Override\n public void onDrawerSlide(View drawerView, float slideOffset) {\n super.onDrawerSlide(drawerView, slideOffset);\n //SlideOffset comes in on a scale of 0-1.\n //40% looks roughly about right to swap out\n if (slideOffset > 0.4) {\n getSupportActionBar().setTitle(R.string.drawer_close);\n stopFullscreenIfNeeded();\n } else {\n setTitleForActiveTag();\n }\n }",
"public final void slidePanel() {\n //Gdx.app.log(\"PhasesUISettings\", \"slidePanel executed\");\n if (!toggle) {\n easeIn();\n toggle = true;\n } else {\n easeOut();\n toggle = false;\n }\n }",
"public GUIScaleView(final ControlPanelInterface parent)\n\t{\n\t\tsuper(\"Scale\", \"Modify the scaling\");\n\n\t\tfinal ChangeListener sliderChangeListener = new ChangeListener()\n\t\t{\n\t\t\t@Override\n\t\t\tpublic void stateChanged(final ChangeEvent e)\n\t\t\t{\n\t\t\t\tif (toggleUniformScaling)\n\t\t\t\t{\n\t\t\t\t\tfinal Object source = e.getSource();\n\t\t\t\t\tif (source instanceof JSlider)\n\t\t\t\t\t{\n\t\t\t\t\t\tfinal JSlider inputSlider = (JSlider)source;\n\t\t\t\t\t\tfinal int value = inputSlider.getValue();\n\n\t\t\t\t\t\tfor (final GUIBoundedSlider slider : sliders)\n\t\t\t\t\t\t\tslider.write(value);\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tparent.update();\n\t\t\t}\n\t\t};\n\t\tfor (int i = 0; i < sliders.length; ++i)\n\t\t{\n\t\t\tsliders[i] = new GUIBoundedSlider(TITLES[i], 0, 200, 100, sliderChangeListener);\n\t\t\tsliders[i].setFeedbackDesign(1, \"%.0f%%\");\n\t add(sliders[i]);\n\t\t}\n\n\t\tfinal ActionListener checkboxActionListener = new ActionListener()\n\t\t{\n\t\t\t@Override\n\t\t\tpublic void actionPerformed(final ActionEvent e)\n\t\t\t{\n\t\t\t\ttoggleUniformScaling = checkboxToggleUniformScaling.isSelected();\n\t\t\t}\n\t\t};\n\t\tcheckboxToggleUniformScaling.addActionListener(checkboxActionListener);\n\t\tadd(checkboxToggleUniformScaling);\n\t}",
"@Override\n public void offsetChange (float xOffset, float yOffset, float xOffsetStep, float yOffsetStep, int xPixelOffset, int yPixelOffset) {\n pixelOffset = xPixelOffset;\n }"
]
| [
"0.6752144",
"0.6598713",
"0.63088304",
"0.62811977",
"0.62731797",
"0.62494564",
"0.6026056",
"0.59685695",
"0.5921257",
"0.59014404",
"0.58947563",
"0.5849425",
"0.5844832",
"0.5836234",
"0.5815136",
"0.57818705",
"0.5779044",
"0.5757334",
"0.5744854",
"0.57369804",
"0.5663417",
"0.56505275",
"0.56379884",
"0.5622331",
"0.5596918",
"0.5593576",
"0.55852634",
"0.5567935",
"0.55372643",
"0.55328965",
"0.55316085",
"0.55231726",
"0.5516726",
"0.55033433",
"0.5501396",
"0.5493422",
"0.54687935",
"0.5467141",
"0.54496074",
"0.54487497",
"0.5437915",
"0.5436661",
"0.5430014",
"0.54276264",
"0.5414235",
"0.5412588",
"0.5411383",
"0.54009485",
"0.53851795",
"0.5377294",
"0.53718257",
"0.5370436",
"0.5370152",
"0.5350047",
"0.53493637",
"0.5340981",
"0.5320574",
"0.53181976",
"0.5310889",
"0.53108287",
"0.53090787",
"0.53012824",
"0.52768224",
"0.5266377",
"0.52612066",
"0.525986",
"0.5242898",
"0.5233001",
"0.5231356",
"0.5229275",
"0.5228857",
"0.52270937",
"0.51938003",
"0.5173627",
"0.51625276",
"0.516117",
"0.5159682",
"0.5151358",
"0.5146693",
"0.5142891",
"0.5140596",
"0.5134535",
"0.5127704",
"0.51265526",
"0.5113842",
"0.5112655",
"0.5112464",
"0.51084006",
"0.5108059",
"0.5102194",
"0.5095413",
"0.5093848",
"0.5092511",
"0.50831586",
"0.5078859",
"0.5075904",
"0.507554",
"0.5064966",
"0.5050106"
]
| 0.65143967 | 3 |
NB: this will produce twice as many messages as the consumer can handle w/o scaling | @Bean
IntegrationFlow producer() {
MessageSource<String> messageSource = () -> (run.get() ? MessageBuilder
.withPayload("Greetings @ " + Instant.now().toString() + ".").build() : null);
return IntegrationFlows
.from(messageSource, ps -> ps.poller(pm -> pm.fixedRate(1000L)))
.channel(channels.output()).get();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void AsyncPush(String topic){\n\t\t\t\t \t\n\t \t/**\n\t \t * output a map, delete existed items\n\t \t */\n\t \t//Map<Key, Integer> deduplicatedBuff = mergeDuplicatedItemsAndDelte(buff);\n\t \t\n\t \t//not in, create, delay\n\t \tif(!producerMap.containsKey(topic)){\n\t \t\ttry {\n\t\t\t\t\t\t\tCreateProducer(topic,LogicController.batchMessagesMaxMessagesPerBatch);\n\t\t\t\t\t\t} catch (InterruptedException e) {\n\t\t\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t\t} catch (ExecutionException e) {\n\t\t\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t\t}\t \t\t \n\t \t}\n\t \tlog.info(\"#publish\"+topic+\", \"+buffMap.size());\n\t \tProducer<byte[]> producer = producerMap.get(topic);\n\t \t/**\n\t \t * init set, copy to hash set\n\t \t */\n\t \t//Set<Key> Keys = Sets.newConcurrentHashSet(buffMap.keySet());\n\t \t\n\t \t \n\t \tfor (Key key : buffMap.keySet()){\n\t \t\t \n\t \t\t //if(buffMap.containsKey(key)){\n\t \t\t \n\t \t\t \n\t \t\t if(buffMap.containsKey(key)){\n\t \t\t\t Integer val = buffMap.get(key);\n\t \t\t\t //clear,skip\n\t \t\t\t if(val<=0){buffMap.remove(key);continue;}\n\t \t\t\t //concenate\n\t \t\t\t byte[] out = createKVByte(key,val);\n\t \t\t\t \n\t \t\t\t//get producer\n\t\t\t \t\t\t \n\t\t\t \t\t\t //byte[] tempTable = new byte[](buffMap);\n\t\t producer.sendAsync(out).thenRun(() -> {\n\t\t\t messagesSent.increment();\n\t\t\t bytesSent.add(out.length);\n\t\t\t //update\n\t\t\t TopicMap.replace(topic, TopicMap.get(topic)+out.length);\t\n\t\t\t \n\t\t\t //delete\n\t\t\t rescaleBufferMap(buffMap,key,val);\n\t\t\t \n\t\t\t //CheckNumberPacketsEnoughEndMessageAndSend(topic);\n\t\t\t //buffMap.remove(key);\n\t\t\t //remove from the set\n\t\t\t //ier.remove();\n\t\t\t \t\t \t\t \n\t\t\t }).exceptionally(ex -> {\n\t\t\t log.warn(\"Write error on message\", ex);\n\t\t\t //System.exit(-1);\n\t\t\t return null;\n\t\t\t });\n\t \t\t }\n\t \t\t }\n\t \t\t \n\t \t }",
"private void startConsumeMsg() {\n try {\n ConsumerRecords<byte[], byte[]> records;\n while (true) {\n records = kafkaConsumer.poll(Long.MAX_VALUE);\n for (ConsumerRecord<byte[], byte[]> record : records) {\n processMsg(record);\n kafkaConsumer.commitSync();\n LOG.info(\"Single consumer consume the message {}th\", counter.incrementAndGet());\n }\n\n }\n } catch (Exception ex) {\n LOG.error(\"Consumer get message error {}\", ex);\n } finally {\n LOG.info(\"Shutting down consumer ...\");\n shutdown();\n }\n }",
"@Test\n public void largeMessageVolumeTest_buffered() {\n int batches = 15;\n int batchSize = 5_000;\n List<Long> sendReceiveTimings = new ArrayList<>();\n List<Long> sendTimings = new ArrayList<>();\n for(int i = 0; i< batches; i++) {\n List<String> messages = messages(batchSize, 100);\n long startTime = System.currentTimeMillis();\n for (String message : messages) {\n publisher.publishBuffered(topic, message.getBytes());\n }\n publisher.flushBatchers();\n sendTimings.add(System.currentTimeMillis()-startTime);\n List<NSQMessage> nsqMessages = handler1.drainMessagesOrTimeOut(batchSize);\n sendReceiveTimings.add(System.currentTimeMillis()-startTime);\n\n validateReceivedAllMessages(messages,nsqMessages,true);\n LOGGER.info(\"published batch {} of {}\",i,batches);\n }\n\n double sendAverageMillis = sendTimings.stream().mapToLong(e -> e).average().getAsDouble();\n double throughput = batchSize/sendAverageMillis*1000;\n LOGGER.info(\"Average send time for {} messages: {} millis, {} op/s\", batchSize, sendAverageMillis, throughput);\n\n double totalAverageMillis = sendReceiveTimings.stream().mapToLong(e -> e).average().getAsDouble();\n throughput = batchSize/totalAverageMillis*1000;\n LOGGER.info(\"Average send time for {} messages: {} millis, {} op/s\", batchSize, totalAverageMillis, throughput);\n }",
"@Override\n\tpublic void invoke() {\n\t\t\n\t\tIBuffer b = Buffer.getBuffer();\n\t\tint r = b.getRemainingCapacity();\n\t\t\n\t\t// the buffer is empty - this means that invoke was called after a grid was removed\n\t\t// and we need to fill it up to prevent starvation. Ideally the only way this could\n\t\t// happen is if the buffer size was 1\n\t\tif (r == 0) {\n\t\t\tPublisher.getInstance().send(new ProduceMessage());\n\t\t\treturn;\n\t\t}\n\t\t\n\t\tif (r < b.getCapacity())\n\t\t\tPublisher.getInstance().send(new ProduceMessage());\n\t\t\n\t\tif (r > 0)\n\t\t\tPublisher.getInstance().send(new ConsumeMessage());\n\t\t\n\t}",
"@Scheduled(fixedRate=20000)\n\tpublic void generateMessages()\n\t{\t\t\n\t\tsynchronized (map_)\n\t\t{\n\t\t\tif (!map_.isEmpty())\n\t\t\t{\n\t\t\t\tint index = generateIndex(map_.size());\n\t\t\t\tint messageIdx = generateIndex(1000);\n\t\t\t\tString topic = topics_.get(index);\n\t\t\t\tBroadcaster b = map_.get(topic);\n\t\t\t\tUserDTO dto = dtoMap_.get(topic);\n\t\t\t\tdto.setAvailability(\"\" + messageIdx);\n\t\t\t\tString stringified;\n\t\t\t\ttry\n\t\t\t\t{\n\t\t\t\t\tstringified = mapper_.writeValueAsString(dto);\n\t\t\t\t\tSystem.out.println(\"broadcasting to topic \" + topic + \" message: \" + stringified);\n\t\t\t\t\tb.broadcast(stringified);\n\t\t\t\t} catch (JsonGenerationException e)\n\t\t\t\t{\n\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\te.printStackTrace();\n\t\t\t\t} catch (JsonMappingException e)\n\t\t\t\t{\n\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\te.printStackTrace();\n\t\t\t\t} catch (IOException e)\n\t\t\t\t{\n\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\te.printStackTrace();\n\t\t\t\t}\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\tSystem.out.println(\"publisher map was empty, skipping this time\");\n\t\t\t}\n\t\t}\n\t}",
"public void drain() {\r\n if (getAndIncrement() == 0) {\r\n SimpleQueue<T> simpleQueue = this.queue;\r\n int i = this.consumed;\r\n int i2 = this.bufferSize;\r\n int i3 = i2 - (i2 >> 2);\r\n boolean z = this.sourceMode != 1;\r\n int i4 = 1;\r\n int i5 = i;\r\n SimpleQueue<T> simpleQueue2 = simpleQueue;\r\n int i6 = i5;\r\n while (true) {\r\n if (simpleQueue2 != null) {\r\n long j = LongCompanionObject.MAX_VALUE;\r\n InnerSubscription[] innerSubscriptionArr = (InnerSubscription[]) this.subscribers.get();\r\n boolean z2 = false;\r\n for (InnerSubscription innerSubscription : innerSubscriptionArr) {\r\n long j2 = innerSubscription.get();\r\n if (j2 != Long.MIN_VALUE) {\r\n j = Math.min(j2 - innerSubscription.emitted, j);\r\n z2 = true;\r\n }\r\n }\r\n long j3 = 0;\r\n if (!z2) {\r\n j = 0;\r\n }\r\n while (true) {\r\n if (j == j3) {\r\n break;\r\n }\r\n boolean z3 = this.done;\r\n try {\r\n Object poll = simpleQueue2.poll();\r\n boolean z4 = poll == null;\r\n if (!checkTerminated(z3, z4)) {\r\n if (z4) {\r\n break;\r\n }\r\n int length = innerSubscriptionArr.length;\r\n for (int i7 = 0; i7 < length; i7++) {\r\n InnerSubscription innerSubscription2 = innerSubscriptionArr[i7];\r\n if (!innerSubscription2.isCancelled()) {\r\n innerSubscription2.downstream.onNext(poll);\r\n innerSubscription2.emitted++;\r\n }\r\n }\r\n if (z) {\r\n i6++;\r\n if (i6 == i3) {\r\n ((Subscription) this.upstream.get()).request((long) i3);\r\n i6 = 0;\r\n }\r\n }\r\n j--;\r\n if (innerSubscriptionArr != this.subscribers.get()) {\r\n break;\r\n }\r\n j3 = 0;\r\n } else {\r\n return;\r\n }\r\n } catch (Throwable th) {\r\n Throwable th2 = th;\r\n Exceptions.throwIfFatal(th2);\r\n ((Subscription) this.upstream.get()).cancel();\r\n simpleQueue2.clear();\r\n this.done = true;\r\n signalError(th2);\r\n return;\r\n }\r\n }\r\n if (checkTerminated(this.done, simpleQueue2.isEmpty())) {\r\n return;\r\n }\r\n }\r\n this.consumed = i6;\r\n i4 = addAndGet(-i4);\r\n if (i4 != 0) {\r\n if (simpleQueue2 == null) {\r\n simpleQueue2 = this.queue;\r\n }\r\n } else {\r\n return;\r\n }\r\n }\r\n }\r\n }",
"@Override\n public void run() {\n while (queue.num < 100) {\n try {\n queue.producer();\n } catch (Exception ex) {\n ex.printStackTrace();\n }\n }\n }",
"@Override\n public Flux<Response> statefulChannel(Publisher<Request> messages, ByteBuf metadata) {\n Flux.from(messages).limitRate(8).subscribe(processor::onNext);\n return responseFlux;\n }",
"public interface IProducer {\n\n\n /** sends out the filled in message to kafka */\n public void dispatchMessage(KeyedMessage<byte[], byte[]> msg);\n\n public void shutdown();\n\n public void dispatchMessage(final List<KeyedMessage<byte[], byte[]>> msgBatch );\n\n\n}",
"private void processAndPublishMessage(byte[] body) {\n Map<String, Object> props = Maps.newHashMap();\n props.put(CORRELATION_ID, correlationId);\n MessageContext mc = new MessageContext(body, props);\n try {\n msgOutQueue.put(mc);\n String message = new String(body, \"UTF-8\");\n log.debug(\" [x] Sent '{}'\", message);\n } catch (InterruptedException | UnsupportedEncodingException e) {\n log.error(ExceptionUtils.getFullStackTrace(e));\n }\n manageSender.publish();\n }",
"public synchronized void produce(){\n\t\tif(num==capacity){\n\t\t\ttry {\n\t\t\t\twait();\n\t\t\t} catch (InterruptedException e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\t\n\t\t}\n\t\tnum++;\n\t\tSystem.out.println(\"Produce 1, now we have \"+num+\" products\");\n\t\tnotify();\n\t}",
"private void publishMessage() throws InterruptedException {\n\t\tDatagramPacket[] packets = moveReceivedPacketsToArray();\r\n\t\t// get packet info\r\n\t\tDatagramPacket packet = packets[0];\r\n\t\tbyte[] packetData = packet.getData();\r\n\t\tbyte[] topicNumberInBytes = new byte[4];\r\n\t\tfor (int index = 2; index < 6; index++) {\r\n\t\t\ttopicNumberInBytes[index - 2] = packetData[index];\r\n\t\t}\r\n\t\tByteBuffer wrapped = ByteBuffer.wrap(topicNumberInBytes);\r\n\t\tint topicNumber = wrapped.getInt();\r\n\r\n\t\t// check if the topic exists\r\n\t\tif (topicNumbers.containsKey(topicNumber)) {\r\n\t\t\tString topicName = topicNumbers.get(topicNumber);\r\n\t\t\tif (subscriberMap.containsKey(topicName)) {\r\n\t\t\t\tArrayList<Integer> topicSubscribers = subscriberMap.get(topicName);\r\n\t\t\t\tfor (int index = 0; index < topicSubscribers.size(); index++) {\r\n\t\t\t\t\t// make an array\r\n\t\t\t\t\tDatagramPacket[] packetsToSendToSub = new DatagramPacket[packets.length];\r\n\t\t\t\t\t// change the destination of all the packets\r\n\t\t\t\t\tfor (int i = 0; i < packets.length; i++) {\r\n\t\t\t\t\t\tDatagramPacket tempPacket = packets[i];\r\n\t\t\t\t\t\t/*\r\n\t\t\t\t\t\t * String pubMessage = processMessageFromPacket(tempPacket); byte[]\r\n\t\t\t\t\t\t * messagePacketBytes = createPacketData(Constants.PUBLICATION, message[2],\r\n\t\t\t\t\t\t * topicNumber, pubMessage.getBytes()); byte[] packetContent =\r\n\t\t\t\t\t\t * tempPacket.getData();\r\n\t\t\t\t\t\t */\r\n\t\t\t\t\t\tInetSocketAddress subAddress = new InetSocketAddress(Constants.DEFAULT_DST_NODE,\r\n\t\t\t\t\t\t\t\ttopicSubscribers.get(index));\r\n\t\t\t\t\t\ttempPacket.setSocketAddress(subAddress);\r\n\t\t\t\t\t\tpacketsToSendToSub[i] = tempPacket;\r\n\t\t\t\t\t}\r\n\t\t\t\t\taddItemsToQueue(packetsToSendToSub);\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"@Override\n public void run()\n {\n while (true) {\n if (isReadyToStop && (buffer.poll() == null)) {\n System.out.println(\"Thread stop\");\n producerClient.close();\n return;\n }\n try {\n Message msg = buffer.poll(config.getBufferPollTimeout());\n if (msg == null) {\n // ignore it\n continue;\n }\n System.out.println(\"Sent out: [\" + msg + \"]\");\n if (msg.getTopic().isPresent()) {\n String topic = msg.getTopic().get();\n Optional<Function<String, Integer>> function = funcMapBuffer.get(topic);\n function.ifPresent(stringLongFunction -> {\n int fiberId = stringLongFunction.apply(msg.getKey());\n msg.setFiberId(fiberId);\n producerClient.send(topic, fiberId, msg);\n });\n // else ignore this message\n }\n // else ignore this message\n }\n catch (InterruptedException ignored) {\n // if poll nothing, enter next loop\n }\n }\n }",
"public synchronized MRPublisherResponse sendBatchWithResponse() {\n if (fPending.isEmpty()) {\n pubResponse.setResponseCode(String.valueOf(HttpStatus.SC_BAD_REQUEST));\n pubResponse.setResponseMessage(\"No Messages to send\");\n return pubResponse;\n }\n\n final long nowMs = Clock.now();\n\n host = this.fHostSelector.selectBaseHost();\n\n final String httpUrl = MRConstants.makeUrl(host, fTopic, props.getProperty(DmaapClientConst.PROTOCOL),\n props.getProperty(DmaapClientConst.PARTITION));\n OutputStream os = null;\n try (ByteArrayOutputStream baseStream = new ByteArrayOutputStream()) {\n os = baseStream;\n final String propsContentType = props.getProperty(DmaapClientConst.CONTENT_TYPE);\n if (propsContentType.equalsIgnoreCase(MRFormat.JSON.toString())) {\n JSONArray jsonArray = parseJSON();\n os.write(jsonArray.toString().getBytes());\n } else if (propsContentType.equalsIgnoreCase(CONTENT_TYPE_TEXT)) {\n for (TimestampedMessage m : fPending) {\n os.write(m.fMsg.getBytes());\n os.write('\\n');\n }\n } else if (propsContentType.equalsIgnoreCase(MRFormat.CAMBRIA.toString())\n || (propsContentType.equalsIgnoreCase(MRFormat.CAMBRIA_ZIP.toString()))) {\n if (propsContentType.equalsIgnoreCase(MRFormat.CAMBRIA_ZIP.toString())) {\n os = new GZIPOutputStream(baseStream);\n }\n for (TimestampedMessage m : fPending) {\n os.write((\"\" + m.fPartition.length()).getBytes());\n os.write('.');\n os.write((\"\" + m.fMsg.length()).getBytes());\n os.write('.');\n os.write(m.fPartition.getBytes());\n os.write(m.fMsg.getBytes());\n os.write('\\n');\n }\n os.close();\n } else {\n for (TimestampedMessage m : fPending) {\n os.write(m.fMsg.getBytes());\n\n }\n }\n\n final long startMs = Clock.now();\n if (ProtocolType.DME2.getValue().equalsIgnoreCase(protocolFlag)) {\n\n try {\n configureDME2();\n\n this.wait(5);\n\n if (fPending.peek() != null) {\n logSendMessage(fPending.size(), url + subContextPath, nowMs - fPending.peek().timestamp);\n }\n sender.setPayload(os.toString());\n\n String dmeResponse = sender.sendAndWait(5000L);\n\n pubResponse = createMRPublisherResponse(dmeResponse, pubResponse);\n\n if (Integer.parseInt(pubResponse.getResponseCode()) < 200\n || Integer.parseInt(pubResponse.getResponseCode()) > 299) {\n\n return pubResponse;\n }\n final String logLine = String.valueOf((Clock.now() - startMs)) + dmeResponse.toString();\n getLog().info(logLine);\n fPending.clear();\n\n } catch (DME2Exception x) {\n getLog().warn(x.getMessage(), x);\n pubResponse.setResponseCode(x.getErrorCode());\n pubResponse.setResponseMessage(x.getErrorMessage());\n } catch (URISyntaxException x) {\n\n getLog().warn(x.getMessage(), x);\n pubResponse.setResponseCode(String.valueOf(HttpStatus.SC_BAD_REQUEST));\n pubResponse.setResponseMessage(x.getMessage());\n } catch (InterruptedException e) {\n throw e;\n } catch (Exception x) {\n\n pubResponse.setResponseCode(String.valueOf(HttpStatus.SC_INTERNAL_SERVER_ERROR));\n pubResponse.setResponseMessage(x.getMessage());\n logger.error(\"exception: \", x);\n\n }\n\n return pubResponse;\n }\n\n if (ProtocolType.AUTH_KEY.getValue().equalsIgnoreCase(protocolFlag)) {\n if (fPending.peek() != null) {\n logSendMessage(fPending.size(), httpUrl, nowMs - fPending.peek().timestamp);\n }\n final String result = postAuthwithResponse(httpUrl, baseStream.toByteArray(), contentType, authKey,\n authDate, username, password, protocolFlag);\n // Here we are checking for error response. If HTTP status\n // code is not within the http success response code\n // then we consider this as error and return false\n\n pubResponse = createMRPublisherResponse(result, pubResponse);\n\n if (Integer.parseInt(pubResponse.getResponseCode()) < 200\n || Integer.parseInt(pubResponse.getResponseCode()) > 299) {\n\n return pubResponse;\n }\n\n logTime(startMs, result);\n fPending.clear();\n return pubResponse;\n }\n\n if (ProtocolType.AAF_AUTH.getValue().equalsIgnoreCase(protocolFlag)) {\n if (fPending.peek() != null) {\n logSendMessage(fPending.size(), httpUrl, nowMs - fPending.peek().timestamp);\n }\n final String result = postWithResponse(httpUrl, baseStream.toByteArray(), contentType, username,\n password, protocolFlag);\n\n // Here we are checking for error response. If HTTP status\n // code is not within the http success response code\n // then we consider this as error and return false\n pubResponse = createMRPublisherResponse(result, pubResponse);\n\n if (Integer.parseInt(pubResponse.getResponseCode()) < 200\n || Integer.parseInt(pubResponse.getResponseCode()) > 299) {\n\n return pubResponse;\n }\n\n final String logLine = String.valueOf((Clock.now() - startMs));\n getLog().info(logLine);\n fPending.clear();\n return pubResponse;\n }\n\n if (ProtocolType.HTTPNOAUTH.getValue().equalsIgnoreCase(protocolFlag)) {\n if (fPending.peek() != null) {\n logSendMessage(fPending.size(), httpUrl, nowMs - fPending.peek().timestamp);\n }\n final String result = postNoAuthWithResponse(httpUrl, baseStream.toByteArray(), contentType);\n\n // Here we are checking for error response. If HTTP status\n // code is not within the http success response code\n // then we consider this as error and return false\n pubResponse = createMRPublisherResponse(result, pubResponse);\n\n if (Integer.parseInt(pubResponse.getResponseCode()) < 200\n || Integer.parseInt(pubResponse.getResponseCode()) > 299) {\n\n return pubResponse;\n }\n\n final String logLine = String.valueOf((Clock.now() - startMs));\n getLog().info(logLine);\n fPending.clear();\n return pubResponse;\n }\n } catch (IllegalArgumentException | HttpException x) {\n getLog().warn(x.getMessage(), x);\n pubResponse.setResponseCode(String.valueOf(HttpStatus.SC_BAD_REQUEST));\n pubResponse.setResponseMessage(x.getMessage());\n\n } catch (IOException x) {\n getLog().warn(x.getMessage(), x);\n pubResponse.setResponseCode(String.valueOf(HttpStatus.SC_INTERNAL_SERVER_ERROR));\n pubResponse.setResponseMessage(x.getMessage());\n } catch (InterruptedException e) {\n getLog().warn(\"Interrupted!\", e);\n // Restore interrupted state...\n Thread.currentThread().interrupt();\n } catch (Exception x) {\n getLog().warn(x.getMessage(), x);\n\n pubResponse.setResponseCode(String.valueOf(HttpStatus.SC_INTERNAL_SERVER_ERROR));\n pubResponse.setResponseMessage(x.getMessage());\n\n } finally {\n if (!fPending.isEmpty()) {\n getLog().warn(\"Send failed, \" + fPending.size() + \" message to send.\");\n pubResponse.setPendingMsgs(fPending.size());\n }\n if (os != null) {\n try {\n os.close();\n } catch (Exception x) {\n getLog().warn(x.getMessage(), x);\n pubResponse.setResponseCode(String.valueOf(HttpStatus.SC_INTERNAL_SERVER_ERROR));\n pubResponse.setResponseMessage(\"Error in closing Output Stream\");\n }\n }\n }\n\n return pubResponse;\n }",
"private void run() throws ExecutionException, InterruptedException {\n\n int messages_per_topic = Integer.parseInt(Main.properties.getProperty(\"messages_per_topic\"));\n Producer p = new Producer();\n long startTime = System.nanoTime();\n int delta = Integer.parseInt(Main.properties.getProperty(\"delta\"));\n LOGGER.info(\"publishing...\");\n for(int i=1; i<=messages_per_topic + delta; i++) {\n //LOGGER.info(\"publishing round: {}\", i);\n //publish the data on kafka\n p.send(p.sense());\n }\n long elapsedTime = System.nanoTime() - startTime;\n double seconds = (double)elapsedTime / 1000000000.0;\n LOGGER.info(\"published {} messages to {} topics\", messages_per_topic, properties.getProperty(\"topics_number\"));\n LOGGER.info(\"elapsed time: {}\", seconds);\n\n }",
"void drainFused() {\n int n;\n int n2 = 1;\n Subscriber<T> subscriber = this.actual;\n SimpleQueueWithConsumerIndex<Object> simpleQueueWithConsumerIndex = this.queue;\n do {\n if (this.cancelled) {\n simpleQueueWithConsumerIndex.clear();\n return;\n }\n Throwable throwable = (Throwable)this.error.get();\n if (throwable != null) {\n simpleQueueWithConsumerIndex.clear();\n subscriber.onError(throwable);\n return;\n }\n n = simpleQueueWithConsumerIndex.producerIndex() == this.sourceCount ? 1 : 0;\n if (!simpleQueueWithConsumerIndex.isEmpty()) {\n subscriber.onNext(null);\n }\n if (n != 0) {\n subscriber.onComplete();\n return;\n }\n n2 = n = this.addAndGet(-n2);\n } while (n != 0);\n }",
"@Test\n\tpublic void sendMessage() {\n\n\t\tExecutorService executorService = Executors.newFixedThreadPool(1);\n\t\tCountDownLatch endSignal = new CountDownLatch(100);\n\n\t\tfor (int i = 0; i < 100; i++) {\n\t\t\tfinal int num = i;\n\t\t\t// Runnable run;\n\t\t\texecutorService.execute(() -> {\n\t\t\t\ttry {\n\t\t\t\t\tmessageSender = new MessageSender();\n\t\t\t\t\tmessageSender.sendMessage(\"bitchin' badass\" + num);\n\t\t\t\t\tendSignal.countDown();\n\t\t\t\t} catch (Exception e) {\n\t\t\t\t\tlog.error(\"exception\", e);\n\t\t\t\t}\n\t\t\t});\n\t\t}\n\n\t\ttry {\n\t\t\tendSignal.await();\n\t\t} catch (InterruptedException e) {\n\t\t\te.printStackTrace();\n\t\t} finally {\n\t\t\tmessageSender.closeAll();\n\n\t\t}\n\t\texecutorService.shutdown();\n\n\n\t\tval consumeFlag = messageConsumer.consume(\"trans_logs_record\");\n\n\t\ttry {\n\t\t\tThread.sleep(5000l);\n\t\t} catch (InterruptedException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t\tAssert.assertEquals(true, consumeFlag);\n\n\t}",
"public int fill(MessagePassingQueue.Supplier<E> s, int batchSize)\r\n/* 296: */ {\r\n/* 297: */ long pIndex;\r\n/* 298: */ long mask;\r\n/* 299: */ E[] buffer;\r\n/* 300: */ for (;;)\r\n/* 301: */ {\r\n/* 302:569 */ long producerLimit = lvProducerLimit();\r\n/* 303:570 */ pIndex = lvProducerIndex();\r\n/* 304:572 */ if ((pIndex & 1L) != 1L)\r\n/* 305: */ {\r\n/* 306:581 */ mask = this.producerMask;\r\n/* 307:582 */ buffer = this.producerBuffer;\r\n/* 308: */ \r\n/* 309: */ \r\n/* 310: */ \r\n/* 311:586 */ long batchIndex = Math.min(producerLimit, pIndex + 2 * batchSize);\r\n/* 312:588 */ if ((pIndex >= producerLimit) || (producerLimit < batchIndex))\r\n/* 313: */ {\r\n/* 314:590 */ int result = offerSlowPath(mask, pIndex, producerLimit);\r\n/* 315:591 */ switch (result)\r\n/* 316: */ {\r\n/* 317: */ case 0: \r\n/* 318: */ case 1: \r\n/* 319: */ break;\r\n/* 320: */ case 2: \r\n/* 321:598 */ return 0;\r\n/* 322: */ case 3: \r\n/* 323:600 */ resize(mask, buffer, pIndex, s.get());\r\n/* 324:601 */ return 1;\r\n/* 325: */ }\r\n/* 326: */ }\r\n/* 327:606 */ else if (casProducerIndex(pIndex, batchIndex))\r\n/* 328: */ {\r\n/* 329:608 */ int claimedSlots = (int)((batchIndex - pIndex) / 2L);\r\n/* 330:609 */ break;\r\n/* 331: */ }\r\n/* 332: */ }\r\n/* 333: */ }\r\n/* 334: */ int claimedSlots;\r\n/* 335:613 */ for (int i = 0; i < claimedSlots; i++)\r\n/* 336: */ {\r\n/* 337:615 */ long offset = LinkedArrayQueueUtil.modifiedCalcElementOffset(pIndex + 2 * i, mask);\r\n/* 338:616 */ UnsafeRefArrayAccess.soElement(buffer, offset, s.get());\r\n/* 339: */ }\r\n/* 340:618 */ return claimedSlots;\r\n/* 341: */ }",
"protected void deliverMessages()\n {\n Set<Envelope> envelopes = messengerDao.getEnvelopes();\n\n Map<String, Set<Envelope>> peerEnvelopesMap = Maps.newHashMap();\n int maxTimeToLive = 0;\n //distribute envelops to peers\n for ( Envelope envelope : envelopes )\n {\n if ( envelope.getTimeToLive() > maxTimeToLive )\n {\n maxTimeToLive = envelope.getTimeToLive();\n }\n Set<Envelope> peerEnvelopes = peerEnvelopesMap.get( envelope.getTargetPeerId() );\n if ( peerEnvelopes == null )\n {\n //sort by createDate asc once more\n peerEnvelopes = new TreeSet<>( new Comparator<Envelope>()\n {\n @Override\n public int compare( final Envelope o1, final Envelope o2 )\n {\n return o1.getCreateDate().compareTo( o2.getCreateDate() );\n }\n } );\n peerEnvelopesMap.put( envelope.getTargetPeerId(), peerEnvelopes );\n }\n\n peerEnvelopes.add( envelope );\n }\n\n\n //try to send messages in parallel - one thread per peer\n try\n {\n for ( Map.Entry<String, Set<Envelope>> envelopsPerPeer : peerEnvelopesMap.entrySet() )\n {\n Peer targetPeer = messenger.getPeerManager().getPeer( envelopsPerPeer.getKey() );\n if ( targetPeer.isLocal() )\n {\n completer.submit(\n new LocalPeerMessageSender( messenger, messengerDao, envelopsPerPeer.getValue() ) );\n }\n else\n {\n completer.submit(\n new RemotePeerMessageSender( messengerDao, targetPeer, envelopsPerPeer.getValue() ) );\n }\n }\n\n //wait for completion\n try\n {\n for ( int i = 0; i < peerEnvelopesMap.size(); i++ )\n {\n Future<Boolean> future = completer.take();\n future.get();\n }\n }\n catch ( InterruptedException | ExecutionException e )\n {\n LOG.warn( \"ignore\", e );\n }\n }\n catch ( PeerException e )\n {\n LOG.error( e.getMessage(), e );\n }\n }",
"synchronized A consume() {\n try {\r\n if ((noMore && slack >= 0) || consumedAll) {\r\n notifyAll();\r\n consumedAll = true;\r\n return null;\r\n }\r\n while (slack != -1) {\r\n wait();\r\n }\r\n A tmp;\r\n\r\n int bSize = CodecUtil.slackOrSize(consumerBuffer, codec);\r\n if(bSize < 0 && endOfStream) {\r\n bSize = Math.abs(bSize);\r\n }\r\n if (bSize <= 0) {\r\n slack = Math.abs(bSize);\r\n notifyAll();\r\n return null;\r\n }\r\n tmp = codec.from(consumerBuffer);\r\n totConsumed += bSize;\r\n notifyAll();\r\n return tmp;\r\n }\r\n catch (InterruptedException e) {\r\n }\r\n return null;\r\n }",
"@Test\n public void multipleProducerAndMultipleConsumerScenarioTest() throws InterruptedException, ExecutionException {\n List<Chunk> chunkList1 = new ArrayList<>();\n //generate chunks for producer 1\n int numOfChunksToUpload = 1000;\n while (numOfChunksToUpload > 0) {\n chunkList1.add(generateChunk(10));\n numOfChunksToUpload--;\n }\n\n //Calculate the cached price list for producer 1\n Map<String, Record> expectedPriceList = new HashMap<>();\n String expectedPrice;\n chunkList1.forEach((chunk) -> {\n Map<String, List<Record>> groupedRecords = chunk.getData().stream().collect(Collectors.groupingBy(Record::getId));\n groupedRecords.forEach((s, l) -> {\n l.sort(recordComparator);\n Record latestRecord = l.get(0);\n expectedPriceList.put(latestRecord.getId(), latestRecord);\n\n });\n\n });\n\n\n List<Chunk> chunkList2 = new ArrayList<>();\n //generate chunks for producer 2\n numOfChunksToUpload = 1000;\n while (numOfChunksToUpload > 0) {\n chunkList2.add(generateChunk(10));\n numOfChunksToUpload--;\n }\n\n //Calculate cached price list for producer 2\n Map<String, Record> cachedPriceList = new HashMap<>();\n chunkList2.forEach((chunk) -> {\n Map<String, List<Record>> groupedRecords = chunk.getData().stream().collect(Collectors.groupingBy(Record::getId));\n groupedRecords.forEach((s, l) -> {\n l.sort(recordComparator);\n Record latestRecord = l.get(0);\n cachedPriceList.put(latestRecord.getId(), latestRecord);\n\n });\n\n });\n\n //calculating expected price with both the producer's cached price list\n cachedPriceList.forEach((k, v) -> {\n Record originalRecord = expectedPriceList.get(k);\n if (originalRecord != null) {\n if (v.getAsOf().compareTo(originalRecord.getAsOf()) >= 0) {\n expectedPriceList.put(k, v);\n }\n } else {\n expectedPriceList.put(k, v);\n }\n });\n\n expectedPrice = String.valueOf(expectedPriceList.get(\"5\").getPayload().get(\"Price\"));\n log.info(\"Expected latest price: \" + expectedPrice);\n //Start the producer 1 thread\n ExecutorService executorService = Executors.newFixedThreadPool(4);\n ProducerThread producerThread1 = new ProducerThread(\"Producer1\", chunkList1, 100, new ApplicationService());\n Future<String> producerResult1 = executorService.submit(producerThread1);\n\n //Start the producer 2 thread\n ProducerThread producerThread2 = new ProducerThread(\"Producer2\", chunkList2, 100, new ApplicationService());\n Future<String> producerResult2 = executorService.submit(producerThread2);\n\n //Wait for both the batch run to start\n Thread.sleep(20);\n //Start a consumer thread to access the price while the batch is running\n Future<String> consumer1Result = executorService.submit(new ConsumerThread(\"Consumer1\", 1, new ApplicationService()));\n assertNull(consumer1Result.get());\n\n //Wait for all the batch runs to be completed\n if (ProducerConstants.BATCH_COMPLETION_MESSAGE.equals(producerResult1.get()) && ProducerConstants.BATCH_COMPLETION_MESSAGE.equals(producerResult2.get())) {\n //Start a consumer thread to access the price and then apply assertion to the expected and actual price\n Future<String> consumer2Result = executorService.submit(new ConsumerThread(\"Consumer2\", 5, new ApplicationService()));\n assertEquals(expectedPrice, consumer2Result.get());\n }\n executorService.shutdown();\n\n }",
"@Override\n public void replicationFinished()\n {\n MyMessage dummyMessage = new MyMessage(this);\n registration().getQueue().enqueue(dummyMessage);\n registration().getQueue().dequeue();\n examination().getQueue().enqueue(dummyMessage);\n examination().getQueue().dequeue();\n vaccination().getQueue().enqueue(dummyMessage);\n vaccination().getQueue().dequeue();\n syringes().getQueue().enqueue(dummyMessage);\n syringes().getQueue().dequeue();\n //End of dummy message\n \n getFinishTime().addSample(currentTime());\n \n getCoolingLengths().addSample(currentTime() - 32400);\n getArrivals().addSample(enviroment().getArrivals());\n getDepartures().addSample(enviroment().getDepartures());\n\n getRegistrationWaitings().addSample(registration().getWaitingStat().mean());\n getExaminationWaitings().addSample(examination().getWaitingStat().mean());\n getVaccinationWaitings().addSample(vaccination().getWaitingStat().mean());\n\n getRegistrationQueueLengths().addSample(registration().getQueueStat().mean());\n getExaminationQueueLengths().addSample(examination().getQueueStat().mean());\n getVaccinationQueueLengths().addSample(vaccination().getQueueStat().mean());\n\n double efficiency = 0.0;\n for (Staff personal : registration().getPersonal()) {\n efficiency += (personal.getWorkingTime() / (currentTime() - (personal.getLunchEnd() - personal.getLunchStart())));\n }\n getRegistrationEfficiency().addSample(efficiency / registration().getPersonal().size());\n\n efficiency = 0.0;\n for (Staff personal : examination().getPersonal()) {\n efficiency += (personal.getWorkingTime() / (currentTime() - (personal.getLunchEnd() - personal.getLunchStart())));\n }\n getExaminationEfficiency().addSample(efficiency / examination().getPersonal().size());\n\n efficiency = 0.0;\n for (Staff personal : vaccination().getPersonal()) {\n efficiency += (personal.getWorkingTime() / (currentTime() - (personal.getLunchEnd() - personal.getLunchStart())));\n }\n getVaccinationEfficiency().addSample(efficiency / vaccination().getPersonal().size());\n\n getWaitingRoomFilling().addSample(waitingRoom().getFillingStat().mean());\n\n getRefillWaitings().addSample(syringes().getWaitingStat().mean());\n getRefillQueueLengths().addSample(syringes().getQueueStat().mean());\n \n getLunchLengths().addSample(canteen().getLunchLengthStat().mean());\n \n super.replicationFinished();\n }",
"private void consume()\r\n\t{\r\n\t\twhile (true)\r\n\t\t{\r\n\t\t\tSubscriberMessage sifMsg = queue.blockingPull();\t\t\t\t\r\n\t\t\tif (sifMsg != null)\r\n\t\t\t{\r\n\t\t\t\tlogger.debug(consumerID+\" has receive a message from its SubscriberQueue.\");\r\n\t\t\t\tif (sifMsg.isEvent())\r\n\t\t\t\t{\r\n\t\t\t\t\tSIFEvent sifEvent = new SIFEvent(sifMsg.getSIFObject(), sifMsg.getEventAction());\r\n\t\t\t\t\ttry\r\n\t\t\t\t\t{\r\n\t\t\t\t\t\tsubscriber.processEvent(sifEvent, sifMsg.getZone(), sifMsg.getMappingInfo(), consumerID);\r\n\r\n\t\t\t\t\t}\r\n\t\t\t\t\tcatch (Exception ex)\r\n\t\t\t\t\t{\r\n\t\t\t\t\t\tlogger.error(\"Failed processing SIF Event for subscriber \"+subscriber.getId()+\": \"+ex.getMessage()+\"\\nEvent Data:\\n\"+sifEvent, ex);\t\t\t\t\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t\telse\r\n\t\t\t\t{\r\n\t\t\t\t\tSIFDataObject sifObj = sifMsg.getSIFObject();\r\n\t\t\t\t\ttry\r\n\t\t\t\t\t{\r\n\t\t\t\t\t\tsubscriber.processResponse(sifObj, sifMsg.getZone(), sifMsg.getMappingInfo(), consumerID);\r\n\t\t\t\t\t}\r\n\t\t\t\t\tcatch (Exception ex)\r\n\t\t\t\t\t{\r\n\t\t\t\t\t\tlogger.error(\"Failed processing SIF Object for subscriber \"+subscriber.getId()+\": \"+ex.getMessage()+\"\\nSIF Object Data:\\n\"+((sifObj == null) ? \"null\" : sifObj.toXML()), ex);\t\t\t\t\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\telse\r\n\t\t\t{\r\n\t\t\t\tlogger.error(consumerID+\" has encountered a problem receiving a message from its SubscriberQueue.\");\r\n\t\t\t}\r\n\t\t}\t\r\n\t}",
"@Override\n public void run() {\n\n int sum = 0;\n\n for (int count = 1; count <= 10; count++) {\n try {\n Thread.sleep(generator.nextInt(3000)); // random sleep\n sharedLocation.set(count); // set value in buffer\n sum += count; // increment sum of values\n System.out.printf(\"\\t%2d\\n\", sum);\n } // end try\n catch (InterruptedException exception) {\n exception.printStackTrace();\n } // end catch\n } // end for\n\n System.out.println(\"Producer done producing\\nTerminating Producer\");\n }",
"private void receive() {\n\t\tMQGetMessageOptions gmo = new MQGetMessageOptions();\n\t\tif (keepMessages) {\n\t\t\tgmo.options = gmo.options | MQConstants.MQGMO_CONVERT | MQConstants.MQGMO_PROPERTIES_FORCE_MQRFH2\n\t\t\t\t\t| MQConstants.MQGMO_BROWSE_FIRST;\n\t\t} else {\n\t\t\tgmo.options = gmo.options | MQConstants.MQGMO_CONVERT | MQConstants.MQGMO_PROPERTIES_FORCE_MQRFH2;\n\t\t\tif (syncPoint) {\n\t\t\t\tgmo.options = gmo.options | MQConstants.MQGMO_SYNCPOINT;\n\t\t\t}\n\t\t}\n\t\tgmo.matchOptions = MQConstants.MQMO_NONE;\n\t\tgmo.waitInterval = this.waitInterval;\n\n\t\ttry {\n\t\t\tint lastSeqNo = 0;\n\t\t\tlong lastTs = 0;\n\t\t\tint messagecounter = 0;\n\t\t\twhile (true) {\n\t\t\t\tif (!(qmgr.isConnected())) {\n\t\t\t\t\treconnectMq();\n\t\t\t\t}\n\t\t\t\tif (!(queue.isOpen())) {\n\t\t\t\t\treconnectMq();\n\t\t\t\t}\n\t\t\t\thaltFileExists();\n\t\t\t\tif (haltStatus) {\n\t\t\t\t\treadQueue = false;\n\t\t\t\t} else {\n\t\t\t\t\treadQueue = true;\n\t\t\t\t}\n\t\t\t\tint queueNotInhibited = queue.getInhibitGet();\n\t\t\t\tif (queueNotInhibited == MQConstants.MQQA_GET_INHIBITED) {\n\t\t\t\t\treadQueue = false;\n\t\t\t\t}\n\t\t\t\tproduceCounts();\n\t\t\t\tif (readQueue) {\n\t\t\t\t\tqueueDepth = queue.getCurrentDepth();\n\t\t\t\t\tif (queueDepth != 0) {\n\t\t\t\t\t\ttry {\n\t\t\t\t\t\t\trcvMessage = new MQMessage();\n\t\t\t\t\t\t\tif (mqccsid != 0) {\n\t\t\t\t\t\t\t\trcvMessage.characterSet = mqccsid;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\tqueue.get(rcvMessage, gmo);\n\t\t\t\t\t\t\trecordCountsRcvd++;\n\t\t\t\t\t\t\tstrLen = rcvMessage.getMessageLength();\n\t\t\t\t\t\t\tstrData = new byte[strLen];\n\t\t\t\t\t\t\trcvMessage.readFully(strData);\n\t\t\t\t\t\t\tmessagePutMs = rcvMessage.putDateTime.getTimeInMillis();\n\t\t\t\t\t\t\tseqNo = rcvMessage.messageSequenceNumber;\n\t\t\t\t\t\t\tif (lastTs == messagePutMs && seqNo == 1) {\n\t\t\t\t\t\t\t\tseqNo = lastSeqNo + seqNo;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\tmsgText = new String(strData);\n\t\t\t\t\t\t\tjsonOut = new JSONArray();\n\t\t\t\t\t\t\tjsonKey = new JSONObject();\n\t\t\t\t\t\t\tjsonValue = new JSONObject();\n\t\t\t\t\t\t\tjsonKey.put(\"key\", Long.toString(messagePutMs) + \"_\" + seqNo);\n\t\t\t\t\t\t\tjsonValue.put(\"value\", msgText);\n\t\t\t\t\t\t\tLOG.debug(\"MQ MsgKey: \" + Long.toString(messagePutMs) + \"_\" + seqNo);\n\t\t\t\t\t\t\tLOG.debug(\"MQ MsgValue: \" + msgText);\n\t\t\t\t\t\t\tjsonOut.put(jsonKey);\n\t\t\t\t\t\t\tjsonOut.put(jsonValue);\n\t\t\t\t\t\t\tmsgList.add(jsonOut.toString());\n\t\t\t\t\t\t\tlastTs = messagePutMs;\n\t\t\t\t\t\t\tlastSeqNo = seqNo;\n\t\t\t\t\t\t\tmessagecounter++;\n\t\t\t\t\t\t\t// move cursor to next message\n\t\t\t\t\t\t\tif (msgList.size() > maxUMsg / 2) {\n\t\t\t\t\t\t\t\tcommitMessages();\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\tif (msgList.size() > queueDepth) {\n\t\t\t\t\t\t\t\tcommitMessages();\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\tif (keepMessages) {\n\t\t\t\t\t\t\t\tgmo.options = MQConstants.MQGMO_CONVERT | MQConstants.MQGMO_PROPERTIES_FORCE_MQRFH2\n\t\t\t\t\t\t\t\t\t\t| MQConstants.MQGMO_WAIT | MQConstants.MQGMO_BROWSE_NEXT;\n\t\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\t\tgmo.options = MQConstants.MQGMO_CONVERT | MQConstants.MQGMO_PROPERTIES_FORCE_MQRFH2\n\t\t\t\t\t\t\t\t\t\t| MQConstants.MQGMO_WAIT;\n\t\t\t\t\t\t\t\tif (syncPoint) {\n\t\t\t\t\t\t\t\t\tgmo.options = gmo.options | MQConstants.MQGMO_SYNCPOINT;\n\t\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t} catch (MQException e) {\n\t\t\t\t\t\t\tif (e.reasonCode == MQConstants.MQRC_NO_MSG_AVAILABLE) {\n\t\t\t\t\t\t\t\tif (msgList.size() > 0) {\n\t\t\t\t\t\t\t\t\tcommitMessages();\n\t\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\t\tnoMessagesCounter++;\n\t\t\t\t\t\t\t\tthreadWait();\n\t\t\t\t\t\t\t} else if (e.reasonCode == MQConstants.MQRC_SYNCPOINT_LIMIT_REACHED) {\n\t\t\t\t\t\t\t\tif (msgList.size() > 0) {\n\t\t\t\t\t\t\t\t\tcommitMessages();\n\t\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\t\tnoMessagesCounter++;\n\t\t\t\t\t\t\t\tthreadWait();\n\t\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\t\tSystem.out.println(\n\t\t\t\t\t\t\t\t\t\tCalendar.getInstance().getTime() + \" - MQ Reason Code: \" + e.reasonCode);\n\t\t\t\t\t\t\t\treconnectMq();\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t} catch (IOException ioe) {\n\t\t\t\t\t\t\tSystem.out.println(Calendar.getInstance().getTime() + \" - Error: \" + ioe.getMessage());\n\t\t\t\t\t\t\treconnectMq();\n\t\t\t\t\t\t}\n\t\t\t\t\t} else {\n\t\t\t\t\t\tif (msgList.size() > 0) {\n\t\t\t\t\t\t\tcommitMessages();\n\t\t\t\t\t\t}\n\t\t\t\t\t\tthreadWait();\n\t\t\t\t\t}\n\t\t\t\t} else {\n\t\t\t\t\tif (msgList.size() > 0) {\n\t\t\t\t\t\tcommitMessages();\n\t\t\t\t\t}\n\t\t\t\t\tthreadWait();\n\t\t\t\t}\n\t\t\t}\n\n\t\t} catch (Throwable t) {\n\t\t\t// restart if there is any other error\n\t\t\trestart(Calendar.getInstance().getTime() + \" - Error receiving data from Queue or QMGR\", t);\n\t\t}\n\n\t}",
"@Test(timeout = 10000)\r\n public void slowConsumer() throws Exception {\r\n ModuleURN instanceURN = new ModuleURN(PROVIDER_URN, \"mymodule\");\r\n Object [] data = {\"item1\", \"item2\", \"item3\", \"item4\"};\r\n DataFlowID flowID = mManager.createDataFlow(new DataRequest[]{\r\n new DataRequest(CopierModuleFactory.INSTANCE_URN, data),\r\n new DataRequest(instanceURN),\r\n new DataRequest(BlockingModuleFactory.INSTANCE_URN)\r\n });\r\n //wait until copier is done emitting all the data\r\n DataFlowInfo flowInfo;\r\n do {\r\n Thread.sleep(100);\r\n flowInfo = mManager.getDataFlowInfo(flowID);\r\n } while(flowInfo.getFlowSteps()[0].getNumEmitted() < 4);\r\n \r\n for(int i = 0; i < data.length; i++) {\r\n //wait for the data to get delivered\r\n BlockingModuleFactory.getLastInstance().getSemaphore().acquire();\r\n //verify the flow info for the last step\r\n flowInfo = mManager.getDataFlowInfo(flowID);\r\n assertFlowStep(flowInfo.getFlowSteps()[2], BlockingModuleFactory.INSTANCE_URN,\r\n false, 0, 0, null, true, i + 1, 0, null, BlockingModuleFactory.INSTANCE_URN, null);\r\n //verify the jmx flow queue size attribute value\r\n if(i < data.length - 1) {\r\n assertEquals(data.length - 1 - i,\r\n getMBeanServer().getAttribute(instanceURN.toObjectName(),\r\n SimpleAsyncProcessor.ATTRIB_PREFIX + flowID));\r\n }\r\n //consume the data\r\n assertEquals(data[i], BlockingModuleFactory.getLastInstance().getNextData());\r\n }\r\n //verify that the queue size is now zero.\r\n assertEquals(0, getMBeanServer().getAttribute(\r\n instanceURN.toObjectName(),\r\n SimpleAsyncProcessor.ATTRIB_PREFIX + flowID));\r\n //cancel data flow\r\n mManager.cancel(flowID);\r\n }",
"@Override\n public void send(Message message) {\n\n expensiveResource.addToResourcesQueue(message);\n expensiveResource.processNextMessage();\n\n }",
"public void consume() throws InterruptedException {\n\t\temptyQueueTime = queue.peek().getProcessedTime();\n\t\tThread.sleep(queue.peek().getProcessedTime());\n\t\tqueue.peek().setFinalTime(System.nanoTime() / Controller.divider - Controller.startTime);\n\t\tqueueEfficency.lazySet((int) (queue.peek().getFinalTime() - queue.peek().getArrivalTime()));\n\t\tqueueAverageWaitingTime = queueEfficency.get() / (10 * dividerOfClients++);\n\t\tBufferedWriter out = null;\n\t\ttry {\n\t\t\tFileWriter fstream = new FileWriter(\"out.txt\", true); // true tells\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// to append\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// data.\n\t\t\tout = new BufferedWriter(fstream);\n\t\t\tout.write(queue.peek().toString2());\n\t\t\tout.newLine();\n\t\t} catch (IOException e) {\n\t\t\tSystem.err.println(\"Error: \" + e.getMessage());\n\t\t} finally {\n\t\t\tif (out != null) {\n\t\t\t\ttry {\n\t\t\t\t\tout.close();\n\t\t\t\t} catch (IOException e) {\n\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\te.printStackTrace();\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\tqueue.take();\n\t}",
"@Override\n public Subscription addConsumer(ConnectionContext context,\n final ConsumerInfo info) throws Exception {\n if (++consumerCount == maxConsumers + (watchTopicAdvisories ? 1:0)) {\n context.setDontSendReponse(true);\n Executors.newSingleThreadExecutor().execute(new Runnable() {\n public void run() {\n LOG.info(\"Stopping broker on consumer: \" + info.getConsumerId());\n try {\n broker.stop();\n } catch (Exception e) {\n e.printStackTrace();\n }\n }\n });\n }\n return super.addConsumer(context, info);\n }",
"@Override\n protected void sink(Message message) {\n }",
"public void propagate(XQueue in, XQueue[] out) throws JMSException {\n Message inMessage = null;\n String msgStr = null, ruleName = null;\n StringBuffer strBuf = null;\n Object o;\n Map rule;\n Browser browser;\n MessageFilter[] filters = null;\n Template template = null;\n AssetList taskList = null;\n String[] propertyName = null, propertyValue = null;\n long[] outInfo = null, ruleInfo = null, taskInfo;\n int[] ruleMap;\n long currentTime, sessionTime;\n long count = 0;\n int mask, ii, hbeat, retry;\n int i = 0, id, hid, tid, m, n;\n int cid = -1; // the cell id of the message in input queue\n int rid = 0; // the id of the ruleset\n int oid = 0; // the id of the output queue\n boolean dspBody = false, inDetail = ((debug & DEBUG_REPT) > 0);\n boolean ckBody = false;\n byte[] buffer = new byte[bufferSize];\n\n i = in.getCapacity();\n if (capacity != i) { // assume it only occurs at startup\n new Event(Event.WARNING, name + \": \" + in.getName() +\n \" has the different capacity of \" + i + \" from \" +\n capacity).send();\n capacity = i;\n msgList.clear();\n msgList = new AssetList(name, capacity);\n cells.clear();\n cells = new CollectibleCells(name, capacity);\n }\n\n // initialize patterns\n n = ruleList.size();\n filters = new MessageFilter[n];\n browser = ruleList.browser();\n ruleMap = new int[n];\n i = 0;\n while ((rid = browser.next()) >= 0) {\n rule = (Map) ruleList.get(rid);\n filters[i] = (MessageFilter) rule.get(\"Filter\");\n if (filters[i] != null) {\n if ((!ckBody) && filters[i].checkBody())\n ckBody = true;\n }\n ruleMap[i++] = rid;\n }\n\n // update assetList\n n = out.length;\n for (i=0; i<n; i++) {\n Object[] asset = (Object[]) assetList.get(i);\n asset[ASSET_XQ] = out[i];\n outInfo = assetList.getMetaData(i);\n if (outInfo[OUT_CAPACITY] != out[i].getCapacity())\n outInfo[OUT_CAPACITY] = out[i].getCapacity();\n }\n pool = out[outLinkMap[POOL_OUT]];\n poolInfo = assetList.getMetaData(outLinkMap[POOL_OUT]);\n if (pool.getCapacity() != reqList.getCapacity()) { // rereate reqList\n reqList.clear();\n reqList = new AssetList(name, pool.getCapacity());\n }\n\n n = ruleMap.length;\n strBuf = new StringBuffer();\n // set all groups active at startup but the first\n hid = heartbeat.length - 1;\n hbeat = heartbeat[hid];\n currentTime = System.currentTimeMillis();\n sessionTime = currentTime;\n ii = 0;\n while (((mask = in.getGlobalMask()) & XQueue.KEEP_RUNNING) > 0) {\n if ((mask & XQueue.STANDBY) > 0) // standby temporarily\n break;\n if ((cid = in.getNextCell(waitTime)) >= 0) { // got a new msg\n currentTime = System.currentTimeMillis();\n\n if ((inMessage = (Message) in.browse(cid)) == null) {\n in.remove(cid);\n new Event(Event.WARNING, name + \": \" + Event.traceStack(\n new JMSException(\"null msg from \"+in.getName()))).send();\n continue;\n }\n\n msgStr = null;\n rid = 0;\n i = 0;\n try {\n if (ckBody)\n msgStr = MessageUtils.processBody(inMessage, buffer);\n for (i=1; i<n; i++) {\n if (filters[i].evaluate(inMessage, msgStr)) {\n rid = ruleMap[i];\n break;\n }\n }\n }\n catch (Exception e) {\n String str = name;\n Exception ex = null;\n if (e instanceof JMSException)\n ex = ((JMSException) e).getLinkedException();\n if (ex != null)\n str += \" Linked exception: \" + ex.toString() + \"\\n\";\n new Event(Event.ERR, str + \" failed to apply the filter \"+i+\n \": \" + Event.traceStack(e)).send();\n i = -1;\n }\n\n ruleName = ruleList.getKey(rid);\n ruleInfo = ruleList.getMetaData(rid);\n\n if (i < 0) // failed on filter\n oid = outLinkMap[FAILURE_OUT];\n else if (TYPE_ACTION != (int) ruleInfo[RULE_PID]) // bypass\n oid = (int) ruleInfo[RULE_OID];\n else try { // to init the monitor and to add it to taskList\n rule = (Map) ruleList.get(rid);\n propertyName = (String[]) rule.get(\"PropertyName\");\n template = (Template) rule.get(\"Template\");\n Map<String,Object> task=initTask(template,buffer,inMessage);\n if (task != null && task.size() > 0) {\n String key = (String) task.get(\"Name\");\n TimeWindows tw = (TimeWindows) task.get(\"TimeWindow\");\n if (ruleInfo[RULE_TTL] > 0)\n tw.setStopTime(currentTime + ruleInfo[RULE_TTL]);\n if (propertyName != null) // copy properties over\n copyProperties(propertyName, task, inMessage);\n taskList = (AssetList) rule.get(\"TaskList\");\n id = taskList.add(key, new long[TASK_TIME+1], task);\n if ((debug & DEBUG_UPDT) > 0)\n new Event(Event.DEBUG, name + \" \" + ruleName +\n \" added a new task of \" + key + \" from \" + cid +\n \" to \" + id + \" with \" + taskList.size() + \" \" +\n ruleInfo[RULE_PEND]).send();\n if (id >= 0) {\n taskInfo = taskList.getMetaData(id);\n for (i=0; i<=TASK_TIME; i++)\n taskInfo[i] = 0;\n taskInfo[TASK_ID] = -1;\n taskInfo[TASK_GID] = -1;\n taskInfo[TASK_STATUS] = NODE_READY;\n taskInfo[TASK_TIME] = currentTime;\n ruleInfo[RULE_PEND] ++;\n ruleInfo[RULE_TIME] = currentTime;\n if (ruleInfo[RULE_OPTION] > 0) { // on wait\n // hold the message until it is done \n taskInfo[TASK_GID] = cid;\n continue;\n }\n oid = outLinkMap[BYPASS_OUT];\n }\n else { // failed to add to the list\n MonitorReport report;\n report = (MonitorReport) task.get(\"Report\");\n if (report != null)\n report.destroy();\n task.clear();\n if (taskList.getID(key) < 0) {\n new Event(Event.ERR, name + \": \" + ruleName +\n \" failed to add new task of \" + key +\n \" \" + taskList.size() + \"/\" +\n ruleInfo[RULE_EXTRA]).send();\n oid = outLinkMap[FAILURE_OUT];\n }\n else {\n new Event(Event.WARNING, name +\": \"+ruleName+\n \" has an active task for \" + key).send();\n oid = outLinkMap[BYPASS_OUT];\n }\n }\n }\n else { // failed to init occurrence\n oid = outLinkMap[FAILURE_OUT];\n new Event(Event.ERR, name + \": \" + ruleName +\n \" failed to init a new task\").send();\n }\n }\n catch (Exception e) {\n oid = outLinkMap[FAILURE_OUT];\n new Event(Event.ERR, name + \": \" + ruleName +\n \" failed to create a new task: \" +\n Event.traceStack(e)).send();\n }\n\n if ((debug & DEBUG_PROP) > 0)\n new Event(Event.DEBUG, name+\" propagate: cid=\" + cid +\n \" rid=\" + rid + \" oid=\" + oid).send();\n\n if (displayMask > 0) try {// display message\n if (dspBody)\n msgStr = MessageUtils.processBody(inMessage, buffer);\n new Event(Event.INFO, name+\": \"+ruleName+\" processed msg \"+\n (count + 1)+\":\"+MessageUtils.display(inMessage, msgStr,\n displayMask, displayPropertyName)).send();\n }\n catch (Exception e) {\n new Event(Event.WARNING, name + \": \" + ruleName +\n \" failed to display msg: \" + e.toString()).send();\n }\n\n count += passthru(currentTime, inMessage, in, rid, oid, cid, 0);\n feedback(in, -1L);\n }\n\n currentTime = System.currentTimeMillis();\n if (currentTime < sessionTime) { // session not due yet\n if (pool.collectible() > 0)\n collect(in, outLinkMap[RESULT_OUT]);\n if (msgList.size() > 0)\n feedback(in, -1L);\n continue;\n }\n\n inDetail = ((debug & DEBUG_REPT) > 0);\n m = 0;\n browser.reset();\n while ((rid = browser.next()) >= 0) { // update active rulesets\n ruleInfo = ruleList.getMetaData(rid);\n if (ruleInfo[RULE_PID] != TYPE_ACTION)\n continue;\n if ((hbeat % (int) ruleInfo[RULE_MODE]) != 0) // not active\n continue;\n if (ruleInfo[RULE_PEND] <= 0) // empty rule\n continue;\n\n ruleName = ruleList.getKey(rid);\n rule = (Map) ruleList.get(rid);\n taskList = null;\n if (rule == null || rule.size() <= 0) {\n new Event(Event.WARNING, name + \": \" + ruleName +\n \" is empty\").send();\n continue;\n }\n taskList = (AssetList) rule.get(\"TaskList\");\n if (taskList == null) {\n new Event(Event.WARNING, name + \": \" + ruleName +\n \" has no taskList\").send();\n continue;\n }\n if (inDetail)\n new Event(Event.DEBUG, name + \": \" + ruleName +\n \" is active with \" + taskList.size() + \" tasks\").send();\n if (taskList.size() <= 0)\n continue;\n retry = (int) ruleInfo[RULE_GID];\n Browser b = taskList.browser();\n while ((tid = b.next()) >= 0) { // dispatch tasks\n taskInfo = taskList.getMetaData(tid);\n id = (int) taskInfo[TASK_ID];\n if (id < 0) { // ready for next run\n ObjectEvent msg = new ObjectEvent();\n msg.setPriority(Event.INFO);\n msg.setAttribute(\"name\", taskList.getKey(tid));\n msg.setBody(taskList.get(tid));\n id = pool.reserve(waitTime);\n if (id >= 0) { // reserved\n if (reqList.existsID(id)) { // preoccupied?\n collect(currentTime, id, in,\n outLinkMap[RESULT_OUT]);\n }\n pool.add(msg, id);\n taskInfo[TASK_ID] = id;\n taskInfo[TASK_STATUS] = NODE_RUNNING;\n taskInfo[TASK_TIME] = currentTime;\n taskInfo[TASK_RETRY] = 0;\n reqList.add(String.valueOf(id),\n new long[]{rid, tid}, msg, id);\n poolInfo[OUT_SIZE] ++;\n poolInfo[OUT_TIME] = currentTime;\n poolInfo[OUT_QTIME] = currentTime;\n m ++;\n if (inDetail)\n strBuf.append(\"\\n\\t\" + ruleName + \"/\" +\n taskList.getKey(tid) + \": \" + tid + \" \" +\n id + \" \" + taskInfo[TASK_RC] + \" \" +\n taskInfo[TASK_COUNT]);\n }\n else { // failed to reserve\n new Event(Event.ERR, name + \" \"+ ruleName + \":\" +\n taskList.getKey(tid) + \" failed to reserve \"+\n \"from \" + pool.getName() + \" \" + pool.depth()+\n \":\" + pool.size() + \"/\" + id).send();\n }\n }\n else if (ruleInfo[RULE_GID] > 0 &&\n taskInfo[TASK_RETRY] >= ruleInfo[RULE_GID]) { // stuck\n taskInfo[TASK_RETRY] ++;\n if (taskInfo[RULE_STATUS] == NODE_RUNNING ||\n taskInfo[RULE_STATUS] == NODE_READY)\n taskInfo[RULE_STATUS] = NODE_RETRYING;\n new Event(Event.ERR, name + \" \"+ ruleName + \":\" +\n taskList.getKey(tid) + \" timed out and stuck \"+\n taskInfo[TASK_RETRY] + \" times at \" + id).send();\n }\n else {\n taskInfo[TASK_RETRY] ++;\n new Event(Event.WARNING, name + \" \"+ ruleName + \":\" +\n taskList.getKey(tid) + \" timed out and stuck \"+\n taskInfo[TASK_RETRY] + \" times at \" + id).send();\n }\n }\n }\n\n if (pool.collectible() > 0)\n collect(in, outLinkMap[RESULT_OUT]);\n if (msgList.size() > 0)\n feedback(in, -1L);\n\n if (inDetail && strBuf.length() > 0) {\n new Event(Event.DEBUG, name + \" RULE/KEY: TID ID RC COUNT - \" +\n m + \" \" + hid + \" \" + hbeat + \" \" + pool.size() + \":\" +\n pool.depth() + \" \" + reqList.size() +\n strBuf.toString()).send();\n strBuf = new StringBuffer();\n }\n\n hid ++;\n if (hid >= heartbeat.length) { // reset session\n hid = 0;\n sessionTime += heartbeat[hid];\n }\n else {\n sessionTime += heartbeat[hid] - hbeat;\n }\n hbeat = heartbeat[hid];\n currentTime = System.currentTimeMillis();\n if (currentTime > sessionTime) // reset sessionTime\n sessionTime = currentTime;\n }\n }",
"@Override\n public void receiveMessages() {\n // put message to currentIncoming message store\n FFIByteVector tmpVector = (FFIByteVector) FFIByteVectorFactory.INSTANCE.create();\n long bytesOfReceivedMsg = 0;\n while (grapeMessager.getPureMessage(tmpVector)) {\n // The retrieved tmp vector has been resized, so the cached objAddress is not available.\n // trigger the refresh\n tmpVector.touch();\n // OutArchive will do the resize;\n if (logger.isDebugEnabled()) {\n logger.debug(\"Frag [{}] digest message of size {}\", fragId, tmpVector.size());\n }\n ///////////////////////////////////////////\n currentIncomingMessageStore.digest(tmpVector);\n ///////////////////////////////////////////\n bytesOfReceivedMsg += tmpVector.size();\n }\n logger.info(\n \"Frag [{}] totally Received [{}] bytes from others starting deserialization\",\n fragId,\n bytesOfReceivedMsg);\n }",
"private void writeNextMessageInQueue() {\n // This should not happen in practice since this method is private and should only be called\n // for a non-empty queue.\n if (mMessageQueue.isEmpty()) {\n Log.e(TAG, \"Call to write next message in queue, but the message queue is empty.\");\n return;\n }\n\n if (mMessageQueue.size() == 1) {\n writeValueAndNotify(mMessageQueue.remove().toByteArray());\n return;\n }\n\n mHandler.post(mSendMessageWithTimeoutRunnable);\n }",
"private void IntervalEndMessageAndSend0() {\n\t\t\t// TODO Auto-generated method stub\n\t\t\t\n\t\t\tString topic;\n\t\t\tIterator<String> ier = TopicMap.keySet().iterator();\n\t\t\twhile(ier.hasNext()){\n\t\t\t\ttopic = ier.next();\n\t\t\t\t//AsyncPushOneFlow(topic, new byte[](new Key(new byte[]{0,0,0}),Sub4SketchingKVStream.endSignal));\n\t\t\t}\n\t\t\t}",
"private void compose() {\n \tnumSamples = duration * sampleRate;\n \tsample = new double[numSamples];\n \tgeneratedSnd = new byte[2 * numSamples];\n\t}",
"@Test\n public void multipleProducerScenarioTest() throws InterruptedException, JsonProcessingException, ExecutionException {\n\n //Create list of chunk for producer 1\n ObjectMapper objectMapper = new ObjectMapper();\n List<Chunk> chunkList1 = new ArrayList<>();\n Chunk chunk = new Chunk();\n chunk.setData(Arrays.asList(objectMapper.readValue(\"{\\\"id\\\":\\\"1\\\", \\\"asOf\\\":\\\"2021-09-07T21:26:57.202898400\\\", \\\"payload\\\":{\\\"Price\\\":20.139961889377744}}\", Record.class),\n objectMapper.readValue(\"{\\\"id\\\":\\\"2\\\", \\\"asOf\\\":\\\"2021-09-07T09:26:57.265399700\\\", \\\"payload\\\":{\\\"Price\\\":70.14384608537513}}\", Record.class)));\n chunkList1.add(chunk);\n ExecutorService executorService = Executors.newFixedThreadPool(2);\n ProducerThread producerThread1 = new ProducerThread(\"Producer1\", chunkList1, 10, new ApplicationService());\n\n Future<String> producerResult = executorService.submit(producerThread1);\n while (true) {\n if (producerResult.isDone())\n break;\n }\n\n //Once the producer 1 is done with the batch run, producer 2 starts the batch run\n if (ProducerConstants.BATCH_COMPLETION_MESSAGE.equals(producerResult.get())) {\n List<Chunk> chunkList2 = new ArrayList<>();\n chunk.setData(Arrays.asList(objectMapper.readValue(\"{\\\"id\\\":\\\"1\\\", \\\"asOf\\\":\\\"2021-09-07T21:55:57.265399700\\\", \\\"payload\\\":{\\\"Price\\\":98.12933222921298}}\", Record.class),\n objectMapper.readValue(\"{\\\"id\\\":\\\"2\\\", \\\"asOf\\\":\\\"2021-09-06T10:26:57.265399700\\\", \\\"payload\\\":{\\\"Price\\\":31.54355122981366}}\", Record.class)));\n chunkList2.add(chunk);\n ProducerThread producerThread2 = new ProducerThread(\"Producer2\", chunkList2, 10, new ApplicationService());\n\n producerResult = executorService.submit(producerThread2);\n while (true) {\n if (producerResult.isDone())\n break;\n }\n\n //Once producer 2 is also done with the batch , then start 2 consumer threads to access the instrument id value.\n if (ProducerConstants.BATCH_COMPLETION_MESSAGE.equals(producerResult.get())) {\n Future<String> priceFromConsumer1 = executorService.submit(new ConsumerThread(\"Consumer1\", 1, new ApplicationService()));\n Future<String> priceFromConsumer2 = executorService.submit(new ConsumerThread(\"Consumer2\", 2, new ApplicationService()));\n\n assertEquals(\"98.12933222921298\", priceFromConsumer1.get());\n assertEquals(\"70.14384608537513\", priceFromConsumer2.get());\n }\n }\n\n executorService.shutdown();\n\n }",
"public static void main(String[] args) {\n\n\n BasicProducer basicProducer = new BasicProducer(\"3-part-topic\");\n long t0 = System.currentTimeMillis();\n basicProducer.postSynchMessage(\"Synched 8 Message\");\n long t1 = System.currentTimeMillis();\n System.out.println(\"time taken basicProducer.postSynchMessage=\" + (t1-t0)); // 192 // 193\n\n long t2 = System.currentTimeMillis();\n basicProducer.postAsynchMessage(\"async 8 Message\");\n long t3 = System.currentTimeMillis();\n System.out.println(\"time taken basicProducer.postSynchMessage=\" + (t3-t2)); //14\n\n\n }",
"@Override\n public void handleMessage(Message msg) {\n sendEmptyMessageDelayed(0, 3000);\n if (resClient.getSendBufferFreePercent() <= 0.05) {\n Toast.makeText(StreamingActivity.this, \"sendbuffer is full,netspeed is low!\", Toast.LENGTH_SHORT).show();\n }\n }",
"private void compose() {\n \tnumSamples = duration * sampleRate;\n \tsample = new double[numSamples];\n \tgeneratedSnd = new byte[2 * numSamples];\t\t\n\t}",
"protected void syncConsumeLoop(MessageConsumer requestConsumer) {\n try {\n Message message = requestConsumer.receive(5000);\n if (message != null) {\n onMessage(message);\n } else {\n System.err.println(\"No message received\");\n }\n } catch (JMSException e) {\n onException(e);\n }\n }",
"private void push() {\n ImmutableSortedSet<T> myAvailable = _outstanding.apply(\n new Syncd.Transformer<ImmutableSortedSet<T>, ImmutableSortedSet<T>>() {\n public Tuple<ImmutableSortedSet<T>, ImmutableSortedSet<T>> apply(ImmutableSortedSet<T> aBefore) {\n final SortedSet<T> myRemaining = new TreeSet<>(new MessageComparator<T>());\n\n // Identify those messages that are sequentially contiguous from _floor and can be passed on\n //\n ImmutableSortedSet<T> myAccessible =\n new ImmutableSortedSet.Builder<>(new MessageComparator<T>()).addAll(\n Iterables.filter(aBefore, new Predicate<T>() {\n public boolean apply(T aMessage) {\n Long myCurrent = _floor.get();\n\n if (aMessage.getSeq() == myCurrent) {\n // This message can be sent out to listeners so long as we're first to try\n //\n if (_floor.testAndSet(myCurrent, myCurrent + 1))\n return true;\n } else\n // This message must remain\n //\n myRemaining.add(aMessage);\n\n // Couldn't send message out or it must remain\n //\n return false;\n }\n })\n ).build();\n\n return new Tuple<>(new ImmutableSortedSet.Builder<>(\n new MessageComparator<T>()).addAll(myRemaining).build(),\n myAccessible);\n }\n }\n );\n\n send(myAvailable);\n archive(myAvailable);\n }",
"public static void main(String[] args) throws Exception {\n\t\tProperties props = new Properties();\n\t\tprops.put(\"bootstrap.servers\", \"127.0.0.1:9092\");\n\t\tprops.put(\"acks\", \"all\");\n\t\tprops.put(\"retries\", 0);\n\t\tprops.put(\"batch.size\", 16384);\n\t\tprops.put(\"linger.ms\", 1);\n\t\tprops.put(\"buffer.memory\", 33554432);\n\t\tprops.put(\"key.serializer\", \"org.apache.kafka.common.serialization.StringSerializer\");\n\t\tprops.put(\"value.serializer\", \"org.apache.kafka.common.serialization.StringSerializer\");\n\n\t\t/*\n\t\t * Define new Kafka producer\n\t\t */\n\t\t@SuppressWarnings(\"resource\")\n\t\tProducer<String, String> producer = new KafkaProducer<>(props);\n\n\t\t/*\n\t\t * parallel generation of JSON messages on Transaction topic\n\t\t * \n\t\t * this could also include business logic, projection, aggregation, etc.\n\t\t */\n\t\tThread transactionThread = new Thread(new Runnable() {\n\t\t\tpublic void run() {\n\t\t\t\tString topic = \"Transaction\";\n\t\t\t\tList<JSONObject> transactions = new ArrayList<JSONObject>();\n\t\t\t\tinitJSONData(\"ETLSpark_Transactions.json\", transactions);\n\t\t\t\tfor (int i = 0; i < transactions.size(); i++) {\n\t\t\t\t\tif (i % 200 == 0) {\n\t\t\t\t\t\tSystem.out.println(\"200 Transaction Messages procuded\");\n\t\t\t\t\t\ttry {\n\t\t\t\t\t\t\tThread.sleep(1000);\n\t\t\t\t\t\t} catch (InterruptedException e) {\n\t\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t\tproducer.send(new ProducerRecord<String, String>(topic, Integer.toString(i), transactions.get(i).toString()));\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\n\t\t/*\n\t\t * parallel generation of customer topic messages \n\t\t */\n\t\tThread customerThread = new Thread(new Runnable() {\n\t\t\tpublic void run() {\n\t\t\t\tString topic = \"Customer\";\n\t\t\t\tList<JSONObject> customer = new ArrayList<JSONObject>();\n\t\t\t\tinitJSONData(\"ETLSpark_Customer.json\", customer);\n\t\t\t\tfor (int i = 0; i < customer.size(); i++) {\n\t\t\t\t\tif (i % 200 == 0) {\n\t\t\t\t\t\tSystem.out.println(\"200 Customer Messages procuded\");\n\t\t\t\t\t\ttry {\n\t\t\t\t\t\t\tThread.sleep(1000);\n\t\t\t\t\t\t} catch (InterruptedException e) {\n\t\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t\tproducer.send(new ProducerRecord<String, String>(topic, Integer.toString(i), customer.get(i).toString()));\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\n\t\t/*\n\t\t * parallel generation of messages (variable produceMessages)\n\t\t * \n\t\t * generated messages are based on mockaroo api\n\t\t */\n\t\tint produceMessages = 100000;\n\t\tThread accountThread = new Thread(new Runnable() {\n\t\t\tpublic void run() {\n\t\t\t\tString topic = \"Account\";\n\t\t\t\tfor (int i = 0; i < produceMessages; i++) {\n//\t\t\t\t\tSystem.out.println(\"Account procuded\");\n\t\t\t\t\tproducer.send(new ProducerRecord<String, String>(topic, Integer.toString(i), getRandomTransactionJSON(i)));\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\n\t\ttransactionThread.start();\n\t\tcustomerThread.start();\n\t\taccountThread.start();\n\n\t}",
"private static void backPressureChallenge() {\n\t\tObservable.range(1, 1000000)\n\t\t//below map will run in sequential\n\t\t//since sequential it has to complete whole task then only it can allow consumer to start\n\t\t\t.map(item -> {\n\t\t\t\tSystem.out.println(\"Produced item \"+item +\" using thread \"+Thread.currentThread().getName());\n\t\t\t\treturn item;\n\t\t\t})\n\t\t\t.observeOn(Schedulers.io())\n\t\t\t//.subscribeOn(Schedulers.io())//with this whole pipelein runs in seprate thread paralleley\n\t\t\t//below will run in concurrent\n\t\t\t.subscribe(item ->{\n\t\t\t\t//mimcing slowness\n\t\t\t\tThreadUtil.sleep(300);\n\t\t\t\tSystem.out.println(\"Consumed item \"+item +\" using thread \"+Thread.currentThread().getName());\n\t\t\t})\n\t\t\t\n\t\t\t;\n\t\t\n\t\t//since running in async we need to sleep\n\t\tThreadUtil.sleep(10000000);\n\t}",
"public InMemoryQueueService(){\n this.ringBufferQueue = new QueueMessage[10000];\n }",
"@Test\n void receivesWithSmallPrefetch() {\n // Arrange\n final String secondPartitionId = \"2\";\n final AtomicBoolean isActive = new AtomicBoolean(true);\n final EventHubProducerAsyncClient producer = toClose(builder.buildAsyncProducerClient());\n\n final Disposable producerEvents = toClose(getEvents(isActive)\n .flatMap(event -> producer.send(event, new SendOptions().setPartitionId(secondPartitionId)))\n .subscribe(\n sent -> {\n },\n error -> logger.error(\"Error sending event\", error),\n () -> logger.info(\"Event sent.\")));\n\n final int prefetch = 5;\n final int backpressure = 3;\n final int batchSize = 10;\n final EventHubConsumerAsyncClient consumer = toClose(builder\n .prefetchCount(prefetch)\n .buildAsyncConsumerClient());\n\n // Act & Assert\n try {\n StepVerifier.create(consumer.receiveFromPartition(secondPartitionId, EventPosition.latest()), prefetch)\n .expectNextCount(prefetch)\n .thenRequest(backpressure)\n .expectNextCount(backpressure)\n .thenRequest(batchSize)\n .expectNextCount(batchSize)\n .thenRequest(batchSize)\n .expectNextCount(batchSize)\n .thenAwait(Duration.ofSeconds(1))\n .thenCancel()\n .verify(TIMEOUT);\n } finally {\n isActive.set(false);\n }\n }",
"private static void backPressureFix() {\n\t\tFlowable.range(1, 1000000)\n\t\t//below map will run in sequential\n\t\t//since sequential it has to complete whole task then only it can allow consumer to start\n\t\t\t.map(item -> {\n\t\t\t\tSystem.out.println(\"Produced item \"+item +\" using thread \"+Thread.currentThread().getName());\n\t\t\t\treturn item;\n\t\t\t})\n\t\t\t.observeOn(Schedulers.io())\n\t\t\t//.subscribeOn(Schedulers.io())//with this whole pipelein runs in seprate thread paralleley\n\t\t\t//below will run in concurrent\n\t\t\t.subscribe(item ->{\n\t\t\t\t//mimcing slowness\n\t\t\t\tThreadUtil.sleep(300);\n\t\t\t\tSystem.out.println(\"Consumed item \"+item +\" using thread \"+Thread.currentThread().getName());\n\t\t\t})\n\t\t\t\n\t\t\t;\n\t\t\n\t\t//since running in async we need to sleep\n\t\tThreadUtil.sleep(10000000);\n\t\t\t\n\t}",
"@Override\n\t\t\tpublic IAMQPPublishAction messages(Collection<byte[]> messages) {\n\t\t\t\treturn null;\n\t\t\t}",
"@Override\n\t\t\tpublic IAMQPPublishAction messages(Collection<byte[]> messages) {\n\t\t\t\treturn null;\n\t\t\t}",
"@Override\n public void subscribe(FlowableEmitter<Integer> e) throws Exception {\n for (int i = 0; i < 128; i++) {\n Log.e(TAG, \"emit \" + i);\n e.onNext(i);\n }\n }",
"private void consumeImpl(Consumer<String, String> messageReader) {\n int pollTimeout = environment.getProperty(\"app.kafka.pull.timeout\", Integer.class);\n long timeoutNoMessages = environment.getProperty(\"app.kafka.timeout.no.messages\", Long.class);\n\n long timeoutNoMessagesMark = System.currentTimeMillis();\n while (true) {\n ConsumerRecords<String, String> records = messageReader.poll(pollTimeout);\n\n if (records.count() == 0) {\n if ((timeoutNoMessagesMark + timeoutNoMessages) < System.currentTimeMillis()) {\n LOG.debug(\"Timeout after \" + timeoutNoMessages + \" milliseconds, terminating.\");\n break;\n }\n\n continue;\n }\n\n timeoutNoMessagesMark = System.currentTimeMillis();\n\n for (ConsumerRecord<String, String> record : records) {\n ++totalConsumed;\n\n consumeRecord(record);\n }\n }\n }",
"@Override\n @SuppressWarnings(\"unchecked\")\n protected void customSync() {\n Exchanger<Void>[] exchangers = (Exchanger<Void>[]) new Exchanger<?>[PRODUCERS_COUNT];\n\n for (int i = 0; i < PRODUCERS_COUNT; i++) {\n exchangers[i] = new Exchanger<>();\n new Producer(params.dataResults, params.postResult, exchangers[i]).start();\n }\n\n new Consumer(params.postFinish, exchangers).start();\n }",
"public static void main(String[] args) {\n MonitorQueue queue = new MonitorQueue(10);\n AtomicInteger num = new AtomicInteger(0);\n IntStream.rangeClosed(0, 5).forEach(\n i -> new Thread(() -> {\n for (; ; ) {\n int andIncrement = num.getAndIncrement();\n queue.produce(andIncrement);\n System.out.println(Thread.currentThread() + \"<---> produce: \" + andIncrement);\n try {\n TimeUnit.MILLISECONDS.sleep(5);\n } catch (InterruptedException e) {\n e.printStackTrace();\n }\n }\n }).start()\n );\n\n IntStream.rangeClosed(0, 2).forEach(\n i -> new Thread(\n () -> {\n for (; ; ) {\n int consume = queue.consume();\n System.out.println(Thread.currentThread() + \"<---> consume: \" + consume);\n try {\n TimeUnit.MILLISECONDS.sleep(5);\n } catch (InterruptedException e) {\n e.printStackTrace();\n }\n }\n }\n ).start()\n );\n\n }",
"private void sendKafkaData(String kafkaConnect, String inputTopic){\n Properties props = new Properties();\n props.put(\"metadata.broker.list\", kafkaConnect);\n props.put(\"serializer.class\", \"kafka.serializer.StringEncoder\");\n props.put(\"partitioner.class\", \"kafka.producer.DefaultPartitioner\");\n props.put(\"request.required.acks\", \"1\");\n props.put(\"retry.backoff.ms\", \"1000\");\n ProducerConfig config = new ProducerConfig(props);\n \n Producer<String, String> producer = new Producer<String, String>(config);\n for(int i = 0; i < numMessages; i++) {\n String messageKey = \"key-\" + i;\n String message = Integer.toString(i);\n producer.send(new KeyedMessage<String, String>(inputTopic, messageKey, message));\n if((i + 1) % 500 == 0) {\n System.out.println(\"Send \" + (i + 1) + \" messages\");\n }\n }\n producer.close();\n }",
"public void run() {\n\t\tString line = null;\n\t\tMessage message;\n\t\tBufferQueueElement<Message> messageList = new BufferQueueElement<Message>();\n\t\tlong t1 = System.nanoTime();\n\t long t2 = 0;\n\t\ttry {\n\t\t\twhile ((line = messageIO.readMessage()) != null) {\n\t\t\t\tt2 = System.nanoTime();\n\t\t\t\t/* Ok, we can close the stream. But process the last message list. */\n\t\t\t\tif (CLOSE_STREAM.equals(line)) {\n\t\t\t\t\tmessageList.setStreamClosed(true);\n\t\t\t\t\tqueue.put(messageList);\n\t\t\t\t\tbreak;\n\t\t\t\t} else if((t2 - t1) < ONE_SECOND) {\n\t\t\t\t\tmessage = new Message(line);\n\t\t\t\t\tmessageList.setMessageElement(message);\n\t\t\t\t} else {\n\t\t\t\t\tqueue.put(messageList);\n\t\t\t\t\tmessageList = new BufferQueueElement<Message>();\n\t\t\t\t\tt1 = System.nanoTime();\n\t\t\t\t\tmessage = new Message(line);\n\t\t\t\t\tmessageList.setMessageElement(message);\n\t\t\t\t}\n\t\t\t}\n\t\t} catch (IOException e) {\n\t\t\tSystem.out.println(e.getMessage());\n\t\t} catch (InterruptedException e) {\n\t\t\tSystem.out.println(e.getMessage());\n\t\t}\n\t}",
"@DSSafe(DSCat.IPC_CALLBACK)\n @DSGenerator(tool_name = \"Doppelganger\", tool_version = \"2.0\", generated_on = \"2013-12-30 12:59:45.580 -0500\", hash_original_method = \"2469457C965E8FC7C139A1D414384428\", hash_generated_method = \"42C86E9B0B120923F19E3F5FDF13C046\")\n \n@Override\n public void handleMessage(Message msg) {\n mResultMsg = Message.obtain();\n mResultMsg.copyFrom(msg);\n synchronized(mLockObject) {\n mLockObject.notify();\n }\n }",
"@Override\n\t\tpublic void run() {\n\t\t\t\tSystem.out.println(\"topic 消息类型开始产生消息 \" + \"生产者: \" + Thread.currentThread().getName());\n\t\t\t\ttry {\n\t\t\t\t\t\t/**第一步 创建连接工厂*/\n\t\t\t\t\t\tfactory = new ActiveMQConnectionFactory(MqConfigConstants.USERNAME, MqConfigConstants.PASSWORD, MqConfigConstants.BROKEURL_ALI);\n\t\t\t\t\t\t/**第二步 创建JMS 连接*/\n\t\t\t\t\t\tConnection connection = factory.createConnection();\n\t\t\t\t\t\tconnection.start();\n\t\t\t\t\t\t/** 第三步 创建Session,开启事务 */\n\t\t\t\t\t\tSession session = connection.createSession(true, Session.AUTO_ACKNOWLEDGE);\n\t\t\t\t\t\t/** 第四步: 创建topic,Topic是 Destination接口的子接口*/\n\t\t\t\t\t\tTopic topic = session.createTopic(MqConfigConstants.TopicName);\n\t\t\t\t\t\t/** 第五步 创建生产者producer */\n\t\t\t\t\t\tMessageProducer producer = session.createProducer(topic);\n\n\t\t\t\t\t\t/** 设置消息不需要持久化 */\n\t\t\t\t\t\tproducer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);\n\t\t\t\t\t\t//发送文本消息\n\t\t\t\t\t\twhile (true) {\n\t\t\t\t\t\t\t\t/** 第六步 发送消息 */\n\t\t\t\t\t\t\t\tMessage message = createMessage(session,\"vincent\",27,\"江西省赣州市\");\n\t\t\t\t\t\t\t\tproducer.send(message);\n\t\t\t\t\t\t\t\tsession.commit();//开启事务必须需要提交,消费者才能获取到\n\t\t\t\t\t\t\t\tSystem.out.println(\"发送消息: \" +message.toString() );\n\t\t\t\t\t\t\t\tThread.sleep(200);\n\t\t\t\t\t\t}\n\t\t\t\t} catch (JMSException e) {\n\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t} catch (InterruptedException e) {\n\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t}\n\t\t}",
"public static void main(String[] args) throws Exception {\n DefaultMQProducer producer = new\n DefaultMQProducer(\"producer1\");\n //Launch the instance.\n producer.setNamesrvAddr(\"192.168.0.159:9876\");\n\n producer.start();\n for (int i = 0; i < 2000; i++) {\n //Create a message instance, specifying topic, tag and message body.\n Message msg = new Message(\"test111\" /* Topic */,\n \"TagA\" /* Tag */,\n (\"{\\\"_db_\\\":\\\"order_service\\\",\\\"_table_\\\":\\\"order_base\\\",\\\"_event_\\\":\\\"row_insert\\\",\\\"order_id\\\":\\\"1\" + i +\"\\\",\\\"order_from\\\":\\\"rocketmq\\\",\\\"order_no\\\":\\\"P12311111\\\",\" +\n \"\\\"category\\\":\\\"1\\\",\\\"serve_type\\\":\\\"2\\\",\\\"account_id\\\":\\\"\\\",\\\"account_type\\\":\\\"\\\",\\\"order_status\\\":\\\"\\\",\\\"region_id\\\":\\\"\\\",\\\"appoint_method\\\":\\\"\\\",\\\"sp_type\\\":\\\"\\\",\\\"order_type\\\":\\\"\\\",\\\"is_delete\\\":\\\"\\\",\\\"refund_status\\\":\\\"\\\",\\\"order_pay_status\\\":\\\"\\\",\\\"is_logistics\\\":\\\"\\\",\\\"repair_type\\\":\\\"\\\",\\\"is_return\\\":\\\"\\\",\\\"create_time\\\":\\\"\\\",\\\"update_time\\\":\\\"\\\"}\").getBytes(RemotingHelper.DEFAULT_CHARSET) /* Message body */\n );\n //Call send message to deliver message to one of brokers.\n SendResult sendResult = producer.send(msg);\n System.out.printf(\"%s%n\", sendResult);\n }\n //Shut down once the producer instance is not longer in use.\n producer.shutdown();\n }",
"private void sendMsgBurst(long stopTime)\n {\n for (ClientChannelInfo clientChannelInfo : _channelHandler.activeChannelList())\n {\n ProviderSession providerSession = (ProviderSession)clientChannelInfo.userSpec;\n\n // The application corrects for ticks that don't finish before the time \n // that the next update burst should start. But don't do this correction \n // for new channels.\n if(providerSession.timeActivated() == 0)\n {\n continue;\n }\n \n int ret = TransportReturnCodes.SUCCESS;\n\n // Send burst of updates\n if(ProviderPerfConfig.updatesPerSec() != 0 && providerSession.updateItemList().count() != 0)\n {\n ret = sendUpdateBurst(providerSession, _error);\n if (ret > TransportReturnCodes.SUCCESS)\n {\n \t // Need to flush\n if (!ProviderPerfConfig.useReactor()) // use UPA Channel\n {\n _channelHandler.requestFlush(clientChannelInfo);\n }\n }\n }\n \n // Send burst of generic messages\n if(ProviderPerfConfig.genMsgsPerSec() != 0 && providerSession.genMsgItemList().count() != 0)\n {\n ret = sendGenMsgBurst(providerSession, _error);\n if (ret > TransportReturnCodes.SUCCESS)\n {\n \t // Need to flush\n if (!ProviderPerfConfig.useReactor()) // use UPA Channel\n {\n _channelHandler.requestFlush(clientChannelInfo);\n }\n }\n }\n\n // Use remaining time in the tick to send refreshes.\n while(ret >= TransportReturnCodes.SUCCESS && providerSession.refreshItemList().count() != 0 && currentTime() < stopTime)\n ret = sendRefreshBurst(providerSession, _error);\n \n if(ret < TransportReturnCodes.SUCCESS)\n {\n switch(ret)\n {\n case TransportReturnCodes.NO_BUFFERS:\n if (!ProviderPerfConfig.useReactor()) // use UPA Channel\n {\n _channelHandler.requestFlush(clientChannelInfo);\n }\n break;\n default:\n \t if (!Thread.interrupted())\n \t {\n \t\t System.out.printf(\"Failure while writing message bursts: %s (%d)\\n\", _error.text(), ret);\n \t\t if (!ProviderPerfConfig.useReactor()) // use UPA Channel\n {\n \t\t _channelHandler.closeChannel(clientChannelInfo, _error); //Failed to send an update. Remove this client\n }\n else // use UPA VA Reactor\n {\n System.out.println(\"Channel Closed.\");\n \n long inactiveTime = System.nanoTime();\n getProvThreadInfo().stats().inactiveTime(inactiveTime);\n \n --_connectionCount;\n \n // unregister selectableChannel from Selector\n try\n {\n SelectionKey key = clientChannelInfo.reactorChannel.selectableChannel().keyFor(_selector);\n key.cancel();\n }\n catch (Exception e) { } // channel may be null so ignore\n \n if (providerSession.clientChannelInfo().parentQueue.size() > 0)\n {\n providerSession.clientChannelInfo().parentQueue.remove(providerSession.clientChannelInfo());\n }\n\n clientChannelInfo.reactorChannel.close(_errorInfo); //Failed to send an update. Remove this client\n }\n \t }\n break;\n }\n }\n else if (ret > TransportReturnCodes.SUCCESS)\n {\n // need to flush\n if (!ProviderPerfConfig.useReactor()) // use UPA Channel\n {\n _channelHandler.requestFlush(clientChannelInfo);\n }\n }\n }\n }",
"public void flush() {\n // all getAndSet will not be synchronous but it's ok since metrics will\n // be spread out among processor worker and we flush every 5s by\n // default\n\n processor.send(new TelemetryMessage(this.metricsSentMetric, this.metricsSent.getAndSet(0), tags));\n processor.send(new TelemetryMessage(this.eventsSentMetric, this.eventsSent.getAndSet(0), tags));\n processor.send(new TelemetryMessage(this.serviceChecksSentMetric, this.serviceChecksSent.getAndSet(0), tags));\n processor.send(new TelemetryMessage(this.bytesSentMetric, this.bytesSent.getAndSet(0), tags));\n processor.send(new TelemetryMessage(this.bytesDroppedMetric, this.bytesDropped.getAndSet(0), tags));\n processor.send(new TelemetryMessage(this.packetsSentMetric, this.packetsSent.getAndSet(0), tags));\n processor.send(new TelemetryMessage(this.packetsDroppedMetric, this.packetsDropped.getAndSet(0), tags));\n processor.send(new TelemetryMessage(this.packetsDroppedQueueMetric, this.packetsDroppedQueue.getAndSet(0), tags));\n processor.send(new TelemetryMessage(this.aggregatedContextsMetric, this.aggregatedContexts.getAndSet(0), tags));\n }",
"public interface EntityCollector {\n\n /**\n * Add httpContent to the queue.\n * @param httpContent httpContent\n */\n void addHttpContent(HttpContent httpContent);\n\n /**\n * Get the first httpContent from the queue.\n * @return HttpContent\n */\n HttpContent getHttpContent();\n\n /**\n * Get the first ByteBuffer version of the HttpContent from the queue.\n * @return ByteBuffer\n */\n ByteBuf getMessageBody();\n\n /**\n * Add the ByteBuffer version the httpContent to the queue.\n * @param msgBody ByteBuffer version of the httpContent.\n */\n void addMessageBody(ByteBuffer msgBody);\n\n /**\n * Check if the queue is empty.\n * @return true or false\n */\n boolean isEmpty();\n\n /**\n * Get the full message length.\n * @return message length\n */\n long getFullMessageLength();\n\n /**\n * Count the message length till the given message length and returns.\n * If the message length is shorter than the given length it returns with the\n * available message size. This method is blocking function. Hence, use with care.\n *\n * @param maxLength is the maximum length to count\n * @return counted length\n * @throws IllegalStateException if illegal state occurs in the absence of content\n */\n long countMessageLengthTill(long maxLength) throws IllegalStateException;\n\n /**\n * Complete the message.\n */\n void completeMessage();\n\n /**\n * This is need to release content before GC.\n */\n void waitAndReleaseAllEntities();\n}",
"public abstract void processMsg(ConsumerRecord<byte[], byte[]> record);",
"Producer(final Consumer<String, Integer> obj, final T1 msg, final int time) {\n cons = obj;\n message = msg;\n this.time = time;\n }",
"@Override\n\tpublic void process(long a_maxReads, String a_topic, int a_partition, List<String> a_seedBrokers, int a_port)\n\t\t\tthrows Exception {\n\n\t}",
"protected abstract void sendMessage(UUID[] players, String[] messages, IntConsumer response);",
"private void ReceiveMessages() throws Exception {\r\n // Variables\r\n Connection connection = null;\r\n Session session = null;\r\n MessageConsumer consumer = null;\r\n\r\n try {\r\n ConnectionFactory connectionFactory = MyCreateConnectionFactory();\r\n\r\n System.out.println(\"Connection Factory created.\");\r\n\r\n connection = MyCreateConnection(connectionFactory);\r\n\r\n System.out.println(\"Connection created.\");\r\n\r\n session = MyCreateSession(connection);\r\n\r\n System.out.println(\"Session created.\");\r\n\r\n Destination destination = MyCreateDestination(session);\r\n\r\n System.out.println(\"Destination created: \" + destination.toString());\r\n\r\n consumer = MyCreateConsumer(session, destination);\r\n\r\n System.out.println(\"Consumer created.\");\r\n\r\n System.out.println(\"Waiting for messages...\");\r\n\r\n // Now receive messages synchronously or asynchronously\r\n\r\n // Synchronously\r\n if (Options.ReceiveMode.Value().equals(Literals.Sync)) {\r\n // Start the connection\r\n connection.start();\r\n\r\n // Receive specified number of messages\r\n Message recvMsg = null;\r\n while (messagesInTotal.equals(Literals.Infinite)\r\n || (messagesReceived < Integer.parseInt(messagesInTotal))) {\r\n // If we want to wait until timeout, use the following call instead\r\n // recvMsg = consumer.receive(TIMEOUTTIME);\r\n\r\n // Receive the message\r\n recvMsg = consumer.receive();\r\n\r\n // Increment the counter\r\n messagesReceived++;\r\n\r\n \r\n if (recvMsg != null) {\r\n // Display received message\r\n DisplayMessage(recvMsg);\r\n }\r\n else {\r\n throw new Exception(\"Message received was null.\");\r\n }\r\n\r\n // Sleep for a while to allow the user to see the output on the screen\r\n Thread.sleep(Options.Interval.ValueAsNumber() * 1000);\r\n\r\n } // end of while\r\n\r\n } // end synchronously\r\n\r\n // Asynchronously\r\n else if (Options.ReceiveMode.Value().equals(Literals.Async)) {\r\n // Create and register a new MessageListener for this consumer\r\n consumer.setMessageListener(new MessageListener() {\r\n\r\n public void onMessage(Message msg) {\r\n // The try block below is unlikely to throw a runtime exception, but as a general good\r\n // practice an asynchronous consumer's message listener or callback should catch a\r\n // potential runtime exception, and optionally divert the message in question to an\r\n // application-specific destination.\r\n try {\r\n synchronized (threadWaitLock) {\r\n // Increment the counter\r\n ++messagesReceived;\r\n\r\n // Display the message that just arrived\r\n DisplayMessage(msg);\r\n\r\n // Notify main thread we've received a message\r\n threadWaitLock.notify();\r\n\r\n // Sleep for a while to allow the user to see the output on the screen\r\n Thread.sleep(Options.Interval.ValueAsNumber() * 1000);\r\n }\r\n } // end try\r\n catch (Exception e) {\r\n System.out.println(\"Exception caught in onMessage():\\n\" + e);\r\n // We have atleast two choices now - (1) rethrow the exception. In this case the\r\n // control passes back to JMS client and which may attempt to redeliver the message,\r\n // depending on session's acknowledge mode, or (2) terminate the process.\r\n // Orthogonally, we may divert the message to an application-specific destination.\r\n\r\n // Terminate the current process\r\n System.exit(-1);\r\n }\r\n return;\r\n } // end onMessage()\r\n }); // end setMessageListener\r\n\r\n // Start the connection\r\n connection.start();\r\n\r\n // Finite number of messages to receive\r\n if (messagesInTotal != Literals.Infinite) {\r\n synchronized (threadWaitLock) {\r\n try {\r\n // Temporary variables\r\n int noProgressCount = 0;\r\n int countLastSeen = -1;\r\n\r\n int expectedNumMessages = Integer.parseInt(messagesInTotal);\r\n while (messagesReceived != expectedNumMessages) {\r\n // Wait for few seconds (or be notified by the listener thread) before checking the\r\n // number of messages received\r\n threadWaitLock.wait(waitTime);\r\n\r\n if (countLastSeen != messagesReceived) {\r\n countLastSeen = messagesReceived;\r\n noProgressCount = 0;\r\n }\r\n else {\r\n ++noProgressCount;\r\n }\r\n\r\n if (++noProgressCount >= MAX_NO_PROGRESS) {\r\n // No progress has been made by the listener in 5 seconds * 3 = 15 seconds.\r\n // Let's quit.\r\n break;\r\n }\r\n\r\n } // end while\r\n } // end try\r\n catch (InterruptedException e) {\r\n System.err\r\n .println(\"Main thread waiting for MessageListener thread to receive message was interupted!\"\r\n + e);\r\n throw e;\r\n }\r\n } // end synchronized block\r\n } // end if\r\n // Infinite number of messages to receive\r\n else {\r\n // Block this thread and let listener thread do all the work (if any).\r\n synchronized (threadWaitLock) {\r\n try {\r\n while (true) {\r\n // Wait to be notified by the listener thread and then wait again!\r\n threadWaitLock.wait();\r\n }\r\n }\r\n catch (InterruptedException e) {\r\n System.err\r\n .println(\"Main thread waiting for MessageListener thread to receive message was interupted!\"\r\n + e);\r\n throw e;\r\n }\r\n\r\n } // end synchronized block\r\n } // end else\r\n } // end asynchronously\r\n }\r\n catch (JMSException jmsex) {\r\n processJMSException(jmsex);\r\n }\r\n finally {\r\n if (consumer != null) {\r\n try {\r\n consumer.close();\r\n }\r\n catch (JMSException jmsex) {\r\n System.out.println(\"Consumer could not be closed.\");\r\n processJMSException(jmsex);\r\n }\r\n }\r\n\r\n if (session != null) {\r\n try {\r\n session.close();\r\n }\r\n catch (JMSException jmsex) {\r\n System.out.println(\"Session could not be closed.\");\r\n processJMSException(jmsex);\r\n }\r\n }\r\n\r\n if (connection != null) {\r\n try {\r\n connection.close();\r\n }\r\n catch (JMSException jmsex) {\r\n System.out.println(\"Connection could not be closed.\");\r\n processJMSException(jmsex);\r\n }\r\n }\r\n }\r\n\r\n // We're finished.\r\n System.out.println(\"\\nSample execution SUCCESSFUL.\\n\");\r\n\r\n return;\r\n }",
"private int consumeElement(int index) throws InterruptedException {\n\t while (sharedBuffer.isEmpty()) {\r\n\t synchronized (sharedBuffer) {\r\n\t \tString msg=\"Queue is empty \" + Thread.currentThread().getName()\r\n + \" is waiting , size: \" + sharedBuffer.size();\r\n\t \t\r\n\t // \t System.out.println(msg);\r\n\t\t writeLn(msg);\r\n\r\n\t sharedBuffer.wait();\r\n\t \r\n\t }\r\n\t }\r\n\r\n\t // Consume data from Buffer and Notify Producer that Data has been consumed from Buffer\r\n\t synchronized (sharedBuffer) {\r\n\t \tsharedBuffer.notifyAll();\r\n\t \t\r\n\t return (Integer) sharedBuffer.poll();\r\n\t }\r\n\t }",
"public synchronized void consume() {\n\t\t// We only want one consumer thread running...\n\t\tif (consumerThread == null) {\n\t\t\tconsumerThread = new ConsumerThread();\n\t\t\t(new Thread(consumerThread)).start();\n\t\t}\n\t}",
"private void publish(PubMsg pubMsg, ChannelHandlerContext ctx) {\n //获取topic订阅者id列表\n String topic = pubMsg.getTopic();\n List<ClientSub> clientList = subscriptionService.searchSubscribeClientList(topic);\n\n //遍历发送\n clientList.forEach(clientSub -> {\n final String clientId = clientSub.getClientId();\n\n //计算Qos\n int pubQos = pubMsg.getQoS();\n int subQos = clientSub.getQos();\n MqttQoS qos = subQos >= pubQos ? MqttQoS.valueOf(pubQos) : MqttQoS.valueOf(subQos);\n\n //组装PubMsg\n MqttPublishMessage mpm = MqttMessageBuilders.publish()\n .messageId(nextMessageId(ctx))\n .qos(qos)\n .topicName(topic)\n .retained(pubMsg.isRetain())\n .payload(Unpooled.wrappedBuffer(pubMsg.getPayload()))\n .build();\n if (qos == MqttQoS.EXACTLY_ONCE || qos == MqttQoS.AT_LEAST_ONCE) {\n publishMessageService.save(clientId, pubMsg);\n }\n\n //发送\n Optional.of(clientId)\n .map(ConnectHandler.clientMap::get)\n .map(BrokerHandler.channels::find)\n .ifPresent(channel -> channel.writeAndFlush(mpm));\n });\n }",
"public synchronized void sendMessage(KafkaMessage msg, String[] topic) {\r\n if (producer != null) {\r\n // Encode message\r\n JsonEncoder json = new JsonEncoder();\r\n\r\n\r\n //producer.beginTransaction(); //begin transactions\r\n try {\r\n for (int index = 0; index < topic.length; index++) {\r\n String encodedMsg = json.encode(msg);\r\n ProducerRecord<Long, String> record = new ProducerRecord<>(topic[index],\r\n encodedMsg);\r\n\r\n producer.send(record).get(); // (A??)-Synchronouse send.\r\n this.requests.mark();\r\n }\r\n //producer.commitTransaction();\r\n } catch (KafkaException e) {\r\n e.printStackTrace();\r\n } catch (InterruptedException e) {\r\n e.printStackTrace();\r\n } catch (ExecutionException e) {\r\n e.printStackTrace();\r\n }\r\n } else {\r\n System.out.println(\"ProducerContainer is not initialized for producer \" + this.ID);\r\n }\r\n }",
"private void receiveMessage() throws InterruptedException {\n Map<Integer, Integer> transTimeMap = new HashMap<>();\n for (int i = 0; i < incomingLinks.size(); i++) {\n int transTime= new Random().nextInt(11);\n transTimeMap.put(i, transTime);\n }\n\n // Sort the random transmission time for the message in the channel.\n List<Map.Entry<Integer, Integer>> timeInfo = new ArrayList<>(transTimeMap.entrySet());\n timeInfo.sort((t1, t2) -> t1.getValue() - t2.getValue());\n\n int time = 0;\n for(int i = 0; i < timeInfo.size(); i++) {\n int index = timeInfo.get(i).getKey();\n int value = timeInfo.get(i).getValue();\n\n // After transmission time units, receive the message.\n Thread.sleep((value - time) * timeUnit);\n time += value - time;\n Message message = incomingLinks.get(index).receive();\n\n\n if (message != null) {\n String type = message.type;\n if (type.equals(\"init\")) {\n // If the process receives a larger id, it let the sender as its parent and broadcast this new\n // max id to all its neighbor except for its new parent.\n if (this.maxId < message.maxId) {\n this.maxId = message.maxId;\n this.parent = message.uid;\n this.listOfChild.clear();\n broadcast(new Message(this.uid, this.maxId, \"init\"), this.parent);\n numOfAck = 0;\n //If the process receives a smaller id, it will reply the sender a nack message.\n } else {\n sendTo(new Message(this.uid, message.maxId, \"nack\"), message.uid);\n }\n } else if (type.equals(\"ack\")) {\n // After receiving the ack message, it adds the number of ack and let the sender as its child.\n if (this.maxId == message.maxId) {\n numOfAck++;\n listOfChild.add(message.uid);\n }\n } else if (type.equals(\"nack\")) {\n // After receiving the nack message, it adds the number of ack.\n if (this.maxId == message.maxId) {\n numOfAck++;\n }\n }\n }\n }\n checkResult();\n }",
"private synchronized boolean sendBatch() {\n if (fPending.isEmpty()) {\n return true;\n }\n\n final long nowMs = Clock.now();\n\n if (this.fHostSelector != null) {\n host = this.fHostSelector.selectBaseHost();\n }\n\n final String httpurl = MRConstants.makeUrl(host, fTopic, props.getProperty(DmaapClientConst.PROTOCOL),\n props.getProperty(DmaapClientConst.PARTITION));\n\n try {\n\n final ByteArrayOutputStream baseStream = new ByteArrayOutputStream();\n OutputStream os = baseStream;\n final String contentType = props.getProperty(DmaapClientConst.CONTENT_TYPE);\n if (contentType.equalsIgnoreCase(MRFormat.JSON.toString())) {\n JSONArray jsonArray = parseJSON();\n os.write(jsonArray.toString().getBytes());\n os.close();\n\n } else if (contentType.equalsIgnoreCase(CONTENT_TYPE_TEXT)) {\n for (TimestampedMessage m : fPending) {\n os.write(m.fMsg.getBytes());\n os.write('\\n');\n }\n os.close();\n } else if (contentType.equalsIgnoreCase(MRFormat.CAMBRIA.toString())\n || (contentType.equalsIgnoreCase(MRFormat.CAMBRIA_ZIP.toString()))) {\n if (contentType.equalsIgnoreCase(MRFormat.CAMBRIA_ZIP.toString())) {\n os = new GZIPOutputStream(baseStream);\n }\n for (TimestampedMessage m : fPending) {\n\n os.write((\"\" + m.fPartition.length()).getBytes());\n os.write('.');\n os.write((\"\" + m.fMsg.length()).getBytes());\n os.write('.');\n os.write(m.fPartition.getBytes());\n os.write(m.fMsg.getBytes());\n os.write('\\n');\n }\n os.close();\n } else {\n for (TimestampedMessage m : fPending) {\n os.write(m.fMsg.getBytes());\n\n }\n os.close();\n }\n\n final long startMs = Clock.now();\n if (ProtocolType.DME2.getValue().equalsIgnoreCase(protocolFlag)) {\n\n configureDME2();\n\n this.wait(5);\n if (fPending.peek() != null) {\n logSendMessage(fPending.size(), url + subContextPath, nowMs - fPending.peek().timestamp);\n }\n sender.setPayload(os.toString());\n String dmeResponse = sender.sendAndWait(5000L);\n\n logTime(startMs, dmeResponse);\n fPending.clear();\n return true;\n }\n\n if (ProtocolType.AUTH_KEY.getValue().equalsIgnoreCase(protocolFlag)) {\n if (fPending.peek() != null) {\n logSendMessage(fPending.size(), httpurl, nowMs - fPending.peek().timestamp);\n }\n final JSONObject result =\n postAuth(new PostAuthDataObject().setPath(httpurl).setData(baseStream.toByteArray())\n .setContentType(contentType).setAuthKey(authKey).setAuthDate(authDate)\n .setUsername(username).setPassword(password).setProtocolFlag(protocolFlag));\n // Here we are checking for error response. If HTTP status\n // code is not within the http success response code\n // then we consider this as error and return false\n if (result.getInt(JSON_STATUS) < 200 || result.getInt(JSON_STATUS) > 299) {\n return false;\n }\n logTime(startMs, result.toString());\n fPending.clear();\n return true;\n }\n\n if (ProtocolType.AAF_AUTH.getValue().equalsIgnoreCase(protocolFlag)) {\n if (fPending.peek() != null) {\n logSendMessage(fPending.size(), httpurl, nowMs - fPending.peek().timestamp);\n }\n final JSONObject result = post(httpurl, baseStream.toByteArray(), contentType, username, password,\n protocolFlag);\n\n // Here we are checking for error response. If HTTP status\n // code is not within the http success response code\n // then we consider this as error and return false\n if (result.getInt(JSON_STATUS) < 200 || result.getInt(JSON_STATUS) > 299) {\n return false;\n }\n logTime(startMs, result.toString());\n fPending.clear();\n return true;\n }\n\n if (ProtocolType.HTTPNOAUTH.getValue().equalsIgnoreCase(protocolFlag)) {\n if (fPending.peek() != null) {\n logSendMessage(fPending.size(), httpurl, nowMs - fPending.peek().timestamp);\n }\n final JSONObject result = postNoAuth(httpurl, baseStream.toByteArray(), contentType);\n\n // Here we are checking for error response. If HTTP status\n // code is not within the http success response code\n // then we consider this as error and return false\n if (result.getInt(JSON_STATUS) < 200 || result.getInt(JSON_STATUS) > 299) {\n return false;\n }\n logTime(startMs, result.toString());\n fPending.clear();\n return true;\n }\n } catch (InterruptedException e) {\n getLog().warn(\"Interrupted!\", e);\n // Restore interrupted state...\n Thread.currentThread().interrupt();\n } catch (Exception x) {\n getLog().warn(x.getMessage(), x);\n }\n return false;\n }",
"private void dequeueMessages()\n\t{\n\t\twhile (_msg_queue.size() > 0)\n\t\t{\n\t\t\ttry\n\t\t\t{\n\t\t\t\t_ml.messageReceived( (Serializable) _msg_queue.removeFirst());\n\t\t\t}\n\t\t\tcatch (RuntimeException rte)\n\t\t\t{\n\t\t\t\trte.printStackTrace();\n\t\t\t}\n\t\t}\n\t}",
"@Override\n public void flush() {\n new QueueConsumer().run();\n }",
"@Override\n public void handleDelivery(String consumerTag, Envelope envelope,\n AMQP.BasicProperties properties, byte[] body) throws IOException \n {\n try\n {\n Object obj = getObjectForBytes(body);\n json = returnJson(obj);\n System.out.println(\"The json is \"+json.toString());\n \n } catch (ClassNotFoundException ex)\n {\n Logger.getLogger(JsonTranslator.class.getName()).log(Level.SEVERE, null, ex);\n }finally \n {\n System.out.println(\" [x] Done\");\n publishJsonData();//VERY INOVATIVE\n //DDO NOT KILL THE \n // channel.basicAck(envelope.getDeliveryTag(), false);\n }\n \n }",
"@Override\n public BytesMessage provideMessage(long msgCounter) throws JMSException {\n return (BytesMessage) createMessage();\n }",
"public void handle(QueueItem<T>[] events, SyncProducer producer, Encoder<T> encoder) throws Exception;",
"void startPCT(){\n int i=0;\n int j=0;\n// System.out.print(\"Number of Producers: \"+numOfProducers+\n// \", Number of Consumers \"+numOfConsumers+\", \");\n _myBuffer.PrintStatus();\n// System.out.println(\"Producers priority = \"+_prodPriority+\n// \", Consumers priority = \"+_consPriority);\n// System.out.println(\"Starting the program :\");\n// System.out.println(\"----------------------\");\n while (i<numOfProducers || j<numOfConsumers){\n if (i<numOfProducers) {\n //System.out.println(\"Starting producer \"+i);\n threadProducer[i].start();\n }\n if (j<numOfConsumers) {\n threadConsumer[j].start();\n //System.out.println(\"Starting consumer \"+i);\n }\n i++;\n if (i<numOfProducers) {\n threadProducer[i].start();\n //System.out.println(\"Starting producer \" +i);\n }\n i++;\n j++;\n }\n }",
"private MQTTopicManager() {\n for(Integer counter=1;counter!=Short.MAX_VALUE;counter++){\n messageIdList.add(counter);\n }\n }",
"@Override\n public void update() {\n String msg = (String) topic.getUpdate(this);\n if(msg == null){\n System.out.println(this.imeRonioca + \" no new messages\");\n }else{\n System.out.println(this.imeRonioca + \" consuming message: \" + msg);\n }\n }",
"public void produce() throws InterruptedException {\n int hydrogenCount = 0;\n int oxygenCount = 0;\n while (true) {\n synchronized (this) {\n // producer thread waits while list\n // is full\n while (hydrogen.size() == capacity || (hydrogen.size() >= 2 && oxygen.size() >= 1))\n wait();\n\n hydrogenCount += 2;\n oxygenCount++;\n\n System.out.println(\"Hydrogen produced-\"\n + hydrogenCount);\n\n System.out.println(\"Oxygen produced-\"\n + oxygenCount);\n // to insert the jobs in the list\n hydrogen.add(hydrogenCount);\n oxygen.add(oxygenCount);\n\n // notifies the consumer thread that\n // now it can start consuming\n notify();\n\n\n Thread.sleep(5000);\n }\n }\n }",
"@SuppressWarnings({ \"rawtypes\", \"unchecked\" })\n\tprivate void deliver(Message m) {\n List<Consumer> listOfSpecificConsumers =\n manager.getConsumerManager().getConsumersFor(m.getContent().getClass());\n for (Consumer consumer : listOfSpecificConsumers) {\n \tConsumerManagementInfo info = manager.getConsumerManager().getManagementInfo(consumer);\n \tif ( info.canReceive(m) ) {\n \t\tconsumer.consume(m.getContent());\n \t}\n }\n if ( listOfSpecificConsumers.size() > 1 ) {\n \tassert Logger.info(this, \"Dispatched object to \" + listOfSpecificConsumers.size() + \" consumers\");\n }\n\n }",
"public void initializeConsumerProducer(int queueSize) {\n\n trainSignal = false;\n if (radioDataSet.isSelected()) {\n consumer = new DataSetConsumer(jmeVisualization);\n producer = new DataSetProducer(neuralNetAndDataSet);\n }\n if (radioWeights.isSelected()) {\n consumer = new NeuralNetworkWeightsConsumer(jmeVisualization);\n producer = new NeuralNetworkWeightsProducer(neuralNetAndDataSet);\n }\n\n /*\n Instantiate producerConsumer and start consuming(drawing)\n */\n consumerProducer = new ConsumerProducer(queueSize);\n consumerProducer.setConsumer(consumer);\n consumerProducer.setProducer(producer);\n\n consumerProducer.startConsuming();\n\n }",
"private void initializeSlotMapForQueue() throws AndesException, ConnectionException {\n int databaseReadsCounter = 0;\n int restoreMessagesCounter = 0;\n long messageCountOfQueue = messageStore.getMessageCountForQueue(queueName);\n\n LongArrayList messageIdList = messageStore.getNextNMessageIdsFromQueue(queueName, 0, slotSize);\n int numberOfMessages = messageIdList.size();\n\n databaseReadsCounter++;\n restoreMessagesCounter = restoreMessagesCounter + messageIdList.size();\n\n long lastMessageID;\n long firstMessageID;\n long lastStatPublishTime = System.currentTimeMillis();\n\n while (numberOfMessages > 0) {\n int lastMessageArrayIndex = numberOfMessages - 1;\n lastMessageID = messageIdList.get(lastMessageArrayIndex);\n firstMessageID = messageIdList.get(0);\n\n if (log.isDebugEnabled()) {\n log.debug(\"Created a slot with \" + messageIdList.size() + \" messages for queue (\" + queueName + \")\");\n }\n\n if (AndesContext.getInstance().isClusteringEnabled()) {\n SlotManagerClusterMode.getInstance().updateMessageID(queueName,\n AndesContext.getInstance().getClusterAgent().getLocalNodeIdentifier(), firstMessageID,\n lastMessageID, lastMessageID);\n } else {\n SlotManagerStandalone.getInstance().updateMessageID(queueName, lastMessageID);\n }\n\n long currentTimeInMillis = System.currentTimeMillis();\n if (currentTimeInMillis - lastStatPublishTime > STAT_PUBLISHING_INTERVAL) {\n // messageCountOfQueue is multiplied by 1.0 to convert it to double\n double recoveredPercentage = (restoreMessagesCounter / (messageCountOfQueue * 1.0)) * 100.0;\n log.info(restoreMessagesCounter + \"/\" + messageCountOfQueue + \" (\" + Math.round(recoveredPercentage)\n + \"%) messages recovered for queue \\\"\" + queueName + \"\\\"\");\n lastStatPublishTime = currentTimeInMillis;\n }\n\n // We need to increment lastMessageID since the getNextNMessageMetadataFromQueue returns message list\n // including the given starting ID.\n messageIdList = messageStore.getNextNMessageIdsFromQueue(queueName, lastMessageID + 1, slotSize);\n numberOfMessages = messageIdList.size();\n //increase value of counters\n databaseReadsCounter++;\n restoreMessagesCounter = restoreMessagesCounter + messageIdList.size();\n }\n\n log.info(\"Recovered \" + restoreMessagesCounter + \" messages for queue \\\"\" + queueName + \"\\\" using \"\n + databaseReadsCounter + \" database calls\");\n }",
"@Test\n public void testConsumerAccessExceptionDuringBatchRun() throws ExecutionException, InterruptedException {\n List<Chunk> chunkList = new ArrayList<>();\n //generate chunks\n int numOfChunksToUpload = 1000;\n while (numOfChunksToUpload > 0) {\n chunkList.add(generateChunk(10));\n numOfChunksToUpload--;\n }\n\n //Start a producer thread\n ExecutorService executorService = Executors.newFixedThreadPool(2);\n ProducerThread producerThread = new ProducerThread(\"Producer1\", chunkList, 20, new ApplicationService());\n Future<String> producerResult = executorService.submit(producerThread);\n //Wait for batch run to start\n Thread.sleep(10);\n //Start a consumer thread in parallel\n Future<String> result = executorService.submit(new ConsumerThread(\"Consumer1\", 1, new ApplicationService()));\n //Consumer threads gets null value of instrument id price\n assertNull(result.get());\n log.info(\"Producer result:\" + producerResult.get());\n\n }",
"@Override\n\tpublic void run() {\n\t\ttry {\n\t\t\tproduce();\n\t\t} catch (InterruptedException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public static void main(String[] args) {\n KafkaConfig kafkaConfig = KafkaUtil.getKafkaConfig();\n System.out.println(kafkaConfig.toString());\n\n // push data to kafka\n SavedState savedState = new SavedState();\n\n producers = new HashMap<Priority, KafkaProducer<String, String>>() {\n {\n put(Priority.MAX_PRIORITY, KafkaUtil.initProducer());\n put(Priority.MEDIUM_PRIORITY, KafkaUtil.initProducer());\n put(Priority.MIN_PRIORITY, KafkaUtil.initProducer());\n }\n };\n\n // create thread for consumer\n executor = Executors.newFixedThreadPool(3);\n executor.execute(new MaxPriorityThread(savedState));\n executor.execute(new MediumPriorityThread(savedState));\n executor.execute(new MinPriorityThread(savedState));\n executor.shutdown();\n\n Random random = new Random();\n for (int i = 0; i <= 10; ++i) {\n int rand = i; // random.nextInt(6);\n logger.info(\"Random number is: \" + rand);\n\n\n if (rand % 2 == 0) {\n String maxPriority = Priority.MAX_PRIORITY.getNameTopic();\n logger.info(\"Topic of max priority is: \" + maxPriority);\n ProducerRecord<String, String> record = new ProducerRecord<>(Priority.MAX_PRIORITY.getNameTopic(), String.valueOf(rand));\n logger.info(\"Data is sent to Max Priority Thread: \" + record.value());\n producers.get(Priority.MAX_PRIORITY).send(record);\n } else if (rand % 3 == 0) {\n String mediumPriority = Priority.MEDIUM_PRIORITY.getNameTopic();\n logger.info(\"Topic of medium priority is: \" + mediumPriority);\n ProducerRecord<String, String> record = new ProducerRecord<>(Priority.MEDIUM_PRIORITY.getNameTopic(), String.valueOf(rand));\n logger.info(\"Data is sent to Medium Priority Thread: \" + record.value());\n producers.get(Priority.MEDIUM_PRIORITY).send(record);\n } else if (rand % 5 == 0) {\n String minPriority = Priority.MIN_PRIORITY.getNameTopic();\n logger.info(\"Topic of min priority is: \" + minPriority);\n ProducerRecord<String, String> record = new ProducerRecord<>(Priority.MIN_PRIORITY.getNameTopic(), String.valueOf(rand));\n logger.info(\"Data is sent to Min Priority Thread: \" + record.value());\n producers.get(Priority.MIN_PRIORITY).send(record);\n }\n }\n }",
"public static void main(String[] args) throws ExecutionException, InterruptedException {\n String topicName = \"mockProducerTopic1\";\n MockProducer<String,String> mockProducer = new MockProducer<String,String>(true, new DefaultPartitioner(),new StringSerializer(),new StringSerializer());\n\n String KEY=\"\";\n for(int i=1;i<=10;i++) {\n KEY= i%2 == 0 ? \"CS\" : \"IT\";\n ProducerRecord<String, String> record = new ProducerRecord<>(\"mockProducerTopic1\", KEY, \"value\"+i);\n Future<RecordMetadata> metadata = mockProducer.send(record);\n System.out.println(\"Topic : \" + metadata.get().topic() + \", Partition : \" + metadata.get().partition() + \", Offset : \" + metadata.get().offset() + \", TimeStamp : \" + metadata.get().hasTimestamp());\n //System.out.println(\"Topic : \" + metadata.topic() + \", Partition : \" + metadata.partition() + \", Offset : \" + metadata.offset() + \", TimeStamp : \" + metadata.timestamp());\n\n }\n\n System.out.println(\"Topic Partitions Details : \" + mockProducer.partitionsFor(\"mockProducerTopic1\"));\n for(int i=0;i<mockProducer.history().size();i++)\n {\n System.out.println(\"Topic : \"+ mockProducer.history().get(i).topic()+ \", Key : \" + mockProducer.history().get(i).key()\n + \", Value : \"+mockProducer.history().get(i).value() );\n }\n\n mockProducer.clear();\n mockProducer.close();\n }",
"public interface MessageBroker {\n\n /**\n * Polls for the next message available in the topic of given name.\n * If there are no messages available, the method will block until\n * message becomes available or until timeout is reached, whichever\n * comes first. If timeout is zero, the method returns without\n * blocking.\n *\n * The consumed messages should be acknowledged once they were\n * successfully processed.\n *\n * @param topicName Name of topic to poll.\n * @param timeout Time to wait for next message in case it is not\n * immediately available.\n *\n * @return Message or null, if there was no message available and\n * timeout expired.\n *\n * @throws IOException When it wasn't possible to communicate with\n * the broker.\n */\n Message poll(String topicName, Duration timeout) throws IOException;\n\n\n /**\n * Marks message with given ID as processed, so that it won't be\n * made visible to other topic consumers ore reprocessed. If message won't be\n * marked as processed before timeout expires, the message will become\n * available for consumption for other consumers.\n *\n * @param topicName The topic of the message.\n * @param partition The partition the message was read from.\n * @param offset The offset of the message within the partition.\n * @throws IOException When it wasn't possible to communicate with\n * * the broker.\n *\n * @see Message#getPartition()\n * @see Message#getOffset()\n */\n void acknowledge(String topicName, int partition, long offset) throws IOException;\n\n /**\n * Publishes the message to another topic.\n *\n * @param topicName The name of the other topic.\n * @param message The message to publish.\n * @throws IOException If there were any problems. The message might not have been published.\n */\n void publish(String topicName, Message message) throws IOException;\n}",
"private ObservableOnSubscribe<Object> receiveLoop() {\n return emitter -> {\n Message message;\n try {\n while ( ( message = consumer.receive( jmsDelegate.receiveTimeout ) ) != null ) {\n streamStep.logDebug( message.toString() );\n emitter.onNext( message.getBody( Object.class ) );\n }\n } catch ( JMSRuntimeException jmsException ) {\n emitter.onError( jmsException );\n }\n emitter.onComplete();\n };\n }",
"@Override\n public byte[] provide() {\n long start = System.nanoTime();\n\n try {\n if (packetQueue.peek() == null) {\n underflowed ++;\n return new byte[0];\n }\n\n OpusPacket packet = packetQueue.remove();\n\n if (packet == null) {\n underflowed ++;\n return new byte[0];\n }\n\n availableInput += packet.getSamples();\n opusBytePosition += packet.getBytes().length;\n opusPacketsSent ++;\n\n return packet.getBytes();\n } catch (NoSuchElementException ex) {\n underflowed ++;\n return new byte[0];\n } finally {\n long networkTime = System.nanoTime() - start;\n\n if (networkTime >= (opusParameters.getOpusFrameTime() * 1000000L)) {\n underflowed++;\n\n Logger.getGlobal().warning(\"[TeamspeakFastMixerSink] provide() took longer than the expected \" +\n opusParameters.getOpusFrameTime() + \"ms: \" + ((double)networkTime / 1_000_000D) + \"ms\");\n }\n\n this.networkTime += networkTime;\n\n if (packetQueue.peek() == null) {\n synchronized (drainLock) {\n drainLock.notifyAll();\n }\n }\n }\n }",
"public void consume() throws InterruptedException {\n\n\t\tRandom random = new Random();\n\t\twhile (true) {\n\t\t\tsynchronized (lock) {\n\t\t\t\twhile (buffer.size() == 0) {\n\t\t\t\t\tlock.wait();\n\t\t\t\t}\n\n\t\t\t\tSystem.out.println(\"Consumed : \" + buffer.removeFirst());\n\t\t\t\tlock.notify();\n\n\t\t\t}\n\t\t\tThread.sleep(random.nextInt(1000));\n\t\t}\n\n\t}",
"public synchronized void consumeX() {\n while(!produced){\n try {\n wait();\n } catch (InterruptedException e) {\n e.printStackTrace();\n }\n }\n //its consuming now\n System.out.println(\"consumed \"+x);\n //after consumption, value is gone, so produced is false\n produced = false;\n // producer to be notified to start production\n notify();\n\n }",
"protected void emitBatch(){\n synchronized(this){\n\n revokeSendBatch();\n\n int viewn = getCurrentViewNumber();\n long seqn = getStateLog().getNextPrePrepareSEQ();\n\n PBFTRequestInfo rinfo = getRequestInfo();\n if(!rinfo.hasSomeWaiting()){\n return;\n }\n /* creates a new pre-prepare message */\n PBFTPrePrepare pp = null;\n\n int size = 0;\n\n /* while has not achieved the batch size and there is digests in queue */\n String digest = null;\n while(size < getBatchSize() && (digest = rinfo.getFirtRequestDigestWaiting())!= null){\n if(pp == null){\n pp = new PBFTPrePrepare(viewn, seqn, getLocalServerID());\n }\n pp.getDigests().add(digest);\n rinfo.assign(digest, RequestState.PREPREPARED);\n size += 1;//rinfo.getRequestSize(digest);\n }\n\n if(pp == null){\n return;\n }\n \n /* emits pre-prepare */\n emitPrePrepare(pp);\n //emit(pp, getLocalGroup().minus(getLocalProcess()));\n\n /* update log current pre-prepare */\n handle(pp);\n\n /* if there is digest then it will schedule a send batch */\n if(rinfo.hasSomeWaiting()){\n batch();\n }//end if digest queue is no empty\n\n }//end synchronized(this)\n }",
"@Test\n public void when_wmOnSingleQueueOnly_then_emittedAfterDelay_multipleWm() {\n for (int time = 0; time < 40; time++) {\n add(q1, wm(100 + time));\n Object[] expectedItems = time < 16 ? new Object[0] : new Object[]{wm(time + 100 - 16)};\n drainAndAssert(time, MADE_PROGRESS, expectedItems);\n }\n }",
"@Override\n public void configure() {\n\n final GroupedMessageAggregationStrategy groupedMessageAggregationStrategy = new GroupedMessageAggregationStrategy();\n final SizeAwareAggregationStrategy aggregationStrategy = new SizeAwareAggregationStrategy(groupedMessageAggregationStrategy);\n final AggregatedSizeCompletionPredicate completionPredicate = new AggregatedSizeCompletionPredicate(MAX_SIZE, aggregationStrategy);\n\n // @formatter:off\n\n from(\"timer:TIMER_1?period=1\")\n .bean(PersonProducer.class)\n .setHeader(GROUP, () -> RANDOM.nextInt(1))\n .marshal().json(Jackson)\n .to(\"seda:persons\")\n ;\n\n from(\"seda:persons?concurrentConsumers=5\")\n .aggregate()\n .header(GROUP)\n .aggregationStrategy(aggregationStrategy)\n .completionPredicate(completionPredicate)\n .parallelProcessing()\n .bean(ResultsPrinter.class)\n ;\n\n // @formatter:on\n }",
"@Test\n\tpublic final void testMessageQueueFlushTest() {\n\t\tfinal int count = 10000;\n\t\tIMessageSourceProvider source = new MessageSourceProvider();\n\t\tIMessengerPacket[] batch = new IMessengerPacket[count];\n\t\tfor (int i = 0; i < count; i++) {\n\t\t\tbatch[i] =Log.makeLogPacket(LogMessageSeverity.VERBOSE, \"GibraltarTest\",\n\t\t\t\t\t\"Test.Core.LogMessage.Performance.Flush\", source, null, null, null, null, null, \"Batch message #%s of %s\", i, count);\n\t\t}\n\n\t\tLog.write(LogMessageSeverity.INFORMATION, LogWriteMode.WAIT_FOR_COMMIT, null, \"Unit Tests\",\n\t\t\t\t\"Clearing message queue\", null);\n\n\t\tOffsetDateTime startWrite = OffsetDateTime.now();\n\n\t\tLog.write(batch, LogWriteMode.QUEUED);\n\n\t\tOffsetDateTime startFlush = OffsetDateTime.now();\n\n\t\tLog.write(LogMessageSeverity.INFORMATION, LogWriteMode.WAIT_FOR_COMMIT, null, \"Unit Tests\",\n\t\t\t\t\"Message batch flushed\", \"All %s messages have been flushed.\", count);\n\n\t\tOffsetDateTime endFlush = OffsetDateTime.now();\n\n\t\tDuration writeDuration = Duration.between(startWrite, startFlush);\n\t\tDuration flushDuration = Duration.between(startFlush, endFlush);\n\n\t\tLog.write(LogMessageSeverity.VERBOSE, \"\", \"Unit test messageQueueFlushTest()\",\n\t\t\t\t\"Write of {0:N0} messages to queue took {1:F3} ms and flush took {2:F3} ms.\", count,\n\t\t\t\twriteDuration.toMillis(), flushDuration.toMillis());\n\n\t\tfor (int i = 0; i < count; i++) {\n\t\t\tbatch[i] = Log.makeLogPacket(LogMessageSeverity.VERBOSE, \"GibraltarTest\",\n\t\t\t\t\t\"Test.Core.LogMessage.Performance.Flush\", source, null, null, null, null, null,\n\t\t\t\t\t\"Batch message #%s of %s\", i, count);\n\t\t}\n\n\t\tOffsetDateTime startWriteThrough = OffsetDateTime.now();\n\n\t\tLog.write(batch, LogWriteMode.WAIT_FOR_COMMIT);\n\n\t\tOffsetDateTime endWriteThrough = OffsetDateTime.now();\n\n\t\tDuration writeThroughDuration = Duration.between(startWriteThrough, endWriteThrough);\n\n\t\tLog.write(LogMessageSeverity.VERBOSE, \"\", \"Unit test messageQueueFlushTest()\",\n\t\t\t\t\"Write of {0:N0} messages as WaitForCommit took {1:F3} ms.\", count, writeThroughDuration.toMillis());\n\n\t}",
"private int doWriteMultiple(ChannelOutboundBuffer in) throws Exception {\n/* 515 */ long maxBytesPerGatheringWrite = config().getMaxBytesPerGatheringWrite();\n/* 516 */ if (PlatformDependent.hasUnsafe()) {\n/* 517 */ IovArray array = ((EpollEventLoop)eventLoop()).cleanArray();\n/* 518 */ array.maxBytes(maxBytesPerGatheringWrite);\n/* 519 */ in.forEachFlushedMessage((ChannelOutboundBuffer.MessageProcessor)array);\n/* */ \n/* 521 */ if (array.count() >= 1)\n/* */ {\n/* 523 */ return writeBytesMultiple(in, array);\n/* */ }\n/* */ } else {\n/* 526 */ ByteBuffer[] buffers = in.nioBuffers();\n/* 527 */ int cnt = in.nioBufferCount();\n/* 528 */ if (cnt >= 1)\n/* */ {\n/* 530 */ return writeBytesMultiple(in, buffers, cnt, in.nioBufferSize(), maxBytesPerGatheringWrite);\n/* */ }\n/* */ } \n/* */ \n/* 534 */ in.removeBytes(0L);\n/* 535 */ return 0;\n/* */ }",
"protected abstract void sendMessage(UUID[] players, BaseComponent[][] messages, IntConsumer response);",
"long incrementInMsgs() {\n return inMsgs.incrementAndGet();\n }",
"public Producer(int numOfConsumers) {\n this.consumerList = new RecordConsumer[numOfConsumers];\n for (int i = 0; i < numOfConsumers; i++) {\n consumerList[i] = new RecordConsumer();\n new Thread(consumerList[i]).start();\n }\n }",
"@Bean\n public MessageProducer inboundMessageHandler() {\n MqttPahoMessageDrivenChannelAdapter adapter =\n new MqttPahoMessageDrivenChannelAdapter(UUID.randomUUID().toString(), mqttPahoClientFactory.get(), \"/newsMessage/notify\");\n adapter.setCompletionTimeout(5000);\n adapter.setConverter(new JSONMqttMessageConvertor(NewsMessage.class));\n adapter.setQos(1);\n adapter.setOutputChannel(mqttEventHandlerInputChannel);\n return adapter;\n }"
]
| [
"0.70083934",
"0.66992074",
"0.6673492",
"0.6660283",
"0.6575914",
"0.63005906",
"0.609361",
"0.60611117",
"0.6006048",
"0.596468",
"0.5959792",
"0.5935346",
"0.593206",
"0.5896492",
"0.5894595",
"0.586372",
"0.58589196",
"0.58524597",
"0.58296216",
"0.5806432",
"0.5804028",
"0.5794284",
"0.5787117",
"0.57657415",
"0.5757765",
"0.5752259",
"0.57435876",
"0.57325304",
"0.57280475",
"0.57271606",
"0.57182044",
"0.5707476",
"0.5703731",
"0.57021886",
"0.56991935",
"0.5691595",
"0.56859493",
"0.5684348",
"0.56796235",
"0.56700575",
"0.56681573",
"0.5656991",
"0.565616",
"0.5651921",
"0.5648321",
"0.564459",
"0.56424904",
"0.56424904",
"0.5641522",
"0.56399786",
"0.5633726",
"0.56291014",
"0.5622293",
"0.56145304",
"0.5594348",
"0.55916226",
"0.5591341",
"0.5581437",
"0.5581263",
"0.55799615",
"0.55725294",
"0.557089",
"0.55602497",
"0.5554479",
"0.5553405",
"0.552686",
"0.5523616",
"0.55119544",
"0.55017245",
"0.5493781",
"0.54934096",
"0.5482693",
"0.5465689",
"0.5465512",
"0.54596066",
"0.54548955",
"0.5453063",
"0.5430506",
"0.5416331",
"0.54078597",
"0.5405277",
"0.5405254",
"0.5402143",
"0.53994334",
"0.53988194",
"0.5395289",
"0.5393085",
"0.5391939",
"0.539188",
"0.5390119",
"0.53886527",
"0.5388164",
"0.53849083",
"0.5379607",
"0.5377807",
"0.53744614",
"0.5372859",
"0.5370615",
"0.53654915",
"0.5361329",
"0.5354379"
]
| 0.0 | -1 |
onCreate method to display specific job on creation | @Override
protected void onCreate(Bundle savedInstanceState) {
super.onCreate(savedInstanceState);
setContentView(R.layout.activity_sitter_page);
jobType = getIntent().getStringExtra("jobType");
setjobList();
allJobsList();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\r\n\tprotected void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\r\n\t\tsetContentView(R.layout.activity_job_details);\r\n\t\tinit();\r\n\t\tgetData();\r\n\t\t\r\n\t}",
"@Override\n\tprotected void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\n\t\tsetContentView(R.layout.activity_updatejob);\n\t\t\n\t\tinitView();\n\t\tinitData();\n\t\tinitAction();\n\t}",
"@Override\n\tpublic void onCreate(Bundle savedInstanceState) {\n\t super.onCreate(savedInstanceState);\n\t setContentView(R.layout.activity_event_history);\n\t Bundle bundle = getIntent().getExtras();\n\t mSelectedSprint = (Sprint) bundle.getParcelable(Sprint.CURRENT_SPRINT);\n\t mEventLayout = (LinearLayout) findViewById(R.id.events_layout);\n\t mRes = getResources();\n\t ActionBar actionBar = getActionBar();\n\t actionBar.setBackgroundDrawable(getResources().getDrawable(R.drawable.action_bar_orange));\n\t actionBar.setTitle(getString(R.string.event_history));\n\t \n\t new LoadPlansTask(this).execute();\n\t}",
"@Override\n public void onClick(View v) {\n Intent intent = new Intent(UIJobOfferEditor.this, UIResultDisplay.class);\n AsyncTask.execute(new Runnable() {\n @Override\n public void run() {\n // Make sure hashtable gets filled\n CompareService.getRankedJobStrings();\n\n // get current job\n current = DataHandler.GetDataHandlerInstance().GetCurrentJob();\n String formattedComp =\n JOB.title + \" | \" + current.title + \"\\n\" +\n JOB.currentJob + \" | \" + current.currentJob + \"\\n\" +\n JOB.company + \" | \" + current.company + \"\\n\" +\n JOB.city + \" | \" + current.city + \"\\n\" +\n JOB.state + \" | \" + current.state + \"\\n\" +\n JOB.yearlySalary + \" | \" + current.yearlySalary + \"\\n\" +\n JOB.yearlyBonus + \" | \" + current.yearlyBonus + \"\\n\" +\n JOB.teleworkDaysPerWeek + \" | \" + current.teleworkDaysPerWeek + \"\\n\" +\n JOB.retirementBenefit + \" | \" + current.retirementBenefit + \"\\n\" +\n JOB.leaveTime + \" | \" + current.leaveTime;\n intent.putExtra(\"job1\", JOB.title + \", \" + JOB.company);\n intent.putExtra(\"job2\", current.title + \", \" + current.company);\n startActivity(intent);\n }\n });\n }",
"@Override\n public void run() {\n CompareService.getRankedJobStrings();\n\n // get current job\n current = DataHandler.GetDataHandlerInstance().GetCurrentJob();\n String formattedComp =\n JOB.title + \" | \" + current.title + \"\\n\" +\n JOB.currentJob + \" | \" + current.currentJob + \"\\n\" +\n JOB.company + \" | \" + current.company + \"\\n\" +\n JOB.city + \" | \" + current.city + \"\\n\" +\n JOB.state + \" | \" + current.state + \"\\n\" +\n JOB.yearlySalary + \" | \" + current.yearlySalary + \"\\n\" +\n JOB.yearlyBonus + \" | \" + current.yearlyBonus + \"\\n\" +\n JOB.teleworkDaysPerWeek + \" | \" + current.teleworkDaysPerWeek + \"\\n\" +\n JOB.retirementBenefit + \" | \" + current.retirementBenefit + \"\\n\" +\n JOB.leaveTime + \" | \" + current.leaveTime;\n intent.putExtra(\"job1\", JOB.title + \", \" + JOB.company);\n intent.putExtra(\"job2\", current.title + \", \" + current.company);\n startActivity(intent);\n }",
"@Override\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\n Bundle savedInstanceState) {\n fileNameList = new ArrayList<String>();\n RequestJobDetail jobDetail = new RequestJobDetail();\n jobDetail.jobId = ((ResponseCompletedJobs) job).getJobId();\n jobDetail.agentId = ((ResponseCompletedJobs) job).getAgentId();\n NetworkController.getInstance().getJobDetail(jobDetail);\n return inflater.inflate(R.layout.fragment_job_wall_detail, container, false);\n }",
"public void goToViewJob(SittingJob job) {\n setContentView(R.layout.activity_view_job);\n currentJob = job;\n Log.w(\"MA\", \"goToViewJob\");\n populateViewJob();\n }",
"@Override\r\n\tpublic void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\r\n\t\ttaskId=getArguments().getInt(\"taskId\");\r\n\t\ttask=DBAccessImpl.getInstance(getActivity()).describeTask(taskId);\r\n\t\tself=this;\r\n\t\ttaskMgr=new TaskMgr(getActivity());\r\n\t\tthis.setStyle(DialogFragment.STYLE_NO_TITLE, 0);\r\n\t}",
"public static void EmployeeJob() {\r\n\t\t\r\n\t\tJLabel e4 = new JLabel(\"Employee's Job:\");\r\n\t\te4.setFont(f);\r\n\t\tGUI1Panel.add(e4);\r\n\t\tGUI1Panel.add(employeeJobType);\r\n\t\te4.setHorizontalAlignment(JLabel.LEFT);\r\n\t\tGUI1Panel.add(Box.createHorizontalStrut(5));\r\n\t}",
"@Override\n\tprotected void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\n\t\trequestWindowFeature(Window.FEATURE_NO_TITLE);\n\t\tsetContentView(R.layout.editjob);\n\n\n\t\tjobObjectfromback = (JobObject) getIntent().getSerializableExtra(\"Data\");\n\n\n\t\tcontext = this;\n\t\tfont=Typeface.createFromAsset(getAssets(), \"fonts/mark.ttf\");\n\t\tfont2=Typeface.createFromAsset(getAssets(), \"fonts/marlbold.ttf\");\n\t\timageloader11 = new ImageLoader11(context);\n\n\t\tfinal Calendar c = Calendar.getInstance();\n\t\tyear = c.get(Calendar.YEAR);\n\t\tmonth = c.get(Calendar.MONTH);\n\t\tday = c.get(Calendar.DAY_OF_MONTH);\n\n\t\tcreate_job_title = (EditText) findViewById(R.id.create_job_title);\n\t\tcreate_company_name = (EditText) findViewById(R.id.create_company_name);\n\t\tcreate_country_name = (EditText) findViewById(R.id.create_country_name);\n\t\tcreate_city_name = (EditText) findViewById(R.id.create_city_name);\n\t\tcreate_requirement = (EditText) findViewById(R.id.create_requirement);\n\t\tcreate_location = (EditText) findViewById(R.id.create_location);\n\t\tcreate_job_type = (EditText) findViewById(R.id.create_job_type);\n\t\tcreate_srart_date = (EditText) findViewById(R.id.create_srart_date);\n\t\tcreate_job_description = (EditText) findViewById(R.id.create_job_description);\n\t\tcreate_salary = (EditText) findViewById(R.id.create_salary);\n\t\tbtn_back = (ImageView) findViewById(R.id.btn_back);\n\t\tcreate_citizen_required = (TextView) findViewById(R.id.create_citizen_required);\n\t\tcreate_btn_draft = (Button) findViewById(R.id.create_btn_draft);\n\n\t\tcreate_btn_postjob = (Button) findViewById(R.id.create_btn_postjob);\n\t\tcitizenship_swich = (Switch) findViewById(R.id.citizenship_swich);\n\t\timage_layout = (RelativeLayout) findViewById(R.id.image_layout);\n\t\tteacher_photo = (ImageView)findViewById(R.id.teacher_photo);\n\t\ttop_header_count = (TextView)findViewById(R.id.top_header_count);\n\n\t\ttry {\n\t\t\tcreate_job_title.setTypeface(font);\n\t\t\tcreate_company_name.setTypeface(font);\n\t\t\tcreate_country_name.setTypeface(font);\n\t\t\tcreate_city_name.setTypeface(font);\n\t\t\tcreate_requirement.setTypeface(font);\n\t\t\tcreate_location.setTypeface(font);\n\t\t\tcreate_job_type.setTypeface(font);\n\t\t\tcreate_srart_date.setTypeface(font);\n\t\t\tcreate_job_description.setTypeface(font);\n\t\t\tcreate_salary.setTypeface(font);\n\t\t\ttop_header_count.setTypeface(font);\n\n\t\t\tcreate_btn_draft.setTypeface(font);\n\t\t\tcreate_btn_postjob.setTypeface(font);\n\n\t\t\tcreate_citizen_required.setTypeface(font);\n\n\t\t\t((TextView) findViewById(R.id.createheader)).setTypeface(font2);\n\n\t\t} catch (Exception e) {\n\n\t\t}\n\n\t\tString count= GlobalClaass.getHeader_Count(context);\n\n\t\tif(count != null){\n\n\t\t\tif(count.length() == 1){\n\t\t\t\ttop_header_count.setText(\" \"+count);\n\t\t\t}if(count.length() == 2){\n\t\t\t\ttop_header_count.setText(\" \"+count);\n\t\t\t}\n\t\t\telse {\n\t\t\t\ttop_header_count.setText(count);\n\t\t\t}\n\t\t}else {\n\t\t\ttop_header_count.setVisibility(View.GONE);\n\t\t}\n\n\n\n\t\tbtn_back.setOnClickListener(new OnClickListener() {\n\n\t\t\t@Override\n\t\t\tpublic void onClick(View arg0) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tGlobalClaass.activitySlideBackAnimation(context);\n\t\t\t\tfinish();\n\t\t\t}\n\t\t});\n\n\t\tteacher_photo.setOnClickListener(new OnClickListener() {\n\n\t\t\t@Override\n\t\t\tpublic void onClick(View arg0) {\n\t\t\t\t// TODO Auto-generated method stub\n\n\t\t\t\tselectImageMethod();\n\t\t\t}\n\n\n\n\t\t});\n\n\t\tcitizenship_swich.setOnCheckedChangeListener(new CompoundButton.OnCheckedChangeListener() {\n\t\t\tpublic void onCheckedChanged(CompoundButton buttonView, boolean isChecked) {\n\t\t\t\tif (isChecked) {\n\t\t\t\t\t// The toggle is enabled\n\t\t\t\t\teu_citizen_required = \"1\";\n\t\t\t\t} else {\n\t\t\t\t\t// The toggle is disabled\n\t\t\t\t\teu_citizen_required = \"0\";\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\n\t\tcreate_btn_postjob.setOnClickListener(new OnClickListener() {\n\n\t\t\t@Override\n\t\t\tpublic void onClick(View v) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tis_draft = \"1\";\n\t\t\t\tValidateValue();\n\n\t\t\t}\n\t\t});\n\n\t\tcreate_btn_draft.setOnClickListener(new OnClickListener() {\n\n\t\t\t@Override\n\t\t\tpublic void onClick(View v) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tis_draft = \"0\";\n\t\t\t\tValidateValue();\n\n\t\t\t}\n\t\t});\n\n\t\tif (com.chalkboard.GlobalClaass.isInternetPresent(context)) {\n\n\t\t\ttry {\n\t\t\t\tgps = new GPSTracker(context);\n\n\t\t\t\t// check if GPS enabled\n\t\t\t\tif (gps.canGetLocation()) {\n\n\t\t\t\t\tdouble latitude = gps.getLatitude();\n\t\t\t\t\tdouble longitude = gps.getLongitude();\n\n\t\t\t\t\tlati = latitude;\n\t\t\t\t\tlongi = longitude;\n\n\t\t\t\t\tloadservice = new LoadService(context,\n\t\t\t\t\t\t\tString.valueOf(lati), String.valueOf(longi));\n\t\t\t\t\tloadservice.execute();\n\n\t\t\t\t}else{\n\n\t\t\t\t\tloadservice = new LoadService(context,\n\t\t\t\t\t\t\t\"0\", \"0\");\n\t\t\t\t\tloadservice.execute();\n\t\t\t\t}\n\n\t\t\t} catch (Exception e) {\n\n\t\t\t}\n\t\t} else {\n\t\t\tcom.chalkboard.GlobalClaass.showToastMessage(context,\n\t\t\t\t\t\"Please check internet connection.\");\n\t\t}\n\n\t\tcreate_srart_date.setOnClickListener(new OnClickListener() {\n\n\t\t\t@SuppressWarnings(\"deprecation\")\n\t\t\t@Override\n\t\t\tpublic void onClick(View v) {\n\n\t\t\t\tshowDialog(DATE_PICKER_ID);\n\t\t\t}\n\t\t});\n\n\t\tcreate_job_type.setOnClickListener(new OnClickListener() {\n\n\t\t\t@Override\n\t\t\tpublic void onClick(View v) {\n\n\t\t\t\tIntent i = new Intent(context, JobTypeListActivity.class);\n\t\t\t\tstartActivityForResult(i, 2);\n\t\t\t}\n\t\t});\n\n\t\tcreate_country_name.setOnClickListener(new OnClickListener() {\n\n\t\t\t@Override\n\t\t\tpublic void onClick(View v) {\n\n\t\t\t\tIntent i = new Intent(context, CountryList_Activity.class);\n\t\t\t\tstartActivityForResult(i, 1);\n\t\t\t}\n\t\t});\n\n\t\ttry {\n\t\t\tcreate_job_title.setText(jobObjectfromback.getJobTitle());\n\t\t\tcreate_company_name.setText(jobObjectfromback.getJobRecruiterName());\n\t\t\tcreate_country_name.setText(jobObjectfromback.getJobCountry());\n\t\t\tcreate_city_name.setText(jobObjectfromback.getJobCity());\n\t\t\tcreate_location.setText(jobObjectfromback.getJobLocation());\n\t\t\tcreate_job_type.setText(\"Full Time\");\n\t\t\tcreate_srart_date.setText(jobObjectfromback.getJobStartdate());\n\t\t\tcreate_job_description.setText(jobObjectfromback.getJobDescription());\t\n\t\t\tcreate_salary.setText(jobObjectfromback.getJobSalary());\n\t\t\tcreate_requirement.setText(jobObjectfromback.getJobRecruiterAbout());\n\n\t\t\timageloader11.DisplayImage(jobObjectfromback.getJobImage(),\n\t\t\t\t\tteacher_photo);\n\n\t\t\tis_draft = jobObjectfromback.isIs_draft()+\"\";\n\n\t\t} catch (Exception e) {\n\n\t\t}\n\n\t}",
"public void showJobOverview() {\n try {\n // Load job overview.\n FXMLLoader loader = new FXMLLoader();\n loader.setLocation(MainApp.class.getResource(\"view/JobOverview.fxml\"));\n HBox jobOverview = loader.load();\n\n // Set job overview into the center of root layout.\n rootLayout.setCenter(jobOverview);\n\n // Give the controller access to the main app.\n JobOverviewController controller = loader.getController();\n controller.setMainApp(this);\n\n controller.print(\"* Hello! v1.00 * \\n\");\n\n } catch (IOException e) {\n e.printStackTrace();\n }\n }",
"public AutomaticJob() {\r\n \r\n }",
"public Job() {\r\n\t\tSystem.out.println(\"Constructor\");\r\n\t}",
"public JobManager(){\n //Initialize the job manager for use of the system\n }",
"private void initData() {\n\t\tIntent intent = getIntent();\n\t\tjob = (Job) intent.getSerializableExtra(\"job\");\n\t\tedt_content.setText(job.getJobContent());\n\t\tedt_course.setText(job.getCourseName());\n\t}",
"public void newTask() {\r\n\r\n todoTaskGui(\"Create\", null);\r\n }",
"@Override\n\tpublic void onCreate(SQLiteDatabase db) {\n\t\t\n\t\tString CREATE_JOBS_TABLE = \"CREATE TABLE IF NOT EXISTS\" + TABLENAME + \"( \"\n\t\t\t\t+ KEY_JOBID + \" TEXT NOT NULL PRIMARY KEY, \" \n\t\t\t\t+ KEY_COMPANY + \" TEXT NOT NULL, \"\n\t\t\t\t+ KEY_POSITION_DESC + \" TEXT NOT NULL, \"\n\t\t\t\t+ KEY_COMPANY + \" TEXT NOT NULL, \"\n\t\t\t\t+ KEY_JOBLOCATION + \" TEXT, \"\n\t\t\t\t+ KEY_EDUCATION_LEVEL + \" TEXT, \"\n\t\t\t\t+ KEY_CREATION_DATE + \" TEXT, \" //convert to Date, Data Type\n\t\t\t\t+ KEY_JOB_SOURCE + \" TEXT, \"\n\t\t\t\t+ KEY_HYPERLINK + \" TEXT, \"\n\t\t\t\t+ KEY_PUBLISH_DATE + \" TEXT);\";\n\t\tdb.execSQL(CREATE_JOBS_TABLE);\n\t\tdatabase = db;\n\t}",
"public JobInfo(Class<? extends Job> jobclass) {\n\t\tthis.jobclass = jobclass;\n\t}",
"private void initialiseView() {\n \tnoTasksMessageView = (TextView)findViewById(R.id.noTasksRunning);\r\n \ttaskKillWarningView = (TextView)findViewById(R.id.progressStatusMessage);\r\n\r\n \tIterator<Progress> jobsIterator = JobManager.iterator();\r\n \twhile (jobsIterator.hasNext()) {\r\n \t\tProgress job = jobsIterator.next();\r\n \t\tfindOrCreateUIControl(job);\r\n \t}\r\n\r\n // allow call back and continuation in the ui thread after JSword has been initialised\r\n \tfinal Handler uiHandler = new Handler();\r\n \tfinal Runnable uiUpdaterRunnable = new Runnable() {\r\n\t\t\t@Override\r\n\t\t\tpublic void run() {\r\n \t\t\tProgress prog = progressNotificationQueue.poll();\r\n \t\t\tif (prog!=null) {\r\n \t\t\t\tupdateProgress(prog);\r\n \t\t\t}\r\n\t\t\t}\r\n };\r\n\r\n // listen for Progress changes and call the above Runnable to update the ui\r\n\t\tworkListener = new WorkListener() {\r\n\t\t\t@Override\r\n\t\t\tpublic void workProgressed(WorkEvent ev) {\r\n\t\t\t\tcallUiThreadUpdateHandler(ev);\r\n\t\t\t}\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic void workStateChanged(WorkEvent ev) {\r\n\t\t\t\tcallUiThreadUpdateHandler(ev);\r\n\t\t\t}\r\n\t\t\tprivate void callUiThreadUpdateHandler(WorkEvent ev) {\r\n\t\t\t\tProgress prog = ev.getJob();\r\n\t\t\t\tprogressNotificationQueue.offer(prog);\r\n \t\t\t// switch back to ui thread to continue\r\n \t\t\tuiHandler.post(uiUpdaterRunnable);\r\n\t\t\t}\r\n\t\t};\r\n\t\tJobManager.addWorkListener(workListener);\r\n\r\n\t\t// give new jobs a chance to start then show 'No Job' msg if nothing running\r\n\t\tuiHandler.postDelayed(\r\n\t\t\tnew Runnable() {\r\n\t\t\t\t@Override\r\n\t\t\t\tpublic void run() {\r\n\t\t\t\t\tif (!JobManager.iterator().hasNext()) {\r\n\t\t\t\t\t\tshowNoTaskMsg(true);\t\t\t\t\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t}, 4000);\r\n }",
"public AddNewJobPanel() {\n initComponents();\n\n DateTime now = new DateTime();\n initializeComboBoxes();\n }",
"public void scheduleJob() {\n JobInfo.Builder builder = null;\n if (android.os.Build.VERSION.SDK_INT >= android.os.Build.VERSION_CODES.LOLLIPOP) {\n builder = new JobInfo.Builder(mJobId++, mServiceComponent);\n builder.setMinimumLatency(1000);\n builder.setRequiredNetworkType(JobInfo.NETWORK_TYPE_ANY);\n // Extras, work duration.\n PersistableBundle extras = new PersistableBundle();\n extras.putLong(WORK_DURATION_KEY, Long.valueOf(1) * 1000);\n extras.putString(\"gsonData\", gsonDataa);\n extras.putInt(\"servicetype\", 1);\n builder.setExtras(extras);\n // Schedule job\n Log.d(TAG, \"Scheduling job\");\n JobScheduler tm = (JobScheduler) getSystemService(Context.JOB_SCHEDULER_SERVICE);\n tm.schedule(builder.build());\n\n }\n\n\n\n }",
"public void setJob(String job) {\n this.job = job;\n }",
"private void handleJobLaunchSuccess() {\n EventBus eventbus = EventBus.getInstance();\n \n JobLaunchedEvent event = new JobLaunchedEvent(tagCaller, fieldName.getValue());\n eventbus.fireEvent(event);\n \n // close dialog now that job has launched\n closeDialog();\n \n MessageBox.info(I18N.DISPLAY.analysisSubmitted(), I18N.DISPLAY.analysisSubmittedMsg(), null);\n \n }",
"@SuppressWarnings({ \"deprecation\" })\n\t@SuppressLint(\"WorldWriteableFiles\")\n\t@Override\n\tprotected void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\n\t\tsetContentView(R.layout.layout_more_job_subscribe);\n\t\tcontext = this;\n\t\trequst = getIntent().getIntExtra(\"request\", 0);\n\t\tsp = getSharedPreferences(DATABASE, Activity.MODE_WORLD_WRITEABLE);\n\t\teditor = sp.edit();\n\t\tinitView();\n\t}",
"@Override\n public boolean onStartJob(JobParameters job) {\n\n String id = job.getTag();\n Log.d(\"TAG+++\", \"Job id: \" + id);\n\n Uri uri = ToDoContract.ToDoEntry.CONTENT_URI.buildUpon().appendPath(id).build();\n Cursor mCursor = getContentResolver().query(uri, null, null, null, null);\n if(mCursor != null){\n if(mCursor.getCount() > 0){\n mCursor.moveToFirst();\n String info = mCursor.getString(mCursor.getColumnIndex(ToDoContract.ToDoEntry.COLUMN_INFO));\n String desc = mCursor.getString(mCursor.getColumnIndex(ToDoContract.ToDoEntry.COLUMN_DESC));\n int priority = mCursor.getInt(mCursor.getColumnIndex(ToDoContract.ToDoEntry.COLUMN_PRIORITY));\n Log.d(\"TAG+++\", \"Info: \" + info + \" | Desc: \" + desc + \" | Priority: \" + priority);\n\n //send notification\n MyNotificationUtil.sendNotification(getApplicationContext(), Integer.valueOf(id), info, desc, priority);\n }\n }\n\n\n //is there anything else to do, any background work still running?\n return false;\n }",
"@Override\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\n Bundle savedInstanceState) {\n View myView = inflater.inflate(R.layout.fragment_main, container, false);\n logger = myView.findViewById(R.id.textView2);\n logger.setText(info);\n\n myView.findViewById(R.id.button).setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n Intent intent = new Intent();\n //normally this intent should have something, like data...\n MyJobIntentService.enqueueWork(getContext(),intent);\n }\n });\n return myView;\n }",
"@Override\n public void onCreate(Bundle savedInstanceState) {\n \tsuper.onCreate(savedInstanceState);\n \n setRequestedOrientation(ActivityInfo.SCREEN_ORIENTATION_PORTRAIT);\n this.requestWindowFeature(Window.FEATURE_NO_TITLE);\n setContentView(R.layout.activity_new_task);\n \n nameText = (EditText) findViewById(R.id.NameBox);\n \tdatePicker = (DatePicker)findViewById(R.id.datepicker);\n \tlengthText = (EditText) findViewById(R.id.estimatedlength);\n \tprogressBar = (SeekBar) findViewById(R.id.currentprogress);\n \tpriorityBox = (CheckBox)findViewById(R.id.highpriority);\n \t\n \t// If a task was passed in, attempt to load it\n \tBundle passedData = getIntent().getExtras();\n if (passedData != null) {\n \tTask task = new Task();\n \ttask.extractBundle(passedData);\n \t\n \ttask.get(Task.Attributes.Name, nameText);\n \ttask.get(Task.Attributes.Duedate, datePicker);\n \ttask.get(Task.Attributes.Hours, lengthText);\n \ttask.get(Task.Attributes.Progress, progressBar);\n \ttask.get(Task.Attributes.Priority, priorityBox);\n \t\n \tid = passedData.getLong(\"DB_ID\");\n \teditmode = true;\n } \n \t\n Button save = (Button) findViewById(R.id.save);\n\t\tsave.setOnClickListener(new OnClickListener() { public void onClick(View v) { saveTask();} } );\n \n }",
"public Job() {\n\t\t\t\n\t\t}",
"@Override\n public void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n\n // Following options to change the Theme must precede setContentView().\n\n toggleTheme();\n setContentView(R.layout.displayitems);\n\n // Identify buttons in XML layout and attach click and long-click\n // listeners to each\n\n View button01 = findViewById(R.id.button01);\n button01.setOnClickListener(this);\n button01.setOnLongClickListener(this);\n View button02 = findViewById(R.id.button02);\n button02.setOnClickListener(this);\n button02.setOnLongClickListener(this);\n\n // Put task description strings in an array for later use\n\n taskDescription[0] = getString(R.string.task_description1);\n taskDescription[1] = getString(R.string.task_description2);\n }",
"@Override\r\n\tprotected void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\r\n\t\tsetContentView(R.layout.activity_detail_program);\r\n\t\t\r\n\t\t// change actionbar title\r\n\t\tint titleId = Resources.getSystem().getIdentifier(\"action_bar_title\", \"id\", \"android\"); \r\n\t\tif ( 0 == titleId ) \r\n\t\t titleId = com.actionbarsherlock.R.id.abs__action_bar_title;\r\n\t\t\r\n\t\t// and change the title color to white\r\n\t\tTextView txtActionbarTitle = (TextView)findViewById(titleId);\r\n\t\ttxtActionbarTitle.setTextColor(getResources().getColor(R.color.actionbar_title_color));\r\n\t\t\r\n\t\t// get actionbar\r\n\t\tactionbar = getSupportActionBar();\r\n\t\tactionbar.setDisplayHomeAsUpEnabled(true);\r\n\t\t\r\n\t\t// connect views object with views id on xml\r\n\t\tlytImage = (FrameLayout) findViewById(R.id.lytImage);\r\n\t\ttxtTitle = (TextView) findViewById(R.id.txtTitle);\r\n\t\ttxtCaption = (TextView) findViewById(R.id.txtCaption);\r\n\t\ttxtSteps = (TextView) findViewById(R.id.txtSteps);\r\n\t\tbtnStart = (Button) findViewById(R.id.btnStart);\r\n\t\tbtnOptions = (Button) findViewById(R.id.btnOptions);\r\n\t\t\r\n\t\t// get id value that is passed from previous page\r\n\t\tIntent i = getIntent();\r\n\t\tSelectedID = i.getIntExtra(\"selectedID\", 0);\r\n\t\t\r\n\t\t// get screen width and height\r\n\t\tDisplayMetrics dm = new DisplayMetrics();\r\n\t\tgetWindowManager().getDefaultDisplay().getMetrics(dm);\r\n\t\tScreenWidth = dm.widthPixels;\r\n\t\tScreenHeight = ScreenWidth / 2 + 50;\r\n\t\t\r\n\t\t// call asynctask to get data from database\r\n\t\tnew getWorkoutDetail().execute();\r\n\t\t\r\n\t\t// listener for btnStart, open stop watch page when clicked\r\n\t\tbtnStart.setOnClickListener(new OnClickListener() {\r\n\t\t\t\r\n\t\t\t@Override\r\n\t\t\tpublic void onClick(View v) {\r\n\t\t\t\t// TODO Auto-generated method stub\r\n\t\t\t\tIntent i = new Intent(DetailProgramActivity.this, StopWatchActivity.class);\r\n\t\t\t\ti.putExtra(\"workout_id\", WorkoutID);\r\n\t\t\t\ti.putExtra(\"name\", Name);\r\n\t\t\t\ti.putExtra(\"time\", Time);\r\n\t\t\t\tstartActivity(i);\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\t// listener for btnOptions, open option dialog when clicked\r\n\t\tbtnOptions.setOnClickListener(new OnClickListener() {\r\n\t\t\t\r\n\t\t\t@Override\r\n\t\t\tpublic void onClick(View v) {\r\n\t\t\t\t// TODO Auto-generated method stub\r\n\t\t\t\toptionsDialog();\r\n\t\t\t}\r\n\t\t});\r\n\t\t\r\n\t}",
"@Override\n\tpublic void onActivityCreated(Bundle arg0) {\n\t\tsuper.onActivityCreated(arg0);\n\t}",
"public String getJob_title() {\r\n return job_title;\r\n }",
"private void addNewFinishedJobItem(Job job) {\n FinishedJobItemView finishedJobItemView = new FinishedJobItemView(this, job);\n finishedJobItemViews.add(finishedJobItemView);\n finishedJobsLinearLayout.addView(finishedJobItemView);\n }",
"@Override\n public void onActivityCreated(Bundle savedInstanceState) {\n super.onActivityCreated(savedInstanceState);\n new Department().execute();\n }",
"@Override\r\n\tpublic void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\r\n\t\tmType = getArguments() != null ? getArguments().getInt(TYPE) : 1;\r\n\t\tswitch (mType) {\r\n\t\tcase 0:\r\n\t\t\tinfoContent = getString(R.string.outline);\r\n\t\t\tbreak;\r\n\t\tcase 1:\r\n\t\t\tinfoContent = getString(R.string.mamber);\r\n\t\t\tbreak;\r\n\t\tcase 2:\r\n\t\t\tinfoContent = getString(R.string.schedule);\r\n\t\t\tbreak;\r\n\t\tcase 3:\r\n\t\t\tinfoContent = getString(R.string.rest);\r\n\t\t\tbreak;\r\n\t\t}\r\n\t}",
"public void onCreate(Bundle bundle) {\n if (Theme.primaryColor == 0) {\n Theme.primaryColor = UtilManager.sharedPrefHelper().getActionBarColor();\n }\n StrictMode.setThreadPolicy(new Builder().permitAll().build());\n if (!getClass().getSimpleName().equalsIgnoreCase(\"aveRssContentViewPager\")) {\n getTheme().applyStyle(new FontSizeHelper(this).getFontStyle().getResId(), true);\n } else if (new FontSizeHelper(this).getContentFontOrder() != -1) {\n getTheme().applyStyle(new FontSizeHelper(this).getContentFontStyle().getResId(), true);\n } else {\n getTheme().applyStyle(new FontSizeHelper(this).getFontStyle().getResId(), true);\n }\n super.onCreate(bundle);\n this.progressViewHelper = new ProgressViewHelper((AppCompatActivity) this);\n injectActivity(activityComponent());\n Intent intent = getIntent();\n String str = Constants.KEY_SCREEN_ID;\n if (intent.hasExtra(str)) {\n this.screenId = getIntent().getStringExtra(str);\n }\n Intent intent2 = getIntent();\n String str2 = Constants.KEY_SCREEN_TYPE;\n if (intent2.hasExtra(str2)) {\n this.screenType = getIntent().getStringExtra(str2);\n }\n Intent intent3 = getIntent();\n String str3 = Constants.KEY_SUB_SCREEN_TYPE;\n if (intent3.hasExtra(str3)) {\n this.subScreenType = getIntent().getStringExtra(str3);\n }\n String str4 = this.screenId;\n if (str4 != null && JSONStorage.containsScreen(str4)) {\n this.screenModel = JSONStorage.getScreenModel(this.screenId);\n }\n checkStats();\n }",
"@Override\n public String getType() {\n return Const.JOB;\n }",
"@Override\n\tprotected void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\n\t\tsetContentView(R.layout.target_products);\n\n\t\tInitializeEverything();\n\n\t\tif (isReportOfCurrentMonth) {\n\t\t\tnew ReportOfTheMonth().execute();\n\t\t} else {\n\t\t\tnew ReportinDateRange().execute();\n\t\t}\n\t}",
"@Override\n\tpublic void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\n\t\tsetContentView(R.layout.kinmuinfolist);\n\t\tsetTitleName(\"勤務情報一覧\");\n\t\tsetTitleIcon(android.R.drawable.ic_menu_agenda);\n\t\tsetUploadStatus();\n\n\t\t// 初期処理を実行する\n\t\tinitActivity();\n\t}",
"@Override\n protected void onPreExecute() {\n this.progressDialog.setMessage(\"Adding workouts...\");\n this.progressDialog.show();\n }",
"@Override\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\n Bundle savedInstanceState) {\n return inflater.inflate(R.layout.fragment_about_sarkari_job, container, false);\n }",
"private synchronized void createJob\n\t\t(Channel theChannel)\n\t\t{\n\t\t// Create Job Frontend proxy object for the channel.\n\t\tJobFrontendRef frontend =\n\t\t\tnew JobFrontendProxy (myChannelGroup, theChannel);\n\t\ttheChannel.info (frontend);\n\n\t\t// Create job information record.\n\t\tJobInfo jobinfo = getJobInfo (frontend);\n\n\t\t// Start lease timers.\n\t\tjobinfo.renewTimer.start\n\t\t\t(Constants.LEASE_RENEW_INTERVAL,\n\t\t\t Constants.LEASE_RENEW_INTERVAL);\n\t\tjobinfo.expireTimer.start\n\t\t\t(Constants.LEASE_EXPIRE_INTERVAL);\n\t\t}",
"private void scheduleJob() {\n Log.d(TAG, \"Long lived task is done.\");\n }",
"@Override\r\n\tpublic void onCreate(Bundle savedInstanceState) {\r\n\t super.onCreate(savedInstanceState);\r\n\t setContentView(R.layout.myschedule);\r\n\t this.setTitle(\"My Events\");\r\n\t \r\n\t // TODO: connect to DB\r\n\t \r\n\t}",
"public void startJob(final String name, final Bundle extras)\n {\n sendEngagementCommand(new Runnable()\n {\n @Override\n public void run()\n {\n try\n {\n mEngagementService.startJob(name, extras);\n }\n catch (Exception e)\n {\n e.printStackTrace();\n }\n }\n });\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.activity_add_task);\n\n Log.d(TAG, \"Firebase User: \" + FirebaseAuth.getInstance().getCurrentUser());\n\n // Use intent to get the list name to add task to\n Intent intent = getIntent();\n listName = intent.getStringExtra(Extra.TASK);\n\n // Set the activity title\n setTitle(\"Add Task to \" + listName);\n }",
"@Override\n\tprotected void onCreate(Bundle buildingInfo) {\n\t\tsetContentView(R.layout.activity_mac_building);\n\t\tsuper.onCreate(buildingInfo);\n\t\t\n\t\tIntent startingIntent = getIntent();\n\t\t\n\t\tBundle b = startingIntent.getBundleExtra(\"android.intent.extra.INTENT\");\n\t\t\n\t\tbuilding = (TextView) findViewById(R.id.building);\n\t\tdescription = (TextView) findViewById(R.id.description);\n\t\t\n\t\tbuildingName = b.getString(\"building\") + \"\\n\";\n\t\tdescriptionText = b.getString(\"buildingDescription\");\n\t\t\n\t\tbuilding.setText(buildingName);\n\t\tdescription.setText(descriptionText);\n\t}",
"private void showExecutionStart() {\n log.info(\"##############################################################\");\n log.info(\"Creating a new web application with the following parameters: \");\n log.info(\"##############################################################\");\n log.info(\"Name: \" + data.getApplicationName());\n log.info(\"Package: \" + data.getPackageName());\n log.info(\"Database Choice: \" + data.getDatabaseChoice());\n log.info(\"Database Name: \" + data.getDatabaseName());\n log.info(\"Persistence Module: \" + data.getPersistenceChoice());\n log.info(\"Web Module: \" + data.getWebChoice());\n }",
"private void newTask()\n {\n \t//TODO add alarm\n \tTask task = new Task(taskName.getText().toString(), taskDetails.getText().toString());\n \tdb.createTask(task);\n \t//TODO Tie notification to an alarm\n \t//Create notification\n \tIntent notifyIntent = new Intent(this, TaskNotification.class);\n \tnotifyIntent.putExtra(\"title\", task.name); //add title name\n \tnotifyIntent.putExtra(\"id\", (int) task.id); //add id\n \tstartActivity(notifyIntent); //create the intent\n \t\n \trefreshData();\n }",
"public GetJobs() {\r\n\t\tsuper();\r\n\t}",
"public DreamJob (String title) {\r\n System.out.println(\"Message from: DreamJob(String title)\");\r\n this.title = title;\r\n\t}",
"public void setJob(String job) {\r\n\t\t\tthis.job = job;\r\n\t\t}",
"public void initialize() {\n sceneSwitch = SceneSwitch.getInstance();\n sceneSwitch.addScene(addPartToJobStackPane, NavigationModel.ADD_PART_TO_JOB_ID);\n usernameLbl.setText(DBLogic.getDBInstance().getUsername());\n usertypeLbl.setText(DBLogic.getDBInstance().getUser_type());\n jobReference = jobReference.getInstance();\n partHashMap = new HashMap<>();\n refreshList();\n }",
"public void viewSpecificJob(String jobID) {\n System.out.println(getJobAtIndex(jobID).toString());\n }",
"private void scheduleJob() {\n\n }",
"public JobBuilder() {\r\n job = new Job();\r\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.add_daily_task);\n init_database();\n init_view();\n init_click();\n init_data();\n init_picker();\n }",
"@Override\n\tprotected void onCreate(Bundle savedInstanceState) {\n\t\tsetContentView(R.layout.caifushi_record);\n\t\tsuper.onCreate(savedInstanceState);\n\t\tinitview();\n\t\tMyApplication.getInstance().addActivity(this);\n\t\t\n\t}",
"public void setJob_title(String job_title) {\r\n this.job_title = job_title;\r\n }",
"public void gotoPostNewJob(View v){\n startActivity( new Intent( ViewSingleJobActivity.this, PostJobActivity.class));\n finish();\n }",
"public schedulerJob() {\n }",
"@Override\n public void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n \n ds = new RecordsDataSource(this);\n\n ShowMain ();\n Update ();\n }",
"public void scheduleJob(JobInfo t) {\n Log.d(TAG, \"Scheduling job\");\n try {\n JobScheduler tm = (JobScheduler) appContext.getSystemService(appContext.JOB_SCHEDULER_SERVICE);\n tm.schedule(t);\n int i = 0;\n } catch (Exception e) {\n e.printStackTrace();\n int i = 0;\n }\n }",
"@Override\r\n public void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\r\n c = (CourseModel) getIntent().getSerializableExtra(ContextUtil.CATEGORY_COURSE);\r\n initSlidingMenu();\r\n setContentView(R.layout.unit);\r\n initView();\r\n setListener();\r\n fm = getSupportFragmentManager();\r\n getCourseInfo();\r\n topName.setText(c.getName());\r\n }",
"private void setJob(String s) {\n switch (s) {\n case \"Wake\":\n _makeAnnouncement(\"The Zookeeper is about to wake the animals!\");\n break;\n case \"Sleep\":\n _makeAnnouncement(\"The Zookeeper is about to put the animals to sleep!\");\n break;\n case \"rollCall\":\n _makeAnnouncement(\"The Zookeeper is about to perform a roll call on the animals!\");\n break;\n case \"Exercise\":\n _makeAnnouncement(\"The Zookeeper is about to make the animals exercise!\");\n break;\n case \"Feed\":\n _makeAnnouncement(\"The Zookeeper is about to feed the animals!\");\n break;\n default:\n break;\n }\n }",
"@Override\n public void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n openAndQueryDatabase();\n \n displayResultList();\n \n \n }",
"@Override\n\tpublic View onCreateView(LayoutInflater inflater, ViewGroup container,\n\t\t\tBundle savedInstanceState) {\n\t\t\n\t\tView view = inflater.inflate(R.layout.fragment_jobs, container, false);\n\n\t\treturn view;\n\t}",
"@Override\n\tprotected void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\n\t\tsetContentView(R.layout.note_loc);\n\t\t\n\t\tdone = (Button)findViewById(R.id.done);\n\t\tdate = (TextView) findViewById(R.id.test_date);\n\t\ttime = (TextView) findViewById(R.id.test_time);\n\t\t\n\t\tdate.setText(getIntent().getExtras().getString(\"date\"));\n\t\ttime.setText(getIntent().getExtras().getString(\"time\"));\n\t\t\n\t\tdone.setOnClickListener(new View.OnClickListener() {\n\t\t\t\n\t\t\t@Override\n\t\t\tpublic void onClick(View v) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\tIntent i = new Intent(note_loc.this, Task.class);\n\t\t\tstartActivity(i);\n\t\t\t}\n\t\t});\n\t}",
"JobResponse create();",
"@Override\n public void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.listexcursionscreen);\n\n ActionsDelegator.getInstance().synchronizeActionsWithServer(this);\n runId = PropertiesAdapter.getInstance(this).getCurrentRunId();\n\n RunDelegator.getInstance().loadRun(this, runId);\n ResponseDelegator.getInstance().synchronizeResponsesWithServer(this, runId);\n\n }",
"@Override\n public void onResponse(String response) {\n Toast.makeText(TaskDueDate.this, \"Job add successfully.\"/* + jobResponse.getJobs()*/, Toast.LENGTH_SHORT).show();\n progressDialog.dismiss();\n Intent intent = new Intent(TaskDueDate.this, MainPage.class);\n intent.putExtra(\"fragment_status\", \"add_task\");\n startActivity(intent);\n finish();\n\n }",
"@Override\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\n Bundle savedInstanceState) {\n\n myJobsBinding = DataBindingUtil.inflate(inflater,R.layout.fragment_my_jobs, container, false);\n view = myJobsBinding.getRoot();\n setReyclerView();\n upcomingJobShift();\n return view;\n }",
"public void completeJob(View v) {\n // FIXME save that it is completed somehow\n Log.w(\"MA\", \"completeJob\");\n setContentView(R.layout.activity_sitter_page);\n allJobsList();\n }",
"private void displayTask() {\n this.task = new Task();\n Color color = this.task.getColor();\n this.taskPanel.displayColor(color);\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n\n super.onCreate(savedInstanceState);\n mEntry = (TimeTableEntry) getIntent().getSerializableExtra(\"entry\");\n\n mIsEdit = getIntent().getBooleanExtra(\"isEdit\", false);\n\n setContentView(R.layout.activity_time_table_entry_creation);\n\n addItemsOnSpinner();\n handleInputs();\n\n //Set the focus to the parent-LinearLayout to not focus the EditText at startup.\n LinearLayout focusableParent = (LinearLayout) findViewById(R.id.entry_creation_form);\n focusableParent.requestFocus();\n\n //Add back button to the ActionBar\n getSupportActionBar().setDisplayHomeAsUpEnabled(true);\n updateTextViews();\n\n if (mIsEdit) {\n setTitle(String.format(getString(R.string.entry_edit_title),\n DateUtils.formatDateTime(this, mEntry.getStart(),\n DateUtils.FORMAT_SHOW_DATE | DateUtils.FORMAT_SHOW_WEEKDAY | DateUtils.FORMAT_ABBREV_WEEKDAY)));\n }\n }",
"public Job() {\n }",
"public Job() {\n }",
"@Override\n\tprotected void onCreate(Bundle arg0) {\n\t\tsuper.onCreate(arg0);\n\t\tsetContentView(R.layout.activity_company_index);\n\t\tView btnAnnouncement = (View) findViewById(R.id.Btn_Announcement);\n\t\tbtnAnnouncement.setOnClickListener(this);\n\n\t\theadBar = (HeadBar) findViewById(R.id.Head_Bar);\n\t\theadBar.setTitle(getStr(R.string.company_info));\n\t\theadBar.setWidgetClickListener(this);\n\t\theadBar.setRightType(BtnType.empty);\n\t\tinitWidget();\n\t}",
"public void setJob(Job jobNum){\n job = jobNum;\n }",
"@Override\r\n public void onCreate(Bundle savedInstanceState) {\r\n super.onCreate(savedInstanceState);\r\n\r\n //画面作成\r\n setDataDisplay();\r\n //保存データ表示\r\n displaySaveData();\r\n }",
"@Override\n public boolean onStartJob(final JobParameters jobParameters) {\n // Here's where we make an AsyncTask so that this is no longer on the main thread\n mBackgroundTask = new BackgroundAsyncTask(new JobCallback() {\n @Override\n public void resultCallback(ArrayList<News> news) {\n Context context = NewsJobService.this;\n // Prepare to show notification\n NotificationUtils.generateNotificationLayout(context, news);\n //Override onPostExecute and called jobFinished. Pass the job parameters\n // and false to jobFinished. This will inform the JobManager that your job is done\n // and that you do not want to reschedule the job.\n\n /*\n * Once the AsyncTask is finished, the job is finished. To inform JobManager that\n * you're done, you call jobFinished with the jobParamters that were passed to your\n * job and a boolean representing whether the job needs to be rescheduled. This is\n * usually if something didn't work and you want the job to try running again.\n */\n jobFinished(jobParameters, false);\n }\n });\n // Execute the AsyncTask\n mBackgroundTask.execute();\n return true;\n }",
"@Override\n public void onCreate() {\n this.rand = randomWithRange(MIN,MAX);\n if (mTimer != null) {\n mTimer.cancel();\n } else {\n // recreate new\n mTimer = new Timer();\n }\n // schedule task\n mTimer.scheduleAtFixedRate(new TimeDisplayTimerTask(), 0, NOTIFY_INTERVAL);\n\n //shellExecuter = new ShellExecuter();\n }",
"public void goBackViewJob(View v) {\n setContentView(R.layout.activity_sitter_page);\n if(jobType.equals(\"open\")) {\n ((TextView) findViewById(R.id.allAcceptedJobsTitle)).setText(\"Available Jobs\");\n }\n else if(jobType.equals(\"owner\")) {\n ((TextView) findViewById(R.id.allAcceptedJobsTitle)).setText(\"Your Open Jobs\");\n }\n else {\n ((TextView) findViewById(R.id.allAcceptedJobsTitle)).setText(\"Accepted Jobs\");\n }\n allJobsList();\n }",
"public void setJobInfo(String jobInfo) {\n this.jobInfo = jobInfo;\n }",
"private void updatejob() {\n\t\tString course = edt_course.getText().toString();\n\t\tString content = edt_content.getText().toString();\n\t\tjob.setCourseName(course);\n\t\tjob.setJobContent(content);\n\t\tjob.update(new UpdateListener() {\n\t\t\t\n\t\t\t@Override\n\t\t\tpublic void done(BmobException e) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tif (e==null) {\n\t\t\t\t\ttoast(\"更新成功\");\n\t\t\t\t\tUpdateJobActivity.this.finish();\n\t\t\t\t} else {\n\t\t\t\t\ttoast(\"错误:\"+e.getMessage());\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\t}",
"private void startJobs() {\n List<JobProfile> profileList = getJobConfDb().getAcceptedJobs();\n for (JobProfile profile : profileList) {\n LOGGER.info(\"init starting job from db {}\", profile.toJsonStr());\n addJob(new Job(profile));\n }\n }",
"public Job(int id) {\n this.id = id;\n }",
"@Override\n protected void onPreExecute() {\n this.progressDialog.setMessage(\"Retrieving workouts list...\");\n this.progressDialog.show();\n }",
"@Override\r\n public void create() {\r\n super.create();\r\n setTitle(title);\r\n }",
"public TriggerEchoJob() {\n\t}",
"@Override\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\n Bundle savedInstanceState) {\n View view = inflater.inflate(R.layout.fragment_view, container, false);\n\n viewTaskName = (TextView)view.findViewById(R.id.viewTaskName);\n viewTaskTime = (TextView)view.findViewById(R.id.viewTaskTime);\n\n Bundle args = getArguments();\n if(args != null){\n viewTaskName.setText(args.getString(\"name\"));\n viewTaskTime.setText(args.getString(\"time\"));\n }\n\n\n\n return view;\n }",
"@Override\r\n public void onCreate(Bundle savedInstanceState) {\r\n\r\n super.onCreate(savedInstanceState);\r\n\r\n Context context = this.getApplicationContext();\r\n\r\n requestWindowFeature(Window.FEATURE_NO_TITLE);\r\n getWindow().setFlags(WindowManager.LayoutParams.FLAG_FULLSCREEN, WindowManager.LayoutParams.FLAG_FULLSCREEN);\r\n\r\n SplashHandler mHandler = new SplashHandler();\r\n final int layoutId = ResourceUtil.getLayoutResourceIdFromName(context, Colorme.LAYOUT_COLORME_AIYOUXI_SPLASH);\r\n setContentView(layoutId);\r\n\r\n final int viewId = ResourceUtil.getIdResourceIdFromName(context, Colorme.ID_COLORME_AIYOUXI_DRAWABLE);\r\n View view = findViewById(viewId);\r\n\r\n int what = 0;\r\n// Intent intent = this.getIntent();\r\n// if (intent != null) {\r\n// Bundle bundle = intent.getExtras();\r\n// if (bundle != null) {\r\n// String type = bundle.getString(KEY_TYPE);\r\n// if (VALUE_JYZA.equals(type)) {\r\n// final int bgId = ResourceUtil.getDrawableResourceIdFromName(context, Colorme.DRAWABLE_COLORME_JYZA);\r\n// view.setBackgroundResource(bgId);\r\n// what = 1;\r\n// }\r\n// }\r\n// }\r\n if (what == 0) {\r\n final int bgId = ResourceUtil.getDrawableResourceIdFromName(context, Colorme.DRAWABLE_COLORME_AIYOUXI);\r\n view.setBackgroundResource(bgId);\r\n }\r\n\r\n Message msg = new Message();\r\n msg.what = what;\r\n mHandler.sendMessageDelayed(msg, 3000);\r\n }",
"public Frm_AddJob() {\n initComponents();\n ClearEdit();\n }",
"@Override\n\tpublic void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\n\t\t//has the mainactivity show the loading screen\n\t}",
"public Job getJob();",
"private void startDownloadJob(final DownloadJob job) {\n\n\t\tfinal int notificationId = ++NOTIFICATION_ID;\n\n\t\tfinal NotificationManager mNotifyManager = (NotificationManager) getSystemService(Context.NOTIFICATION_SERVICE);\n\t\tfinal NotificationCompat.Builder mBuilder = new NotificationCompat.Builder(this);\n\t\t// mBuilder.setContentTitle(\"Message Download\")\n\t\tString notificationTitle = job.getFolderName();\n\t\tFBFriend loggedUser = DataStorage.getLoggedUser();\n\t\tif (loggedUser != null) {\n\t\t\tnotificationTitle = job.getThread().getFriendsNames(loggedUser);\n\t\t}\n\t\tmBuilder.setContentTitle(notificationTitle).setContentText(\"Download in progress\")\n\t\t\t\t.setSmallIcon(R.drawable.ic_launcher).setAutoCancel(true);\n\n\t\tIntent resultIntent = new Intent(this, StatusActivity.class);\n\t\tresultIntent.putExtra(StatusActivity.INTENT_EXTRA_STATUS, 1);\n\t\tresultIntent.putExtra(StatusActivity.INTENT_EXTRA_JOB, job);\n\t\tresultIntent.addFlags(Intent.FLAG_ACTIVITY_NEW_TASK | Intent.FLAG_ACTIVITY_CLEAR_TOP\n\t\t\t\t| Intent.FLAG_ACTIVITY_SINGLE_TOP);\n\t\t// resultIntent.addFlags(Intent.FLAG_ACTIVITY_CLEAR_TOP |\n\t\t// Intent.FLAG_ACTIVITY_SINGLE_TOP);\n\n\t\t// generate unique request id\n\t\tint n = new Random().nextInt(50) + 1;\n\t\tint requestID = n * notificationId;\n\n\t\tPendingIntent resultPendingIntent = PendingIntent.getActivity(this, requestID, resultIntent,\n\t\t\t\tPendingIntent.FLAG_UPDATE_CURRENT);\n\t\t// PendingIntent.FLAG_ONE_SHOT);\n\t\tmBuilder.setContentIntent(resultPendingIntent);\n\n\t\tThread thread = new Thread() {\n\n\t\t\t@Override\n\t\t\tpublic void run() {\n\t\t\t\tsuper.run();\n\t\t\t\tdownloading = true;\n\t\t\t\tString threadId = job.getThread().getThreadId();\n\n\t\t\t\tFBMessageTable dbTable = new FBMessageTable(getApplicationContext(), threadId);\n\t\t\t\tdbTable.createTableIfNotExist();\n\n\t\t\t\t// indexes starts from 0\n\t\t\t\t// start from begining or from the last index\n\t\t\t\t// long start = Math.max(job.getMinIndex() - 1,\n\t\t\t\t// job.getDownloadIndex());\n\t\t\t\tlong start = job.getMinIndex() - 1;\n\t\t\t\tlong end = job.getMaxIndex() - 1;\n\n\t\t\t\tlong current = start;\n\n\t\t\t\tAppLogger.log(TAG, \"Job started thread_id=\" + threadId + \" from \" + start + \" to \" + end);\n\n\t\t\t\tDate startDate = new Date();\n\n\t\t\t\tboolean working = true;\n\t\t\t\tjob.setWorking(true);\n\t\t\t\tsaveJobList();\n\t\t\t\twhile (working) {\n\n\t\t\t\t\tlong lowerLimit = current;\n\t\t\t\t\t// long upperLimit = Math.min(end, current +\n\t\t\t\t\t// FB_MAX_MESSAGE_LIMIT);\n\t\t\t\t\tlong upperLimit = Math.min(end, current + FB_MAX_MESSAGE_LIMIT);\n\n\t\t\t\t\t// check if already found in the database\n\t\t\t\t\tCursor cursor = dbTable.getExportMessages(threadId, lowerLimit, upperLimit);\n\n\t\t\t\t\tboolean contains = containsAll(lowerLimit, upperLimit, cursor);\n\t\t\t\t\tdbTable.closeReadableDatabase();\n\t\t\t\t\tif (contains) {\n\t\t\t\t\t\tStringBuilder sb = new StringBuilder();\n\t\t\t\t\t\tsb.append(\"found in database from \");\n\t\t\t\t\t\tsb.append(lowerLimit);\n\t\t\t\t\t\tsb.append(\" to \");\n\t\t\t\t\t\tsb.append(upperLimit);\n\t\t\t\t\t\tAppLogger.log(TAG, sb.toString());\n\t\t\t\t\t} else {\n\t\t\t\t\t\t// List<FBMessage> messages =\n\t\t\t\t\t\t// DataLoader.loadMessages(threadId, lowerLimit,\n\t\t\t\t\t\t// upperLimit);\n\t\t\t\t\t\tList<FBMessage> messages = DataLoader.loadMessages(threadId, lowerLimit, FB_MAX_MESSAGE_LIMIT);\n\n\t\t\t\t\t\tif (messages == null) {\n\t\t\t\t\t\t\t// error occured\n\n\t\t\t\t\t\t\t// 104 = OAuthException.\n\t\t\t\t\t\t\tif (DataLoader.getErrorCode() == 104) {\n\t\t\t\t\t\t\t\t// try to create session from cache\n\t\t\t\t\t\t\t\tvalidateFBLogin();\n\t\t\t\t\t\t\t\t// try missed one again\n\t\t\t\t\t\t\t\tupperLimit = lowerLimit;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\t// TODO testing use. should remove after testing\n\t\t\t\t\t\t\tStringBuilder sb = new StringBuilder();\n\t\t\t\t\t\t\tsb.append(\"Messages from \");\n\t\t\t\t\t\t\tsb.append(lowerLimit);\n\t\t\t\t\t\t\tsb.append(\" to \");\n\t\t\t\t\t\t\tsb.append(upperLimit);\n\t\t\t\t\t\t\tsb.append(\" size=\");\n\t\t\t\t\t\t\tsb.append(messages.size());\n\n\t\t\t\t\t\t\tAppLogger.log(TAG, sb.toString());\n\n\t\t\t\t\t\t\t// save to database\n\t\t\t\t\t\t\tdbTable.addAll(messages, lowerLimit);\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\n\t\t\t\t\tjob.setDownloadIndex(current);\n\t\t\t\t\t// saveJobList();\n\n\t\t\t\t\t// prepare for next iteration\n\t\t\t\t\tcurrent = upperLimit;\n\n\t\t\t\t\tif (current >= end) {\n\t\t\t\t\t\tworking = false;\n\t\t\t\t\t}\n\n\t\t\t\t\tif (job.isStop()) {\n\t\t\t\t\t\tworking = false;\n\n\t\t\t\t\t}\n\n\t\t\t\t\tint progress = 0;\n\t\t\t\t\tif (end == start) {\n\t\t\t\t\t\tprogress = 0;\n\t\t\t\t\t} else {\n\t\t\t\t\t\tprogress = (int) ((current - start) * 100 / (end - start));\n\t\t\t\t\t}\n\t\t\t\t\tmBuilder.setProgress(100, progress, false);\n\t\t\t\t\tmNotifyManager.notify(notificationId, mBuilder.build());\n\t\t\t\t\tpublishStatus(job, progress);\n\t\t\t\t}\n\n\t\t\t\tAppLogger.log(TAG, \"Job ended thread_id=\" + threadId + \" from \" + start + \" to \" + end + \" in \"\n\t\t\t\t\t\t+ (new Date().getTime() - startDate.getTime()) / 1000 + \"seconds\");\n\n\t\t\t\t// write csv file\n\t\t\t\tmBuilder.setContentText(\"Download complete. Generating file\").setProgress(0, 0, false);\n\t\t\t\tCursor cursor = dbTable.getExportMessages(threadId, start, end);\n\n\t\t\t\tif (cursor != null) {\n\t\t\t\t\tgenerateOutFile(job, cursor);\n\t\t\t\t}\n\n\t\t\t\tdbTable.closeReadableDatabase();\n\n\t\t\t\t// //////////////\n\t\t\t\tif (job.isStop()) {\n\t\t\t\t\tmBuilder.setContentText(\"Download stopped\").setProgress(0, 0, false);\n\t\t\t\t} else {\n\t\t\t\t\tmBuilder.setContentText(\"Finished\").setProgress(0, 0, false);\n\t\t\t\t}\n\t\t\t\tmNotifyManager.notify(notificationId, mBuilder.build());\n\n\t\t\t\t// //////////////\n\t\t\t\tjob.setStop(true);\n\t\t\t\tboolean removed = removeJob(job);\n\t\t\t\tif (removed) {\n\t\t\t\t\tsaveJobList();\n\t\t\t\t}\n\t\t\t\tdownloading = false;\n\t\t\t\tif (jobs != null) {\n\t\t\t\t\tif (jobs.size() == 0) {\n\t\t\t\t\t\tstopSelf();\n\t\t\t\t\t} else {\n\t\t\t\t\t\tstartAllDownloads();\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t}\n\n\t\t};\n\n\t\tif (threads == null) {\n\t\t\tthreads = new ArrayList<Thread>();\n\t\t}\n\t\tthreads.add(thread);\n\t\tthread.start();\n\n\t}",
"@Override\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\n Bundle savedInstanceState) {\n View view= inflater.inflate(R.layout.fragment_my_requirement_detail0, container, false);\n getActivity().setTitle(\"\"+getArguments().getString(\"title\"));\n MainActivity.linerFilter.setVisibility(View.INVISIBLE);\n grigView=view.findViewById(R.id.grigView);\n DataList=new ArrayList<>();\n\n Log.d(\"sdfsdfgsdfgdsfhgdfh\",getArguments().getString(\"id\"));\n Log.d(\"sdfsdfgsdfgdsfhgdfh\",getArguments().getString(\"date\"));\n\n new ReqListing().execute();\n\n\n\n return view;\n }",
"public String getJob() {\n return job;\n }",
"@Override\r\n public View onCreateView(LayoutInflater inflater, ViewGroup container, Bundle savedInstanceState) {\n View view = inflater.inflate(R.layout.fragment_seeker_status_reports, container, false);\r\n lvStatusReport = (ListView) view.findViewById(R.id.lvStatusReport);\r\n lvStatusReport.setOnItemClickListener(new AdapterView.OnItemClickListener() {\r\n @Override\r\n public void onItemClick(AdapterView<?> parent, View view, int position, long id) {\r\n\r\n final Job job = CommonObjects.getGetOffersResponse().getJobs().get(position);\r\n if (job.getStatus().equals(\"2\")) {\r\n CommonMethods.callAnActivityWithParameter(getActivity(), SeekerCandidatesArrivedActivity.class, \"position\", String.valueOf(position));\r\n } else\r\n CommonMethods.callAnActivityWithParameter(getActivity(), SeekerCandidatesDetailActivity.class\r\n , \"position\", String.valueOf(position));\r\n }\r\n });\r\n return view;\r\n }",
"@Digits(integer=9,fraction=0)\n\t@Override\n\tpublic String getJob() {\n\t\treturn super.getJob();\n\t}"
]
| [
"0.67259246",
"0.6531007",
"0.6410277",
"0.6298392",
"0.6236475",
"0.6226164",
"0.6223062",
"0.613376",
"0.6126532",
"0.6104845",
"0.6104407",
"0.60144633",
"0.59410626",
"0.5922265",
"0.5886861",
"0.58689666",
"0.58605474",
"0.5807883",
"0.57632154",
"0.5747337",
"0.5739854",
"0.57257766",
"0.571206",
"0.5704122",
"0.5678733",
"0.56775236",
"0.56388754",
"0.5624417",
"0.56181544",
"0.56071615",
"0.5607057",
"0.56064284",
"0.5586178",
"0.5577236",
"0.5565143",
"0.5563042",
"0.5560378",
"0.55574864",
"0.5551698",
"0.55407304",
"0.5537749",
"0.5535509",
"0.55296564",
"0.5519321",
"0.5513532",
"0.55133045",
"0.55123526",
"0.5511841",
"0.5509862",
"0.55072165",
"0.54974025",
"0.54950976",
"0.54920423",
"0.5490186",
"0.54874396",
"0.5487265",
"0.5486672",
"0.5485639",
"0.54832757",
"0.54771566",
"0.54714036",
"0.5470755",
"0.54697084",
"0.54602003",
"0.5458007",
"0.54528415",
"0.544873",
"0.54482245",
"0.54349476",
"0.5429792",
"0.5425828",
"0.5420021",
"0.54158694",
"0.5399631",
"0.539659",
"0.53777874",
"0.53777874",
"0.53723043",
"0.5365476",
"0.53634566",
"0.5361871",
"0.5357161",
"0.5353345",
"0.534637",
"0.5329708",
"0.5326325",
"0.5325094",
"0.5324296",
"0.5319709",
"0.53182364",
"0.53180254",
"0.5316703",
"0.5315808",
"0.5313727",
"0.5312085",
"0.53026253",
"0.53018695",
"0.5300603",
"0.52967954",
"0.52923393"
]
| 0.65064013 | 2 |
This returns an array of Strings of each Job object, for the Job ListView in sitter_page | public String[] getJobArr() {
String[] jobArr;
jobArr = new String[jobList.size()];
for(int i=0;i<jobList.size();i++) {
Log.w("MA", ""+jobList.get(i).listString(jobType));
jobArr[i] = (jobList.get(i)).listString(jobType);
}
return jobArr;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public String[] getAllJobs();",
"java.util.List<cb.Careerbuilder.Job> \n getJobsList();",
"@Override\r\n\tpublic List<IncomingJobResponse> getJobList() {\n\t\tList<IncomingJobs> js = (List<IncomingJobs>)incomingRepository.fetchincomingJobs();\r\n\t\tList<IncomingJobResponse> joblist = new ArrayList<IncomingJobResponse>();\r\n\t\tfor(IncomingJobs job :js){\r\n\t\t\tIncomingJobResponse jobs = new IncomingJobResponse();\r\n\t\t\tSystem.out.println(\"ATA:\"+job.getAta()+\"ETA:\"+job.getEta());\r\n\t\t\tjobs.setJobid(job.getID());\r\n\t\t\t\r\n\t\t\tif(job.getEta()!=null){\r\n\t\t\tjobs.setEta(job.getEta().toString());\r\n\t\t\t}\r\n\t\t\tif(job.getAta()!=null){\r\n\t\t\tjobs.setAta(job.getAta().toString());\r\n\t\t\t}\r\n\t\t\tjobs.setBroker(job.getBroker());\r\n\t\t\tjobs.setClear(job.getClear());\r\n\t\t\tjobs.setConsignee(job.getConsignee());\r\n\t\t\tjobs.setDestination(job.getDestination());\r\n\t\t\tjobs.setFlight(job.getFlight());\r\n\t\t\tjobs.setHawb(job.getHawb());\r\n\t\t\tjobs.setHeld(job.getHeld());\r\n\t\t\tjobs.setMawb(job.getMawb());\r\n\t\t\tjobs.setMLID(job.getMLID());\r\n\t\t\tjobs.setNote(job.getNote());\r\n\t\t\tjobs.setOutturn(job.getOutturn());\r\n\t\t\tjobs.setPiece(job.getPiece());\r\n\t\t\tjobs.setWeight(job.getWeight());\r\n\t\t\tif(job.getInjectionDate()!=null){\r\n\t\t\t\tjobs.setInjectionDate(job.getInjectionDate().toString());\r\n\t\t\t\t}\r\n\t\t\tif(job.getClearanceDate()!=null){\r\n\t\t\t\tjobs.setClearanceDate(job.getClearanceDate().toString());\r\n\t\t\t\t}\r\n\t\t\tjobs.setDamage(job.getDamageNotes());\r\n\t\t\tjobs.setSurplus(job.getSurplusShortage());\r\n\t\t\tjoblist.add(jobs);\r\n\t\t\t\r\n\t\t}\r\n\t\treturn joblist;\r\n\t}",
"public void getJobs(String response) {\n\t\tDocument doc = Jsoup.parse(response);\r\n\t\tElements body = doc.getElementsByTag(\"tbody\");\r\n\t\tElement listOfJobs = body.get(3);\r\n\t\tElements groupOfJobs = listOfJobs.children(); //25 jobs\r\n\r\n\t\tfor (Element job: groupOfJobs) {\r\n\t\t\tJob newJob = createJob(job);\r\n\t\t\tmListOfJobs.add(newJob);\r\n\t\t}\r\n\t\tif (mAdapter != null) {\r\n\t\t\tmAdapter.notifyDataSetChanged();\r\n\t\t}\r\n\t}",
"java.util.List<com.google.cloud.talent.v4.Job> \n getJobsList();",
"cb.Careerbuilder.Job getJobs(int index);",
"public java.util.List<cb.Careerbuilder.Job> getJobsList() {\n if (jobsBuilder_ == null) {\n return java.util.Collections.unmodifiableList(jobs_);\n } else {\n return jobsBuilder_.getMessageList();\n }\n }",
"public java.util.List<cb.Careerbuilder.Job> getJobsList() {\n return jobs_;\n }",
"@Override\r\n\tpublic List<Job> ShowAllJobs() {\n\t\treturn null;\r\n\t}",
"com.google.cloud.talent.v4.Job getJobs(int index);",
"public List<RequestJob> getAllJob() {\n List<RequestJob> allJob = null;\n if (allJob == null) {\n allJob = requestJobMapper.selectByExample(new RequestJobExample());\n }\n MemCacheUtil.set(\"job-list\", allJob);\n return allJob;\n }",
"public cb.Careerbuilder.Job getJobs(int index) {\n return jobs_.get(index);\n }",
"public cb.Careerbuilder.Job getJobs(int index) {\n if (jobsBuilder_ == null) {\n return jobs_.get(index);\n } else {\n return jobsBuilder_.getMessage(index);\n }\n }",
"public ArrayList<Job> getJobs(){\n return jobs;\n }",
"public static ArrayList<Job> getJob()\n {\n conn = DatabaseConnectionPostgre.connection();\n try {\n ArrayList<Job> returnValue = new ArrayList<>();\n\n stmt = conn.createStatement();\n String sql = \"SELECT * FROM job NATURAL JOIN recruiter NATURAL JOIN location;\";\n ResultSet rs = stmt.executeQuery(sql);\n while(rs.next()) {\n returnValue.add(new Job(\n rs.getInt(\"job_id\"),\n rs.getString(\"job_name\"),\n new Recruiter(\n rs.getInt(\"recruiter_id\"),\n rs.getString(\"name\"),\n rs.getString(\"email\"),\n rs.getString(\"phone_number\"),\n new Location(\n rs.getString(\"province\"),\n rs.getString(\"city\"),\n rs.getString(\"description\")\n )\n ),\n rs.getInt(\"fee\"),\n JobCategory.valueOf(rs.getString(\"category\"))\n ));\n }\n rs.close();\n stmt.close();\n conn.close();\n return returnValue;\n } catch (Exception e) {\n System.err.println(e.getClass().getName()+\": \"+ e.getMessage());\n return null;\n }\n }",
"@RequestMapping(value = \"/list/{pjobId}\",\n method = RequestMethod.GET,\n produces = { MediaType.APPLICATION_JSON_VALUE })\n @ResponseBody\n public List<Job> getJobList1(@PathVariable(\"pjobId\") Integer pjobId) {\n ProfessionJob professionJob = professionJobService.getProfessionJob(pjobId).get();\n List<JobRequireProfessionJob> list = jobService.findAllByProfessionJob(professionJob);\n List<Job> jobsAfterFilterByProfession = new ArrayList<>();\n for(JobRequireProfessionJob jrpj : list) {\n jobsAfterFilterByProfession.add(jrpj.getJob());\n }\n return jobsAfterFilterByProfession;\n }",
"public Collection<String> list() {\n return jobs.keySet();\n }",
"public void listJobExecutions() {\r\n\t\tRestCall caller = new RestCall();\r\n\t\tHttpURLConnection connection = caller.connect(endpoint + tenantId\r\n\t\t\t\t+ \"/job-executions\", null, \"GET\", token);\r\n\t\ttry {\r\n\t\t\tconnection.connect();\r\n\t\t\tSystem.out.println(caller.getResponse(connection));\r\n\t\t\tconnection.disconnect();\r\n\t\t} catch (MalformedURLException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}",
"@Override\r\n\tpublic int getCount() {\n\t\treturn jobList.size();\r\n\t}",
"@ApiModelProperty(value = \"Array of Job IDs generated by this flow\")\n public List<Job> getJobs() {\n return jobs;\n }",
"java.util.List<com.lvl6.proto.QuestProto.UserQuestJobProto> \n getUserQuestJobsList();",
"private String jobs() {\r\n\t\tint[] j=tile.getJobs();\r\n\t\tString out = \"Jobs Are: \";\r\n\t\tfor(int i=0; i<j.length;i++) {\r\n\t\t\tout=out.concat(i+\": \"+(j[i])+\" || \");\r\n\t\t}\r\n\t\treturn out;\r\n\t}",
"cb.Careerbuilder.JobOrBuilder getJobsOrBuilder(\n int index);",
"public static List<Job> findAll() {\n\t\treturn getPersistence().findAll();\n\t}",
"@SuppressWarnings(\"unchecked\")\n\tpublic List<IJobQueue> getJobs() throws IOException {\n\t\tfinal String sql = \"SELECT * from jobqueue order by id\";\n\t\tList<? extends IJobQueue> result = this.queryDataList(JobQueue.class,IJobQueue.Props.class, sql);\n\t\treturn (List<IJobQueue>) result;\t\t\n\t}",
"public java.util.List<? extends cb.Careerbuilder.JobOrBuilder> \n getJobsOrBuilderList() {\n if (jobsBuilder_ != null) {\n return jobsBuilder_.getMessageOrBuilderList();\n } else {\n return java.util.Collections.unmodifiableList(jobs_);\n }\n }",
"private void loadJobs(){\n\t\tsuperJobsList.clear();\n\t\tsuperJobs=jdbc.getProjectsAndJobs();\n\t\tfor(Job j: superJobs){\n\t\t\tsuperJobsList.addElement(j.jobname);\n\t\t}\n\t\t\n\t}",
"public List<IJobTemplate> getJobTemplates();",
"@GET\n @Path(\"/job/{id}/tasks\")\n @Produces(MediaType.APPLICATION_JSON)\n public Response getJobTasks(@PathParam(\"id\") String jobId) {\n LGJob lg = Utils.getJobManager().getJob(jobId);\n if (null == lg) {\n return Response.status(404).entity(\"Not found\").build();\n }\n JSONObject result = new JSONObject();\n result.put(\"tasks\",getTasksHelper(lg));\n return Response.status(200).entity(result.toString(1)).build();\n }",
"public ObservableList<Job> getJobData() {\n return jobData;\n }",
"private void saveJobList() {\n\t\tFileLoader.saveObject(getApplicationContext(), FILE_NAME_JOBS, (Serializable) jobs);\n\t}",
"public String getJobInfo() {\n return jobInfo;\n }",
"public GetAllPrintJobListResponse getAllPrintJobs(){\n GetAllPrintJobResponse printJobResponse =\n new GetAllPrintJobResponse(null, null, null, null, null,\n null, null, null);\n\n List<GetAllPrintJobResponse> printJobResponses = new ArrayList<GetAllPrintJobResponse>();\n printJobResponses.add(printJobResponse);\n\n return new GetAllPrintJobListResponse(printJobResponses);\n }",
"public String[] getJobsWaiting();",
"public java.util.List<com.lvl6.proto.QuestProto.UserQuestJobProto> getUserQuestJobsList() {\n if (userQuestJobsBuilder_ == null) {\n return java.util.Collections.unmodifiableList(userQuestJobs_);\n } else {\n return userQuestJobsBuilder_.getMessageList();\n }\n }",
"public List<byte[]> getAllJobInfo() {\n // Fetch a job list with protobuf bytes format from GCS.\n synchronized (GlobalStateAccessor.class) {\n validateGlobalStateAccessorPointer();\n return this.nativeGetAllJobInfo(globalStateAccessorNativePointer);\n }\n }",
"public java.util.List<? extends cb.Careerbuilder.JobOrBuilder> \n getJobsOrBuilderList() {\n return jobs_;\n }",
"@SuppressWarnings(\"rawtypes\")\n private String getSourcePageIds(Job job)\n {\n StringBuilder spIds = new StringBuilder();\n Iterator spIter = job.getSourcePages().iterator();\n while (spIter.hasNext())\n {\n SourcePage sp = (SourcePage) spIter.next();\n spIds.append(sp.getId()).append(\",\");\n }\n\n String result = spIds.toString();\n if (result.endsWith(\",\"))\n {\n return result.substring(0, result.length() - 1);\n }\n return \"\";\n }",
"@Override\r\n\tpublic List<JobDTO> getAllJobs() {\n\t\treturn accountDao.getAllJobs();\r\n\t}",
"DataResult<List<Job>> getAll();",
"com.lvl6.proto.QuestProto.UserQuestJobProto getUserQuestJobs(int index);",
"@RequestMapping(\"/listjobs\")\n public String listJobs(Model model)\n {\n model.addAttribute(\"alljobs\",jobs.findAll());\n return \"listjobs\";\n }",
"public void storeJobsToJobList(String jobDetails)\n {\n String[] allJob = jobDetails.split(\";\");\n \n \n for (int line = 0; line < allJob.length ; line++)\n {\n String[] details = allJob[line].split(\"///\");\n String jobRecruiterUsername = details[0];\n String title = details[1];\n String description = details[2];\n int salary = Integer.parseInt(details[3].trim());\n String location = details[4];\n String[] categories = details[5].split(\",\");\n ArrayList<String> category = new ArrayList<String>();\n for (int i = 0; i < categories.length; i++)\n {\n category.add(categories[i]);\n }\n String[] skillset = details[6].split(\",\");\n ArrayList<String> skillsets = new ArrayList<String>();\n for (int i = 0; i < skillset.length; i++)\n {\n skillsets.add(skillset[i]);\n }\n String[] jobSeekerUsernames = details[7].split(\",\");\n ArrayList<String> jobSeekerUsername = new ArrayList<String>();\n for (int i = 0; i < jobSeekerUsernames.length; i++)\n {\n jobSeekerUsername.add(jobSeekerUsernames[i]);\n }\n \n Job job = new Job(jobRecruiterUsername, title, description, salary, location, category, skillsets, jobSeekerUsername); \n \n jobList.add(job); \n \n }\n }",
"public java.util.List<cb.Careerbuilder.Job.Builder> \n getJobsBuilderList() {\n return getJobsFieldBuilder().getBuilderList();\n }",
"public ArrayList<AvailableJobModal> getAvailablejoblist() {\n return availablejoblist;\n }",
"public String getJob() {\n return job;\n }",
"@Override\r\n public PaginationResult getTasksByJobType(TaskSearchCriteriaBean object) throws Exception {\n PaginationResult result = new PaginationResult();\r\n result.setStart(object.getStart());\r\n result.setNum(object.getEnd());\r\n//\t\tresult.setTotal(mapper.countAllTasksByType(BeanUtil.transBean2Map(object)));\r\n//\t\tresult.setList(mapper.getTasksByJobType(object));\r\n return result;\r\n }",
"@RequestMapping(value = \"/getJobsList\", method = RequestMethod.GET, produces = \"application/json\")\n\t@ResponseBody\n\tpublic List<GetJobsResponse> getJobsList(@RequestParam String jobType, \n\t\t\t@RequestParam String jobTitle,@RequestParam String emailId) {\n \tList<GetJobsResponse> getJobsResponseList = null;\n\t\ttry {\n\t\t\t\n\t\t\tgetJobsResponseList = this.econnectService.getJobsList(jobType,jobTitle,emailId);\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn getJobsResponseList;\n\t}",
"List<MiniJobForUser> getMiniJobForUserId( String userId );",
"java.util.List<? extends com.google.cloud.talent.v4.JobOrBuilder> \n getJobsOrBuilderList();",
"@GetMapping(\"/job-bids\")\n @Timed\n public List<JobBid> getAllJobBids() {\n log.debug(\"REST request to get all JobBids\");\n return jobBidRepository.findAll();\n }",
"public String getJob() {\r\n\t\t\treturn job;\r\n\t\t}",
"public ArrayList<PISSTaskWrapper> projectJobTaskList(List<String> parsedServiceJob) {\n ArrayList<PISSTaskWrapper> translationList = new ArrayList<>();\n /* if (parsedServiceJob.size() == 0 || parsedServiceJob.isEmpty()) {\n this.aResponse = true; // No result\n return null;\n }*/\n\n this.mResult = parsedServiceJob.size() >= 0;\n\n for (String credential : parsedServiceJob) {\n PISSTaskWrapper sw = new PISSTaskWrapper();\n String[] pieces = credential.split(LIST_DELIM);\n\n sw.setID(Integer.parseInt(pieces[0]));\n sw.setProjectID(Integer.parseInt(pieces[1]));\n sw.setSerialNo(pieces[2]);\n sw.setDescription(pieces[3]);\n sw.setConformance(pieces[4]);\n sw.setComments(pieces[5]);\n sw.setStatus(pieces[6]);\n sw.setDrawingBefore(pieces[7]);\n // sw.setDrawingAfter(pieces[8]);\n translationList.add(sw);\n }\n return translationList;\n }",
"public cb.Careerbuilder.JobOrBuilder getJobsOrBuilder(\n int index) {\n return jobs_.get(index);\n }",
"public GetJobs() {\r\n\t\tsuper();\r\n\t}",
"java.util.List<java.lang.String> getContentsList();",
"@Override\n public String toString() {\n StringBuilder sb = new StringBuilder();\n sb.append(\"{\");\n if (getJobId() != null)\n sb.append(\"JobId: \").append(getJobId()).append(\",\");\n if (getJobStatus() != null)\n sb.append(\"JobStatus: \").append(getJobStatus());\n sb.append(\"}\");\n return sb.toString();\n }",
"public ArrayList<String> getAllWorkoutItems() {\n\n ArrayList<String> items = new ArrayList<>();\n Cursor cursor = db.query(DATABASE_TABLE_WORKOUTS, new String[] {\n KEY_ID, KEY_WORKOUT}, null, null, null, null, null);\n\n if (cursor.moveToFirst()) {\n do {\n String workout = cursor.getString(COLUMN_WORKOUT_INDEX);\n\n items.add(workout);\n } while (cursor.moveToNext());\n }\n\n cursor.close();\n return items;\n }",
"public List<? extends JobEntry> getScheduledJobs()\n {\n return schedulerService.listJobs();\n }",
"@Override\n public List<HistoryJobEntity> findExpiredJobs(Page page) {\n return Lists.newArrayList();\n }",
"public List<com.moseeker.baseorm.db.profiledb.tables.pojos.ProfileWorkexp> fetchByJob(String... values) {\n return fetch(ProfileWorkexp.PROFILE_WORKEXP.JOB, values);\n }",
"java.util.List<? extends cb.Careerbuilder.JobOrBuilder> \n getJobsOrBuilderList();",
"public List<JobParam> findByJobId(String jobId);",
"public cb.Careerbuilder.JobOrBuilder getJobsOrBuilder(\n int index) {\n if (jobsBuilder_ == null) {\n return jobs_.get(index); } else {\n return jobsBuilder_.getMessageOrBuilder(index);\n }\n }",
"public java.util.List<com.lvl6.proto.QuestProto.UserQuestJobProto> getUserQuestJobsList() {\n return userQuestJobs_;\n }",
"private void postJobRequestSorting(String url, String sType) {\n\n loadingDialog();\n\n HashMap<String, String> jsonParams = new HashMap<String, String>();\n jsonParams.put(\"provider_id\", provider_id);\n jsonParams.put(\"type\", sType);\n jsonParams.put(\"page\", \"0\");\n jsonParams.put(\"perPage\", \"20\");\n jsonParams.put(\"orderby\", Str_orderby);\n jsonParams.put(\"sortby\", Str_sortby);\n jsonParams.put(\"from\", Str_from);\n jsonParams.put(\"to\", Str_to);\n\n\n System.out.println(\"---------from------------\" + Str_from);\n System.out.println(\"---------to------------\" + Str_to);\n System.out.println(\"---------orderby------------\" + Str_orderby);\n System.out.println(\"---------sortby------------\" + Str_sortby);\n\n System.out.println(\"---------My Jobs user_id------------\" + provider_id);\n System.out.println(\"---------My Jobs type------------\" + sType);\n System.out.println(\"---------My Jobs Page page------------\" + \"1\");\n System.out.println(\"---------My Jobs url------------\" + url);\n\n mRequest = new ServiceRequest(getActivity());\n mRequest.makeServiceRequest(url, Request.Method.POST, jsonParams, new ServiceRequest.ServiceListener() {\n @Override\n public void onCompleteListener(String response) {\n\n System.out.println(\"--------- sortingname response------------\" + response);\n String Str_status = \"\", Str_totaljobs = \"\", Str_Response = \"\";\n\n try {\n JSONObject jobject = new JSONObject(response);\n Str_status = jobject.getString(\"status\");\n\n if (Str_status.equalsIgnoreCase(\"1\")) {\n convertedlist.clear();\n JSONObject object = jobject.getJSONObject(\"response\");\n Str_Pagination = object.getString(\"next_page\");\n Str_PageDateCount = object.getString(\"perPage\");\n Str_totaljobs = object.getString(\"total_jobs\");\n\n Object check_list_object = object.get(\"jobs\");\n if (check_list_object instanceof JSONArray) {\n\n JSONArray jarry = object.getJSONArray(\"jobs\");\n if (jarry.length() > 0) {\n convertedlist.clear();\n\n for (int i = 0; i < jarry.length(); i++) {\n JSONObject object2 = jarry.getJSONObject(i);\n MyjobConverted_Pojo pojo = new MyjobConverted_Pojo();\n pojo.setConverted_address(object2.getString(\"location\"));\n pojo.setConverted_category(object2.getString(\"category_name\"));\n pojo.setConverted_date(object2.getString(\"booking_time\"));\n pojo.setConverted_user_name(object2.getString(\"user_name\"));\n pojo.setConverted_user_image(object2.getString(\"user_image\"));\n pojo.setOrder_id(object2.getString(\"job_id\"));\n pojo.setConvertedjob_status(object2.getString(\"job_status\"));\n String address= getCompleteAddressString(Double.parseDouble(object2.getString(\"location_lat\")),Double.parseDouble(object2.getString(\"location_lng\")));\n pojo.setAddress(address);\n convertedlist.add(pojo);\n isConvertedJobAvailable = true;\n }\n show_progress_status = true;\n } else {\n show_progress_status = false;\n isConvertedJobAvailable = false;\n }\n } else {\n\n isConvertedJobAvailable = false;\n\n }\n } else {\n Str_Response = jobject.getString(\"response\");\n }\n\n if (Str_status.equalsIgnoreCase(\"1\")) {\n\n if (isConvertedJobAvailable) {\n adapter = new MyjobConverted_Adapter(getActivity(), convertedlist);\n listView.setAdapter(adapter);\n adapter.notifyDataSetChanged();\n\n if (show_progress_status) {\n layout_nojobs_converted.setVisibility(View.GONE);\n } else {\n layout_nojobs_converted.setVisibility(View.VISIBLE);\n listView.setEmptyView(layout_nojobs_converted);\n }\n } else {\n layout_nojobs_converted.setVisibility(View.VISIBLE);\n listView.setEmptyView(layout_nojobs_converted);\n }\n\n } else {\n\n Alert(getResources().getString(R.string.server_lable_header), Str_Response);\n\n }\n if (swipeRefreshLayout.isRefreshing()) {\n swipeRefreshLayout.setRefreshing(false);\n }\n\n } catch (Exception e) {\n dismissDialog();\n e.printStackTrace();\n }\n dismissDialog();\n }\n\n @Override\n public void onErrorListener() {\n dismissDialog();\n }\n });\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.activity_sitter_page);\n jobType = getIntent().getStringExtra(\"jobType\");\n setjobList();\n\n allJobsList();\n }",
"public static List<Job> findByUuid(String uuid) {\n\t\treturn getPersistence().findByUuid(uuid);\n\t}",
"@Nonnull\n List<AbstractProject<?,?>> getAllJobs();",
"public static List<Job> findByTitle(String title) {\n\t\treturn getPersistence().findByTitle(title);\n\t}",
"public String getJobName() {\n return this.mJob;\n }",
"public Dsjob getJobObject() { return job; }",
"public List<JobParam> findByJob(Job job);",
"public List<Job> loadJobs(Map<String, Object> cmap) {\n CriteriaBuilder builder = em.getCriteriaBuilder();\n CriteriaQuery<JobEntity> criteriaQuery = builder.createQuery(JobEntity.class);\n Root<JobEntity> jobRoot = criteriaQuery.from(JobEntity.class);\n criteriaQuery.select(jobRoot);\n\n List<Predicate> predicates = buildPredicatesFromConditions(cmap, builder, jobRoot);\n criteriaQuery.where(builder.and(predicates.toArray(new Predicate[0])));\n return getResultsFromQuery(criteriaQuery);\n }",
"com.google.cloud.talent.v4.JobOrBuilder getJobsOrBuilder(\n int index);",
"public void get_all_rooms(){\n new Thread(new Runnable() {\n @Override\n public void run() {\n// throw new UnsupportedOperationException(\"Not supported yet.\"); //To change body of generated methods, choose Tools | Templates.\n try {\n HttpResponse<String> httpResponse = Unirest.get(GlobalClass.ip+\"fetch_all_rooms\")\n .asString();\n if(httpResponse.getStatus() == 200){\n String res = httpResponse.getBody();\n \n arrayList.clear();\n StringTokenizer st1 = new StringTokenizer(res,\"~~\"); //row\n while(st1.hasMoreTokens()){\n String res2 = st1.nextToken();\n StringTokenizer st2 = new StringTokenizer(res2,\"$$\");//column\n while(st2.hasMoreTokens()){\n int rid = Integer.parseInt(st2.nextToken());\n String roomname = st2.nextToken();\n String photo = st2.nextToken();\n String category = st2.nextToken();\n arrayList.add(new Rooms(rid, roomname, category, photo));\n System.out.println(\"\"+roomname);\n }\n \n }\n \n System.out.println(\"\"+arrayList.size());\n j_rooms.getColumnModel().getColumn(3).setCellRenderer(new ImageRenderer());\n j_rooms.setRowHeight(100);\n tm.fireTableDataChanged();\n \n }\n \n \n } catch (Exception ex) {\n Logger.getLogger(Admin_Mage_Rooms.class.getName()).log(Level.SEVERE, null, ex);\n }\n \n \n \n }\n }).start();\n}",
"public com.lvl6.proto.QuestProto.UserQuestJobProto getUserQuestJobs(int index) {\n if (userQuestJobsBuilder_ == null) {\n return userQuestJobs_.get(index);\n } else {\n return userQuestJobsBuilder_.getMessage(index);\n }\n }",
"@Override\n public void run() {\n CompareService.getRankedJobStrings();\n\n // get current job\n current = DataHandler.GetDataHandlerInstance().GetCurrentJob();\n String formattedComp =\n JOB.title + \" | \" + current.title + \"\\n\" +\n JOB.currentJob + \" | \" + current.currentJob + \"\\n\" +\n JOB.company + \" | \" + current.company + \"\\n\" +\n JOB.city + \" | \" + current.city + \"\\n\" +\n JOB.state + \" | \" + current.state + \"\\n\" +\n JOB.yearlySalary + \" | \" + current.yearlySalary + \"\\n\" +\n JOB.yearlyBonus + \" | \" + current.yearlyBonus + \"\\n\" +\n JOB.teleworkDaysPerWeek + \" | \" + current.teleworkDaysPerWeek + \"\\n\" +\n JOB.retirementBenefit + \" | \" + current.retirementBenefit + \"\\n\" +\n JOB.leaveTime + \" | \" + current.leaveTime;\n intent.putExtra(\"job1\", JOB.title + \", \" + JOB.company);\n intent.putExtra(\"job2\", current.title + \", \" + current.company);\n startActivity(intent);\n }",
"public Jobs jobs();",
"PagingLoadResult<GWTJahiaJobDetail> getJobs(int offset, int limit, String sortField, String sortDir, String groupState, List<String> groupNames) throws GWTJahiaServiceException;",
"Collection<String> submitJob(Job job) throws JobExecutionException;",
"public com.lvl6.proto.QuestProto.UserQuestJobProto getUserQuestJobs(int index) {\n return userQuestJobs_.get(index);\n }",
"@GetMapping(\"/at-job-applications\")\n @Timed\n public ResponseEntity<List<AtJobApplicationsDTO>> getAllAtJobApplications(Pageable pageable) {\n log.debug(\"REST request to get a page of AtJobApplications\");\n Page<AtJobApplications> page = atJobApplicationsRepository.findAll(pageable);\n HttpHeaders headers = PaginationUtil.generatePaginationHttpHeaders(page, \"/api/at-job-applications\");\n return new ResponseEntity<>(atJobApplicationsMapper.toDto(page.getContent()), headers, HttpStatus.OK);\n }",
"public String toString() {\n return getJobtitle() + \" by \" + getUsername() + \"\\n\" +\n getLocation() + \" - PhP\" + getSalary() + \" - \" + getJobfield();\n }",
"public String list() {\n final StringBuilder list = new StringBuilder(\"Here are the tasks in your list:\\n\\t\");\n records.forEach((el) -> list.append(\n String.format(\"%1$d. %2$s \\n\\t\",\n records.indexOf(el) + 1, el.toString())));\n return list.toString();\n }",
"public JSONObject handleListJobs(String cursor, int count) {\n List<MapReduceState> states = new ArrayList<MapReduceState>();\n Cursor newCursor = MapReduceState.getMapReduceStates(ds, cursor, count, states);\n JSONArray jobs = new JSONArray();\n for (MapReduceState state : states) {\n jobs.put(state.toJson(false));\n }\n \n JSONObject retValue = new JSONObject();\n try {\n retValue.put(\"jobs\", jobs);\n if (newCursor != null) {\n retValue.put(\"cursor\", newCursor.toWebSafeString());\n }\n } catch (JSONException e) {\n throw new RuntimeException(\"Hard coded string is null\", e);\n }\n \n return retValue;\n }",
"protected synchronized ArrayList<Person> getResources(Job job) {\n\n // Declarations\n ResourcePool skillGroup;\n ArrayList<Person> candidates;\n boolean areAllRequirementsMet;\n String workerLogLine;\n Person worker;\n HashMap<String, Integer> mapOfNeededSkills;\n\n // Definitions\n candidates = new ArrayList<>();\n areAllRequirementsMet = true;\n workerLogLine = \"\";\n mapOfNeededSkills = new HashMap<>();\n\n /**\n * Implementation suggested <a href=\"https://stackoverflow.com/questions/81346\">here</a> as\n * an ideal Java 8 solution. Basically, to more easily keep track of duplicate skills needed\n * (i.e. two cooks for a job), we create a <code>HashMap</code> entry of that skill to\n * <code>mapOfNeededSkills</code> where the value is the number of workers with that skill\n * that are required to complete the job.\n */\n job.getRequirements().forEach((String skill) -> {\n mapOfNeededSkills.merge(skill, 1, Integer::sum);\n });\n\n outerLoop:\n for (String skill : job.getRequirements()) {\n\n // Grab the resource pool possessing all the workers who have this skill in the port\n skillGroup = this.getResourcePools().get(skill);\n\n // If no workers exist in the port with this specific skill...\n if (skillGroup == null) {\n job.getStatusLog().append(\"No qualified workers found for \" + job.getName()\n + \" (\" + job.getParentShip().getName() + \")\\n\");\n\n // Release the chopstick, Socrates\n this.returnResources(candidates);\n job.endJob();\n return new ArrayList<>();\n\n // If the total number of people with this skill is smaller than the needed number...\n } else if (skillGroup.getPersonsInPool().size() < mapOfNeededSkills.get(skill)) {\n job.getStatusLog().append(\"Not enough qualified workers found for \" + job.getName()\n + \" (\" + job.getParentShip().getName() + \")\\n\");\n\n // Gimme the fork, Epicurus\n this.returnResources(candidates);\n job.endJob();\n return new ArrayList<>();\n\n // Otherwise...\n } else {\n\n // For all workers with the required skill\n for (Person person : skillGroup.getPersonsInPool()) {\n\n // If this individual is not employed\n if (!person.getIsWorking()) {\n skillGroup.reservePerson(person);\n candidates.add(person);\n continue outerLoop;\n }\n }\n\n // If no available workers are present, we have to keep waiting\n areAllRequirementsMet = false;\n break;\n }\n } // end outerLoop\n\n // Basically a case of logical conjunction; we only return workers if all cases are true\n if (areAllRequirementsMet) {\n workerLogLine += job.getName() + \" (\" + job.getParentShip().getName() + \") reserving\";\n\n for (int i = 0; i < candidates.size(); i++) {\n worker = candidates.get(i);\n\n if (i == 0) {\n workerLogLine += \" \";\n } else if (i < candidates.size() - 1) {\n workerLogLine += \", \";\n } else {\n workerLogLine += \" & \";\n }\n\n workerLogLine += worker.getName();\n }\n job.getStatusLog().append(workerLogLine + \"\\n\");\n\n return candidates;\n } else {\n\n this.returnResources(candidates);\n return null;\n }\n }",
"public java.util.List<? extends com.lvl6.proto.QuestProto.UserQuestJobProtoOrBuilder> \n getUserQuestJobsOrBuilderList() {\n if (userQuestJobsBuilder_ != null) {\n return userQuestJobsBuilder_.getMessageOrBuilderList();\n } else {\n return java.util.Collections.unmodifiableList(userQuestJobs_);\n }\n }",
"java.util.List<org.tensorflow.proto.distruntime.JobDeviceFilters> \n getJobsList();",
"public static String[] parseHudsonWebURL( String jobURL )\n {\n //!!!! PLEASE note that this code is copied to SourceTreeInfoComposite to avoid interdependencies\n // any change done here has to be duplicated there..\n String serverName = null;\n String jobName = null;\n\n Pattern p = Pattern.compile( \"(.*)/job/([^/]*)/*.*\" );\n Matcher m = p.matcher( jobURL );\n if ( !m.find() )\n return null;\n\n serverName = m.group( 1 );\n jobName = m.group( 2 );\n\n Pattern viewPattern = Pattern.compile( \"(.*)/view.*\" );\n Matcher m2 = viewPattern.matcher( m.group( 1 ) );\n if ( m2.find() )\n serverName = m2.group( 1 );\n return new String[] { serverName, jobName };\n }",
"public List<BatchJob> findAll() {\r\n\t\treturn dao.findAll();\r\n\t}",
"private void storeJobSeekersToJobSeekerList(String jobSeekerDetails)\n {\n String[] allJobSeeker = jobSeekerDetails.split(\";\");\n \n \n for (int line = 0; line < allJobSeeker.length ; line++)\n {\n String[] details = allJobSeeker[line].split(\",\");\n String seekerName = details[0];\n String seekerUsername = details[1];\n String role = details[2];\n String seekerGender = details[3];\n String seekerEmail = details[4];\n String pass = details[5];\n ArrayList<String> seekerSkills = new ArrayList<String>();\n for (int i = 6; i < details.length; i++)\n {\n seekerSkills.add(details[i]);\n }\n int totalUser = userList.size();\n int id = totalUser + 1; \n \n JobSeeker seeker = new JobSeeker();\n seeker.setName(seekerName);\n seeker.setUserName(seekerUsername);\n seeker.setRole(role);\n seeker.setGender(seekerGender);\n seeker.setEmail(seekerEmail);\n seeker.setPassword(pass);\n seeker.setSkillsets(seekerSkills);\n \n jobSeekerList.add(seeker);\n userList.add(seeker);\n }\n }",
"public String getJobName() {\n return this.JobName;\n }",
"public String[][] generarJobs(int numeroJobs,int numeroParametros, Rango[] rangoParametros);",
"public String getJobName() {\n return this.jobName;\n }",
"@Override\n public void onClick(View v) {\n Intent intent = new Intent(UIJobOfferEditor.this, UIResultDisplay.class);\n AsyncTask.execute(new Runnable() {\n @Override\n public void run() {\n // Make sure hashtable gets filled\n CompareService.getRankedJobStrings();\n\n // get current job\n current = DataHandler.GetDataHandlerInstance().GetCurrentJob();\n String formattedComp =\n JOB.title + \" | \" + current.title + \"\\n\" +\n JOB.currentJob + \" | \" + current.currentJob + \"\\n\" +\n JOB.company + \" | \" + current.company + \"\\n\" +\n JOB.city + \" | \" + current.city + \"\\n\" +\n JOB.state + \" | \" + current.state + \"\\n\" +\n JOB.yearlySalary + \" | \" + current.yearlySalary + \"\\n\" +\n JOB.yearlyBonus + \" | \" + current.yearlyBonus + \"\\n\" +\n JOB.teleworkDaysPerWeek + \" | \" + current.teleworkDaysPerWeek + \"\\n\" +\n JOB.retirementBenefit + \" | \" + current.retirementBenefit + \"\\n\" +\n JOB.leaveTime + \" | \" + current.leaveTime;\n intent.putExtra(\"job1\", JOB.title + \", \" + JOB.company);\n intent.putExtra(\"job2\", current.title + \", \" + current.company);\n startActivity(intent);\n }\n });\n }",
"public String getJob_title() {\r\n return job_title;\r\n }",
"protected static void printJobList(List<Job> list) {\n //String indent = \" \";\n String indent = \"\\t\";\n Log.printLine();\n Log.printLine(\"========== OUTPUT ==========\");\n Log.printLine(\"Job ID\" + indent + indent + \"Task ID\" + indent + indent + \"STATUS\" + indent + indent\n + \"Data center ID\" + indent + \"VM ID\" + indent + indent\n + \"Time\" + indent + indent + \"Start Time\" + indent + \"Finish Time\" + indent + \"Depth\");\n DecimalFormat dft = new DecimalFormat(\"###.##\");\n for (Job job : list) {\n \tLog.print(job.getCloudletId() + indent + indent);\n if (job.getClassType() == ClassType.STAGE_IN.value) {\n \tLog.print(\"Stage-in\");\n if (job.getCloudletStatus() == Cloudlet.SUCCESS) {\n \tLog.print(indent + \"SUCCESS\");\n \tLog.printLine(indent + indent + job.getResourceId() + indent + indent + job.getVmId()\n + indent + indent + dft.format(job.getActualCPUTime())\n + indent + indent + dft.format(job.getExecStartTime()) + indent + indent\n + dft.format(job.getFinishTime()) + indent + indent + job.getDepth());\n } else if (job.getCloudletStatus() == Cloudlet.FAILED) {\n \tLog.print(\"FAILED\");\n \tLog.printLine(indent + indent + job.getResourceId() + indent + indent + job.getVmId()\n + indent + indent + dft.format(job.getActualCPUTime())\n + indent + indent + dft.format(job.getExecStartTime()) + indent + indent\n + dft.format(job.getFinishTime()) + indent + indent + job.getDepth());\n }\n }\n for (Task task : job.getTaskList()) {\n \tLog.print(task.getCloudletId());\n if (job.getCloudletStatus() == Cloudlet.SUCCESS) {\n \tLog.print(indent + indent + \"SUCCESS\");\n \tLog.printLine(indent + indent + job.getResourceId() + indent + indent + job.getVmId()\n + indent + indent + dft.format(job.getActualCPUTime())\n + indent + indent + dft.format(job.getExecStartTime()) + indent + indent\n + dft.format(job.getFinishTime()) + indent + indent + job.getDepth());\n } else if (job.getCloudletStatus() == Cloudlet.FAILED) {\n \tLog.print(\"FAILED\");\n \tLog.printLine(indent + indent + job.getResourceId() + indent + indent + job.getVmId()\n + indent + indent + dft.format(job.getActualCPUTime())\n + indent + indent + dft.format(job.getExecStartTime()) + indent + indent\n + dft.format(job.getFinishTime()) + indent + indent + job.getDepth());\n }\n }\n //Verbose.toPrint(indent);\n \n \n }\n }",
"public List<Workout> getList() {\n List<Workout> list = new ArrayList<Workout>();\r\n String[] colunas = new String[]{Col_1, Col_2, Col_3, Col_4, Col_5, Col_6, Col_7, Col_8, Col_9};\r\n Cursor cursor = BaseDados.query(\"workout\", colunas, null, null, null, null, \"bodypart ASC\");\r\n if (cursor.getCount() > 0) {\r\n cursor.moveToFirst();\r\n do {\r\n //BodyPart part, int reps, int weight, String cmt\r\n Workout workout = new Workout(new BodyPart(cursor.getString(3), cursor.getInt(7), cursor.getString(4)), cursor.getInt(5), cursor.getInt(8), cursor.getString(6));\r\n workout.setDate(cursor.getInt(0), cursor.getInt(1), cursor.getInt(2));\r\n list.add(workout);\r\n } while (cursor.moveToNext());\r\n }\r\n return list;\r\n }",
"@Digits(integer=9,fraction=0)\n\t@Override\n\tpublic String getJob() {\n\t\treturn super.getJob();\n\t}"
]
| [
"0.71936053",
"0.7036851",
"0.65818185",
"0.65456027",
"0.6541709",
"0.65387976",
"0.65107834",
"0.6460911",
"0.6415815",
"0.6332801",
"0.6220312",
"0.6171023",
"0.6161288",
"0.6061175",
"0.60341644",
"0.6033407",
"0.5968217",
"0.5894654",
"0.58855504",
"0.58797824",
"0.5835661",
"0.58007294",
"0.5760985",
"0.5750461",
"0.57362735",
"0.5718091",
"0.5711644",
"0.5694689",
"0.5651134",
"0.56463873",
"0.5636021",
"0.56137264",
"0.5593073",
"0.5590497",
"0.5588209",
"0.5531222",
"0.5506922",
"0.54915714",
"0.5491318",
"0.5481393",
"0.5470982",
"0.5468172",
"0.54623276",
"0.5457432",
"0.5447887",
"0.54413176",
"0.54321045",
"0.53667367",
"0.5340547",
"0.5339879",
"0.53298306",
"0.53054416",
"0.5297083",
"0.52804315",
"0.5263119",
"0.5245066",
"0.5244927",
"0.5222354",
"0.5217297",
"0.5213801",
"0.52056444",
"0.5187488",
"0.5187348",
"0.5186742",
"0.51859576",
"0.51835245",
"0.517405",
"0.517246",
"0.51703715",
"0.5170055",
"0.51523626",
"0.51416546",
"0.51405275",
"0.5137454",
"0.5127428",
"0.51199883",
"0.5118624",
"0.51161003",
"0.5114182",
"0.5108799",
"0.5108775",
"0.5103579",
"0.5096717",
"0.5077044",
"0.50764006",
"0.5072867",
"0.50699544",
"0.5066299",
"0.5055013",
"0.50545925",
"0.50482434",
"0.50355655",
"0.503511",
"0.50277644",
"0.5023332",
"0.5022533",
"0.5022144",
"0.5016404",
"0.50158566",
"0.5012316"
]
| 0.68029314 | 2 |
<<<<<<< HEAD View a single job | public void goToViewJob(SittingJob job) {
setContentView(R.layout.activity_view_job);
currentJob = job;
Log.w("MA", "goToViewJob");
populateViewJob();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void viewSpecificJob(String jobID) {\n System.out.println(getJobAtIndex(jobID).toString());\n }",
"public String getJobId();",
"public Job getJob();",
"public int getJobId() ;",
"java.lang.String getJobId();",
"@Override\n\tpublic long getJobId() {\n\t\treturn model.getJobId();\n\t}",
"public JobId job() { return Objects.requireNonNull(job, \"production revisions have no associated job\"); }",
"@javax.annotation.Nullable\n @ApiModelProperty(value = \"The identifier of the job\")\n\n public String getJob() {\n return job;\n }",
"public String getJob() {\n return job;\n }",
"@RequestMapping( value = \"/buildJob/{jobName}\", method = RequestMethod.GET)\n public String startJob(@PathVariable(\"jobName\") String jobName) throws IOException {\n QueueReference queueReference= jenkinsServer\n .getJob(jobName)\n .build();\n// .build(scrum_token);\n\n\n\n return queueReference.getQueueItemUrlPart();\n\n }",
"public Dsjob getJobObject() { return job; }",
"@Override\n\tpublic String getJobName() {\n\t\treturn model.getJobName();\n\t}",
"public String getJob() {\r\n\t\t\treturn job;\r\n\t\t}",
"@Override\r\n\tpublic T getJob() {\n\t\treturn super.getJob();\r\n\t}",
"public String getJobId() {\n return this.jobId;\n }",
"public String getJobId() {\n return this.jobId;\n }",
"public String getJobId() {\n return this.jobId;\n }",
"public void setJob(String job) {\n this.job = job;\n }",
"@Digits(integer=9,fraction=0)\n\t@Override\n\tpublic String getJob() {\n\t\treturn super.getJob();\n\t}",
"public Job getJob(){\n return job;\n }",
"public ViewObjectImpl getDcmJobView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmJobView\");\r\n }",
"public interface Job {\n\n /** unique id for this job that is used as a reference in the service methods */\n String getId();\n\n /** job executor identification that has acquired this job and is going to execute it */\n String getLockOwner();\n\n /** in case this is a timer, it is the time that the timer should fire, in case this \n * is a message, it is null. */\n Date getDueDate();\n\n /** in case this is a timer, it is the time that the timer should fire, in case this \n * is a message, it is null.\n * @deprecated call {@link #getDueDate()} instead */\n @Deprecated\n Date getDuedate();\n\n /** exception that occurred during the last execution of this job. The transaction \n * of the job execution is rolled back. A synchronization is used to create \n * a separate transaction to update the exception and decrement the retries. */\n String getException();\n\n /** number of retries left. This is only decremented when an exception occurs during job \n * execution. The transaction of the job execution is rolled back. A synchronization is used to create \n * a separate transaction to update the exception and decrement the retries. */\n int getRetries();\n\n /** indicates if this job should be executed separate from any other job \n * in the same process instance */\n boolean isExclusive();\n\n /** the related execution */\n Execution getExecution();\n\n /** the related process instance */\n Execution getProcessInstance();\n\n Date getLockExpirationTime();\n\n}",
"@RequestMapping(value = \"/getJobApplyPage\", method = RequestMethod.GET)\n public String getJobDetailPage(Model model, Principal principal, @RequestParam(\"postid\") int id) {\n \tJob job = userService.getJobById(id);\n \tmodel.addAttribute(\"job\", job);\n return \"jobDetailPage\";\n }",
"public Job currentJob() {\n \t\treturn currentJob;\n \t}",
"cb.Careerbuilder.Job getJobs(int index);",
"@Override\n public void run() {\n CompareService.getRankedJobStrings();\n\n // get current job\n current = DataHandler.GetDataHandlerInstance().GetCurrentJob();\n String formattedComp =\n JOB.title + \" | \" + current.title + \"\\n\" +\n JOB.currentJob + \" | \" + current.currentJob + \"\\n\" +\n JOB.company + \" | \" + current.company + \"\\n\" +\n JOB.city + \" | \" + current.city + \"\\n\" +\n JOB.state + \" | \" + current.state + \"\\n\" +\n JOB.yearlySalary + \" | \" + current.yearlySalary + \"\\n\" +\n JOB.yearlyBonus + \" | \" + current.yearlyBonus + \"\\n\" +\n JOB.teleworkDaysPerWeek + \" | \" + current.teleworkDaysPerWeek + \"\\n\" +\n JOB.retirementBenefit + \" | \" + current.retirementBenefit + \"\\n\" +\n JOB.leaveTime + \" | \" + current.leaveTime;\n intent.putExtra(\"job1\", JOB.title + \", \" + JOB.company);\n intent.putExtra(\"job2\", current.title + \", \" + current.company);\n startActivity(intent);\n }",
"public String getJobId() {\n\t\treturn this.jobId;\n\t}",
"@Override\n public String getType() {\n return Const.JOB;\n }",
"public String getJobName() {\n return this.mJob;\n }",
"public String getJobName() {\n return this.jobName;\n }",
"public void setJob(String job) {\r\n\t\t\tthis.job = job;\r\n\t\t}",
"public String getJobId() {\n return jobId;\n }",
"long getJobIDTarget();",
"public Job getHadoopJob() ;",
"public String getJobInfo() {\n return jobInfo;\n }",
"public JobStatus getStatus();",
"public Long getJobID() {\n return jobID;\n }",
"public String getJobName() {\n return jobName;\n }",
"public String getJobName() {\n return jobName;\n }",
"public String getJobName() {\n return this.JobName;\n }",
"public int getJobId() {\r\n\t\treturn jobId;\r\n\t}",
"@Override\n\tpublic int getJobStatus() {\n\t\treturn model.getJobStatus();\n\t}",
"public void setJob(Job jobNum){\n job = jobNum;\n }",
"@Deprecated\n//Will be moved to internal scope\npublic interface TaskView {\n /**\n * Specifies the display value of this task plugin. This value is used in the job UI's task dropdown\n * as well as in the title of the task definition dialog box.\n *\n * @return display value for the task plugin\n */\n String displayValue();\n\n /**\n * The template for the task configuration, written using Angular.js templating language.\n *\n * @return Angular.js template for the task configuration\n */\n String template();\n}",
"@DISPID(1)\r\n\t// = 0x1. The runtime will prefer the VTID if present\r\n\t@VTID(7)\r\n\tint jobID();",
"long getJobIDSource();",
"@Test\n public void _03getJob() throws ApiException {\n OCRJobResponse response = api.getJob(ocrJob.getJobId());\n Assert.assertNotNull(response);\n Assert.assertTrue(response.getStatus() == OCRJobResponse.StatusEnum.PROCESSING || response.getStatus() == OCRJobResponse.StatusEnum.DONE);\n }",
"@RequestMapping(value = \"/viewJob/{job_post_id}\", method = RequestMethod.GET)\n\tpublic String viewJob(Model m, @PathVariable Long job_post_id, HttpServletRequest req) {\n\t\tSystem.out.println(\"I'm viewing job\");\n\t\tHttpSession session = req.getSession();\n\t\tString uriReadJobPost = SMART_HIRE_URL + \"/jobPostRC/read/\" + job_post_id + \"/\";\n\t\tString uriReadEmployer = SMART_HIRE_URL + \"/employerRC/read/\";\n\t\tString uriReadJobPostSkillsRequirement = SMART_HIRE_URL + \"/jobPostSkillsRC/getListById/\" + job_post_id + \"/\";\n\t\tString uriReadJobPostSkillsReq = SMART_HIRE_URL + \"/jobPostSkillsRC/getListById/\";\n\n\t\tString username = (String) session.getAttribute(\"username\");\n\t\tSystem.out.println(\"session username = \" + username);\n\t\tString firstname = (String) session.getAttribute(\"firstname\");\n\t\tm.addAttribute(\"firstname\", firstname);\n\n\t\tRestTemplate restTemplate = new RestTemplate();\n\t\trestTemplate.setErrorHandler(new DefaultResponseErrorHandler() {\n\t\t\tprotected boolean hasError(HttpStatus statusCode) {\n\t\t\t\treturn false;\n\t\t\t}\n\t\t});\n\n\t\tJobPost jp = null;\n\t\tResponseEntity<JobPost> reJobPost = restTemplate.getForEntity(uriReadJobPost, JobPost.class);\n\t\tif (reJobPost.getBody() != null) {\n\t\t\tjp = reJobPost.getBody();\n\t\t\tSystem.err.println(\"\\nJobPost retrieved!\");\n\t\t\tResponseEntity<Employer> reEmployer = restTemplate\n\t\t\t\t\t.getForEntity(uriReadEmployer + reJobPost.getBody().getUsername() + \"/\", Employer.class);\n\t\t\tif (reEmployer.getBody() != null) {\n\t\t\t\tSystem.out.println(\"Retrieved employer from the job post id = \" + reJobPost.getBody().getJob_post_id());\n\t\t\t\tSystem.err.println(\"Employer retrieved!\");\n\t\t\t\tm.addAttribute(\"emp\", reEmployer.getBody());\n\t\t\t}\n\n\t\t\tResponseEntity<JobPostSkills[]> readSkillsReq = restTemplate\n\t\t\t\t\t.getForEntity(uriReadJobPostSkillsReq + \"/\" + job_post_id + \"/\", JobPostSkills[].class);\n\t\t\tif (readSkillsReq.getBody() != null) {\n\t\t\t\tm.addAttribute(\"skillsReq\", readSkillsReq.getBody());\n\t\t\t\tSystem.err.println(\"Required skills retrieved!\");\n\t\t\t}\n\n\t\t\tm.addAttribute(\"jp\", reJobPost.getBody());\n\t\t\t// m.addAttribute(\"state\", \"viewJob\");\n\t\t} else {\n\t\t\tSystem.err.println(\"read job post failed\");\n\n\t\t}\n\n\t\tsession.setAttribute(\"username\", username);\n\t\tm.addAttribute(\"username\", username);\n\t\tm.addAttribute(\"state\", \"viewJob\");\n\t\tSystem.out.println(\"Proceed to view js.home --> js.job page\");\n\t\treturn \"js.home\";\n\t}",
"public void print(T job) {\n System.out.println(\"Printing job id \" + job.getId() + \": \" + job.getDocument().getText());\n }",
"public int getJobStatus(int jNo);",
"@Override\n public void onClick(View v) {\n Intent intent = new Intent(UIJobOfferEditor.this, UIResultDisplay.class);\n AsyncTask.execute(new Runnable() {\n @Override\n public void run() {\n // Make sure hashtable gets filled\n CompareService.getRankedJobStrings();\n\n // get current job\n current = DataHandler.GetDataHandlerInstance().GetCurrentJob();\n String formattedComp =\n JOB.title + \" | \" + current.title + \"\\n\" +\n JOB.currentJob + \" | \" + current.currentJob + \"\\n\" +\n JOB.company + \" | \" + current.company + \"\\n\" +\n JOB.city + \" | \" + current.city + \"\\n\" +\n JOB.state + \" | \" + current.state + \"\\n\" +\n JOB.yearlySalary + \" | \" + current.yearlySalary + \"\\n\" +\n JOB.yearlyBonus + \" | \" + current.yearlyBonus + \"\\n\" +\n JOB.teleworkDaysPerWeek + \" | \" + current.teleworkDaysPerWeek + \"\\n\" +\n JOB.retirementBenefit + \" | \" + current.retirementBenefit + \"\\n\" +\n JOB.leaveTime + \" | \" + current.leaveTime;\n intent.putExtra(\"job1\", JOB.title + \", \" + JOB.company);\n intent.putExtra(\"job2\", current.title + \", \" + current.company);\n startActivity(intent);\n }\n });\n }",
"public JobDetail getJob(int jobId) \r\n\t{\r\n\t\ttry\r\n\t\t{\r\n\t\t\tSession session = sessionfactory.openSession();\r\n\t\t\tJobDetail jobDetail = (JobDetail) session.get(JobDetail.class, jobId);\r\n\t\t\tsession.close();\r\n\t\t\treturn jobDetail;\r\n\t\t}\r\n\t\tcatch(Exception e)\r\n\t\t{\r\n\t\t\tSystem.out.println(\"Exception Info: \"+e);\r\n\t\t\treturn null;\r\n\t\t}\r\n\t}",
"public Job(int id) {\n this.id = id;\n }",
"public JobID getJobID() {\n \n \t\treturn this.environment.getJobID();\n \t}",
"public void showJobOverview() {\n try {\n // Load job overview.\n FXMLLoader loader = new FXMLLoader();\n loader.setLocation(MainApp.class.getResource(\"view/JobOverview.fxml\"));\n HBox jobOverview = loader.load();\n\n // Set job overview into the center of root layout.\n rootLayout.setCenter(jobOverview);\n\n // Give the controller access to the main app.\n JobOverviewController controller = loader.getController();\n controller.setMainApp(this);\n\n controller.print(\"* Hello! v1.00 * \\n\");\n\n } catch (IOException e) {\n e.printStackTrace();\n }\n }",
"public java.lang.String getJobNumber() {\r\n return jobNumber;\r\n }",
"public static JPanel getJobPanel() {\n return myJobPanel;\n }",
"public String getFullJobName() {\n return jobGroup + \".\" + jobName;\n }",
"@RequestMapping(value = \"todoList/jobInfo/{id}\",method = RequestMethod.GET)\n public String doActions(@PathVariable Integer id, ModelMap modelMap) {\n\t\tSystem.out.println(\"aaa \"+ jDao.getJob(id).get(0).getJobId());\n\t\tmodelMap.put(\"jobForm\", jDao.getJob(id).get(0));\n\t\treturn \"todoList/jobInfo\";\t\n\t\t\n }",
"public StatusCheckDataObject getJob_StatusCheck() {\r\n return job_StatusCheck;\r\n }",
"public interface Job {\n\n public enum Status {\n IDLE,\n RUNNING,\n SUCCESS,\n ERROR,\n FAIL\n }\n\n /**\n * @return the job ID.\n */\n public default JobId getId() {\n return getContext().getId();\n }\n\n /**\n * @return the job status\n */\n public Status getStatus();\n\n /**\n * @return the job priority\n */\n public Priority getPriority();\n\n /**\n * @return The context of this job.\n */\n public JobContext getContext();\n\n /**\n * Run the job using the {@link XProcEngine}.\n */\n public void run(XProcEngine engine);\n\n}",
"@Override\n public String getJobName() {\n return operate_name;\n }",
"@ApiModelProperty(required = true, value = \"JobId of associated job\")\n public String getJobId() {\n return jobId;\n }",
"protected abstract String getJobSubmitId();",
"public Jobs jobs();",
"public int getJobNum()\n\t{\n\t\treturn jobNum;\n\t}",
"@GET\n @Path(\"/job/{id}/tasks\")\n @Produces(MediaType.APPLICATION_JSON)\n public Response getJobTasks(@PathParam(\"id\") String jobId) {\n LGJob lg = Utils.getJobManager().getJob(jobId);\n if (null == lg) {\n return Response.status(404).entity(\"Not found\").build();\n }\n JSONObject result = new JSONObject();\n result.put(\"tasks\",getTasksHelper(lg));\n return Response.status(200).entity(result.toString(1)).build();\n }",
"@Override\n public boolean onStartJob(JobParameters job) {\n\n String id = job.getTag();\n Log.d(\"TAG+++\", \"Job id: \" + id);\n\n Uri uri = ToDoContract.ToDoEntry.CONTENT_URI.buildUpon().appendPath(id).build();\n Cursor mCursor = getContentResolver().query(uri, null, null, null, null);\n if(mCursor != null){\n if(mCursor.getCount() > 0){\n mCursor.moveToFirst();\n String info = mCursor.getString(mCursor.getColumnIndex(ToDoContract.ToDoEntry.COLUMN_INFO));\n String desc = mCursor.getString(mCursor.getColumnIndex(ToDoContract.ToDoEntry.COLUMN_DESC));\n int priority = mCursor.getInt(mCursor.getColumnIndex(ToDoContract.ToDoEntry.COLUMN_PRIORITY));\n Log.d(\"TAG+++\", \"Info: \" + info + \" | Desc: \" + desc + \" | Priority: \" + priority);\n\n //send notification\n MyNotificationUtil.sendNotification(getApplicationContext(), Integer.valueOf(id), info, desc, priority);\n }\n }\n\n\n //is there anything else to do, any background work still running?\n return false;\n }",
"public JobEntry getJob(String jobId)\n {\n JobEntry je = null;\n\n try\n {\n je = schedulerService.getJob(Integer.parseInt(jobId));\n }\n catch (TurbineException e)\n {\n log.error(\"Could not retreive job id #{}\", jobId, e);\n }\n\n return je;\n }",
"public String getJob_title() {\r\n return job_title;\r\n }",
"@Override\r\n\tpublic List<Job> ShowAllJobs() {\n\t\treturn null;\r\n\t}",
"public String getJobID() {\n\t\t\treturn JobID;\n\t\t}",
"public java.lang.String getJobId() {\n java.lang.Object ref = jobId_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n jobId_ = s;\n }\n return s;\n }\n }",
"public String getJobStatus() {\n return this.jobStatus;\n }",
"public String getJobStatus() {\n return this.jobStatus;\n }",
"public JSONObject handleGetJobDetail(String jobId) {\n MapReduceState state;\n try {\n state = MapReduceState.getMapReduceStateFromJobID(ds, JobID.forName(jobId));\n } catch (EntityNotFoundException e) {\n throw new IllegalArgumentException(\"Couldn't find MapReduce for id:\" + jobId, e);\n }\n return state.toJson(true);\n }",
"public void setJobId( int jobId ) ;",
"@GET\n @Path( \"/start/{id : .+}\" )\n @Produces( { MediaType.APPLICATION_JSON } )\n public JobStatus startJob( @PathParam( \"id\" ) String id ) {\n Job job = CarteResource.getJob( id );\n CarteObjectEntry entry = CarteResource.getCarteObjectEntry( id );\n try {\n if ( job.isInitialized() && !job.isActive() ) {\n // Re-create the job from the jobMeta\n //\n // We might need to re-connect to the repository\n //\n if ( job.getRep() != null && !job.getRep().isConnected() ) {\n if ( job.getRep().getUserInfo() != null ) {\n job.getRep().connect( job.getRep().getUserInfo().getLogin(), job.getRep().getUserInfo().getPassword() );\n } else {\n job.getRep().connect( null, null );\n }\n }\n\n // Create a new job object to start from a sane state. Then replace\n // the new job in the job map\n //\n synchronized ( this ) {\n JobConfiguration jobConfiguration = CarteSingleton.getInstance().getJobMap().getConfiguration( entry );\n\n String carteObjectId = UUID.randomUUID().toString();\n SimpleLoggingObject servletLoggingObject =\n new SimpleLoggingObject( getClass().getName(), LoggingObjectType.CARTE, null );\n servletLoggingObject.setContainerObjectId( carteObjectId );\n\n Job newJob = new Job( job.getRep(), job.getJobMeta(), servletLoggingObject );\n newJob.setLogLevel( job.getLogLevel() );\n\n // Discard old log lines from the old job\n //\n KettleLogStore.discardLines( job.getLogChannelId(), true );\n\n CarteSingleton.getInstance().getJobMap().replaceJob( entry, newJob, jobConfiguration );\n job = newJob;\n }\n }\n job.start();\n } catch ( KettleException e ) {\n e.printStackTrace();\n }\n return getJobStatus( id );\n }",
"public JobInfo(Class<? extends Job> jobclass) {\n\t\tthis.jobclass = jobclass;\n\t}",
"@CheckForNull\n AbstractProject<?, ?> getJobByName(String name);",
"com.google.cloud.talent.v4.Job getJobs(int index);",
"@Override\n public AsyncJob getJob() {\n final AsyncJob job = s_jobMgr.getAsyncJob(_job.getId());\n return job;\n }",
"@Override\n public String toString() {\n StringBuilder sb = new StringBuilder();\n sb.append(\"{\");\n if (getJobId() != null)\n sb.append(\"JobId: \").append(getJobId()).append(\",\");\n if (getJobStatus() != null)\n sb.append(\"JobStatus: \").append(getJobStatus());\n sb.append(\"}\");\n return sb.toString();\n }",
"private synchronized RunningJobImpl get(final String jobIdentifier) {\n final RunningJobImpl result = this.jobs.get(jobIdentifier);\n if (null == result) {\n throw new RuntimeException(\"Trying to get a RunningJob that is unknown: \" + jobIdentifier);\n }\n return result;\n }",
"private void updatejob() {\n\t\tString course = edt_course.getText().toString();\n\t\tString content = edt_content.getText().toString();\n\t\tjob.setCourseName(course);\n\t\tjob.setJobContent(content);\n\t\tjob.update(new UpdateListener() {\n\t\t\t\n\t\t\t@Override\n\t\t\tpublic void done(BmobException e) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tif (e==null) {\n\t\t\t\t\ttoast(\"更新成功\");\n\t\t\t\t\tUpdateJobActivity.this.finish();\n\t\t\t\t} else {\n\t\t\t\t\ttoast(\"错误:\"+e.getMessage());\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\t}",
"public int getHC_JobDataChange_ID();",
"public GetJobs() {\r\n\t\tsuper();\r\n\t}",
"@Override\n\tpublic void doJob() {\n\t\tSystem.out.println(\"Studying\");\n\t}",
"@RequestMapping(value = \"/showeditcourse/{id}\", method = RequestMethod.GET)\n public String showEditJobCode(@PathVariable(\"id\") Integer id,Model model) {\n\n model.addAttribute(\"jobcodeId\", id);\n return \"editcourse\";\n }",
"@Override\n public String getTypeID() {\n return job_id;\n }",
"public interface JobService {\n boolean registerJob(Job job);\n\n boolean deleteJob(String domain, String jobId);\n\n List<JobWrapper> listJob(String domain);\n\n JobWrapper readJob(String domain, String jobId);\n\n NodeResult readNodeResult(String domain, String jobId, String ip);\n\n boolean runJob(String domain, String jobId);\n\n}",
"public interface MemoryJobInstance<ID> extends JobInstance<ID> {\n\n /**\n * Sets the given id.\n *\n * @param id The id\n */\n void setId(ID id);\n\n /**\n * Returns the version.\n *\n * @return the version\n */\n long getVersion();\n\n /**\n * Sets the given version.\n *\n * @param version The version\n */\n void setVersion(long version);\n\n}",
"public java.lang.String getJobId() {\n java.lang.Object ref = jobId_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n jobId_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }",
"@Override\n public Job getJobPOJO() {\n return jobUnproxied;\n }",
"public BigDecimal getJOB_ID() {\r\n return JOB_ID;\r\n }",
"public interface JobHistoryRepository extends CrudRepository<JobHistoryEntity,Long> {\n List<JobHistoryEntity> findByJob(JobEntity file);\n}",
"@Override\n\tpublic void setJob(String job) {\n\t\tsuper.setJob(job);\n\t}",
"boolean hasJobId();",
"public String getJob_description() {\r\n return job_description;\r\n }",
"public static void jobReadTest() {\n String fl = \"/tmp/basic-aurora/basic-aurora3354891958097304472/twister2-core/basic-aurora.job\";\n JobAPI.Job job = JobUtils.readJobFile(fl);\n System.out.println(\"job name: \" + job.getJobName());\n System.out.println(\"job worker class name: \" + job.getWorkerClassName());\n System.out.println(\"job workers: \" + job.getNumberOfWorkers());\n System.out.println(\"CPUs: \" + job.getComputeResource(0).getCpu());\n System.out.println(\"RAM: \" + job.getComputeResource(0).getRamMegaBytes());\n System.out.println(\"Disk: \" + job.getComputeResource(0).getDiskGigaBytes());\n JobAPI.Config conf = job.getConfig();\n System.out.println(\"number of key-values in job conf: \" + conf.getKvsCount());\n\n for (JobAPI.Config.KeyValue kv : conf.getKvsList()) {\n System.out.println(kv.getKey() + \": \" + kv.getValue());\n }\n\n }"
]
| [
"0.669832",
"0.64687675",
"0.64625674",
"0.64141303",
"0.6353682",
"0.6301035",
"0.62134254",
"0.60975343",
"0.60197234",
"0.60127765",
"0.60091436",
"0.59815216",
"0.5948216",
"0.59303695",
"0.5859054",
"0.5859054",
"0.5859054",
"0.58201265",
"0.5819274",
"0.581448",
"0.5807295",
"0.57354546",
"0.5730295",
"0.5723983",
"0.5714479",
"0.56797165",
"0.5637931",
"0.5634946",
"0.561091",
"0.5609578",
"0.55831",
"0.5571061",
"0.5533931",
"0.55281377",
"0.5506321",
"0.5496837",
"0.54856503",
"0.54821247",
"0.54821247",
"0.5466863",
"0.54610044",
"0.5455856",
"0.54507893",
"0.54356927",
"0.54345083",
"0.54302585",
"0.5429441",
"0.5415607",
"0.53916675",
"0.5379889",
"0.5369081",
"0.5364982",
"0.5360707",
"0.5352614",
"0.5348353",
"0.5344545",
"0.5326428",
"0.53186613",
"0.5318403",
"0.5304345",
"0.5297697",
"0.5290522",
"0.5290503",
"0.5279105",
"0.527105",
"0.5255429",
"0.525093",
"0.52183",
"0.52106774",
"0.52098703",
"0.5198099",
"0.51967466",
"0.5196153",
"0.5177646",
"0.5177646",
"0.5172391",
"0.51649535",
"0.51576227",
"0.5156623",
"0.5154082",
"0.51511216",
"0.51382947",
"0.5122303",
"0.5121524",
"0.51166683",
"0.5110336",
"0.51058924",
"0.5104362",
"0.5101554",
"0.5097258",
"0.509269",
"0.5079396",
"0.5078424",
"0.5070837",
"0.5067253",
"0.5066451",
"0.50647223",
"0.506035",
"0.5055545",
"0.5047982"
]
| 0.614853 | 7 |
<<<<<<< HEAD Go back to the dashboard | public void goBackAllJobs(View v) {
finish();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void goBack() throws IOException { DashboardController.dbc.loadHomeScene(); }",
"public void actionPerformed(ActionEvent e)\r\n\t\t{\n\t\t\tif(true)\r\n\t\t\t{\r\n\t\t\t\tUser u ;\r\n\t\t\t\tu = DataBase.findUser(mail.getText());\r\n\t\t\t\tnew Home_Page(u);\r\n<<<<<<< HEAD\r\n\t\t\t\t\r\n\t\t\t\t\r\n=======\r\n\t\t\t\tframe.setVisible(false);\r\n>>>>>>> refs/remotes/origin/master\r\n\t\t\t}\t\r\n\r\n\t\t}\r\n\t }",
"@Override\n protected void onSubmit() {\n getCommander().resetUserHistory( getUser().getUsername(), true );\n redirectHere();\n }",
"@Override\n\tpublic void goHome() {\n\t\tSystem.out.println(\"回窝了!!!!\");\n\t}",
"@Secured(\"@\")\n public void doBackPage() {\n infoOrderDetail = false;\n haveDepositPrice = false;\n orderStockTag.resetOrderStock();\n }",
"private void backButtonAction() {\n CurrentUI.changeScene(SceneNames.LOGIN);\n }",
"public void goHome() {\n shouldWork = false;\n }",
"void updateDashboard() {\n\t}",
"@Override\n public void onClick(int dashboardId) {\n // We aren't using this method in this application\n }",
"public void goHome() {\r\n\t\tif (mActivity instanceof DashboardActivity) {\r\n\t\t\treturn;\r\n\t\t}\r\n\r\n\t\tfinal Intent intent = new Intent(mActivity, DashboardActivity.class);\r\n\t\tintent.setFlags(Intent.FLAG_ACTIVITY_CLEAR_TOP);\r\n\t\tmActivity.startActivity(intent);\r\n\r\n\t}",
"@Override\n public final void switchBack() {\n }",
"public static void switch_back_frame() throws CheetahException {\n\t\tCheetahEngine.logger.logMessage(null, \"SeleniumActions\", \"Attempting to Switch back from frame\",\n\t\t\t\tConstants.LOG_INFO);\n\n\t\ttry {\n\t\t\tCheetahEngine.getDriverInstance().switchTo().defaultContent();\n\t\t} catch (Exception e) {\n\t\t\tthrow new CheetahException(e);\n\t\t}\n\t}",
"@Override\n\tpublic void DoGoToCashier() {\n\t\t\n\t}",
"private void setupBack() {\n\t\tmakeButton(\"Back\", (ActionEvent e) -> {\n\t\t\tchangeView(\"login\");\n\t\t});\n\t}",
"private String doGoBack( HttpServletRequest request )\r\n {\r\n String strJspBack = request.getParameter( StockConstants.MARK_JSP_BACK );\r\n\r\n return StringUtils.isNotBlank( strJspBack ) ? ( AppPathService.getBaseUrl( request ) + strJspBack )\r\n : ( AppPathService.getBaseUrl( request ) + JSP_MANAGE_CATEGORYS );\r\n }",
"public void back() {\n Views.goBack();\n }",
"public void gitThis(){\n\t}",
"public void goHome() throws ManipulatorException;",
"@Override\n\tpublic void msgExitHome() {\n\t\t\n\t}",
"@FXML\n void onActGoBack(ActionEvent event) throws IOException {\n sceneManage(\"/View/Reports.fxml\", event);\n }",
"public String back() {\r\n\t\treturn \"/private/admin/Admin?faces-redirect=true\";\r\n\t}",
"@Override\n\tpublic void goToBack() {\n\t\tif(uiHomePrestamo!=null){\n\t\tuiHomePrestamo.getHeader().getLblTitulo().setText(constants.prestamos());\n\t\tuiHomePrestamo.getHeader().setVisibleBtnMenu(true);\n\t\tuiHomePrestamo.getContainer().showWidget(1);\n\t\t}else if(uiHomeCobrador!=null){\t\t\t\t\t\t\t\t\t\t\t\n\t\t\tuiHomeCobrador.getContainer().showWidget(2);\n\t\t\tuiHomeCobrador.getUiClienteImpl().cargarClientesAsignados();\n\t\t\tuiHomeCobrador.getUiClienteImpl().reloadTitleCobrador();\n\t\t}\n\t}",
"@Override\r\n\tpublic void backButton() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void back() {\nPizzaHut.main(null);\r\n\t}",
"@Override\r\n\tpublic String back() {\n\t\treturn RDIR + \"homeContents\";\r\n\t}",
"private void home(HttpServletRequest request, HttpServletResponse response) throws ServletException, IOException {\n\t\tresponse.sendRedirect(\"/WebBuyPhone/admin/darkboard.jsp\");\n\t}",
"public void showHistorySwitchAction() {\n\t\tanimalsListPanel.switchToPast();\n\t}",
"public String returnToPreviousPage() {\n if (datasetVersion.isDraft()) {\n return \"/dataset.xhtml?persistentId=\" +\n datasetVersion.getDataset().getGlobalId().asString() + \"&version=DRAFT&faces-redirect=true\";\n }\n return \"/dataset.xhtml?persistentId=\"\n + datasetVersion.getDataset().getGlobalId().asString()\n + \"&faces-redirect=true&version=\"\n + datasetVersion.getVersionNumber() + \".\" + datasetVersion.getMinorVersionNumber();\n }",
"private void navigateToDefaultView() {\n\t\tif (navigator!=null && \"\".equals(navigator.getState())) {\n\t\t\t// TODO: switch the view to the \"dashboard\" view\n\t\t}\n\t}",
"private void back_home(HttpServletRequest request, HttpServletResponse response) throws IOException {\n\t\tresponse.sendRedirect(\"restaurant\");\n\t\treturn;\n\t}",
"public void goHome();",
"public void back(){\n\t\tswitch(state){\n\t\tcase LOGINID:\n\t\t\tbreak; //do nothing, already at top menu\n\t\tcase LOGINPIN:\n\t\t\tloginMenu();\n\t\t\tbreak;\n\t\tcase TRANSACTION:\n\t\t\tbreak; //do nothing, user must enter the choice to log out\n\t\tcase DEPOSIT:\n\t\t\ttransactionMenu();\n\t\t\tbreak;\n\t\tcase DEPOSITNOTIFICATION:\n\t\t\tbreak; //do nothing, user must press ok\n\t\tcase WITHDRAW:\n\t\t\ttransactionMenu();\n\t\t\tbreak;\n\t\tcase BALANCE:\n\t\t\tbreak; //do nothing, user must press ok\n\t\tcase WITHDRAWALNOTIFICATION:\n\t\t\tbreak; //do onthing, user must press ok\n\t\t}\n\t\t\n\t\tcurrentInput = \"\";\n\t}",
"@Override\n\tpublic void backButton() {\n\n\t}",
"@Override\n public void goBack() {\n\n }",
"private void goGuide() {\n }",
"public void gotoAdminLogin(){ application.gotoAdminLogin(); }",
"public void goBack() {\n goBackBtn();\n }",
"private void backPage()\n {\n page--;\n open();\n }",
"default public void clickBack() {\n\t\tclickMenu();\n\t}",
"@FXML\r\n private void handleBackButton() {\r\n\r\n CommonFunctions.showAdminMenu(backButton);\r\n\r\n }",
"public void naviagteBackToPage() {\n\t\tgetDriver().close();\n\t}",
"@Override\r\n\tpublic void beforeNavigateBack(WebDriver arg0) {\n\t\t\r\n\t}",
"protected void goBack() {\r\n\t\tfinish();\r\n\t}",
"@Override\n\tpublic void onBackPressed() {\n\treturn;\n\t}",
"public void back(ActionEvent actionEvent) throws IOException {\n new PageLoader().load(\"Login\");\n }",
"public String home()\n\t{\n\t\treturn SUCCESS;\n\t}",
"@Override\n public void onBackPressed() {\n if (!mEditSymptomChanged) {\n super.onBackPressed();\n return;\n }\n //otherwise if there are unsaved changes setup a dialog to warn the user\n //handles the user confirming that changes should be made\n mHomeChecked = false;\n showUnsavedChangesDialogFragment();\n }",
"public void checkOut() {\n\t}",
"void actionBack();",
"public void backToHome(){\n logger.debug(\"click on Back to Home button\");\n driver.findElement(oBackToHome).click();\n }",
"public void gotoHome(){ application.gotoHome(); }",
"private void goBack() {\n View.clearViews();\n View.cambiar(\"operador.cliente\", new RegistrarClientes(operador));\n }",
"void goMainScreen(){\n\t\tcheckSavePwd();\n\t\tActionEvent e = new ActionEvent();\n\t\te.sender = this;\n\t\te.action = ActionEventConstant.ACTION_SWITH_TO_CATEGORY_SCREEN;\n\t\tUserController.getInstance().handleSwitchActivity(e);\n\t}",
"@Override\r\n public void onClickHome(View view) {\r\n \t// if user is performing an IMCI or CCM assessment then \r\n \t// display a confirmation dialog to confirm that the user wishes \r\n \t// to exit the patient assessment\r\n \texitAssessmentDialogHandler();\r\n }",
"public void back()\n\t{\n\t\tdriver.findElementById(OR.getProperty(\"BackButton\")).click();\n\t}",
"@Override\n public void onClick(View v) {\n XhookApp.getPreferences().edit().remove(PREF_LAST_SEEN_BINARY).commit();\n vInstallRevertedWarning.setVisibility(View.GONE);\n }",
"@Override\n\tpublic void onBackPressed() {\n\t\treturn;\n\t}",
"@Override\n\tpublic void cookAtHome() {\n\t\t\n\t}",
"@Override\n\tpublic void beforeNavigateBack(WebDriver arg0) {\n\n\t}",
"private void goToMainPage() {\n mAppModel.getErrorBus().removePropertyChangeListener(this);\n mAppModel.removePropertyChangeListener(this);\n mNavigationHandler.goToMainPage();\n }",
"private void backButton() {\n navigate.goPrev(this.getClass(), stage);\n }",
"@Override\n void undo() {\n assert false;\n }",
"public void checkout() {\n\t}",
"private void navBack() {\n Intent intent = new Intent(this, standard_home.class);\n startActivity(intent);\n }",
"@Override\n\tpublic void backToHomePosition() {\n\t\t\n\t}",
"public void transitionToHome() throws RemoteException{\n removeAll();\n mainPanel = new MainPanel(contr);\n add(mainPanel, \"span 1\");\n }",
"@Override\n\tpublic void goToLogin() {\n\t\t\n\t}",
"static public void order66() {\n System.exit(0);\n }",
"@Override\n protected boolean canGoBack() {\n return false;\n }",
"@Override\n public void onClick(View v) {\n try {\n launchActivity(MGERRIT, MGERRIT_AOKP_CHANGELOG);\n } catch (ActivityNotFoundException failToMarket) {\n launchUrl(getString(R.string.url_aokp_gerrit));\n }\n\n }",
"@Override\n public void onBackPressed() {\n chamarTelaInicial(status_recreate);\n }",
"public void cmdRevert(User teller) {\n exit(6, \"Reverting to prior release at the request of {0}. I''ll be right back!\", teller);\n }",
"@Override\n public void onEditHat() {\n\n moveToFragment(0);\n }",
"Request back();",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.activity_kebijakan_privasi);\n\n//<<<<<<< HEAD\n backButton = (ImageView) findViewById(R.id.backButton);\n//=======\n// backButton = (Button)findViewById(R.id.backButton);\n//>>>>>>> 119aa4894c2e45db3ce3b525cae85ac9d9c30345\n\n// backButton.setOnClickListener(new View.OnClickListener() {\n// @Override\n// public void onClick(View v) {\n//\n// startActivity(new Intent(KebijakanPrivasiActivity.this,HomePageActivity.class));\n// finish();\n// }\n// });\n }",
"public void GoBack(ActionEvent actionEvent) throws IOException\n {\n Main.backToMain();\n }",
"< HEAD\n//\t//下滑更新\n//\t\tpublic void CustomReflash(View view){\n//\t\t\trefreshableView = (RefreshableView) view.findViewById(R.id.refreshable_view); \n//\t\t\trefreshableView.setOnRefreshListener(new PullToRefreshListener() { \n//\t @Override \n//\t public void onRefresh() { \n//\t try { \n//\t Thread.sleep(3000); \n//\t } catch (InterruptedException e) { \n//\t e.printStackTrace(); \n//\t } \n//\t refreshableView.finishRefreshing(); \n//\t } \n//\t }, 0); \n//\t \n//\t\t}\n=======\n\t\n>>>>>>> origin/master\n>>>>>>> origin/master\n\n\n\t// 重新整理\n\tpublic void refreshC() {\n\n\t}",
"public String back2() {\r\n\t\treturn \"/private/admin/Aktienerfassen?faces-redirect=true\";\r\n\t}",
"public void navigate_back() throws CheetahException {\n\t\ttry {\n\t\t\tCheetahEngine.getDriverInstance().navigate().back();\n\t\t} catch (Exception e) {\n\t\t\tthrow new CheetahException(e);\n\t\t}\n\t}",
"@Override\n\tpublic void beforeNavigateBack(WebDriver driver) {\n\t\t\n\t}",
"@Override\n\tpublic void afterNavigateBack(WebDriver arg0) {\n\n\t}",
"public void cancelBankDdPrintLocation() {\n\t\tSystem.out.println(\"inside cancel \");\n\t\ttry{\n\t\t\tExternalContext context = FacesContext.getCurrentInstance().getExternalContext(); \n\t\t\tcontext.redirect(\"../login/login.xhtml\");\n\t\t} catch(Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"private void boom() {\n showMessage(\"BOOM! Reload to try again\", \"boom\");\n }",
"@Override\r\n\tpublic void onBackPressed() {\n\t\tsuper.onBackPressed();\r\n\t\tif (cmd == ConstantTool.PAY_SUCCESS) {\r\n\t\t\tIntent intent = new Intent(OrderList.this, Homemenu.class);\r\n\t\t\tstartActivity(intent);\r\n\t\t}\r\n\t}",
"@Override\n\tpublic void onBackPressed()\n\t{\n\t}",
"public void GoBack(){\n if (prev_hostgui != null){\n this.setVisible(false);\n prev_hostgui.setVisible(true);\n } else{\n this.setVisible(false);\n prev_guestgui.setVisible(true);\n }\n }",
"public void gotoMain(View view) {\n finish();\n }",
"@Override\n\tpublic void onBackPressed() {\n\t\tsuper.onBackPressed();\n\t\treturn;\n\t}",
"@Override\n public void onBackPressed() {\n confirmExit();\n }",
"public void navigateToDashboard() {\n String currentUrl = driver.getCurrentUrl();\n if(!currentUrl.contains(DashboardPageAddress)) {\n driver.navigate().to(baseUrl + DashboardPageAddress);\n }\n }",
"@FXML\n void goBack(ActionEvent event) throws IOException{\n loadMain(event, session);\n }",
"public void onDiscardClick(){\n if (mHomeChecked){ // at Home Checkmark\n NavUtils.navigateUpFromSameTask(EditSymptomActivity.this);\n }\n if (!mHomeChecked) { // at BackPressed\n finish();\n }\n }",
"@Override\r\n\tpublic void onBackPressed() {\r\n\t\tsuper.onBackPressed();\r\n\t\tlogout();\r\n\t}",
"public void backMenu() {\n openWindowGeneral(\"/gui/administrator/fxml/FXMLMenuAdministrator.fxml\", btnCancel);\n }",
"@Override\n\tpublic void onBackPressed() {\n\t}",
"@Override\n\tpublic void onBackPressed() {\n\t}",
"@Override\n\tpublic void onBackPressed() {\n\t}",
"@Override\n\tpublic void onBackPressed() {\n\t}",
"@Override\r\n public PhoenixDriver back()\r\n {\n return null;\r\n }",
"public void backToMain(ActionEvent event) throws IOException{\n try {\n FXMLLoader loader = new FXMLLoader(getClass().getResource(\"../view/main.fxml\"));\n root = loader.load();\n MainController controller = loader.getController();\n controller.selectTab(1);\n stage = (Stage)((Node)event.getSource()).getScene().getWindow();\n scene = new Scene(root);\n stage.setScene(scene);\n stage.show();\n } catch (IOException e) {\n showError(true, \"Can not load the protected page.\");\n }\n }",
"public void redirectToHomePageNotLoggedIn() {\r\n\t\t\r\n\t\twebAppDriver.get(baseUrl);//+\"?optimizely_x8236533790=0\"\r\n\t\t/*try {\r\n\t\t\twebAppDriver.verifyElementTextContains(By.id(linkLogoutId), \"Logout\", true);\r\n\t\t\tloginAction.clickOnLogOut();\r\n\t\t} catch (Exception e) {\r\n\t\t\t// this is just to do logout if customer is auto logged in during\r\n\t\t\t// reservation\r\n\t\t}\r\n\t\t*/\r\n\t}"
]
| [
"0.60902464",
"0.57860297",
"0.57693964",
"0.5737387",
"0.5717667",
"0.56512094",
"0.56480956",
"0.5602208",
"0.5588247",
"0.55882037",
"0.5583467",
"0.5568901",
"0.55670816",
"0.5552783",
"0.55331",
"0.55320066",
"0.5521436",
"0.5508995",
"0.548035",
"0.54434496",
"0.5428837",
"0.54278857",
"0.54264337",
"0.5426314",
"0.54125917",
"0.5411394",
"0.5392781",
"0.5375953",
"0.5357584",
"0.5356759",
"0.53500825",
"0.5348934",
"0.534623",
"0.53423715",
"0.53413266",
"0.53392607",
"0.53369737",
"0.5335412",
"0.5332045",
"0.5320052",
"0.53167033",
"0.53038514",
"0.53035855",
"0.53025615",
"0.5294978",
"0.5291949",
"0.5287155",
"0.5284076",
"0.52833414",
"0.5281285",
"0.52797586",
"0.527412",
"0.5267228",
"0.5264564",
"0.5259697",
"0.52552253",
"0.5251564",
"0.52502143",
"0.5240222",
"0.5233342",
"0.52297926",
"0.5226882",
"0.5223107",
"0.52076435",
"0.5193816",
"0.5191219",
"0.51812124",
"0.5177352",
"0.51753634",
"0.5168884",
"0.5166883",
"0.5166058",
"0.51572365",
"0.5153963",
"0.5153233",
"0.5149359",
"0.51473796",
"0.51380086",
"0.5135485",
"0.5135315",
"0.5132562",
"0.5130879",
"0.51229817",
"0.51210177",
"0.51187927",
"0.51184577",
"0.5118176",
"0.5114472",
"0.5107363",
"0.5103959",
"0.5103313",
"0.5103077",
"0.5102144",
"0.5101348",
"0.5098264",
"0.5098264",
"0.5098264",
"0.5098264",
"0.5092483",
"0.5087286",
"0.5083964"
]
| 0.0 | -1 |
<<<<<<< HEAD Go back to the sitter page | public void goBackViewJob(View v) {
setContentView(R.layout.activity_sitter_page);
if(jobType.equals("open")) {
((TextView) findViewById(R.id.allAcceptedJobsTitle)).setText("Available Jobs");
}
else if(jobType.equals("owner")) {
((TextView) findViewById(R.id.allAcceptedJobsTitle)).setText("Your Open Jobs");
}
else {
((TextView) findViewById(R.id.allAcceptedJobsTitle)).setText("Accepted Jobs");
}
allJobsList();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void gitThis(){\n\t}",
"public static void main(String[] args) {\nSystem.out.println(\"nagarjuna is .................\");\r\n//second commit\r\nSystem.out.println(\"vinay is ..............................\");\r\n//third commit\r\nSystem.out.println(\"vinay is a ?\");\r\n\t}",
"private void generateConflict(String fileName,\n String headContent, String givenContent) {\n File theFile = new File(Main.CWD, fileName);\n if (givenContent == null) {\n givenContent = \"\";\n }\n if (headContent == null) {\n headContent = \"\";\n }\n String mes = \"<<<<<<< HEAD\\n\" + headContent\n + \"=======\\n\" + givenContent + \">>>>>>>\\n\";\n Utils.writeContents(theFile, mes);\n }",
"Response head(String repoName, String repoPath, UriInfo baseURI);",
"public void testGitHub() {\n\t}",
"public void actionPerformed(ActionEvent e)\r\n\t\t{\n\t\t\tif(true)\r\n\t\t\t{\r\n\t\t\t\tUser u ;\r\n\t\t\t\tu = DataBase.findUser(mail.getText());\r\n\t\t\t\tnew Home_Page(u);\r\n<<<<<<< HEAD\r\n\t\t\t\t\r\n\t\t\t\t\r\n=======\r\n\t\t\t\tframe.setVisible(false);\r\n>>>>>>> refs/remotes/origin/master\r\n\t\t\t}\t\r\n\r\n\t\t}\r\n\t }",
"public static void main(String[] args) {\nint score = 91;\nString grade;\nif (score >90)\n{\n\tgrade = \"A\";\n}\n\n\n\nelse if (score>=80)\n{\n\tgrade = \"B\";\n}\n//THis is to test Git\n//THis is to test Git\n//THis is to test Git2\n//This is to test the brach made by gitdemo\n//Change from GitX\nelse \n{\n\tgrade = \"C\";\n}\nSystem.out.println(grade);\n}",
"@SuppressWarnings(\"unused\")\n\tprivate void version() {\n\n\t}",
"public static void main(String[] args) {\nSystem.out.println(\"this is git learing \");\n\t}",
"public static void main(String[] args) {\n\t\tSystem.out.println(\"Hola_Git\"\r\n\t\t\t\t+ \"Un placer\");\r\n\t\tSystem.out.println(\"change2\");\r\n\t\t\r\n\t}",
"public void checkout() {\n\t}",
"public static void main(String[] args) {\n\t\tSystem.out.println(\"trying git\"); \r\n\t\tSystem.out.println(\"Getting there\");\r\n\t\t//Faisel\r\n\t}",
"private void checkout(){\n Scanner input = new Scanner(System.in);\n System.out.println(\"checkout commit : \");\n System.out.println(\"masukan nama commit : \"); // nama commit bukan kode hash\n String value = input.nextLine();\n \n // overwrite file commit ke file-untuk-git\n overWriteFile(\"file-untuk-git\", value + \".txt\", false);\n \n \n }",
"public static void main(String[] args) {\nSystem.out.println(\"This is for git\");\n\t}",
"@Override\n\tpublic void cookAtHome() {\n\t\t\n\t}",
"protected void post_commit_hook() { }",
"void updateBranch(Commit newt) {\n String nextBranch = null;\n Commit theNext = null;\n File parent = new File(\".gitlet/current\");\n for (File file : parent.listFiles()) {\n nextBranch = file.getName();\n }\n try {\n File getHead = new File(\".gitlet/heads/\" + nextBranch);\n FileOutputStream fieOut = new FileOutputStream(getHead);\n ObjectOutputStream obetOut = new ObjectOutputStream(fieOut);\n obetOut.writeObject(newt);\n } catch (IOException e) {\n System.out.println(\"Didn't work.\");\n }\n try {\n File hideous = new File(\".gitlet/current/\" + nextBranch);\n FileOutputStream ieOut = new FileOutputStream(hideous);\n ObjectOutputStream betOut = new ObjectOutputStream(ieOut);\n betOut.writeObject(newt);\n } catch (IOException e) {\n System.out.println(\"Didn't work.\");\n }\n }",
"protected void contributeToHead(final StringBuffer contributionBuffer) {\r\n\r\n\t}",
"public static void main(String[] args) {\nSystem.out.println(\"day one example how to use git\");\r\n\t}",
"< HEAD\n//\t//下滑更新\n//\t\tpublic void CustomReflash(View view){\n//\t\t\trefreshableView = (RefreshableView) view.findViewById(R.id.refreshable_view); \n//\t\t\trefreshableView.setOnRefreshListener(new PullToRefreshListener() { \n//\t @Override \n//\t public void onRefresh() { \n//\t try { \n//\t Thread.sleep(3000); \n//\t } catch (InterruptedException e) { \n//\t e.printStackTrace(); \n//\t } \n//\t refreshableView.finishRefreshing(); \n//\t } \n//\t }, 0); \n//\t \n//\t\t}\n=======\n\t\n>>>>>>> origin/master\n>>>>>>> origin/master\n\n\n\t// 重新整理\n\tpublic void refreshC() {\n\n\t}",
"public static void main(String[] args) {\n\t\tSystem.out.println(\"git hi\");\r\n\t\tSystem.out.println(\"git 연습1\");\r\n\t}",
"public void cmdRecompile(User teller) {\n exit(5, \"Deploying version update at the request of {0}. I''ll be right back!\", teller);\n }",
"public GitRef getHead() { return getRef(Constants.HEAD); }",
"public static void main(String[] args) {\n\r\n\t\tSystem.out.println(\"github\");\r\n\t\t\r\n\t\tSystem.out.println(\"changed it for job text\");\r\n\t}",
"void commit(boolean isMajor);",
"public static void main(String[] args) {\n\t\tSystem.out.println(\"Hellow GitHub!!!\");\n\t\t// commit testing...\n\t\t// add: line 9 write...\n\t\tSystem.out.println(\"add code\");\n\t\t\n\t\tint a = 0;\n\t\tfor(int i=0; i<5; i++) {\n\t\t\ta++;\n\t\t}\n\t\tSystem.out.println(a);\n\t}",
"public static void main(String[] args) {\n\t\tSystem.out.println(\" commit\");\n\t\tSystem.out.println(\"3rd commit\");\n\t\tSystem.out.println(\"final commit\");\n\t\tSystem.out.println(\"pull\");\n\t}",
"public void checkout(String name) throws IOException {\n\t\tif (myBranch.keySet().contains(name)) {\n\t\t\tif (conflictState) {\n\t\t\t\tSystem.out\n\t\t\t\t\t\t.println(\"Cannot do this command until the merge conflict has been resolved.\");\n\t\t\t\treturn;\n\t\t\t}\n\t\t\tif (name == currentBranch) {\n\t\t\t\tSystem.out.println(\"No need to checkout the current branch.\");\n\t\t\t\treturn;\n\t\t\t}\n\t\t\tfor (String s : myBranch.get(name).file().keySet()) {\n\t\t\t\tcheckoutHelper(s);\n\t\t\t\tFile before = new File(myBranch.get(name).file().get(s));\n\t\t\t\tFile after = new File(\"./\" + s);\n\t\t\t\tcopyFile(before.getCanonicalPath(), after.getCanonicalPath());\n\t\t\t}\n\t\t\tcurrentBranch = name;\n\t\t\tmyHead = myBranch.get(name);\n\t\t\ttracked = myHead.file();\n\n\t\t} else if (myHead.file().keySet().contains(name)) {\n\t\t\tcheckoutHelper(name);\n\t\t\tString path = myHead.file().get(name);\n\t\t\tFile workingDirectory = new File(\".\");\n\t\t\tFile result = new File(workingDirectory.getCanonicalPath() + \"/\"\n\t\t\t\t\t+ name);\n\t\t\tcopyFile(path, result.getCanonicalPath());\n\t\t} else {\n\t\t\tSystem.out\n\t\t\t\t\t.println(\"File does not exist in the most recent commit, or no such branch exists.\");\n\t\t}\n\t\tSerialization();\n\t}",
"public static void main(String[] args) {\n\r\n\t\tSystem.out.println(\"Submitted Fourth project -branch 2 shelve\");\r\n\t}",
"public void test431874() throws Exception\n {\n executeTidyTest(\"431874.html\");\n assertWarnings(2);\n }",
"public void printModified() {\n System.out.println(\"\\n\"\n + \"=== Modifications Not Staged For Commit ===\");\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.activity_kebijakan_privasi);\n\n//<<<<<<< HEAD\n backButton = (ImageView) findViewById(R.id.backButton);\n//=======\n// backButton = (Button)findViewById(R.id.backButton);\n//>>>>>>> 119aa4894c2e45db3ce3b525cae85ac9d9c30345\n\n// backButton.setOnClickListener(new View.OnClickListener() {\n// @Override\n// public void onClick(View v) {\n//\n// startActivity(new Intent(KebijakanPrivasiActivity.this,HomePageActivity.class));\n// finish();\n// }\n// });\n }",
"public void referToSpecialist(){\r\n\t\t//here is some code that we do not have access to\r\n\t}",
"private void goGuide() {\n }",
"public static void main(String[] args) {\n\t\tSystem.out.println(\"Hello\");\n\t\t//ADDing comment 1 in testRebase branch\n\t\t//Adding commit2 in testRebase branch\n\t\t\n\t\t\n\t\t//Add commit 1.1 in master branch\n\n\t}",
"public void test559774() throws Exception\n {\n executeTidyTest(\"559774.html\");\n assertNoWarnings();\n }",
"@Override\r\n\tpublic int updateHahtag(int hashtag_no) {\n\t\treturn 0;\r\n\t}",
"private void commitInitialize(String message){\n Scanner input = new Scanner(System.in);\n if(initialize == null) {\n initialize = new GitHead();\n System.out.println(\"tolong bilang saya anda siapa ? \");\n System.out.println(\"tolong isi username dan email\");\n System.out.println(\"masukan username : \");\n String userName = input.nextLine();\n System.out.println(\"masukan email : \");\n String email = input.nextLine();\n initialize.setUserName(userName);\n initialize.setUserEmail(email);\n // pointer.setInitialize(pointer);\n initialize.setHead(initialize);\n initialize.message = message;\n last = initialize;\n }\n overWriteFile(message,\"file-untuk-git.txt\", true);\n }",
"void fetch() throws GitException, InterruptedException;",
"void z_piracy()\n {\n //branch (!f_setup.piracy);\n\n }",
"public void log() {\n String headID = head.getCommitID();\n while (headID != null) {\n File curr = new File(\".gitlet/commits/\" + headID);\n Comm currcomm = Utils.readObject(curr, Comm.class);\n System.out.println(\"===\");\n System.out.println(\"commit \" + currcomm.getCommitID());\n if (currcomm.getMergepointer() != null) {\n System.out.println(\"Merge: \"\n + currcomm.getParent().getCommitID()\n .substring(0, 7) + \" \"\n + currcomm.getMergepointer().getCommitID()\n .substring(0, 7));\n }\n System.out.println(\"Date: \" + currcomm.getDate());\n System.out.println(currcomm.getMessage());\n System.out.println();\n if (currcomm.getParent() == null) {\n break;\n } else {\n headID = currcomm.getParent().getCommitID();\n }\n }\n }",
"static void jump_when_sign(String passed){\n\t\tif(S)\n\t\t\tcomplete_jump_req(passed.substring(3));\n\t}",
"@Override\n\tpublic void preBacktrack() {\n\t\t\n\t}",
"public void test427844() throws Exception\n {\n executeTidyTest(\"427844.html\");\n\n assertNoWarnings();\n }",
"private HelloGitUtil(){\n\t}",
"@Override\n public void onComplete(@NonNull Task<AuthResult> task) {\n<<<<<<< HEAD:Increment-3/Source/ufo/app/src/main/java/com/example/rust/ufo/LoginActivity.java\n progressBar.setVisibility(View.GONE);\n=======\n // progressBar.setVisibility(View.GONE);\n>>>>>>> 5d99259722ed85eb1569d51feee4d1cb7fa6cf5b:Increment - 2/Source/ufo/app/src/main/java/com/example/rust/ufo/LoginActivity.java\n if (!task.isSuccessful()) {\n // there was an error\n\n if (password.length() < 6) {\n Password.setError(getString(R.string.minimum_password));\n } else {\n<<<<<<< HEAD:Increment-3/Source/ufo/app/src/main/java/com/example/rust/ufo/LoginActivity.java\n //Log.w(TAG, \"signInWithEmailAndPassword\", task.getException());\n=======\n // Log.w(TAG, \"signInWithEmailAndPassword\", task.getException());\n>>>>>>> 5d99259722ed85eb1569d51feee4d1cb7fa6cf5b:Increment - 2/Source/ufo/app/src/main/java/com/example/rust/ufo/LoginActivity.java\n Toast.makeText(LoginActivity.this, getString(R.string.auth_failed), Toast.LENGTH_LONG).show();\n }\n } else {\n Intent intent = new Intent(LoginActivity.this, HomepageActivity.class);\n startActivity(intent);\n finish();\n }\n }",
"public String sendHeadSecure(String url)\n\t{\n\t\ttry \n\t\t{\n\t\t\t//Creating URL and connection objects\n\t\t\tURL https_url = new URL(url);\n\t\t\tHttpsURLConnection secure_connection = (HttpsURLConnection)https_url.openConnection();\n\t\t\t//Setting request method to HEAD\n\t\t\tsecure_connection.setRequestMethod(\"HEAD\");\n\t\t\t//Sending all headers except for host (since URLConnection will take care of this)\n\t\t\tfor (String h: headers.keySet())\n\t\t\t{\n\t\t\t\tif (!h.equals(\"Host\"))\n\t\t\t\t{\n\t\t\t\t\tsecure_connection.setRequestProperty(h, headers.get(h));\n\t\t\t\t}\n\t\t\t}\n\t\t\t//Setting all Reposnse Headers \n\t\t\tp = new ResponseParser();\n\t\t\tMap<String,String> p_headers = p.getHeaders();\n\t\t\tMap<String, List<String>> response_headers = secure_connection.getHeaderFields();\n\t\t\tfor (Map.Entry<String, List<String>> entry : response_headers.entrySet()) \n\t\t\t{\n\t\t\t\tif (entry.getKey() == null)\n\t\t\t\t{\n\t\t\t\t\tp.setResponse(entry.getValue().get(0));\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tp_headers.put(entry.getKey(),entry.getValue().get(0));\n\t\t\t\t}\n\t\t\t}\n\t\t\t//If we didn't get any headers in the response, the URL was invalid\n\t\t\tif (p.getHeaders().size() == 0)\n\t\t\t{\n\t\t\t\treturn (\"invalid url\");\n\t\t\t}\n\t\t\t\n\t\t\t//Otherwise return the contents of the returned document\n\t\t\treturn (\"good head\");\n\t\t\t\n\t\t} \n\t\tcatch (IOException | IllegalArgumentException e) \n\t\t{\n\t\t\te.printStackTrace();\n\t\t\treturn \"invalid url\";\n\t\t}\n\t}",
"public void verliesLeven() {\r\n\t\t\r\n\t}",
"public static void main(String[] args) {\n System.out.println(\"GitHub is for everyone!\");\n }",
"public void test427834() throws Exception\n {\n // no warnings\n executeTidyTest(\"427834.html\");\n assertNoWarnings();\n }",
"void replaceWithHEADRevision(Collection<ChangedFile> changedFiles);",
"@Override\n\tpublic void credit() {\n\t\t// TODO Auto-generated method stub\n\t\tSystem.out.println(\"hsbc credit\");\n\t}",
"public void test427827() throws Exception\n {\n // line 6 column 1 - Warning: missing </a> before <a>\n // line 7 column 6 - Warning: discarding unexpected </a>\n // 2 warnings, 0 errors were found!\n\n executeTidyTest(\"427827.html\");\n assertWarnings(2);\n }",
"void branch(String branchName) {\n File curr = new File(\".gitlet/current\");\n String path = null;\n File newBranch = new File(\".gitlet/heads/\" + branchName + \".ser\");\n for (File file: curr.listFiles()) {\n path = file.getName();\n }\n if (newBranch.exists()) {\n System.out.println(\"A branch with that name already exists.\");\n return;\n } else {\n Commit currCom = deserializeCommit(\".gitlet/current/\" + path);\n try {\n FileOutputStream fieOut = new FileOutputStream(newBranch);\n ObjectOutputStream obetOut = new ObjectOutputStream(fieOut);\n obetOut.writeObject(currCom);\n } catch (IOException e) {\n System.out.println(\"p\");\n }\n }\n }",
"public static void branch(String arg){\n commitPointers.branches = commitPointers.readBranches();\n if (commitPointers.branches.containsKey(arg)){\n exitWithError(\"A branch with that name already exists.\");\n }\n\n String headID = commitPointers.readHeadCommit()[1];\n commitPointers.branches.put(arg, headID);\n commitPointers.saveBranches();\n }",
"void hook() {\n\t}",
"public void removeBranch() {\n if (LogWriter.needsLogging(LogWriter.TRACE_DEBUG))\n LogWriter.logMessage(LogWriter.TRACE_DEBUG, \"removeBranch()\");\n Via via=(Via)sipHeader;\n \n via.removeParameter(Via.BRANCH);\n }",
"public void commit(String message) throws IOException {\n\t\t// check whether stage folder is empty\n\t\tboolean check = commitChecker();\n\t\tif (check == false)\n\t\t\treturn;// check whether we can commit now\n\t\tVersion currentCommit = new Version(ID, message, myHead, true,\n\t\t\t\tcurrentBranch);// create a new Version instance\n\t\tFile current = new File(\".gitlet/\" + ID);\n\t\tcurrent.mkdir();// create a folder for this commit\n\t\tif (messageMap.keySet().contains(message)) {\n\t\t\tArrayList<Integer> lst = messageMap.get(message);\n\t\t\tlst.add(ID);\n\t\t} else {\n\t\t\tArrayList<Integer> lst = new ArrayList<Integer>();\n\t\t\tlst.add(ID);\n\t\t\tmessageMap.put(message, lst);// add to the message map\n\t\t}\n\t\tmyCommit.put(ID, currentCommit);// add to commit map\n\t\tfor (String s : stagedFiles) {// find the staged folder and files inside\n\t\t\tFile beCopy = new File(\".gitlet/\" + ID + \"/\" + filenameHelper(s));\n\t\t\tbeCopy.createNewFile();\n\t\t\tcopyFile(\".gitlet/stage/\" + filenameHelper(s),\n\t\t\t\t\tbeCopy.getCanonicalPath());\n\t\t\tcurrentCommit\n\t\t\t\t\t.myMapPut(s, \".gitlet/\" + ID + \"/\" + filenameHelper(s));\n\t\t\tFile fl = new File(\".gitlet/stage/\" + filenameHelper(s));\n\t\t\tfl.delete();// copy the staged file into the new commit folder and\n\t\t\t\t\t\t// delete the file in stage folder\n\t\t}\n\t\tfor (Map.Entry<String, String> f : tracked.entrySet()) {\n\t\t\tif (!stagedFiles.contains(f.getKey())) {\n\t\t\t\tcurrentCommit.myMapPut(f.getKey(), f.getValue());// copy tracked\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// files\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// into the\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// tracked\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// Hashmap\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// of the\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// new\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// Version\n\t\t\t}\n\t\t}\n\t\tstagedFiles = new ArrayList<String>();\n\t\tuntrackedFiles = new ArrayList<String>();\n\t\ttracked = currentCommit.file();// reset tracked files, untracked files\n\t\t\t\t\t\t\t\t\t\t// and staged files\n\t\tmyHead = currentCommit;\n\t\tmyBranch.put(currentBranch, currentCommit);\n\t\tID++;\n\t\tconflictState = false;// other settings\n\t\tSerialization();\n\t}",
"public void Head() {\n\n\t}",
"void reset() throws GitException, InterruptedException;",
"public static String transformGFM(IStoredSettings settings, String input, String repositoryName) {\r\n\t\tString text = input;\r\n\r\n\t\t// strikethrough\r\n\t\ttext = text.replaceAll(\"~~(.*)~~\", \"<s>$1</s>\");\r\n\t\ttext = text.replaceAll(\"\\\\{(?:-){2}(.*)(?:-){2}}\", \"<s>$1</s>\");\r\n\r\n\t\t// underline\r\n\t\ttext = text.replaceAll(\"\\\\{(?:\\\\+){2}(.*)(?:\\\\+){2}}\", \"<u>$1</u>\");\r\n\r\n\t\t// strikethrough, replacement\r\n\t\ttext = text.replaceAll(\"\\\\{~~(.*)~>(.*)~~}\", \"<s>$1</s><u>$2</u>\");\r\n\r\n\t\t// highlight\r\n\t\ttext = text.replaceAll(\"\\\\{==(.*)==}\", \"<span class='highlight'>$1</span>\");\r\n\r\n\t\tString canonicalUrl = settings.getString(Keys.web.canonicalUrl, \"https://localhost:8443\");\r\n\r\n\t\t// emphasize and link mentions\r\n\t\tString mentionReplacement = String.format(\" **[@$1](%1s/user/$1)**\", canonicalUrl);\r\n\t\ttext = text.replaceAll(\"\\\\s@([A-Za-z0-9-_]+)\", mentionReplacement);\r\n\r\n\t\t// link ticket refs\n\t\tString ticketReplacement = MessageFormat.format(\"$1[#$2]({0}/tickets?r={1}&h=$2)$3\", canonicalUrl, repositoryName);\n\t\ttext = text.replaceAll(\"([\\\\s,]+)#(\\\\d+)([\\\\s,:\\\\.\\\\n])\", ticketReplacement);\n\n\t\t// link commit shas\r\n\t\tint shaLen = settings.getInteger(Keys.web.shortCommitIdLength, 6);\r\n\t\tString commitPattern = MessageFormat.format(\"\\\\s([A-Fa-f0-9]'{'{0}'}')([A-Fa-f0-9]'{'{1}'}')\", shaLen, 40 - shaLen);\r\n\t\tString commitReplacement = String.format(\" [`$1`](%1$s/commit?r=%2$s&h=$1$2)\", canonicalUrl, repositoryName);\r\n\t\ttext = text.replaceAll(commitPattern, commitReplacement);\r\n\r\n\t\tString html = transformMarkdown(text);\r\n\t\treturn html;\r\n\t}",
"public void fileNameCheckOut(String fileName) throws IOException {\n String id = getHeadCommitID();\n File commitFile = new File(Main.ALL_COMMITS, id);\n processCheckout(commitFile, fileName);\n }",
"public void saveBeforeJavadoc() { }",
"public void saveBeforeJavadoc() { }",
"private void checkout(ObjectId headId, String refName) throws IOException {\n \t\tif (!Constants.HEAD.equals(refName))\n \t\t\tdb.writeSymref(Constants.HEAD, refName);\n \n \t\tfinal Commit commit = db.mapCommit(headId);\n \t\tfinal RefUpdate u = db.updateRef(Constants.HEAD);\n \t\tu.setNewObjectId(commit.getCommitId());\n \t\tResult result = u.forceUpdate();\n \t\t\n \t\t//X TODO REMOVE DEBUGGING OUTPUT and CHECK RESULT!\n \t\tSystem.out.println(\"updateRef \" + u + \" returned Result=\" + result);\n \n \t\tfinal GitIndex index = db.getIndex();\n \t\tfinal Tree tree = commit.getTree();\n \t\tfinal WorkDirCheckout co;\n \n \t\tco = new WorkDirCheckout(db, db.getWorkDir(), index, tree);\n \t\tco.checkout();\n \t\tindex.write();\n \t}",
"public void merge() throws Exception\n{\n Git git = getGit();\n MergeCommand merge = git.merge();\n ObjectId remoteOriginMaster = getRepo().resolve(\"refs/remotes/origin/master\");\n merge.include(remoteOriginMaster);\n MergeResult result = merge.call();\n System.out.println(\"Merge Result: \" + result.getMergeStatus());\n \n // Reset index\n getIndexSite().resetFiles(); _index = null;\n}",
"public final void mT__38() throws RecognitionException {\n try {\n int _type = T__38;\n int _channel = DEFAULT_TOKEN_CHANNEL;\n // ../org.xtext.example.mydslsample/src-gen/org/xtext/example/mydsl/parser/antlr/internal/InternalMyDslSample.g:38:7: ( 'HEAD' )\n // ../org.xtext.example.mydslsample/src-gen/org/xtext/example/mydsl/parser/antlr/internal/InternalMyDslSample.g:38:9: 'HEAD'\n {\n match(\"HEAD\"); \n\n\n }\n\n state.type = _type;\n state.channel = _channel;\n }\n finally {\n }\n }",
"boolean nack( long revision );",
"private void checkout() {\n throw new UnsupportedOperationException(\"Not yet implemented\");\n }",
"@Override\n\tpublic void goHome() {\n\t\tSystem.out.println(\"回窝了!!!!\");\n\t}",
"void merge(String revSpec) throws GitException, InterruptedException;",
"private void fixNode429()\r\n \t{\r\n \t\tif (! (origFile.getName().equals(\"node429.html\") && pageTitle.contains(\"UNIX-Guru\")))\r\n \t\t\treturn;\r\n \t\tSimpleLogger.verbose(\" Fixing buggy heading...\");\r\n \t\tElement buggyParagraph = (Element) xPathQuery(\"//html:p[contains(text(),'gpGlossar18133')]\").get(0);\r\n \t\tElement heading = new Element(\"h1\");\r\n \t\t//heading.appendChild(\"unix\");\r\n \t\tbodyTag.appendChild(heading);\r\n \t\tElement link = new Element(\"a\");\r\n \t\tlink.appendChild(\"unix\");\r\n \t\theading.appendChild(link);\r\n \t\treplaceNodeBy(buggyParagraph, heading);\r\n \t}",
"public void test545067() throws Exception\n {\n // should NOT output:\n // line 3 column 1 - Warning: <p> isn't allowed in <head> elements\n // since body tags implicitly terminate the <head> section\n\n // ok in jtidy r7\n\n executeTidyTest(\"545067.html\");\n assertLogDoesntContains(\"<head>\");\n }",
"private static void iRebase(Gitlet currCommit, String[] args) {\n if (!isSure()) {\n return;\n } else if (rebaseCheck(currCommit, args)) {\n return;\n } else if (sameHist(currCommit, args[1])) {\n Commit toChange = currCommit.tree.getHeadCommit(args[1]);\n currCommit.tree.setHeadCommit(toChange);\n currCommit.tree.setCommit(Integer.parseInt(toChange.getId()));\n } else {\n Commit split = findSplitBranch(currCommit, args);\n HashMap<String, String> splitMap = split.getFileLoc();\n TreeSet<Commit> tempCurr = currCommit.tree.getCommits();\n TreeSet<Commit> tempBranch = currCommit.tree.getCommits(args[1]);\n TreeSet<Commit> currCommits = (TreeSet<Commit>) tempCurr.subSet(\n currCommit.tree.getHeadCommit(), true, split, true);\n TreeSet<Commit> branchCommits = (TreeSet<Commit>) tempBranch\n .subSet(currCommit.tree.getHeadCommit(args[1]), true,\n split, true);\n int count = 1;\n int size = currCommits.size();\n for (Commit x : currCommits) {\n System.out.println(\"Currently replaying:\");\n System.out.println(x.generateMessage());\n String question = \"Would you like to (c)ontinue, (s)kip this commit, \";\n question += \"or change this commit's (m)essage?\";\n System.out.println(question);\n Scanner in = new Scanner(System.in);\n in = new Scanner(System.in);\n String answer = in.nextLine();\n if (answer.equals(\"s\")) {\n while (true) {\n if (count == 1 || count == size) {\n String error = \"You can not skip, please enter (c)ontinue\";\n error += \" or (m)essage\";\n System.out.println(error);\n answer = in.nextLine();\n }\n if (!answer.equals(\"s\")) {\n break;\n }\n }\n } else if (answer.equals(\"s\") && count != 1 && count != size) {\n continue;\n } else if (answer.equals(\"c\") || answer.equals(\"m\")) {\n currCommit.tree.removeCommit(x);\n currCommit.tree.addSize();\n String newId = currCommit.tree.getSize().toString();\n Commit commitToAdd = x.commitCopy(x, newId);\n\n HashMap<String, String> newMap = propogate(\n x.getFileLoc(),\n currCommit.tree.getHeadCommit(args[1]).getFileLoc(),\n splitMap);\n commitToAdd.setFileLoc(newMap);\n\n currCommit.tree.addData(commitToAdd);\n if (currCommit.tree.getHeadCommit().same(x)) {\n currCommit.tree.setHeadCommit(commitToAdd);\n\n }\n currCommit.tree.addCommit(commitToAdd);\n }\n }\n for (Commit x : branchCommits) {\n currCommit.tree.addCommit(x);\n }\n updateFiles(currCommit);\n }\n addSerializeFile(currCommit);\n }",
"@Override\n public void onMasterBranchVersionChange(String newVersion, String oldVersion, JGitFlowInfo flow) throws MavenJGitFlowExtensionException\n {\n try\n {\n Git git = flow.git();\n\n //get the README.md file\n File readmeFile = new File(flow.getProjectRoot(), README_MD);\n\n //do the replacement\n //NOTE: This is not performant or scalable. It's only here for example purposes.\n String readmeContent = Files.toString(readmeFile, Charsets.UTF_8);\n String newContent = readmeContent.replace(oldVersion, newVersion);\n\n Files.write(newContent, readmeFile, Charsets.UTF_8);\n\n //now commit the change\n JGitFlowCommitHelper.commitAllChanges(flow, \"updating version in README.md\");\n\n }\n catch (Exception e)\n {\n throw new MavenJGitFlowExtensionException(\"Error updating \" + README_MD + \" file!\", e);\n }\n }",
"private void boom() {\n showMessage(\"BOOM! Reload to try again\", \"boom\");\n }",
"public void checkoutbranch(String givenbranch) {\n if (branch.equals(givenbranch)) {\n Utils.message(\"No need to checkout the current branch. \");\n throw new GitletException();\n } else if (!branches.containsKey(givenbranch)) {\n Utils.message(\"No such branch exists.\");\n throw new GitletException();\n } else {\n Comm curr = head;\n if (hasuntracked(curr)) {\n Utils.message(\"There is an untracked file in the way;\"\n + \" delete it or add it first.\");\n throw new GitletException();\n } else {\n head = branches.get(givenbranch);\n branch = givenbranch;\n branches.put(branch, head);\n for (Blob b: head.getContents().values()) {\n File f = new File(b.getName());\n Utils.writeContents(f,\n head.getContents().get(b.getName()).getContent());\n stagingarea.clear();\n }\n deleteuntracked(head);\n }\n }\n }",
"@Override\n protected void onSubmit() {\n getCommander().resetUserHistory( getUser().getUsername(), true );\n redirectHere();\n }",
"Git getGit();",
"public void cmdRevert(User teller) {\n exit(6, \"Reverting to prior release at the request of {0}. I''ll be right back!\", teller);\n }",
"@Override\r\n\tpublic void downloadHomework() {\n\t\t\r\n\t}",
"@Override\n public void onEditHat() {\n\n moveToFragment(0);\n }",
"public void test553414() throws Exception\n {\n executeTidyTest(\"553414.html\");\n assertLogContains(\"given is \\\"-//W3C//DTD XHTML 1.0 Strict//EN\\\"\");\n assertLogContains(\"looks like XHTML 1.0 Transitional\");\n assertWarnings(1);\n }",
"public void merge(String branchName) throws IOException {\n if (!Utils.plainFilenamesIn(INDEX).isEmpty()\n || !Utils.plainFilenamesIn(REMOVAL).isEmpty()) {\n System.out.println(\"You have uncommitted changes.\");\n System.exit(0);\n }\n\n File givenBranch = new File(Main.ALL_BRANCHES, branchName);\n if (!givenBranch.exists()) {\n System.out.println(\" A branch with that name does not exist.\");\n System.exit(0);\n }\n String currentCommit = Utils.readObject(HEADFILE, String.class);\n String givenCommitID = Utils.readObject(givenBranch, String.class);\n if (givenCommitID.equals(currentCommit)) {\n System.out.println(\"Cannot merge a branch with itself.\");\n System.exit(0);\n }\n Commit splitPt = findSplitPt(branchName, new HashSet<>());\n if (splitPt.getShaCode().equals(givenCommitID)) {\n System.out.println(\"Given branch \"\n + \"is an ancestor of the current branch.\");\n System.exit(0);\n }\n if (currentCommit.equals(splitPt.getShaCode())) {\n System.out.println(\"Current branch fast-forwarded.\");\n checkOutBranch(branchName);\n System.exit(0);\n }\n boolean conflictPresent = checkConflict(branchName, splitPt);\n String lgMsg = \"Merged \" + branchName + \" into \"\n + Utils.readObject(HEADNAME, String.class) + \".\";\n String lgWithConflict = \"Encountered a merge conflict.\";\n Commit newCommit = new Commit(lgMsg, currentCommit,\n Utils.readObject(givenBranch, String.class));\n helperCommit(newCommit);\n if (conflictPresent) {\n System.out.println(lgWithConflict);\n System.exit(0);\n }\n }",
"public static void main(String[] args) {\n\n\t\tString mensajeGit = \"Hello Git and GitHub, a bug was fixed!!\";\n\t\t\n\t\t/* String mensajeGit = \"Hello Git!\";\n\t\t * String mensajeGit = \"Hello GitHub!\";\n\t\t * String mensajeGit = \"Hello Git and GitHub!\";\n\t\t * String mensajeGit = \"Hello Git a bug was fixed!!\";\n\t\t * String mensajeGit = \"Hello Git and GitHub, a bug was fixed!!\";\n\t\t*/\n\t\t\n\t\tSystem.out.println(\"<<< \" + mensajeGit + \" >>>\");\n\n\t}",
"public GitFileSite(GitCommit aGC) { _cmt = aGC; setURL(createURL()); }",
"private static void merge(Gitlet currCommit, String[] args) {\n if (!isSure()) {\n return;\n } else if (args.length != 2) {\n System.out.println(\"Please input the branch name\");\n } else if (!currCommit.tree.hasBranch(args[1])) {\n System.out.println(\"A branch with that name does not exist.\");\n } else if (args[1].equals(currCommit.tree.getCurrentBranch())) {\n System.out.println(\"Cannot merge a branch with itself.\");\n } else {\n HashMap<String, String> splitMap = findSplitBranch(currCommit, args)\n .getFileLoc();\n HashMap<String, String> headMap = currCommit.tree.getHeadCommit()\n .getFileLoc();\n HashMap<String, String> mergeMap = currCommit.tree.getHeadCommit(\n args[1]).getFileLoc();\n for (String mergeFile : mergeMap.keySet()) {\n if (splitMap.containsKey(mergeFile)\n && headMap.containsKey(mergeFile)) {\n if (splitMap.get(mergeFile).equals(headMap.get(mergeFile))\n && !headMap.get(mergeFile).equals(\n mergeMap.get(mergeFile))) {\n FileManip origin = new FileManip(\n mergeMap.get(mergeFile));\n origin.copyFile(mergeFile);\n } else if (!splitMap.get(mergeFile).equals(\n headMap.get(mergeFile))\n && !splitMap.get(mergeFile).equals(\n mergeMap.get(mergeFile))) {\n FileManip origin = new FileManip(\n mergeMap.get(mergeFile));\n origin.copyFile(mergeFile + \".conflicted\");\n }\n } else if (!splitMap.containsKey(mergeFile)\n && headMap.containsKey(mergeFile)) {\n FileManip origin = new FileManip(mergeMap.get(mergeFile));\n if (!origin.isSame(headMap.get(mergeFile))) {\n origin.copyFile(mergeFile + \".conflicted\");\n }\n }\n }\n }\n }",
"public void checkout(long chatId) {\n }",
"private void rewriteRepHeader() {\r\n\t\t// assume that the value of headVersionNum has been \r\n\t\t// incremented before coming here\r\n\t\ttry {\r\n\t\t\t// 1. delete current header\r\n\t\t\tif (client==null) this.initAnnoteaClient();\r\n\t\t\tclient.delete(this.repHeaderLoc);\r\n\t\t\t// 2. post new header\r\n\t\t\tDescription header = new Description();\r\n\t\t\tURI[] headerURI = new URI[1];\r\n\t\t\theaderURI[0] = new URI(this.repositoryURI.toString() + \"#header\");\r\n\t\t\theader.setAnnotates(headerURI);\r\n\t\t\theader.setAuthor(this.repositoryAuthor);\r\n\t\t\theader.setCreated(this.reposityCreatedDate);\r\n\t\t\theader.setAnnotatedEntityDefinition(this.baseOntologyURI.toString());\r\n\t\t\theader.setBody(String.valueOf(this.headVersionNumber));\r\n\t\t\theader.setBodyType(\"text/html\");\r\n\t\t\theader.setAnnotationType(this.annotType);\r\n\t\t\t// 3. update new header location URL\r\n\t\t\trepHeaderLoc = client.post(header);\r\n\t\t\t// 4. update value in versionDescriptions array and update swoopModel' versionRepository\r\n\t\t\tthis.versionDescriptions[0] = header;\r\n\t\t\tswoopModel.updateVersionRepository(this.repositoryURI, versionDescriptions);\r\n\t\t}\r\n\t\tcatch (Exception ex) {\r\n\t\t\tex.printStackTrace();\r\n\t\t}\r\n\t}",
"String branch();",
"public static void main(String[] args) {\n\t\t\tSystem.out.println(\"git_test!\");\n\t}",
"public void checkoutfile(String file) {\n\n if (!head.getContents().containsKey(file)) {\n Utils.message(\"File does not exist in that commit.\");\n throw new GitletException();\n }\n File curr = new File(file);\n Utils.writeContents(curr, head.getContents().get(file).getContent());\n }",
"@Test\r\n\tpublic void testScanePage_malformedLink() {\n\t}",
"public void test517528() throws Exception\n {\n executeTidyTest(\"517528.html\");\n\n assertNoWarnings();\n }",
"public abstract void commitSprintBacklog();",
"@Override\n public void followOnGithub() {\n if (sp.getBoolean(\"in_app_browser\",true)){\n CustomTabActivityHelper.openCustomTab(\n activity,\n customTabsIntent.build(),\n Uri.parse(activity.getString(R.string.github_url)),\n new CustomFallback() {\n @Override\n public void openUri(Activity activity, Uri uri) {\n super.openUri(activity, uri);\n }\n });\n } else {\n try{\n activity.startActivity(new Intent(Intent.ACTION_VIEW).setData(Uri.parse( activity.getString(R.string.github_url))));\n } catch (android.content.ActivityNotFoundException ex){\n view.showBrowserNotFoundError();\n }\n }\n }",
"public static void main(String[] args) {\n\t\tSystem.out.println(\"Primer commit\");\r\n\t\tSystem.out.println(\"18/05/2020 - segundo commit\");\r\n\t\tSystem.out.println(\"Rosana - tercer commit\");\r\n\t\tSystem.out.println(\"prueba - sexto commit\");\r\n\t}",
"@FXML\n private void git(MouseEvent event) throws URISyntaxException, IOException {\n Desktop desktop = Desktop.getDesktop();\n desktop.browse(new URI(\"https://github.com/ashMohseni\"));\n }",
"public void markVersionMerge() throws JNCException {\n markLeafMerge(\"version\");\n }",
"void doHome()\n\t{\n\t\ttry\n\t\t{\n\t\t\tLocation l = getCurrentLocation();\n\t\t\tSourceFile file = l.getFile();\n\t\t\tint module = file.getId();\n\t\t\tint line = l.getLine();\n\n\t\t\t// now set it\n setListingPosition(module, line);\n\t\t}\n\t\tcatch(NullPointerException npe)\n\t\t{\n\t\t\terr(getLocalizationManager().getLocalizedTextString(\"currentLocationUnknown\")); //$NON-NLS-1$\n\t\t}\n\t}",
"private void mian() {\n\t\tSystem.out.println(\"提交\");\r\n\t\tSystem.out.println(\"提交2次\");\r\n\t}"
]
| [
"0.6105997",
"0.5584225",
"0.52708507",
"0.52441263",
"0.51579744",
"0.5150096",
"0.510461",
"0.51028055",
"0.503479",
"0.50201184",
"0.5017102",
"0.5014196",
"0.5011363",
"0.50067407",
"0.4996786",
"0.49847195",
"0.49604994",
"0.4956707",
"0.49555567",
"0.49150747",
"0.48758376",
"0.484733",
"0.48130354",
"0.47842667",
"0.47821406",
"0.47787514",
"0.4766328",
"0.4762637",
"0.4756999",
"0.47355992",
"0.47299063",
"0.47290257",
"0.47264835",
"0.4705459",
"0.47050488",
"0.47002333",
"0.46990082",
"0.46914467",
"0.46844083",
"0.46837154",
"0.46757603",
"0.46695545",
"0.46593675",
"0.46592325",
"0.46459877",
"0.46447167",
"0.46339658",
"0.46230185",
"0.46130666",
"0.46116802",
"0.46098045",
"0.4603052",
"0.45887616",
"0.45885462",
"0.4585661",
"0.45854172",
"0.45775285",
"0.45699295",
"0.45674595",
"0.45666456",
"0.45606235",
"0.45516104",
"0.45512176",
"0.45512176",
"0.4551199",
"0.45482597",
"0.45387477",
"0.45352402",
"0.45314077",
"0.45305648",
"0.45271805",
"0.4524556",
"0.45167023",
"0.45126995",
"0.4512641",
"0.45119613",
"0.45097092",
"0.4501503",
"0.45012465",
"0.44997543",
"0.44933096",
"0.44929668",
"0.44886506",
"0.44879898",
"0.44799474",
"0.44709268",
"0.44687226",
"0.44649294",
"0.44623357",
"0.44589803",
"0.4456688",
"0.4443358",
"0.44407266",
"0.4439436",
"0.4435819",
"0.44356048",
"0.4435243",
"0.4432161",
"0.44305226",
"0.4429396",
"0.4423885"
]
| 0.0 | -1 |
This method accepts the job currently being viewed, adding it to the user account | public void acceptJob(View v) {
SittingJob job = currentJob;
try {
Controller.model.deleteJob(currentJob);
Controller.model.openJobs.remove(currentJob);
job.jobInfo.put("sitterIDKey", ""+Controller.currentUser.accountInfo.get("ownerIDKey"));
Controller.model.createJob(job, false);
Log.w("MA", "Success accepting job");
}
catch(JSONException je) {
Log.w("MA", "JSONException accepting a job");
}
setContentView(R.layout.activity_sitter_page);
setjobList();
allJobsList();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void goToViewJob(SittingJob job) {\n setContentView(R.layout.activity_view_job);\n currentJob = job;\n Log.w(\"MA\", \"goToViewJob\");\n populateViewJob();\n }",
"public void saveJob(View v){\n FirebaseDatabase database = FirebaseDatabase.getInstance();\n DatabaseReference mySavedJobsRef = database.getReference(\"Users\").child(currentUser.getUid().toString()).child(\"savedjobs\");\n //Dont save your own jobs\n if(!currentUser.getUid().toString().equals(jobPost.getUserid())) {\n mySavedJobsRef.addListenerForSingleValueEvent(\n new ToggleAddIDVEListener(ViewSingleJobActivity.this,jobPost.getPostid()));\n }\n }",
"public void setJob(String job) {\n this.job = job;\n }",
"public void setJob(String job) {\r\n\t\t\tthis.job = job;\r\n\t\t}",
"public void completeJob(View v) {\n // FIXME save that it is completed somehow\n Log.w(\"MA\", \"completeJob\");\n setContentView(R.layout.activity_sitter_page);\n allJobsList();\n }",
"protected void processJobSubmissionResponse(JobSubmissionResponseTO result) {\n\t\tList<Integer> jobID = result.getJobIDs();\n\t\tUserModel userModel = OurGridPortal.getUserModel();\n\t\tfor (Integer integer : jobID) {\n\t\t\tuserModel.addJobId(getJobViewId(), integer);\n\t\t}\n\t\t\n\t}",
"@Override\n public void run() {\n CompareService.getRankedJobStrings();\n\n // get current job\n current = DataHandler.GetDataHandlerInstance().GetCurrentJob();\n String formattedComp =\n JOB.title + \" | \" + current.title + \"\\n\" +\n JOB.currentJob + \" | \" + current.currentJob + \"\\n\" +\n JOB.company + \" | \" + current.company + \"\\n\" +\n JOB.city + \" | \" + current.city + \"\\n\" +\n JOB.state + \" | \" + current.state + \"\\n\" +\n JOB.yearlySalary + \" | \" + current.yearlySalary + \"\\n\" +\n JOB.yearlyBonus + \" | \" + current.yearlyBonus + \"\\n\" +\n JOB.teleworkDaysPerWeek + \" | \" + current.teleworkDaysPerWeek + \"\\n\" +\n JOB.retirementBenefit + \" | \" + current.retirementBenefit + \"\\n\" +\n JOB.leaveTime + \" | \" + current.leaveTime;\n intent.putExtra(\"job1\", JOB.title + \", \" + JOB.company);\n intent.putExtra(\"job2\", current.title + \", \" + current.company);\n startActivity(intent);\n }",
"public void setJobProgress(JobProgress jobProgress) {\n this.jobProgress = jobProgress;\n }",
"@Override\n public void onClick(View v) {\n Intent intent = new Intent(UIJobOfferEditor.this, UIResultDisplay.class);\n AsyncTask.execute(new Runnable() {\n @Override\n public void run() {\n // Make sure hashtable gets filled\n CompareService.getRankedJobStrings();\n\n // get current job\n current = DataHandler.GetDataHandlerInstance().GetCurrentJob();\n String formattedComp =\n JOB.title + \" | \" + current.title + \"\\n\" +\n JOB.currentJob + \" | \" + current.currentJob + \"\\n\" +\n JOB.company + \" | \" + current.company + \"\\n\" +\n JOB.city + \" | \" + current.city + \"\\n\" +\n JOB.state + \" | \" + current.state + \"\\n\" +\n JOB.yearlySalary + \" | \" + current.yearlySalary + \"\\n\" +\n JOB.yearlyBonus + \" | \" + current.yearlyBonus + \"\\n\" +\n JOB.teleworkDaysPerWeek + \" | \" + current.teleworkDaysPerWeek + \"\\n\" +\n JOB.retirementBenefit + \" | \" + current.retirementBenefit + \"\\n\" +\n JOB.leaveTime + \" | \" + current.leaveTime;\n intent.putExtra(\"job1\", JOB.title + \", \" + JOB.company);\n intent.putExtra(\"job2\", current.title + \", \" + current.company);\n startActivity(intent);\n }\n });\n }",
"protected void configureJob(Job job) {\n\t\tjob.setUser(true);\n\t\tjob.setPriority(Job.LONG);\n\t}",
"protected void doPost(MCRServletJob job) throws Exception {\n\t\torg.apache.shiro.subject.Subject currentUser = SecurityUtils.getSubject();\n\t\tif (currentUser.hasRole(\"userAdmin\")) {\n\t\t\tString type = getParameter(job, \"type\");\n\t\t\tString name = getParameter(job, \"name\");\n\t\t\tif (type.equals(\"userDelete\")) {\n\t\t\t\tUserDAO.deleteUser(name);\n\t\t\t\tLOGGER.info(\"deleted user \" + name);\n\n\t\t\t} else if (type.equals(\"roleDelete\")) {\n\t\t\t\tString roleName = getParameter(job, \"roleName\");\n\t\t\t\tUserRole role = new UserRole();\n\t\t\t\trole.setUsername(name);\n\t\t\t\trole.setRoleName(roleName);\n\t\t\t\tUserRoleDAO.delete(role);\n\t\t\t\tLOGGER.info(\"deleted role \" + roleName + \" for user \" + name);\n\t\t\t} else if (type.equals(\"roleAdd\")) {\n\t\t\t\tString roleName = getParameter(job, \"roleName\");\n\t\t\t\tUserRole role = new UserRole();\n\t\t\t\trole.setUsername(name);\n\t\t\t\trole.setRoleName(roleName);\n\t\t\t\tUserRoleDAO.insert(role);\n\t\t\t\tLOGGER.info(\"added role \" + roleName + \" for user \" + name);\n\t\t\t} \n\t\t\tjob.getResponse().sendRedirect(\"userManagement\");\n\t\t}else {\n\t\t\tElement output = new Element(\"error\").addContent((new Element(\"message\")).addContent(\"error.noPermission\"));\n\t\t\tsendOutput(job,output);\n\t\t}\n\t}",
"@Override\n public void onItemClick(AdapterView<?> parent, View view, int position, long id) {\n Intent newIntent = new Intent(this,UserNavigation.class);\n newIntent.putExtra(\"Job\",jobList.get(position));\n startActivity(newIntent);\n\n }",
"@Override\n public void onLoggedInVerified(User user) {\n bakery.toastShort(user.getEmail());\n loadTaskActivity();\n }",
"@Override\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tdispose();\n\t\t\t\tJobHandler.viewJobs(userID);\n\t\t\t}",
"@Override\n\tpublic void setJob(String job) {\n\t\tsuper.setJob(job);\n\t}",
"void EditWorkerProfileUser(String uid, boolean isWorker, List<Skill> skills);",
"@Override\n public void onClick(View view) {\n Intent intent = new Intent(view.getContext(), PollCreationActivity.class);\n Bundle b = new Bundle();\n b.putSerializable(Constants.UserBundleKey, currentUser);\n intent.putExtras(b);\n startActivity(intent);\n }",
"@Override\n public void onAttach(Activity activity) {\n super.onAttach(activity);\n context=activity;\n userPreferences = new UserPreferences(context);\n jobManager = new JobManager(context);\n }",
"@Override\n protected boolean isCalledForCurrentUserLocked() {\n return true;\n }",
"private void addNewFinishedJobItem(Job job) {\n FinishedJobItemView finishedJobItemView = new FinishedJobItemView(this, job);\n finishedJobItemViews.add(finishedJobItemView);\n finishedJobsLinearLayout.addView(finishedJobItemView);\n }",
"public void setJob(Job jobNum){\n job = jobNum;\n }",
"@Override\n protected void onSubmit() {\n getCommander().resetUserHistory( getUser().getUsername(), true );\n redirectHere();\n }",
"private void updatejob() {\n\t\tString course = edt_course.getText().toString();\n\t\tString content = edt_content.getText().toString();\n\t\tjob.setCourseName(course);\n\t\tjob.setJobContent(content);\n\t\tjob.update(new UpdateListener() {\n\t\t\t\n\t\t\t@Override\n\t\t\tpublic void done(BmobException e) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tif (e==null) {\n\t\t\t\t\ttoast(\"更新成功\");\n\t\t\t\t\tUpdateJobActivity.this.finish();\n\t\t\t\t} else {\n\t\t\t\t\ttoast(\"错误:\"+e.getMessage());\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\t}",
"protected void jobFinished(Progress job) {\n }",
"public void viewSpecificJob(String jobID) {\n System.out.println(getJobAtIndex(jobID).toString());\n }",
"public Job getJob(){\n return job;\n }",
"private void loggedInUser() {\n\t\t\n\t}",
"@Override\n public void addToWatchListClick(boolean isAddedOrNot, ContentDatum contentDatum) {\n currentActivity.sendBroadcast(new Intent(AppCMSPresenter.PRESENTER_PAGE_LOADING_ACTION));\n if (isUserLoggedIn()) {\n editWatchlist(contentDatum.getGist().getId() != null ? contentDatum.getGist().getId() : contentDatum.getId(), appCMSAddToWatchlistResult -> {\n currentActivity.sendBroadcast(new Intent(AppCMSPresenter.PRESENTER_STOP_PAGE_LOADING_ACTION));\n Toast.makeText(currentContext, \"Updated Successfully :\", Toast.LENGTH_LONG);\n }, isAddedOrNot);\n } else {\n if (isAppSVOD() && isUserLoggedIn()) {\n showEntitlementDialog(AppCMSPresenter.DialogType.SUBSCRIPTION_REQUIRED, null);\n } else {\n showEntitlementDialog(AppCMSPresenter.DialogType.LOGIN_REQUIRED, null);\n }\n currentActivity.sendBroadcast(new Intent(AppCMSPresenter.PRESENTER_STOP_PAGE_LOADING_ACTION));\n }\n }",
"public void submitJob(Job job) {\n\t\tthis.jobs.add(job);\n\t}",
"public Job currentJob() {\n \t\treturn currentJob;\n \t}",
"@Override\n public void onClick(View v) {\n try {\n JOB = GetLayoutFieldDataAsJob();\n } catch(Exception e){\n System.out.println(\"Error reading input.\");\n }\n if(JOB != null) {\n final boolean[] enabled = new boolean[1];\n AsyncTask.execute(new Runnable() {\n @Override\n public void run() {\n try {\n // set currentJob flag to false\n JobService.saveJob(JOB);\n if(DataHandler.GetDataHandlerInstance().GetCurrentJob()!=null){\n enabled[0] = true;\n }\n } catch (Exception e) {\n System.out.println(\"Error saving the job offer:\" + e.getMessage());\n\n }\n runOnUiThread(new Runnable() {\n @Override\n public void run() {\n compareCurrent.setEnabled(enabled[0]);\n }\n });\n }\n\n });\n // enable post-save button options\n// new Thread(new Runnable() {\n// @Override\n// public void run() {\n// final isAbleToCompare task = new isAbleToCompare();\n// task.execute();\n// }\n// }).start();\n saveJobOffer.setEnabled(false);\n enterAnotherJob.setEnabled(true);\n }\n }",
"public void gotoPostNewJob(View v){\n startActivity( new Intent( ViewSingleJobActivity.this, PostJobActivity.class));\n finish();\n }",
"public void attachJob(Job job) {\n\t\tthis.job = job.copy();\n\t}",
"@Override\n\tpublic void doJob() {\n\t\tSystem.out.println(\"Studying\");\n\t}",
"public void goBackViewJob(View v) {\n setContentView(R.layout.activity_sitter_page);\n if(jobType.equals(\"open\")) {\n ((TextView) findViewById(R.id.allAcceptedJobsTitle)).setText(\"Available Jobs\");\n }\n else if(jobType.equals(\"owner\")) {\n ((TextView) findViewById(R.id.allAcceptedJobsTitle)).setText(\"Your Open Jobs\");\n }\n else {\n ((TextView) findViewById(R.id.allAcceptedJobsTitle)).setText(\"Accepted Jobs\");\n }\n allJobsList();\n }",
"@RequestMapping(value = \"/applyJob/{job_post_id}\", method = RequestMethod.GET)\n\tpublic String applyJob(Model m, HttpServletRequest req, @PathVariable Long job_post_id) {\n\t\tHttpSession session = req.getSession();\n\t\tString username = (String) session.getAttribute(\"username\");\n\t\tSystem.out.println(\"session username = \" + username);\n\t\tSystem.out.println(\"Apply Job. Jobseeker Controller. job_post_id: \" + job_post_id);\n\t\tRestTemplate restTemplate = new RestTemplate();\n\t\trestTemplate.setErrorHandler(new DefaultResponseErrorHandler() {\n\t\t\tprotected boolean hasError(HttpStatus statusCode) {\n\t\t\t\treturn false;\n\t\t\t}\n\t\t});\n\t\tsession.setAttribute(\"username\", username);\n\n\t\tJobPostApplicants jpa = new JobPostApplicants(job_post_id, username, \"\");\n\t\tResponseEntity<JobPostApplicants> readExistingApplication = restTemplate.getForEntity(\n\t\t\t\turiCheckExistApplication + \"/\" + job_post_id + \"/\" + username + \"/\", JobPostApplicants.class);\n\t\tif (readExistingApplication.getBody() != null) {\n\t\t\t// there is an existing application do not add\n\t\t\treturn \"redirect:../contentViewRecentJobs?username=\" + username;\n\t\t} else {\n\t\t\t// no application record ; create\n\t\t\tResponseEntity<JobPostApplicants> rejp = restTemplate.postForEntity(uriCreateJobPostApplicants, jpa,\n\t\t\t\t\tJobPostApplicants.class);\n\t\t\tif (rejp.getStatusCode().equals(HttpStatus.OK)) {\n\t\t\t\t// return \"redirect:../contentViewJobsApplied\";\n\t\t\t\treturn \"redirect:../contentViewRecentJobs?username=\" + username;\n\t\t\t} else {\n\t\t\t\treturn \"redirect:../contentViewRecentJobs?username=\" + username;\n\t\t\t}\n\t\t}\n\t}",
"@RequestMapping(value = \"/editAccountPage\", method = RequestMethod.GET)\n\tpublic String jobseekerEditAccount(Model m, HttpServletRequest req) {\n\t\tHttpSession session = req.getSession();\n\t\tString username = (String) session.getAttribute(\"username\");\n\t\tSystem.out.println(\"session username = \" + username);\n\t\tString firstname = (String) session.getAttribute(\"firstname\");\n\t\tm.addAttribute(\"firstname\", firstname);\n\t\tm.addAttribute(\"state\", \"editAccount\");\n\t\tSystem.out.println(\"I'm jobseeker editAccount\");\n\t\treturn \"js.editAccount\";\n\t\t// return \"redirect:../home\";\n\t}",
"public void getStarted(View view)\n {\n\n if(ParseUser.getCurrentUser().getUsername()!=null)\n {\n\n\n ParseUser.getCurrentUser().put(\"riderOrdriver\",currentUserIs);\n\n\n ParseUser.getCurrentUser().saveInBackground(new SaveCallback() {\n @Override\n public void done(ParseException e) {\n if(e == null)\n {\n Log.i(\"userSaved as \",ParseUser.getCurrentUser().getUsername()); //save in the object of that user the type\n }else\n {\n Log.i(\"error in saving\",e.toString());\n\n }\n\n }\n });\n\n activityStartType(currentUserIs);\n }\n\n }",
"public Dsjob getJobObject() { return job; }",
"@RequestMapping(value = \"/jsEditAccounts\", method = RequestMethod.GET)\n\tpublic String jsEdit(Model m, @RequestParam(value = \"username\") String username, HttpServletRequest req) {\n\t\tSystem.out.println(\"Proceed to editAccountJobSeeker Page\");\n\t\tHttpSession session = req.getSession();\n\t\tsession.setAttribute(\"username\", username);\n\t\tm.addAttribute(\"state\", \"editAccount\");\n\t\tm.addAttribute(\"username\", username);\n\t\treturn \"js.home\";\n\t}",
"@RequestMapping(value = \"/viewJob/{job_post_id}\", method = RequestMethod.GET)\n\tpublic String viewJob(Model m, @PathVariable Long job_post_id, HttpServletRequest req) {\n\t\tSystem.out.println(\"I'm viewing job\");\n\t\tHttpSession session = req.getSession();\n\t\tString uriReadJobPost = SMART_HIRE_URL + \"/jobPostRC/read/\" + job_post_id + \"/\";\n\t\tString uriReadEmployer = SMART_HIRE_URL + \"/employerRC/read/\";\n\t\tString uriReadJobPostSkillsRequirement = SMART_HIRE_URL + \"/jobPostSkillsRC/getListById/\" + job_post_id + \"/\";\n\t\tString uriReadJobPostSkillsReq = SMART_HIRE_URL + \"/jobPostSkillsRC/getListById/\";\n\n\t\tString username = (String) session.getAttribute(\"username\");\n\t\tSystem.out.println(\"session username = \" + username);\n\t\tString firstname = (String) session.getAttribute(\"firstname\");\n\t\tm.addAttribute(\"firstname\", firstname);\n\n\t\tRestTemplate restTemplate = new RestTemplate();\n\t\trestTemplate.setErrorHandler(new DefaultResponseErrorHandler() {\n\t\t\tprotected boolean hasError(HttpStatus statusCode) {\n\t\t\t\treturn false;\n\t\t\t}\n\t\t});\n\n\t\tJobPost jp = null;\n\t\tResponseEntity<JobPost> reJobPost = restTemplate.getForEntity(uriReadJobPost, JobPost.class);\n\t\tif (reJobPost.getBody() != null) {\n\t\t\tjp = reJobPost.getBody();\n\t\t\tSystem.err.println(\"\\nJobPost retrieved!\");\n\t\t\tResponseEntity<Employer> reEmployer = restTemplate\n\t\t\t\t\t.getForEntity(uriReadEmployer + reJobPost.getBody().getUsername() + \"/\", Employer.class);\n\t\t\tif (reEmployer.getBody() != null) {\n\t\t\t\tSystem.out.println(\"Retrieved employer from the job post id = \" + reJobPost.getBody().getJob_post_id());\n\t\t\t\tSystem.err.println(\"Employer retrieved!\");\n\t\t\t\tm.addAttribute(\"emp\", reEmployer.getBody());\n\t\t\t}\n\n\t\t\tResponseEntity<JobPostSkills[]> readSkillsReq = restTemplate\n\t\t\t\t\t.getForEntity(uriReadJobPostSkillsReq + \"/\" + job_post_id + \"/\", JobPostSkills[].class);\n\t\t\tif (readSkillsReq.getBody() != null) {\n\t\t\t\tm.addAttribute(\"skillsReq\", readSkillsReq.getBody());\n\t\t\t\tSystem.err.println(\"Required skills retrieved!\");\n\t\t\t}\n\n\t\t\tm.addAttribute(\"jp\", reJobPost.getBody());\n\t\t\t// m.addAttribute(\"state\", \"viewJob\");\n\t\t} else {\n\t\t\tSystem.err.println(\"read job post failed\");\n\n\t\t}\n\n\t\tsession.setAttribute(\"username\", username);\n\t\tm.addAttribute(\"username\", username);\n\t\tm.addAttribute(\"state\", \"viewJob\");\n\t\tSystem.out.println(\"Proceed to view js.home --> js.job page\");\n\t\treturn \"js.home\";\n\t}",
"boolean addJob(PrintJob job);",
"public String getJob() {\n return job;\n }",
"@Override\n public void pipeStepQueueJob(final Job job) {\n synchronized(jobs_queue) {\n pipeStepLog(\"Queuing JOB #\" + job.getId());\n jobs_queue.add(job);\n jobs_queue.notifyAll();\n }\n }",
"@Override\n protected void insertJobInQueueUponArrival (final J job, final double time)\n {\n addRealJobLocal (job);\n }",
"public Job getJob();",
"public void setRequested(User requested) {\n this.requested = requested;\n }",
"@Override\n public boolean onStartJob(JobParameters job) {\n\n String id = job.getTag();\n Log.d(\"TAG+++\", \"Job id: \" + id);\n\n Uri uri = ToDoContract.ToDoEntry.CONTENT_URI.buildUpon().appendPath(id).build();\n Cursor mCursor = getContentResolver().query(uri, null, null, null, null);\n if(mCursor != null){\n if(mCursor.getCount() > 0){\n mCursor.moveToFirst();\n String info = mCursor.getString(mCursor.getColumnIndex(ToDoContract.ToDoEntry.COLUMN_INFO));\n String desc = mCursor.getString(mCursor.getColumnIndex(ToDoContract.ToDoEntry.COLUMN_DESC));\n int priority = mCursor.getInt(mCursor.getColumnIndex(ToDoContract.ToDoEntry.COLUMN_PRIORITY));\n Log.d(\"TAG+++\", \"Info: \" + info + \" | Desc: \" + desc + \" | Priority: \" + priority);\n\n //send notification\n MyNotificationUtil.sendNotification(getApplicationContext(), Integer.valueOf(id), info, desc, priority);\n }\n }\n\n\n //is there anything else to do, any background work still running?\n return false;\n }",
"public void setJob_location(String job_location) {\r\n this.job_location = job_location;\r\n }",
"void setJobName(String jobName);",
"public void addJobToWaitingList(CommonCommand newJob) {\n \t\tif (null != localMonitor)\n \t\t\tlocalMonitor.newJobToWaitingList(newJob);\n \t}",
"@RequestMapping(value = \"/getJobApplyPage\", method = RequestMethod.GET)\n public String getJobDetailPage(Model model, Principal principal, @RequestParam(\"postid\") int id) {\n \tJob job = userService.getJobById(id);\n \tmodel.addAttribute(\"job\", job);\n return \"jobDetailPage\";\n }",
"@Override\n public void setUserVisibleHint(boolean isVisibleToUser) {\n super.setUserVisibleHint(isVisibleToUser);\n if (isVisibleToUser && !alreadyMadeApplicationsApiCall) {\n alreadyMadeApplicationsApiCall = true;\n fetchItemsWithUrl(getActivity(), ApiManager.getApprovedApplicationsUrl());\n }\n }",
"@Override\n\t\t\tpublic void onClick(ClickEvent event) {\n\t\t\t\t\n\t\t\t\tString toSave = assignmentObjectiveView.getAssignmentObjective().getText();\n\t\t\t\tint jobCreationId = selectedJobId;\n\t\t\t\t\n\t\t\t\t\n\t\t\t\tAuditEngagement e = new AuditEngagement();\n\t\t\t\te.setAssignmentObj(toSave);\n\t\t\t\t\n\t\t\t\tJobCreation j = new JobCreation();\n\t\t\t\tj.setJobCreationId(jobCreationId);\n\t\t\t\te.setJobCreation(j);\n\t\t\t\t\n\t\t\t\trpcService.updateAuditEngagement(e, \"assignmentObj\", new AsyncCallback<Boolean>() {\n\t\t\t\t\t\n\t\t\t\t\t@Override\n\t\t\t\t\tpublic void onSuccess(Boolean arg0) {\n\t\t\t\t\t\tWindow.alert(\"success\");\n\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t\t@Override\n\t\t\t\t\tpublic void onFailure(Throwable caught) {\n\t\t\t\t\t\tWindow.alert(\"fail\");\n\t\t\t\t\t\t\n\n\t\t\t\t\t\tlogger.log(Level.INFO, \"FAIL: updateAuditEngagement .Inside Audit AuditAreaspresenter\");\n\t\t\t\t\t\tif(caught instanceof TimeOutException){\n\t\t\t\t\t\t\tHistory.newItem(\"login\");\n\t\t\t\t\t\t}else{\n\t\t\t\t\t\t\tSystem.out.println(\"FAIL: updateAuditEngagement .Inside AuditAreaspresenter\");\n\t\t\t\t\t\t\tWindow.alert(\"FAIL: updateAuditEngagement\");// After FAIL ... write RPC Name NOT Method Name..\n\t\t\t\t\t\t}\n\t\t\t\t\t\t\n\t\t\t\t\t\t\n\t\t\t\t\t}\n\t\t\t\t});\n\t\t\t\t\n\t\t\t\t\n\t\t\t\t// call rpc from here.. and save this data to this selectedJobId.. in our new table under column assignmentObjective\n\t\t\t}",
"@OnClick(R.id.buttonSignUp)\n void signUp()\n {\n if (from.equals(Keys.FROM_FIND_JOB)) {\n Intent intent = new Intent(this, LoginSignUpSeekerActivity.class);\n intent.putExtra(Keys.CLICKED_EVENT, Keys.CLICKED_EVENT_SIGNUP);\n startActivity(intent);\n overridePendingTransition(R.anim.slide_in_right, R.anim.slide_out_left);\n } else {\n Intent intent = new Intent(this, LoginSignUpRecruiterActivity.class);\n intent.putExtra(Keys.CLICKED_EVENT, Keys.CLICKED_EVENT_SIGNUP);\n startActivity(intent);\n overridePendingTransition(R.anim.slide_in_right, R.anim.slide_out_left);\n }\n }",
"@Override\n public void updateActionUI() {\n JSONObject jobContractsAndItsBidIds = getJobContractsAndItsBidIds(getContracts(), super.getId());\n JSONArray jobContracts = jobContractsAndItsBidIds.getJSONArray(\"jobContracts\");\n JSONArray offerContracts = jobContractsAndItsBidIds.getJSONArray(\"offerContracts\");\n JSONArray jobContractBidsJSONArray = jobContractsAndItsBidIds.getJSONArray(\"jobContractBids\");\n aboutToExpireContracts = jobContractsAndItsBidIds.getJSONArray(\"aboutToExpireContracts\");\n\n // converting jobContractBidsJSONArray into an arraylist\n ArrayList<String> jobContractBids = new ArrayList<>();\n for (int i = 0; i < jobContractBidsJSONArray.length(); i++) {\n jobContractBids.add(jobContractBidsJSONArray.getString(i));\n }\n\n //get available bids\n JSONArray availableBids = getAvailableBids(jobContractBids, getBids(true), super.getCompetencies(), getId());\n\n // getting tutor's actions\n ArrayList<Action> tutorActions = getTutorActions(view, availableBids, jobContracts, offerContracts, this);\n\n // getting default user actions and adding them to tutor's actions\n ArrayList<Action> defaultActions = getDefaultActions();\n\n for (int i =0; i < defaultActions.size(); i++) {\n tutorActions.add(defaultActions.get(i));\n }\n\n // setting user's action as tutor's action\n super.setActions(tutorActions);\n }",
"public void manageProfile(String username)\n {\n User tmpUser = getUser(username);\n Scanner input = new Scanner(System.in);\n String option = \"\";\n if(tmpUser.getRole().equals(\"Job Seeker\"))\n {\n JobSeeker tmpSeeker = getJobSeeker(username);\n tmpSeeker.displayJobSeeker();\n do\n {\n menu.manageSeekerProfile();\n option = input.nextLine();\n switch (option)\n {\n case \"1\":\n System.out.println(\"Please enter new name: \");\n tmpSeeker.setName(input.nextLine().trim());break;\n case \"2\":\n System.out.println(\"Please enter new email: \");\n tmpSeeker.setEmail(input.nextLine().trim());break;\n case \"3\":\n System.out.println(\"Please enter new gender: \");\n tmpSeeker.setGender(input.nextLine().trim());break;\n case \"4\":\n System.out.println(\"Please add new skill: \");\n String newSkill = input.nextLine().trim();\n tmpSeeker.addSkill(newSkill);break;\n case \"5\":\n break;\n default:\n System.out.println(\"Wrong input. Please input valid number(1-5)\");\n break;\n }\n }while(!option.equals(\"5\"));\n System.out.println(\"Your new profile is:\");\n tmpSeeker.displayJobSeeker();\n runOJSSJobSeeker(tmpSeeker);\n }\n \n if(tmpUser.getRole().equals(\"Job Recruiter\"))\n {\n JobRecruiter tmpRecruiter = getJobRecruiter(username);\n tmpRecruiter.displayJobRecruiter();\n do\n {\n menu.manageRecruiterProfile();\n option = input.nextLine();\n switch (option)\n {\n case \"1\":\n System.out.println(\"Please enter new name: \");\n tmpRecruiter.setName(input.nextLine().trim());break;\n case \"2\":\n System.out.println(\"Please enter new email: \");\n tmpRecruiter.setEmail(input.nextLine().trim());break;\n case \"3\":\n System.out.println(\"Please enter new gender: \");\n tmpRecruiter.setGender(input.nextLine().trim());break;\n case \"4\":\n System.out.println(\"Please enter new company name: \");\n tmpRecruiter.setCompanyName(input.nextLine().trim());break;\n case \"5\":\n System.out.println(\"Please enter new location: \");\n tmpRecruiter.setLocation(input.nextLine().trim());break;\n case \"6\":\n break;\n default:\n System.out.println(\"Wrong input. Please input valid number(1-6)\");\n break;\n }\n }while(!option.equals(\"6\"));\n System.out.println(\"Your new profile is:\");\n tmpRecruiter.displayJobRecruiter();\n runOJSSJobRecruiter(tmpRecruiter);\n }\n }",
"private void addNewHomework() {\n\t\tIntent myIntent = new Intent(HomeworkActivity.this,\n\t\t\t\tHomeworkDetailActivity.class);\n\n\t\tmyIntent.putExtra(HOMEWORK_EDIT, false);\n\n\t\tHomeworkActivity.this.startActivityForResult(myIntent,\n\t\t\t\tADD_NEW_HOMEWORK_REQUEST);\n\n\t}",
"private void getCurrentUser() {\r\n // Eingeloggte Person holen\r\n currentUser = loginBean.getLoggedInPerson();\r\n\r\n if (currentUser != null && currentUser.getEmployees().isEmpty() == false) {\r\n employeeList.clear();\r\n employeeList.addAll(currentUser.getEmployees());\r\n }\r\n }",
"private void handleJobLaunchSuccess() {\n EventBus eventbus = EventBus.getInstance();\n \n JobLaunchedEvent event = new JobLaunchedEvent(tagCaller, fieldName.getValue());\n eventbus.fireEvent(event);\n \n // close dialog now that job has launched\n closeDialog();\n \n MessageBox.info(I18N.DISPLAY.analysisSubmitted(), I18N.DISPLAY.analysisSubmittedMsg(), null);\n \n }",
"public void viewUser() {\n\t\tsuper.viewUser();\n\t}",
"protected void startProcessAndCompleteUserTask() {\n runtimeService.startProcessInstanceByKey(\"HistoryLevelTest\");\n Task task = taskService.createTaskQuery().singleResult();\n taskService.complete(task.getId());\n }",
"void markAsUserSession();",
"@Override\n\t\t\t\t\t\tpublic boolean onItemLongClick(AdapterView<?> parent,\n\t\t\t\t\t\t\t\tView view, int position, long id) {\n\t\t\t\t\t\t\tnew user_approve().execute();\n\t\t\t\t\t\t\treturn false;\n\t\t\t\t\t\t}",
"@Override\n\tpublic void submitJobEmployee(int je_id, String caller) {\n\n\t}",
"public void addAsPerSearch(List<Job> searchedJob) {\n int currentSize = mJobList.size();\n //remove the current items\n mJobList.clear();\n //add all the new items\n mJobList.addAll(searchedJob);\n //tell the recycler view that all the old items are gone\n notifyItemRangeRemoved(0, currentSize);\n //tell the recycler view how many new items we added\n notifyItemRangeInserted(0, mJobList.size());\n }",
"public String getJob() {\r\n\t\t\treturn job;\r\n\t\t}",
"private void saveJobList() {\n\t\tFileLoader.saveObject(getApplicationContext(), FILE_NAME_JOBS, (Serializable) jobs);\n\t}",
"public void storeToRequest() {\r\n HttpServletRequest httpServletRequest = GrouperUiFilter.retrieveHttpServletRequest();\r\n httpServletRequest.setAttribute(\"inviteExternalSubjectsContainer\", this);\r\n }",
"public void setJobName(String jobName) {\n this.jobName = jobName;\n }",
"public void setJobName(String jobName) {\n this.jobName = jobName;\n }",
"public void setJobName(String jobName) {\n this.jobName = jobName;\n }",
"public void setUpInterview(String jobID, String email){\n appList= JobSystemCoordinator.appManager.getPendingApplications(jobID);\n currentJob = getJobAtIndex(jobID);\n for(Application app : appList){\n if(app.getApplicant().getEmail().equals(email)){\n app.setStatus(\"Awaiting Interview\");\n String success = String.format(\"===========SETTING UP INTERVIEWS FOR A JOB========\\n\" +\n \"Details of setting up interviews:\\n\" +\n \"Job ID: %s\\n\" +\n \"Candidate list: %s\\n\",currentJob.getJobID(),app.getApplicant().getEmail());\n System.out.println(success);\n }\n }\n }",
"public void addJob(String name, JobInProgress job) {\n Queue<JobInProgress> queue = queues.get(name);\n if (null != queue)\n queue.addJob(job);\n }",
"public final void addToWatchList(long j) {\n AuctionSalesListActivity auctionSalesListActivity2 = this.auctionSalesListActivity;\n if (auctionSalesListActivity2 == null) {\n Intrinsics.throwUninitializedPropertyAccessException(\"auctionSalesListActivity\");\n }\n Application application = auctionSalesListActivity2.getApplication();\n Intrinsics.checkExpressionValueIsNotNull(application, \"auctionSalesListActivity.application\");\n String userIdPreferencesMVVM = IAASharedPreference.getUserIdPreferencesMVVM(application.getApplicationContext());\n Intrinsics.checkExpressionValueIsNotNull(userIdPreferencesMVVM, \"IAASharedPreference.getU…ation.applicationContext)\");\n this.userId = userIdPreferencesMVVM;\n String string = getResources().getString(C2723R.string.lbl_watch_action_add);\n Intrinsics.checkExpressionValueIsNotNull(string, \"resources.getString(R.string.lbl_watch_action_add)\");\n this.action = string;\n AuctionSalesListViewModel auctionSalesListViewModel = this.viewModel;\n if (auctionSalesListViewModel == null) {\n Intrinsics.throwUninitializedPropertyAccessException(\"viewModel\");\n }\n StringCompanionObject stringCompanionObject = StringCompanionObject.INSTANCE;\n Object[] objArr = new Object[2];\n SessionManager sessionManager2 = this.sessionManager;\n if (sessionManager2 == null) {\n Intrinsics.throwUninitializedPropertyAccessException(\"sessionManager\");\n }\n objArr[0] = sessionManager2.getCurrentSessionUsername();\n SessionManager sessionManager3 = this.sessionManager;\n if (sessionManager3 == null) {\n Intrinsics.throwUninitializedPropertyAccessException(\"sessionManager\");\n }\n objArr[1] = sessionManager3.getCurrentSessionPassword();\n String format = String.format(\"%s:%s\", Arrays.copyOf(objArr, objArr.length));\n Intrinsics.checkExpressionValueIsNotNull(format, \"java.lang.String.format(format, *args)\");\n auctionSalesListViewModel.updateWatchStatus(format, String.valueOf(j), this.userId, this.action);\n }",
"@RequestMapping(\"/addjob\")\n public String addJob(Model model)\n {\n model.addAttribute(\"aJob\",new Job());\n return \"addjob\";\n }",
"public void launchSubPart3(View view) {\n Intent inscrPart3 = new Intent(getApplicationContext(), subscription_part3_Activity.class);\n inscrPart3.putExtra(\"User\", user);\n startActivity(inscrPart3);\n finish();\n\n }",
"private void addCompletedJobStats(CascadingJob job, HadoopStepStats stats) {\n if (workflowVersion == null) {\n workflowVersion = currentFlowId;\n }\n\n job.setJobStats(stats);\n jobs.add(job);\n }",
"@RequestMapping(\"/savejob\")\n public String saveJob(@ModelAttribute(\"aJob\") Job theJob)\n {\n jobs.save(theJob);\n return \"redirect:/listjobs\";\n }",
"public void addLocal(String user, String email, String role){\n //Add user to signed in\n SharedPreferences preferences = PreferenceManager.getDefaultSharedPreferences(this);\n SharedPreferences.Editor editor = preferences.edit();\n editor.putString(\"Username\", user);\n editor.putString(\"Email\", email);\n editor.putString(\"Role\", role);\n editor.apply();\n\n //Send to appropriate page\n if(role.equals(\"Child\")) {\n Intent intent = new Intent(this, childView.class);\n startActivity(intent);\n }else if(role.equals(\"Parent\")){\n Intent intent = new Intent(this, parentView.class);\n startActivity(intent);\n }\n }",
"private void launchEditVolPage(View view, Volunteer thisGuy){\n final Intent launchEdit = new Intent(manageVolunteers.this,ManagerEditVolunteer.class);\n\n Bundle bundle = new Bundle();\n bundle.putSerializable(\"thisGuy\", thisGuy);\n launchEdit.putExtra(\"bundle\", bundle);\n startActivity(launchEdit);\n }",
"private void addUserAsMarker() {\n firestoreService.findUserById(new OnUserDocumentReady() {\n @Override\n public void onReady(UserDocument userDocument) {\n if(userDocument != null && userDocument.getUserid().equals(preferences.get(\"user_id\",0L))) {\n String id = preferences.get(DOCUMENT_ID, \"\");\n //Add current user to ListInBounds\n userDocumentAll.setDocumentid(id);\n userDocumentAll.setUsername(userDocument.getUsername());\n userDocumentAll.setPicture(userDocument.getPicture());\n userDocumentAll.setLocation(userDocument.getLocation());\n userDocumentAll.setFollowers(userDocument.getFollowers());\n userDocumentAll.setIsvisible(userDocument.getIsvisible());\n userDocumentAll.setIsprivate(userDocument.getIsprivate());\n userDocumentAll.setIsverified(userDocument.getIsverified());\n userDocumentAll.setUserid(userDocument.getUserid());\n userDocumentAll.setToken(userDocument.getToken());\n oneTimeAddableList.add(userDocumentAll);\n }\n }\n\n @Override\n public void onFail() {\n\n }\n\n @Override\n public void onFail(Throwable cause) {\n\n }\n });\n\n }",
"@Override\n protected Object doMonitoredTask() {\n String originalEmail = getUser().getEmailAddress();\n String originalName = getUser().getDisplayName();\n\n getAreaContext().doAreaTask(new DeleteUserTask(getUser().getOid()));\n\n // bl: delete all of the user's content synchronously, too.\n getNetworkContext().doGlobalTask(new DeleteUserAccountContentTask(getUser(), originalName));\n\n // jw: send an email to the user so they have a record of this change. Important if someone else got access to their account and did this for them.\n getAreaContext().doAreaTask(new SendUserDeletedOrActivationStatusChangeEmailTask(getUser(), originalName, originalEmail, true));\n\n return null;\n }",
"private void prepareProgression(User user,\n HttpServletRequest req,\n Language lang) {\n var countedSolvedAndAll = taskService\n .countProgression(user.getUserId(), lang);\n req.getSession().setAttribute(\"currentCountedTasks\", countedSolvedAndAll);\n }",
"@Override\r\n\tpublic T getJob() {\n\t\treturn super.getJob();\r\n\t}",
"private void storeJobSeekersToJobSeekerList(String jobSeekerDetails)\n {\n String[] allJobSeeker = jobSeekerDetails.split(\";\");\n \n \n for (int line = 0; line < allJobSeeker.length ; line++)\n {\n String[] details = allJobSeeker[line].split(\",\");\n String seekerName = details[0];\n String seekerUsername = details[1];\n String role = details[2];\n String seekerGender = details[3];\n String seekerEmail = details[4];\n String pass = details[5];\n ArrayList<String> seekerSkills = new ArrayList<String>();\n for (int i = 6; i < details.length; i++)\n {\n seekerSkills.add(details[i]);\n }\n int totalUser = userList.size();\n int id = totalUser + 1; \n \n JobSeeker seeker = new JobSeeker();\n seeker.setName(seekerName);\n seeker.setUserName(seekerUsername);\n seeker.setRole(role);\n seeker.setGender(seekerGender);\n seeker.setEmail(seekerEmail);\n seeker.setPassword(pass);\n seeker.setSkillsets(seekerSkills);\n \n jobSeekerList.add(seeker);\n userList.add(seeker);\n }\n }",
"public void addJob(String jobID, String jobTitle, String jobType,\n String salary, String jobDescription, String expirationDate,\n String contactEmail) {\n //Will check if the amount is less than 100 jobs added\n //then Will add the job to the end of the arrayList\n //will return true if added else return false\n currentJob = new Job(contactEmail, jobType, jobID, jobDescription, salary, jobTitle, expirationDate);\n if(jobs.size() <= 100)\n {\n jobs.add(currentJob);\n String success = String.format(\"================JOB POSTING SUCCESS================\\n\" +\n \"A new job has been posted with following details:\\n\" +\n \"Job ID: %s\\n\" +\n \"Job Name: %s\\n\" +\n \"Job Type: %s\\n\" +\n \"Salary: %s\\n\" +\n \"Job Description: %s\\n\" +\n \"Expiration Date: %s\\n\" +\n \"Contact email: %s\\n\", jobID, jobTitle, jobType, salary, jobDescription, expirationDate, contactEmail);\n\n System.out.println(success);\n } else {\n String success = String.format(\"================JOB POSTING FAILURE ================\\n\" +\n \"THERE ARE MORE THAN 100 JOBS IN THE SYSTEM:\\n\");\n System.out.println(success);\n }\n }",
"@Override\n public void onSuccess(JsonObject otherUserJSON) {\n if (otherUserJSON.get(\"success\").getAsInt() == 1) {\n view.startBucketActivity();\n } else {\n view.showNoBucket();\n }\n }",
"public void setUser(java.lang.String param){\r\n localUserTracker = true;\r\n \r\n this.localUser=param;\r\n \r\n\r\n }",
"public void setUser(java.lang.String param){\r\n localUserTracker = true;\r\n \r\n this.localUser=param;\r\n \r\n\r\n }",
"public void setUser(java.lang.String param){\r\n localUserTracker = true;\r\n \r\n this.localUser=param;\r\n \r\n\r\n }",
"public void flagUser() {\n\t\tsuper.flagUser();\n\t}",
"public void actionPerformed(ActionEvent ev)\r\n\t\t\t{\t\t\t\t\r\n\t\t\t\tviewJob();\t\t\t\t\r\n \t\t\t}",
"public void addPlayer(HeroClass newJob){job.add(newJob);}",
"private void startDownloadJob(final DownloadJob job) {\n\n\t\tfinal int notificationId = ++NOTIFICATION_ID;\n\n\t\tfinal NotificationManager mNotifyManager = (NotificationManager) getSystemService(Context.NOTIFICATION_SERVICE);\n\t\tfinal NotificationCompat.Builder mBuilder = new NotificationCompat.Builder(this);\n\t\t// mBuilder.setContentTitle(\"Message Download\")\n\t\tString notificationTitle = job.getFolderName();\n\t\tFBFriend loggedUser = DataStorage.getLoggedUser();\n\t\tif (loggedUser != null) {\n\t\t\tnotificationTitle = job.getThread().getFriendsNames(loggedUser);\n\t\t}\n\t\tmBuilder.setContentTitle(notificationTitle).setContentText(\"Download in progress\")\n\t\t\t\t.setSmallIcon(R.drawable.ic_launcher).setAutoCancel(true);\n\n\t\tIntent resultIntent = new Intent(this, StatusActivity.class);\n\t\tresultIntent.putExtra(StatusActivity.INTENT_EXTRA_STATUS, 1);\n\t\tresultIntent.putExtra(StatusActivity.INTENT_EXTRA_JOB, job);\n\t\tresultIntent.addFlags(Intent.FLAG_ACTIVITY_NEW_TASK | Intent.FLAG_ACTIVITY_CLEAR_TOP\n\t\t\t\t| Intent.FLAG_ACTIVITY_SINGLE_TOP);\n\t\t// resultIntent.addFlags(Intent.FLAG_ACTIVITY_CLEAR_TOP |\n\t\t// Intent.FLAG_ACTIVITY_SINGLE_TOP);\n\n\t\t// generate unique request id\n\t\tint n = new Random().nextInt(50) + 1;\n\t\tint requestID = n * notificationId;\n\n\t\tPendingIntent resultPendingIntent = PendingIntent.getActivity(this, requestID, resultIntent,\n\t\t\t\tPendingIntent.FLAG_UPDATE_CURRENT);\n\t\t// PendingIntent.FLAG_ONE_SHOT);\n\t\tmBuilder.setContentIntent(resultPendingIntent);\n\n\t\tThread thread = new Thread() {\n\n\t\t\t@Override\n\t\t\tpublic void run() {\n\t\t\t\tsuper.run();\n\t\t\t\tdownloading = true;\n\t\t\t\tString threadId = job.getThread().getThreadId();\n\n\t\t\t\tFBMessageTable dbTable = new FBMessageTable(getApplicationContext(), threadId);\n\t\t\t\tdbTable.createTableIfNotExist();\n\n\t\t\t\t// indexes starts from 0\n\t\t\t\t// start from begining or from the last index\n\t\t\t\t// long start = Math.max(job.getMinIndex() - 1,\n\t\t\t\t// job.getDownloadIndex());\n\t\t\t\tlong start = job.getMinIndex() - 1;\n\t\t\t\tlong end = job.getMaxIndex() - 1;\n\n\t\t\t\tlong current = start;\n\n\t\t\t\tAppLogger.log(TAG, \"Job started thread_id=\" + threadId + \" from \" + start + \" to \" + end);\n\n\t\t\t\tDate startDate = new Date();\n\n\t\t\t\tboolean working = true;\n\t\t\t\tjob.setWorking(true);\n\t\t\t\tsaveJobList();\n\t\t\t\twhile (working) {\n\n\t\t\t\t\tlong lowerLimit = current;\n\t\t\t\t\t// long upperLimit = Math.min(end, current +\n\t\t\t\t\t// FB_MAX_MESSAGE_LIMIT);\n\t\t\t\t\tlong upperLimit = Math.min(end, current + FB_MAX_MESSAGE_LIMIT);\n\n\t\t\t\t\t// check if already found in the database\n\t\t\t\t\tCursor cursor = dbTable.getExportMessages(threadId, lowerLimit, upperLimit);\n\n\t\t\t\t\tboolean contains = containsAll(lowerLimit, upperLimit, cursor);\n\t\t\t\t\tdbTable.closeReadableDatabase();\n\t\t\t\t\tif (contains) {\n\t\t\t\t\t\tStringBuilder sb = new StringBuilder();\n\t\t\t\t\t\tsb.append(\"found in database from \");\n\t\t\t\t\t\tsb.append(lowerLimit);\n\t\t\t\t\t\tsb.append(\" to \");\n\t\t\t\t\t\tsb.append(upperLimit);\n\t\t\t\t\t\tAppLogger.log(TAG, sb.toString());\n\t\t\t\t\t} else {\n\t\t\t\t\t\t// List<FBMessage> messages =\n\t\t\t\t\t\t// DataLoader.loadMessages(threadId, lowerLimit,\n\t\t\t\t\t\t// upperLimit);\n\t\t\t\t\t\tList<FBMessage> messages = DataLoader.loadMessages(threadId, lowerLimit, FB_MAX_MESSAGE_LIMIT);\n\n\t\t\t\t\t\tif (messages == null) {\n\t\t\t\t\t\t\t// error occured\n\n\t\t\t\t\t\t\t// 104 = OAuthException.\n\t\t\t\t\t\t\tif (DataLoader.getErrorCode() == 104) {\n\t\t\t\t\t\t\t\t// try to create session from cache\n\t\t\t\t\t\t\t\tvalidateFBLogin();\n\t\t\t\t\t\t\t\t// try missed one again\n\t\t\t\t\t\t\t\tupperLimit = lowerLimit;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\t// TODO testing use. should remove after testing\n\t\t\t\t\t\t\tStringBuilder sb = new StringBuilder();\n\t\t\t\t\t\t\tsb.append(\"Messages from \");\n\t\t\t\t\t\t\tsb.append(lowerLimit);\n\t\t\t\t\t\t\tsb.append(\" to \");\n\t\t\t\t\t\t\tsb.append(upperLimit);\n\t\t\t\t\t\t\tsb.append(\" size=\");\n\t\t\t\t\t\t\tsb.append(messages.size());\n\n\t\t\t\t\t\t\tAppLogger.log(TAG, sb.toString());\n\n\t\t\t\t\t\t\t// save to database\n\t\t\t\t\t\t\tdbTable.addAll(messages, lowerLimit);\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\n\t\t\t\t\tjob.setDownloadIndex(current);\n\t\t\t\t\t// saveJobList();\n\n\t\t\t\t\t// prepare for next iteration\n\t\t\t\t\tcurrent = upperLimit;\n\n\t\t\t\t\tif (current >= end) {\n\t\t\t\t\t\tworking = false;\n\t\t\t\t\t}\n\n\t\t\t\t\tif (job.isStop()) {\n\t\t\t\t\t\tworking = false;\n\n\t\t\t\t\t}\n\n\t\t\t\t\tint progress = 0;\n\t\t\t\t\tif (end == start) {\n\t\t\t\t\t\tprogress = 0;\n\t\t\t\t\t} else {\n\t\t\t\t\t\tprogress = (int) ((current - start) * 100 / (end - start));\n\t\t\t\t\t}\n\t\t\t\t\tmBuilder.setProgress(100, progress, false);\n\t\t\t\t\tmNotifyManager.notify(notificationId, mBuilder.build());\n\t\t\t\t\tpublishStatus(job, progress);\n\t\t\t\t}\n\n\t\t\t\tAppLogger.log(TAG, \"Job ended thread_id=\" + threadId + \" from \" + start + \" to \" + end + \" in \"\n\t\t\t\t\t\t+ (new Date().getTime() - startDate.getTime()) / 1000 + \"seconds\");\n\n\t\t\t\t// write csv file\n\t\t\t\tmBuilder.setContentText(\"Download complete. Generating file\").setProgress(0, 0, false);\n\t\t\t\tCursor cursor = dbTable.getExportMessages(threadId, start, end);\n\n\t\t\t\tif (cursor != null) {\n\t\t\t\t\tgenerateOutFile(job, cursor);\n\t\t\t\t}\n\n\t\t\t\tdbTable.closeReadableDatabase();\n\n\t\t\t\t// //////////////\n\t\t\t\tif (job.isStop()) {\n\t\t\t\t\tmBuilder.setContentText(\"Download stopped\").setProgress(0, 0, false);\n\t\t\t\t} else {\n\t\t\t\t\tmBuilder.setContentText(\"Finished\").setProgress(0, 0, false);\n\t\t\t\t}\n\t\t\t\tmNotifyManager.notify(notificationId, mBuilder.build());\n\n\t\t\t\t// //////////////\n\t\t\t\tjob.setStop(true);\n\t\t\t\tboolean removed = removeJob(job);\n\t\t\t\tif (removed) {\n\t\t\t\t\tsaveJobList();\n\t\t\t\t}\n\t\t\t\tdownloading = false;\n\t\t\t\tif (jobs != null) {\n\t\t\t\t\tif (jobs.size() == 0) {\n\t\t\t\t\t\tstopSelf();\n\t\t\t\t\t} else {\n\t\t\t\t\t\tstartAllDownloads();\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t}\n\n\t\t};\n\n\t\tif (threads == null) {\n\t\t\tthreads = new ArrayList<Thread>();\n\t\t}\n\t\tthreads.add(thread);\n\t\tthread.start();\n\n\t}",
"@javax.annotation.Nullable\n @ApiModelProperty(value = \"The identifier of the job\")\n\n public String getJob() {\n return job;\n }",
"public void updateCurrentTrempitUser() {\n\n // create the trempituser object\n TrempitUser currentUser = new TrempitUser();\n currentUser.setFullName(Profile.getCurrentProfile().getName());\n currentUser.setId(Long.valueOf(Profile.getCurrentProfile().getId()));\n\n // update the global variable so all activities can access the user\n globalState.setCurrentUser(currentUser);\n\n // insert the user to the server\n insertTrempitUserToServer(currentUser);\n\n Toast.makeText(this, \"logged in to facebook:\" + globalState.getCurrentUser().getFullName(), Toast.LENGTH_LONG).show();\n }",
"private void scheduleJob() {\n\n }",
"public String getJob_location() {\r\n return job_location;\r\n }",
"@Override\n public void run() {\n try {\n stringOrganizationIds.remove(defaultOrg);\n List<Integer> organizationIds = FluentIterable.from(stringOrganizationIds)\n .transform(Ints.stringConverter()).toList();\n\n newUser.setActive(false);\n UserProfileStruct savedUser = createAccountInternal(conn, newUser, password, resetQuestion,\n resetAnswer, givenName, surname, organizationId);\n for (Integer orgId : organizationIds) {\n Profile profile = new Profile();\n profile.setGivenName(givenName);\n profile.setSurname(surname);\n profile.setOrganizationId(orgId);\n profile.setUserId(savedUser.credentialedUser.getId());\n profile = profilePersister.createProfile(profile, conn);\n\n authService.grantAtLeast(profile.getId(), ROLE_READER, orgId);\n authService.grantAtLeast(orgId, ROLE_ADMIN, profile.getId());\n }\n\n User user = savedUser.credentialedUser.getUser();\n user.setActive(true);\n persistenceService.process(conn, new UserPersister.UpdateUserFunc(user));\n conn.commit();\n } catch (Exception e) {\n closeConnection(conn);\n }\n }"
]
| [
"0.6483548",
"0.5983079",
"0.56892955",
"0.5525844",
"0.55131",
"0.54916227",
"0.5484836",
"0.5422122",
"0.5417419",
"0.53992784",
"0.538662",
"0.5302152",
"0.52864534",
"0.52692366",
"0.5263824",
"0.52209944",
"0.52105004",
"0.51669395",
"0.516535",
"0.51640594",
"0.51596403",
"0.5147537",
"0.5138198",
"0.5135401",
"0.51330096",
"0.51127154",
"0.50936544",
"0.50895864",
"0.5069868",
"0.5058898",
"0.5058181",
"0.5036876",
"0.50187176",
"0.50118417",
"0.5001217",
"0.5000365",
"0.49994764",
"0.49949047",
"0.4990172",
"0.4983862",
"0.4978658",
"0.49763262",
"0.49761325",
"0.4966167",
"0.49466848",
"0.4943829",
"0.49321082",
"0.49088004",
"0.4905811",
"0.49047172",
"0.49019146",
"0.4894198",
"0.48939472",
"0.48876274",
"0.4878372",
"0.4868878",
"0.4862329",
"0.48609373",
"0.48406592",
"0.48368266",
"0.48344064",
"0.48317546",
"0.48271552",
"0.48170453",
"0.48168007",
"0.48166502",
"0.48153996",
"0.48135424",
"0.48133728",
"0.48089483",
"0.48089483",
"0.48089483",
"0.4802334",
"0.47998574",
"0.4795765",
"0.47905612",
"0.47903943",
"0.4786037",
"0.47784925",
"0.47725466",
"0.47707826",
"0.4770576",
"0.4769133",
"0.47617787",
"0.475844",
"0.47578177",
"0.47562262",
"0.47553748",
"0.47435343",
"0.47435343",
"0.47435343",
"0.4743413",
"0.47427973",
"0.47372997",
"0.47193682",
"0.47182417",
"0.47169313",
"0.47105184",
"0.47027832",
"0.4701872"
]
| 0.66396296 | 0 |
Mark a job as completed | public void completeJob(View v) {
// FIXME save that it is completed somehow
Log.w("MA", "completeJob");
setContentView(R.layout.activity_sitter_page);
allJobsList();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"synchronized public void jobDone(){ // l'action a été réalisée\n\t\tdone = true; // changement d'état\n\t\tthis.notifyAll(); // on notifie tout le monde\n\t}",
"void completeJob();",
"public void markAsDone() {\n this.isDone = true;\n this.completed = \"1\";\n }",
"protected void jobFinished(Progress job) {\n }",
"public void markAsDone() {\r\n this.isDone = true;\r\n }",
"public void markAsDone() {\n this.isDone = true;\n\n }",
"public void markAsDone() {\n this.isDone = true;\n }",
"public void markAsDone() {\n this.isDone = true;\n }",
"public void markAsDone() {\n this.isDone = true;\n }",
"public void completed(final Status status);",
"public void completeTask() {\n completed = true;\n }",
"public void markAsDone() {\n this.done = true;\n }",
"@Override\n public String markComplete() {\n if (this.isDone) {\n return Ui.getTaskAlrCompletedMessage(this);\n } else {\n this.isDone = true;\n return Ui.getMarkCompleteEventMessage(this);\n }\n }",
"public void markAsDone() {\n isDone = true;\n }",
"public void markAsDone() {\n isDone = true;\n }",
"public void markAsDone() {\n isDone = true;\n }",
"public void setCompleted() {\n this.completed = true;\n }",
"public void setCompleted(boolean flag) {\r\n completed = flag;\r\n }",
"public abstract Task markAsDone();",
"public void markAsDone() {\n // TODO consider adding assertion here\n isDone = true;\n }",
"public void markAsDone(){\n isDone = true;\n }",
"public void markComplete()\n {\n setCount(getGoal());\n }",
"public void markDone() {\n isDone = true;\n }",
"public void complete()\n {\n isComplete = true;\n }",
"public synchronized void setComplete() {\n status = Status.COMPLETE;\n }",
"public void setCompleted(){\r\n\t\tisCompleted = true;\r\n\t}",
"public void set_completed();",
"protected void markAsDone() {\n isDone = true;\n }",
"public String markAsDone() {\n this.isComplete = true;\n return Ui.getTaskDoneMessage(this);\n }",
"public void CompleteTask() {\n\t\tCompletionDate = new Date();\n\t}",
"public void finalizeJob() {\n // override to implement\n }",
"private void doMarkTaskAsCompleted() {\n System.out.println(\n \"Select the task you would like to mark as complete by entering the appropriate index number.\");\n int index = input.nextInt();\n todoList.markTaskAsCompleted(index);\n System.out.println(\"The selected task has been marked as complete. \");\n }",
"protected void finished(){\n if (doFilterUpdate) {\n //runFilterUpdates();\n }\n \n double groupTotalTimeSecs = (System.currentTimeMillis() - (double) groupStartTime) / 1000;\n log.info(\"Job \"+id+\" finished \" /*+ parsedType*/ + \" after \"\n + groupTotalTimeSecs + \" seconds\");\n \n ((DistributedTileBreeder)breeder).jobDone(this);\n }",
"public void markJobAsSuccess(String jobId) {\n JobWrapper wrapper = jobs.remove(jobId);\n if (wrapper != null) {\n jobMetrics.runningJobs.decrementAndGet();\n LOGGER.info(\"job instance {} is success\", jobId);\n // mark job as success.\n jobConfDB.updateJobState(jobId, StateSearchKey.SUCCESS);\n }\n }",
"public void complete() {\n\t}",
"synchronized public void markDone() {\n this.done = true;\n }",
"public void finishJob(View v) {\n JobScheduler jobScheduler = (JobScheduler) getSystemService(Context.JOB_SCHEDULER_SERVICE);\n List<JobInfo> allPendingJobs = jobScheduler.getAllPendingJobs();\n if (allPendingJobs.size() > 0) {\n // Finish the last one\n int jobId = allPendingJobs.get(0).getId();\n jobScheduler.cancel(jobId);\n Toast.makeText(\n MainActivity.this, String.format(getString(R.string.cancelled_job), jobId),\n Toast.LENGTH_SHORT).show();\n } else {\n Toast.makeText(\n MainActivity.this, getString(R.string.no_jobs_to_cancel),\n Toast.LENGTH_SHORT).show();\n }\n }",
"public void taskComplete() {\n mTasksLeft--;\n if ((mTasksLeft==0) & mHasCloRequest){\n onAllTasksCompleted();\n }\n }",
"private void onSyncFinished(JobParameters job) {\n jobFinished(job, false); // Is a reschedule needed?\n Log.d(LOG_TAG, \"Sync job finished\");\n }",
"public void setDone() {\n this.isDone = true;\n }",
"public void setDone() {\n this.isDone = true;\n }",
"public void setDone() {\n this.isDone = true;\n }",
"public void setFinished(Boolean finished) {\n this.finished = finished;\n }",
"public void SetDone(){\n this.isDone = true;\n }",
"@Override\n\tpublic void eventFinished() {\n\t\tstatus=EventCompleted;\n\t}",
"void TaskFinished(Task task) {\n\n repository.finishTask(task);\n }",
"protected void setFinished(boolean finished) {\n this.finished = finished;\n }",
"public boolean completed() {\n return completed;\n }",
"public void taskCompleted(FJWorker worker, double time) {\n if (FJSimulator.DEBUG) System.out.println(\"task \"+worker.current_task.path_log_id+\" completed \"+time);\n FJTask task = worker.current_task;\n task.completion_time = time;\n task.completed = true;\n worker.current_task = null;\n \n // check if this task was the last one of a job\n //TODO: this could be more efficient\n boolean compl = true;\n for (FJTask t : task.job.tasks) {\n compl = compl && t.completed;\n }\n task.job.completed = compl;\n \n if (task.job.completed) {\n // it is the last, record the completion time\n task.job.completion_time = time;\n \n // for this type of server it is also the departure time\n task.job.departure_time = time;\n \n // sample and dispose of the job\n if (FJSimulator.DEBUG) System.out.println(\"job departing: \"+task.job.path_log_id);\n jobDepart(task.job);\n \n // service the next job, if any\n feedWorkers(time);\n } else {\n serviceTask(worker, worker.queue.poll(), time);\n }\n }",
"@Override\n public boolean completed() {\n return false;\n }",
"public void markComplete(int taskNumber) {\n Task currentTask = storage.get(taskNumber);\n currentTask.complete();\n line();\n System.out.println(\"Marked task \" + (taskNumber + 1) + \" as complete.\");\n System.out.println(currentTask);\n line();\n }",
"public Task markAsDone() {\n isDone = true;\n status = \"\\u2713\"; // A tick symbol indicating the task is done.\n\n return this;\n }",
"public String markDone() {\n this.isDone = true;\n return String.format(\"Nice! I've marked this task as done:\\n [X] %s\", this.description);\n }",
"boolean completed();",
"public void setCompleted (boolean isCompleted) {\n this.isCompleted = isCompleted;\n }",
"private void completeAbandonedJob(Integer id) {\r\n\t\tabandonedJobs++;\r\n\t\tBatchJobInstance batchJobInstance = batchJobInstanceManager.findById(id);\r\n\t\tif (batchJobInstance != null) {\r\n\t\t\tDate rightNow = new Date();\r\n\t\t\tbatchJobInstance.setStatus(BatchJobService.STATUS_ABANDONED);\r\n\t\t\tBatchJobEvent batchJobEvent = new BatchJobEvent();\r\n\t\t\tbatchJobEvent.setEvent(BatchJobService.STATUS_ABANDONED);\r\n\t\t\tbatchJobEvent.setDescription(\"Job marked as abandoned by PeriodicBatchJobReview\");\r\n\t\t\tbatchJobEvent.setCreationDate(rightNow);\r\n\t\t\tbatchJobEvent.setCreatedBy(\"PeriodicBatchJobReview\");\r\n\t\t\tbatchJobEvent.setLastUpdate(rightNow);\r\n\t\t\tbatchJobEvent.setLastUpdateBy(\"PeriodicBatchJobReview\");\r\n\t\t\tbatchJobInstance.addEvent(batchJobEvent);\r\n\t\t\tbatchJobInstance.setLastUpdate(rightNow);\r\n\t\t\tbatchJobInstance.setLastUpdateBy(\"PeriodicBatchJobReview\");\r\n\t\t\tbatchJobInstanceManager.save(batchJobInstance);\r\n\t\t\tupdatedJobs++;\r\n\t\t} else {\r\n\t\t\tlog.error(\"Unable to retrieve instance \" + id + \"; job will not be updated.\");\r\n\t\t\tfailedUpdates++;\r\n\t\t}\r\n\t}",
"public void setCompleted(boolean achievementCompleted) {\n\t\t\n\t\tcompleted = achievementCompleted;\n\t\t\n\t}",
"public long getCompleted() { return completed; }",
"@IcalProperty(pindex = PropertyInfoIndex.COMPLETED,\n todoProperty = true)\n public void setCompleted(final String val) {\n completed = val;\n }",
"private void complete(final Resource resource) throws PersistenceException {\n final ModifiableValueMap mvm = resource.adaptTo(ModifiableValueMap.class);\n final String jobName = mvm.get(KEY_JOB_NAME, String.class);\n\n if (StringUtils.isNotBlank(jobName)) {\n scheduler.removeJob(jobName);\n\n log.info(\"Bulk Workflow Manager completed for [ {} ]\", jobName);\n\n mvm.put(KEY_STATE, STATE_COMPLETE);\n mvm.put(KEY_COMPLETED_AT, Calendar.getInstance());\n\n resource.getResourceResolver().commit();\n } else {\n log.error(\"Trying to complete a job without a name from Bulk Workflow Manager resource [ {} ]\",\n resource.getPath());\n }\n }",
"public void finishTask() {\n\t\t\n\t}",
"@Override\n public void completed(Integer result, String attachment)\n {\n }",
"@Override\n\tpublic void complete()\n\t{\n\t}",
"public void setDone() {\n isDone = true;\n }",
"public boolean is_completed();",
"void reportJobTaskProgress(final String jobTaskId, final int estimatedPercentageCompleted) throws JobReportingException;",
"public void completeTask() {\r\n int selected = list.getSelectedIndex();\r\n if (selected >= 0) {\r\n Task task = myTodo.getTaskByIndex(selected + 1);\r\n myTodo.getTodo().get(task.getHashKey()).setComplete(true);\r\n showCompleted = true;\r\n playSound(\"c1.wav\");\r\n }\r\n todoListGui();\r\n }",
"public void setDone(){\n this.status = \"Done\";\n }",
"public void finish(boolean b) {\n\t\tisFinished = b;\n\t}",
"private void addCompletedJobStats(CascadingJob job, HadoopStepStats stats) {\n if (workflowVersion == null) {\n workflowVersion = currentFlowId;\n }\n\n job.setJobStats(stats);\n jobs.add(job);\n }",
"@Override\n public void jobFinishedNotification(String scriptId, JobStats stats) {\n DAGNode<PigJob> node = dagNodeJobIdMap.get(stats.getJobId());\n if (node == null) {\n log.warn(\"Unrecognized jobId reported for succeeded job: \" + stats.getJobId());\n return;\n }\n\n addCompletedJobStats(node.getJob(), stats);\n pushEvent(scriptId, new Event.JobFinishedEvent(node));\n }",
"@Test\n void markCompleted() {\n }",
"public void setFinished(boolean fin) {\n finished = fin;\n }",
"public void setTaskCompleted(TaskAttemptID taskID) {\n taskStatuses.get(taskID).setState(TaskStatus.SUCCEEDED);\n successfulTaskID = taskID;\n activeTasks.remove(taskID);\n }",
"public void done() {\n isDone = true;\n }",
"public void setComplete(boolean complete) {\n\t\t\n\t}",
"public void markTaskItemAsComplete(int index) throws Exception {\n toggleBookMark(index, true);\n }",
"public void setFinished(boolean fin) {\n\t\tfinished = fin;\n\t}",
"public void setComplete(Boolean complete){\n this.complete = complete;\n }",
"boolean isDone(long number) throws NoSuchJobException;",
"void complete();",
"void complete();",
"public void setComplete(boolean complete) {\n }",
"protected void afterJobExecution() {\n\t}",
"@Override\n public final void onCompleted(final Run run, @Nonnull final TaskListener listener) {\n final String jobName = run.getParent().getDisplayName();\n\n // Process only if job in NOT in blacklist\n if ( isJobTracked(jobName) ) {\n logger.fine(\"Completed build!\");\n\n // Collect Data\n JSONObject builddata = gatherBuildMetadata(run, listener);\n\n // Add event_type to assist in roll-ups\n builddata.put(\"event_type\", \"build result\"); // string\n\n // Report Data\n event(builddata);\n gauge(\"jenkins.job.duration\", builddata, \"duration\");\n if ( \"SUCCESS\".equals(builddata.get(\"result\")) ) {\n serviceCheck(\"jenkins.job.status\", this.OK, builddata);\n } else {\n serviceCheck(\"jenkins.job.status\", this.CRITICAL, builddata);\n }\n }\n }",
"public void setStateComplete() {state = STATUS_COMPLETE;}",
"@DISPID(36)\r\n\t// = 0x24. The runtime will prefer the VTID if present\r\n\t@VTID(35)\r\n\tasci.activebatch.enumJobFlags jobStepsCompleted();",
"private void finishJob(int id) {\n Call<FinishJobResult> call = apiService.finishJob(id);\n final SharedPreferences.Editor editor = sharedPreferences.edit();\n call.enqueue(new Callback<FinishJobResult>() {\n @Override\n public void onResponse(Call<FinishJobResult> call, Response<FinishJobResult> response) {\n FinishJobResult finishJobResult = response.body();\n try {\n if (finishJobResult.getSuccess() == 1) {\n //job is now status 2 and it is finished\n editor.putInt(\"JOB_HANDLED\", 0);\n editor.apply();\n Toast.makeText(MapActivity.this, \"Done handling request.\", Toast.LENGTH_SHORT).show();\n recreate();\n }\n } catch (Exception e) {\n }\n }\n\n @Override\n public void onFailure(Call<FinishJobResult> call, Throwable t) {\n Toast.makeText(MapActivity.this, \"lease try again\", Toast.LENGTH_SHORT).show();\n }\n });\n }",
"@Override\n public void afterCompletion(boolean arg0) throws EJBException,\n \t\tRemoteException {\n \tSystem.out.println(\"taskerBean transaction done\");\n }",
"private void doFinishJob\n\t\t(long now,\n\t\t JobInfo jobinfo)\n\t\tthrows IOException\n\t\t{\n\t\tmyLog.log (now, \"Job \" + jobinfo.jobnum + \" finished\");\n\t\tdoCleanupJob (now, jobinfo);\n\t\t}",
"void completed(TestResult tr);",
"public synchronized void setFinished(boolean f){\n finished = f;\n }",
"@Override\r\n\tpublic void doAfterJob() {\n\r\n\t}",
"@Override\n public boolean isFinished() {\n return complete;\n }",
"public void markAsCompleted(BulkItemResponse translatedResponse) {\n assertInvariants(ItemProcessingState.EXECUTED);\n assert executionResult != null && translatedResponse.getItemId() == executionResult.getItemId();\n assert translatedResponse.getItemId() == getCurrentItem().id();\n\n if (translatedResponse.isFailed() == false && requestToExecute != null && requestToExecute != getCurrent()) {\n request.items()[currentIndex] = new BulkItemRequest(request.items()[currentIndex].id(), requestToExecute);\n }\n getCurrentItem().setPrimaryResponse(translatedResponse);\n currentItemState = ItemProcessingState.COMPLETED;\n advance();\n }",
"public void saveAndUpdateJobStatus(AbstractPersistedAnalysisJob job) {\r\n job.setLastUpdateDate(new Date());\r\n getWorkspaceService().savePersistedAnalysisJob(job);\r\n updateJobStatus(job);\r\n }",
"@Override\n\tpublic void completed() {\n\t\tSystem.out.println(\"Message Completed: \" + toString());\n\t\tscheduler.putResourceIdle();\n\t\ttry {\n\t\t\tscheduler.applyScheduling();\n\t\t} catch (Exception e) {\n\t\t\t// this should be logged or on a GUI show a dialog of the error\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public void setComplete(boolean value) {\n\t\tif (value) {\n\t\t\tcountdown = EXIT_COUNT;\n\t\t}\n\t\tcomplete = value;\n\t\t//\t\tif (value) waitSeconds(3);\n\t}",
"public void setDone(boolean value) {\n this.done = value;\n }",
"public void markTaskCompleted(int taskIndex) {\n Task taskToMark = tasks.get(taskIndex);\n taskToMark.markTaskAsCompleted();\n cachedTasks.push(new CachedTask(taskToMark, \"done\", taskIndex));\n }"
]
| [
"0.76233125",
"0.74712735",
"0.73772866",
"0.7176261",
"0.7134803",
"0.71107465",
"0.7099229",
"0.7099229",
"0.7099229",
"0.7044932",
"0.7004043",
"0.6981851",
"0.6969456",
"0.68910736",
"0.68910736",
"0.68910736",
"0.68586075",
"0.68369293",
"0.68194795",
"0.6797855",
"0.6796036",
"0.67725116",
"0.6766198",
"0.67608786",
"0.6759695",
"0.6699679",
"0.66859484",
"0.663273",
"0.6604209",
"0.659886",
"0.64911264",
"0.6487713",
"0.64875513",
"0.64219475",
"0.6393949",
"0.63611597",
"0.63234234",
"0.6309889",
"0.6308938",
"0.630294",
"0.630294",
"0.630294",
"0.62868726",
"0.62464124",
"0.6241876",
"0.62404996",
"0.6231763",
"0.62150264",
"0.6174449",
"0.6167859",
"0.61584944",
"0.6132941",
"0.6110982",
"0.6099999",
"0.6085642",
"0.60633534",
"0.60529137",
"0.60414386",
"0.60358506",
"0.60140276",
"0.6013856",
"0.6007832",
"0.6002763",
"0.6000124",
"0.59913737",
"0.59898174",
"0.59869254",
"0.597739",
"0.59771043",
"0.5968909",
"0.59681904",
"0.59627795",
"0.5958952",
"0.5957293",
"0.5953663",
"0.5949411",
"0.5940004",
"0.5936855",
"0.59358406",
"0.5924599",
"0.5895544",
"0.5895544",
"0.5893188",
"0.58865905",
"0.58858997",
"0.5879522",
"0.5877627",
"0.5844059",
"0.58373904",
"0.583144",
"0.5829058",
"0.5820539",
"0.5810496",
"0.5807444",
"0.58042973",
"0.57967305",
"0.57934576",
"0.57878",
"0.5786748",
"0.57855886"
]
| 0.62121254 | 48 |
init of blocks and registration naming oredict gameregistry | public static void init () {
/*
* Letter block naming and registry code
*/
for (int i = 0; i <= NameHandler.length(); ++i) {
BlockLetter bL = new BlockLetter();
String name = NameHandler.getNameFromIndex(i);
bL.setBlockName(name);
GameRegistry.registerBlock(bL, name);
letterBlocks.add(bL);
}
copperBlock.setBlockName(Names.Blocks.COPPER_BLOCK);
tinBlock.setBlockName(Names.Blocks.TIN_BLOCK);
silverBlock.setBlockName(Names.Blocks.SILVER_BLOCK);
classicBronzeBlock.setBlockName(Names.Blocks.CLASSIC_BRONZE_BLOCK);
mildBronzeBlock.setBlockName(Names.Blocks.MILD_BRONZE_BLOCK);
electrumBlock.setBlockName(Names.Blocks.ELECTRUM_BLOCK);
copperDustBlock.setBlockName(Names.Blocks.COPPER_DUST_BLOCK);
copperOre.setBlockName(Names.Blocks.COPPER_ORE);
tinOre.setBlockName(Names.Blocks.TIN_ORE);
silverOre.setBlockName(Names.Blocks.SILVER_ORE);
marble.setBlockName(Names.Blocks.MARBLE);
grindstone.setBlockName(Names.Blocks.GRINDSTONE);
GameRegistry.registerBlock(column, Names.Blocks.COLUMN);
GameRegistry.registerBlock(copperBlock, Names.Blocks.COPPER_BLOCK);
GameRegistry.registerBlock(tinBlock, Names.Blocks.TIN_BLOCK);
GameRegistry.registerBlock(silverBlock, Names.Blocks.SILVER_BLOCK);
GameRegistry.registerBlock(classicBronzeBlock, Names.Blocks.CLASSIC_BRONZE_BLOCK);
GameRegistry.registerBlock(mildBronzeBlock, Names.Blocks.MILD_BRONZE_BLOCK);
GameRegistry.registerBlock(electrumBlock, Names.Blocks.ELECTRUM_BLOCK);
GameRegistry.registerBlock(copperDustBlock, Names.Blocks.COPPER_DUST_BLOCK);
GameRegistry.registerBlock(copperOre, Names.Blocks.COPPER_ORE);
GameRegistry.registerBlock(tinOre, Names.Blocks.TIN_ORE);
GameRegistry.registerBlock(silverOre, Names.Blocks.SILVER_ORE);
GameRegistry.registerBlock(marble, Names.Blocks.MARBLE);
GameRegistry.registerBlock(grindstone, Names.Blocks.GRINDSTONE);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public static void init()\n {\n oreStarSteel = new BlockOreStarSteel(MSAConfig.ores, Material.rock);\n storageStarSteel = new BlockStorageStarSteel(MSAConfig.storageBlock, Material.iron);\n // tech blocks\n launchTower = new BlockLaunchTower(MSAConfig.launchTower, Material.iron);\n launchTowerController = new BlockLaunchControl(MSAConfig.launchController, Material.iron);\n rocketAssembler = new BlockRocketAssembler(MSAConfig.rocketAssembler, Material.iron);\n comSatellite = new BlockComSatellite(MSAConfig.comSatellite, Material.iron);\n ssBuilding = new BlockSSBuilding(MSAConfig.ssBuilding, Material.rock);\n commandCenter = new BlockCommandCenter(MSAConfig.commandCenter, Material.iron);\n\n /* Register Blocks */\n // ore blocks\n GameRegistry.registerBlock(oreStarSteel, \"oreStarSteel\");\n GameRegistry.registerBlock(storageStarSteel, \"storageStarSteel\");\n // tech blocks\n GameRegistry.registerBlock(launchTower, \"launchTower\");\n GameRegistry.registerBlock(launchTowerController, \"launchTowerController\");\n GameRegistry.registerBlock(rocketAssembler, \"rocketAssembler\");\n GameRegistry.registerBlock(comSatellite, \"comSatellite\");\n GameRegistry.registerBlock(ssBuilding, \"ssBuilding\");\n GameRegistry.registerBlock(commandCenter, \"commandCenter\");\n\n /* Set block harvest level */\n // ore blocks\n MinecraftForge.setBlockHarvestLevel(oreStarSteel, \"pickaxe\", 2);\n MinecraftForge.setBlockHarvestLevel(storageStarSteel, \"pickaxe\", 2);\n // building blocks\n MinecraftForge.setBlockHarvestLevel(ssBuilding, \"pickaxe\", 2);\n // tech blocks\n MinecraftForge.setBlockHarvestLevel(launchTower, \"pickaxe\", 1);\n }",
"public static void initializeBlocks() {\n if (Config.enableGiveADamn) {\n giveADamn = new GiveADamn();\n }\n\n if (Config.enableGlowstone) {\n glowstone = new HeavyLight();\n }\n\n if (Config.enableSpicedSand) {\n sandSpiced = new SpicedSand();\n }\n /*\n\n if (Config.enableMuffler){\n muffler = new Muffler();\n }\n */\n }",
"public static void init() {\n Handler.log(Level.INFO, \"Loading Blocks\");\n\n oreAluminum = new BaseOre(Config.oreAluminumID).setUnlocalizedName(Archive.oreAluminum)\n .setHardness(3.0F).setResistance(5.0F);\n\n blockGrinder = new BaseContainerBlock(Config.blockGrinderID, Archive.grinderGUID)\n .setUnlocalizedName(Archive.blockGrinder);\n\n blockOven = new BaseContainerBlock(Config.blockOvenID, Archive.ovenGUID)\n .setUnlocalizedName(Archive.blockOven);\n }",
"public static void initialize()\n {\n CHUNK_LOADER = new ChunkLoader();\n //VILLAGE_INDICATOR = new VillageIndicator();\n\n BLOCK_LIST.add(CHUNK_LOADER);\n //BLOCK_LIST.add(VILLAGE_INDICATOR);\n Log.info(\"=========================================================> Initialized Blocks\");\n }",
"private void setBlocks() {\n // load the class\n ClassLoader cl = ClassLoader.getSystemClassLoader();\n // create an InputStream object\n InputStream inputStream = cl.getResourceAsStream(this.map.get(\"block_definitions\"));\n // initialize this factory with a factory\n this.factory = BlocksDefinitionReader.fromReader(new InputStreamReader(inputStream));\n try {\n inputStream.close();\n } catch (IOException e) {\n e.printStackTrace();\n }\n\n }",
"private static void registerBlocks() {\n for(Block block : modBlocks) {\n ForgeRegistries.BLOCKS.register(block);\n\n ItemBlock itemBlock = new ItemBlock(block);\n itemBlock.setRegistryName(block.getRegistryName());\n ForgeRegistries.ITEMS.register(itemBlock);\n }\n }",
"public static void registerBlocks() {\n\t\tRegistry.register(Registry.BLOCK, new Identifier(EggMod.MOD_ID, \"egg_block\"), EGG_BLOCK);\n\t\t\n\t\t// Yolk\n\t\tSTILL_YOLK = Registry.register(Registry.FLUID, new Identifier(EggMod.MOD_ID, \"yolk_flow\"), new YolkFluid.Still());\n\t\tFLOWING_YOLK = Registry.register(Registry.FLUID, new Identifier(EggMod.MOD_ID, \"yolk_still\"), new YolkFluid.Flowing());\n\t\tYOLK = Registry.register(Registry.BLOCK, new Identifier(EggMod.MOD_ID, \"yolk\"), new FluidBlock(STILL_YOLK, FabricBlockSettings.copy(Blocks.WATER)){});\n\t}",
"public void register(WorldGenKawaiiBaseWorldGen.WorldGen gen)\r\n\t{\t\r\n\t\tif (!this.Enabled) return; \r\n\t\tGameRegistry.registerBlock(this, this.getUnlocalizedName());\r\n\t\t\r\n\t\tString saplingName = name + \".sapling\";\r\n\t\tSapling = new ItemKawaiiSeed(saplingName, SaplingToolTip, this);\r\n\t\tSapling.OreDict = SaplingOreDict;\r\n\t\tSapling.MysterySeedWeight = SeedsMysterySeedWeight;\r\n\t\tSapling.register();\r\n\r\n\t\tString fruitName = name + \".fruit\";\r\n\t\tif (FruitEdible)\r\n\t\t{\r\n\t\t\tItemKawaiiFood fruit = new ItemKawaiiFood(fruitName, FruitToolTip, FruitHunger, FruitSaturation, FruitPotionEffets);\r\n\t\t\tFruit = fruit;\r\n\t\t\tfruit.OreDict = FruitOreDict;\r\n\t\t\t\r\n\t\t\tfruit.register();\r\n\t\t}\r\n\t\telse\r\n\t\t{\r\n\t\t\tItemKawaiiIngredient fruit = new ItemKawaiiIngredient(fruitName, FruitToolTip);\r\n\t\t\tFruit = fruit;\r\n\t\t\tfruit.OreDict = FruitOreDict;\r\n\t\t\t\r\n\t\t\tfruit.register();\r\n\t\t}\r\n\t\t\r\n\t\tif (gen.weight > 0)\r\n\t\t{\r\n\t\t\tgen.generator = new WorldGenKawaiiTree(this);\r\n\t\t\tModWorldGen.WorldGen.generators.add(gen);\r\n\t\t}\r\n\r\n\t\tModBlocks.AllTrees.add(this);\t\t\r\n\t}",
"public static void init () {\n\t\tGameRegistry.addRecipe(new ItemStack(ModBlocks.sea_lantern), \"XYX\", \"YYY\", \"XYX\", 'X', ModItems.prismarine_shard, 'Y', ModItems.prismarine_crystals);\r\n\t\t//Prismarine\r\n\t\tGameRegistry.addRecipe(new ItemStack(ModBlocks.prismarine, 1, 0), \" \", \"XX \", \"XX \", 'X', ModItems.prismarine_shard);\r\n\t\t//Prismarine Bricks\r\n\t\tGameRegistry.addRecipe(new ItemStack(ModBlocks.prismarine, 1, 1), \"XXX\", \"XXX\", \"XXX\", 'X', ModItems.prismarine_shard);\r\n\t\t//Dark Prismarine\r\n\t\tGameRegistry.addRecipe(new ItemStack(ModBlocks.prismarine, 1, 2), \"XXX\", \"XYX\", \"XXX\", 'X', ModItems.prismarine_shard, 'Y', Item.getItemById(351));\r\n\t\t//Cooked mutton\r\n\t\tGameRegistry.addSmelting(new ItemStack(ModItems.mutton_raw), new ItemStack(ModItems.mutton_cooked), 0.35f);\r\n\t\t//Iron trapdoor\r\n\t\tGameRegistry.addRecipe(new ItemStack(ModBlocks.iron_trapdoor), \"XX \", \"XX \", \" \", 'X', Blocks.iron_bars);\r\n\t\tGameRegistry.addRecipe(new ItemStack(ModBlocks.iron_trapdoor), \" XX\", \" XX\", \" \", 'X', Blocks.iron_bars);\r\n\t\tGameRegistry.addRecipe(new ItemStack(ModBlocks.iron_trapdoor), \" \", \"XX \", \"XX \", 'X', Blocks.iron_bars);\r\n\t\tGameRegistry.addRecipe(new ItemStack(ModBlocks.iron_trapdoor), \" \", \" XX\", \" XX\", 'X', Blocks.iron_bars);\r\n\t}",
"private static void registerBlock(Block b)\n\t{\n\t}",
"public static void initAndRegister() {\n\t\tAcaciaPlate.setHarvestLevel(\"axe\", 0);\n\t\tBirchPlate.setHarvestLevel(\"axe\", 0);\n\t\tCactusPlate.setHarvestLevel(\"axe\", 0);\n\t\tDarkOakPlate.setHarvestLevel(\"axe\", 0);\n\t\tDiamondPlate.setHarvestLevel(\"pickaxe\", 2);\n\t\tEmeraldPlate.setHarvestLevel(\"pickaxe\", 2);\n\t\tGlowingObsidianPlate.setHarvestLevel(\"pickaxe\", 3);\n\t\tJunglePlate.setHarvestLevel(\"axe\", 0);\n\t\tSilverPlate.setHarvestLevel(\"pickaxe\", 2);\n\t\tRubyPlate.setHarvestLevel(\"pickaxe\", 2);\n\t\tSprucePlate.setHarvestLevel(\"axe\", 0);\n\n\t\t//grass and dirt\n\t\tUtils.regBlock(DirtPlate.setUnlocalizedName(\"DirtPlate\").setRegistryName(\"dirt_pressure_plate\"));\n\t\tUtils.regBlock(GrassPlate.setUnlocalizedName(\"GrassPlate\").setRegistryName(\"grass_pressure_plate\"));\n\t\t\n\t\t//special\n\t\tUtils.regBlock(DiamondPlate.setUnlocalizedName(\"DiamondPlate\").setRegistryName(\"diamond_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(EmeraldPlate.setUnlocalizedName(\"EmeraldPlate\").setRegistryName(\"emerald_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(glassPlate.setUnlocalizedName(\"GlassPlate\").setRegistryName(\"glass_pressure_plate\").setHardness(0.1F));\n\t\tUtils.regBlock(SilverPlate.setUnlocalizedName(\"SilverPlate\").setRegistryName(\"silver_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(RubyPlate.setUnlocalizedName(\"RubyPlate\").setRegistryName(\"ruby_pressure_plate\").setHardness(0.5F));\n\n\t\t//stone variants\n\t\tUtils.regBlock(MossyPlate.setUnlocalizedName(\"MossyPlate\").setRegistryName(\"mossy_cobblestone_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(CobblestonePlate.setUnlocalizedName(\"CobblestonePlate\").setRegistryName(\"cobblestone_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(AndesitePlate.setUnlocalizedName(\"AndesitePlate\").setRegistryName(\"andesite_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(DioritePlate.setUnlocalizedName(\"DioritePlate\").setRegistryName(\"diorite_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(GranitePlate.setUnlocalizedName(\"GranitePlate\").setRegistryName(\"granite_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(EndPlate.setUnlocalizedName(\"EndPlate\").setRegistryName(\"end_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(sandstonePlate.setUnlocalizedName(\"SandstonePlate\").setRegistryName(\"sandstone_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(redSandstonePlate.setUnlocalizedName(\"RedSandstonePlate\").setRegistryName(\"red_sandstone_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(VoidPlate.setUnlocalizedName(\"VoidPlate\").setRegistryName(\"void_pressure_plate\").setHardness(0.5F));\n\n\t\t//unbreakable\n\t\tUtils.regBlock(BedrockPlate.setUnlocalizedName(\"BedrockPlate\").setRegistryName(\"bedrock_pressure_plate\").setHardness(-1F).setResistance(6000000F).setBlockUnbreakable());\n\t\tUtils.regBlock(GlowingObsidianPlate.setUnlocalizedName(\"GlowingObsidianPlate\").setRegistryName(\"glowing_obsidian_pressure_plate\").setHardness(51F).setResistance(2000F).setLightLevel(.46666667F));\n\n\t\t//wooden\n\t\tUtils.regBlock(AcaciaPlate.setUnlocalizedName(\"AcaciaPlate\").setRegistryName(\"acacia_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(BirchPlate.setUnlocalizedName(\"BirchPlate\").setRegistryName(\"birch_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(CactusPlate.setUnlocalizedName(\"CactusPlate\").setRegistryName(\"cactus_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(DarkOakPlate.setUnlocalizedName(\"DarkOakPlate\").setRegistryName(\"dark_oak_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(JunglePlate.setUnlocalizedName(\"JunglePlate\").setRegistryName(\"jungle_pressure_plate\").setHardness(0.5F));\n\t\tUtils.regBlock(SprucePlate.setUnlocalizedName(\"SprucePlate\").setRegistryName(\"spruce_pressure_plate\").setHardness(0.5F));\n\t}",
"public static void init() {\n GameRegistry.addSmelting(OinkBlocks.OINK_IRON_ORE, new ItemStack(OinkItems.OINK_IRON_INGOT), 1.0F);\n GameRegistry.addSmelting(OinkBlocks.OINK_GOLD_ORE, new ItemStack(OinkItems.OINK_GOLD_INGOT), 1.0F);\n\n //Oink Dust to Ingots\n GameRegistry.addSmelting(OinkItems.OINK_PIG_IRON_DUST, new ItemStack(OinkItems.OINK_IRON_INGOT, 2, 0), 0.7F);\n GameRegistry.addSmelting(OinkItems.OINK_PIG_GOLD_DUST, new ItemStack(OinkItems.OINK_GOLD_INGOT, 2, 0), 0.7F);\n GameRegistry.addSmelting(OinkItems.OINK_PIG_DIAMOND_DUST, new ItemStack(OinkItems.OINK_DIAMOND, 2, 0), 0.7F);\n GameRegistry.addSmelting(OinkItems.OINK_IRON_DUST, new ItemStack(Items.IRON_INGOT, 1, 0), 0.7F);\n GameRegistry.addSmelting(OinkItems.OINK_GOLD_DUST, new ItemStack(Items.GOLD_INGOT, 1, 0), 0.7F);\n GameRegistry.addSmelting(OinkItems.OINK_DIAMOND_DUST, new ItemStack(Items.DIAMOND, 1, 0), 0.7F);\n\n //Oink Ingots to Vanilla Ingots\n GameRegistry.addSmelting(OinkItems.OINK_IRON_INGOT, new ItemStack(Items.IRON_INGOT, 1, 0), 0.7F);\n GameRegistry.addSmelting(OinkItems.OINK_GOLD_INGOT, new ItemStack(Items.GOLD_INGOT, 1, 0), 0.7F);\n GameRegistry.addSmelting(OinkItems.OINK_DIAMOND, new ItemStack(Items.DIAMOND, 1, 0), 0.7F);\n\n //Food\n GameRegistry.addSmelting(OinkItems.OINK_MINCED_PORK, new ItemStack(Items.COOKED_PORKCHOP, 2, 0), 0.5F);\n GameRegistry.addSmelting(OinkItems.OINK_IRON_PORKCHOP_RAW, new ItemStack(OinkItems.OINK_IRON_PORKCHOP, 1, 0), 0.5F);\n GameRegistry.addSmelting(OinkItems.OINK_GOLD_PORKCHOP_RAW, new ItemStack(OinkItems.OINK_GOLD_PORKCHOP, 1, 0), 0.5F);\n GameRegistry.addSmelting(OinkItems.OINK_DIAMOND_PORKCHOP_RAW, new ItemStack(OinkItems.OINK_DIAMOND_PORKCHOP, 1, 0), 0.5F);\n GameRegistry.addSmelting(OinkItems.OINK_ULTIMATE_PORKCHOP_RAW, new ItemStack(OinkItems.OINK_ULTIMATE_PORKCHOP, 1, 0), 3.0F);\n\n //Oink Stuff to MC Stuff\n GameRegistry.addSmelting(OinkItems.OINK_IRON_INGOT, new ItemStack(Items.IRON_INGOT, 2), 1.8F);\n }",
"public void initialize() {\r\n addSprite(this.info.getBackground());\r\n createBorders();\r\n defineDeathBlock();\r\n addIndicators();\r\n BlockRemover removeBlock = new BlockRemover(this, this.remainingBlocks);\r\n// this.remainingBlocks=removeBlock.getRemainingBlocks();\r\n ScoreTrackingListener scoreTrackingListener = new ScoreTrackingListener(this.score);\r\n for (int i = 0; i < info.blocks().size(); i++) {\r\n info.blocks().get(i).addHitListener(removeBlock);\r\n info.blocks().get(i).addHitListener(scoreTrackingListener);\r\n info.blocks().get(i).addToGame(this);\r\n }\r\n }",
"public static void preInit() {\n registerBlocks();\n }",
"public static void register() {\n Registry.register(Registry.BLOCK, new Identifier(\"cultivation\", \"sieve_block\"), SIEVE_BLOCK);\n Registry.register(Registry.ITEM, new Identifier(\"cultivation\", \"sieve_block\"), new BlockItem(SIEVE_BLOCK, new Item.Settings().group(Cultivation.GROUP)));\n Registry.register(Registry.BLOCK, new Identifier(\"cultivation\", \"pod_shell\"), POD_SHELL);\n }",
"public static void initializeBlockFields() {\n KitchenMod.LOGGER.log(\"Initializing static block fields\");\n KMComposterBlock.rinit();\n\n StakeBlock.registerPlant(GRAPE_VINE);\n StakeBlock.registerPlant(TOMATO_VINE);\n StakeBlock.registerPlant(VANILLA_VINE);\n }",
"public void initialize() {\n // create a runner using a function\n this.createScreenBorders();\n // create a keyboard sensor.\n this.keyboard = this.runner.getGUI().getKeyboardSensor();\n //create the environment for the game (game environment and sprites collection)\n this.createEnvironment();\n // BACKGROUND CREATION //\n this.createBackground();\n // create the counters for the game.\n this.createCounters();\n // LISTENERS CREATION //\n //create a message printing listener.\n HitListener phl = new PrintingHitListener();\n //create a new block remover listener.\n HitListener blockrmv = new BlockRemover(this, blockCounter);\n //create a new ball remover listener.\n HitListener ballrmv = new BallRemover(this, ballCounter);\n //create a new score counter listener.\n HitListener scorelstn = new ScoreTrackingListener(this.scoreCounter);\n // BLOCKS CREATION //\n this.createBlocks(phl, blockrmv, scorelstn);\n // SIDE BLOCKS CREATION //\n this.createSideBlocks();\n // DEATH BLOCK CREATION //\n this.createDeathBlock(ballrmv);\n // LEVEL'S NAME //\n LevelsName name = new LevelsName(this.levelInfo.levelName());\n // add the whole-game indicators to the sprites list.\n this.sprites.addSprite(scoreIndi);\n this.sprites.addSprite(lifeIndi);\n this.sprites.addSprite(name);\n }",
"static void init() {\n\t\tContainerProviderRegistry.INSTANCE.registerFactory(ROCKET_CRATE_CONTAINER,\n\t\t\t\t(syncId, id, player, buf) -> new RocketCrateScreenHandler(syncId, buf.readInt(), player.inventory));\n\t\tContainerProviderRegistry.INSTANCE.registerFactory(LAUNCH_PAD_CONTAINER,\n\t\t\t\t(syncId, id, player, buf) -> new LaunchPadScreenHandler(syncId, buf.readBlockPos(), player.inventory));\n\t\tContainerProviderRegistry.INSTANCE.registerFactory(CONTRACT_MACHINE,\n\t\t\t\t(syncId, id, player, buf) -> new ContractMachineScreenHandler(syncId, buf.readBlockPos(), player.inventory));\n\t}",
"public static void registerBlocks() {\n\t\tModLoader.registerBlock(blockWirelessR,\n\t\t\t\tBlockItemRedstoneWirelessR.class);\n\t\tModLoader.addName(blockWirelessR, \"Wireless Receiver\");\n\t\tModLoader.addName(blockWirelessR, \"de_DE\", \"Drahtloser Empfänger\");\n\t\tModLoader.registerTileEntity(TileEntityRedstoneWirelessR.class,\n\t\t\t\t\"Wireless Receiver\", new TileEntityRedstoneWirelessRenderer());\n\n\t\tModLoader.registerBlock(blockWirelessT,\n\t\t\t\tBlockItemRedstoneWirelessT.class);\n\t\tModLoader.addName(blockWirelessT, \"Wireless Transmitter\");\n\t\tModLoader.addName(blockWirelessT, \"de_DE\", \"Drahtloser Sender\");\n\t\tModLoader.registerTileEntity(TileEntityRedstoneWirelessT.class,\n\t\t\t\t\"Wireless Transmitter\",\n\t\t\t\tnew TileEntityRedstoneWirelessRenderer());\n\t\tregisterBlockForCreativeGui(blockWirelessR);\n\t\tregisterBlockForCreativeGui(blockWirelessT);\n\t}",
"public static void registerBlockEntities()\n\t{\n\t}",
"public HMetis() {\n\t\tthis.init();\n\t}",
"Tetrisblock2()\n {\n newblockparam();\n newmapparam();\n setboundary();\n }",
"@Override\n\tpublic void onInitialize() {\n\n\t\tSystem.out.println(\"Welcome to Plastic Version 1.0\");\n\t\tRegistry.register(Registry.BLOCK, new Identifier(\"plastic\", \"plastic_ore\"), plastic_ore);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"plastic_ore\"), new BlockItem(plastic_ore, new Item.Settings().group(plastic_tab)));\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"plastic\"), plastic);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"plastic_dust\"), plastic_dust);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"plastic_mix\"), plastic_mix);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"apple_plastic\"), apple_plastic);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"raw_plastic\"), raw_plastic);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"plastic_pick\"), new PickaxeBase(new PlasticTool(), -2.2f));\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"duct_tape\"), duct_tape);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"plastic_bowl\"), plastic_bowl);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"dank\"), dank);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"burnt_plastic\"), burnt_plastic);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"burnt_bowl\"), burnt_bowl);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"strong_plastic\"), strong_plastic);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"raw_mix\"), raw_mix);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"plastic_book\"), plastic_book);\n\n\t\t// shit for blocks with inventories\n\t\tRegistry.register(Registry.BLOCK, new Identifier(\"plastic\", \"plastic_box\"), plastic_box);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"plastic_box\"), new BlockItem(plastic_box, new Item.Settings().group(plastic_tab)));\n\t\tplasticBox_ent = Registry.register(Registry.BLOCK_ENTITY_TYPE, \"plastic:plastic_box_ent\", BlockEntityType.Builder.create(PlasticBox::new, plastic_box).build(null));\n\t\tplasticBox_ent2 = Registry.register(Registry.BLOCK_ENTITY_TYPE, \"plastic:plastic_box_ent2\", BlockEntityType.Builder.create(PlasticBox2::new, plastic_boxtwo).build(null));\n\t\tContainerProviderRegistry.INSTANCE.registerFactory(new Identifier(\"plastic\", \"plastic_box\"), (syncId, id, player, buf) -> new GuiController(configUtil.getControllerConfig(syncId, 1), player.inventory, BlockContext.create(player.world, buf.readBlockPos()), \"block.plastic.plastic_box\"));\n\t\tRegistry.register(Registry.BLOCK, new Identifier(\"plastic\", \"plastic_boxtwo\"), plastic_boxtwo);\n\t\tContainerProviderRegistry.INSTANCE.registerFactory(new Identifier(\"plastic\", \"plastic_boxtwo\"), (syncId, id, player, buf) -> new GuiController(configUtil.getControllerConfig(syncId, 2), player.inventory, BlockContext.create(player.world, buf.readBlockPos()), \"block.plastic.plastic_boxtwo\"));\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"plastic_boxtwo\"), new BlockItem(plastic_boxtwo, new Item.Settings().group(plastic_tab)));\n\n\t\t// Plastic Combiner stuff starts here\n\t\tRegistry.register(Registry.BLOCK, new Identifier(\"plastic\", \"plastic_compressor\"), plastic_compressor);\n\t\tRegistry.register(Registry.ITEM, new Identifier(\"plastic\", \"plastic_compressor\"), new BlockItem(plastic_compressor, new Item.Settings().group(plastic_tab)));\n\t\tplasticCombine_ent = Registry.register(Registry.BLOCK_ENTITY_TYPE, \"plastic:plastic_combine_ent\", BlockEntityType.Builder.create(PlasticCompressor::new, plastic_compressor).build(null));\n\t\tContainerProviderRegistry.INSTANCE.registerFactory(new Identifier(\"plastic\", \"plastic_compressor\"), (syncId, id, player, buf) -> new CompressorGUI(syncId, player.inventory, BlockContext.create(player.world, buf.readBlockPos())));\n\n\t}",
"public static void createItems(){\n Registry.register(Registry.ITEM, new Identifier(nameSpace, \"breadly\"), BREADLY);\n Registry.register(Registry.ITEM, new Identifier(nameSpace, \"hard_boiled_egg\"), HARD_BOILED_EGG);\n\n\n Registry.register(Registry.ITEM, new Identifier(nameSpace, \"ender_dragon_spawn_egg\"), ENDER_DRAGON_SPAWN_EGG);\n Registry.register(Registry.ITEM, new Identifier(nameSpace, \"wither_spawn_egg\"), WITHER_SPAWN_EGG);\n Registry.register(Registry.ITEM, new Identifier(nameSpace, \"illusioner_spawn_egg\"), ILLUSIONER_SPAWN_EGG);\n Registry.register(Registry.ITEM, new Identifier(nameSpace, \"giant_spawn_egg\"), GIANT_SPAWN_EGG);\n Registry.register(Registry.ITEM, new Identifier(nameSpace, \"spawn_spawn_egg\"), SPAWN_SPAWN_EGG);\n }",
"public final void init() {\r\n GroundItemManager.create(this);\r\n SPAWNS.add(this);\r\n }",
"public Block(){\n\t\tinstns = new ArrayList<Instruction>();\n\t}",
"public void init() {\n\t\t\n\t\t\n\t\tprepareGaborFilterBankConcurrent();\n\t\t\n\t\tprepareGaborFilterBankConcurrentEnergy();\n\t}",
"public static void init() {\n\t\tregisterRecipes();\n\t\tregisterShapelessRecipes();\n\t\tregisterSmeltingRecipes();\n\t}",
"public static void mainRegistry() {\n\t\tregisterTileEntity(TileEntityLightningCell.class);\n\t\tregisterTileEntity(TileEntityLightningFurnace.class);\n\t\tregisterTileEntity(TileEntityLightningCrusher.class);\n\t\tregisterTileEntity(TileEntityLightningInfuser.class);\n\t\tregisterTileEntity(TileEntityLightningBreaker.class);\n\t\tregisterTileEntity(TileEntityLightningMiner.class);\n\t\tregisterTileEntity(TileEntityStaticGenerator.class);\n\t\tregisterTileEntity(TileEntityChargingPlate.class);\n\t\tregisterTileEntity(TileEntityEnchReallocator.class);\n\t\tregisterTileEntity(TileEntityLightningCannon.class);\n\t\tregisterTileEntity(TileEntityLightningTransmitter.class);\n\t\tregisterTileEntity(TileEntityLightningReceiver.class);\n\t\tregisterTileEntity(TileEntityEnergyProvider.class);\n\t\tregisterTileEntity(TileEntityEnergyReceiver.class);\n\t}",
"private void init() {\n\n\t}",
"@SubscribeEvent\n public static void onRegisterBlocks(RegistryEvent.Register<Block> event) {\n CoffeeMachineBlock coffeMachine = new CoffeeMachineBlock(\n Block.Properties.create(Material.ANVIL)\n .hardnessAndResistance(-1.0F, 360000F));\n event.getRegistry().registerAll(setup(coffeMachine, \"coffee_machine\"));\n }",
"public void init() {\n\t\t\n\t\tdebugPrintln(\"Doing init.\");\n\t\t\n\t\t// can sanity check some things by requesting notification when nodes\n\t\t// are created/deleted/etc.\n\t\t// It does not notify when playBufs reach the end of a buffer, though.\n\t\t// Too bad, that. Would have to poll.\n\t\tsendMessage(\"/notify\", new Object[] { 1 });\n\n\t\t//start by cleaning up any detritus from previous runs on the same server:\n\t\tcleanup();\n\n\t\t//sclang creates the default group, not supercollider, so let's follow that convention.\n\t\tcreateGroup(1, 0);\n\n\t\t// create a mother group, under the default group (1),\n\t\t// which will contain all of the SCSoundControl objects.\n\t\t//this is where we would query if another node == _motherGroupID already exists.\n\t\t//if so, would need to choose an alternate groupID (e.g. += 10000)\n\t\tcreateGroup(_motherGroupID, 1);\n\t\t\n\t}",
"Tetrisblock()\n {\n newblockparam();\n newmapparam();\n setboundary();\n }",
"private static void populateBlocks() {\n\n //TODO set sensors for each\n\n /* Path A */\n SW1A.setProceeding(new Block[]{SW2A, STA1Z, SW2B});\n SW1A.setPreceding(new Block[]{PTH5A});\n\n SW2A.setProceeding(new Block[]{LD1A});\n SW2A.setPreceding(new Block[]{SW1A});\n\n SW3A.setProceeding(new Block[]{SW4A});\n SW3A.setPreceding(new Block[]{LD1A});\n\n SW4A.setProceeding(new Block[]{PTH1A});\n SW4A.setPreceding(new Block[]{SW3A, STA1Z, SW3B});\n\n PTH1A.setProceeding(new Block[]{PTH2A});\n PTH1A.setPreceding(new Block[]{SW4A});\n\n PTH2A.setProceeding(new Block[]{PTH3A});\n PTH2A.setPreceding(new Block[]{PTH1A});\n\n PTH3A.setProceeding(new Block[]{PTH4A});\n PTH3A.setPreceding(new Block[]{PTH2A});\n\n PTH4A.setProceeding(new Block[]{PTH5A});\n PTH4A.setPreceding(new Block[]{PTH3A});\n\n PTH5A.setProceeding(new Block[]{SW1A});\n PTH5A.setPreceding(new Block[]{PTH4A});\n\n LD1A.setProceeding(new Block[]{SW3A});\n LD1A.setPreceding(new Block[]{SW2A});\n\n\n /* Station */\n STA1Z.setProceeding(new Block[]{SW4A});\n STA1Z.setPreceding(new Block[]{SW1A});\n\n\n /* Path B */\n //TODO path B items aren't in yet\n LD1B.setProceeding(new Block[]{SW3B});\n LD1B.setPreceding(new Block[]{SW2B});\n\n SW2B.setProceeding(new Block[]{LD1B});\n SW2B.setPreceding(new Block[]{SW1B});\n\n SW3B.setProceeding(new Block[]{SW4B});\n SW3B.setPreceding(new Block[]{LD1B});\n\n\n /* Maintenance Bay */\n //TODO maintenance bay items aren't in yet\n\n\n\n\n /* Set up array */\n blocksArray = new Block[] {}; //TODO fill\n }",
"public static void BlockRegister()\n\t{\n\t\tString[] umberstoneBlock = {\"umberstone\"};\n\t\tString[] umbercobbleBlock = {\"cobbleUmber\"};\n\t\tStoneRegister umberstone = getStoneRegister(ModBlocks.umberstone, ModBlocks.umberstone, \"umberstone\", umberstoneBlock, umbercobbleBlock, \"erebus\");\n\t\tumberstone.mossyCobble = false;\n\t\tumberstone.genReplaceable = false;\n\t\tumberstone.register();\n\t}",
"private void init() {\n\n\n\n }",
"protected void initModules()\n {\n\n }",
"public void init() {\r\n\r\n\t}",
"public void init() {\n\t\t\n\t}",
"public void init() {\n\n\t}",
"public void init() {\n\n\t}",
"public void init() {\n\n\t}",
"public static void init(){\n\n HELMET_COPPER = new ItemModArmor(COPPERARMOR, 1, EntityEquipmentSlot.HEAD, \"helmet_copper\");\n CHESTPLATE_COPPER = new ItemModArmor(COPPERARMOR, 1, EntityEquipmentSlot.CHEST, \"chestplate_copper\");\n LEGGINGS_COPPER = new ItemModArmor(COPPERARMOR, 2, EntityEquipmentSlot.LEGS, \"leggings_copper\");\n BOOTS_COPPER = new ItemModArmor(COPPERARMOR, 1, EntityEquipmentSlot.FEET, \"boots_copper\");\n\n }",
"@Override\n\tpublic void init() {\n\t\tworld = new World(gsm);\n\t\tworld.init();\n\t\t\n\t\tif(worldName == null){\n\t\t\tworldName = \"null\";\n\t\t\tmap_name = \"map\";\n\t\t} \n\t\tworld.generate(map_name);\n\t}",
"private void registerFleshBlock(){\n\t\tgetVariantBuilder(OrganicTechBlocks.FLESH_BLOCK.get()).forAllStates(state -> {\n\t\t\t//Generate the set of rotations for a flesh block w/o eyes\n\t\t\tConfiguredModel[] rotations = ConfiguredModel.allRotations(models().cubeAll(\"flesh_block\", modLoc(BLOCK_DIR + \"/flesh_block\")), false, 4);\n\t\t\t//then append the rotations for one eye\n\t\t\trotations = ArrayUtils.addAll(rotations, ConfiguredModel.allRotations(models().cubeAll(\"flesh_block_1eye\", modLoc(BLOCK_DIR + \"/flesh_block_1eye\")), false, 1));\n\t\t\t//then append the rotations for two eyes and return\n\t\t\treturn ArrayUtils.addAll(rotations, ConfiguredModel.allRotations(models().cubeAll(\"flesh_block_2eye\", modLoc(BLOCK_DIR + \"/flesh_block_2eye\")), false, 1));\n\t\t});\n\t}",
"public void addComponents()\r\n\t{\n\t\tSteveTechFarming.fruit = new BlockFruit(SteveTechFarming.config.getBlockID(1202, \"Fruit\", null)).setBlockName(\"WiduX-SteveTech-Farm-Fruit\");\r\n\t\tSteveTechFarming.crops = new BlockCrops(SteveTechFarming.config.getBlockID(1203, \"Crops\", null)).setBlockName(\"WiduX-SteveTech-Farm-Crops\");\r\n\t\t\r\n\t\tSteveTechFarming.seeds = new ItemSeeds(SteveTechFarming.config.getItemID(11000, \"Seeds\", null)).setItemName(\"WiduX-SteveTech-Farm-Seeds\");\r\n\t\tSteveTechFarming.harvestedItems = new ItemHarvest(SteveTechFarming.config.getItemID(11002, \"Harvest\", null)).setItemName(\"WiduX-SteveTech-Farm-Harvest\");\r\n\t\tSteveTechFarming.creativeTools = new ItemCreativeTools(SteveTechFarming.config.getItemID(11001, \"Creative Tools\", null)).setItemName(\"WiduX-SteveTech-Farm-CTools\");\r\n\t\tSteveTechFarming.foods = new Item[EnumFood.getNumberFoods()];\r\n\t\tint firstFoodItemID = SteveTechFarming.config.getItemID(11003, \"Foods Array\", \"This is the first item ID in the list of foods. Item IDs used will start here, and use the next \" + EnumFood.getNumberFoods() + \" IDs. Make sure they are all available.\");\r\n\t\tfor(int idOffset = 0; idOffset < SteveTechFarming.foods.length; idOffset++)\r\n\t\t{\r\n\t\t\tEnumFood food = EnumFood.getFood(idOffset);\r\n\t\t\tSteveTechFarming.foods[idOffset] = new ItemSTFood(firstFoodItemID + idOffset, food).setItemName(\"WiduX-SteveTech-Farm-Foods-Food\" + idOffset);\r\n\t\t}\r\n\t}",
"private void init() {\n }",
"private void init() {\n }",
"private void init() {\n }",
"private void init() {\n }",
"protected void initGSM() {\n gsm = new GameStateManager();}",
"@Override\n\tpublic void registerRecipes() {\n\n\t\tItemStack block, ingot;\n\n\t\tfor (MetalType metal : MetalType.VALUES) {\n\n\t\t\tblock = this.createItemStack(metal, 1);\n\t\t\tingot = BrItems.ingotMetals.createItemStack(metal, 1);\n\n\t\t\tGameRegistry.addShapelessRecipe(block, ingot, ingot, ingot, ingot, ingot, ingot, ingot, ingot, ingot);\n\t\t\tingot.stackSize = 9;\n\t\t\tGameRegistry.addShapelessRecipe(ingot, block);\n\t\t}\n\n\t\t// Ludicrite block. Because.\n\n\t\tfinal ItemStack ludicriteBlock = this.createItemStack(MetalType.Ludicrite, 1);\n\n\t\tGameRegistry.addRecipe(new ShapedOreRecipe(ludicriteBlock, \"BPB\", \"ENE\", \"BPB\",\n\t\t\t\t'N', Items.NETHER_STAR, 'P', Items.ENDER_PEARL, 'E', Blocks.EMERALD_BLOCK,\n\t\t\t\t'B', BigReactors.CONFIG.recipeBlutoniumIngotName));\n\n\t\tif (OreDictionaryHelper.doesOreNameExist(\"blockEnderium\")) {\n\n\t\t\t// Ok, how about some ludicrous shit here. Enderium and blaze rods. Have fun, bucko.\n\t\t\tGameRegistry.addRecipe(new ShapedOreRecipe(ludicriteBlock, \"BRB\", \"E E\", \"BRB\",\n\t\t\t\t\t'B', BigReactors.CONFIG.recipeBlutoniumIngotName, 'R', Items.BLAZE_ROD, 'E', \"blockEnderium\"));\n\t\t}\n\t}",
"public static void registerTags() {\n\n\t\tPonderRegistry.tags.forTag(PonderTag.KINETIC_RELAYS)\n\t\t\t.add(AllBlocks.SHAFT)\n\t\t\t.add(AllBlocks.COGWHEEL)\n\t\t\t.add(AllBlocks.LARGE_COGWHEEL)\n\t\t\t.add(AllItems.BELT_CONNECTOR)\n\t\t\t.add(AllBlocks.GEARBOX)\n\t\t\t.add(AllBlocks.CLUTCH)\n\t\t\t.add(AllBlocks.GEARSHIFT)\n\t\t\t.add(AllBlocks.ENCASED_CHAIN_DRIVE)\n\t\t\t.add(AllBlocks.ADJUSTABLE_CHAIN_GEARSHIFT)\n\t\t\t.add(AllBlocks.SEQUENCED_GEARSHIFT)\n\t\t\t.add(AllBlocks.ROTATION_SPEED_CONTROLLER);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.KINETIC_SOURCES)\n\t\t\t.add(AllBlocks.HAND_CRANK)\n\t\t\t.add(AllBlocks.COPPER_VALVE_HANDLE)\n\t\t\t.add(AllBlocks.WATER_WHEEL)\n\t\t\t.add(AllBlocks.ENCASED_FAN)\n\t\t\t.add(AllBlocks.WINDMILL_BEARING)\n\t\t\t.add(AllBlocks.FURNACE_ENGINE)\n\t\t\t.add(AllBlocks.FLYWHEEL)\n\t\t\t.add(AllBlocks.CREATIVE_MOTOR);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.KINETIC_APPLIANCES)\n\t\t\t.add(AllBlocks.MILLSTONE)\n\t\t\t.add(AllBlocks.TURNTABLE)\n\t\t\t.add(AllBlocks.ENCASED_FAN)\n\t\t\t.add(AllBlocks.CUCKOO_CLOCK)\n\t\t\t.add(AllBlocks.MECHANICAL_PRESS)\n\t\t\t.add(AllBlocks.MECHANICAL_MIXER)\n\t\t\t.add(AllBlocks.MECHANICAL_CRAFTER)\n\t\t\t.add(AllBlocks.MECHANICAL_DRILL)\n\t\t\t.add(AllBlocks.MECHANICAL_SAW)\n\t\t\t.add(AllBlocks.DEPLOYER)\n\t\t\t.add(AllBlocks.MECHANICAL_PUMP)\n\t\t\t.add(AllBlocks.MECHANICAL_ARM)\n\t\t\t.add(AllBlocks.MECHANICAL_PISTON)\n\t\t\t.add(AllBlocks.ROPE_PULLEY)\n\t\t\t.add(AllBlocks.MECHANICAL_BEARING)\n\t\t\t.add(AllBlocks.GANTRY_SHAFT)\n\t\t\t.add(AllBlocks.GANTRY_CARRIAGE)\n\t\t\t.add(AllBlocks.CLOCKWORK_BEARING)\n\t\t\t.add(AllBlocks.CRUSHING_WHEEL);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.FLUIDS)\n\t\t\t.add(AllBlocks.FLUID_PIPE)\n\t\t\t.add(AllBlocks.MECHANICAL_PUMP)\n\t\t\t.add(AllBlocks.FLUID_VALVE)\n\t\t\t.add(AllBlocks.SMART_FLUID_PIPE)\n\t\t\t.add(AllBlocks.HOSE_PULLEY)\n\t\t\t.add(AllBlocks.ITEM_DRAIN)\n\t\t\t.add(AllBlocks.SPOUT)\n\t\t\t.add(AllBlocks.PORTABLE_FLUID_INTERFACE)\n\t\t\t.add(AllBlocks.FLUID_TANK)\n\t\t\t.add(AllBlocks.CREATIVE_FLUID_TANK);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.ARM_TARGETS)\n\t\t\t.add(AllBlocks.MECHANICAL_ARM)\n\t\t\t.add(AllItems.BELT_CONNECTOR)\n\t\t\t.add(AllBlocks.CHUTE)\n\t\t\t.add(AllBlocks.DEPOT)\n\t\t\t.add(AllBlocks.WEIGHTED_EJECTOR)\n\t\t\t.add(AllBlocks.BASIN)\n\t\t\t.add(AllBlocks.ANDESITE_FUNNEL)\n\t\t\t.add(AllBlocks.BRASS_FUNNEL)\n\t\t\t.add(AllBlocks.MECHANICAL_CRAFTER)\n\t\t\t.add(AllBlocks.MILLSTONE)\n\t\t\t.add(AllBlocks.DEPLOYER)\n\t\t\t.add(AllBlocks.MECHANICAL_SAW)\n\t\t\t.add(AllBlocks.BLAZE_BURNER)\n\t\t\t.add(AllBlocks.CRUSHING_WHEEL)\n\t\t\t.add(Blocks.COMPOSTER)\n\t\t\t.add(Blocks.JUKEBOX);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.LOGISTICS)\n\t\t\t.add(AllItems.BELT_CONNECTOR)\n\t\t\t.add(AllItems.FILTER)\n\t\t\t.add(AllItems.ATTRIBUTE_FILTER)\n\t\t\t.add(AllBlocks.CHUTE)\n\t\t\t.add(AllBlocks.SMART_CHUTE)\n\t\t\t.add(AllBlocks.DEPOT)\n\t\t\t.add(AllBlocks.WEIGHTED_EJECTOR)\n\t\t\t.add(AllBlocks.MECHANICAL_ARM)\n\t\t\t.add(AllBlocks.ANDESITE_FUNNEL)\n\t\t\t.add(AllBlocks.BRASS_FUNNEL)\n\t\t\t.add(AllBlocks.ANDESITE_TUNNEL)\n\t\t\t.add(AllBlocks.BRASS_TUNNEL)\n\t\t\t.add(AllBlocks.CONTENT_OBSERVER)\n\t\t\t.add(AllBlocks.STOCKPILE_SWITCH)\n\t\t\t.add(AllBlocks.ADJUSTABLE_CRATE)\n\t\t\t.add(AllBlocks.CREATIVE_CRATE)\n\t\t\t.add(AllBlocks.PORTABLE_STORAGE_INTERFACE);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.DECORATION)\n\t\t\t.add(AllBlocks.NIXIE_TUBE)\n\t\t\t.add(AllBlocks.CUCKOO_CLOCK)\n\t\t\t.add(AllBlocks.WOODEN_BRACKET)\n\t\t\t.add(AllBlocks.METAL_BRACKET)\n\t\t\t.add(AllBlocks.ANDESITE_CASING)\n\t\t\t.add(AllBlocks.BRASS_CASING)\n\t\t\t.add(AllBlocks.COPPER_CASING);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.CREATIVE)\n\t\t\t.add(AllBlocks.CREATIVE_CRATE)\n\t\t\t.add(AllBlocks.CREATIVE_FLUID_TANK)\n\t\t\t.add(AllBlocks.CREATIVE_MOTOR);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.SAILS)\n\t\t\t.add(AllBlocks.SAIL)\n\t\t\t.add(AllBlocks.SAIL_FRAME)\n\t\t\t.add(Blocks.WHITE_WOOL);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.REDSTONE)\n\t\t\t.add(AllBlocks.NIXIE_TUBE)\n\t\t\t.add(AllBlocks.REDSTONE_CONTACT)\n\t\t\t.add(AllBlocks.ANALOG_LEVER)\n\t\t\t.add(AllBlocks.REDSTONE_LINK)\n\t\t\t.add(AllBlocks.ADJUSTABLE_REPEATER)\n\t\t\t.add(AllBlocks.PULSE_REPEATER)\n\t\t\t.add(AllBlocks.ADJUSTABLE_PULSE_REPEATER)\n\t\t\t.add(AllBlocks.POWERED_LATCH)\n\t\t\t.add(AllBlocks.POWERED_TOGGLE_LATCH);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.MOVEMENT_ANCHOR)\n\t\t\t.add(AllBlocks.MECHANICAL_PISTON)\n\t\t\t.add(AllBlocks.WINDMILL_BEARING)\n\t\t\t.add(AllBlocks.MECHANICAL_BEARING)\n\t\t\t.add(AllBlocks.CLOCKWORK_BEARING)\n\t\t\t.add(AllBlocks.ROPE_PULLEY)\n\t\t\t.add(AllBlocks.GANTRY_CARRIAGE)\n\t\t\t.add(AllBlocks.CART_ASSEMBLER);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.CONTRAPTION_ASSEMBLY)\n\t\t\t.add(AllBlocks.LINEAR_CHASSIS)\n\t\t\t.add(AllBlocks.SECONDARY_LINEAR_CHASSIS)\n\t\t\t.add(AllBlocks.RADIAL_CHASSIS)\n\t\t\t.add(AllItems.SUPER_GLUE)\n\t\t\t.add(AllBlocks.STICKER)\n\t\t\t.add(Blocks.SLIME_BLOCK)\n\t\t\t.add(Blocks.HONEY_BLOCK);\n\n\t\tPonderRegistry.tags.forTag(PonderTag.CONTRAPTION_ACTOR)\n\t\t\t.add(AllBlocks.MECHANICAL_HARVESTER)\n\t\t\t.add(AllBlocks.MECHANICAL_PLOUGH)\n\t\t\t.add(AllBlocks.MECHANICAL_DRILL)\n\t\t\t.add(AllBlocks.MECHANICAL_SAW)\n\t\t\t.add(AllBlocks.DEPLOYER)\n\t\t\t.add(AllBlocks.PORTABLE_STORAGE_INTERFACE)\n\t\t\t.add(AllBlocks.PORTABLE_FLUID_INTERFACE)\n\t\t\t.add(AllBlocks.MECHANICAL_BEARING)\n\t\t\t.add(AllBlocks.ANDESITE_FUNNEL)\n\t\t\t.add(AllBlocks.BRASS_FUNNEL)\n\t\t\t.add(AllBlocks.SEATS[0])\n\t\t\t.add(AllBlocks.REDSTONE_CONTACT)\n\t\t\t.add(Blocks.BELL)\n\t\t\t.add(Blocks.DISPENSER)\n\t\t\t.add(Blocks.DROPPER);\n\n\t}",
"protected abstract void initializeBartender();",
"@Override\n public void init() {\n robot = new MecanumBotHardware(true,true,true,true);\n robot.init(hardwareMap);\n int deg180=845;\n // Create the state machine and configure states.\n smDrive = new StateMachine(this, 16);\n smDrive.addStartState(new WaitState(\"wait\",0.1,\"MainDriveTeleop\"));\n smDrive.addState(new GigabyteTeleopDriveState(\"MainDriveTeleop\", robot));\n smDrive.addState(new SpinPose(\"90DegSpin\",(int)(deg180*0.5),robot,0.1f));\n smDrive.addState(new SpinPose(\"180DegSpin\",deg180,robot,0.1f));\n smDrive.addState(new SpinPose(\"270DegSpin\",(int)(deg180*1.5),robot,0.1f));\n\n smArm = new StateMachine(this, 16);\n smArm.addStartState(new WaitState(\"wait\",0.1,\"MainArmTeleop\"));\n smArm.addState(new GigabyteTeleopArmState(\"MainArmTeleop\", robot));\n smArm.addState(new ShoulderPose(\"Pose1\", robot,0, \"MainArmTeleop\"));//0.12\n smArm.addState(new ShoulderPose(\"Pose2\", robot,1079, \"MainArmTeleop\"));//0.05\n smArm.addState(new ShoulderPose(\"Pose3\", robot,2602, \"MainArmTeleop\"));//-0.17\n smArm.addState(new ShoulderPose(\"Pose4\", robot,3698, \"MainArmTeleop\" ));//-0.35\n // Init the state machine\n smDrive.init();\n smArm.init();\n }",
"private void init() {\n }",
"public static void initialize() {\r\n\t\tgraph = null;\r\n\t\tmseeObjectNames = new HashMap<String, String>();\r\n\t\tmseeEventTypes = new HashMap<String, String>();\r\n\t\tmodifiedIdentifiers = new HashMap<String, String>();\r\n\t}",
"public void init() {\n\t}",
"public void init() {\n\t}",
"public void init() {\n\t}",
"private void init() {\n System.out.println(\"Binding to RMIRegistry...\");\n String theName = getConfigManager().getString(\"REMOTE_NAME\");\n if (null != theName) {\n bind(theName, this);\n } else {\n LoggingServices.getCurrent().logMsg(getClass().getName(), \"init()\"\n , \"Could not find name to bind to in registry.\"\n , \"Make sure loyalty.cfg contains a RMIREGISTRY entry.\", LoggingServices.MAJOR);\n }\n }",
"public void init() {\n\t\tfor(int i = 0; i < roamingAliens; ++i) {\n\t\t\tAlien alien = new Alien(ColorUtil.MAGENTA, screenHeight, screenWidth, speed, speedMulti);\n\t\t\tgameObject.add((GameObject) alien); \n\t\t}\n\t\tfor(int i = 0; i < roamingAstronauts; ++i) {\n\t\t\tAstronaut astronaut = new Astronaut(ColorUtil.GREEN, screenHeight, screenWidth, speed, speedMulti);\n\t\t\tgameObject.add((GameObject) astronaut);\n\t\t}\n\t\tgameObject.add((Spaceship.getSpaceship()));\n\t\tthis.setChanged();\n\t\tthis.notifyObservers();\n\t\tthis.clearChanged();\n\t}",
"public void GameInit() {\n ufot = new ArrayList();\n kuti = new Kuti();\n pelaaja = new Pelaaja();\n ufokuti = new UfoKuti();\n ufokuti.setVisible(false);\n kuti.setVisible(false);\n grafiikka = new Grafiikka(this);\n grafiikka.asetaKuvaRajahdykselle();\n grafiikka.asetaKuvaPelaajalle(grafiikka.pelaajaIcon(pelaaja), pelaaja);\n asetaUfotRiveihin();\n ufokutiInit();\n }",
"@Mod.EventHandler\n public void preinit(FMLInitializationEvent event)\n {\n \tCOBIDs.ids();\n \t//Solid\n \tCSBIDs.ids();\n //Items\n \t//Gems\n \tGIDs.ids();\n //Copper\n \t//Ar\n \t//Ores\n \tCOIDs.ids();\n //Tools\n \t//Hoes\n \tCHIDs.ids();\n \t//Swords\n \tCSWIDs.ids();\n \t//SwordsSlot1\n \tCSWS1IDs.ids();\n \t//Pickaxes\n \tCPIDs.ids();\n \t//PikaxesSlot1\n \tCPS1IDs.ids();\n \t//Axes\n \tCAIDs.ids();\n\t\t//Shovel\n \tCSIDs.ids();\n \t\n //Reg\n //Blocks\n \t//Copper\n \tCOBReg.reg();\n \tCSBReg.reg();\n //Items\n \t//Gems\n \tGReg.reg();\n //Copper\n \t//Ore\n \tCOReg.reg();\n //Tools\n \t//Hoes\n \tCHReg.reg();\n \t//Swords\n \tCSWReg.reg();\n \t//SwordsSlot1\n \tCSWS1Reg.reg();\n \t//Pickaxes\n \tCPReg.reg();\n \t//PckaxesSlot1\n \tCPS1Reg.reg();\n \t//Axes\n \tCAReg.reg();\n \t//Shovel\n \tCSReg.reg();\n \t//Renders\n \tproxy.init();\n }",
"public void init() {\n\t\n\t}",
"public static void registerMachineRecipes()\n {\n ThermalExpansionHelper.addTransposerFill(10000, new ItemStack(BlockFrame.instance, 1, 0), new ItemStack(BlockFrame.instance, 1, BlockFrame.REDSTONE_INTERFACE), new FluidStack(FluidRegistry.getFluidID(\"redstone\"), 200), false);\n ThermalExpansionHelper.addTransposerFill(10000, new ItemStack(ItemBlankUpgrade.instance, 1, 0), new ItemStack(ItemUpgrade.instance, 1, 0), new FluidStack(FluidRegistry.getFluidID(\"redstone\"), 200), false);\n\n ThermalExpansionHelper.addTransposerFill(15000, new ItemStack(BlockFrame.instance, 1, 0), new ItemStack(BlockFrame.instance, 1, BlockFrame.NETWORK_INTERFACE), new FluidStack(FluidRegistry.getFluidID(\"ender\"), 125), false);\n ThermalExpansionHelper.addTransposerFill(15000, new ItemStack(ItemBlankUpgrade.instance, 1, 1), new ItemStack(ItemUpgrade.instance, 1, 1), new FluidStack(FluidRegistry.getFluidID(\"ender\"), 125), false);\n\n ThermalExpansionHelper.addTransposerFill(25000, new ItemStack(BlockStabilizerEmpty.instance, 1, 0), new ItemStack(BlockStabilizer.instance, 1, 0), new FluidStack(FluidRegistry.getFluidID(\"ender\"), 150), false);\n }",
"private void initSpriteProviders(final String name) {\n for (final SpriteProvider sp : spriteProviders) {\n sp.init(name);\n }\n }",
"public static void init(){\n for(EOres ore: EOres.values()){\n new TileOre(ore).register();\n }\n \n for(EOres ore : EOres.values()){\n addDependencyForOre(ore.name());\n }\n }",
"private void instantiate(){\n inputAddressList = new LinkedList<Address>();\n inputGroupList = new LinkedList<Group>();\n root = new Group(\"root\", 0);\n }",
"public void init() {\n\r\n\t}",
"public void init() {\n\r\n\t}",
"public void init() {\n\t\t}",
"private void init() {\n UNIGRAM = new HashMap<>();\n }",
"public static void loadBlockTextures() {\n\t\tspriteTopOn = ModLoader.addOverride(\"/terrain.png\",\n\t\t\t\t\"/WirelessSprites/topOn.png\");\n\t\tspriteTopOff = ModLoader.addOverride(\"/terrain.png\",\n\t\t\t\t\"/WirelessSprites/topOff.png\");\n\t\tspriteROn = ModLoader.addOverride(\"/terrain.png\",\n\t\t\t\t\"/WirelessSprites/rxOn.png\");\n\t\tspriteROff = ModLoader.addOverride(\"/terrain.png\",\n\t\t\t\t\"/WirelessSprites/rxOff.png\");\n\t\tspriteTOn = ModLoader.addOverride(\"/terrain.png\",\n\t\t\t\t\"/WirelessSprites/txOn.png\");\n\t\tspriteTOff = ModLoader.addOverride(\"/terrain.png\",\n\t\t\t\t\"/WirelessSprites/txOff.png\");\n\t}",
"public abstract void initialize(GameContainer gc);",
"@SuppressWarnings(\"static-access\")\n\tprivate void init() {\n\t\tdisplay= new Display(title,width,height);\n\t\tdisplay.getFrame().addMouseListener(mouseManager);\n\t\tdisplay.getFrame().addMouseMotionListener(mouseManager);\n\t\tdisplay.getCanvas().addMouseListener(mouseManager);\n\t\tdisplay.getCanvas().addMouseMotionListener(mouseManager);\n\n\t\t\n\t\t//~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~Declarare imagini~~~~~~~~~~~~~~~~~~~~~~~~~~~~\n Assets.init();\n \n\t\tgameState= new GameState(this);\n\t\tgameStateAI= new GameStateAI(this);\n\t\tmenuState = new MenuState(this);\n\t\tsettingsState= new SettingsState(this);\n\t\tState.setState(menuState);\t\n\t\t\n\t\n\t}",
"private void init(){\n \tdimension.set(0.5f, 0.5f);\n \tsetAnimation(Assets.instance.goldCoin.animGoldCoin);\n \tstateTime = MathUtils.random(0.0f,1.0f);\n \t\n \t//regGoldCoin = Assets.instance.goldCoin.goldCoin;\n \t // Set bounding box for collision detection\n \tbounds.set(0,0,dimension.x, dimension.y);\n \tcollected = false;\n }",
"@Override\n\tpublic void init() {\n\t\tfor(EnumStoneType type: EnumStoneType.values()) {\n\t\t\taddChiselVariation(\"stonebrick\", blockStone, type.getMetadata());\n\t\t}\n\n\t\t//Add chisel variations for Endstone Blocks\n\t\tfor(EnumEndStoneType type: EnumEndStoneType.values()) {\n\t\t\taddChiselVariation(\"endstone\", blockEndstone, type.getMetadata());\n\t\t}\n\n\t\tfor(EnumEndStoneSlabType type: EnumEndStoneSlabType.values()) {\n\t\t\taddChiselVariation(\"endstoneslab\", slabEndstone, type.getMetadata());\n\t\t}\n\n\t\t//Add chisel variations for Limestone Blocks\n\t\tfor(EnumLimestoneType type: EnumLimestoneType.values()) {\n\t\t\taddChiselVariation(\"limestone\", blockLimestone, type.getMetadata());\n\t\t}\n\n\t\tfor(EnumLimestoneSlabType type: EnumLimestoneSlabType.values()) {\n\t\t\taddChiselVariation(\"limestoneslab\", slabLimestone, type.getMetadata());\n\t\t}\n\n\t\t//Add chisel variations for Cobblestone Blocks\n\t\tfor(EnumCobblestoneType type: EnumCobblestoneType.values()) {\n\t\t\taddChiselVariation(\"cobblestone\", blockCobblestone, type.getMetadata());\n\t\t}\n\n\t\taddChiselVariation(\"cobblestoneslab\", Blocks.STONE_SLAB, 3);\n\t\tfor(EnumCobblestoneSlabType type: EnumCobblestoneSlabType.values()) {\n\t\t\taddChiselVariation(\"cobblestoneslab\", slabCobblestone, type.getMetadata());\n\t\t}\n\n\t\tfor(EnumMarbleSlabType type: EnumMarbleSlabType.values()) {\n\t\t\taddChiselVariation(\"marbleslab\", slabMarble, type.getMetadata());\n\t\t}\n\n\t\taddChiselVariation(\"stonebrickstairs\", Blocks.STONE_BRICK_STAIRS, 0);\n\t\tstairsStone.forEach(s -> addChiselVariation(\"stonebrickstairs\", s, 0));\n\n\t\tstairsEndstone.forEach(s -> addChiselVariation(\"endstonestairs\", s, 0));\n\n\t\tstairsLimestone.forEach(s -> addChiselVariation(\"limestonestairs\", s, 0));\n\n\t\taddChiselVariation(\"cobblestonestairs\", Blocks.STONE_STAIRS, 0);\n\t\tstairsCobblestone.forEach(s -> addChiselVariation(\"cobblestonestairs\", s, 0));\n\t\n\t\tstairsMarble.forEach(s -> addChiselVariation(\"marblestairs\", s, 0));\n\t\t\n\t}",
"private static void initConfig() {\n /*\n * Human IO\n */\n {\n /*\n * Constants\n */\n {\n /*\n * Joysticks\n */\n {\n addToConstants(\"joysticks.left\", 0);\n addToConstants(\"joysticks.right\", 1);\n addToConstants(\"joysticks.operator\", 2);\n }\n\n /*\n * Buttons and axis\n */\n {\n }\n }\n }\n\n /*\n * RobotIO\n */\n {\n /*\n * Constants\n */\n {\n /*\n * Kicker\n */\n addToConstantsA(\"kicker.encoder.distPerPulse\", 360.0 / 1024.0);\n }\n }\n\n /*\n * Chassis\n */\n {\n /*\n * Constants\n */\n {\n }\n\n /*\n * Variables\n */\n {\n }\n }\n\n /*\n * Kicker\n */\n {\n /*\n * Constants\n */\n {\n addToConstants(\"kicker.kick.normal\", 1.75);\n addToConstants(\"kicker.kick.timeout\", 0.75);\n\n addToConstants(\"kicker.shaken.voltage\", -0.3316);\n addToConstants(\"kicker.shaken.tolerance\", 3.0);\n\n addToConstants(\"kicker.zero.voltage\", 0.8);\n addToConstants(\"kicker.zero.duration\", 0.75);\n }\n\n /*\n * Variables\n */\n {\n }\n }\n\n /*\n * Gripper\n */\n {\n /*\n * Constants\n */\n {\n addToConstants(\"gripper.collection.voltage\", 0.82);\n addToConstants(\"gripper.ejection.voltage\", -0.45);\n }\n }\n }",
"public void initComponents() {\n\t\t\n\t\tDocumentBuilder builder;\n\t\tDocumentBuilderFactory factory =DocumentBuilderFactory.newInstance();\n\t\tElement root;\n\t\tNodeList modules;\n\t\tint indexNodes;\n\t\t\n\t\ttry {\n\t\t\t\tbuilder = factory.newDocumentBuilder();\n\t\t\t\tDocument document =builder.parse(\n\t\t\t\tClassLoader.getSystemResourceAsStream(m_fileModuleNameStructure));\n\t\t\t\t\n\t\t\t\t\n\t\t\t\troot = document.getDocumentElement();\n\t\t\t\tmodules = root.getElementsByTagName(\"module\");\n\t\t\t\t\n\t\t\t\tfor(indexNodes = 0; indexNodes < modules.getLength(); indexNodes++)\n\t\t\t\t\tparseDataOneModule(modules.item(indexNodes));\n\t\t\t\t\n\t\t\t\t\n\t\t} \n\t\tcatch (ParserConfigurationException e) \n\t\t{\n\t\t\t\t\n\t\t\t\te.printStackTrace();\n\t\t} catch (SAXException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (IOException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t\t\n\t}",
"public void init() { \r\n\t\t// TODO Auto-generated method\r\n\t }",
"public static void init() {\n\t\t\n\t}",
"private void init() {\n\n\t\tinitializeLists();\n\t\tcreateTiles();\n\t\tcreateTileViews();\n\t\tshuffleTiles();\n\n\t}",
"private void startComponents(){\n\n if(isAllowed(sentinel)){\n SentinelComponent sentinelComponent = new SentinelComponent(getInstance());\n sentinelComponent.getCanonicalName();\n }\n\n if(isAllowed(\"fileserver\")){\n FileServer fileServer = new FileServer(getInstance());\n fileServer.getCanonicalName();\n }\n\n if(isAllowed(\"manager\")){\n ManagerComponent Manager = new ManagerComponent(getInstance());\n Manager.getCanonicalName();\n }\n\n// if(isAllowed(\"sdk\")){\n// SDK sdk = new SDK(getInstance());\n// sdk.getCanonicalName();\n// }\n\n if(isAllowed(\"centrum\")){\n CentrumComponent centrum1 = new CentrumComponent(getInstance(), null);\n centrum1.getCanonicalName();\n }\n\n }",
"private void _init() {\n }",
"public void init() {}",
"public void init() {}",
"private void initializeNodes() {\n for (NasmInst inst : nasm.listeInst) {\n Node newNode = graph.newNode();\n inst2Node.put(inst, newNode);\n node2Inst.put(newNode, inst);\n if (inst.label != null) {\n NasmLabel label = (NasmLabel) inst.label;\n label2Inst.put(label.toString(), inst);\n }\n }\n }",
"private void initialize() {\n\t\t\n\t}",
"public void init() {\n \n }",
"public void init() {\n }",
"public void init() {\n }",
"public void init() {\n }",
"public void init() {\n }",
"public void init(){\r\n\t\tbuild(0);\r\n\t\taddFestiveCity(1);\r\n\t}",
"public void init()\n {\n }",
"public static void register(GenericBlock block)\n\t{\n\t\tBLOCKS.add(block);\n\t}",
"public void init(){\r\n\t\t\r\n\t}",
"protected void _init(){}",
"protected void setup() {\n\t\tgetContentManager().registerOntology(JADEManagementOntology.getInstance());\r\n getContentManager().registerLanguage(new SLCodec(), FIPANames.ContentLanguage.FIPA_SL0);\r\n\t\tSystem.out.println(\"Agent FixCop cree : \"+getLocalName());\r\n\t\tObject[] args = getArguments();\r\n\t\tList<String> itinerary = (List<String>) args[0];\r\n\t\tint period = (int) args[1];\r\n\t\t\r\n\t\t\r\n\t// POLICIER STATIONNAIRE DO THE CYCLIC BEHAVIOUR TO SCAN THE ROOT , IF THE INTRUDER IS IN ROOT, POLICIER STATIO KILLS HIM.\r\n addBehaviour(new StationScanRootBehaviour(this));\r\n\r\n\t// RESPAWN ANOTHER POLICIER MOBILE AFTER EACH POLICIER MOBILE's LIFETIME DURATION ELAPSES.\r\n addBehaviour(new RespawnCopBehaviour(this, period, itinerary));\r\n\r\n\t}"
]
| [
"0.7293143",
"0.7265467",
"0.6954017",
"0.6718041",
"0.6699126",
"0.6628596",
"0.6609233",
"0.6575248",
"0.6458508",
"0.64330494",
"0.63834476",
"0.63531584",
"0.62794083",
"0.6217623",
"0.620836",
"0.61399645",
"0.61237264",
"0.6090731",
"0.6050633",
"0.60113764",
"0.59859365",
"0.5981356",
"0.5978355",
"0.5969447",
"0.59692156",
"0.59576714",
"0.5933564",
"0.59303564",
"0.59284997",
"0.5892018",
"0.5890271",
"0.5882999",
"0.5854294",
"0.5847508",
"0.582083",
"0.58165234",
"0.578877",
"0.57701594",
"0.57630426",
"0.57618934",
"0.57618934",
"0.57618934",
"0.57552004",
"0.57541513",
"0.57445407",
"0.5735522",
"0.57350993",
"0.57350993",
"0.57350993",
"0.57350993",
"0.57265186",
"0.5722343",
"0.57189286",
"0.56949604",
"0.5694343",
"0.569243",
"0.5688595",
"0.5680826",
"0.5680826",
"0.5680826",
"0.56747824",
"0.56700975",
"0.56611335",
"0.56584924",
"0.5650096",
"0.56407017",
"0.5633395",
"0.5633333",
"0.56318647",
"0.5605194",
"0.5605194",
"0.56047875",
"0.5601675",
"0.55986166",
"0.5582325",
"0.5570519",
"0.55699337",
"0.5569923",
"0.55695885",
"0.55671155",
"0.5562632",
"0.5556193",
"0.555579",
"0.5546196",
"0.554467",
"0.55335623",
"0.55335623",
"0.553337",
"0.5532206",
"0.5531002",
"0.5529199",
"0.5529199",
"0.5529199",
"0.5529199",
"0.55286545",
"0.5527721",
"0.5523715",
"0.5519932",
"0.5518518",
"0.5518311"
]
| 0.73843074 | 0 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.COIN_TYPE_ID | public String getCoinTypeId() {
return coinTypeId;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public int getSqlType() { return _type; }",
"public int getIdType() {\r\n return idType;\r\n }",
"public Integer getIdType() {\n return idType;\n }",
"public BigDecimal getTypeId() {\n return typeId;\n }",
"public TransactionType findTxnTypeById(int parseLong);",
"public Long getTypeid() {\n return typeid;\n }",
"ResultColumn getTypeIdColumn(TableReference tableReference);",
"public long getType() {\r\n return type;\r\n }",
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"public String getId_type() {\n return id_type;\n }",
"public Integer getTypeCode() {\n return typeCode;\n }",
"public String getIdType() {\n return idType;\n }",
"public BikeType getType(int typeId){\n try(Connection con = DatabaseConnector.getConnection();\n PreparedStatement ps = con.prepareStatement(TYPE_BY_ID + typeId);\n ResultSet rs = ps.executeQuery()){\n \n if(rs.next()){\n BikeType type = new BikeType(rs.getString(cTypeName),rs.getDouble(cRentalPrice));\n type.setTypeId(rs.getInt(cTypeId));\n return type;\n }\n\n }catch(Exception e){\n System.out.println(\"Exception: \" + e);\n }\n return null;\n }",
"public Long getTypeId() {\r\n\t\treturn typeId;\r\n\t}",
"public int getMinecartType() {\n return type;\n }",
"public Integer getTypeId() {\n return typeId;\n }",
"public int getJDBCTypeId() {\r\n return typeId.getJDBCTypeId();\r\n }",
"public int getType() throws SQLException\n {\n return m_rs.getType();\n }",
"public Class<Long> getIdType() {\n return Long.class;\n }",
"int getTypeIdValue();",
"public String getTypeCode() {\n return typeCode;\n }",
"public String getTypeCode() {\n return typeCode;\n }",
"public String getTypeCode() {\n return typeCode;\n }",
"public String getTypeCode() {\n return typeCode;\n }",
"public String getTypeId() {\r\n return typeId;\r\n }",
"public int getJdbcType();",
"public int getData_type_id() {\n return data_type_id;\n }",
"String getOrderTypeId();",
"@Override\n\tpublic long getTypePK() {\n\t\treturn _dlSyncEvent.getTypePK();\n\t}",
"public Integer getEntityTypeId() {\n // get entity type code\n String code = getEntityTypeCode();\n // check cache, (may contain null)\n if (entityTypeIdCache.containsKey(code)) {\n return entityTypeIdCache.get(code);\n }\n // query, cache, and return metadata driven ids\n EntityType entityType = getMetadata().getEntityTypeByName(code);\n Integer id = ((entityType != null) ? entityType.getEntityTypeId() : null);\n entityTypeIdCache.put(code, id);\n return id;\n }",
"SellType selectByPrimaryKey(Integer sell_type_id);",
"public void setCoinTypeId(String coinTypeId) {\n this.coinTypeId = coinTypeId;\n }",
"public Integer getType() {\r\n\t\treturn type;\r\n\t}",
"public long getOutfitTypeId() {\t\t\n\t\tAttribute attributeValue = null;\n\t\tLong atttributeId = null;\n\t\tList list = getHibernateTemplate().find(\"FROM Attribute WHERE name =\\'OUTFIT_Type\\'\");\n\t\tIterator itr = list.iterator();\n\t\tif (itr.hasNext()) {\n\t\t\tattributeValue = (Attribute) itr.next();\n\t\t\tatttributeId = (attributeValue != null ? attributeValue.getAttributeId() : null);\n\t\t}\n\t\treturn (atttributeId != null ? atttributeId.longValue() : null);\n\t}",
"@Override\n\tpublic BigInteger selectUserIdByAccount(String account,Long type) {\n\t\t\n\t\tLoginNo loginNo = accountManageDao.selectLoginNoDetail(account, type);\n\t\tBigInteger res = loginNo==null?null:loginNo.gettUserFId();\n\t\treturn res;\n\t}",
"public Integer getType() {\n\t\treturn type;\n\t}",
"public int getJDBCTypeId()\n {\n return JDBCTypeId;\n }",
"public Integer getType() {\n return type;\n }",
"public Integer getType() {\n return type;\n }",
"public Integer getType() {\n return type;\n }",
"public Integer getType() {\n return type;\n }",
"public Integer getType() {\n return type;\n }",
"public Integer getType() {\n return type;\n }",
"public Integer getType() {\n return type;\n }",
"public Integer getType() {\n return type;\n }",
"@Override\n public String getJavaByJdbcType(DbAttribute attribute, int type) {\n String jdbcType = TypesMapping.getSqlNameByType(type);\n DbType dbType;\n if (attribute != null) {\n dbType = new DbType(\n jdbcType,\n attribute.getMaxLength(),\n attribute.getAttributePrecision(),\n attribute.getScale(),\n attribute.isMandatory());\n } else {\n dbType = new DbType(jdbcType);\n }\n\n String typeName = getJavaByJdbcType(dbType);\n\n if (usePrimitives != null && usePrimitives) {\n String primitive = classToPrimitive.get(typeName);\n if (primitive != null) {\n return primitive;\n }\n }\n\n return typeName;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public int getType(){\n return type;\n }",
"public int getType()\r\n {\r\n return type;\r\n }",
"public int getType() {\n return _type;\n }",
"public int getType() {\n return _type;\n }",
"public int getTypeId() {\n return typeId_;\n }",
"com.cantor.drop.aggregator.model.CFTrade.SecurityIdType getSecIdType();",
"public int getType(){\n\t\treturn type;\n\t}",
"public int getType(){\n\t\treturn this.type;\n\t}",
"public int getType(){\n\t\treturn this.type;\n\t}",
"public TypeId getTypeId() {\r\n return typeId;\r\n }",
"public int getType() {\r\n return type;\r\n }",
"public int getType() {\r\n return type;\r\n }",
"public int getType() {\r\n return type;\r\n }",
"public int getType(){\r\n\t\treturn type;\r\n\t}",
"public java.lang.Long getTradeType () {\r\n\t\treturn tradeType;\r\n\t}",
"public int getType()\r\n\t{\r\n\t\treturn type;\r\n\t}",
"@Override\n public String convertToDatabaseColumn(TransactionType transactionType) {\n if (transactionType == null) return null;\n\n return transactionType.getTransactionType();\n }",
"@ApiModelProperty(required = true, value = \"The type of the PayID\")\n @NotNull\n\n\n public TypeEnum getType() {\n return type;\n }",
"public int getType()\n {\n return type;\n }",
"public int getType()\n {\n return type;\n }",
"public int getType() {\n return this.type;\n }",
"public int getType() {\n return type;\n }",
"public int getType() {\n return type;\n }",
"public int getTypeValue() {\n return type_;\n }",
"public int getType() {\n return type;\n }",
"public int getType() {\n return type;\n }",
"public int getType() {\n return type;\n }",
"public int getType() {\n return type;\n }",
"public Integer getTypeCode() {\n return (Integer) getAttributeInternal(TYPECODE);\n }",
"public int getType() {\r\n\t\treturn type;\r\n\t}",
"@java.lang.Override\n public int getTypeValue() {\n return type_;\n }",
"@java.lang.Override\n public int getTypeValue() {\n return type_;\n }",
"public String getSqlType() {\n\t\treturn this.sqlType;\n\t}",
"public int getType() {\n\t\treturn type;\n\t}",
"public int getType() {\n\t\treturn type;\n\t}",
"public int getType() {\n\t\treturn type;\n\t}",
"public int getType() {\n\t\treturn type;\n\t}",
"public int getType() {\n\t\treturn type;\n\t}",
"public int getType() {\n\t\treturn type;\n\t}",
"public int getTypeValue() {\n return type_;\n }",
"public int getTypeValue() {\n return type_;\n }",
"public int getTypeValue() {\n return type_;\n }",
"public int getTypeValue() {\n return type_;\n }"
]
| [
"0.5974829",
"0.5936235",
"0.5902617",
"0.58978444",
"0.58934903",
"0.5875374",
"0.58400005",
"0.58116096",
"0.5789331",
"0.5760741",
"0.57382274",
"0.57052106",
"0.56930184",
"0.56787986",
"0.5641551",
"0.5639575",
"0.5627759",
"0.560951",
"0.5603192",
"0.56026685",
"0.55628234",
"0.55628234",
"0.55628234",
"0.55628234",
"0.5494837",
"0.5465375",
"0.54602855",
"0.5457039",
"0.5453852",
"0.54441994",
"0.5436081",
"0.54309344",
"0.54225683",
"0.54217166",
"0.54211473",
"0.5410898",
"0.541018",
"0.5408447",
"0.5408447",
"0.5408447",
"0.5408447",
"0.5408447",
"0.5408447",
"0.5408447",
"0.5408447",
"0.54060644",
"0.5391334",
"0.5391334",
"0.5391334",
"0.5391334",
"0.5391334",
"0.5391334",
"0.5391334",
"0.5391334",
"0.5391334",
"0.5391334",
"0.5391334",
"0.5376837",
"0.5374468",
"0.5364283",
"0.5364283",
"0.53548425",
"0.53453857",
"0.5335486",
"0.53337085",
"0.53337085",
"0.53328556",
"0.5332219",
"0.5332219",
"0.5332219",
"0.5330822",
"0.5325327",
"0.5318598",
"0.5314973",
"0.5314337",
"0.5311247",
"0.5311247",
"0.5304196",
"0.5303046",
"0.53027856",
"0.53011227",
"0.5296361",
"0.5296361",
"0.5296361",
"0.5296361",
"0.52947557",
"0.52908033",
"0.528822",
"0.528822",
"0.5287828",
"0.52857554",
"0.52857554",
"0.52857554",
"0.52857554",
"0.52857554",
"0.52857554",
"0.5285608",
"0.5285608",
"0.5285608",
"0.5285608"
]
| 0.6266818 | 0 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.COIN_TYPE_ID | public void setCoinTypeId(String coinTypeId) {
this.coinTypeId = coinTypeId;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setIdType(int idType) {\r\n this.idType = idType;\r\n }",
"public void setType(long type) {\r\n this.type = type;\r\n }",
"public void setIdType(Integer idType) {\n this.idType = idType;\n }",
"public void setTypeid(Long typeid) {\n this.typeid = typeid;\n }",
"private void setTypeId(int value) {\n \n typeId_ = value;\n }",
"public void setType(int type) throws DBException {\n _type = type;\n }",
"public void setType(int type) throws DBException {\n _type = type;\n }",
"@Override\n\tpublic void setTypePK(long typePK) {\n\t\t_dlSyncEvent.setTypePK(typePK);\n\t}",
"public void setMinecartType(final int type) {\n this.type = type;\n }",
"public void setTypeId(Long typeId) {\r\n\t\tthis.typeId = typeId;\r\n\t}",
"public String getCoinTypeId() {\n return coinTypeId;\n }",
"public void xsetType(org.apache.xmlbeans.XmlInt type)\n {\n synchronized (monitor())\n {\n check_orphaned();\n org.apache.xmlbeans.XmlInt target = null;\n target = (org.apache.xmlbeans.XmlInt)get_store().find_attribute_user(TYPE$2);\n if (target == null)\n {\n target = (org.apache.xmlbeans.XmlInt)get_store().add_attribute_user(TYPE$2);\n }\n target.set(type);\n }\n }",
"public void setTypeId(BigDecimal typeId) {\n this.typeId = typeId;\n }",
"public void setType(int pType) {\n mType = pType;\n }",
"public void setType(int type)\n {\n synchronized (monitor())\n {\n check_orphaned();\n org.apache.xmlbeans.SimpleValue target = null;\n target = (org.apache.xmlbeans.SimpleValue)get_store().find_attribute_user(TYPE$2);\n if (target == null)\n {\n target = (org.apache.xmlbeans.SimpleValue)get_store().add_attribute_user(TYPE$2);\n }\n target.setIntValue(type);\n }\n }",
"public void setTypeCode(Integer typeCode) {\n this.typeCode = typeCode;\n }",
"public void setId_type(String id_type) {\n this.id_type = id_type;\n }",
"public void setIdType(String idType) {\n this.idType = idType == null ? null : idType.trim();\n }",
"public void setType(int type) {\r\n this.type = type;\r\n }",
"public void setType(int type) {\r\n this.type = type;\r\n }",
"public void setType(SupplyType type) \r\n {\r\n if (type==SupplyType.COUNT&&amount%1.0!=0)\r\n {\r\n throw new IllegalArgumentException(\"Countable units must be of\" +\r\n \t\t\" an integer quantity\");\r\n }\r\n this.type = type;\r\n }",
"public void setTradeType (java.lang.Long tradeType) {\r\n\t\tthis.tradeType = tradeType;\r\n\t}",
"public void setIdVoteType( int idVoteType )\n {\n _nIdVoteType = idVoteType;\n }",
"public void setType(int type) {\n type_ = type;\n }",
"public void setType (int type) {\n this.type = type;\n }",
"public void setType (int type) {\n this.type = type;\n }",
"public abstract void setCurrencyType(String currencyType);",
"public void setType(int type) {\n this.type = type;\n }",
"public void setTypeId(Integer typeId) {\n this.typeId = typeId;\n }",
"public void setTypeId(com.walgreens.rxit.ch.cda.POCDMT000040InfrastructureRootTypeId typeId)\n {\n synchronized (monitor())\n {\n check_orphaned();\n com.walgreens.rxit.ch.cda.POCDMT000040InfrastructureRootTypeId target = null;\n target = (com.walgreens.rxit.ch.cda.POCDMT000040InfrastructureRootTypeId)get_store().find_element_user(TYPEID$2, 0);\n if (target == null)\n {\n target = (com.walgreens.rxit.ch.cda.POCDMT000040InfrastructureRootTypeId)get_store().add_element_user(TYPEID$2);\n }\n target.set(typeId);\n }\n }",
"public void setType(int type)\n\t{\n\t\tthis.type = type;\n\t}",
"public void setType(Integer type) {\n this.type = type;\n }",
"public void setType(Integer type) {\n this.type = type;\n }",
"public void setType(Integer type) {\n this.type = type;\n }",
"public void setType(Integer type) {\n this.type = type;\n }",
"public void setType(Integer type) {\n this.type = type;\n }",
"public void setType(Integer type) {\n this.type = type;\n }",
"public void setType(Integer type) {\n this.type = type;\n }",
"public void setUserType(String type) {\r\n switch(type) {\r\n case (\"admin\"): \r\n this.userType = 0;\r\n break;\r\n case (\"seller\"):\r\n this.userType = 1;\r\n break;\r\n case (\"buyer\"):\r\n this.userType = 2;\r\n break;\r\n \r\n }\r\n }",
"public void setType(int type) {\n\t\tthis.type = type;\n\t}",
"@Override\n\tpublic void setType(int type) {\n\t\t_expandoColumn.setType(type);\n\t}",
"public void setType(Integer type) {\r\n\t\tthis.type = type;\r\n\t}",
"public void setData_type_id(int data_type_id) {\n this.data_type_id = data_type_id;\n }",
"public void setType(Integer type) {\n\t\tthis.type = type;\n\t}",
"public void setC_DocType_ID(boolean isReceipt) {\n setIsReceipt(isReceipt);\n String sql = \"SELECT C_DocType_ID FROM C_DocType WHERE AD_Client_ID=? AND DocBaseType=? ORDER BY IsDefault DESC\";\n try {\n PreparedStatement pstmt = DB.prepareStatement(sql, get_TrxName());\n pstmt.setInt(1, getAD_Client_ID());\n if (isReceipt) {\n pstmt.setString(2, MDocType.DOCBASETYPE_ARReceipt);\n } else {\n pstmt.setString(2, MDocType.DOCBASETYPE_APPayment);\n }\n ResultSet rs = pstmt.executeQuery();\n if (rs.next()) {\n setC_DocType_ID(rs.getInt(1));\n } else {\n log.warning(\"setDocType - NOT found - isReceipt=\" + isReceipt);\n }\n rs.close();\n pstmt.close();\n } catch (SQLException e) {\n log.log(Level.SEVERE, sql, e);\n }\n }",
"public void setType(java.lang.Integer type) {\n this.type = type;\n }",
"public void setType(java.lang.Integer type) {\n this.type = type;\n }",
"public void setTypeID(TypeID typeID) {\n\t\tthis.typeID = typeID;\n\t}",
"void setTxnTypeId(int id)\t{\n\t\tmType = TransactionTypeEnum.getTransactionType(id);\n\t}",
"public void setType( int type ) {\r\n typ = type;\r\n }",
"public void setOwnerType(OwnerType ownerType) {\n\t\tthis.ownerType = ownerType;\n\t}",
"public void setTypeCode(String typeCode) {\n this.typeCode = typeCode;\n }",
"public void setType(gov.nih.nci.calims2.domain.common.Type type) {\n this.type = type;\n }",
"public void setType(int t){\n this.type = t;\n }",
"public void setSettlementtype(Integer settlementtype) {\n this.settlementtype = settlementtype;\n }",
"public void setTypeCode(String typeCode) {\n this.typeCode = typeCode == null ? null : typeCode.trim();\n }",
"public void setTypeCode(String typeCode) {\n this.typeCode = typeCode == null ? null : typeCode.trim();\n }",
"public void setTypeCode(String typeCode) {\n this.typeCode = typeCode == null ? null : typeCode.trim();\n }",
"public void setType(int nType) { m_nType = nType; }",
"void setForPersistentMapping_Type(Type type) {\n this.type = type;\n }",
"public void setType(int id) {\n _type = id;\n }",
"public void setTransactionType(int transactionChoice);",
"private void _setIndexType(String ndxType)\n {\n if (this.indexType == null) {\n synchronized (this.indexTypeLock) {\n if (this.indexType == null) {\n this.indexType = ndxType;\n }\n }\n }\n }",
"public void assignDiscountType(int acc_no, String discount_type){\n try {\n Stm = conn.prepareStatement(\"UPDATE `bapers`.`Customer` SET Discount_type = ? WHERE Account_no =? AND Customer_type = ?;\");\n Stm.setString(1, discount_type);\n Stm.setInt(2,acc_no);\n Stm.setString(3, \"Valued\");\n Stm.executeUpdate();\n Stm.close();\n } catch (SQLException e) {\n e.printStackTrace();\n }\n }",
"public void setIdentType(Integer identType) {\n this.identType = identType;\n }",
"public void setType(int type)\n {\n editor.putInt(KEY_TYPE, type);\n // commit changes\n editor.commit();\n Log.d(TAG,\"user type modified in pref\");\n }",
"public void setAccountType(int value) {\r\n this.accountType = value;\r\n }",
"public void setC_Currency_ID (int C_Currency_ID);",
"public void setOwnerType(String ownerType) {\n\t\tthis.ownerType = ownerType;\n\t}",
"public void setType(int value) {\n this.type = value;\n }",
"public BigDecimal getTypeId() {\n return typeId;\n }",
"public int getSqlType() { return _type; }",
"public void setResult(int type, String typeName, Class javaType) {\r\n ObjectRelationalDatabaseField field = new ObjectRelationalDatabaseField(\"\");\r\n field.setSqlType(type);\r\n field.setSqlTypeName(typeName);\r\n field.setType(javaType);\r\n getParameters().set(0, field);\r\n }",
"@Override\n\tpublic Boolean setUserId(String openId, UserAccountType type, Long userId) {\n\t\tString key = CacheConstants.KEY_PRE_XLUSERID_BY_OPENID_TYPE + openId + \":\" + type.name();\n\t\treturn cache.set(key, userId, CacheConstants.EXPIRE_XLUSERID_BY_OPENID_TYPE) > 0;\n\t}",
"public void setType(int a_type) {\n\t\tthis.m_type = a_type;\n\t}",
"void setType(Type type)\n {\n this.type = type;\n }",
"public void setTypeCode(XActRelationshipEntry typeCode) {\n\t\tthis.typeCode = typeCode;\n\t}",
"public void setType(int tmp) {\n this.type = tmp;\n }",
"public void setType (int nType)\n\t{\n\t\tm_nType = nType;\n\t}",
"public void setTypeCode(Integer value) {\n setAttributeInternal(TYPECODE, value);\n }",
"public void setType(int paramtype)\r\n\t{\r\n\t\ttype = paramtype;\r\n\t}",
"void setDataType(int type );",
"public int getIdType() {\r\n return idType;\r\n }",
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"@Test\r\n public void testSetTypeId() {\r\n System.out.println(\"setTypeId\");\r\n int tid = 0;\r\n \r\n instance.setTypeId(tid);\r\n assertEquals(tid, instance.getTypeId());\r\n \r\n }",
"public void setAccountType(PaymentAccountTypeId value) {\n this.accountType = value;\n }",
"public int editType(BikeType type){\n final int EDITED = 0;\n final int NOT_EDITED = 1;\n final int NOT_FOUND = 2;\n if(!findType(type.getTypeId())){ //No matching type_id registered\n return NOT_FOUND;\n }else{ \n \n try(Connection con = DatabaseConnector.getConnection();\n PreparedStatement ps = con.prepareStatement(UPDATE)){\n \n ps.setString(1, type.getTypeName());\n ps.setDouble(2, type.getRentalPrice());\n ps.setInt(3, type.getTypeId());\n ps.executeUpdate();\n return EDITED;\n }catch(Exception e){\n System.out.println(\"Exception: \" + e);\n }\n }\n return NOT_EDITED;\n }",
"public void setType(String type)\r\n {\r\n this.mType = type;\r\n }",
"public void setBalanceType(Integer balanceType) {\n this.balanceType = balanceType;\n }",
"public void setType(type type) {\r\n\t\tthis.Type = type;\r\n\t}",
"public void setType(int t) {\r\n\t\ttype = t;\r\n\t}",
"public void setC_POSDocType_ID (int C_POSDocType_ID)\n{\nif (C_POSDocType_ID < 1) throw new IllegalArgumentException (\"C_POSDocType_ID is mandatory.\");\nset_ValueNoCheck (COLUMNNAME_C_POSDocType_ID, Integer.valueOf(C_POSDocType_ID));\n}",
"public void setTYPE(String TYPE) {\n this.TYPE = TYPE;\n }",
"public void setTypeId(String typeId) {\r\n\t\t\tthis.typeId = typeId;\r\n\t\t}",
"public void setType(Object type)\r\n {\r\n\tthis.type = type;\r\n }",
"private void setType(String type) {\n mType = type;\n }",
"public void setType(String type) {\n this.type = type;\n }",
"public Long getTypeId() {\r\n\t\treturn typeId;\r\n\t}",
"public void setTypeId(String typeId) {\r\n this.typeId = typeId == null ? null : typeId.trim();\r\n }",
"void setType(String type) {\n this.type = type;\n }"
]
| [
"0.61935174",
"0.6164011",
"0.6121947",
"0.5858175",
"0.5734242",
"0.57333857",
"0.57333857",
"0.57207406",
"0.56674045",
"0.56434894",
"0.5631274",
"0.56096226",
"0.56015986",
"0.559747",
"0.5591776",
"0.5586988",
"0.5579228",
"0.55552816",
"0.55348945",
"0.55348945",
"0.5520597",
"0.548749",
"0.5481508",
"0.54775846",
"0.54730725",
"0.54730725",
"0.54659206",
"0.5451616",
"0.5414823",
"0.53862745",
"0.53779846",
"0.53606623",
"0.53606623",
"0.53606623",
"0.53606623",
"0.53606623",
"0.53606623",
"0.53606623",
"0.5357047",
"0.5355495",
"0.5353376",
"0.53296375",
"0.53035635",
"0.527017",
"0.5264524",
"0.52574563",
"0.52574563",
"0.52564627",
"0.5255171",
"0.5252051",
"0.52493215",
"0.5247613",
"0.5232798",
"0.523001",
"0.5220666",
"0.5212038",
"0.5212038",
"0.5212038",
"0.5211867",
"0.5204927",
"0.5203837",
"0.5192656",
"0.51626265",
"0.5161076",
"0.51548624",
"0.5152089",
"0.5140534",
"0.51124346",
"0.51031715",
"0.50857556",
"0.50850457",
"0.5084577",
"0.50825405",
"0.50815463",
"0.50657517",
"0.5063607",
"0.5039121",
"0.5033245",
"0.50310194",
"0.5029554",
"0.5017411",
"0.5002371",
"0.49916595",
"0.49898392",
"0.49652955",
"0.49519262",
"0.49464977",
"0.49449247",
"0.49446052",
"0.4942477",
"0.49410936",
"0.49379972",
"0.4934316",
"0.49333555",
"0.49321464",
"0.49298054",
"0.4904069",
"0.4903841",
"0.48991087",
"0.48971522"
]
| 0.6040192 | 3 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.REC_TIME | public Date getRecTime() {
return recTime;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"long getRetrievedTime();",
"public int getRecitationTime(){\n\t\treturn this.recitationTime;\n\t}",
"public java.util.Date getRecCrtTs () {\n\t\treturn recCrtTs;\n\t}",
"final public long getDateTime() {\n return crtime ;\n }",
"public java.sql.Time getREQ_END_TIME()\n {\n \n return __REQ_END_TIME;\n }",
"@Override\n public long getModificationTime() {\n if (exists()) {\n try {\n if (((Node)item).hasProperty(JcrConstants.JCR_LASTMODIFIED)) {\n return ((Node)item).getProperty(JcrConstants.JCR_LASTMODIFIED).getLong();\n }\n } catch (RepositoryException e) {\n log.warn(\"Error while accessing jcr:lastModified property\");\n }\n }\n // fallback: return 'now'\n return new Date().getTime();\n }",
"public String getModifytime() {\n return modifytime;\n }",
"public long lastTime()\r\n/* 219: */ {\r\n/* 220:412 */ return this.lastTime.get();\r\n/* 221: */ }",
"public java.sql.Timestamp getRecdate() {\n\treturn recdate;\n}",
"public Long getCreatetime() {\n return createtime;\n }",
"public long getTime() {\n return timeMillis;\n }",
"long getCurrentTime() {\n if (dm == null) {\n return -1;\n }\n return DLockService.getLockTimeStamp(dm);\n }",
"public Date getReadTime() {\n\t\treturn readTime;\n\t}",
"public Date getModifytime() {\n return modifytime;\n }",
"public long getReceiveTimeL() {\n\t\treturn Long.parseLong(receiveTime);\n\t}",
"public java.sql.Time getREQ_START_TIME()\n {\n \n return __REQ_START_TIME;\n }",
"public Date getClModifyTime() {\r\n\t\treturn clModifyTime;\r\n\t}",
"@ApiModelProperty(value = \"修改时间\")\n public Date getRowUpdateTime() {\n return rowUpdateTime;\n }",
"public Timestamp getRecordStatusTime() {\n\t\treturn null;\n\t}",
"private long baseTime() {\n return Bytes.getUnsignedInt(row, tsdb.metrics.width());\n }",
"public long getTime() {\n\t\treturn (Sys.getTime() * 1000) / Sys.getTimerResolution();\n\t}",
"public LocalDateTime getReadTime() {\n\t\treturn readTime;\n\t}",
"public long getTime() {\r\n \treturn time;\r\n }",
"public Long getTime() {\n return time;\n }",
"@ApiModelProperty(value = \"创建时间\")\n public Date getRowAddTime() {\n return rowAddTime;\n }",
"public Date getReadTime() {\n return readTime;\n }",
"public OffsetDateTime getModifiedTime()\n\t{\n\t\treturn (OffsetDateTime) this.getKeyValue(\"Modified_Time\");\n\n\t}",
"public long getLastReadTime() {\n return LAST_READ_TIME;\n }",
"public Integer getModifyTime() {\n\t\treturn modifyTime;\n\t}",
"public long getDateRecordLastUpdated(){\n return dateRecordLastUpdated;\n }",
"@Column(name = \"D_MTIME\", nullable = false)\n public Date getMtime() {\n return this.mtime;\n }",
"long getLastAccessedTime();",
"public int getLTime() {\n return lTime;\n }",
"public long getTotalTime() {\n/* 73 */ return this.totalTime;\n/* */ }",
"public Long getTime() {\n if (timeEnd == null) {\n return null;\n }\n return timeEnd - timeStart;\n }",
"public Timestamp getTransactionTime() {\r\n return (Timestamp) getAttributeInternal(TRANSACTIONTIME);\r\n }",
"public long getTime(){\n return this.time;\n }",
"public Calendar GetAccurateLastStartTime (int opID)\r\n {\r\n Calendar retCal = null;\r\n IDBAdapter db = null;\r\n ResultSet rs = null;\r\n try {\r\n String sql = \"select CREATED_DTTM from NODE_OPERATION_LOG where OPERATION_ID = '\" +opID+ \"' order by CREATED_DTTM desc\";\r\n db = this.GetNodeDB();\r\n rs = db.GetResultSet(sql);\r\n if (rs != null && rs.first()) {\r\n Timestamp createdDate = rs.getTimestamp(\"CREATED_DTTM\");\r\n if (createdDate != null) {\r\n Node.Utils.LoggingUtils.Log(\"NodeOperationLog>>>GetAccurateLastStartTime>>>LastStartTime is: \" + new Date(createdDate.getTime()), Level.DEBUG\r\n , Phrase.TaskLoggerName);\r\n\r\n //SimpleDateFormat format = new SimpleDateFormat(\"yyyy-MM-dd hh:mm:ss\");\r\n retCal = new GregorianCalendar();\r\n retCal.setTime(new Date(createdDate.getTime()));\r\n }\r\n }\r\n } catch (Exception e) {\r\n this.LogException(\"Could Not Get Last Start Time: \" + e.toString());\r\n } finally {\r\n try {\r\n if (rs != null)\r\n rs.close();\r\n if (db != null)\r\n db.Close();\r\n } catch (Exception e) {\r\n this.LogException(e.toString());\r\n }\r\n }\r\n return retCal;\r\n }",
"@ApiModelProperty(value = \"更新时间\")\n\tpublic Date getRowUpdateTime() {\n\t\treturn rowUpdateTime;\n\t}",
"public long getTime() {\r\n\t\treturn time;\r\n\t}",
"@Override\r\n\tpublic long getTime() {\n\t\treturn this.time;\r\n\t}",
"@ApiModelProperty(value = \"添加时间\")\n\tpublic Date getRowAddTime() {\n\t\treturn rowAddTime;\n\t}",
"public Date getcTime() {\r\n return cTime;\r\n }",
"public Long getChecktime() {\n return checktime;\n }",
"public Date getReceiveTime() {\r\n return receiveTime;\r\n }",
"public java.sql.Time getTime(String attr) {\n return (java.sql.Time) super.get(attr);\n }",
"public String getModifyTime() {\n return modifyTime;\n }",
"public Date getLockTime() {\n\t\treturn lockTime;\n\t}",
"public int getwaitTime(){\r\n\t\t String temp=rb.getProperty(\"waitTime\");\r\n\t\t return Integer.parseInt(temp);\r\n\t}",
"public Date getModifyTime() {\n return this.modifyTime;\n }",
"public Date getModifyTime() {\r\n return modifyTime;\r\n }",
"public Date getOPER_TIME() {\n return OPER_TIME;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public long getTime() {\n return _time;\n }",
"public Long getTimeStamp() {\n return this.TimeStamp;\n }",
"public Date getOperatetime() {\r\n return operatetime;\r\n }",
"public static long getTime() {\n\t\treturn (Sys.getTime() * 1000) / Sys.getTimerResolution();\n\t}",
"public int getTimeStamp() {\r\n return fTimeStamp;\r\n }",
"public double time()\n\t{\n\t\treturn _dblTime;\n\t}",
"public double time()\n\t{\n\t\treturn _dblTime;\n\t}",
"public Integer getCusTime() {\r\n return cusTime;\r\n }",
"public Date getReceiveTime() {\n return receiveTime;\n }",
"public java.sql.Time getTime(int columnIndex) throws SQLException\n {\n return m_rs.getTime(columnIndex);\n }",
"public double getCBRTime();",
"public Date getOprTime() {\n return oprTime;\n }",
"public String getTime() {\n\t\t\tDateFormat dateFormat = new SimpleDateFormat(\"HH:mm:ss\");\n\t\t\tCalendar cal = Calendar.getInstance();\n\t\t\tString time = dateFormat.format(cal.getTime());\n\t\t\treturn time;\n\t\t}",
"public java.util.Date getResultRecordedTime() {\n return resultRecordedTime;\n }",
"public int getTime() {\n if (USE_SERIALIZABLE) {\n return childBuilder.getTime();\n } else {\n // @todo Replace with real Builder object if possible\n return convertNullToNOT_SET(childBuilderElement.getAttributeValue(\"time\"));\n }\n }",
"public long getTime(){\n\n formatDate(mCalendar.getTimeInMillis());\n\n return mCalendar.getTimeInMillis();\n\n }",
"public Date getClCreateTime() {\r\n return clCreateTime;\r\n }",
"public Date getOperateTime() {\n return operateTime;\n }",
"public Date getOperateTime() {\n return operateTime;\n }",
"public Date getOperateTime() {\n return operateTime;\n }",
"public String getModifyTime() {\r\n\t\treturn modifyTime;\r\n\t}",
"public String getModifyTime() {\r\n\t\treturn modifyTime;\r\n\t}",
"public String getModifyTime() {\r\n\t\treturn modifyTime;\r\n\t}",
"public String getModifyTime() {\r\n\t\treturn modifyTime;\r\n\t}",
"public long getTime() {\n return time;\n }",
"public String getCreatetime() {\r\n return createtime;\r\n }",
"private Time getTimeValueFromRecordBean(RecordBean recordBean){\n DateFormat formatter = new SimpleDateFormat(\"MM/dd/yyyy HH:mm:ss\");\n Time timeValue = null;\n try {\n timeValue = new Time(formatter.parse((String)recordBean.getValues().get(\"_timestamp\")).getTime());\n\n if (timeValue == null) {\n List<String> items = Arrays.asList(((String)recordBean.getValues().get(\"_message\")).split(\"\\\\s*,\\\\s*\"));\n timeValue = new Time(formatter.parse(items.get(0)).getTime());\n\n }\n\n } catch (Exception e) {\n e.printStackTrace();\n }\n return timeValue;\n }",
"public long getTimerTime() {\n return timerTime;\n }",
"public java.lang.String getCreatetime () {\n\t\treturn createtime;\n\t}",
"protected long getLastMsTime() {\r\n return lastMsTime;\r\n }",
"public Date getModifyTime() {\n\t\treturn modifyTime;\n\t}",
"public Date getModifyTime() {\n\t\treturn modifyTime;\n\t}",
"public Date getModifyTime() {\n\t\treturn modifyTime;\n\t}",
"public String getTime() {\n return this.time;\n }",
"public long getEventTime();",
"public Time getTime(int columnIndex) throws SQLException {\n\n try {\n debugCodeCall(\"getTime\", columnIndex);\n return get(columnIndex).getTime();\n }\n catch (Exception e) {\n throw logAndConvert(e);\n }\n }",
"public Date getModifiTime() {\n return modifiTime;\n }",
"public Date getLogtime()\r\n {\r\n return logtime;\r\n }",
"public synchronized String getTime() {\n\t\treturn time;\n\t}"
]
| [
"0.5921349",
"0.58910257",
"0.5812946",
"0.5797282",
"0.5763677",
"0.5757098",
"0.57562256",
"0.5738044",
"0.5735445",
"0.5735167",
"0.5694209",
"0.568744",
"0.56802696",
"0.56775665",
"0.5666558",
"0.5651597",
"0.56346375",
"0.5633115",
"0.56326234",
"0.5610541",
"0.5603061",
"0.56007874",
"0.55971754",
"0.55951685",
"0.5588418",
"0.55856234",
"0.5584666",
"0.5568051",
"0.5558685",
"0.5548264",
"0.55470836",
"0.5542455",
"0.5530498",
"0.55183923",
"0.55150974",
"0.54798955",
"0.54622364",
"0.5457608",
"0.54540896",
"0.54539675",
"0.5451222",
"0.5440645",
"0.5433392",
"0.543064",
"0.5426778",
"0.54265565",
"0.5424598",
"0.54205245",
"0.5419982",
"0.54168135",
"0.5416572",
"0.54158485",
"0.5407552",
"0.5407552",
"0.5407552",
"0.5407552",
"0.5407552",
"0.5407552",
"0.5407552",
"0.5407552",
"0.5407552",
"0.5407188",
"0.5405034",
"0.53992397",
"0.5398801",
"0.5398369",
"0.5395158",
"0.5395158",
"0.5394889",
"0.5393383",
"0.53884923",
"0.5383031",
"0.53804034",
"0.53803843",
"0.538022",
"0.53784025",
"0.5378394",
"0.5376439",
"0.5376389",
"0.5376389",
"0.5376389",
"0.5373394",
"0.5373394",
"0.5373394",
"0.5373394",
"0.5361301",
"0.5354015",
"0.53527236",
"0.53509516",
"0.5342127",
"0.5340315",
"0.5340203",
"0.5340203",
"0.5340203",
"0.5335758",
"0.5327541",
"0.53270644",
"0.532611",
"0.5325215",
"0.532508"
]
| 0.66718453 | 0 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.REC_TIME | public void setRecTime(Date recTime) {
this.recTime = recTime;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setTime(){\n \tDatabaseManager.getDBM().setLockedTime(cal); \n }",
"public Date getRecTime() {\n return recTime;\n }",
"void setRetrievedTime(long retrievedTime);",
"private MadisRecord setRecordTime(MadisRecord rec) {\n try {\n rec.setDataTime(new DataTime(rec.getTimeObs()));\n return rec;\n } catch (Exception e) {\n statusHandler.handle(Priority.ERROR, \"Can't set Madis Record URI! \"\n + rec.getStationId(), e);\n }\n\n return null;\n }",
"public void setExpiryTime(java.util.Calendar param){\n localExpiryTimeTracker = true;\n \n this.localExpiryTime=param;\n \n\n }",
"protected void setLastMsTime(long lastMsTime) {\r\n TaskTimeElementDB.lastMsTime = lastMsTime;\r\n }",
"public void setREQ_START_TIME(java.sql.Time value)\n {\n if ((__REQ_START_TIME == null) != (value == null) || (value != null && ! value.equals(__REQ_START_TIME)))\n {\n _isDirty = true;\n }\n __REQ_START_TIME = value;\n }",
"public void setREQ_END_TIME(java.sql.Time value)\n {\n if ((__REQ_END_TIME == null) != (value == null) || (value != null && ! value.equals(__REQ_END_TIME)))\n {\n _isDirty = true;\n }\n __REQ_END_TIME = value;\n }",
"public void setProvisionTime(java.util.Calendar param){\n localProvisionTimeTracker = true;\n \n this.localProvisionTime=param;\n \n\n }",
"public void setClModifyTime(Date clModifyTime) {\r\n\t\tthis.clModifyTime = clModifyTime;\r\n\t}",
"public void setExpiryTime(long ldtExpiry)\n {\n m_metaInf.setExpiryTime(ldtExpiry);\n }",
"public void setTime(){\n Date currentDate = new Date();\n\n SharedPreferences.Editor editor = mSharedPreferences.edit();\n editor.putLong(\"WAIT_TIME\", currentDate.getTime() + 1800000); //30 min\n editor.commit();\n }",
"private void setTime(long value) {\n \n time_ = value;\n }",
"private void setTime(long value) {\n \n time_ = value;\n }",
"private void setTime(long value) {\n \n time_ = value;\n }",
"public void setREC_ID(Integer REC_ID) {\n this.REC_ID = REC_ID;\n }",
"public void setExpiryMillis(long lMillis)\n {\n m_dtExpiry = lMillis;\n }",
"public void setModified(java.sql.Timestamp tmp) {\n this.modified = tmp;\n }",
"public void setRecCrtTs (java.util.Date recCrtTs) {\n\t\tthis.recCrtTs = recCrtTs;\n\t}",
"public Date getModifytime() {\n return modifytime;\n }",
"@Override public void checkpointReadLockTimeout(long val) {\n checkpointReadLockTimeout = val;\n }",
"public void set(final long timeValue) {\n stamp = timeValue;\n }",
"public void setTime(long timeMillis) {\n this.timeMillis = timeMillis;\n }",
"public com.twc.bigdata.views.avro.viewing_info.Builder setStartTime(java.lang.Long value) {\n validate(fields()[0], value);\n this.start_time = value;\n fieldSetFlags()[0] = true;\n return this; \n }",
"void setFetchedDate(long time);",
"public void setModifiyTime(Date modifiyTime) {\n this.modifiyTime = modifiyTime;\n }",
"private static void fillReserveTime(ResultSet resultSet, ReserveTime reserveTime){\n\t\ttry {\n\t\t\treserveTime.setID(resultSet.getInt(1));\n\t\t\treserveTime.setUnitID(resultSet.getInt(2));\n\t\t\treserveTime.setDateID(resultSet.getInt(3));\n\t\t\treserveTime.setMiddayID(MiddayID.getByValue(resultSet.getInt(4)));\n\t\t\treserveTime.setStartTime(resultSet.getObject(5, LocalTime.class));\n\t\t\treserveTime.setDuration(resultSet.getInt(6));\n\t\t\treserveTime.setStatus(ReserveTimeStatus.getByValue(resultSet.getInt(7)));\n\t\t\treserveTime.setClientID(resultSet.getInt(8));\n\t\t\treserveTime.setResCodeID(resultSet.getString(9));\n\t\t\treserveTime.setReserveTimeGRDateTime(resultSet.getObject(10, LocalDateTime.class));\n\t\t}catch (SQLException e){\n\t\t\tLogger.getLogger(\"Exception\").log(Level.SEVERE, \"Exception \" + e);\n\t\t}\n\t}",
"void setReportTime(long time);",
"@ApiModelProperty(value = \"修改时间\")\n public Date getRowUpdateTime() {\n return rowUpdateTime;\n }",
"public void setCreateTime(Date createTime)\n/* */ {\n/* 184 */ this.createTime = createTime;\n/* */ }",
"private void setTime(long value) {\n \n time_ = value;\n }",
"private void setTime(long value) {\n \n time_ = value;\n }",
"private void setTime(long value) {\n \n time_ = value;\n }",
"private void setTime(long value) {\n \n time_ = value;\n }",
"public String getModifytime() {\n return modifytime;\n }",
"public void setCreatetime(Long createtime) {\n this.createtime = createtime;\n }",
"public void setCreatTime(Date creatTime) {\n this.creatTime = creatTime;\n }",
"public void setCreatTime(Date creatTime) {\n this.creatTime = creatTime;\n }",
"public void setRowAddTime(Date rowAddTime) {\n this.rowAddTime = rowAddTime;\n }",
"public void setReadTime(Date readTime) {\n this.readTime = readTime;\n }",
"public Date getClModifyTime() {\r\n\t\treturn clModifyTime;\r\n\t}",
"public void setReadTime(Date readTime) {\n\t\tthis.readTime = readTime;\n\t}",
"@Override\n\tpublic RcuSettime selectByPrimaryKey(String rcuid) {\n\t\treturn rcuSettimeMapper.selectByPrimaryKey(rcuid);\n\t}",
"public void setStartTime (long x)\r\n {\r\n startTime = x;\r\n }",
"public void setActivationTime(java.util.Calendar param){\n localActivationTimeTracker = true;\n \n this.localActivationTime=param;\n \n\n }",
"private void setCreateTime(long createTime) {\n this.createTime = createTime;\n }",
"public void setModifytime(Date modifytime) {\n this.modifytime = modifytime;\n }",
"public Date getModifyTime() {\r\n return modifyTime;\r\n }",
"public void setModifiTime(Date modifiTime) {\n this.modifiTime = modifiTime;\n }",
"public void setRecdate(java.sql.Timestamp newValue) {\n\tthis.recdate = newValue;\n}",
"public void setMtime(DateTime mtime) {\r\n this.mtime = mtime;\r\n }",
"public void setClCreateTime(Date clCreateTime) {\r\n this.clCreateTime = clCreateTime;\r\n }",
"public void setRowAddTime(Date rowAddTime) {\n\t\tthis.rowAddTime = rowAddTime;\n\t}",
"public void setRegdate(long newVal) {\n setRegdate(new java.sql.Timestamp(newVal));\n }",
"public void setMtime(Date mtime) {\n this.mtime = mtime;\n }",
"public void setStartTime(double startTime)\r\n {\r\n synchronized (monitor())\r\n {\r\n check_orphaned();\r\n org.apache.xmlbeans.SimpleValue target = null;\r\n target = (org.apache.xmlbeans.SimpleValue)get_store().find_attribute_user(STARTTIME$22);\r\n if (target == null)\r\n {\r\n target = (org.apache.xmlbeans.SimpleValue)get_store().add_attribute_user(STARTTIME$22);\r\n }\r\n target.setDoubleValue(startTime);\r\n }\r\n }",
"public void setReadTime(LocalDateTime readTime) {\n\t\tthis.readTime = readTime;\n\t}",
"public BrowseHistoryContentValues putLastReadTime(long value) {\n mContentValues.put(BrowseHistoryColumns.LAST_READ_TIME, value);\n return this;\n }",
"public java.util.Date getRecCrtTs () {\n\t\treturn recCrtTs;\n\t}",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Date getModifyTime() {\n return modifyTime;\n }",
"public Long getCreatetime() {\n return createtime;\n }",
"public Date getModifyTime() {\n return this.modifyTime;\n }",
"public void setRowUpdateTime(Date rowUpdateTime) {\n this.rowUpdateTime = rowUpdateTime;\n }",
"@Model\r\n\tprotected void setModificationTime() {\r\n modificationTime = new Date();\r\n }",
"public void setLastAccessedTime(long lastAccessTime) {\r\n \t\tthis.lastAccessTime= lastAccessTime;\r\n \t}",
"private void setLastCacheUpdateTimeMillis() {\n long currentMillis = System.currentTimeMillis();\n this.fileManager.writeToPreferences(this.context, SETTINGS_KEY, currentMillis);\n }",
"void setLastAccessTimeUtc(String path, long newTime) throws IOException;",
"public void updateLecture_Time(Class c) {\n\t\tSqlSession sqlSession = MyBatisUtil.getSqlSessionFactory()\n\t\t\t\t.openSession();\n\t\ttry {\n\t\t\tClassMapper classMapper = sqlSession.getMapper(ClassMapper.class);\n\t\t\tclassMapper.updateLecture_Time(c);\n\t\t\tsqlSession.commit();\n\t\t} finally {\n\t\t\tsqlSession.close();\n\t\t}\n\t}",
"@Column(name = \"D_MTIME\", nullable = false)\n public Date getMtime() {\n return this.mtime;\n }",
"public void setConsumerTime(java.lang.Long value) {\n this.consumer_time = value;\n }",
"public void setOperatetime(Date operatetime) {\r\n this.operatetime = operatetime;\r\n }",
"public void setRowUpdateTime(Date rowUpdateTime) {\n\t\tthis.rowUpdateTime = rowUpdateTime;\n\t}",
"public void setRptrecvtime(Date rptrecvtime) {\n this.rptrecvtime = rptrecvtime;\n }",
"public void setClCreateTime(Date clCreateTime) {\r\n\t\tthis.clCreateTime = clCreateTime;\r\n\t}",
"public void pickRecitationTime(int start){\n\t\tthis.recitationTime = start;\n\t}",
"public void setOPER_TIME(Date OPER_TIME) {\n this.OPER_TIME = OPER_TIME;\n }",
"public void setStartTime(long value) {\r\n this.startTime = value;\r\n }",
"public void setReceiveTime(Date receiveTime) {\r\n this.receiveTime = receiveTime;\r\n }",
"private void setSlaveUserAccessTime(final VOUser user, final Long time)\n throws Exception {\n runTX(new Callable<Void>() {\n @Override\n public Void call() throws Exception {\n PlatformUser user1 = dm.getReference(PlatformUser.class,\n user.getKey());\n if (time != null) {\n user1.getMaster().getDataContainer()\n .setLastAccessTime(time.longValue());\n }\n return null;\n }\n });\n }",
"public java.sql.Time getREQ_END_TIME()\n {\n \n return __REQ_END_TIME;\n }",
"public int getRecitationTime(){\n\t\treturn this.recitationTime;\n\t}",
"public Date getModifiyTime() {\n return modifiyTime;\n }",
"public void setClUpdateTime(Date clUpdateTime) {\r\n this.clUpdateTime = clUpdateTime;\r\n }",
"public void setcTime(Date cTime) {\r\n this.cTime = cTime;\r\n }",
"public void setStartTime(java.lang.Long value) {\n this.start_time = value;\n }",
"public final void updateModifyDateTime() {\n \tm_modifyDate = System.currentTimeMillis();\n \tm_accessDate = m_modifyDate;\n }",
"public Integer getModifyTime() {\n\t\treturn modifyTime;\n\t}",
"@Override\n public long getModificationTime() {\n if (exists()) {\n try {\n if (((Node)item).hasProperty(JcrConstants.JCR_LASTMODIFIED)) {\n return ((Node)item).getProperty(JcrConstants.JCR_LASTMODIFIED).getLong();\n }\n } catch (RepositoryException e) {\n log.warn(\"Error while accessing jcr:lastModified property\");\n }\n }\n // fallback: return 'now'\n return new Date().getTime();\n }",
"public void setTime(long time) {\r\n this.time = time;\r\n }",
"@ApiModelProperty(value = \"更新时间\")\n\tpublic Date getRowUpdateTime() {\n\t\treturn rowUpdateTime;\n\t}",
"public Builder setCreateTime(long value) {\n\n createTime_ = value;\n onChanged();\n return this;\n }",
"final public long getDateTime() {\n return crtime ;\n }"
]
| [
"0.6348822",
"0.57561445",
"0.5713019",
"0.56354016",
"0.54413813",
"0.531161",
"0.5304101",
"0.5303472",
"0.5300685",
"0.5294441",
"0.52903473",
"0.528789",
"0.5219394",
"0.5219394",
"0.5219394",
"0.5198427",
"0.5198401",
"0.5187433",
"0.51655376",
"0.5156053",
"0.51544046",
"0.5149097",
"0.5117208",
"0.5101921",
"0.5072475",
"0.50635946",
"0.5059548",
"0.50489783",
"0.5041034",
"0.50409395",
"0.50286883",
"0.50286883",
"0.50286883",
"0.50286883",
"0.5026384",
"0.5007866",
"0.4989918",
"0.4989918",
"0.49824744",
"0.49738684",
"0.4969889",
"0.49693885",
"0.49672583",
"0.49669406",
"0.49655622",
"0.49626786",
"0.49599546",
"0.49597394",
"0.49592936",
"0.495552",
"0.49452817",
"0.49415532",
"0.49388942",
"0.49378672",
"0.4937389",
"0.49281216",
"0.49218228",
"0.49118474",
"0.4911572",
"0.49105686",
"0.49105686",
"0.49105686",
"0.49105686",
"0.49105686",
"0.49105686",
"0.49105686",
"0.49105686",
"0.49105686",
"0.49084228",
"0.48938194",
"0.48931405",
"0.4891973",
"0.48908293",
"0.48871434",
"0.48866862",
"0.48850045",
"0.4884296",
"0.48841438",
"0.4874095",
"0.48696038",
"0.48661762",
"0.48592898",
"0.48583144",
"0.48534483",
"0.4850992",
"0.48491335",
"0.48471162",
"0.48468533",
"0.48372415",
"0.48350862",
"0.48341745",
"0.48300305",
"0.4821966",
"0.4820378",
"0.48183638",
"0.48139203",
"0.48138845",
"0.48129264",
"0.4809332",
"0.48084927"
]
| 0.6262308 | 1 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.ACTIONTYPE | public Integer getActiontype() {
return actiontype;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Integer getActionType() {\n return actionType;\n }",
"public String getActionType() {\n return actionType;\n }",
"public String getActionType() {\n return actionType;\n }",
"public Type getActionType() {\n return actionType;\n }",
"ActionType getType();",
"public int getActionType();",
"Action getType();",
"@Override\n\tpublic Class<LoginUserAction> getActionType() {\n\t\treturn null;\n\t}",
"public com.cantor.drop.aggregator.model.CFTrade.TradeAction getAction() {\n com.cantor.drop.aggregator.model.CFTrade.TradeAction result = com.cantor.drop.aggregator.model.CFTrade.TradeAction.valueOf(action_);\n return result == null ? com.cantor.drop.aggregator.model.CFTrade.TradeAction.EXECUTED : result;\n }",
"public com.cantor.drop.aggregator.model.CFTrade.TradeAction getAction() {\n com.cantor.drop.aggregator.model.CFTrade.TradeAction result = com.cantor.drop.aggregator.model.CFTrade.TradeAction.valueOf(action_);\n return result == null ? com.cantor.drop.aggregator.model.CFTrade.TradeAction.EXECUTED : result;\n }",
"public RepositoryActionType getAction() {\n\t\t\treturn action;\n\t\t}",
"public Long getActionId() {\n return actionId;\n }",
"public int getAction() {\n\t\treturn action;\n\t}",
"public Class<?> getActionClass() {\n return this.action;\n }",
"public String getActionInfo() {\n\n String\taction\t= getAction();\n\n if (ACTION_AppsProcess.equals(action)) {\n return \"Process:AD_Process_ID=\" + getAD_Process_ID();\n } else if (ACTION_DocumentAction.equals(action)) {\n return \"DocumentAction=\" + getDocAction();\n } else if (ACTION_AppsReport.equals(action)) {\n return \"Report:AD_Process_ID=\" + getAD_Process_ID();\n } else if (ACTION_AppsTask.equals(action)) {\n return \"Task:AD_Task_ID=\" + getAD_Task_ID();\n } else if (ACTION_SetVariable.equals(action)) {\n return \"SetVariable:AD_Column_ID=\" + getAD_Column_ID();\n } else if (ACTION_SubWorkflow.equals(action)) {\n return \"Workflow:MPC_Order_Workflow_ID=\" + getMPC_Order_Workflow_ID();\n } else if (ACTION_UserChoice.equals(action)) {\n return \"UserChoice:AD_Column_ID=\" + getAD_Column_ID();\n } else if (ACTION_UserWorkbench.equals(action)) {\n return \"Workbench:?\";\n } else if (ACTION_UserForm.equals(action)) {\n return \"Form:AD_Form_ID=\" + getAD_Form_ID();\n } else if (ACTION_UserWindow.equals(action)) {\n return \"Window:AD_Window_ID=\" + getAD_Window_ID();\n }\n\n /*\n * else if (ACTION_WaitSleep.equals(action))\n * return \"Sleep:WaitTime=\" + getWaitTime();\n */\n return \"??\";\n\n }",
"public void setActionType(Integer actionType) {\n this.actionType = actionType;\n }",
"public void setActiontype(Integer actiontype) {\n this.actiontype = actiontype;\n }",
"@ApiModelProperty(required = true, value = \"The action type to be applied. When UPDATE_INTEREST_SETTINGS action type is used, all the existing deposit accounts will be updated with the latest interest-related fields at the end of day job execution\")\n @JsonProperty(JSON_PROPERTY_ACTION)\n @JsonInclude(value = JsonInclude.Include.ALWAYS)\n\n public ActionEnum getAction() {\n return action;\n }",
"public ActionType getActionType(com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.abedmnlib_hva.v1.ActionType res){\n\t\tActionType actionType = new ActionType();\n\t\t\n\t\tactionType.setActionCode( res.getActionCode() );\n\t\tactionType.setDescription( res.getDescription() );\n\t\t\n\t\treturn actionType;\n\t}",
"public ActionParameterType getType() {\n\n\t\treturn _type;\n\n\t}",
"public int getAction() {\n return action_;\n }",
"public int getAction() {\n return action;\n }",
"public int getAction() {\n return action_;\n }",
"public Class getActionClass() {\n return actionClass;\n }",
"public int getSqlType() { return _type; }",
"public Integer getactioncode() {\n return (Integer) getAttributeInternal(ACTIONCODE);\n }",
"public String getAction() {\r\n\t\treturn action;\r\n\t}",
"public String getLockType() {\n return this.lockType;\n }",
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"com.cantor.drop.aggregator.model.CFTrade.TradeAction getAction();",
"String getTYPE() {\n return TYPE;\n }",
"public String getAction() {\n\t\treturn action;\n\t}",
"public String getAction() {\n\t\treturn action;\n\t}",
"public String getAction() {\n\t\treturn action;\n\t}",
"public String getAction() {\n\t\treturn action;\n\t}",
"@Nullable\n @Generated\n @Selector(\"handoffUserActivityType\")\n public native String handoffUserActivityType();",
"public String getAction () {\n return action;\n }",
"public String getActionVariableType(String actionName) {\r\n\t\tString str = null;\r\n\t\tfor (DataVariable var : dataTestModel) {\r\n\r\n\t\t\tif (var.getName().equals(actionName)) {\r\n\t\t\t\tstr = var.getType();\r\n\t\t\t}\r\n\t\t}\r\n\r\n\t\treturn str;\r\n\t}",
"public com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.abedmnlib_hva.v1.ActionType getActionTypeReq(ActionType actionType){\n\t\tcom.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.abedmnlib_hva.v1.ActionType actionTypeReq =\n\t\t\tnew com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.abedmnlib_hva.v1.ActionType();\n\t\t\n\t\tactionTypeReq.setActionCode( actionType.getActionCode() );\n\t\tactionTypeReq.setDescription( actionType.getDescription() );\n\t\t\n\t\treturn actionTypeReq;\n\t}",
"public String getActionId() {\n return actionId;\n }",
"public int getAction()\n {\n return m_action;\n }",
"public com.vmware.converter.AlarmAction getAction() {\r\n return action;\r\n }",
"public String getTYPE() {\n return TYPE;\n }",
"public String getAction() {\n\t\treturn action.get();\n\t}",
"public EventType type() {\n return _type;\n }",
"public String getAction() {\n return this.action;\n }",
"public TYPE getType(){\n return this.type;\n }",
"public Long getOperatetype() {\n return operatetype;\n }",
"public Action getAction() {\n\treturn action;\n }",
"public String getIndexType()\n {\n if (this.indexType == null) {\n try {\n this.getMySQLTableStatus();\n } catch (DBException dbe) {\n // continue below\n }\n // \"this.indexType\" should be set (but possibly \"?\" if error)\n if (this.indexType == null) {\n // still null? set to \"?\"\n this._setIndexType(\"?\");\n }\n }\n return this.indexType;\n }",
"public int getJdbcType();",
"public String getAction() {\n return action;\n }",
"public int Gettype(){\n\t\treturn type;\n\t}",
"public int getType(){\n return type;\n }",
"public String getAction() {\n return action;\n }",
"public String getAction() {\n return action;\n }",
"public String getAction() {\n return action;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public String getJdbcType() {\n return this.jdbcType;\n }",
"public int getType() {\n\t return type;\n\t }",
"public int getUserAction()\n {\n return userAction;\n }",
"public TransactionType getTransactionType()\n {\n return transactionType;\n }",
"public String getSqlType() {\n\t\treturn this.sqlType;\n\t}",
"public int getType(){\r\n\t\treturn type;\r\n\t}",
"public int getType () {\r\n return type;\r\n }",
"public int getType()\r\n {\r\n return type;\r\n }",
"public static com.fasterxml.jackson.core.type.TypeReference<ProductSetMetaTitleAction> typeReference() {\n return new com.fasterxml.jackson.core.type.TypeReference<ProductSetMetaTitleAction>() {\n @Override\n public String toString() {\n return \"TypeReference<ProductSetMetaTitleAction>\";\n }\n };\n }",
"public int getType() {\r\n\t\treturn (type);\r\n\t}",
"public int getType(){\n\t\treturn type;\n\t}",
"public String type(){\n\t\treturn type;\n\t}",
"protected RowLock getUpdateLockType() \n {\n\t\treturn(RowLock.RU3);\n }",
"public int getType() {\n return type;\n }",
"public int type() {\n return type;\n }",
"public int getType() {\r\n return type;\r\n }",
"public int getType() {\r\n return type;\r\n }",
"public int getType() {\r\n return type;\r\n }",
"public void setActionType(final String actionType) {\n this.actionType = actionType;\n }",
"public int getType() {\n return _type;\n }",
"public int getType() {\n return _type;\n }",
"public int getActionCommand() {\n return actionCommand_;\n }",
"public ReadOperationResultType getResultType()\n {\n if(resultType == null) resultType = ReadOperationResultType.ALL;\n return resultType;\n }",
"public NATActionType getNATAction() {\n\t\treturn NATAction;\n\t}",
"public long getType() {\r\n return type;\r\n }",
"java.lang.String getKeyRevocationActionType();",
"public String getType(){\r\n return type;\r\n }",
"public String getActionId() {\n\t\treturn actionId;\n\t}",
"public int getActionCommand() {\n return actionCommand_;\n }",
"public int getType()\n {\n return type;\n }",
"public int getType()\n {\n return type;\n }",
"public A getAction() {\r\n\t\treturn action;\r\n\t}",
"public int getType() { \n return type; \n }"
]
| [
"0.6543143",
"0.64688724",
"0.6280919",
"0.62469333",
"0.60668284",
"0.59817135",
"0.57427937",
"0.56497294",
"0.5609137",
"0.55973136",
"0.5361593",
"0.53382933",
"0.5334381",
"0.5332504",
"0.5320116",
"0.53162324",
"0.531017",
"0.52783483",
"0.52690744",
"0.5231313",
"0.522886",
"0.52285135",
"0.522717",
"0.5182447",
"0.5147623",
"0.51448834",
"0.5083844",
"0.50719386",
"0.5071417",
"0.50648445",
"0.5049102",
"0.5035917",
"0.5035917",
"0.5035917",
"0.5035917",
"0.50300854",
"0.50238025",
"0.5020936",
"0.5011091",
"0.50044316",
"0.4997203",
"0.49922186",
"0.4987478",
"0.49843678",
"0.49749863",
"0.49676853",
"0.49652246",
"0.49561274",
"0.4945422",
"0.49263793",
"0.49262482",
"0.49203214",
"0.49203214",
"0.49049717",
"0.4903282",
"0.4903282",
"0.4903282",
"0.4896785",
"0.4896785",
"0.4896785",
"0.4896785",
"0.4896785",
"0.4896785",
"0.4896785",
"0.4896785",
"0.4896785",
"0.4896785",
"0.4896785",
"0.48945358",
"0.48903993",
"0.48892167",
"0.48821893",
"0.48674774",
"0.48636898",
"0.4861396",
"0.4857998",
"0.48492622",
"0.48479334",
"0.48472548",
"0.4843897",
"0.48422995",
"0.4841531",
"0.48303598",
"0.48303598",
"0.48303598",
"0.48271504",
"0.48252523",
"0.48252523",
"0.482483",
"0.48152938",
"0.48146397",
"0.4814303",
"0.48129976",
"0.48082405",
"0.48079267",
"0.4805448",
"0.48013136",
"0.48013136",
"0.47984868",
"0.47965795"
]
| 0.6639593 | 0 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.ACTIONTYPE | public void setActiontype(Integer actiontype) {
this.actiontype = actiontype;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setActionType(Integer actionType) {\n this.actionType = actionType;\n }",
"public String getActionType() {\n return actionType;\n }",
"public Integer getActionType() {\n return actionType;\n }",
"public void setActionType(final String actionType) {\n this.actionType = actionType;\n }",
"public Integer getActiontype() {\n return actiontype;\n }",
"public Type getActionType() {\n return actionType;\n }",
"public String getActionType() {\n return actionType;\n }",
"@POST\n @Path(\"/actions\")\n public void setActionType(ActionType actionType) {\n definitionsService.setActionType(actionType);\n }",
"ActionType getType();",
"public void setAction(String action) { this.action = action; }",
"public void setAction(String action);",
"public void setType( final int type )\n {\n this.type = type;\n fireActionChanged();\n }",
"public int getActionType();",
"public void setAction (String action) {\n this.action = action;\n }",
"public void setAction(com.vmware.converter.AlarmAction action) {\r\n this.action = action;\r\n }",
"@Override\n\tpublic Class<LoginUserAction> getActionType() {\n\t\treturn null;\n\t}",
"public void setType(long type) {\r\n this.type = type;\r\n }",
"public void setType(int type)\n {\n editor.putInt(KEY_TYPE, type);\n // commit changes\n editor.commit();\n Log.d(TAG,\"user type modified in pref\");\n }",
"public FlowAction(FlowActionType type) {\n this.actionType = type;\n }",
"private void setAction(String action)\r\n/* 46: */ {\r\n/* 47: 48 */ this.action = action;\r\n/* 48: */ }",
"public void setAction(String action) {\n this.action = action;\n }",
"public void setAction(String action) {\n this.action = action;\n }",
"public void setType(int type) throws DBException {\n _type = type;\n }",
"public void setType(int type) throws DBException {\n _type = type;\n }",
"public void setType(int type) {\n type_ = type;\n }",
"@ApiModelProperty(required = true, value = \"The action type to be applied. When UPDATE_INTEREST_SETTINGS action type is used, all the existing deposit accounts will be updated with the latest interest-related fields at the end of day job execution\")\n @JsonProperty(JSON_PROPERTY_ACTION)\n @JsonInclude(value = JsonInclude.Include.ALWAYS)\n\n public ActionEnum getAction() {\n return action;\n }",
"public void setType(int type)\n {\n synchronized (monitor())\n {\n check_orphaned();\n org.apache.xmlbeans.SimpleValue target = null;\n target = (org.apache.xmlbeans.SimpleValue)get_store().find_attribute_user(TYPE$2);\n if (target == null)\n {\n target = (org.apache.xmlbeans.SimpleValue)get_store().add_attribute_user(TYPE$2);\n }\n target.setIntValue(type);\n }\n }",
"public void setTYPE(String TYPE) {\n this.TYPE = TYPE;\n }",
"public void setAction(String action) {\n\t\tthis.action = action;\n\t}",
"public void setActionInfo(String actionInfo);",
"public void setType(int type) {\r\n this.type = type;\r\n }",
"public void setType(int type) {\r\n this.type = type;\r\n }",
"public void setTransactionType(int transactionChoice);",
"public void setAction(A action) {\r\n\t\tthis.action = action;\r\n\t}",
"AutodiscAction(final AutodiscActionType actionType, final T content)\n {\n this.actionType = actionType;\n this.content = content;\n }",
"public void m12739a() {\n C2756f.m12786a(this);\n Bundle bundle = new Bundle();\n bundle.putInt(\"com.tonyodev.fetch.action_type\", 325);\n FetchService.m12646a(this.f9046c, bundle);\n }",
"public void setType(int t){\n this.type = t;\n }",
"public void setAction(int value) {\n this.action = value;\n }",
"public void xsetType(org.apache.xmlbeans.XmlInt type)\n {\n synchronized (monitor())\n {\n check_orphaned();\n org.apache.xmlbeans.XmlInt target = null;\n target = (org.apache.xmlbeans.XmlInt)get_store().find_attribute_user(TYPE$2);\n if (target == null)\n {\n target = (org.apache.xmlbeans.XmlInt)get_store().add_attribute_user(TYPE$2);\n }\n target.set(type);\n }\n }",
"public void setType(int a_type) {\n\t\tthis.m_type = a_type;\n\t}",
"public void updateActionItem() throws SQLException {\n actionItemClass obj = new actionItemClass();\n obj.updateActionItem(this);\n \n }",
"public void setType(int type) {\n this.type = type;\n }",
"Action getType();",
"public void setAction(String action) {\n\t\tthis.action.set(action);\n\t}",
"@Override\n\tpublic void setType(int type) {\n\t\t_dmGtStatus.setType(type);\n\t}",
"public void setType(int type) {\n\t\tthis.type = type;\n\t}",
"public void setType (int type) {\n this.type = type;\n }",
"public void setType (int type) {\n this.type = type;\n }",
"public void setType(int type)\n\t{\n\t\tthis.type = type;\n\t}",
"public void setAction(Action action) {\n this.action = action;\n }",
"public void setType(int pType) {\n mType = pType;\n }",
"public String updateContactTypeStatement() {\n\t\treturn \"UPDATE CONTACTSTYPES SET (CONTACT_TYPE) = ? WHERE ID = ?\";\n\t}",
"public void setType(String type)\r\n {\r\n this.mType = type;\r\n }",
"public void setType(type type) {\r\n\t\tthis.Type = type;\r\n\t}",
"private void setType(String type) {\n mType = type;\n }",
"@Override\n\tpublic void setType(int type) {\n\t\t_expandoColumn.setType(type);\n\t}",
"public void setExecuteAction(Action action) {\n this.data.setExecuteAction(action);\n }",
"public void setType( int type ) {\r\n typ = type;\r\n }",
"public void setType(int t) {\r\n\t\ttype = t;\r\n\t}",
"public ActionType getActionType(com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.abedmnlib_hva.v1.ActionType res){\n\t\tActionType actionType = new ActionType();\n\t\t\n\t\tactionType.setActionCode( res.getActionCode() );\n\t\tactionType.setDescription( res.getDescription() );\n\t\t\n\t\treturn actionType;\n\t}",
"public void setType(String type) {\n this.type = type;\n }",
"public void setType(String type){\n \tthis.type = type;\n }",
"public void setActionId(Long actionId) {\n this.actionId = actionId;\n }",
"@Override\n\tpublic void setType(java.lang.String type) {\n\t\t_dlSyncEvent.setType(type);\n\t}",
"public void setAction(String str) {\n\t\taction = str;\n\t}",
"public void setType(String type) {\n m_Type = type;\n }",
"public void setType(String type) {\n\t this.mType = type;\n\t}",
"public Object execute(OcmAction<T> action, boolean autoSave) throws DataAccessException;",
"void setType(Type type)\n {\n this.type = type;\n }",
"protected void setCode(UiAction uiAction, ResultSet rs, int rowNumber) throws SQLException{\n\t\t\n\t\tString code = rs.getString(UiActionTable.COLUMN_CODE);\n\t\t\n\t\tif(code == null){\n\t\t\t//do nothing when nothing found in database\n\t\t\treturn;\n\t\t}\n\t\t\n\t\tuiAction.setCode(code);\n\t}",
"public void setAction(GrouperActivemqPermissionAction action1) {\r\n this.action = action1;\r\n }",
"public void setUserType(String type) {\r\n switch(type) {\r\n case (\"admin\"): \r\n this.userType = 0;\r\n break;\r\n case (\"seller\"):\r\n this.userType = 1;\r\n break;\r\n case (\"buyer\"):\r\n this.userType = 2;\r\n break;\r\n \r\n }\r\n }",
"void setType(String type) {\n this.type = type;\n }",
"StateClass(String action) {\r\n setAccountAction(action); \r\n }",
"public void setType(String type) \n {\n this.type = type;\n }",
"public void setJoinAction(IAction value) \n\t{\t\n\t\tjoinAction = value;\n\t}",
"public void setType(String type){\n this.type = type;\n }",
"public Target setActionClass(Class<?> action) {\n this.action = action;\n return this;\n }",
"public void setType(String type) {\r\n this.type = type;\r\n }",
"public void setType(Integer type) {\r\n\t\tthis.type = type;\r\n\t}",
"public void setOperatetype(Long operatetype) {\n this.operatetype = operatetype;\n }",
"public void setType(Object type)\r\n {\r\n\tthis.type = type;\r\n }",
"public void setType(Type type){\n\t\tthis.type = type;\n\t}",
"public com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.abedmnlib_hva.v1.ActionType getActionTypeReq(ActionType actionType){\n\t\tcom.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.abedmnlib_hva.v1.ActionType actionTypeReq =\n\t\t\tnew com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.abedmnlib_hva.v1.ActionType();\n\t\t\n\t\tactionTypeReq.setActionCode( actionType.getActionCode() );\n\t\tactionTypeReq.setDescription( actionType.getDescription() );\n\t\t\n\t\treturn actionTypeReq;\n\t}",
"public void setAction(String action)\n {\n // Check property\n if (action == null) \n { \n action = \"\"; \n }\n \n // If the specified context path already contains\n // a query string, append an ampersand character\n // for further parameter concatenation\n if (action.indexOf(\"=\") != -1)\n {\n action = action + \"&\";\n }\n else\n {\n action = action + \"?\";\n }\n \n // Set property\n this.action = action;\n }",
"public void change_type(int type_){\n\t\ttype = type_;\n\t\tif(type != 0)\n\t\t\toccupe = 1;\n\t}",
"public void setactioncode(Integer value) {\n setAttributeInternal(ACTIONCODE, value);\n }",
"public void setType(String type) {\r\n this.type = type;\r\n }",
"public setAcl_args setAction(TSetAclAction action) {\n this.action = action;\n return this;\n }",
"private void setUserAction(User user, ActionTypeName actionTypeName) {\r\n\t\tList<UserAction> actionList;\r\n\r\n\t\tLOG.info(\"Se entra en el metodo setUserAction\");\r\n\r\n\t\tLOG.info(new StringBuffer(\"Se recibe el usuario: \").append(user\r\n\t\t\t\t.getName()));\r\n\t\tLOG.info(new StringBuffer(\"Se recibe la accion: \")\r\n\t\t\t\t.append(actionTypeName));\r\n\r\n\t\tactionList = (List<UserAction>) user.getActions();\r\n\t\tif (actionList == null) {\r\n\t\t\tactionList = new ArrayList<UserAction>();\r\n\t\t}\r\n\r\n\t\tUserAction action = new UserAction();\r\n\r\n\t\tLOG.info(new StringBuffer(\"Se crea una nueva accion para el usuario: \")\r\n\t\t\t\t.append(user.getName()));\r\n\r\n\t\taction.setUser(user);\r\n\t\tActionType actionType = new ActionType();\r\n\r\n\t\tLOG.info(new StringBuffer(\"Se añade la accion: \")\r\n\t\t\t\t.append(actionTypeName));\r\n\r\n\t\tactionType.setName(actionTypeName);\r\n\r\n\t\tLOG.info(new StringBuffer(\"La accion es del tipo: \").append(actionType\r\n\t\t\t\t.getName()));\r\n\r\n\t\taction.setActionType(actionType);\r\n\t\tactionList.add(action);\r\n\r\n\t\tLOG.info(new StringBuffer(\"La lista de usuario actua es: \")\r\n\t\t\t\t.append(actionList));\r\n\r\n\t\tuser.setActions(actionList);\r\n\t}",
"public void setAction(String action) {\n this.action = action == null ? null : action.trim();\n }",
"public void setType(String type) {\r\n this.type = type;\r\n }",
"public void setType(String type) {\r\n this.type = type;\r\n }",
"public void setType(String type) {\r\n this.type = type;\r\n }",
"public void setType(String type) {\r\n this.type = type;\r\n }",
"public void setExaminationType(ExaminationType_type1 param){\n \n this.localExaminationType=param;\n \n\n }",
"public void setType(String type) {\r\n\t\tthis.type=type;\r\n\t}",
"public void setAct (jkt.hms.masters.business.MasEmployee act) {\n\t\tthis.act = act;\n\t}",
"public void setType( String type )\n {\n this.type = type;\n }",
"public void setType(Integer type) {\n\t\tthis.type = type;\n\t}"
]
| [
"0.6159836",
"0.5747661",
"0.5665965",
"0.5647385",
"0.5572517",
"0.54976124",
"0.5487883",
"0.53179055",
"0.5226472",
"0.51910305",
"0.51563144",
"0.5149975",
"0.51273674",
"0.5114153",
"0.5112351",
"0.510638",
"0.50819033",
"0.5067338",
"0.5023042",
"0.4981529",
"0.49769408",
"0.49769408",
"0.49754393",
"0.49754393",
"0.4964015",
"0.4956205",
"0.49406835",
"0.4922439",
"0.49174312",
"0.49086383",
"0.4904312",
"0.4904312",
"0.49005738",
"0.48934957",
"0.48848698",
"0.488333",
"0.48578435",
"0.48347533",
"0.48326206",
"0.48109612",
"0.48087695",
"0.4806883",
"0.48068792",
"0.4800051",
"0.47862247",
"0.4785969",
"0.47837988",
"0.47837988",
"0.47776234",
"0.47584915",
"0.47583264",
"0.47356105",
"0.47343647",
"0.47275886",
"0.47230908",
"0.47205576",
"0.4711723",
"0.47064632",
"0.46788654",
"0.46660024",
"0.46632987",
"0.46599454",
"0.46469358",
"0.46407834",
"0.46286702",
"0.4624129",
"0.4618627",
"0.4612359",
"0.46120828",
"0.4599869",
"0.45980462",
"0.4594114",
"0.45940158",
"0.45818788",
"0.4564031",
"0.45608014",
"0.45542935",
"0.45489666",
"0.45480418",
"0.45420086",
"0.45384213",
"0.4536624",
"0.45360154",
"0.4534298",
"0.45331427",
"0.45322838",
"0.4530842",
"0.45226127",
"0.4521404",
"0.45207864",
"0.45207196",
"0.45103356",
"0.45103356",
"0.45103356",
"0.45103356",
"0.45088145",
"0.4507641",
"0.45020205",
"0.44953075",
"0.4493682"
]
| 0.60824764 | 1 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.LOCK_ID | public String getLockId() {
return lockId;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"public Long getLockNum() {\n return lockNum;\n }",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"long getLockOwnersID(String uuid) throws DatabaseException;",
"public Dao<Lock, Integer> getLockDao() throws SQLException {\n\t\tif (lockDao == null) {\n\t\t\tlockDao = getDao(Lock.class);\n\t\t}\n\t\treturn lockDao;\n\t}",
"public Long getOtherLockNum() {\n return otherLockNum;\n }",
"private Integer getLockFromId(long lockId)\n throws IOException {\n if(lockId == -1L) {\n return null;\n }\n String lockName = String.valueOf(lockId);\n Integer rl = null;\n synchronized(rowlocks) {\n rl = rowlocks.get(lockName);\n }\n if(rl == null) {\n throw new IOException(\"Invalid row lock\");\n }\n this.leases.renewLease(lockName);\n return rl;\n }",
"public String getLockType() {\n return this.lockType;\n }",
"public String getLockUser() {\n return lockUser;\n }",
"public String isLockedFor() {\n return (lockId == null ? \"\" : lockId);\n }",
"public long getLockStatus() {\r\n return lockStatus;\r\n }",
"public String getLockedUserId() {\n\t\treturn lockedUserId;\n\t}",
"@Transient\n\tpublic long getTransactionIdLong() {\n\t\treturn mTransactionIdLong;\n\t}",
"public long getTransactionid() {\n return transactionid;\n }",
"public long getTransactionID() {\r\n return transactionID;\r\n }",
"@ManyToOne\n\t@JoinColumn(name=\"LockStatus\", nullable=false)\n\t@Fetch(FetchMode.SELECT)\n\t@NotFound(action=NotFoundAction.IGNORE)\n\tpublic AccessStatus getLockStatus() {\n\t\treturn this.lockStatus;\n\t}",
"public int getLockon() {\r\n return lockon;\r\n }",
"public int getLockAddress() {\n\t\treturn 0;\n\t}",
"private String getSingleLockSBRStmt() {\n\n if (null == mSingleLockStmt) {\n initClauses();\n mSingleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE s.EUID = ? AND s.REVISIONNUMBER = ? \" + mForUpdateClause;\n }\n\n return mSingleLockStmt;\n }",
"public long getPrimaryKey() {\n return _sTransaction.getPrimaryKey();\n }",
"public RuntimeExceptionDao<Lock, Integer> getLockDataDao() {\n\t\tif (lockRuntimeDao == null) {\n\t\t\tlockRuntimeDao = getRuntimeExceptionDao(Lock.class);\n\t\t}\n\t\treturn lockRuntimeDao;\n\t}",
"final public Lock test_get_lock() {\r\n\t\treturn lock_;\r\n\t}",
"public Lock getLock();",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"Lock getLock(String lockName);",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"long getLoginId();",
"long getLoginId();",
"long getLoginId();",
"protected String generateLockId() {\n return AkkaUtils.nextId();\n }",
"public Long getBlockroomid()\n {\n return blockroomid; \n }",
"long getOwnerIdLong();",
"String getLockOwner();",
"protected String getLockManagerName() {\n return getName();\n }",
"public Lock getLock() {\n return lock;\n }",
"public java.lang.String getXlock () {\n\t\treturn xlock;\n\t}",
"public void setLockId(String lockId) {\n this.lockId = lockId;\n }",
"public Integer getLoginId() {\n return loginId;\n }",
"public Long getRoomstlogid()\n {\n return roomstlogid; \n }",
"public Integer getRowId() {\n return rowId;\n }",
"public Date getLockTime() {\n\t\treturn lockTime;\n\t}",
"public java.lang.Long getId();",
"private Lock getLock(int tid, int varIndex) {\n if (_lockTable.containsKey(varIndex)) {\n List<Lock> lockList = _lockTable.get(varIndex);\n for (Lock lc : lockList) {\n if (lc.getTranId() == tid) {\n return lc;\n }\n }\n }\n return null;\n }",
"String getTransactionID();",
"@Override\n\tpublic long getPrimaryKey() {\n\t\treturn _dlSyncEvent.getPrimaryKey();\n\t}",
"@Override\n\tpublic Lock getLock() {\n\t\treturn this.lock;\n\t}",
"public Integer getLoginid() {\n return loginid;\n }",
"long getTxid();",
"public Long getTransactionId() {\n return this.transactionId;\n }",
"@Transient\n\tpublic long getRefundPaymentTransactionIdLong() {\n\t\tif (mRefundPaymentTransactionIdLong == -1) {\n\t\t\tif (mRefundPaymentTransactionId != null) {\n\t\t\t\ttry {\n\t\t\t\t\tmRefundPaymentTransactionIdLong = Long.parseLong(mRefundPaymentTransactionId);\n\t\t\t\t}\n\t\t\t\tcatch (NumberFormatException ne) {\n\t\t\t\t\t// nothing\n\t\t\t\t\tmRefundPaymentTransactionIdLong = -2;\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn mRefundPaymentTransactionIdLong;\n\t}",
"@Override\n public int getTxTimeoutInMillis() {\n return Globals.lockingTimeout;\n }",
"Long getDbId();",
"public int getTransactionID() {\r\n return transactionID;\r\n }",
"public Long getReservationroomid()\n {\n return reservationroomid; \n }",
"public java.lang.Long getUsua_id();",
"static String getLockNodeIdFromName(String lockNodeName) {\n\t\tint lastPathSep = lockNodeName.lastIndexOf(\"/\");\n\t\tif (lastPathSep != -1)\n\t\t\treturn lockNodeName.substring(lastPathSep+1);\n\t\telse\n\t\t\treturn lockNodeName;\n\t}",
"public Long getRoomstid()\n {\n return roomstid; \n }",
"public void setLockKey( Long lockKey ) {\n this.lockKey = lockKey;\n }",
"public Long getLock_latency() {\n return lock_latency;\n }",
"public int getLoginId() {\n return loginId;\n }",
"public java.lang.Long getIdentificador()\r\n {\r\n return this.identificador;\r\n }",
"SoftLock findSoftLockById(SoftLockID softLockId);",
"public Object getLock() {\n return dataLock;\n }",
"public int geti_ordertrx_temp_ID();",
"public int getId() {\n return txId;\n }",
"public static int getRowIdFromDb() {\n // get DB helper\n mDbHelper = PointOfSaleDb.getInstance(context);\n\n // Each row in the list stores amount and date of transaction -- retrieves history from DB\n SQLiteDatabase db = mDbHelper.getReadableDatabase();\n\n // get the following columns:\n String[] tableColumns = { PointOfSaleDb.TRANSACTIONS_COLUMN_CREATED_AT,\n \"_ROWID_\"};// getting also _ROWID_ to save the txID after getting the response\n\n String sortOrder = PointOfSaleDb.TRANSACTIONS_COLUMN_CREATED_AT + \" DESC\";\n Cursor c = db.query(PointOfSaleDb.TRANSACTIONS_TABLE_NAME, tableColumns, null, null, null, null, sortOrder);\n int rowId=0;\n if(c.moveToFirst()) {\n rowId = Integer.parseInt(c.getString(1));\n }\n return rowId;\n }",
"public Long getTransactionId() {\n\t\treturn transactionId;\n\t}",
"public Long getRowKey() {\n return (Long) getAttributeInternal(ROWKEY);\n }",
"public long getTransactionId();",
"String get_row_id()\n {\n return row_id;\n }",
"java.lang.String getTxId();",
"public final long lock() {\n explicitlyLocked = true;\n return byteBase.longLockPointer();\n }",
"String getID(String pid) {\n try {\n Cursor cursor = selectTable(makeMax(TableColumn.ChecklistTable.CID), makeCondition(TableColumn.ChecklistTable.PID, pid));\n cursor.moveToFirst();\n String id = cursor.getString(0);\n cursor.close();\n return id;\n } catch (SQLiteException sql_ex) {\n Log.e(\"SQL\", sql_ex.toString());\n } catch (CursorIndexOutOfBoundsException cur_ex) {\n Log.e(\"SQL\", cur_ex.toString());\n }\n return null;\n }",
"long getTruckId();",
"public int getCurrentOperationId(){\n int nmr = 1;\n operationLock.lock();\n try (\n Statement s = rawDataSource.getConnection().createStatement(ResultSet.TYPE_SCROLL_INSENSITIVE, ResultSet.CONCUR_READ_ONLY);\n ResultSet res = s.executeQuery(\n \"SELECT OP_ID FROM APP.OPERATIONS ORDER BY OP_ID ASC\")) {\n\n if (res.last()) {\n nmr = Integer.parseInt(res.getString(\"OP_ID\")) + 1;\n }\n } catch (SQLException ex) {\n return nmr;\n }\n\n operationLock.unlock();\n return nmr;\n }",
"public Integer getLogid() {\n return logid;\n }",
"Long getId();",
"Long getId();",
"Long getId();",
"int getRowId();",
"int getRowId();",
"int getRowId();",
"int getRowId();",
"int getRowId();",
"public Long getEventID()\n/* */ {\n/* 111 */ return this.eventID;\n/* */ }",
"public Integer getTicketId() {\r\n return ticketId;\r\n }",
"public BookingLockDetails getBookingLockDetails(com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.bookinglockdetails.v1.BookingLockDetails res){\n\t\tBookingLockDetails bookingLockDetails = new BookingLockDetails();\n\t\t\n\t\tbookingLockDetails.setBookingNo( res.getBookingNo() );\n\t\tbookingLockDetails.setLockId( res.getLockId() );\n\t\tbookingLockDetails.setLockMessage( res.getLockMessage() );\n\t\tif( res.isAlreadyLocked() != null ){\n\t\t\tbookingLockDetails.setAlreadyLocked( res.isAlreadyLocked().booleanValue() );\n\t\t}\n\t\tif( res.isAdmin() != null ){\n\t\t\tbookingLockDetails.setAdmin( res.isAdmin().booleanValue() );\n\t\t}\n\t\t\n\t\treturn bookingLockDetails;\n\t}",
"public long getID(String transactionUID){\n long id = -1;\n Cursor c = mDb.query(TransactionEntry.TABLE_NAME,\n new String[]{TransactionEntry._ID},\n TransactionEntry.COLUMN_UID + \"='\" + transactionUID + \"'\",\n null, null, null, null);\n if (c != null) {\n if (c.moveToFirst()) {\n id = c.getLong(0);\n }\n c.close();\n }\n return id;\n }",
"public long getTransactionId() {\n return _sTransaction.getTransactionId();\n }",
"public Integer getManagerId() {\n return managerId;\n }",
"final long internalLongLock() {\n return byteBase.longLockPointer();\n }",
"public BigDecimal getLstCustManagerId() {\n return lstCustManagerId;\n }",
"public String getTransactionID() {\n\t return this.transactionID;\n\t}",
"private long getReserveRecNo() {\n\t\tfinal int selectedRow = this.clientUI.getSelectedRowNo();\n\t\treturn this.model.getRecNo(selectedRow);\n\t}",
"public Long getOid() {\n return tid;\n }",
"public long snapshotId() {\n return snapshotId;\n }",
"private int getRID() throws SQLException {\n\t\tResultSet result = getRidStatement.executeQuery();\n\t\tif (result.next()) {\n\t\t\tint out = result.getInt(1);\n\t\t\tresult.close();\n\t\t\tif (DEBUG) {\n\t\t\t\tSystem.out.println(\"getRID: \"+out+\"\\n\");\n\t\t\t}\n\t\t\treturn out;\n\t\t} else {\n\t\t\tif (DEBUG) {\n\t\t\t\tSystem.out.println(\"getRID: \"+0+\"\\n\");\n\t\t\t}\n\t\t\treturn 0;\n\t\t}\n\t}",
"public String fetchPrimaryKey(){\n\t\treturn primaryKey;\n\t}"
]
| [
"0.677609",
"0.64829946",
"0.62959033",
"0.5993747",
"0.58650756",
"0.58127683",
"0.58007306",
"0.5701492",
"0.56778556",
"0.56680894",
"0.5618233",
"0.5494253",
"0.54736423",
"0.5462675",
"0.54532677",
"0.541606",
"0.5348849",
"0.5340242",
"0.53170633",
"0.53068393",
"0.530288",
"0.5286042",
"0.5268859",
"0.5262915",
"0.5262915",
"0.5262915",
"0.5251914",
"0.5240555",
"0.52336705",
"0.52336705",
"0.52336705",
"0.52194494",
"0.52192503",
"0.5217078",
"0.5214013",
"0.5209062",
"0.5205588",
"0.51758546",
"0.5172645",
"0.51724446",
"0.51724356",
"0.51706517",
"0.51479894",
"0.5146759",
"0.5146417",
"0.51459897",
"0.51397693",
"0.5121846",
"0.5121085",
"0.51190025",
"0.5114772",
"0.51112115",
"0.5105963",
"0.5101359",
"0.5100073",
"0.5095633",
"0.50493646",
"0.5044419",
"0.5012082",
"0.50035006",
"0.49969316",
"0.49936163",
"0.49836794",
"0.4978553",
"0.49769625",
"0.49755108",
"0.49640915",
"0.4963027",
"0.49626103",
"0.49539396",
"0.49434084",
"0.49430278",
"0.49352995",
"0.4934105",
"0.49319193",
"0.49310216",
"0.4917799",
"0.49053404",
"0.49039575",
"0.49039575",
"0.49039575",
"0.49034092",
"0.49034092",
"0.49034092",
"0.49034092",
"0.49034092",
"0.49012294",
"0.49004197",
"0.48977405",
"0.48908216",
"0.48893702",
"0.48843634",
"0.4875165",
"0.48713684",
"0.4870546",
"0.48691452",
"0.48653278",
"0.48616296",
"0.485816",
"0.48578644"
]
| 0.6838373 | 0 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.LOCK_ID | public void setLockId(String lockId) {
this.lockId = lockId;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setLockKey( Long lockKey ) {\n this.lockKey = lockKey;\n }",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"public void setLockUserid(String lockUserid) {\n\t\tthis.lockUserid = lockUserid == null ? null : lockUserid.trim();\n\t}",
"public void setLockStatus(long lockStatus) {\r\n this.lockStatus = lockStatus;\r\n }",
"public String getLockId() {\n return lockId;\n }",
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"public void setTransactionID(long value) {\r\n this.transactionID = value;\r\n }",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_dlSyncEvent.setPrimaryKey(primaryKey);\n\t}",
"public void setTransactionid(long value) {\n this.transactionid = value;\n }",
"public void setOtherLockNum(Long otherLockNum) {\n this.otherLockNum = otherLockNum;\n }",
"public Long getLockNum() {\n return lockNum;\n }",
"public void setBlockroomid(Long newVal) {\n if ((newVal != null && this.blockroomid != null && (newVal.compareTo(this.blockroomid) == 0)) || \n (newVal == null && this.blockroomid == null && blockroomid_is_initialized)) {\n return; \n } \n this.blockroomid = newVal; \n blockroomid_is_modified = true; \n blockroomid_is_initialized = true; \n }",
"public void setSdSeminarID(long value){\n\t\tthis.m_bIsDirty = (this.m_bIsDirty || (value != this.m_lSdSeminarID));\n\t\tthis.m_lSdSeminarID=value;\n\t}",
"public LockImpl(long id) {\n\t\tthis.id = id;\n\t}",
"public void setLockFlag(Integer aLockFlag) {\n lockFlag = aLockFlag;\n }",
"public void setLockFlag(Integer aLockFlag) {\n lockFlag = aLockFlag;\n }",
"public void setLockFlag(Integer aLockFlag) {\n lockFlag = aLockFlag;\n }",
"public void setPrimaryKey(long primaryKey) {\n _sTransaction.setPrimaryKey(primaryKey);\n }",
"public void setLockUser(String lockUser) {\n this.lockUser = lockUser == null ? null : lockUser.trim();\n }",
"@Override\n public void setLockOwner(Object lockOwner) {\n }",
"protected void setId(EmployeeLeave employeeLeave, ResultSet rs, int rowNumber) throws SQLException{\n\t\tString id = rs.getString(EmployeeLeaveTable.COLUMN_ID);\n\t\tif(id == null){\n\t\t\t//do nothing when nothing found in database\n\t\t\treturn;\n\t\t}\n\t\n\t\temployeeLeave.setId(id);\n\t}",
"public void setRoomstid(Long newVal) {\n if ((newVal != null && this.roomstid != null && (newVal.compareTo(this.roomstid) == 0)) || \n (newVal == null && this.roomstid == null && roomstid_is_initialized)) {\n return; \n } \n this.roomstid = newVal; \n roomstid_is_modified = true; \n roomstid_is_initialized = true; \n }",
"private void setLock(int tid, int varIndex, Lock.Type type) {\n List<Lock> lockList = null;\n if (_lockTable.containsKey(varIndex)) {\n lockList = _lockTable.get(varIndex);\n lockList.add(new Lock(tid, type));\n } else {\n lockList = new ArrayList<Lock>();\n lockList.add(new Lock(tid, type));\n _lockTable.put(varIndex, lockList);\n }\n }",
"void setLong(int index, long value) throws SQLException;",
"public void setReservationroomid(Long newVal) {\n if ((newVal != null && this.reservationroomid != null && (newVal.compareTo(this.reservationroomid) == 0)) || \n (newVal == null && this.reservationroomid == null && reservationroomid_is_initialized)) {\n return; \n } \n this.reservationroomid = newVal; \n reservationroomid_is_modified = true; \n reservationroomid_is_initialized = true; \n }",
"public void SetIsLock(boolean isLock)\n {\n this._lock = isLock;\n }",
"public void setEventID(Long eventID)\n/* */ {\n/* 123 */ this.eventID = eventID;\n/* */ }",
"private void setRoomId(long value) {\n \n roomId_ = value;\n }",
"public void setTransactionID(int tid) {\n m_TransactionID = tid;\n // setChanged(true);\n }",
"@Override\n public void setTxTimeoutInMillis(int ms) {\n Globals.lockingTimeout = ms;\n }",
"public void setLocksInDb(String value)\n\t{\n\t\tm_locksInDb = new Boolean(value).booleanValue();\n\t}",
"public void setRoomstlogid(Long newVal) {\n if ((newVal != null && this.roomstlogid != null && (newVal.compareTo(this.roomstlogid) == 0)) || \n (newVal == null && this.roomstlogid == null && roomstlogid_is_initialized)) {\n return; \n } \n this.roomstlogid = newVal; \n roomstlogid_is_modified = true; \n roomstlogid_is_initialized = true; \n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_userSync.setPrimaryKey(primaryKey);\n\t}",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setWriteLockValue(Vector primaryKey, Object writeLockValue) {\n CacheKey cacheKey = getCacheKey(primaryKey);\n\n if (cacheKey != null) {\n //lock/release the cache key during the lock value updating\n cacheKey.acquire();\n cacheKey.setWriteLockValue(writeLockValue);\n cacheKey.release();\n }\n }",
"void setLoginId(long loginId);",
"void setLoginId(long loginId);",
"void setLoginId(long loginId);",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_dmGtStatus.setPrimaryKey(primaryKey);\n\t}",
"public void setId(Long value) {\r\n this.id = value;\r\n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_state.setPrimaryKey(primaryKey);\n\t}",
"public static void setLockManagerActorRef(ActorRef lockManager) {\n\t\tglobalLockManagerActorRef = lockManager;\n\t}",
"void setTransactionId( long txId )\n {\n this.transactionId = txId;\n }",
"public void setSPEventID(Long SPEventID)\n/* */ {\n/* 76 */ this.SPEventID = SPEventID;\n/* */ }",
"public void setBundleID(long param){\n localBundleIDTracker = true;\n \n this.localBundleID=param;\n \n\n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_employee.setPrimaryKey(primaryKey);\n\t}",
"public void setSequenceId(long sequence_id)\n {\n sequence_id_ = sequence_id;\n }",
"public void setLockedUserId(String lockedUserId) {\n\t\tthis.lockedUserId = lockedUserId;\n\t}",
"public void setId(long param) {\n localIdTracker = param != java.lang.Long.MIN_VALUE;\r\n\r\n this.localId = param;\r\n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_second.setPrimaryKey(primaryKey);\n\t}",
"public void setBlockroomid(long newVal) {\n setBlockroomid(new Long(newVal));\n }",
"public void setLockTime(Date lockTime) {\n\t\tthis.lockTime = lockTime;\n\t}",
"public void setId(Long value) {\n this.id = value;\n }",
"public void setPrimaryKey(long primaryKey) {\n this.primaryKey = primaryKey;\n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_candidate.setPrimaryKey(primaryKey);\n\t}",
"public void seti_ordertrx_temp_ID (int i_ordertrx_temp_ID);",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_userTracker.setPrimaryKey(primaryKey);\n\t}",
"public void setRoomstid(long newVal) {\n setRoomstid(new Long(newVal));\n }",
"public void setLock_latency(Long lock_latency) {\n this.lock_latency = lock_latency;\n }",
"public void setInstrumentedWorkExecutorID(java.lang.Long value) {\n __getInternalInterface().setFieldValue(INSTRUMENTEDWORKEXECUTORID_PROP.get(), value);\n }",
"public void setLong(String parName, long parVal) throws HibException;",
"public void setInstrumentedWorkExecutorID(java.lang.Long value) {\n __getInternalInterface().setFieldValue(INSTRUMENTEDWORKEXECUTORID_PROP.get(), value);\n }",
"public void setId(Long id)\n/* */ {\n/* 66 */ this.id = id;\n/* */ }",
"@Override\n\tpublic void setRowId(int parameterIndex, RowId x) throws SQLException {\n\t\t\n\t}",
"public final synchronized void setOpLock(OpLockDetails oplock)\n\t\tthrows ExistingOpLockException {\n\n\t\tif ( m_oplock == null)\n\t\t\tm_oplock = oplock;\n\t\telse\n\t\t\tthrow new ExistingOpLockException();\n\t}",
"public void setLong(int parameterIndex, long x) throws SQLException {\n currentPreparedStatement.setLong(parameterIndex, x);\n\n }",
"@Override\n public final void setItsId(final Long pId) {\n //stub\n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_buySellProducts.setPrimaryKey(primaryKey);\n\t}",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_esfTournament.setPrimaryKey(primaryKey);\n\t}",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_changesetEntry.setPrimaryKey(primaryKey);\n\t}",
"protected void setIdentity(long identity)\n\t{\n\t\tthis.identity=new Long(identity);\n\t}",
"private Locks() {\n\t\tlockId = ObjectId.get().toString();\n\t}",
"public Long getOtherLockNum() {\n return otherLockNum;\n }",
"public void setStudentID(long studentID);",
"public String isLockedFor() {\n return (lockId == null ? \"\" : lockId);\n }",
"long getLockOwnersID(String uuid) throws DatabaseException;",
"public void setPrimaryKey(long primaryKey) {\n\t\t_forumUser.setPrimaryKey(primaryKey);\n\t}",
"public String getLockUser() {\n return lockUser;\n }",
"public void setTransactionId(Long transactionId) {\r\n this.transactionId = transactionId;\r\n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_contentupdate.setPrimaryKey(primaryKey);\n\t}",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_expandoColumn.setPrimaryKey(primaryKey);\n\t}",
"public void setMedioTransactionalID(int value) {\r\n this.medioTransactionalID = value;\r\n }",
"public void setPrimaryKey(long primaryKey) {\n\t\t_tempNoTiceShipMessage.setPrimaryKey(primaryKey);\n\t}"
]
| [
"0.62645775",
"0.62131774",
"0.58275545",
"0.5824624",
"0.58147967",
"0.58078486",
"0.5692614",
"0.55449694",
"0.5398705",
"0.53773624",
"0.53750724",
"0.53571904",
"0.53398764",
"0.52649826",
"0.52567536",
"0.5256732",
"0.5256732",
"0.5256732",
"0.5238114",
"0.52066845",
"0.5189071",
"0.5173638",
"0.5165189",
"0.5145233",
"0.5138493",
"0.51329976",
"0.5119408",
"0.5117358",
"0.5112978",
"0.50858057",
"0.50791126",
"0.50684315",
"0.50640017",
"0.5041049",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5038638",
"0.5034504",
"0.5024099",
"0.5024099",
"0.5024099",
"0.50176316",
"0.5009783",
"0.5003135",
"0.49958384",
"0.4990737",
"0.4982693",
"0.4967233",
"0.4966612",
"0.49635997",
"0.4961764",
"0.49460483",
"0.4940956",
"0.49254978",
"0.49177337",
"0.49165097",
"0.4896045",
"0.48874366",
"0.4885902",
"0.48756275",
"0.48709896",
"0.48674312",
"0.48659873",
"0.48633215",
"0.4863228",
"0.486115",
"0.48556468",
"0.48430842",
"0.4841443",
"0.48378903",
"0.48332655",
"0.4831906",
"0.48273546",
"0.48261622",
"0.48251268",
"0.48237827",
"0.48137146",
"0.48117328",
"0.48109895",
"0.479619",
"0.479385",
"0.47937074",
"0.4791541",
"0.47909838",
"0.47809505",
"0.47785687"
]
| 0.62133324 | 1 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.USER_ID | public String getUserId() {
return userId;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Long getUserid() {\r\n return userid;\r\n }",
"Long getUserId();",
"public Integer getUser_id() {\n\t\treturn user_id;\n\t}",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"public long getUserId();",
"public long getUserId();",
"public long getUserId();",
"public long getUserId();",
"public String getUserId() {\n\t\treturn _userLoginId;\n\t}",
"public Long getUserId()\n/* */ {\n/* 73 */ return this.userId;\n/* */ }",
"public Long getUserId() {\n return this.user.getId();\n }",
"public Integer getUserID() {\n return userID;\n }",
"public Integer getIdUser() {\r\n\t\treturn idUser;\r\n\t}",
"long getUserId();",
"long getUserId();",
"public Long getUserId() {\r\n return userId;\r\n }",
"public Long getUserId() {\r\n return userId;\r\n }",
"public Long getUserId() {\r\n return userId;\r\n }",
"public Long getUser() {\n return user;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public Integer getUserid() {\n return userid;\n }",
"public long getUserId() {\r\n return userId;\r\n }",
"java.lang.String getUserId();",
"java.lang.String getUserId();",
"java.lang.String getUserId();",
"Integer getUserId();",
"public Integer getUserid() {\r\n\t\treturn userid;\r\n\t}",
"public Long getUserId() {\r\n\t\treturn userId;\r\n\t}",
"public int getUserId()\r\n\t{\r\n\t\treturn this.userId;\r\n\t}",
"public long getUserId() {\n return userId;\n }",
"public Integer getUserId() {\r\n return userId;\r\n }",
"public Integer getUserId() {\r\n return userId;\r\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Long getUserId() {\n return userId;\n }",
"public Integer getUserid() {\n\t\treturn this.userid;\n\t}",
"public int getIduser() {\n return iduser;\n }",
"public Long getUserId() {\n\t\treturn userId;\n\t}",
"public int getIdUser() {\n return idUser;\n }",
"public int getIdUser() {\n return idUser;\n }",
"@Override\n\tpublic long getUserId() {\n\t\treturn _employee.getUserId();\n\t}",
"public Integer getUserId() {\r\n\t\treturn userId;\r\n\t}",
"public Integer getUserId() {\r\n\t\treturn userId;\r\n\t}",
"public Integer getUserId() {\r\n\t\treturn userId;\r\n\t}",
"@Override\n\tpublic long getUserId();",
"@Override\n\tpublic long getUserId();",
"public int getUserId() {\r\n return this.UserId;\r\n }",
"public long getUserID() {\r\n\t\treturn userID;\r\n\t}",
"protected long getUserID() {\n return userID;\n }",
"@Override\n\tpublic long getUserId() {\n\t\treturn _userSync.getUserId();\n\t}",
"public java.lang.Long getUserId() {\n return userId;\n }",
"public int getUserID() {\n return userID;\n }",
"public int getUserID() {\n return userID;\n }",
"public int getUserID() {\n return userID;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"public Integer getUserId() {\n return userId;\n }",
"@Override\n\tpublic Long getUserId() {\n\t\treturn user.getKey().getId();\n\t}",
"public int getUserID()\n {\n return this.userID;\n }"
]
| [
"0.67942774",
"0.67462516",
"0.6675051",
"0.6582201",
"0.65590453",
"0.65590453",
"0.65590453",
"0.65590453",
"0.6554827",
"0.65533733",
"0.6551452",
"0.65027076",
"0.6501879",
"0.649973",
"0.649973",
"0.64898825",
"0.64898825",
"0.64898825",
"0.64712995",
"0.6466942",
"0.6466942",
"0.6466942",
"0.6466942",
"0.6466942",
"0.6466942",
"0.6466942",
"0.6466942",
"0.6466942",
"0.6466942",
"0.6466942",
"0.6466942",
"0.64631456",
"0.6456467",
"0.6456467",
"0.6456467",
"0.64519525",
"0.6433487",
"0.64297396",
"0.64048696",
"0.63947153",
"0.6389989",
"0.6389989",
"0.6389321",
"0.6389321",
"0.6389321",
"0.6389321",
"0.6389321",
"0.6389321",
"0.6389321",
"0.6389321",
"0.6389321",
"0.6389321",
"0.6389321",
"0.6389321",
"0.63689536",
"0.636516",
"0.6354795",
"0.6351903",
"0.6351903",
"0.63478345",
"0.6346848",
"0.6346848",
"0.6346848",
"0.63462484",
"0.63462484",
"0.6343733",
"0.6328923",
"0.632629",
"0.63175553",
"0.6316641",
"0.63127553",
"0.63127553",
"0.63127553",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6299746",
"0.6282735",
"0.6278982"
]
| 0.0 | -1 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.USER_ID | public void setUserId(String userId) {
this.userId = userId;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setUserId(long value) {\r\n this.userId = value;\r\n }",
"private void setUserId(long value) {\n \n userId_ = value;\n }",
"public void setUserId(long value) {\n this.userId = value;\n }",
"private void setUserId(long value) {\n\n userId_ = value;\n }",
"public void setIdUser(int value) {\n this.idUser = value;\n }",
"public void setUserId(Long userId)\n/* */ {\n/* 80 */ this.userId = userId;\n/* */ }",
"public void setIdUser(Integer idUser) {\r\n\t\tthis.idUser = idUser;\r\n\t}",
"public void setUserId(java.lang.Long value) {\n this.userId = value;\n }",
"void setUserId(Long userId);",
"public void setIduser(int aIduser) {\n iduser = aIduser;\n }",
"public void setUserId(long userId);",
"public void setUserId(long userId);",
"public void setUserId(long userId);",
"public void setUserId(long userId);",
"public void setUserId(int value) {\n this.userId = value;\n }",
"private void setUserId(int value) {\n \n userId_ = value;\n }",
"public void setUserID(int value) {\n this.userID = value;\n }",
"public void setUserID(long userID) {\n UserID = userID;\n }",
"public void setIdUser(String idUser) {\n\t\tthis.idUser = idUser;\n\t}",
"public void setUser(Long user) {\n this.user = user;\n }",
"public void setUserid(Long userid) {\r\n this.userid = userid;\r\n }",
"@Override\n\tpublic void setUserId(long userId);",
"@Override\n\tpublic void setUserId(long userId);",
"public void setId_user(int id_user) {\r\n this.id_user = id_user;\r\n }",
"public void setUserId(Long userId) {\r\n this.userId = userId;\r\n }",
"public void setUserId(Long userId) {\r\n this.userId = userId;\r\n }",
"public void setUserId(Long userId) {\r\n this.userId = userId;\r\n }",
"public void setId_user(int id_user) {\n this.id_user = id_user;\n }",
"@Override\n\tpublic void setUserId(long userId) {\n\t\t_userSync.setUserId(userId);\n\t}",
"public void setLockUserid(String lockUserid) {\n\t\tthis.lockUserid = lockUserid == null ? null : lockUserid.trim();\n\t}",
"@Override\n\tpublic void setUserId(long userId) {\n\t\t_employee.setUserId(userId);\n\t}",
"public void setUserId(int userId) {\n this.mUserId = userId;\n }",
"public void setUserId(int userId) {\n this.mUserId = userId;\n }",
"public void setUserId(String value) {\r\n setAttributeInternal(USERID, value);\r\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"public void setUserId(Long userId) {\n this.userId = userId;\n }",
"@Override\n\tpublic void setUserId(long userId) {\n\t\t_changesetEntry.setUserId(userId);\n\t}",
"public void setUserId(Long userId) {\r\n\t\tthis.userId = userId;\r\n\t}",
"public void setUserId(Integer userId) {\r\n this.userId = userId;\r\n }",
"public void setUserId(Integer userId) {\r\n this.userId = userId;\r\n }",
"@Override\n\tpublic void setUserId(long userId) {\n\t\t_second.setUserId(userId);\n\t}",
"public void setJdbcUser(String val)\n {\n setValue(DataSourceDobj.FLD_JDBC_USER, val);\n }",
"public void setUserID(java.lang.String param) {\r\n localUserIDTracker = param != null;\r\n\r\n this.localUserID = param;\r\n }",
"public void setLockedUserId(String lockedUserId) {\n\t\tthis.lockedUserId = lockedUserId;\n\t}",
"public synchronized static void setUserId(String userId){\n setUserId(context,userId);\n }",
"public void setUserId(int userId)\r\n\t{\r\n\t\tthis.userId = userId;\r\n\t}",
"public void setUserId(java.lang.String param) {\r\n localUserIdTracker = param != null;\r\n\r\n this.localUserId = param;\r\n }",
"public void setUserId(java.lang.String param) {\r\n localUserIdTracker = param != null;\r\n\r\n this.localUserId = param;\r\n }",
"public void setUserid(java.lang.String value) {\n this.userid = value;\n }",
"public void setCreateUser(User createUser)\r\n/* */ {\r\n/* 151 */ this.createUser = createUser;\r\n/* */ }",
"public void setOwnerUserId(Long ownerUserId) {\n this.ownerUserId = ownerUserId;\n }",
"public void setUserId(final Long userId) {\n this.userId = userId;\n }",
"public void setUserID(int userID) {\n this.userID = userID;\n }",
"public void setUserID(int userID) {\n this.userID = userID;\n }",
"public de.hpi.msd.salsa.serde.avro.Edge.Builder setUserId(long value) {\n validate(fields()[0], value);\n this.userId = value;\n fieldSetFlags()[0] = true;\n return this;\n }",
"public void setUserID(Integer userID) {\n this.userID = userID;\n }",
"public void setUserId(int userId) {\n this.userId = userId;\n }",
"public void setUserId(int userId) {\n this.userId = userId;\n }",
"public void setUserId(int userId) {\n this.userId = userId;\n }",
"public void setUserId( Integer userId ) {\n this.userId = userId;\n }",
"public Builder setUserId(long value) {\n copyOnWrite();\n instance.setUserId(value);\n return this;\n }",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public void setUserId(Integer userId) {\n this.userId = userId;\n }",
"public Builder setUserId(long value) {\n \n userId_ = value;\n onChanged();\n return this;\n }",
"public void setUserId(Integer userId) {\r\n\t\tthis.userId = userId;\r\n\t}",
"public void setUserId(Integer userId) {\r\n\t\tthis.userId = userId;\r\n\t}",
"public void setUserId(Integer userId) {\r\n\t\tthis.userId = userId;\r\n\t}",
"public void setUserId(java.lang.String param) {\n localUserIdTracker = true;\n\n this.localUserId = param;\n }"
]
| [
"0.6759799",
"0.6721845",
"0.6692499",
"0.6675379",
"0.6582288",
"0.65371704",
"0.6518113",
"0.64828986",
"0.6441128",
"0.64241093",
"0.6372192",
"0.6372192",
"0.6372192",
"0.6372192",
"0.6370061",
"0.634748",
"0.6345891",
"0.6293144",
"0.622483",
"0.62005407",
"0.61800325",
"0.6171652",
"0.6171652",
"0.61518013",
"0.61407226",
"0.61407226",
"0.61407226",
"0.6072919",
"0.6064481",
"0.6041957",
"0.6037801",
"0.6011426",
"0.59988666",
"0.59984136",
"0.5995549",
"0.5995549",
"0.5995549",
"0.5995549",
"0.5995549",
"0.5995549",
"0.5995549",
"0.5995549",
"0.5995549",
"0.5995549",
"0.5995549",
"0.59724146",
"0.5966182",
"0.5963924",
"0.5963924",
"0.59551567",
"0.5954179",
"0.5946927",
"0.59419304",
"0.5928303",
"0.5924009",
"0.5915238",
"0.5915238",
"0.5901493",
"0.5899378",
"0.5884338",
"0.5880798",
"0.58777225",
"0.58777225",
"0.5877647",
"0.587391",
"0.58646",
"0.58646",
"0.58646",
"0.58629906",
"0.5851302",
"0.58443683",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.58413726",
"0.5837626",
"0.58313966",
"0.58313966",
"0.58313966",
"0.5825386"
]
| 0.0 | -1 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.SERVER_IP | public String getServerIp() {
return serverIp;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public String getServerIP()\n\t{\n\t\treturn this.serverIP;\n\t}",
"public String getServerIP() {\n\t\treturn serverIP;\n\t}",
"public String getServerip() {\n return serverip;\n }",
"public static String getServerIpAddress() {\n return _serverIpAddress;\n }",
"public String getServerIp() {\r\n\t\treturn serverIp;\r\n\t}",
"public static String getServerIP() {\n return serverIP;\n }",
"public String getIpServer()\n \t{\n \t\treturn ipServer;\n \t}",
"public String getIpAddress()\n\t{\n\t\t/* TODO: The IP address returned is in this format: /127.0.0.1:9845\n\t\t * Rewrite to remove the unnessecary data. */\n\t\treturn getSession().getIpAddress();\n\t}",
"public String getDataServerIp() {\n return dataServerIp;\n }",
"public static String getServerIP() { return tfJoinIP.getText(); }",
"public String getNiceServerIP(){\n\t\treturn(niceServerAddress);\n\t}",
"public java.lang.String getIp(){\r\n return localIp;\r\n }",
"public java.lang.String getIp(){\r\n return localIp;\r\n }",
"java.lang.String getIp();",
"java.lang.String getIp();",
"java.lang.String getIp();",
"java.lang.String getIp();",
"java.lang.String getIp();",
"java.lang.String getIp();",
"java.lang.String getIp();",
"java.lang.String getIp();",
"public int getIp() {\n return instance.getIp();\n }",
"public int getIp() {\n return instance.getIp();\n }",
"public static InetAddress getServerInet(){\n return thisServer.getIp();\n }",
"java.lang.String getAgentIP();",
"public String getServerAddress() {\r\n\t\treturn this.serverAddress;\r\n\t}",
"public String getIP() {\n return this.IP;\n }",
"java.lang.String getSnIp();",
"java.lang.String getSnIp();",
"public int getIp() {\n return ip_;\n }",
"public String getIp() {\n return (String) get(24);\n }",
"public String getIPAddress()\n {\n return fIPAddress;\n }",
"public String getClientip() {\n return clientip;\n }",
"public int getInIp() {\n return instance.getInIp();\n }",
"public int getInIp() {\n return instance.getInIp();\n }",
"public String getBackupServerIp(){\n\t return backupServerIP;\n }",
"public String get_ipaddress() throws Exception {\n\t\treturn this.ipaddress;\n\t}",
"public int getIp() {\n return ip_;\n }",
"public int getIp() {\n return ip_;\n }",
"public int getIp() {\n return ip_;\n }",
"public String getIp() {\r\n return ip;\r\n }",
"public int getInIp() {\n return inIp_;\n }",
"public int getInIp() {\n return inIp_;\n }",
"public String getLoginIp() {\n return loginIp;\n }",
"public String getIp() {\n return getIpString(inetAddress);\n }",
"public IpAddress getIpAddressValue() throws JNCException {\n return (IpAddress)getValue(\"ip-address\");\n }",
"public String getIp();",
"public String virtualIP() {\n return this.virtualIP;\n }",
"int getInIp();",
"int getInIp();",
"@Column(length = 1024)\r\n @PlaceHolder(key = \"host\")\r\n public String getServerName() {\r\n return serverName;\r\n }",
"public static String getIP() {\n\t\treturn ip;\r\n\t}",
"String getIp();",
"String getIp();",
"public String ipAddress() {\n return this.ipAddress;\n }",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public java.lang.String getIP() {\r\n return IP;\r\n }",
"public String getServerAddress() {\n\t\treturn mServerAddress;\n\t}",
"public String getIp() {\n return ip;\n }",
"public String getIpAddr() {\r\n return ipAddr;\r\n }",
"public String getDeviceIp(){\n\t return deviceIP;\n }",
"@Override\n\tpublic String getIp() {\n\t\treturn ip;\n\t}",
"public IpAddress getIpAddress2Value() throws JNCException {\n IpAddress ipAddress2 = (IpAddress)getValue(\"ip-address2\");\n if (ipAddress2 == null) {\n ipAddress2 = new IpAddress(\"0.0.0.0\"); // default\n }\n return ipAddress2;\n }",
"public IpAddress getIpAddress2Value() throws JNCException {\n return (IpAddress)getValue(\"ip-address2\");\n }",
"public String getIp() {\n\t\treturn InfraUtil.getIpMachine();\n\t}",
"public String getIPAddress () {\n\t\treturn _ipTextField.getText();\n\t}",
"public String getIpaddress ()\n {\n return ipaddress;\n }",
"public java.lang.String getIp() {\r\n return ip;\r\n }",
"java.lang.String getDestinationIp();",
"public String getIpAddr() {\n return ipAddr;\n }",
"int getIp();",
"int getIp();",
"int getIp();",
"public String getIp() {\n\t\treturn ip.getText();\n\t}",
"public String sourceIPAddress() {\n return this.sourceIPAddress;\n }",
"public String getIp(){\n\treturn ip;\n }",
"public java.lang.String getIp () {\r\n\t\treturn ip;\r\n\t}",
"public java.lang.String getIp () {\r\n\t\treturn ip;\r\n\t}",
"public String get()\r\n\t{\r\n\t\tignoreIpAddress = ignoreIpAddressService.getIgnoreIpAddress(id, false);\r\n\t\treturn \"get\";\r\n\t}",
"public String getIpAddress() {\n return ipAddress;\n }",
"public String getLastLoginip() {\n return lastLoginip;\n }",
"public String getUpdateUserip() {\r\n\t\treturn updateUserip;\r\n\t}",
"public String getClientIp() {\n return clientIp;\n }",
"public String getIpAddress() {\n return ipAddress;\n }",
"public String getIpAddress() {\n return ipAddress;\n }",
"@Override\r\n\tpublic String getIp() {\n\t\treturn null;\r\n\t}",
"public java.lang.String getSnIp() {\n java.lang.Object ref = snIp_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n snIp_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }",
"public java.lang.String getSnIp() {\n java.lang.Object ref = snIp_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n snIp_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }",
"public String getLastLoginIp() {\r\n return lastLoginIp;\r\n }",
"String getRemoteIpAddress();",
"public String getInsipaddr() {\r\n return insipaddr;\r\n }",
"@Override\r\n public String getIPAddress() {\r\n return address;\r\n }",
"public java.lang.String getSnIp() {\n java.lang.Object ref = snIp_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n snIp_ = s;\n return s;\n }\n }"
]
| [
"0.67380905",
"0.6674228",
"0.66580266",
"0.66517746",
"0.6641699",
"0.65379065",
"0.6249868",
"0.6195837",
"0.6195282",
"0.61503893",
"0.6081395",
"0.5947231",
"0.5947231",
"0.5936467",
"0.5936467",
"0.5936467",
"0.5936467",
"0.5936467",
"0.5936467",
"0.5936467",
"0.5936467",
"0.5933404",
"0.5933404",
"0.5905687",
"0.5881778",
"0.58720934",
"0.5867289",
"0.5865673",
"0.5865673",
"0.58487296",
"0.58327883",
"0.58260334",
"0.5824795",
"0.58243245",
"0.58243245",
"0.58167106",
"0.58101493",
"0.5792008",
"0.5792008",
"0.5792008",
"0.5756221",
"0.5746948",
"0.5746948",
"0.5743978",
"0.57217735",
"0.570471",
"0.57031417",
"0.5702691",
"0.5701738",
"0.5701738",
"0.5698812",
"0.5687659",
"0.56872445",
"0.56872445",
"0.56857544",
"0.56798625",
"0.56600475",
"0.56600475",
"0.56600475",
"0.56600475",
"0.56600475",
"0.56600475",
"0.56591314",
"0.5658736",
"0.5657703",
"0.565125",
"0.56289136",
"0.562227",
"0.5618842",
"0.560557",
"0.5604038",
"0.56008947",
"0.5588747",
"0.55859494",
"0.55812657",
"0.5579415",
"0.55764925",
"0.55764925",
"0.55764925",
"0.5569728",
"0.5561943",
"0.5557781",
"0.55414706",
"0.55414706",
"0.55334264",
"0.551642",
"0.5499939",
"0.5485352",
"0.5480099",
"0.5468803",
"0.5468803",
"0.54576737",
"0.5446341",
"0.5446341",
"0.5439137",
"0.54366577",
"0.54240054",
"0.542396",
"0.54071873"
]
| 0.65249574 | 7 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.SERVER_IP | public void setServerIp(String serverIp) {
this.serverIp = serverIp;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setServerIp(String serverIp) {\r\n\t\tthis.serverIp = serverIp;\r\n\t}",
"public void setIpServer(String ipServer)\n \t{\n \t\tthis.ipServer = ipServer;\n \t}",
"public void setIp(java.lang.String param){\r\n localIpTracker = true;\r\n \r\n this.localIp=param;\r\n \r\n\r\n }",
"public void setIp(java.lang.String param){\r\n localIpTracker = true;\r\n \r\n this.localIp=param;\r\n \r\n\r\n }",
"public void setServerIP(String serverIP) {\n\t\tthis.serverIP = serverIP;\n\t}",
"public void setServerip(String serverip) {\n this.serverip = serverip == null ? null : serverip.trim();\n }",
"public void setServerIP(String ip)\n\t{\n\t\tthis.serverIP = ip;\n\t}",
"private void setIp(int value) {\n \n ip_ = value;\n }",
"private void setIp(int value) {\n \n ip_ = value;\n }",
"public void setBackupServerIp(String argIp){\n\t backupServerIP=argIp;\n }",
"private void setInIp(int value) {\n \n inIp_ = value;\n }",
"private void setInIp(int value) {\n \n inIp_ = value;\n }",
"public void setServerIP(String serverIP) {\r\n\t\trmiClient.setServerIP(serverIP);\r\n\t}",
"public String getServerIp() {\r\n\t\treturn serverIp;\r\n\t}",
"public String getServerip() {\n return serverip;\n }",
"public String getServerIP() {\n\t\treturn serverIP;\n\t}",
"public String getServerIP()\n\t{\n\t\treturn this.serverIP;\n\t}",
"public static String getServerIpAddress() {\n return _serverIpAddress;\n }",
"public String getIpServer()\n \t{\n \t\treturn ipServer;\n \t}",
"@Column(length = 1024)\r\n @PlaceHolder(key = \"host\")\r\n public String getServerName() {\r\n return serverName;\r\n }",
"public void setIpAddress(InetAddress addr) \n\t{\n\t\tthis.ipAddress = addr;\n\t}",
"public void setDeviceIP(String argIp){\n\t deviceIP=argIp;\n }",
"public String getServerIp() {\n return serverIp;\n }",
"public String getServerIp() {\n return serverIp;\n }",
"public void setIp(String value) {\n set(24, value);\n }",
"private void setS1Ip(int value) {\n \n s1Ip_ = value;\n }",
"public static String getServerIP() {\n return serverIP;\n }",
"public void setIP(String IP) {\n this.IP = IP;\n }",
"public String getDataServerIp() {\n return dataServerIp;\n }",
"public java.lang.String getIp(){\r\n return localIp;\r\n }",
"public java.lang.String getIp(){\r\n return localIp;\r\n }",
"public boolean modFileServerIpAddr(String serverid, String serveripaddr) {\n\t\tFileServer fileserver = (FileServer) getHibernateTemplate().get(FileServer.class, serverid);\r\n\t\tif (fileserver == null)\r\n\t\t\treturn false;\r\n\t\telse {\r\n\t\t\tfileserver.setIpaddr(serveripaddr);\r\n\t\t\tgetHibernateTemplate().update(fileserver);\r\n\t\t\treturn true;\r\n\t\t}\r\n\t}",
"private void setTargetServer(){\n mTargetServer = findViewById(R.id.network_scanner_host_edit_text);\n String ip = DefaultPreferences.getIp(this);\n if(ip != null) {\n mTargetServer.setText(ip);\n }\n\n mTargetServer.addTextChangedListener(new TextWatcher() {\n @Override\n public void beforeTextChanged(CharSequence s, int start, int count, int after) {\n\n }\n\n @Override\n public void onTextChanged(CharSequence s, int start, int before, int count) {\n DefaultPreferences.setIp(NetworkScannerActivity.this, s.toString());\n }\n\n @Override\n public void afterTextChanged(Editable s) {\n\n }\n });\n }",
"public void setIp(String ip) {\n this.ip = ip;\n }",
"public void setServerAddress(String mDbServerAddress) {\n\t\tthis.mServerAddress = mDbServerAddress;\n\t}",
"void updateCustomServerAddress(String customServerAddress);",
"public void setIP(java.lang.String IP) {\r\n this.IP = IP;\r\n }",
"public void setSERVER(String SERVER) {\n \t\tthis.SERVER = SERVER;\n \t}",
"public Builder setServerAddress(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n serverAddress_ = value;\n onChanged();\n return this;\n }",
"public void setIp(String ip) {\n this.ip = ip;\n }",
"public void setIp(String ip) {\n this.ip = ip;\n }",
"public String getNiceServerIP(){\n\t\treturn(niceServerAddress);\n\t}",
"public void setIp(String ip) {\n this.ip = ip;\n }",
"public static String getServerIP() { return tfJoinIP.getText(); }",
"@Override\n\t\tpublic void ipChange() {\n\t\t\t\n\t\t}",
"public void setIp(final String ip) {\n this.ip = ip;\n }",
"public Builder setIp(\n String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n ip_ = value;\n onChanged();\n return this;\n }",
"public void setIpAddress(String ipAddress) {\n this.ipAddress = ipAddress;\n }",
"public void setIp(java.lang.String ip) {\r\n this.ip = ip;\r\n }",
"public Builder setIp(int value) {\n copyOnWrite();\n instance.setIp(value);\n return this;\n }",
"public Builder setIp(int value) {\n copyOnWrite();\n instance.setIp(value);\n return this;\n }",
"public void setIpAddress(String ipAddress) {\n this.ipAddress = WordCache.getWordCache(ipAddress);\n }",
"public void setPersistSvcIPAddr(String ipAddrStr) throws UnknownHostException {\n persistSvcIPAddrObj = InetAddress.getByName(ipAddrStr);\n }",
"public void markIpAddressReplace() throws JNCException {\n markLeafReplace(\"ipAddress\");\n }",
"public String getIp() {\r\n return ip;\r\n }",
"public void setIpAddress2Value(IpAddress ipAddress2Value)\n throws JNCException {\n setLeafValue(Epc.NAMESPACE,\n \"ip-address2\",\n ipAddress2Value,\n childrenNames());\n }",
"public void setIpAddress2Value(IpAddress ipAddress2Value)\n throws JNCException {\n setLeafValue(Epc.NAMESPACE,\n \"ip-address2\",\n ipAddress2Value,\n childrenNames());\n }",
"public String getBackupServerIp(){\n\t return backupServerIP;\n }",
"public void setIpSource(String value) {\n setProperty(IP_SOURCE, value, \"\");\n }",
"public void setIpAddressValue(IpAddress ipAddressValue) throws JNCException {\n setLeafValue(Epc.NAMESPACE,\n \"ip-address\",\n ipAddressValue,\n childrenNames());\n }",
"public void setIpAddr(String ipAddr) {\n this.ipAddr = ipAddr == null ? null : ipAddr.trim();\n }",
"Update withNextHopToVirtualAppliance(String ipAddress);",
"public Builder setSnIp(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n snIp_ = value;\n onChanged();\n return this;\n }",
"public Builder setSnIp(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n snIp_ = value;\n onChanged();\n return this;\n }",
"public boolean setIP(String IP) {\n try {\n mIP = IP;\n return true;\n } catch (Exception ex) {\n return false;\n }\n }",
"@Test\n public void testSetInterfaceIp() throws Exception {\n isisNeighbor.setInterfaceIp(interfaceIp);\n result2 = isisNeighbor.interfaceIp();\n assertThat(result2, is(interfaceIp));\n }",
"public String getIP() {\n return this.IP;\n }",
"public String getIp(){\n\treturn ip;\n }",
"public int getIp() {\n return ip_;\n }",
"public void setInsipaddr(String insipaddr) {\r\n this.insipaddr = insipaddr;\r\n }",
"public void setServer(int server) {\n this.server = server;\n }",
"public void setIp (java.lang.String ip) {\r\n\t\tthis.ip = ip;\r\n\t}",
"public void setIp (java.lang.String ip) {\r\n\t\tthis.ip = ip;\r\n\t}",
"public String getIp() {\n return ip;\n }",
"public void setIpAddress2Value(String ipAddress2Value) throws JNCException {\n setIpAddress2Value(new IpAddress(ipAddress2Value));\n }",
"public void setIpAddress2Value(String ipAddress2Value) throws JNCException {\n setIpAddress2Value(new IpAddress(ipAddress2Value));\n }",
"public void setIp(String ip) {\r\n this.ip = ip == null ? null : ip.trim();\r\n }",
"public void setIpAddr(String ipAddr) {\r\n if (StringUtil.isNotNUll(ipAddr)) {\r\n this.ipAddr = ipAddr == null ? null : ipAddr.trim();\r\n } else {\r\n this.ipAddr = null;\r\n }\r\n }",
"private void setServerAddressList(){\n\n if (mCallBack != null){\n mCallBack.onGetServerAddressListCompleted(mServerAddressList);\n }\n }",
"public Builder setIp(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n ip_ = value;\n onChanged();\n return this;\n }",
"public String getIp() {\n return ip;\n }",
"public IpAddress getIpAddress2Value() throws JNCException {\n IpAddress ipAddress2 = (IpAddress)getValue(\"ip-address2\");\n if (ipAddress2 == null) {\n ipAddress2 = new IpAddress(\"0.0.0.0\"); // default\n }\n return ipAddress2;\n }",
"public int getIp() {\n return ip_;\n }",
"public int getIp() {\n return ip_;\n }",
"public int getIp() {\n return ip_;\n }",
"private static void getServerIPAddress() {\r\n // Get local IP address\r\n try {\r\n Enumeration<NetworkInterface> enumeratedNetworkInterface = NetworkInterface.getNetworkInterfaces();\r\n\r\n NetworkInterface networkInterface;\r\n Enumeration<InetAddress> enumeratedInetAddress;\r\n InetAddress inetAddress;\r\n\r\n for (; enumeratedNetworkInterface.hasMoreElements(); ) {\r\n networkInterface = enumeratedNetworkInterface.nextElement();\r\n enumeratedInetAddress = networkInterface.getInetAddresses();\r\n\r\n for (; enumeratedInetAddress.hasMoreElements(); ) {\r\n inetAddress = enumeratedInetAddress.nextElement();\r\n String anIPAddress = inetAddress.getHostAddress();\r\n if (log.isDebugEnabled()) {\r\n log.debug(\"Scanning local IP space: \" + anIPAddress);\r\n }\r\n\r\n // exclude loop-back and MAC address\r\n if (!(anIPAddress.equals(\"127.0.0.1\") || anIPAddress.contains(\":\")))\r\n localIPAddress = anIPAddress;\r\n }\r\n }\r\n } catch (Exception e) {\r\n log.error(\"Error in retrieving the local IP address: \" + e.toString());\r\n }\r\n }",
"public void setLoginIp(String loginIp) {\n this.loginIp = loginIp == null ? null : loginIp.trim();\n }",
"@Override\n\tpublic String getIp() {\n\t\treturn ip;\n\t}",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public String getIp() {\n return ip;\n }",
"public void markIpAddressMerge() throws JNCException {\n markLeafMerge(\"ipAddress\");\n }",
"@Override\r\n\tpublic String getIp() {\n\t\treturn null;\r\n\t}",
"public Builder setIp(int value) {\n bitField0_ |= 0x00000100;\n ip_ = value;\n onChanged();\n return this;\n }",
"public String getIpAddr() {\r\n return ipAddr;\r\n }",
"public void setIp(String ip) {\n this.ip = ip == null ? null : ip.trim();\n }"
]
| [
"0.6096655",
"0.6086424",
"0.6066759",
"0.6066759",
"0.59609765",
"0.59436435",
"0.593591",
"0.5795259",
"0.5795259",
"0.5733461",
"0.56873316",
"0.56873316",
"0.56372684",
"0.55126226",
"0.5510261",
"0.5456573",
"0.54239815",
"0.5416918",
"0.5405191",
"0.5398605",
"0.5374844",
"0.53453374",
"0.53246087",
"0.53246087",
"0.52975416",
"0.52907556",
"0.5236591",
"0.51699895",
"0.51527363",
"0.51501834",
"0.51501834",
"0.51475334",
"0.5141438",
"0.5141223",
"0.51411873",
"0.51379323",
"0.5115945",
"0.50855005",
"0.5041145",
"0.5030203",
"0.5030203",
"0.5027166",
"0.50262463",
"0.5016603",
"0.5006407",
"0.49762753",
"0.49612856",
"0.4955479",
"0.493096",
"0.4926868",
"0.4926868",
"0.4926585",
"0.49261874",
"0.49257168",
"0.49240518",
"0.49058014",
"0.49058014",
"0.49055782",
"0.48978028",
"0.48913616",
"0.4880719",
"0.48798016",
"0.48791626",
"0.48791626",
"0.4875123",
"0.48701325",
"0.48609826",
"0.48571122",
"0.48517543",
"0.4828993",
"0.48274747",
"0.4823428",
"0.4823428",
"0.48232555",
"0.48188323",
"0.48188323",
"0.4811242",
"0.48098293",
"0.48045367",
"0.4802738",
"0.4800327",
"0.47961733",
"0.4794942",
"0.4794942",
"0.4794942",
"0.479364",
"0.47893444",
"0.47891423",
"0.47846553",
"0.47846553",
"0.47846553",
"0.47846553",
"0.47846553",
"0.47846553",
"0.47792295",
"0.4770588",
"0.4770054",
"0.47667792",
"0.4766228"
]
| 0.6188033 | 1 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.GAME_ID | public String getGameId() {
return gameId;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Integer getGameId() {\n return gameId;\n }",
"public Integer getGameID() {\n\t\treturn game_id;\n\t}",
"String getGameId();",
"public int getGameID() {\n return GameID;\n }",
"public int getGameID() {\n return gameID;\n }",
"GameCode getGameCode(Long gameId);",
"public int getGameNumber() {\n\t\tint result = -1;\n\t\ttry {\n\t\t\tthis.rs = smt.executeQuery(\"SELECT count(id) FROM tp.gamerecord\");\n\t\t\tif(this.rs.next()) {\n\t\t\t\tresult = rs.getInt(1);\n\t\t\t}\n\t\t} catch (SQLException e) {\n\t\t\tSystem.err.println(\"Query is Failed!\");\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn result;\n\t}",
"public int getGameManagerID() {\n return ID;\n }",
"@Override\n\tpublic long getPrimaryKey() {\n\t\treturn _esfTournament.getPrimaryKey();\n\t}",
"long getPlayerId();",
"Game getGameById(long id);",
"Long getDbId();",
"public abstract Game getGame(int game_id) throws SQLException;",
"public String getGameNumber() {\n return gameNumber;\n }",
"public Game getGameDataById(int gameID) {\n Game loadedGame = null;\n Session session = sessionFactory.openSession();\n // Try to return the user by the given nickname\n try {\n session.beginTransaction();\n\n loadedGame = (Game) session.get(Game.class, gameID);\n \n session.getTransaction().commit();\n session.flush();\n } \n catch (HibernateException e) { return null; } \n finally { session.close(); }\n // Return userID if seted\n return loadedGame;\n }",
"public Long getLeagueId() {\n return (this.leagueId);\n }",
"@Override\r\n\tpublic int getID() {\r\n\t\treturn GameOver.ID;\r\n\t}",
"private Game getGameById(long idGame) {\n Game game;\n synchronized (this.games) {\n if (!this.games.containsKey(idGame)) {\n return null;\n }\n game = this.games.get(idGame);\n }\n return game;\n }",
"public final int getGameKey() {\n\t\treturn mGameKey;\n\t}",
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"public String getLockId() {\n return lockId;\n }",
"public void setGameId(Integer gameId) {\n this.gameId = gameId;\n }",
"public String getGameIdForMap(int gameId) {\n\t\tCursor cursor = getReadableDatabase().rawQuery(\n\t\t\t\t\"SELECT map_id FROM maps WHERE game.game_id =? LIMIT 1\",\n\t\t\t\tnew String[] { \"\" + gameId });\n\t\tcursor.moveToFirst();\n\t\tif (cursor.getCount() < 1) {\n\t\t\treturn \"Game/Map Not Available\";\n\t\t} else {\n\t\t\treturn cursor.getString(cursor.getColumnIndex(\"map_id\"));\n\t\t}\n\t}",
"@Override\n public Game readGame(Long game_id) {\n return gameDataAccess.findById(game_id).get();\n }",
"public int getLeagueId() {\n return leagueId;\n }",
"public List<Integer> getGameIDs(){\r\n\t\treturn discountedGameIDs;\r\n\t}",
"public int getPlayerId();",
"public Long getLockNum() {\n return lockNum;\n }",
"private GameInfo retrieveGameInfo(String gameId) {\n GameInfo gameInfo = sessionInfo.getGameInfo();\n if(gameInfo != null && gameId.equals(gameInfo.getId())) {\n return gameInfo;\n }\n return null;\n }",
"long getRoomId();",
"public abstract java.lang.Long getId_causal_peticion();",
"long getSteamID();",
"java.lang.String getLobbyId();",
"int getPlayerId();",
"int getPlayerId();",
"public Long createGame() {\n Game game;\n synchronized (this.games) {\n Long id = this.sessionService.incrementGameId();\n\n game = new Game(id,\n new ArrayList<>(), new ArrayList<>());\n\n this.games.put(id, game);\n }\n this.save(game);\n\n return game.getGameIdentifier();\n }",
"long getOwnerIdLong();",
"public int getId() {\n return playerId;\n }",
"public java.lang.Long getId();",
"java.lang.String getPlayerId();",
"public int getId() {\n\t\treturn gfId;\n\t}",
"public int getLobbyID() {\r\n return lobbyID;\r\n }",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"Long getId();",
"Long getId();",
"Long getId();",
"long getEncounterId();",
"public Integer getId()\r\n\t\t{ return mapping.getId(); }",
"public Integer getGameCurrencyid() {\n return gameCurrencyid;\n }",
"@Override\n\tpublic Game getGameById(Long gameId) {\n\t\treturn iGameRepository.findById(gameId).get();\n\t}",
"public Hash saveHash(Hash game){\n Session session = sessionFactory.openSession();\n // Try to return the user by the given nickname\n try {\n session.beginTransaction();\n\n session.save(game);\n\n session.getTransaction().commit();\n session.flush();\n } \n catch (HibernateException e) { e.printStackTrace(); return null;} \n finally { session.close(); }\n // Return userID if seted\n return game;\n \n }",
"@Override\n\tpublic long getPrimaryKey() {\n\t\treturn _dlSyncEvent.getPrimaryKey();\n\t}",
"private int readId(String playerName) {\n int id = -1;\n\n try {\n PreparedStatement statement = connection.prepareStatement(\"SELECT id FROM \" + tablePrefix + \"users WHERE user = ?\");\n statement.setString(1, playerName);\n id = readInt(statement);\n }\n catch (SQLException ex) {\n printErrors(ex);\n }\n\n return id;\n }",
"@Override\n\t/**\n\t * Method that returns the mule mount state of the game\n\t * @return The ID of the mule mount state\n\t */\n\tpublic int getID() {\n\t\treturn 4;\n\t}",
"java.lang.String getDatabaseId();",
"@Override\n\tpublic long getPrimaryKey() {\n\t\treturn _phieugiahan.getPrimaryKey();\n\t}",
"public static long getRoomIdForUser(String nick) throws SQLException {\n UserEntity userInfo = getUserInfo(nick);\n List<Map <String, String>> result = db.get(SELECT_GET_GAME_ID_FOR_USER, userInfo.getId(), userInfo.getId());\n if (result.size() > 0) {\n return Long.valueOf(result.get(0).get(\"id\"));\n } else {\n return -1;\n }\n }",
"public int dbId() { return dbId; }",
"public Integer getGameUseTime() {\n return gameUseTime;\n }",
"@Override\n public Object doInHibernate(Session session) throws HibernateException {\n return (Long) session.createSQLQuery(\"SELECT NEXTVAL('SGSWEB.SEQ_CUESTIONARIO') as id\").addScalar(\"id\", LongType.INSTANCE).uniqueResult();\n }",
"public int getId() {\n return (roomId);\n }",
"public Map<String, Object> getPrimaryKey() {\n Map<String, Object> ret = new LinkedHashMap<String, Object>(6);\n ret.put(\"idacquirente\", Integer.valueOf(getIdacquirente()));\n return ret;\n }",
"@Override\n\tpublic long getPrimaryKey() {\n\t\treturn _esfShooterAffiliationChrono.getPrimaryKey();\n\t}",
"public int getHighestId() {\n final SQLiteStatement statement = db.compileStatement(\"SELECT MAX(_id) FROM Games\");\n return (int) statement.simpleQueryForLong();\n }",
"@Override\n\tpublic long getPrimaryKey() {\n\t\treturn _employee.getPrimaryKey();\n\t}",
"public CheckersGame getGameByID(Integer gameID){\n return games.get(gameID);\n }",
"public Integer getId() {\n return aao.getId();\n }",
"public int getID() {\n return gID;\n }",
"public String getGameKey() {\n return gameKey;\n }",
"long getLoginId();",
"long getLoginId();",
"long getLoginId();",
"public com.agbar.service.service.persistence.PnaNoticiaGrupoLectorPK getPrimaryKey() {\n\t\treturn _pnaNoticiaGrupoLector.getPrimaryKey();\n\t}",
"public abstract boolean existsGame(int game_id) throws SQLException;",
"public void setGameId(String gameId) {\n this.gameId = gameId;\n }",
"public void setGameId(String gameId) {\n this.gameId = gameId;\n }",
"public long getID();",
"@Nullable\n public String putGame(@Nullable Game game) {\n if (game == null) {\n throw new IllegalArgumentException(\"game should not be null.\");\n }\n if (game.getHasBeenAdded()) {\n return game.getId();\n }\n\n String id = game.getId() != null ? game.getId() : gamesRef.push().getKey();\n if (id == null) {\n throw new IllegalArgumentException(\"Could not add game to database, id is null.\");\n }\n game.setId(id);\n gamesRef.child(id).setValue(game.getGameDbData());\n linkPlayersToDB(game);\n linkCoinsToDB(game);\n game.setHasBeenAdded(true);\n game.setStarted(false, false);\n game.setEnded(false, false);\n game.setStartTime(System.currentTimeMillis() / 1000, false);\n return id;\n }",
"public int getLobbyId(int index) {\n return lobbyId_.getInt(index);\n }",
"public Long getRoomstlogid()\n {\n return roomstlogid; \n }",
"public java.lang.Long getId_tecnico();",
"public int getLockon() {\r\n return lockon;\r\n }",
"public IGame getGame(String uniqGameID){\r\n\t\treturn null;\r\n\t}",
"public int getGameID(Location location){\n\t\tint gameID = 0;\n\t\t\n\t\treturn gameID;\n\t}",
"public String getActiveGame() {\n return myActiveGame;\n }",
"public Integer getSnapshotId() {\r\n return snapshotId;\r\n }",
"public Integer getIDByPlayer(Player player){\n // This is operating under the assumption that\n // a player is only in one game.\n\n synchronized (games) {\n for (Integer id: games.keySet()){\n CheckersGame game = games.get(id);\n if (game.hasPlayer(player) && !game.isGameOver()) {\n return id;\n }\n }\n return null;\n }\n }",
"public java.lang.Long getUsua_id();",
"@Override\n\tpublic long getPrimaryKey() {\n\t\treturn _dmGTShipPosition.getPrimaryKey();\n\t}",
"public Integer getId() {\n\t\treturn loanId; //changed LoAn_Id to loanId\r\n\t}",
"SysTeam selectByPrimaryKey(Integer teamId);",
"public Long getSPEventID()\n/* */ {\n/* 64 */ return this.SPEventID;\n/* */ }",
"public long getPlayerId() {\n return playerId_;\n }",
"long getId();",
"long getId();",
"long getId();",
"long getId();",
"long getId();",
"long getId();"
]
| [
"0.6837099",
"0.66233206",
"0.6513763",
"0.6497123",
"0.6479826",
"0.620028",
"0.609867",
"0.5942891",
"0.5718963",
"0.56774724",
"0.5675201",
"0.55910647",
"0.5589982",
"0.5576083",
"0.5550949",
"0.5547249",
"0.5535192",
"0.5449115",
"0.5423797",
"0.5376708",
"0.5352449",
"0.535075",
"0.5341591",
"0.5299997",
"0.529536",
"0.52939147",
"0.52675164",
"0.5256527",
"0.52480793",
"0.52287376",
"0.5223834",
"0.52107453",
"0.5197626",
"0.5178323",
"0.5178323",
"0.51679707",
"0.5166213",
"0.5163769",
"0.51628214",
"0.51184326",
"0.51061267",
"0.5104432",
"0.5097781",
"0.50901896",
"0.50901896",
"0.50901896",
"0.50865203",
"0.507937",
"0.50770605",
"0.50734746",
"0.5062213",
"0.50613177",
"0.5059905",
"0.50485456",
"0.5044625",
"0.50432885",
"0.504079",
"0.5037803",
"0.5028406",
"0.50247693",
"0.50209546",
"0.5017405",
"0.5016301",
"0.5014673",
"0.5014376",
"0.50083476",
"0.5003209",
"0.49981207",
"0.49957052",
"0.499503",
"0.499503",
"0.499503",
"0.49831107",
"0.4974703",
"0.4972108",
"0.4972108",
"0.49703494",
"0.4963383",
"0.49594036",
"0.4956546",
"0.49558833",
"0.49530965",
"0.49514058",
"0.49485078",
"0.49466097",
"0.49455908",
"0.4941579",
"0.49358004",
"0.49318752",
"0.49301368",
"0.49242386",
"0.49224716",
"0.49222776",
"0.49130887",
"0.49130887",
"0.49130887",
"0.49130887",
"0.49130887",
"0.49130887"
]
| 0.65440136 | 3 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.GAME_ID | public void setGameId(String gameId) {
this.gameId = gameId;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setGameId(Integer gameId) {\n this.gameId = gameId;\n }",
"public Integer getGameId() {\n return gameId;\n }",
"public int getGameID() {\n return GameID;\n }",
"public String getGameId() {\n return gameId;\n }",
"public String getGameId() {\n return gameId;\n }",
"public Integer getGameID() {\n\t\treturn game_id;\n\t}",
"public int getGameID() {\n return gameID;\n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_esfTournament.setPrimaryKey(primaryKey);\n\t}",
"private void startDBValue(String target){\n database.getReference(gameCodeRef).child(target).setValue(1);\n }",
"private void setRoomId(long value) {\n \n roomId_ = value;\n }",
"public void setLeagueId(int value) {\n this.leagueId = value;\n }",
"public void setGame(Game game) {\n this.game = game;\n }",
"public long autoSetGameId(long memberId) {\r\n\t\tlong gameId=0;\r\n\t\tMember member = memberDao.findById(memberId);\r\n\t\tList<Player> players = playerDao.findByMember(member);\r\n\t\tif (players.size() == 1) {\r\n\t\t\tgameId = players.get(0).getGame().getId();\r\n\t\t} \r\n\t\telse {\r\n\t\t\tfor (Player p : players) {\r\n\t\t\t\tif (p.getIsActionRequired()) {\r\n\t\t\t\t\tgameId = p.getGame().getId();\r\n\t\t\t\t\tbreak;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}\t\r\n\t\tif (gameId <= 0) {\r\n\t\t\tlong activeId = 0;\r\n\t\t\tlong activeCount = 0;\r\n\t\t\tfor (Player p : players) {\r\n\t\t\t\tif (p.getGame().getIsActive())\t {\r\n\t\t\t\t\tactiveId = p.getGame().getId();\r\n\t\t\t\t\tactiveCount++;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\tif (activeCount == 1) gameId = activeId;\r\n\t\t}\t\r\n\t\t\r\n\t\tlogger.debug(\"Auto set game id = \" + gameId);\r\n\t\treturn gameId;\r\n\t}",
"public int getGameManagerID() {\n return ID;\n }",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"protected void setGame(Game game) {\n this.game = game;\n }",
"@Override\n public void setStartGame() {\n database.getReference(gameCodeRef).child(\"StartGame\").setValue(true);\n }",
"public void setGameId(String gameId) {\n this.gameIdDisplay.setText(gameId);\n }",
"void setGame (Game game) {\n this.game = game;\n }",
"public static void updateDb(GameDto game) throws PictionnaryDbException {\n try {\n java.sql.Connection connexion = DBManager.getConnection();\n\n java.sql.PreparedStatement update;\n update = connexion.prepareStatement(\"Update Game set \"\n + \" gdrawer = ?,\"\n + \" gpartner = ?,\"\n + \" gstarttime = ?,\"\n + \" gendtime = ?,\"\n + \" gstopplayer = ?\"\n + \" where gid= ?\");\n update.setInt(1, game.getDrawer());\n update.setInt(2, game.getPartner());\n\n if (game.getStartTime() == null) {\n update.setNull(3, Types.TIMESTAMP);\n } else {\n update.setTimestamp(3, game.getStartTime());\n }\n\n if (game.getEndTime() == null) {\n update.setNull(4, Types.TIMESTAMP);\n } else {\n update.setTimestamp(4, game.getEndTime());\n }\n\n update.setInt(5, game.getStopPlayer());\n update.setInt(6, game.getId());\n int a = update.executeUpdate();\n } catch (Exception ex) {\n throw new PictionnaryDbException(\"Game, modification impossible:\\n\" + ex.getMessage());\n }\n }",
"public void setGameScore(Integer gameScore) {\n this.gameScore = gameScore;\n }",
"String getGameId();",
"public void setSPEventID(Long SPEventID)\n/* */ {\n/* 76 */ this.SPEventID = SPEventID;\n/* */ }",
"private void joinGame(int gameId){\n\n }",
"public final /* synthetic */ void mo9963a(SelectGameDialogFragment selectGameDialogFragment, Game game) {\n this.f9686o = game;\n m11876a(game);\n selectGameDialogFragment.dismiss();\n if (game == null) {\n this.f9685n.mo25021a(\"hotsoon.pref.LAST_SET_GAME\", (Object) \"\").mo25023a();\n } else {\n this.f9685n.mo25021a(\"hotsoon.pref.LAST_SET_GAME\", (Object) game.toJsonString()).mo25023a();\n }\n }",
"public void setLockKey( Long lockKey ) {\n this.lockKey = lockKey;\n }",
"public void initializeGameRoom() {\n DatabaseReference game = database.getReference(gameCodeRef);\n game.child(\"NumberOfPlayers\").setValue(0);\n game.child(\"PlayersDoneBrainstorming\").setValue(0);\n game.child(\"PlayersDoneEliminating\").setValue(0);\n game.child(\"AllDoneBrainstorming\").setValue(false);\n game.child(\"AllDoneEliminating\").setValue(false);\n game.child(\"StartGame\").setValue(false);\n\n }",
"void setPlayerId(int playerId);",
"public void setGame() {\n }",
"public void setGameNumber(String gameNumber) {\n this.gameNumber = gameNumber;\n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_dmGTShipPosition.setPrimaryKey(primaryKey);\n\t}",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_esfShooterAffiliationChrono.setPrimaryKey(primaryKey);\n\t}",
"GameCode getGameCode(Long gameId);",
"public void setBundleID(long param){\n localBundleIDTracker = true;\n \n this.localBundleID=param;\n \n\n }",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setPrimaryKey(long primaryKey);",
"public void setGame(Game g)\r\n\t{\r\n\t\tgame = g;\r\n\t}",
"void setLong(int index, long value) throws SQLException;",
"public void setDealingUserID(Long dealingUserID)\n/* */ {\n/* 147 */ this.dealingUserID = dealingUserID;\n/* */ }",
"public void setMatch(Match game) {\n this.game = game;\n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_phieugiahan.setPrimaryKey(primaryKey);\n\t}",
"void makeGameInvisible(int gameId) throws DAOException;",
"public void setId(Long id)\n/* */ {\n/* 66 */ this.id = id;\n/* */ }",
"public void setKlasaAutomobilaID(long value) {\r\n this.klasaAutomobilaID = value;\r\n }",
"public void setId(Long value) {\r\n this.id = value;\r\n }",
"protected void setId(EmployeeLeave employeeLeave, ResultSet rs, int rowNumber) throws SQLException{\n\t\tString id = rs.getString(EmployeeLeaveTable.COLUMN_ID);\n\t\tif(id == null){\n\t\t\t//do nothing when nothing found in database\n\t\t\treturn;\n\t\t}\n\t\n\t\temployeeLeave.setId(id);\n\t}",
"public void endGameDetailsUpdate(Game game){\n String sql = \"update game_table set match_time=?, amount=?, remark=? where match_id=?\";\n PreparedStatement ps = connect(sql, false);\n try{\n ps.setInt(1, game.getMatchTime());\n ps.setDouble(2, game.getAmount());\n ps.setString(3, game.getRemark());\n ps.setInt(4, game.getMatchId());\n \n if(ps.executeUpdate()==1){\n System.out.println(\"Game end calculations update success..\");\n }\n }catch(SQLException ex){\n System.out.println(ex);\n }\n }",
"public void setSnapshotId(long value) {\n this.snapshotId = value;\n }",
"public void setActiveOpponent(long opponent) {\n\t\tm_Opponent = opponent;\n\t}",
"public void setRoomstid(Long newVal) {\n if ((newVal != null && this.roomstid != null && (newVal.compareTo(this.roomstid) == 0)) || \n (newVal == null && this.roomstid == null && roomstid_is_initialized)) {\n return; \n } \n this.roomstid = newVal; \n roomstid_is_modified = true; \n roomstid_is_initialized = true; \n }",
"@Nullable\n public String putGame(@Nullable Game game) {\n if (game == null) {\n throw new IllegalArgumentException(\"game should not be null.\");\n }\n if (game.getHasBeenAdded()) {\n return game.getId();\n }\n\n String id = game.getId() != null ? game.getId() : gamesRef.push().getKey();\n if (id == null) {\n throw new IllegalArgumentException(\"Could not add game to database, id is null.\");\n }\n game.setId(id);\n gamesRef.child(id).setValue(game.getGameDbData());\n linkPlayersToDB(game);\n linkCoinsToDB(game);\n game.setHasBeenAdded(true);\n game.setStarted(false, false);\n game.setEnded(false, false);\n game.setStartTime(System.currentTimeMillis() / 1000, false);\n return id;\n }",
"public void setGameUseTime(Integer gameUseTime) {\n this.gameUseTime = gameUseTime;\n }",
"public abstract void setCod_actividad(java.lang.Long newCod_actividad);",
"public void setEventID(Long eventID)\n/* */ {\n/* 123 */ this.eventID = eventID;\n/* */ }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_dlSyncEvent.setPrimaryKey(primaryKey);\n\t}",
"public void setGameRoomID(String gameArea, String gameRoomID)\r\n\t{\r\n\t\tif(gameArea.toLowerCase().equals(\"fireworks\"))\r\n\t\t{\r\n\t\t\tgameFireworks.setRoomID(gameRoomID);\r\n\t\t}\r\n\t\telse if(gameArea.toLowerCase().equals(\"pirates\"))\r\n\t\t{\r\n\t\t\tgamePirates.setRoomID(gameRoomID);\r\n\t\t}\r\n\t}",
"public void setLockId(String lockId) {\n this.lockId = lockId;\n }",
"public abstract void setGame(Gyges game);",
"public void setId(Long value) {\n this.id = value;\n }",
"void setLoginId(long loginId);",
"void setLoginId(long loginId);",
"void setLoginId(long loginId);",
"public void setId(int driverDBId);",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_scienceApp.setPrimaryKey(primaryKey);\n\t}",
"public void setHC_EmployeeGrade2_ID (int HC_EmployeeGrade2_ID);",
"public abstract void setAcma_id(java.lang.Long newAcma_id);",
"public void setID(long id);",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_employee.setPrimaryKey(primaryKey);\n\t}",
"public Builder setSteamID(long value) {\n bitField0_ |= 0x00000001;\n steamID_ = value;\n onChanged();\n return this;\n }",
"@Override\n public Game updateGame(Long game_id, Game game) {\n removeGame(game_id);\n gameDataAccess.save(game);\n return game;\n }",
"public Builder setPlayerId(long value) {\n \n playerId_ = value;\n onChanged();\n return this;\n }",
"@Override\n\tpublic void setId(long value) {\n super.setId(value);\n }",
"@Override\n\tpublic void setPrimaryKey(long primaryKey) {\n\t\t_state.setPrimaryKey(primaryKey);\n\t}",
"public void setEventDealingID(Long eventDealingID)\n/* */ {\n/* 99 */ this.eventDealingID = eventDealingID;\n/* */ }",
"public void sethId(Long hId) {\n this.hId = hId;\n }",
"public void setGamesPlayed(String teamName, int games)\n\t throws SQLException\n\t \t\t{\n\t\t // Create a connection to the database.\n\t\t conn = DriverManager.getConnection(DB_URL);\n\n\t\t// Create a Statement object for the query.\n\t\tStatement stmt = conn.createStatement();\n\n\t\t// Execute the update.\n\t\tstmt.executeUpdate(\"UPDATE Team \" +\n\t \"SET games = \" +\n\t games +\n\t \" WHERE teamName = '\" +\n\t teamName + \"'\");\n\n\t\t// Close the Connection and Statement objects.\n\t\tconn.close();\n\t\tstmt.close();\n\t\t}",
"private void setId(int ida2) {\n\t\tthis.id=ida;\r\n\t}",
"public void setRoomstlogid(Long newVal) {\n if ((newVal != null && this.roomstlogid != null && (newVal.compareTo(this.roomstlogid) == 0)) || \n (newVal == null && this.roomstlogid == null && roomstlogid_is_initialized)) {\n return; \n } \n this.roomstlogid = newVal; \n roomstlogid_is_modified = true; \n roomstlogid_is_initialized = true; \n }",
"public void setJamSelesai(java.lang.Long value) {\n this.jam_selesai = value;\n }",
"public void setIdOwner(Long idOwner) {\r\n this.idOwner = idOwner;\r\n }",
"@Override\n public final void setItsId(final Long pId) {\n //stub\n }",
"@Override public void setGameAvailabilityTrue(Game game)\r\n throws RemoteException, SQLException {\r\n gameListClientModel.setGameAvailableTrue(game);\r\n }",
"void setScore(long score);",
"public void setLoyaltyCardId(long value) {\n this.loyaltyCardId = value;\n }"
]
| [
"0.60613644",
"0.5822259",
"0.5606895",
"0.5592111",
"0.5592111",
"0.5589403",
"0.5555305",
"0.5459791",
"0.5405316",
"0.5395874",
"0.52869034",
"0.52652717",
"0.52397823",
"0.52033925",
"0.5201829",
"0.5200242",
"0.5196537",
"0.51937145",
"0.5187432",
"0.5184461",
"0.5183405",
"0.5181369",
"0.51666737",
"0.5118102",
"0.511048",
"0.50908923",
"0.504887",
"0.50269705",
"0.5022082",
"0.5015895",
"0.50028074",
"0.49500048",
"0.49468404",
"0.49463248",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49288186",
"0.49193916",
"0.49152413",
"0.490915",
"0.49086258",
"0.4902012",
"0.49008274",
"0.48981053",
"0.48978457",
"0.4896233",
"0.4896121",
"0.4891181",
"0.48845384",
"0.48721763",
"0.4853293",
"0.4836839",
"0.4832043",
"0.48319378",
"0.4815091",
"0.48103106",
"0.48038265",
"0.480275",
"0.4797774",
"0.47948623",
"0.47880378",
"0.47880378",
"0.47880378",
"0.47797075",
"0.47697052",
"0.4764497",
"0.4754213",
"0.4751581",
"0.47502592",
"0.47460654",
"0.47444665",
"0.4742338",
"0.474137",
"0.4732049",
"0.47296837",
"0.47288987",
"0.4714056",
"0.47126",
"0.47124672",
"0.47123533",
"0.4712183",
"0.47118214",
"0.47103792",
"0.47101763",
"0.4706121"
]
| 0.5688647 | 3 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.SERVER_NAME | public String getServerName() {
return serverName;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public String getServerName(){\n return this.serverName;\n }",
"@Column(length = 1024)\r\n @PlaceHolder(key = \"host\")\r\n public String getServerName() {\r\n return serverName;\r\n }",
"public String getServername() {\r\n return servername;\r\n }",
"public String getDBName()\n {\n return dbServer;\n }",
"public String getServerName() {\n\t\treturn m_serverName;\n\t}",
"public static server getNameServer(){\n return nameServer;\n }",
"public YangString getSrvTargetNameValue() throws JNCException {\n return (YangString)getValue(\"srv-target-name\");\n }",
"public String getUsrnm() throws Exception\n\t{\n\t\tString usrnm=\"null\";\n\t\ttry(Connection connection = DriverManager.getConnection(\"jdbc:mysql://localhost:3306/usersdb?useTimezone=true&serverTimezone=UTC\", \"root\", \"123\");\n\t\t\tPreparedStatement preparedStatement = connection.prepareStatement(\"SELECT clients_username FROM usersdb.telephone_numbers;\"))\n\t\t{\n\t\t\tResultSet result = preparedStatement.executeQuery();\n\t\t\t\n\t\t\twhile(result.next()) \n\t\t\t{\n\t\t\t\tif(username.equals(result.getString(\"clients_username\"))) \n\t\t\t\t{\n\t\t\t\t\tusrnm = result.getString(\"clients_username\");\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\tcatch(SQLException e) \n\t\t{\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn usrnm;\n\t}",
"public String getSERVER() {\n \t\treturn SERVER;\n \t}",
"@Override\n\t\tpublic String getServerName() {\n\t\t\treturn null;\n\t\t}",
"public String getServerName() {\n if (server == null) {\n final String version = OpenEjbVersion.get().getVersion();\n final String os = System.getProperty(\"os.name\") + \"/\" + System.getProperty(\"os.version\") + \" (\" + System.getProperty(\"os.arch\") + \")\";\n server = \"OpenEJB/\" + version + \" \" + os;\n }\n return server;\n }",
"protected String getLockManagerName() {\n return getName();\n }",
"public String getSelectedServerId() {\n return details != null ? StringUtils.stripToNull(details.getArtifactoryName()) : null;\n }",
"public final static String getServerIdentificator() {\r\n\t\treturn serverID;\r\n\t}",
"@Override\n public String getLName() {\n\n if(this.lName == null){\n\n this.lName = TestDatabase.getInstance().getClientField(token, id, \"lName\");\n }\n\n return lName;\n }",
"@Override\n public String getServerDisplayName() {\n return serverDisplayName;\n }",
"public Optional<String> tlsServerName() {\n return Codegen.stringProp(\"tlsServerName\").config(config).get();\n }",
"private String getPhysicalDbName() {\n String pdbName =TestConfiguration.getCurrent().getJDBCUrl();\n if (pdbName != null)\n pdbName=pdbName.substring(pdbName.lastIndexOf(\"oneuse\"),pdbName.length());\n else {\n // with JSR169, we don't *have* a protocol, and so, no url, and so\n // we'll have had a null.\n // But we know the name of the db is something like system/singleUse/oneuse#\n // So, let's see if we can look it up, if everything's been properly\n // cleaned, there should be just 1...\n pdbName = (String) AccessController.doPrivileged(new java.security.PrivilegedAction() {\n String filesep = getSystemProperty(\"file.separator\");\n public Object run() {\n File dbdir = new File(\"system\" + filesep + \"singleUse\");\n String[] list = dbdir.list();\n // Some JVMs return null for File.list() when the directory is empty\n if( list != null)\n {\n if(list.length > 1)\n {\n for( int i = 0; i < list.length; i++ )\n {\n if(list[i].indexOf(\"oneuse\")<0)\n continue;\n else\n {\n return list[i];\n }\n }\n // give up trying to be smart, assume it's 0\n return \"oneuse0\";\n }\n else\n return list[0];\n }\n return null;\n }\n });\n \n }\n return pdbName;\n }",
"public String getName() { return _sqlName; }",
"@Override\n\tpublic String getServerName() {\n\t\treturn null;\n\t}",
"@Override\n\tpublic String getServerName() {\n\t\treturn null;\n\t}",
"public String getSysPropertyName() {\n return sysProperty;\n }",
"java.lang.String getField1433();",
"private String getServerDetails() {\n String sServerLine = \"Server: Ramon's Killer \";\n String sSocketType = (bIsSecure ? \"(SECURE)\" : \"(unsecure)\");\n sServerLine = sServerLine + sSocketType + \" Server\";\n return sServerLine;\n }",
"public String getTutRepositoryServerName()\n {\n return tutRepositoryServerName;\n }",
"public String getServerName();",
"String getServerName() {\n return game.z.C;\n }",
"public String getJdbcUser()\n {\n return getStringValue(DataSourceDobj.FLD_JDBC_USER);\n }",
"public String get_vservername() throws Exception {\n\t\treturn this.vservername;\n\t}",
"public String getDbName() {\r\n\t\tif (this.dbname == null)\r\n\t\t\treturn null;\r\n\r\n\t\treturn (String) this.dbname.getSelectedItem();\r\n\t}",
"public String getLockUser() {\n return lockUser;\n }",
"public String getServiceSn() {\n return serviceSn;\n }",
"public String getServerAlias() {\n return serverAlias;\n }",
"public String getWorldName() {\n String worldname = getMapName();\n if (worldname.equals(\"MpServer\")) {\n //This removes the port\n String[] split = getServerName().toLowerCase().split(\":\");\n worldname = split[0];\n }\n return worldname;\n }",
"public String getServerDetails();",
"public String displayNameTickets(){\n String p = \" \";\n try {\n \n rs = stmt.executeQuery \n (\"select * from JEREMY.TICKET ORDER BY NAME\");\n p = loopDBInfo(rs);\n \n } catch (Exception e) {\n System.out.println(\"SQL problem \" + e);\n } \n return p;\n \n }",
"public com.flexnet.opsembedded.webservices.ExternalIdQueryType getServerUniqueId() {\n return serverUniqueId;\n }",
"public String getFullName()\n {\n String schema = db.getSchema();\n return (schema!=null) ? schema+\".\"+name : name;\n }",
"public String getDatabaseName(){\n\treturn strDbName;\n }",
"String getLockOwner();",
"public String getConnectionName() {\n return connectionName;\r\n }",
"public String getServer() {\r\n return server;\r\n }",
"@Override\n public String getBusinessName() {\n\n if(this.businessName == null){\n\n this.businessName = TestDatabase.getInstance().getClientField(token, id, \"businessName\");\n }\n\n return businessName;\n }",
"public String getUsername() {\n return jdbcUsername;\n }",
"public String getServer()\n {\n return server;\n }",
"public String getConnectionDetails() {\n return getName();\n }",
"@Override\n public String getDatabaseName() {\n return mappings.getDatabaseName();\n }",
"public String getName() {\n return this.session.sessionPersona().getRealName();\n }",
"public static String getNetServerHandlerName() {\n \t\treturn getNetServerHandlerClass().getSimpleName();\n \t}",
"String getCassandraName();",
"@NonNull\n public String getServerHostname() {\n return mServerHostname;\n }",
"public static String getSystemName()\n {\n return sSysName;\n }",
"public String getName()\n\t{\n\t\treturn getName( getSession().getSessionContext() );\n\t}",
"public String getStuname() {\n return stuname;\n }",
"@Override\n\tpublic String getJdbcTypeName() {\n\t\tString text = JdbcTypesManager.getJdbcTypes().getTextForCode( getJdbcTypeCode() );\n\t\treturn text != null ? text : \"???\" ;\n\t}",
"public String getServerAddress() {\r\n\t\treturn this.serverAddress;\r\n\t}",
"public Integer getServerId() {\n return serverId;\n }",
"public Integer getServerId() {\n return serverId;\n }",
"public String getConnectionName() {\n return this.connectionName;\n }",
"public String getDbName();",
"public String getIdGeneratorDatabaseUsername(){\n \t\treturn getProperty(\"org.sagebionetworks.id.generator.database.username\");\n \t}",
"public String getMesosMaster() {\n return properties.getProperty(MESOS_LOC_KEY);\n }",
"protected abstract String getPropertyValue(Server instance);",
"public String getUserLoginName() {\n return userLoginName;\n }",
"public String getLoginName() {\r\n return loginName;\r\n }",
"public String getLoginName() {\r\n return loginName;\r\n }",
"public String getClientName ()\n\t{\n\t\treturn clientName;\n\t}",
"public String getClientName() {\r\n return clientName;\r\n }",
"public String getServerErrorCode() {\r\n String toReturn = recentServerErrorCode;\r\n\r\n return toReturn;\r\n }",
"java.lang.String getDatabaseName();",
"java.lang.String getDatabaseName();",
"java.lang.String getDatabaseName();",
"java.lang.String getDatabaseName();",
"public String getClient() throws Exception \n\t{\n\t\tString c=\"null\";\n\t\ttry(Connection connection = DriverManager.getConnection(\"jdbc:mysql://localhost:3306/usersdb?useTimezone=true&serverTimezone=UTC\", \"root\", \"123\");\n\t\t\tPreparedStatement preparedStatement = connection.prepareStatement(\"SELECT clients_username FROM usersdb.bills;\"))\n\t\t{\n\t\t\tResultSet result = preparedStatement.executeQuery();\n\t\t\t\n\t\t\twhile(result.next()) \n\t\t\t{\n\t\t\t\tif(username.equals(result.getString(\"clients_username\"))) \n\t\t\t\t{\n\t\t\t\t\tc = result.getString(\"clients_username\");\n\t\t\t\t\tclient = result.getString(\"clients_username\");\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\tcatch(SQLException e) \n\t\t{\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn c;\n\t}",
"private String getSingleLockSBRStmt() {\n\n if (null == mSingleLockStmt) {\n initClauses();\n mSingleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE s.EUID = ? AND s.REVISIONNUMBER = ? \" + mForUpdateClause;\n }\n\n return mSingleLockStmt;\n }",
"public String getDbName() {\n return dbName;\n }",
"public String getDbName() {\n return dbName;\n }",
"public static String getServer() {\n\t\tif(produccion){\n\t\t\treturn server_produccion;\n\t\t}else{\n\t\t\treturn server;\n\t\t}\t\t\n\t}",
"public String getClientName() {\n return (String)getAttributeInternal(CLIENTNAME);\n }",
"public String vmmServerId() {\n return this.innerProperties() == null ? null : this.innerProperties().vmmServerId();\n }",
"public String getName()\n throws RemoteException, DeadlockException;",
"public String getServerAddress() {\n\t\treturn mServerAddress;\n\t}",
"@Override\n public String toString() {\n return getDbName() + \", \" + getDbHost();\n }",
"public String getOriginalServerId() {\n return originalServerId;\n }",
"public String getRepositoryDatabaseUsername(){\n \t\treturn getProperty(\"org.sagebionetworks.repository.database.username\");\n \t}",
"public String getDetailString()\n {\n String msg = \"{0}, database: {1}, schema: {2}\";\n String unspec = \"<not specified>\";\n String db = StringUtils.isBlank(m_database) ? unspec : m_database;\n String orig = StringUtils.isBlank(m_origin) ? unspec : m_origin;\n return MessageFormat.format(msg, m_jdbcUrl, db, orig);\n }",
"public String getLoginName() {\n return loginName;\n }",
"public String getLoginName() {\n return loginName;\n }",
"public String getLoginName() {\n return loginName;\n }",
"public String getLoginName() {\n return loginName;\n }",
"public String fetchForeignServerName(String tableName) throws SQLException {\n String foreginServerName = null;\n PreparedStatement fetchForeignServerNameStatement = null;\n\n try {\n long tableId = fetchTableId(tableName);\n\n fetchForeignServerNameStatement =\n masterNodeConnection.prepareStatement(FETCH_FOREIGN_SERVER_NAME);\n fetchForeignServerNameStatement.setLong(1, tableId);\n\n ResultSet foreignServerNameResultSet = fetchForeignServerNameStatement.executeQuery();\n\n foreignServerNameResultSet.next();\n foreginServerName = foreignServerNameResultSet.getString(FOREIGN_SERVER_NAME_FIELD);\n\n } finally {\n releaseResources(fetchForeignServerNameStatement);\n }\n\n return foreginServerName;\n }",
"@java.lang.Override\n public java.lang.String getDatabaseName() {\n java.lang.Object ref = databaseName_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n databaseName_ = s;\n return s;\n }\n }",
"@java.lang.Override\n public java.lang.String getDatabaseName() {\n java.lang.Object ref = databaseName_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n databaseName_ = s;\n return s;\n }\n }",
"@java.lang.Override\n public java.lang.String getDatabaseName() {\n java.lang.Object ref = databaseName_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n databaseName_ = s;\n return s;\n }\n }",
"@java.lang.Override\n public java.lang.String getDatabaseName() {\n java.lang.Object ref = databaseName_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n databaseName_ = s;\n return s;\n }\n }",
"public String getJdbcUsername() {\n if(isJakartaNamespace()) {\n return \"jakarta.persistence.jdbc.user\";\n }\n return \"javax.persistence.jdbc.user\";\n }",
"@Override\n\tpublic Object executeDatabaseOperation(Connection conn) throws SQLException {\n\t\tString name = \"\";\n\t\tPreparedStatement sta = conn.prepareStatement(\"select first_name from client where email = ? AND IS_DELETED = 0\");\n\t\t\n\t\tsta.setString(1, this.email);\n\t\t\n\t\tResultSet rs = sta.executeQuery();\n\t\t\n\t\tif (rs.next()) {\n\t\t\tname = rs.getString(1);\n\t\t}\n\t\t\n\t\trs.close();\n\t\tsta.close();\n\t\t\n\t\treturn name;\n\t}",
"public java.lang.String getNAME2()\n {\n \n return __NAME2;\n }",
"public String databaseName() {\n return this.databaseName;\n }"
]
| [
"0.6078156",
"0.6066081",
"0.59527314",
"0.5919755",
"0.5829915",
"0.56983596",
"0.5620478",
"0.5491372",
"0.5433678",
"0.5400942",
"0.5368112",
"0.5358021",
"0.53196234",
"0.5311369",
"0.52942634",
"0.527403",
"0.522195",
"0.5220821",
"0.52022934",
"0.5201974",
"0.5201974",
"0.5199674",
"0.5174995",
"0.5170601",
"0.51661026",
"0.51645315",
"0.51556945",
"0.5150706",
"0.51006967",
"0.5088842",
"0.506742",
"0.50598574",
"0.50451726",
"0.503213",
"0.50254923",
"0.50231755",
"0.50013006",
"0.49952248",
"0.49806786",
"0.49792516",
"0.49788335",
"0.4973227",
"0.49523067",
"0.4950364",
"0.49405104",
"0.49154633",
"0.49129987",
"0.48949963",
"0.48937485",
"0.48902628",
"0.48901117",
"0.48859173",
"0.4883395",
"0.4873679",
"0.4873451",
"0.48693526",
"0.48680007",
"0.48680007",
"0.48634183",
"0.48570046",
"0.48530567",
"0.48446277",
"0.48419517",
"0.4840586",
"0.48375922",
"0.48375922",
"0.48369378",
"0.48362356",
"0.48356152",
"0.48305145",
"0.48305145",
"0.48305145",
"0.48305145",
"0.482616",
"0.4825525",
"0.4824636",
"0.4824636",
"0.4821049",
"0.48130968",
"0.4808024",
"0.48000956",
"0.47957388",
"0.47954494",
"0.47954246",
"0.47941148",
"0.4791501",
"0.47912273",
"0.47912273",
"0.47912273",
"0.47912273",
"0.47781155",
"0.47719213",
"0.47719213",
"0.47719213",
"0.47719213",
"0.4769627",
"0.47664934",
"0.47516337",
"0.47515497"
]
| 0.54741937 | 9 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.SERVER_NAME | public void setServerName(String serverName) {
this.serverName = serverName;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Column(length = 1024)\r\n @PlaceHolder(key = \"host\")\r\n public String getServerName() {\r\n return serverName;\r\n }",
"public void setServerName(String serverName){\n this.serverName = serverName;\n }",
"public void setServerName(String serverName) {\r\n this.serverName = serverName;\r\n }",
"public String getServerName(){\n return this.serverName;\n }",
"public void setServerName(String serverName) {\n this.serverName = serverName == null ? null : serverName.trim();\n }",
"public void setServerName(final String serverName) {\n this.serverName = serverName;\n }",
"public void setSERVER(String SERVER) {\n \t\tthis.SERVER = SERVER;\n \t}",
"public void setServername(String servername) {\r\n this.servername = servername == null ? null : servername.trim();\r\n }",
"public void setDbName(String sDbName);",
"@Override\n\t\tpublic String getServerName() {\n\t\t\treturn null;\n\t\t}",
"public void setBackupServerName(String argName){\n\t backupServerName=argName;\n }",
"@Override\r\n\t\tpublic void setClientInfo(String name, String value)\r\n\t\t\t\tthrows SQLClientInfoException {\n\t\t\t\r\n\t\t}",
"public void setName(final String value)\n\t{\n\t\tsetName( getSession().getSessionContext(), value );\n\t}",
"public String getServername() {\r\n return servername;\r\n }",
"public void setSrvTargetNameValue(YangString srvTargetNameValue)\n throws JNCException {\n setLeafValue(Epc.NAMESPACE,\n \"srv-target-name\",\n srvTargetNameValue,\n childrenNames());\n }",
"public void setName (String name) {\n this.name = name;\n NameRegistrar.register (\"server.\"+name, this);\n }",
"public String getServerName() {\n\t\treturn m_serverName;\n\t}",
"public void setLocksInDb(String value)\n\t{\n\t\tm_locksInDb = new Boolean(value).booleanValue();\n\t}",
"@Override\n\tpublic String getServerName() {\n\t\treturn null;\n\t}",
"@Override\n\tpublic String getServerName() {\n\t\treturn null;\n\t}",
"public void setJdbcUser(String val)\n {\n setValue(DataSourceDobj.FLD_JDBC_USER, val);\n }",
"public String getDBName()\n {\n return dbServer;\n }",
"public String getServerName() {\n return serverName;\n }",
"public String getServerName() {\n return serverName;\n }",
"@Override\n\tpublic Server updateServerName(String tenantId, ServerUpdateReq uReq)\n\t\t\tthrows Exception {\n\t\treturn null;\n\t}",
"public void markSrvTargetNameReplace() throws JNCException {\n markLeafReplace(\"srvTargetName\");\n }",
"public void setSrvTargetNameValue(String srvTargetNameValue)\n throws JNCException {\n setSrvTargetNameValue(new YangString(srvTargetNameValue));\n }",
"public void setTutRepositoryServerName(String tutRepositoryServerName)\n {\n this.tutRepositoryServerName = tutRepositoryServerName;\n }",
"public void addSrvTargetName() throws JNCException {\n setLeafValue(Epc.NAMESPACE,\n \"srv-target-name\",\n null,\n childrenNames());\n }",
"public void setServiceName(java.lang.String param){\n localServiceNameTracker = true;\n \n this.localServiceName=param;\n \n\n }",
"public static server getNameServer(){\n return nameServer;\n }",
"public void setServerAddress(String mDbServerAddress) {\n\t\tthis.mServerAddress = mDbServerAddress;\n\t}",
"public void setOperationName(java.lang.String param){\n localOperationNameTracker = true;\n \n this.localOperationName=param;\n \n\n }",
"public void markSrvTargetNameMerge() throws JNCException {\n markLeafMerge(\"srvTargetName\");\n }",
"public void setDatabaseName(String paramDb){\n\tstrDbName = paramDb;\n }",
"public void setServiceGroupName(java.lang.String param){\n localServiceGroupNameTracker = true;\n \n this.localServiceGroupName=param;\n \n\n }",
"public void setStunServer(String server);",
"public void setLockUser(String lockUser) {\n this.lockUser = lockUser == null ? null : lockUser.trim();\n }",
"public YangString getSrvTargetNameValue() throws JNCException {\n return (YangString)getValue(\"srv-target-name\");\n }",
"@Update(\n \"UPDATE \" + ServeInfoSqlProvider.TABLE_NAME +\n \" SET owner_id = #{ownerId} \" +\n \" WHERE id = #{serveId}\"\n )\n int changeServeOwner(@Param(\"serveId\") Long serveId, @Param(\"ownerId\") Long ownerId);",
"public void setSiteHttpServerName(String pSiteHttpServerName) {\n mSiteHttpServerName = pSiteHttpServerName;\n }",
"protected String getLockManagerName() {\n return getName();\n }",
"public String getServerName() {\n if (server == null) {\n final String version = OpenEjbVersion.get().getVersion();\n final String os = System.getProperty(\"os.name\") + \"/\" + System.getProperty(\"os.version\") + \" (\" + System.getProperty(\"os.arch\") + \")\";\n server = \"OpenEJB/\" + version + \" \" + os;\n }\n return server;\n }",
"public void setServicename(java.lang.String newServicename) {\n\tservicename = newServicename;\n}",
"@Override\n public String getServerDisplayName() {\n return serverDisplayName;\n }",
"public void setDistDbName(String dbName) {\n\t\tthis.setMsgItem(\"dist_db_name\", dbName);\n\t\tdistDbName = dbName;\n\t}",
"public void setObjectName(java.lang.String param){\n localObjectNameTracker = true;\n \n this.localObjectName=param;\n \n\n }",
"public void setDataSourceName(String paramDSName) {\n\tstrDSName = paramDSName;\n }",
"public Builder setServerMs(long value) {\n \n serverMs_ = value;\n onChanged();\n return this;\n }",
"public String getSelectedServerId() {\n return details != null ? StringUtils.stripToNull(details.getArtifactoryName()) : null;\n }",
"public ServerScheduledEventBuilder setName(String name) {\n delegate.setName(name);\n return this;\n }",
"public void setNAME2(java.lang.String value)\n {\n if ((__NAME2 == null) != (value == null) || (value != null && ! value.equals(__NAME2)))\n {\n _isDirty = true;\n }\n __NAME2 = value;\n }",
"public void setMsisdn(java.lang.String param){\n localMsisdnTracker = true;\n \n this.localMsisdn=param;\n \n\n }",
"@Override\n\tprotected final void setFromArgument(CommandContext<ServerCommandSource> context, String name) {\n\t}",
"public Builder setServerTime(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n serverTime_ = value;\n onChanged();\n return this;\n }",
"public Builder setServerAddress(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n serverAddress_ = value;\n onChanged();\n return this;\n }",
"public void setSchedulerName(String schedulerName)\r\n/* 20: */ {\r\n/* 21: 58 */ this.schedulerName = schedulerName;\r\n/* 22: */ }",
"public void setNameSite(String nameSite){\n this.mFarm.setNameSite(nameSite);\n }",
"public void setSpId(java.lang.String param){\r\n \r\n if (param != null){\r\n //update the setting tracker\r\n localSpIdTracker = true;\r\n } else {\r\n localSpIdTracker = false;\r\n \r\n }\r\n \r\n this.localSpId=param;\r\n \r\n\r\n }",
"public void setTestSettings(String testServerAddress) {\n INDEX_NAME = testServerAddress;\n }",
"public void setClientName(String value) {\n setAttributeInternal(CLIENTNAME, value);\n }",
"public String getSERVER() {\n \t\treturn SERVER;\n \t}",
"public String getServerName();",
"public void setServer(Server server) {\n\t\t\r\n\t}",
"public void setHttpServerName(String httpServerName) {\n this.httpServerName = httpServerName;\n }",
"void updateCustomServerAddress(String customServerAddress);",
"protected void addBaseServerNamePropertyDescriptor(Object object) {\n\t\titemPropertyDescriptors.add(createItemPropertyDescriptor(\n\t\t\t\t((ComposeableAdapterFactory) adapterFactory).getRootAdapterFactory(), getResourceLocator(),\n\t\t\t\tgetString(\"_UI_WebsphereServerTask_baseServerName_feature\"),\n\t\t\t\tgetString(\"_UI_PropertyDescriptor_description\", \"_UI_WebsphereServerTask_baseServerName_feature\",\n\t\t\t\t\t\t\"_UI_WebsphereServerTask_type\"),\n\t\t\t\tServerPackage.Literals.WEBSPHERE_SERVER_TASK__BASE_SERVER_NAME, true, false, false,\n\t\t\t\tItemPropertyDescriptor.GENERIC_VALUE_IMAGE, null, null));\n\t}",
"public void setNameValue(String nameValue) throws JNCException {\n setNameValue(new YangString(nameValue));\n }",
"public void setNameValue(String nameValue) throws JNCException {\n setNameValue(new YangString(nameValue));\n }",
"public void setName(String v){\n\t\ttry{\n\t\tsetProperty(SCHEMA_ELEMENT_NAME + \"/name\",v);\n\t\t_Name=null;\n\t\t} catch (Exception e1) {logger.error(e1);}\n\t}",
"UserInfo setName(String name);",
"public void setCustomName ( String name ) {\n\t\texecute ( handle -> handle.setCustomName ( name ) );\n\t}",
"public Builder setDatabaseName(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n databaseName_ = value;\n onChanged();\n return this;\n }",
"public Builder setDatabaseName(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n databaseName_ = value;\n onChanged();\n return this;\n }",
"public Builder setDatabaseName(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n databaseName_ = value;\n onChanged();\n return this;\n }",
"public Builder setDatabaseName(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n databaseName_ = value;\n onChanged();\n return this;\n }",
"public void setNamedId(String dbNameId);",
"public void setInstanceName(final String value)\n {\n instanceName = value;\n }",
"public void setLastName (String ticketLastName)\r\n {\r\n lastName = ticketLastName;\r\n }",
"public void setSenderName(final String value) {\n setProperty(SENDER_NAME_KEY, value);\n }",
"public void setSpid(int param){\n localSpidTracker = true;\n \n this.localSpid=param;\n \n\n }",
"public void setOwnerStatus(String ownerStatus)\n {\n // put your code here\n this.ownerStatus = ownerStatus;\n }",
"public void setDbName(String dbName) {\n this.dbName = dbName;\n }",
"private void setServerList() {\n ArrayList<ServerObjInfo> _serverList =\n ServerConfigurationUtils.getServerListFromFile(mContext, ExoConstants.EXO_SERVER_SETTING_FILE);\n ServerSettingHelper.getInstance().setServerInfoList(_serverList);\n\n int selectedServerIdx = Integer.parseInt(mSharedPreference.getString(ExoConstants.EXO_PRF_DOMAIN_INDEX, \"-1\"));\n mSetting.setDomainIndex(String.valueOf(selectedServerIdx));\n mSetting.setCurrentServer((selectedServerIdx == -1) ? null : _serverList.get(selectedServerIdx));\n }",
"void setParentDriverName(String value)\r\n throws Exception;",
"public Optional<String> tlsServerName() {\n return Codegen.stringProp(\"tlsServerName\").config(config).get();\n }",
"public void setUserName(java.lang.String value) {\n\t\tsetValue(org.jooq.examples.oracle.sys.packages.dbms_xplan.DiffPlanOutline.USER_NAME, value);\n\t}",
"public void markSrvTargetNameCreate() throws JNCException {\n markLeafCreate(\"srvTargetName\");\n }",
"public native final void setServerType(String serverType)/*-{\n this.serverType = serverType;\n }-*/;",
"public void setSystemIdentifier(gov.ucore.ucore._2_0.StringType systemIdentifier)\n {\n synchronized (monitor())\n {\n check_orphaned();\n gov.ucore.ucore._2_0.StringType target = null;\n target = (gov.ucore.ucore._2_0.StringType)get_store().find_element_user(SYSTEMIDENTIFIER$0, 0);\n if (target == null)\n {\n target = (gov.ucore.ucore._2_0.StringType)get_store().add_element_user(SYSTEMIDENTIFIER$0);\n }\n target.set(systemIdentifier);\n }\n }",
"public void setOwner( String owner ){\r\n \ttry{\r\n \t\t_lockObject.lock();\r\n \t_owner = owner;\r\n \t_itDepartment.setDirector(_owner);\r\n \t}finally{\r\n \t\t_lockObject.unlock();\r\n \t}\r\n }",
"public void setServiceId(java.lang.String param){\r\n \r\n if (param != null){\r\n //update the setting tracker\r\n localServiceIdTracker = true;\r\n } else {\r\n localServiceIdTracker = false;\r\n \r\n }\r\n \r\n this.localServiceId=param;\r\n \r\n\r\n }",
"public void setName(String name)\r\n/* */ {\r\n/* 137 */ this.name = name;\r\n/* */ }",
"public void setName(final SessionContext ctx, final String value)\n\t{\n\t\tsetProperty(ctx, NAME,value);\n\t}",
"public void setManager(String manager) {\n\n if (manager.isEmpty()) {\n\n System.out.println(\"Manager must not be empty\");\n /**\n * If Owner manager is ever an empty String, a NullPointerException will be thrown when the\n * listings are loaded in from the JSON file. I believe this is because the JSON parser we're\n * using stores empty Strings as \"null\" in the .json file. TODO this fix is fine for now, but\n * I want to make it safer in the future.\n */\n this.manager = \" \";\n } else {\n\n this.manager = manager;\n }\n }",
"public void setServer (\r\n String strServer) throws java.io.IOException, com.linar.jintegra.AutomationException;",
"public static void set_SetName(String v) throws RuntimeException\n {\n UmlCom.send_cmd(CmdFamily.javaSettingsCmd, JavaSettingsCmd._setJavaSetNameCmd, v);\n UmlCom.check();\n \n _set_name = v;\n }",
"public void setServer(int server) {\n this.server = server;\n }",
"public void setBundleName(java.lang.String param){\n localBundleNameTracker = true;\n \n this.localBundleName=param;\n \n\n }",
"public void setStuname(String stuname) {\n this.stuname = stuname == null ? null : stuname.trim();\n }"
]
| [
"0.57876796",
"0.5659852",
"0.5493197",
"0.5407421",
"0.53928405",
"0.53810024",
"0.5341607",
"0.51190954",
"0.50897217",
"0.50871783",
"0.5077672",
"0.50718766",
"0.5048043",
"0.5030893",
"0.5010979",
"0.5008728",
"0.49850306",
"0.49298006",
"0.49196553",
"0.49196553",
"0.4896101",
"0.48803508",
"0.48794952",
"0.48794952",
"0.48713592",
"0.48650977",
"0.4849018",
"0.48449376",
"0.48356423",
"0.48266342",
"0.48231852",
"0.48199695",
"0.47803757",
"0.47683218",
"0.47683036",
"0.4744691",
"0.47185954",
"0.46802747",
"0.46673498",
"0.46417388",
"0.4592867",
"0.45770672",
"0.4571375",
"0.45607015",
"0.45587143",
"0.45452335",
"0.4536344",
"0.4528641",
"0.45239034",
"0.45234153",
"0.45224273",
"0.45210302",
"0.4510848",
"0.44997287",
"0.44743484",
"0.44717595",
"0.44709367",
"0.44697708",
"0.4463227",
"0.44614047",
"0.44604042",
"0.44537264",
"0.4448614",
"0.4439706",
"0.44277295",
"0.44263485",
"0.44247842",
"0.44186518",
"0.44186518",
"0.44156933",
"0.44127372",
"0.4409858",
"0.4409679",
"0.4409679",
"0.4409679",
"0.4409679",
"0.44065845",
"0.44032553",
"0.4400412",
"0.4399624",
"0.43995753",
"0.43974677",
"0.4397443",
"0.43919548",
"0.438053",
"0.43707725",
"0.43654007",
"0.4363526",
"0.43605858",
"0.43556046",
"0.43535712",
"0.43520498",
"0.43505788",
"0.4349388",
"0.43491942",
"0.4345558",
"0.43426454",
"0.43395415",
"0.43374208",
"0.43298745"
]
| 0.53890914 | 5 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.LOCK_NUM | public Long getLockNum() {
return lockNum;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Long getOtherLockNum() {\n return otherLockNum;\n }",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"public String getLockId() {\n return lockId;\n }",
"public long getLockStatus() {\r\n return lockStatus;\r\n }",
"public int getLockon() {\r\n return lockon;\r\n }",
"public String getLockType() {\n return this.lockType;\n }",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"public int getLockAddress() {\n\t\treturn 0;\n\t}",
"public Long getLock_latency() {\n return lock_latency;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Long getOrderNo () {\r\n\t\treturn orderNo;\r\n\t}",
"public String getWaiting_lock_duration() {\n return waiting_lock_duration;\n }",
"public String getLockUser() {\n return lockUser;\n }",
"public long getSequenceNo() {\n\treturn sequenceNo;\n }",
"private long getReserveRecNo() {\n\t\tfinal int selectedRow = this.clientUI.getSelectedRowNo();\n\t\treturn this.model.getRecNo(selectedRow);\n\t}",
"public Long getBillDtlNo() {\n return billDtlNo;\n }",
"public Integer getRowNo() {\n return rowNo;\n }",
"public Long getBillNo() {\n return billNo;\n }",
"public AtomicInteger getSerialNo() {\n return serialNo;\n }",
"public java.lang.String getXlock () {\n\t\treturn xlock;\n\t}",
"@Override\n public int getTxTimeoutInMillis() {\n return Globals.lockingTimeout;\n }",
"@Version\r\n @Column(name=\"optlock\")\r\n public Integer getVersion()\r\n {\r\n return version;\r\n }",
"public Long getCreditNum() {\n return creditNum;\n }",
"private String getSingleLockSBRStmt() {\n\n if (null == mSingleLockStmt) {\n initClauses();\n mSingleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE s.EUID = ? AND s.REVISIONNUMBER = ? \" + mForUpdateClause;\n }\n\n return mSingleLockStmt;\n }",
"public int getSerialNum()\r\n\t{\r\n\t\treturn(serialNum);\r\n\t}",
"public String isLockedFor() {\n return (lockId == null ? \"\" : lockId);\n }",
"protected String getLockManagerName() {\n return getName();\n }",
"public void setOtherLockNum(Long otherLockNum) {\n this.otherLockNum = otherLockNum;\n }",
"public long getSeqNo() {\n return seqNo;\n }",
"public BigDecimal getSERIAL_NO() {\r\n return SERIAL_NO;\r\n }",
"public BigDecimal getSERIAL_NO() {\r\n return SERIAL_NO;\r\n }",
"final public Lock test_get_lock() {\r\n\t\treturn lock_;\r\n\t}",
"public java.lang.String getTicketNo () {\r\n\t\treturn ticketNo;\r\n\t}",
"public long gettNum() {\n return tNum;\n }",
"public long getnNum() {\n return nNum;\n }",
"public java.lang.Long getTransNo () {\r\n\t\treturn transNo;\r\n\t}",
"public NM getSessionNo() { \r\n\t\tNM retVal = this.getTypedField(28, 0);\r\n\t\treturn retVal;\r\n }",
"@ManyToOne\n\t@JoinColumn(name=\"LockStatus\", nullable=false)\n\t@Fetch(FetchMode.SELECT)\n\t@NotFound(action=NotFoundAction.IGNORE)\n\tpublic AccessStatus getLockStatus() {\n\t\treturn this.lockStatus;\n\t}",
"public long getSerial() {\n\t\treturn this.serialNumber;\n\t}",
"public String getWaiting_lock_type() {\n return waiting_lock_type;\n }",
"public String getBlocking_lock_duration() {\n return blocking_lock_duration;\n }",
"public String getSerialNo() {\n\t\treturn serialNo;\n\t}",
"public Integer getMonitorNum() {\n return monitorNum;\n }",
"int getTransactionNum();",
"public Dao<Lock, Integer> getLockDao() throws SQLException {\n\t\tif (lockDao == null) {\n\t\t\tlockDao = getDao(Lock.class);\n\t\t}\n\t\treturn lockDao;\n\t}",
"public Date getLockTime() {\n\t\treturn lockTime;\n\t}",
"@Override\r\n\tpublic int getEnterNo() {\n\t\treturn session.selectOne(\"enter.getEnterNo\");\r\n\t}",
"public boolean getlock()\r\n\t{\r\n\t\tif(cnt > 10)\r\n\t\t{\r\n\t\t\tcnt = 0;\r\n\t\t\treturn unlocked;\r\n\t\t}\r\n\t\treturn false;\r\n\t}",
"public String serialNumber() {\n return this.innerProperties() == null ? null : this.innerProperties().serialNumber();\n }",
"@Override\n\tpublic LockThreadInfo mapRow(ResultSet rs, int rowNum) throws SQLException {\n\t\tLockThreadInfo lockThreadInfo = new LockThreadInfo(rs.getString(\"tid\"), rs.getString(\"nid\"), rs.getString(\"state\"));\n\t\treturn lockThreadInfo;\n\t}",
"public long getComNumber() {\r\n return comNumber;\r\n }",
"public ApplicationLockLevel lockLevel() {\n return this.lockLevel;\n }",
"long getLockOwnersID(String uuid) throws DatabaseException;",
"public int getStatus(String serialNumber){\n return myDatabase.getStatus(serialNumber);\n }",
"public Lock getLock() {\n return lock;\n }",
"public Lock getLock();",
"public Long getReceiveNum() {\r\n return receiveNum;\r\n }",
"public int getAccountNo()\r\n\t{\r\n\t\t\r\n\t\treturn accountNo;\r\n\t\t\r\n\t}",
"@Nullable\n public Integer getSerialNumber() {\n return serialNumber;\n }",
"public String getOrderSeqNo() {\n return orderSeqNo;\n }",
"public int getSerialNumber() {\n\t\treturn serialNumber;\n\t}",
"public long getNumber(){\n return number;\r\n }",
"public int getCPTLNO() {\n return cptlno;\n }",
"private Integer getSequence() {\r\n\t\t\tInteger seq;\r\n\t\t\tString sql = \"select MAX(vendorid)from vendorTable\";\r\n\t\t\tseq = template.queryForObject(sql, new Object[] {}, Integer.class);\r\n\t\t\treturn seq;\r\n\t\t}",
"public RuntimeExceptionDao<Lock, Integer> getLockDataDao() {\n\t\tif (lockRuntimeDao == null) {\n\t\t\tlockRuntimeDao = getRuntimeExceptionDao(Lock.class);\n\t\t}\n\t\treturn lockRuntimeDao;\n\t}",
"public String getSysNo() {\n return sysNo;\n }",
"Lock getLock(String lockName);",
"public long getVersionNo() {\r\n return versionNo;\r\n }",
"public long getaNum() {\n return aNum;\n }",
"public java.lang.Long getPosTransNo () {\r\n\t\treturn posTransNo;\r\n\t}",
"@Transient\n\tpublic long getTransactionIdLong() {\n\t\treturn mTransactionIdLong;\n\t}",
"public Integer getCocSerialNo() {\n\t\treturn cocSerialNo;\n\t}",
"@Override\n \tpublic long getLatestSequenceNumber() {\n \t\tsharedLock.lock();\n \t\ttry {\n \t\t\treturn sequenceNumber;\n \t\t} finally {\n \t\t\tsharedLock.unlock();\n \t\t}\n \t}",
"public String getNumber() {\n return this.mNumber;\n }",
"@Override\n\tpublic Lock getLock() {\n\t\treturn this.lock;\n\t}",
"protected final Object getTreeLock() {\n return Component.LOCK;\n }",
"private Integer getLockFromId(long lockId)\n throws IOException {\n if(lockId == -1L) {\n return null;\n }\n String lockName = String.valueOf(lockId);\n Integer rl = null;\n synchronized(rowlocks) {\n rl = rowlocks.get(lockName);\n }\n if(rl == null) {\n throw new IOException(\"Invalid row lock\");\n }\n this.leases.renewLease(lockName);\n return rl;\n }",
"public java.lang.String getLocalLock() {\r\n return localLock;\r\n }",
"public java.math.BigInteger getSerialNumber() {\r\n return serialNumber;\r\n }",
"public void setLockStatus(long lockStatus) {\r\n this.lockStatus = lockStatus;\r\n }",
"public int getLBR_SeqNumberInBank_ID () \n\t{\n\t\tInteger ii = (Integer)get_Value(COLUMNNAME_LBR_SeqNumberInBank_ID);\n\t\tif (ii == null)\n\t\t\t return 0;\n\t\treturn ii.intValue();\n\t}",
"public BookingLockDetails getBookingLockDetails(com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.bookinglockdetails.v1.BookingLockDetails res){\n\t\tBookingLockDetails bookingLockDetails = new BookingLockDetails();\n\t\t\n\t\tbookingLockDetails.setBookingNo( res.getBookingNo() );\n\t\tbookingLockDetails.setLockId( res.getLockId() );\n\t\tbookingLockDetails.setLockMessage( res.getLockMessage() );\n\t\tif( res.isAlreadyLocked() != null ){\n\t\t\tbookingLockDetails.setAlreadyLocked( res.isAlreadyLocked().booleanValue() );\n\t\t}\n\t\tif( res.isAdmin() != null ){\n\t\t\tbookingLockDetails.setAdmin( res.isAdmin().booleanValue() );\n\t\t}\n\t\t\n\t\treturn bookingLockDetails;\n\t}",
"public String getLockedUserId() {\n\t\treturn lockedUserId;\n\t}",
"public BigInteger getSerialNumber() {\n return serialNumber;\n }",
"public long getSequenceNum() {\n return sequenceNum;\n }",
"public int getAccountNo() {\n return accountNo;\n }",
"public int getNewNumber() {\r\n int num;\r\n num=unusedLockers.get(0);\r\n unusedLockers.remove(0);\r\n return num;\r\n }",
"protected RowLock getUpdateLockType() \n {\n\t\treturn(RowLock.RU3);\n }",
"private String getDoubleLockSBRStmt() {\n\n if (null == mDoubleLockStmt) {\n initClauses();\n mDoubleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE ( s.EUID = ? AND s.REVISIONNUMBER = ?) OR ( s.EUID = ? AND s.REVISIONNUMBER = ?)\" + mForUpdateClause;\n }\n\n return mDoubleLockStmt;\n }",
"public Integer getVersionNo() {\r\n\t\treturn versionNo;\r\n\t}",
"public String getLstCustNo() {\n return lstCustNo;\n }",
"public final long lock() {\n explicitlyLocked = true;\n return byteBase.longLockPointer();\n }",
"public Number getSequenceNo() {\n return (Number)getAttributeInternal(SEQUENCENO);\n }",
"public int getNum() {\n return this.num;\n }",
"public Long getChangeNum() {\n return changeNum;\n }",
"long getSeqnum();",
"long getSeqnum();"
]
| [
"0.63157725",
"0.6218543",
"0.576415",
"0.5720919",
"0.56742936",
"0.55929816",
"0.5544176",
"0.5468113",
"0.5397154",
"0.53803426",
"0.5314445",
"0.5314445",
"0.5314445",
"0.52524996",
"0.5221379",
"0.52021956",
"0.5201427",
"0.5191612",
"0.51797885",
"0.51423496",
"0.5137503",
"0.51318777",
"0.51311165",
"0.5123767",
"0.51157624",
"0.5101967",
"0.5095503",
"0.5065833",
"0.50647557",
"0.50638956",
"0.5059594",
"0.5052441",
"0.50523865",
"0.50523865",
"0.5046504",
"0.5034647",
"0.503228",
"0.5013403",
"0.4997552",
"0.49887657",
"0.49815693",
"0.4979329",
"0.49750844",
"0.49512264",
"0.49381065",
"0.4936199",
"0.49334633",
"0.49331555",
"0.49303302",
"0.49238577",
"0.49024993",
"0.48961967",
"0.48899144",
"0.48894683",
"0.48855934",
"0.48822358",
"0.48786202",
"0.4874923",
"0.48733267",
"0.48638806",
"0.48635638",
"0.48623058",
"0.48491663",
"0.48442483",
"0.48414135",
"0.48401275",
"0.48240325",
"0.48129743",
"0.48103437",
"0.4807789",
"0.4807507",
"0.48016357",
"0.47957495",
"0.47820553",
"0.47728878",
"0.4771344",
"0.47682154",
"0.47681737",
"0.47678894",
"0.47615218",
"0.4760758",
"0.47596225",
"0.47579557",
"0.47573704",
"0.4755049",
"0.47540218",
"0.47531903",
"0.47520092",
"0.47511736",
"0.4743629",
"0.47334048",
"0.47294313",
"0.4726814",
"0.47198862",
"0.47189733",
"0.4713962",
"0.47133073",
"0.47130448",
"0.4708458",
"0.4708458"
]
| 0.7061703 | 0 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.LOCK_NUM | public void setLockNum(Long lockNum) {
this.lockNum = lockNum;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Long getLockNum() {\n return lockNum;\n }",
"public void setOtherLockNum(Long otherLockNum) {\n this.otherLockNum = otherLockNum;\n }",
"public void setLockKey( Long lockKey ) {\n this.lockKey = lockKey;\n }",
"public void setLockStatus(long lockStatus) {\r\n this.lockStatus = lockStatus;\r\n }",
"public void setCreditNum(Long creditNum) {\n this.creditNum = creditNum;\n }",
"public Long getOtherLockNum() {\n return otherLockNum;\n }",
"public void setLockFlag(Integer aLockFlag) {\n lockFlag = aLockFlag;\n }",
"public void setLockFlag(Integer aLockFlag) {\n lockFlag = aLockFlag;\n }",
"public void setLockFlag(Integer aLockFlag) {\n lockFlag = aLockFlag;\n }",
"public void setSequenceNo(long n) {\n\tsequenceNo = n;\n }",
"public void setOrderNo (Long orderNo) {\r\n\t\tthis.orderNo = orderNo;\r\n\t}",
"void set_num(ThreadContext tc, RakudoObject classHandle, double Value);",
"public void setComNumber(long value) {\r\n this.comNumber = value;\r\n }",
"public void setTestNo(Long testNo) {\n this.testNo = testNo;\n }",
"public void setSequenceNumberForHibernate(INT sequenceNumber) {\n _sequenceNumber = sequenceNumber;\n }",
"public void setReceiveNum(Long receiveNum) {\r\n this.receiveNum = receiveNum;\r\n }",
"@Override\n\tprotected void unLockNbr() {\n\t\t\n\t}",
"private void setLock(int tid, int varIndex, Lock.Type type) {\n List<Lock> lockList = null;\n if (_lockTable.containsKey(varIndex)) {\n lockList = _lockTable.get(varIndex);\n lockList.add(new Lock(tid, type));\n } else {\n lockList = new ArrayList<Lock>();\n lockList.add(new Lock(tid, type));\n _lockTable.put(varIndex, lockList);\n }\n }",
"@Override\n public void setAtomicNumber(int atomicNumber) {\n }",
"public void setLock_latency(Long lock_latency) {\n this.lock_latency = lock_latency;\n }",
"public void SetIsLock(boolean isLock)\n {\n this._lock = isLock;\n }",
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"public void setNumToProcess(long aNumToProcess) {\n numToProcess = aNumToProcess;\n }",
"public void setNUMSEC(int value) {\n this.numsec = value;\n }",
"public void setNUMSEC(int value) {\n this.numsec = value;\n }",
"public void setNUMSEC(int value) {\n this.numsec = value;\n }",
"public void setCLNO(int value) {\n this.clno = value;\n }",
"public final void setOrderNumber(Long ordernumber)\r\n\t{\r\n\t\tsetOrderNumber(getContext(), ordernumber);\r\n\t}",
"public void setSerialNum(String serialNum)\r\n\t{\r\n\t\tthis.serialNum = serialNum;\r\n\t}",
"public void setSequenceNo(Number value) {\n setAttributeInternal(SEQUENCENO, value);\n }",
"public void setLockId(String lockId) {\n this.lockId = lockId;\n }",
"@Override\n public void setTxTimeoutInMillis(int ms) {\n Globals.lockingTimeout = ms;\n }",
"@Override\n\tpublic void setMinnum(long minnum) {\n\t\t_esfTournament.setMinnum(minnum);\n\t}",
"public void setBillNo(Long billNo) {\n this.billNo = billNo;\n }",
"public void setMonitorNum(Integer monitorNum) {\n this.monitorNum = monitorNum;\n }",
"void lock(Connection con, EnterpriseObject eo, String revisionNumber,\n boolean lock) throws DataModifiedException {\n try {\n if ((!lock) || (eo == null) || (con.getAutoCommit())) {\n return; // no locking, no revision update\n\n }\n SBR sbr = eo.getSBR();\n String euid = eo.getEUID();\n if (revisionNumber != null) {\n lockSBR(con, euid, revisionNumber);\n } else {\n Integer curRevisionNumber = sbr.getRevisionNumber();\n lockSBR(con, euid, curRevisionNumber);\n }\n sbr.setRevisionNumber(sbr.getRevisionNumber().intValue() + 1);\n } catch (ObjectException ex) {\n throw new DataModifiedException(mLocalizer.t(\"OPS525: Could not lock \" +\n \"EnterpriseObject: {0}\", ex));\n } catch (SQLException se) {\n throw new DataModifiedException(mLocalizer.t(\"OPS526: Could not lock \" +\n \"EnterpriseObject: {0}\", se));\n }\n }",
"public void setSerialNo(String serialNo) {\n inputParameters.Serial_No = serialNo;\n\n }",
"public void setSERIAL_NO(BigDecimal SERIAL_NO) {\r\n this.SERIAL_NO = SERIAL_NO;\r\n }",
"public void setSERIAL_NO(BigDecimal SERIAL_NO) {\r\n this.SERIAL_NO = SERIAL_NO;\r\n }",
"public void setSeqNo (int SeqNo);",
"public void setSeqNo (int SeqNo);",
"public void setLocksInDb(String value)\n\t{\n\t\tm_locksInDb = new Boolean(value).booleanValue();\n\t}",
"public void setLockOnChangeMode(LockOnChange lockOnChangeMode){\r\n this.lockOnChangeMode = lockOnChangeMode;\r\n }",
"public void setNum(int num) {\r\n this.num = num;\r\n }",
"public void setTicketNo (java.lang.String ticketNo) {\r\n\t\tthis.ticketNo = ticketNo;\r\n\t}",
"void setLong(int index, long value) throws SQLException;",
"public void setRowNumber(int number){\r\n\t\trowNumber = number;\r\n\t}",
"public void setRowNumber(int number){\r\n\t\trowNumber = number;\r\n\t}",
"public void setNumber(int number) {\r\n\t\tthis.num = number;\r\n\t}",
"protected void setStudentNumber(Integer studentNum)\n {\n studentNumber = studentNum;\n }",
"public static void setLockManagerActorRef(ActorRef lockManager) {\n\t\tglobalLockManagerActorRef = lockManager;\n\t}",
"public void setSequenceNumber(long value) {\n this.sequenceNumber = value;\n }",
"public void setRowNo(Integer rowNo) {\n this.rowNo = rowNo;\n }",
"void setNumber(int num) {\r\n\t\tnumber = num;\r\n\t}",
"public void setLockUser(String lockUser) {\n this.lockUser = lockUser == null ? null : lockUser.trim();\n }",
"public String getLockId() {\n return lockId;\n }",
"public void setUserSeqNbr(Long userSeqNbr) \n\t{\n\t\tthis.userSeqNbr = userSeqNbr;\n\t}",
"public void setAccountNo(int number){\n\t\taccountNo = number;\n\t}",
"public void setUserSeqNbr(Long userSeqNbr)\n\t{\n\t\tthis.userSeqNbr = userSeqNbr;\n\t}",
"public void setLong(String parName, long parVal) throws HibException;",
"public void setNum(int num) {\n\t\tthis.num = num;\n\t}",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"public void setSerialNumber(java.math.BigInteger serialNumber) {\r\n this.serialNumber = serialNumber;\r\n }",
"public void setNum(Integer num) {\n this.num = num;\n }",
"public void setNum(Integer num) {\n this.num = num;\n }",
"public void setLockUserid(String lockUserid) {\n\t\tthis.lockUserid = lockUserid == null ? null : lockUserid.trim();\n\t}",
"public void setTransNo (java.lang.Long transNo) {\r\n\t\tthis.transNo = transNo;\r\n\t\tthis.hashCode = Integer.MIN_VALUE;\r\n\t}",
"public int getLockAddress() {\n\t\treturn 0;\n\t}",
"public void setCodigo() throws SQLException {\n try (PreparedStatement query = Herramientas.getConexion().prepareStatement(\"SELECT MAX(codigo_ticket) FROM ticket\"); \n ResultSet resultado = query.executeQuery()) {\n resultado.next();\n this.codigo = (resultado.getInt(1))+1;\n }\n \n }",
"public void setSerialNo(String serialNo) {\n\t\tthis.serialNo = serialNo;\n\t}",
"@Override public void checkpointReadLockTimeout(long val) {\n checkpointReadLockTimeout = val;\n }",
"public void setNUM_DB(int NUM_DB) \r\n {\r\n if(NUM_DB > 0)\r\n this.NUM_DB = NUM_DB;\r\n }",
"public long getLockStatus() {\r\n return lockStatus;\r\n }",
"public int getLockon() {\r\n return lockon;\r\n }",
"public void setTmpLock(boolean tmpLock) {\n \t\tthis.tmpLock = tmpLock;\n \t}",
"public void setSMNR(java.math.BigInteger SMNR) {\n this.SMNR = SMNR;\n }",
"void setSequenceNumber(int sequenceNumber);",
"public static void setRowNumber(int pRowNumber) {\r\n\t\trowNumber = pRowNumber;\r\n\t}",
"public void setBillDtlNo(Long billDtlNo) {\n this.billDtlNo = billDtlNo;\n }",
"public String getLockType() {\n return this.lockType;\n }",
"public void setSale_num(Integer sale_num) {\n this.sale_num = sale_num;\n }",
"@Override\n\tpublic LockThreadInfo mapRow(ResultSet rs, int rowNum) throws SQLException {\n\t\tLockThreadInfo lockThreadInfo = new LockThreadInfo(rs.getString(\"tid\"), rs.getString(\"nid\"), rs.getString(\"state\"));\n\t\treturn lockThreadInfo;\n\t}",
"public void setSeqNbr(int seqNbr) {\n this.seqNbr = seqNbr;\n }",
"public void setLockTime(Date lockTime) {\n\t\tthis.lockTime = lockTime;\n\t}",
"public void setTransactionID(long value) {\r\n this.transactionID = value;\r\n }",
"public void setSeqNo (java.lang.Integer seqNo) {\n\t\tthis.seqNo = seqNo;\n\t}",
"public void setChangeNum(Long changeNum) {\n this.changeNum = changeNum;\n }",
"public void setLotNo(int inLotNo) {\r\n\t\tlotNo = inLotNo;\r\n\t}",
"@Override\n public void cUSerialNumber(long value) {\n //throw new UnsupportedOperationException(\"Not supported yet.\"); //To change body of generated methods, choose Tools | Templates.\n }",
"@Override\n public void setLockOwner(Object lockOwner) {\n }",
"public final void setNum_emp(String val) {\n setString(getNum_empAttribute(getMtDatabase()), val);\n }",
"public void set_next_local_commitment_number(long val) {\n\t\tbindings.ChannelReestablish_set_next_local_commitment_number(this.ptr, val);\n\t}",
"void setSpinCount(long spinCount);",
"public void setVersionNumber(Long versionNumber){\r\n this.versionNumber = versionNumber;\r\n }",
"public void setVersionNumber(Long versionNumber){\r\n this.versionNumber = versionNumber;\r\n }",
"public void setLockEnabled(boolean lockEnabled) {\r\n\t\tthis.lockEnabled = lockEnabled;\r\n\t}",
"public void setOrderSeqNo(String orderSeqNo) {\n this.orderSeqNo = orderSeqNo;\n }",
"public void setLong(int parameterIndex, long x) throws SQLException {\n currentPreparedStatement.setLong(parameterIndex, x);\n\n }",
"public void setNum (java.lang.Integer num) {\r\n\t\tthis.num = num;\r\n\t}",
"public void setNumber(int number)\n {\n Number = number;\n }"
]
| [
"0.612606",
"0.5999024",
"0.5840665",
"0.5773736",
"0.5517215",
"0.5443086",
"0.53247464",
"0.53247464",
"0.53247464",
"0.53223145",
"0.5301006",
"0.5218512",
"0.5177841",
"0.510431",
"0.5058694",
"0.5027298",
"0.50106436",
"0.50104016",
"0.49908704",
"0.49766725",
"0.49571344",
"0.49407947",
"0.49407658",
"0.49359214",
"0.49359214",
"0.49359214",
"0.49315295",
"0.49307021",
"0.4923465",
"0.49197",
"0.4919164",
"0.4916939",
"0.49165422",
"0.49140862",
"0.49060515",
"0.49024346",
"0.4902416",
"0.4877687",
"0.4877687",
"0.48699266",
"0.48699266",
"0.48503017",
"0.48485246",
"0.483889",
"0.4830816",
"0.48108277",
"0.48002896",
"0.48002896",
"0.47983602",
"0.47965834",
"0.47958854",
"0.47956604",
"0.47922987",
"0.47922125",
"0.47910836",
"0.47903693",
"0.4789761",
"0.47817904",
"0.4778048",
"0.47579908",
"0.47569615",
"0.47531986",
"0.47483432",
"0.47443146",
"0.47443146",
"0.47382534",
"0.47176817",
"0.47081953",
"0.4701409",
"0.46944723",
"0.46937022",
"0.46935955",
"0.46912998",
"0.4682447",
"0.4670782",
"0.46604657",
"0.46600983",
"0.46556252",
"0.46493518",
"0.46323064",
"0.46311316",
"0.46238554",
"0.46227896",
"0.46221644",
"0.46164653",
"0.46122605",
"0.46063945",
"0.4604591",
"0.46018255",
"0.45912898",
"0.45853797",
"0.4576114",
"0.45741013",
"0.4566491",
"0.4566491",
"0.45640314",
"0.45616803",
"0.45565358",
"0.45543125",
"0.45325622"
]
| 0.72441286 | 0 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.CHANGE_NUM | public Long getChangeNum() {
return changeNum;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setChangeNum(Long changeNum) {\n this.changeNum = changeNum;\n }",
"public String getOldNum(){\n return cal.getOldNum();\n }",
"public int getChangeType() {\r\n return changeType;\r\n }",
"@Override\n public int getColChange() {\n return colChange;\n }",
"@javax.annotation.Nullable\n public String getChange() {\n return change;\n }",
"public long getStateChange() {\n return stateChange_;\n }",
"public long getStateChange() {\n return stateChange_;\n }",
"public int getChangeMessageIndex() {\n return changeMessageIndex;\n }",
"public I getChangeInfo(int startSeqNum);",
"public int getHC_JobDataChange_ID();",
"long getChangeset();",
"public java.lang.Long getTransNo () {\r\n\t\treturn transNo;\r\n\t}",
"public Long getLockNum() {\n return lockNum;\n }",
"public double getChange() \n\t{\n\t\treturn purchase.getPayment().getChange();\n\t}",
"@Override\n public int getRowChange() {\n return rowChange;\n }",
"@NotNull\n @JsonProperty(\"change\")\n public String getChange();",
"@NotNull\n @JsonProperty(\"change\")\n public String getChange();",
"@NotNull\n @JsonProperty(\"change\")\n public String getChange();",
"public BigDecimal getREF_NO() {\r\n return REF_NO;\r\n }",
"public int getBSCA_PriceChangePrev_ID();",
"int getTransactionNum();",
"public static WTChangeOrder2 getChangeNoticeByNumber(String sCNNumber) throws WTException \r\n\t{\n\t QuerySpec qs = new QuerySpec(WTChangeOrder2.class);\r\n\t SearchCondition condition = new SearchCondition(WTChangeOrder2.class, WTChangeOrder2.NUMBER, SearchCondition.EQUAL, sCNNumber);\r\n\t qs.appendWhere(condition, new int[]{0});\r\n\t QueryResult qr = PersistenceHelper.manager.find((StatementSpec)qs);\r\n\t WTChangeOrder2 cn = null;\r\n\t WTChangeOrder2 cn2 = null;\r\n\t\twhile(qr.hasMoreElements())\r\n\t\t{\r\n\t\t\tcn = (WTChangeOrder2)qr.nextElement();\r\n\t\t\tbreak;\r\n\t\t}\r\n\t\tif(cn != null)\r\n\t\t{\r\n\t\t\tQueryResult qr2 = VersionControlHelper.service.allVersionsOf(cn);\r\n\t\t\tcn2= (WTChangeOrder2)qr2.nextElement();\r\n\t\t}\r\n\t\t\r\n\t\t\r\n\t\treturn cn2;\r\n\t}",
"String transactionChangeString() {\n return transaction_mod_list.toString();\n }",
"public String getTenderResultIdChangeCode() {\n return tenderResultIdChangeCode;\n }",
"public final long getChangeDateTime() {\n \treturn m_changeDate;\n }",
"public Long getOtherLockNum() {\n return otherLockNum;\n }",
"public Long getBillNo() {\n return billNo;\n }",
"public long getVersionNo() {\r\n return versionNo;\r\n }",
"private int dbChanges(SQLiteDatabase db) {\n String SELECT_CHANGE = \"SELECT total_changes()\";\n Boolean success = true;\n int ret = Integer.valueOf(-1);\n try {\n Cursor cursor = db.rawQuery(SELECT_CHANGE, null);\n if (cursor != null) {\n if (cursor.moveToFirst()) {\n ret = Integer.parseInt(cursor.getString(0));\n }\n }\n cursor.close();\n } catch (Exception e) {\n Log.d(TAG, \"Error: dbChanges failed: \", e);\n } finally {\n return ret;\n }\n }",
"public Integer getVersionNo() {\r\n\t\treturn versionNo;\r\n\t}",
"public synchronized int getCommitNumber()\n\t{\n\t\treturn m_dbCommitNum;\n\t}",
"public java.lang.String getChangeOperation() {\r\n return changeOperation;\r\n }",
"public int getChange() {\n\t\treturn player.getDay(0).calculateChangeFactor();\n\t\t\n\t}",
"public Long getOrderNo () {\r\n\t\treturn orderNo;\r\n\t}",
"int getConversionsNumber() throws SQLException;",
"public int getMultChanged() {\r\n\t\treturn this.multChanged;\r\n\t}",
"public Double getChange(int in);",
"public long getSequenceNo() {\n\treturn sequenceNo;\n }",
"public String getLastChange() {\n return lastChange;\n }",
"public static long getLastDatabaseChangeTimeStamp() {\r\n \t\treturn DatabaseIntegrityManager.lastChangeTimeStampInMillis;\r\n \t}",
"public Integer getRowNo() {\n return rowNo;\n }",
"public Double getChange();",
"public String getNewModuleId() {\n String lastModuleId = null;\n String newModuleId = null;\n\n try {\n\n Connection con = DBConnection.getConnection();\n String query = \"SELECT moduleId FROM module\\n\"\n + \"order by moduleId desc limit 1;\";\n PreparedStatement preparedStmt = (PreparedStatement) con.prepareStatement(query);\n\n // execute the preparedstatement\n ResultSet rs = preparedStmt.executeQuery();\n if (rs.next()) {\n lastModuleId = rs.getString(\"moduleId\");\n }\n String last3 = lastModuleId.substring(lastModuleId.length() - 3);\n newModuleId = lastModuleId.substring(0, 4) + String.valueOf(Integer.parseInt(last3) + 1);\n\n con.close();\n\n } catch (SQLException | HeadlessException e) {\n JOptionPane.showMessageDialog(null, e);\n }\n return newModuleId;\n }",
"public java.lang.Long getPosTransNo () {\r\n\t\treturn posTransNo;\r\n\t}",
"public String getIndividualDropboxChangeSql() \r\n \t{\r\n \t\treturn \"select LAST_UPDATE from CONTENT_DROPBOX_CHANGES where (DROPBOX_ID = ?)\";\r\n \t}",
"public String getBuild2Number() {\n\t\treturn \"\"+nb_build2;\n\t}",
"public PriceChangeEdit getPriceChange()\n\t{\n\t\treturn priceChange;\n\t}",
"@Override\n public int getNbChanges()\n {\n return nbChanges;\n }",
"public java.lang.String getTicketNo () {\r\n\t\treturn ticketNo;\r\n\t}",
"ChangeData getChangeData(Project.NameKey projectName, Change.Id changeId);",
"public String fetchRecentChange(){\n\t\treturn recentChange;\n\t}",
"public int getNumber() {\n\t\treturn 666;\n\t}",
"public int getCLNO() {\n return clno;\n }",
"public long getnNum() {\n return nNum;\n }",
"public Long getReceiveNum() {\r\n return receiveNum;\r\n }",
"public int getAccountNo()\r\n\t{\r\n\t\t\r\n\t\treturn accountNo;\r\n\t\t\r\n\t}",
"private long getReserveRecNo() {\n\t\tfinal int selectedRow = this.clientUI.getSelectedRowNo();\n\t\treturn this.model.getRecNo(selectedRow);\n\t}",
"public static Integer getTransactionNumber() {\n\t\tRandom r = new Random(System.currentTimeMillis());\n\t\treturn r.nextInt(100000) * 00001;\n\n\t}",
"public String getOrderNo()\n\t{\n\t\treturn getColumn(OFF_ORDER_NO, LEN_ORDER_NO) ;\n\t}",
"@javax.persistence.Column(name = \"event_code\", nullable = false)\n\tpublic java.lang.Integer getEventCode() {\n\t\treturn getValue(org.jooq.examples.cubrid.demodb.tables.Record.RECORD.EVENT_CODE);\n\t}",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"public String getRevisionNumber()\n { // begin getRevisionNumber()\n // return string\n return(revisionNumber);\n }",
"public String getRevisionNumber()\n { // begin getRevisionNumber()\n // return string\n return(revisionNumber);\n }",
"public long getcNum() {\n return cNum;\n }",
"public ChangeCustomLineItemQuantityChangeBuilder change(final String change) {\n this.change = change;\n return this;\n }",
"public String getRevisionNumber()\n {\n return(revisionNumber);\n }",
"public double getxChange() {\n\t\treturn xChange;\n\t}",
"public Integer getOidold() {\n return oidold;\n }",
"public Long getCreditNum() {\n return creditNum;\n }",
"public long getComNumber() {\r\n return comNumber;\r\n }",
"long getStateChange();",
"public String getUpdateClRegNo() {\n\t\treturn updateClRegNo;\n\t}",
"public String getRevisionNumber()\n {\n return (revisionNumber);\n }",
"public void setHC_JobDataChange_ID (int HC_JobDataChange_ID);",
"public LockOnChange getLockOnChangeMode(){\r\n return this.lockOnChangeMode;\r\n }",
"public long getSeqNo() {\n return seqNo;\n }",
"public java.lang.String getBillNo () {\n\t\treturn billNo;\n\t}",
"public String getOrderSeqNo() {\n return orderSeqNo;\n }",
"public void setREF_NO(BigDecimal REF_NO) {\r\n this.REF_NO = REF_NO;\r\n }",
"private static int getChange(int n) {\n \t\n int count =0, tempCount = 0;\n while(n!=0){\n \t\n \tif(n >= 10){\n \t\ttempCount = n/10;\n \t\tn = n % 10;\n \t\tcount = count + tempCount;\n \t\tif(n==0)\n \t\t\tbreak;\n \t}\n \tif( n >= 5 && n < 10){\n \t\ttempCount = n/5;\n \t\tn = n % 5;\n \t\tcount = count + tempCount;\n \t\tif(n == 0)\n \t\t\tbreak;\n \t}\n \tif(n >= 1 && n < 5){\n \t\tcount = count + n;\n break;\n \t}\n }\n return count;\n }",
"public java.lang.Long getCardTransno () {\r\n\t\treturn cardTransno;\r\n\t}",
"public long gettNum() {\n return tNum;\n }",
"public int getYChange() {\r\n \treturn yChange;\r\n }",
"public ChangeDate getChangeDate() {\n return changeDate;\n }",
"public ChangeDate getChangeDate() {\n return changeDate;\n }",
"String getModuleVersionNumber();",
"public String getTransseqnbr() {\n\t\treturn transseqnbr;\n\t}",
"public String getRevisionNumber()\n {\n return(Util.parseRevisionNumber(revisionNumber));\n }",
"public Long getBillDtlNo() {\n return billDtlNo;\n }",
"public int getTransactionReferenceNumber() {\n\t\treturn transactionReferenceNumber;\n\t}",
"public int getNumber() {\n\t\t\n\t\treturn number;\n\t}",
"long getNextChangeByTableName(String tableName, Object dbContext) throws SQLException;",
"public void setTransNo (java.lang.Long transNo) {\r\n\t\tthis.transNo = transNo;\r\n\t\tthis.hashCode = Integer.MIN_VALUE;\r\n\t}",
"public int getAccountNo() {\n return accountNo;\n }",
"public Integer getChangePasswordCycle() {\n return changePasswordCycle;\n }",
"@Override\r\n\tpublic int getEnterNo() {\n\t\treturn session.selectOne(\"enter.getEnterNo\");\r\n\t}",
"public AtomicInteger getSerialNo() {\n return serialNo;\n }",
"public Integer getCocSerialNo() {\n\t\treturn cocSerialNo;\n\t}",
"public int getNum() {\n return this.num;\n }",
"public int getNumber() {\r\n\t\treturn number;\r\n\t}"
]
| [
"0.66604555",
"0.5747519",
"0.57005984",
"0.5699161",
"0.5628183",
"0.5535376",
"0.549725",
"0.5428344",
"0.5422368",
"0.53305525",
"0.53083515",
"0.52490497",
"0.5236352",
"0.52270406",
"0.52050006",
"0.5185092",
"0.5185092",
"0.5185092",
"0.517766",
"0.5175093",
"0.5139351",
"0.51270044",
"0.51077354",
"0.5032519",
"0.5008146",
"0.50078994",
"0.49961227",
"0.49788672",
"0.4965691",
"0.49644074",
"0.49573854",
"0.49536717",
"0.4918383",
"0.4894591",
"0.48796764",
"0.4853174",
"0.4842608",
"0.48079613",
"0.47878215",
"0.47645098",
"0.4760627",
"0.4756139",
"0.4731315",
"0.4723956",
"0.47120553",
"0.47025058",
"0.4702213",
"0.46914595",
"0.46899948",
"0.46889073",
"0.4677535",
"0.46722254",
"0.4671811",
"0.46649373",
"0.4661435",
"0.46480182",
"0.46413207",
"0.46366054",
"0.46315166",
"0.46173045",
"0.46144843",
"0.461346",
"0.461346",
"0.46050352",
"0.46045247",
"0.46015146",
"0.4601318",
"0.4597541",
"0.45957613",
"0.4595313",
"0.45936105",
"0.45873883",
"0.45797178",
"0.45786217",
"0.45726192",
"0.456225",
"0.45517892",
"0.45495784",
"0.4547265",
"0.454227",
"0.45413333",
"0.4540957",
"0.45405886",
"0.45393452",
"0.45393452",
"0.4538311",
"0.4537138",
"0.45365176",
"0.4529612",
"0.45264822",
"0.4526149",
"0.45242265",
"0.45241964",
"0.4523641",
"0.45182592",
"0.45112246",
"0.45091945",
"0.4505381",
"0.45052454",
"0.45041278"
]
| 0.74144524 | 0 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.CHANGE_NUM | public void setChangeNum(Long changeNum) {
this.changeNum = changeNum;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Long getChangeNum() {\n return changeNum;\n }",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"public void setHC_JobDataChange_ID (int HC_JobDataChange_ID);",
"public void setBSCA_PriceChangePrev_ID (int BSCA_PriceChangePrev_ID);",
"public void setTransNo (java.lang.Long transNo) {\r\n\t\tthis.transNo = transNo;\r\n\t\tthis.hashCode = Integer.MIN_VALUE;\r\n\t}",
"public abstract void setCod_actividad(java.lang.Long newCod_actividad);",
"public ChangeCustomLineItemQuantityChangeBuilder change(final String change) {\n this.change = change;\n return this;\n }",
"public void setREF_NO(BigDecimal REF_NO) {\r\n this.REF_NO = REF_NO;\r\n }",
"public void setSequenceNo(long n) {\n\tsequenceNo = n;\n }",
"public void setCLNO(int value) {\n this.clno = value;\n }",
"public void setTestNo(Long testNo) {\n this.testNo = testNo;\n }",
"public void setOrderNo (Long orderNo) {\r\n\t\tthis.orderNo = orderNo;\r\n\t}",
"public void setNum(int num) {\r\n this.num = num;\r\n }",
"public void setBillNo(Long billNo) {\n this.billNo = billNo;\n }",
"public synchronized void updateCommitNumber()\n\t{\n\t\tm_dbCommitNum++;\n\t}",
"public void setCreditNum(Long creditNum) {\n this.creditNum = creditNum;\n }",
"public void setOtherLockNum(Long otherLockNum) {\n this.otherLockNum = otherLockNum;\n }",
"public void setSeqNo (int SeqNo);",
"public void setSeqNo (int SeqNo);",
"public void setComNumber(long value) {\r\n this.comNumber = value;\r\n }",
"public void setNum(int num) {\n\t\tthis.num = num;\n\t}",
"public void setNumber(int number) {\r\n\t\tthis.num = number;\r\n\t}",
"long getChangeset();",
"public void setSale_num(Integer sale_num) {\n this.sale_num = sale_num;\n }",
"public void setCar_number( java.lang.String newValue ) {\n __setCache(\"car_number\", newValue);\n }",
"public void setReceiveNum(Long receiveNum) {\r\n this.receiveNum = receiveNum;\r\n }",
"public void setNumber(String newValue);",
"public void updateReadCount(String num){\r\n\t\tString sql=\"update board_notice set readcount=readcount+1 where num=?\";\r\n\t\tConnection conn=null;\r\n\t\tPreparedStatement pstmt=null;\r\n\t\ttry{\r\n\t\t\tconn=DBManager.getConnection();\r\n\t\t\tpstmt=conn.prepareStatement(sql);\r\n\t\t\tpstmt.setString(1, num);\r\n\t\t\tpstmt.executeUpdate();\r\n\t\t}catch(Exception e){\r\n\t\t\te.printStackTrace();\r\n\t\t}finally{\r\n\t\t\tDBManager.close(conn,pstmt);\r\n\t\t}\r\n\t}",
"public void setChangeDate(ChangeDate changeDate) {\n this.changeDate = changeDate;\n }",
"public void setChangeDate(ChangeDate changeDate) {\n this.changeDate = changeDate;\n }",
"public void setNUM_DB(int NUM_DB) \r\n {\r\n if(NUM_DB > 0)\r\n this.NUM_DB = NUM_DB;\r\n }",
"void setNumber(int num) {\r\n\t\tnumber = num;\r\n\t}",
"@Override\n public int getColChange() {\n return colChange;\n }",
"public void setNum(Integer num) {\n this.num = num;\n }",
"public void setNum(Integer num) {\n this.num = num;\n }",
"public void setAccountNo(int number){\n\t\taccountNo = number;\n\t}",
"public I getChangeInfo(int startSeqNum);",
"public void setRowNo(Integer rowNo) {\n this.rowNo = rowNo;\n }",
"public void setZTEL_NUMBER2(java.lang.String value)\n {\n if ((__ZTEL_NUMBER2 == null) != (value == null) || (value != null && ! value.equals(__ZTEL_NUMBER2)))\n {\n _isDirty = true;\n }\n __ZTEL_NUMBER2 = value;\n }",
"public final void setNum_emp(String val) {\n setString(getNum_empAttribute(getMtDatabase()), val);\n }",
"void changeStatus(long receiptId, long statusId, long managerId) throws DbException;",
"public static void setColumnNumber(Configuration conf, int columnNum) {\n\t\tassert columnNum > 0;\n\t\tconf.setInt(RCFile.COLUMN_NUMBER_CONF_STR, columnNum);\n\t}",
"@Override\n\t\t\tpublic void changeSelectItem(int selectNum) {\n\t\t\t\tholder.num = selectNum;\n\t\t\t\tLogUtils.burtLog(\"selectNum==\"+selectNum);\n\t\t\t\tholder.tv_store.setText(\"-\"+selectNum*item.data.zsmdwypxhjfs+\" 剩余\"\n\t\t\t\t\t\t+(item.data1.num_syjf-selectNum*item.data.zsmdwypxhjfs));\n\t\t\t}",
"public void setNumToProcess(long aNumToProcess) {\n numToProcess = aNumToProcess;\n }",
"public void setNum (java.lang.Integer num) {\r\n\t\tthis.num = num;\r\n\t}",
"public void setModifyEmp(Integer modifyEmp) {\n\t\tthis.modifyEmp = modifyEmp;\n\t}",
"public void changeBet(int change) {\n\t\tthis.bet = change;\n\t}",
"@Override\r\n\tpublic void changeNumber(String name, String newNumber) {\n\t\tfor (Entry e : array[name.toUpperCase().charAt(0) - 'A']) {\r\n\t\t\tif (e.name == name) {\r\n\t\t\t\te.setNumber(newNumber);\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"public void setLockOnChangeMode(LockOnChange lockOnChangeMode){\r\n this.lockOnChangeMode = lockOnChangeMode;\r\n }",
"public void setNumber(int number)\n {\n Number = number;\n }",
"public void setRowNumber(int number){\r\n\t\trowNumber = number;\r\n\t}",
"public void setRowNumber(int number){\r\n\t\trowNumber = number;\r\n\t}",
"public void setVersionNo(Integer versionNo) {\r\n\t\tthis.versionNo = versionNo;\r\n\t}",
"public void setNumer(float newNumer){\n\t\tnumer = newNumer;\n\t}",
"void setSequenceNumber(int sequenceNumber);",
"@Override\n public int getRowChange() {\n return rowChange;\n }",
"public void setOrderNumber(int value) {\n this.orderNumber = value;\n }",
"@Override\n public void onAmountChange(View view, int amount) {\n item.num = amount;\n }",
"public void updatedNumber(String key, Number val) {}",
"@Override\r\n public void changed(ObservableValue<? extends Number> observable, Number oldValue, Number newValue) {\n try {\r\n int i = newValue.intValue();\r\n if (i < 0) {\r\n\r\n } else {\r\n if (tanggal.getCellData(i) == null) {\r\n\r\n } else {\r\n dtanggal.setValue(LocalDate.parse(tanggal.getCellData(i)));\r\n }\r\n ids = kode_transaksi.getCellData(i);\r\n tkode_bahan.setText(kode_bahan.getCellData(i));\r\n tnama.setText(nama_bahan.getCellData(i));\r\n tjumlah.setText(jumlah_total.getCellData(i));\r\n tharga.setText(harga_satuan.getCellData(i));\r\n cakunuang.getEditor().setText(tabledata.get(i).kode_akun_keuangan + \"-\"\r\n + tabledata.get(i).nama_akun_keuangan);\r\n }\r\n } catch (Exception e) {\r\n oh.error(e);\r\n }\r\n\r\n }",
"public void setStatusChange(int statusChange) {\n\t\tthis.statusChance = statusChange;\n\t}",
"public int getChangeType() {\r\n return changeType;\r\n }",
"@Override\n\tpublic void setEmpno(Integer empno) {\n\t\tsuper.setEmpno(empno);\n\t}",
"public void setTransactionID(int tid) {\n m_TransactionID = tid;\n // setChanged(true);\n }",
"public void setNUMSEC(int value) {\n this.numsec = value;\n }",
"public void setNUMSEC(int value) {\n this.numsec = value;\n }",
"public void setNUMSEC(int value) {\n this.numsec = value;\n }",
"public void setCostume(int newCostumeNumber) {\n costumeNumber=newCostumeNumber;\n }",
"public String getOldNum(){\n return cal.getOldNum();\n }",
"public void changedUpdate(DocumentEvent evt, FoldHierarchyTransaction transaction) {\n }",
"void set_num(ThreadContext tc, RakudoObject classHandle, double Value);",
"void set(long newValue);",
"@Override\n public void setAtomicNumber(int atomicNumber) {\n }",
"public void set_next_local_commitment_number(long val) {\n\t\tbindings.ChannelReestablish_set_next_local_commitment_number(this.ptr, val);\n\t}",
"public void setSequenceNumber(long value) {\n this.sequenceNumber = value;\n }",
"public void setChangeTo(String changeTo) {\n\t\t\tthis.changeTo = checkAndPad(changeTo);\n\t\t}",
"public void setTeamNo(int teamNo) {\r\n\t\tthis.teamNo = teamNo;\r\n\t}",
"public void setChangeAction(String changeAction)\r\n\t{\r\n\t\tthis.changeAction = changeAction;\r\n\t}",
"public void setNumber(int number)\n {\n this.number = number;\n }",
"public void setNoOfTicket(String noOfTickets) {\n \r\n }",
"@Override\r\n\tpublic void increaseViewCnt(int no) {\n\t\tsqlSession.update(namespace + \".increaseViewCnt\", no);\r\n\t}",
"public void setAutoCommit (int value) {\n this.autoCommit = value;\n }",
"public abstract void setCntCod(int cntCod);",
"@Override\r\n\t\t\tpublic void modifyText(ModifyEvent me) {\n\t\t\t\tString newValue = newEditor.getText();\r\n\t\t\t\teditor.getItem().setText(VALUE_COLUMN_NO, newValue);\r\n\t\t\t\t//isEditorModify = true;\r\n\t\t\t\t//propertyInfo.setValue(newValue);\r\n\t\t\t}",
"public void setSequenceNumberForHibernate(INT sequenceNumber) {\n _sequenceNumber = sequenceNumber;\n }",
"public void setSERIAL_NO(BigDecimal SERIAL_NO) {\r\n this.SERIAL_NO = SERIAL_NO;\r\n }",
"public void setSERIAL_NO(BigDecimal SERIAL_NO) {\r\n this.SERIAL_NO = SERIAL_NO;\r\n }",
"public final void setOrderNumber(Long ordernumber)\r\n\t{\r\n\t\tsetOrderNumber(getContext(), ordernumber);\r\n\t}",
"public void setNumber(int number) {\r\n\t\tthis.number = number;\r\n\t}",
"public void setSequenceNo(Number value) {\n setAttributeInternal(SEQUENCENO, value);\n }",
"@Override\n public void onValueChange(NumberPicker numberPicker, int oldVal, int newVal) {\n long timeHelper = newVal * 1000;\n mSelectedStartTime = timeHelper;\n mTextViewCountDown.setText(String.valueOf(newVal));\n mTimeLeftInMillis = timeHelper;\n }",
"public void setSL_NO(BigDecimal SL_NO) {\r\n this.SL_NO = SL_NO;\r\n }",
"public void setSL_NO(BigDecimal SL_NO) {\r\n this.SL_NO = SL_NO;\r\n }",
"public void setSL_NO(BigDecimal SL_NO) {\r\n this.SL_NO = SL_NO;\r\n }",
"public void changeNumber(int y,int z,int x,int numChange)\r\n\t{\r\n\t\tthis.maze[y][z][x] = numChange;\r\n\t}",
"private void change(Node n, int value) {\n\t\tn.pendingVal = value;\n\t\tn.sum = n.size() * value;\n\t\tn.min = value;\n\t\tarray[n.from] = value;\n\n\t}",
"protected void setTableOrder(int num)\n\t\t{\n\t\t\tOrder = num ;\n\t\t}",
"public Long getLockNum() {\n return lockNum;\n }",
"public void setClickNum(Integer clickNum) {\n this.clickNum = clickNum;\n }",
"public synchronized void setNumberOfServers(int num) {\n\t\tif(num != this.numServers) {\n\t\t\tthis.updating = true;\n\t\t\tthis.prevNumServers = this.numServers;\n\t\t\tthis.numServers = num;\n\t\t\tthis.rehashUsers();\n\t\t\tthis.updating = false;\n\t\t\tthis.notifyAll();\n\t\t}\n\t}"
]
| [
"0.6515542",
"0.57043374",
"0.56386185",
"0.5426319",
"0.53509825",
"0.52559",
"0.52229303",
"0.5204109",
"0.5195643",
"0.51855284",
"0.5135807",
"0.5101292",
"0.50344557",
"0.5030552",
"0.5025556",
"0.50113076",
"0.50029254",
"0.50025547",
"0.50025547",
"0.49858376",
"0.49673364",
"0.49123895",
"0.49040726",
"0.49031746",
"0.48973212",
"0.48972133",
"0.48920456",
"0.4891898",
"0.48917404",
"0.48917404",
"0.4876421",
"0.48633736",
"0.48550686",
"0.48485637",
"0.48485637",
"0.48418787",
"0.48340732",
"0.48312062",
"0.4822918",
"0.48222154",
"0.4808342",
"0.48029837",
"0.48011872",
"0.47973156",
"0.47954977",
"0.47751477",
"0.47685188",
"0.47592574",
"0.47499865",
"0.47428554",
"0.4732251",
"0.4732251",
"0.47317162",
"0.4726037",
"0.472503",
"0.47236815",
"0.46991315",
"0.46977708",
"0.46943104",
"0.4691168",
"0.46845984",
"0.46788388",
"0.46758094",
"0.4670006",
"0.466215",
"0.466215",
"0.466215",
"0.46542206",
"0.4653726",
"0.4653425",
"0.4648568",
"0.46434703",
"0.46378645",
"0.46346694",
"0.46324828",
"0.46307534",
"0.46213418",
"0.46079132",
"0.46061087",
"0.46039742",
"0.46037817",
"0.46020955",
"0.46004578",
"0.459786",
"0.45973933",
"0.45908284",
"0.45908284",
"0.4589838",
"0.45873612",
"0.45834106",
"0.45800075",
"0.45611188",
"0.45611188",
"0.45611188",
"0.45535976",
"0.45510122",
"0.45503727",
"0.45470414",
"0.45458654",
"0.45456406"
]
| 0.74794245 | 0 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.REMAIN_NUM | public Long getRemainNum() {
return remainNum;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private long getReserveRecNo() {\n\t\tfinal int selectedRow = this.clientUI.getSelectedRowNo();\n\t\treturn this.model.getRecNo(selectedRow);\n\t}",
"protected long getLastCleanedRow() {\n List<String> res = dbconnector.execRead(\"SELECT value FROM MS_DataCleaning_conf \" +\n \"WHERE name='sample_last_cleaned_row'\").get(0);\n return Long.parseLong(res.get(0));\n }",
"public String getRebillAmount()\n\t{\n\t\tif(response.containsKey(\"reb_amount\")) {\n\t\t\treturn response.get(\"reb_amount\");\n\t\t} else {\n\t\t\treturn null;\n\t\t}\n\t}",
"public long getContainNReadNum() {\n return containNReadNum;\n }",
"public Long getReceiveNum() {\r\n return receiveNum;\r\n }",
"public java.lang.Long getRelateTransno () {\r\n\t\treturn relateTransno;\r\n\t}",
"public void setRemainNum(Long remainNum) {\n this.remainNum = remainNum;\n }",
"@Accessor(qualifier = \"redemptionQuantityLimit\", type = Accessor.Type.GETTER)\n\tpublic Integer getRedemptionQuantityLimit()\n\t{\n\t\treturn getPersistenceContext().getPropertyValue(REDEMPTIONQUANTITYLIMIT);\n\t}",
"public String getRebillCyclesRemain()\n\t{\n\t\tif(response.containsKey(\"cycles_remain\")) {\n\t\t\treturn response.get(\"cycles_remain\");\n\t\t} else {\n\t\t\treturn null;\n\t\t}\n\t}",
"public final int getRollNo() {\n\t\t// this.rollNo = 10 ;\n\t\treturn this.rollNo;\n\t}",
"@Override\r\n\tpublic int selectLastNo() {\n\t\treturn sqlSession.selectOne(namespace + \".selectLastNo\");\r\n\t}",
"@Override\r\n\tpublic int selectLastNo() {\n\t\treturn sqlSession.selectOne(namespace + \".selectLastNo\");\r\n\t}",
"public BigDecimal getREF_NO() {\r\n return REF_NO;\r\n }",
"public int getRightNumber() {\n return rightNumber;\n }",
"public int getRollNo() {\n\t\treturn this.roll_no;\n\t}",
"public java.lang.String getRrNo () {\n\t\treturn rrNo;\n\t}",
"public int getM_Requisition_ID() {\n\t\tInteger ii = (Integer) get_Value(\"M_Requisition_ID\");\n\t\tif (ii == null)\n\t\t\treturn 0;\n\t\treturn ii.intValue();\n\t}",
"public Long get_cachetotrevalidationmiss() throws Exception {\n\t\treturn this.cachetotrevalidationmiss;\n\t}",
"public String getRequisitionNumber() {\r\n return requisitionNumber;\r\n }",
"@Override\r\n\tpublic int getEnterNo() {\n\t\treturn session.selectOne(\"enter.getEnterNo\");\r\n\t}",
"public String getp_recpt_no() {\n return (String)getNamedWhereClauseParam(\"p_recpt_no\");\n }",
"public int getLBR_SeqNumberInBank_ID () \n\t{\n\t\tInteger ii = (Integer)get_Value(COLUMNNAME_LBR_SeqNumberInBank_ID);\n\t\tif (ii == null)\n\t\t\t return 0;\n\t\treturn ii.intValue();\n\t}",
"public Long getLockNum() {\n return lockNum;\n }",
"@Accessor(qualifier = \"redemptionQuantityLimitPerUser\", type = Accessor.Type.GETTER)\n\tpublic Integer getRedemptionQuantityLimitPerUser()\n\t{\n\t\treturn getPersistenceContext().getPropertyValue(REDEMPTIONQUANTITYLIMITPERUSER);\n\t}",
"public Integer getResnr() {\n\t\treturn this.resnr;\n\t}",
"public int getReceivalMonth(){\n\t\treturn this.receivalMonth;\n\t}",
"public Long get_cachefulltoconditionalrequestrate() throws Exception {\n\t\treturn this.cachefulltoconditionalrequestrate;\n\t}",
"Integer getMaxRecourseUsage() {\n if(daoInterface.getMaxRecourseUsage()==null){\n return 0;\n }\n else {\n return daoInterface.getMaxRecourseUsage() ;\n }}",
"@Override\n\tpublic int religioncount() throws Exception {\n\t\treturn dao.religioncount();\n\t}",
"private int getRID() throws SQLException {\n\t\tResultSet result = getRidStatement.executeQuery();\n\t\tif (result.next()) {\n\t\t\tint out = result.getInt(1);\n\t\t\tresult.close();\n\t\t\tif (DEBUG) {\n\t\t\t\tSystem.out.println(\"getRID: \"+out+\"\\n\");\n\t\t\t}\n\t\t\treturn out;\n\t\t} else {\n\t\t\tif (DEBUG) {\n\t\t\t\tSystem.out.println(\"getRID: \"+0+\"\\n\");\n\t\t\t}\n\t\t\treturn 0;\n\t\t}\n\t}",
"public long getSeqNo() {\n return seqNo;\n }",
"public BigDecimal getTRS_NO() {\r\n return TRS_NO;\r\n }",
"public BigDecimal getTRS_NO() {\r\n return TRS_NO;\r\n }",
"public String getRequisitionTotalAmount() {\r\n return requisitionTotalAmount;\r\n }",
"public Integer getRtid() {\r\n\t\treturn rtid;\r\n\t}",
"public Long get_cachetotsuccessfulrevalidation() throws Exception {\n\t\treturn this.cachetotsuccessfulrevalidation;\n\t}",
"@Override\r\n\tpublic Integer getMaxInvSrno() {\n\t\tQStnLooseMt qStnLooseMt = QStnLooseMt.stnLooseMt;\r\n\t\tJPAQuery query = new JPAQuery(entityManager);\r\n\t\tInteger retVal = -1;\r\n\t\t\r\n\t\tCalendar date = new GregorianCalendar();\r\n\t\t\r\n\t\tList<Integer> maxSrno = query\r\n\t\t\t.from(qStnLooseMt)\r\n\t\t\t.where(qStnLooseMt.invDate.year().eq(date.get(Calendar.YEAR))).list(qStnLooseMt.srNo.max());\r\n\t\t\r\n\t\tfor (Integer srno : maxSrno) {\r\n\t\t\tretVal = (srno == null ? 0 : srno);\r\n\t\t}\r\n\r\n\t\t\r\n\t\t\r\n\t\treturn retVal;\r\n\t}",
"public java.lang.String getPaymentRefNo()\n {\n synchronized (monitor())\n {\n check_orphaned();\n org.apache.xmlbeans.SimpleValue target = null;\n target = (org.apache.xmlbeans.SimpleValue)get_store().find_element_user(PAYMENTREFNO$0, 0);\n if (target == null)\n {\n return null;\n }\n return target.getStringValue();\n }\n }",
"public Integer getRowNo() {\n return rowNo;\n }",
"public Long getBillNo() {\n return billNo;\n }",
"public Integer getRentId() {\n return rentId;\n }",
"public java.lang.Long getTransNo () {\r\n\t\treturn transNo;\r\n\t}",
"public Long getChangeNum() {\n return changeNum;\n }",
"public String getreceiptnum() {\n return (String) getAttributeInternal(RECEIPTNUM);\n }",
"public Long getOtherLockNum() {\n return otherLockNum;\n }",
"public BigDecimal getTRX_NO() {\r\n return TRX_NO;\r\n }",
"public ResultSet returnAccount(Long demataccountNo)throws Exception {\n\trs=DbConnect.getStatement().executeQuery(\"select BANK_ACC_NO from CUSTOMER_DETAILS where DEMAT_ACC_NO=\"+demataccountNo+\"\");\r\n\treturn rs;\r\n}",
"private String sequenceNumberGenerator() {\n\t\tint sequenceId = 0;\n\t\tRid entity = null;\n\t\ttry {\n\t\t\tentity = ridRepository.findLastRid();\n\t\t} catch (DataAccessException | DataAccessLayerException e) {\n\t\t\tthrow new RidException(RidGeneratorExceptionConstant.RID_FETCH_EXCEPTION.getErrorCode(),\n\t\t\t\t\tRidGeneratorExceptionConstant.RID_FETCH_EXCEPTION.errorMessage, e);\n\t\t}\n\t\ttry {\n\t\t\tif (entity == null) {\n\t\t\t\tentity = new Rid();\n\t\t\t\tsequenceId = sequenceInitialValue;\n\t\t\t\tentity.setCurrentSequenceNo(sequenceInitialValue);\n\t\t\t\tridRepository.save(entity);\n\t\t\t} else {\n\t\t\t\tif (entity.getCurrentSequenceNo() == sequenceEndvalue) {\n\t\t\t\t\tsequenceId = sequenceInitialValue;\n\t\t\t\t\tridRepository.updateRid(sequenceInitialValue, entity.getCurrentSequenceNo());\n\t\t\t\t} else {\n\t\t\t\t\tsequenceId = entity.getCurrentSequenceNo() + 1;\n\t\t\t\t\tridRepository.updateRid(sequenceId, entity.getCurrentSequenceNo());\n\t\t\t\t}\n\t\t\t}\n\t\t} catch (DataAccessException | DataAccessLayerException e) {\n\t\t\tthrow new RidException(RidGeneratorExceptionConstant.RID_UPDATE_EXCEPTION.getErrorCode(),\n\t\t\t\t\tRidGeneratorExceptionConstant.RID_UPDATE_EXCEPTION.errorMessage, e);\n\t\t}\n\t\treturn String.format(sequenceFormat, sequenceId);\n\t}",
"public String getRemasterCatalogueNumber() {\r\n\t\treturn this.remasterCatalogueNumber;\r\n\t}",
"public int getNuevoNumTransaccionBR() throws BaseDeDatosExcepcion, ConexionExcepcion {\n\t\tif (logger.isDebugEnabled()) {\n\t\t\tlogger.debug(\"getNuevoNumTransaccionBR() - start\");\n\t\t}\n\t\t\n\t\tint result = 0;\n\t\t\n\t\tincrementarNumTransBR();\n\t\tresult = numTransaccionBR;\n\t\t\n\t\tif (logger.isDebugEnabled()) {\n\t\t\tlogger.debug(\"getNuevoNumTransaccionBR() - end\");\n\t\t}\n\t\treturn result;\n\t}",
"public int getLastSavedId() {\n\t\tNativeQuery query = session.createNativeQuery(\"SELECT Id FROM terms ORDER BY Id DESC LIMIT 1\");\n\t\t// int lastUpdatedValue=(int)query;\n\t\tint lastUpdatedValue = ((Number) query.getSingleResult()).intValue();\n\t\tSystem.out.println(\"the result is\" + lastUpdatedValue);\n\t\treturn lastUpdatedValue;\n\t}",
"public int getLicencePlateNumberLastDigit() {\r\n return Integer.parseInt(this.licencePlateNumber.substring(\r\n this.licencePlateNumber.length() - 1, \r\n this.licencePlateNumber.length()));\r\n }",
"public String getInvestorNo() {\r\n return investorNo;\r\n }",
"public int getAccountNo()\r\n\t{\r\n\t\t\r\n\t\treturn accountNo;\r\n\t\t\r\n\t}",
"public static int getEndReadId(UploadResult uploadResult) {\n\t\tif (uploadResult == null) {\n\t\t\treturn -1;\n\t\t}\n\n\t\t// first read db\n\t\tTreeSet<Integer> ids = uploadResult.getReadButNotUploadIds();\n\t\tif (ids == null) {\n\t\t\treturn -1;\n\t\t}\n\t\t\n\t\tTreeSet<Integer> readFailedIds = uploadResult.getReadFailedIds();\n\t\tif (uploadResult.getReadOvered()) {\n\t\t\tif (readFailedIds.isEmpty()) {\n\t\t\t\treturn 0;\n\t\t\t} else {\n\t\t\t\treturn uploadResult.getReadFailedIds().last();\t\t\t\t\n\t\t\t}\n\t\t}\n\t\t\n\t\treturn -1;\n\t}",
"public long getCedulaPersonaRecido() {\r\n\t\treturn cedulaPersonaRecive;\r\n\t}",
"public String getOldNum(){\n return cal.getOldNum();\n }",
"public int getAccountNo() {\n return accountNo;\n }",
"@Override\r\n\tpublic int maxNum() throws Exception {\n\t\treturn session.selectOne(\"com.mapper.cook.maxNum\");\r\n\t}",
"public int GetLastnumero()\r\n throws SQLException{\r\n int code = 0;\r\n ResultSet result = null;\r\n \r\n result = RequeteSelect(result,\"select max(CodeFiche) from Travaux\");\r\n while (result.next()){\r\n if(result.getString(1) == null)\r\n code = 0;\r\n else code = Integer.parseInt(new String(result.getString(1)))+1;\r\n }\r\n \r\n Close();\r\n result.close();\r\n \r\n return code;\r\n }",
"public double getReell() {\n\t\treturn reell;\n\t}",
"public Long getBillDtlNo() {\n return billDtlNo;\n }",
"public int getReadedRecordNumber();",
"public String getRebillNextAmount()\n\t{\n\t\tif(response.containsKey(\"next_amount\")) {\n\t\t\treturn response.get(\"next_amount\");\n\t\t} else {\n\t\t\treturn null;\n\t\t}\n\t}",
"public int getSubstanceLotNumberReps() {\r\n \treturn this.getReps(15);\r\n }",
"public int getTakeupSeqNo() {\n\t\treturn takeupSeqNo;\n\t}",
"public long getSequenceNo() {\n\treturn sequenceNo;\n }",
"public int getM_RequisitionLine_ID() {\n\t\tInteger ii = (Integer) get_Value(\"M_RequisitionLine_ID\");\n\t\tif (ii == null)\n\t\t\treturn 0;\n\t\treturn ii.intValue();\n\t}",
"public int getRemaining( int telObsCompIndex )\n\t{\n\t\treturn _avTable.getInt( ATTR_REMAINING , telObsCompIndex , 0 ) ;\n\t}",
"public String getUpdateClRegNo() {\n\t\treturn updateClRegNo;\n\t}",
"public String getNewModuleId() {\n String lastModuleId = null;\n String newModuleId = null;\n\n try {\n\n Connection con = DBConnection.getConnection();\n String query = \"SELECT moduleId FROM module\\n\"\n + \"order by moduleId desc limit 1;\";\n PreparedStatement preparedStmt = (PreparedStatement) con.prepareStatement(query);\n\n // execute the preparedstatement\n ResultSet rs = preparedStmt.executeQuery();\n if (rs.next()) {\n lastModuleId = rs.getString(\"moduleId\");\n }\n String last3 = lastModuleId.substring(lastModuleId.length() - 3);\n newModuleId = lastModuleId.substring(0, 4) + String.valueOf(Integer.parseInt(last3) + 1);\n\n con.close();\n\n } catch (SQLException | HeadlessException e) {\n JOptionPane.showMessageDialog(null, e);\n }\n return newModuleId;\n }",
"public java.lang.String getRefnum() {\n return refnum;\n }",
"public String consultaValorRevenda() {\n\t\treturn \"[REVENDA] Celular #\" + this.modelo + \": R$ \" + this.valorRevenda;\n\t}",
"int getTransactionNum();",
"public long getMaxRIT() {\n return localMaxRIT;\n }",
"@Transient\n\tpublic long getRefundPaymentTransactionIdLong() {\n\t\tif (mRefundPaymentTransactionIdLong == -1) {\n\t\t\tif (mRefundPaymentTransactionId != null) {\n\t\t\t\ttry {\n\t\t\t\t\tmRefundPaymentTransactionIdLong = Long.parseLong(mRefundPaymentTransactionId);\n\t\t\t\t}\n\t\t\t\tcatch (NumberFormatException ne) {\n\t\t\t\t\t// nothing\n\t\t\t\t\tmRefundPaymentTransactionIdLong = -2;\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn mRefundPaymentTransactionIdLong;\n\t}",
"long getSeqnum();",
"long getSeqnum();",
"long getSeqnum();",
"long getSeqnum();",
"long getSeqnum();",
"long getSeqnum();",
"long getSeqnum();",
"public StringWithCustomFacts getRecIdNumber() {\n return recIdNumber;\n }",
"public String getAfterOrderHandleNumber() throws ErpServiceException {\n\t\ttry {\t \n\t\t\treturn afterSalesDao.getAfterOrderHandleNumber();\n\t\t} catch (Exception e) {\n\t\t\tlogger.error(e.getMessage());\n\t\t\tthrow new ErpServiceException(e.getMessage());\n\t\t}\n\t}",
"public long getDataEntryRVA() {\n return DataEntryRVA;\n }",
"public Integer getREC_ID() {\n return REC_ID;\n }",
"public void setReceiveNum(Long receiveNum) {\r\n this.receiveNum = receiveNum;\r\n }",
"@Transient\n\tpublic int getReIssue() {\n\t\treturn mReIssue;\n\t}",
"public long getRId() {\r\n return rId;\r\n }",
"public java.lang.Long getCardTransno () {\r\n\t\treturn cardTransno;\r\n\t}",
"public java.lang.String getRegistNo() {\n return registNo;\n }",
"public String getAccountNo() {\n return accountNo;\n }",
"public BigDecimal getSERIAL_NO() {\r\n return SERIAL_NO;\r\n }",
"public BigDecimal getSERIAL_NO() {\r\n return SERIAL_NO;\r\n }",
"public BigDecimal getRESERVE_AMOUNT() {\r\n return RESERVE_AMOUNT;\r\n }",
"public String getRightRevision() {\n return rightRevision;\n }",
"public int getCurrentOperationId(){\n int nmr = 1;\n operationLock.lock();\n try (\n Statement s = rawDataSource.getConnection().createStatement(ResultSet.TYPE_SCROLL_INSENSITIVE, ResultSet.CONCUR_READ_ONLY);\n ResultSet res = s.executeQuery(\n \"SELECT OP_ID FROM APP.OPERATIONS ORDER BY OP_ID ASC\")) {\n\n if (res.last()) {\n nmr = Integer.parseInt(res.getString(\"OP_ID\")) + 1;\n }\n } catch (SQLException ex) {\n return nmr;\n }\n\n operationLock.unlock();\n return nmr;\n }",
"@Override\n\tpublic int getPerformScheduleSeqMax() {\n\t\treturn dao.getPerformScheduleSeqMax();\n\t}",
"public String getMasterResetCode() {\r\n \r\n \tString key = \"\";\r\n String selectQuery = \"SELECT * FROM \" + TABLE_MAIN;\r\n \r\n SQLiteDatabase db = this.getReadableDatabase();\r\n Cursor cursor = db.rawQuery(selectQuery, null);\r\n \r\n if (cursor.moveToFirst()) {\r\n do {\r\n \tkey = cursor.getString(1);\r\n } while (cursor.moveToNext());\r\n }\r\n \r\n cursor.close();\r\n db.close();\r\n\r\n return key;\r\n }"
]
| [
"0.5984577",
"0.5342329",
"0.53394943",
"0.5306277",
"0.53008217",
"0.5272712",
"0.5265135",
"0.51989913",
"0.519383",
"0.5192908",
"0.5100262",
"0.5100262",
"0.50862956",
"0.50820696",
"0.5049472",
"0.5047395",
"0.50324154",
"0.50231606",
"0.5022022",
"0.49998832",
"0.49766773",
"0.4972571",
"0.49721432",
"0.49137607",
"0.49070266",
"0.48956674",
"0.48949146",
"0.48728442",
"0.48674303",
"0.48644277",
"0.48571527",
"0.48481843",
"0.48481843",
"0.48375267",
"0.483505",
"0.48266193",
"0.48224637",
"0.4813877",
"0.4802799",
"0.4800921",
"0.47873375",
"0.47864655",
"0.47808772",
"0.47803548",
"0.47790006",
"0.477773",
"0.47649068",
"0.47582468",
"0.475627",
"0.47558215",
"0.47446415",
"0.4737989",
"0.4736046",
"0.4735992",
"0.47235447",
"0.4723118",
"0.47209844",
"0.4718261",
"0.47181702",
"0.47026217",
"0.4701801",
"0.4695503",
"0.46926862",
"0.46874",
"0.46715787",
"0.46711722",
"0.46706322",
"0.46646547",
"0.4662498",
"0.46566516",
"0.46507058",
"0.46430027",
"0.46378708",
"0.4631952",
"0.46300593",
"0.46220094",
"0.46088195",
"0.46088195",
"0.46088195",
"0.46088195",
"0.46088195",
"0.46088195",
"0.46088195",
"0.45957625",
"0.45953014",
"0.45950645",
"0.4593928",
"0.45920432",
"0.45845786",
"0.45789656",
"0.4577952",
"0.45767996",
"0.45718342",
"0.45689577",
"0.45689577",
"0.45688993",
"0.45670262",
"0.45616877",
"0.45608348",
"0.4559822"
]
| 0.6051777 | 0 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.REMAIN_NUM | public void setRemainNum(Long remainNum) {
this.remainNum = remainNum;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setReceiveNum(Long receiveNum) {\r\n this.receiveNum = receiveNum;\r\n }",
"public Long getRemainNum() {\n return remainNum;\n }",
"private long getReserveRecNo() {\n\t\tfinal int selectedRow = this.clientUI.getSelectedRowNo();\n\t\treturn this.model.getRecNo(selectedRow);\n\t}",
"public void setRetiredValue(java.lang.Long value) {\n __getInternalInterface().setFieldValue(RETIREDVALUE_PROP.get(), value);\n }",
"private void setRetiredValue(java.lang.Long value) {\n __getInternalInterface().setFieldValue(RETIREDVALUE_PROP.get(), value);\n }",
"public void setRId(long value) {\r\n this.rId = value;\r\n }",
"void setNumberPaymentReceipt(int nRicevuta);",
"public void setREF_NO(BigDecimal REF_NO) {\r\n this.REF_NO = REF_NO;\r\n }",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"protected void setRemark(EmployeeLeave employeeLeave, ResultSet rs, int rowNumber) throws SQLException{\n\t\tString remark = rs.getString(EmployeeLeaveTable.COLUMN_REMARK);\n\t\tif(remark == null){\n\t\t\t//do nothing when nothing found in database\n\t\t\treturn;\n\t\t}\n\t\n\t\temployeeLeave.setRemark(remark);\n\t}",
"public abstract void setCntRod(int cntRod);",
"public void setRESERVE_AMOUNT(BigDecimal RESERVE_AMOUNT) {\r\n this.RESERVE_AMOUNT = RESERVE_AMOUNT;\r\n }",
"public void setRelateTransno (java.lang.Long relateTransno) {\r\n\t\tthis.relateTransno = relateTransno;\r\n\t}",
"public void recover(long aSeqNum) {\n synchronized(this) {\n if (aSeqNum > theSeqNum) {\n theSeqNum = aSeqNum;\n }\n }\n }",
"public void setTestNo(Long testNo) {\n this.testNo = testNo;\n }",
"protected void setVersion(EmployeeLeave employeeLeave, ResultSet rs, int rowNumber) throws SQLException{\n\t\tInteger version = rs.getInt(EmployeeLeaveTable.COLUMN_VERSION);\n\t\tif(version == null){\n\t\t\t//do nothing when nothing found in database\n\t\t\treturn;\n\t\t}\n\t\n\t\temployeeLeave.setVersion(version);\n\t}",
"public void setTRS_NO(BigDecimal TRS_NO) {\r\n this.TRS_NO = TRS_NO;\r\n }",
"public void setTRS_NO(BigDecimal TRS_NO) {\r\n this.TRS_NO = TRS_NO;\r\n }",
"public void setSequenceNo(long n) {\n\tsequenceNo = n;\n }",
"public void restartRebill(HashMap<String, String> params) {\n\t\tTRANSACTION_TYPE = \"SET\";\n\t\tREBILL_ID = params.get(\"rebillID\");\n\t\tNEXT_DATE = params.get(\"nextDate\");\n\t\tREBILL_STATUS = \"active\";\n\t\tAPI = \"bp20rebadmin\";\n\t}",
"public void setTakeupSeqNo(int takeupSeqNo) {\n\t\tthis.takeupSeqNo = takeupSeqNo;\n\t}",
"public void setCreditNum(Long creditNum) {\n this.creditNum = creditNum;\n }",
"public abstract void setCod_actividad(java.lang.Long newCod_actividad);",
"public void setSeqNo (int SeqNo);",
"public void setSeqNo (int SeqNo);",
"public void setRollNo ( int rollno ) {\n\t\tthis.rollno = rollno;\t\n\t}",
"@Override public void checkpointReadLockTimeout(long val) {\n checkpointReadLockTimeout = val;\n }",
"public void updateRebill(HashMap<String, String> params) {\n\t\tTRANSACTION_TYPE = \"SET\";\n\t\tREBILL_ID = params.get(\"rebillID\");\n\t\tTEMPLATE_ID = params.get(\"templateID\");\n\t\tNEXT_DATE = params.get(\"nextDate\");\n\t\tREB_EXPR = params.get(\"expr\");\n\t\tREB_CYCLES = params.get(\"cycles\");\n\t\tREB_AMOUNT = params.get(\"rebillAmount\");\n\t\tNEXT_AMOUNT = params.get(\"nextAmount\");\n\t\tAPI = \"bp20rebadmin\";\n\t}",
"public void set_next_remote_commitment_number(long val) {\n\t\tbindings.ChannelReestablish_set_next_remote_commitment_number(this.ptr, val);\n\t}",
"public void setRowNo(Integer rowNo) {\n this.rowNo = rowNo;\n }",
"public void setTRX_NO(BigDecimal TRX_NO) {\r\n this.TRX_NO = TRX_NO;\r\n }",
"public void setMaxRIT(long param) {\n if (param == java.lang.Long.MIN_VALUE) {\n localMaxRITTracker = false;\n } else {\n localMaxRITTracker = true;\n }\n this.localMaxRIT = param;\n }",
"public int setInactiveForNoRebill();",
"public void set_next_local_commitment_number(long val) {\n\t\tbindings.ChannelReestablish_set_next_local_commitment_number(this.ptr, val);\n\t}",
"public void onRequeryResult (String merchantCode, String refNo, String amount, String result)\n {\n IPay88.r_merchantCode = merchantCode;\n IPay88.r_referenceNo = refNo;\n IPay88.r_amount = amount;\n IPay88.r_result = result;\n }",
"public void actualizarNumSeqMerchant() throws BaseDeDatosExcepcion, ConexionExcepcion {\n MediadorBD.actualizarNumSeqMerchantCaja(this.numSeqMerchant);\n }",
"@Override\n\tpublic TaskForUserOngoingRecord setNumRevives(Integer value) {\n\t\tsetValue(6, value);\n\t\treturn this;\n\t}",
"private void exeMODMCT(int P_intROWNO) \n\t\t{ \n\t\t try\n\t\t {\n\t\t\t \tString strSQLQRY=\" select count(*) from HW_MCTRN \";\n\t\t\t\t//strSQLQRY+=\" where MCT_SYSTP='\"+tblLICDL.getValueAt(P_intROWNO,TB1_SYSTP).toString().trim()+\"' \";\n\t\t\t\tstrSQLQRY+=\" where MCT_SFTCT='\"+hstSFTCT.get(cmbSFTCT.getSelectedItem().toString())+\"' AND MCT_SFTCD='\"+txtSFTCD.getText().toString()+\"'\";\n\t\t\t\tstrSQLQRY+=\" and ifnull(MCT_STSFL,'')<>'X' AND MCT_SWSRL='\"+txtSRLNO.getText().toString()+\"'\";\n\t\t\t\tstrSQLQRY += \" AND MCT_LICNO='\"+tblLICDL.getValueAt(P_intROWNO,TB1_LICNO).toString().trim()+\"' \";\n\t\t\t\t\n\t\t\t\tResultSet rstRSSET = cl_dat.exeSQLQRY(strSQLQRY);\n\t\t\t\t//System.out.println(\">>>Count2>>\"+strSQLQRY);\n\t\t\t\tif(rstRSSET.next() && rstRSSET!= null)\n\t\t\t\t{\n\t\t\t\t\tif(rstRSSET.getInt(1)>0)\n\t\t\t\t\t{\n\t\t\t\t\t \tM_strSQLQRY = \"UPDATE HW_MCTRN SET\";\t\n\t\t\t\t\t \tif(cmbLICTP.getSelectedIndex()>0)\n\t\t\t\t\t \t\tM_strSQLQRY +=\"\tMCT_LICTP='\"+hstLICTP.get(cmbLICTP.getSelectedItem().toString())+\"'\";\n\t\t\t\t\t \telse\n\t\t\t\t\t \t\tM_strSQLQRY +=\"\tMCT_LICTP='XX'\";\n\t\t\t\t\t\tM_strSQLQRY +=\" where MCT_SFTCT = '\"+hstSFTCT.get(cmbSFTCT.getSelectedItem().toString())+\"' \";\n\t\t\t\t\t\tM_strSQLQRY +=\" AND MCT_SFTCD = '\"+txtSFTCD.getText()+\"' \";\n\t\t\t\t\t\tM_strSQLQRY +=\" AND MCT_SWSRL = '\"+txtSRLNO.getText().toString()+\"' \";\n\t\t\t\t\t\tM_strSQLQRY +=\" AND MCT_LICNO='\"+tblLICDL.getValueAt(P_intROWNO,TB1_LICNO).toString().trim()+\"' \";\n\t\t\t\t\t\t\n\t\t\t\t\t\tcl_dat.M_flgLCUPD_pbst = true;\n\t\t\t\t\t\tcl_dat.exeSQLUPD(M_strSQLQRY ,\"setLCLUPD\");\n\t\t\t\t\t\t//System.out.println(\">>>Delete>>\"+M_strSQLQRY);\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t }\n\t\t catch(Exception L_EX)\n\t\t {\n\t\t setMSG(L_EX,\"exeMODMCT()\");\t\t\n\t\t }\n\t\t}",
"public void setCodigo() throws SQLException {\n try (PreparedStatement query = Herramientas.getConexion().prepareStatement(\"SELECT MAX(codigo_ticket) FROM ticket\"); \n ResultSet resultado = query.executeQuery()) {\n resultado.next();\n this.codigo = (resultado.getInt(1))+1;\n }\n \n }",
"private void setDocumentNo() {\n //\tCash Transfer\n if (\"X\".equals(getTenderType())) {\n return;\n }\n //\tCurrent Document No\n String documentNo = getDocumentNo();\n //\tExisting reversal\n if (documentNo != null\n && documentNo.indexOf(REVERSE_INDICATOR) >= 0) {\n return;\n }\n\n //\tIf external number exists - enforce it\n if (getR_PnRef() != null && getR_PnRef().length() > 0) {\n if (!getR_PnRef().equals(documentNo)) {\n setDocumentNo(getR_PnRef());\n }\n return;\n }\n\n documentNo = \"\";\n\n /* Begin e-Evolution\n //\tCredit Card\n if (TENDERTYPE_CreditCard.equals(getTenderType()))\n {\n documentNo = getCreditCardType()\n + \" \" + Obscure.obscure(getCreditCardNumber())\n + \" \" + getCreditCardExpMM()\n + \"/\" + getCreditCardExpYY();\n }\n //\tOwn Check No\n else\n // End e-Evolution */\n\n if (TENDERTYPE_Check.equals(getTenderType())\n && !isReceipt()\n && getCheckNo() != null && getCheckNo().length() > 0) {\n documentNo = getCheckNo();\n }\n //\tCustomer Check: Routing: Account #Check\n //begin e-evolution vpj-cd 11 MAy 2006\n\t\t/*else if (TENDERTYPE_Check.equals(getTenderType())\n && isReceipt())\n {\n if (getRoutingNo() != null)\n documentNo = getRoutingNo() + \": \";\n if (getAccountNo() != null)\n documentNo += getAccountNo();\n if (getCheckNo() != null)\n {\n if (documentNo.length() > 0)\n documentNo += \" \";\n documentNo += \"#\" + getCheckNo();\n }\n }\n // End e-Evolution */\n //\tSet Document No\n documentNo = documentNo.trim();\n if (documentNo.length() > 0) {\n setDocumentNo(documentNo);\n }\n }",
"public final int getRollNo() {\n\t\t// this.rollNo = 10 ;\n\t\treturn this.rollNo;\n\t}",
"public VoucherRedeemResult(long serialNumber) {\r\n\t\tthis.redeemVoucherResultStatus = ResultStatusCode.SUCCESS;\r\n\t\tthis.serialNumber = serialNumber;\r\n\t}",
"public String getRequisitionNumber() {\r\n return requisitionNumber;\r\n }",
"public void setManagescore(BigDecimal managescore) {\n this.managescore = managescore;\n }",
"@Override\n\tpublic void msgRentDue(Landlord l, int rentrate) {\n\t\thouseperson.getBills().add(8);\n\t\tlog.add(new LoggedEvent(\"Received rent due from Landlord\"));\n\t}",
"public void setRrNo (java.lang.String rrNo) {\n\t\tthis.rrNo = rrNo;\n\t}",
"@Override\n\tpublic int religioncount() throws Exception {\n\t\treturn dao.religioncount();\n\t}",
"public void setNbr_read(int nbr_read) {\r\n\t\tthis.nbrRead = nbr_read;\r\n\t}",
"public void payDueAmount(String mobileNumber, int dueAmount) {\n\t\tSystem.out.println(em.find(Receipt.class, mobileNumber));\r\n\t\tReceipt receipt = em.find(Receipt.class, mobileNumber);\r\n\r\n\t\tint currentDue = receipt.getDueAmount() - dueAmount;\r\n\r\n\t\t/**\r\n\t\t * store the records in due pay table\r\n\t\t */\r\n\t\tDuePay duePay = new DuePay();\r\n\t\tduePay.setBatchNo(receipt.getBatchNo());\r\n\t\tduePay.setStudentId(receipt.getStudentId());\r\n\t\tduePay.setStudentName(receipt.getStudentName());\r\n\t\tduePay.setCourse(receipt.getCourse());\r\n\t\tduePay.setDate(\"08-08-2018\");\r\n\t\tduePay.setDuePaid(dueAmount);\r\n\t\tduePay.setEmailId(receipt.getEmailId());\r\n\t\tduePay.setStudentName(receipt.getStudentName());\r\n\t\tduePay.setTotalDueAmount(receipt.getDueAmount());\r\n\t\tduePay.setMobileNumber(mobileNumber);\r\n\t\tduePay.setBalDueAmount(currentDue);\r\n\t\t/**\r\n\t\t * transaction begin\r\n\t\t */\r\n\t\tem.getTransaction().begin();\r\n\t\t\r\n\t\tem.persist(duePay);\r\n\r\n\t\t/**\r\n\t\t * upadating previous Receipt Due with due paid amount\r\n\t\t */\r\n\t\treceipt.setDueAmount(currentDue);\r\n\t/**\r\n\t * updating total amount in Receipt table\r\n\t */\r\n\t\tInteger currentTotalAmount = receipt.getTotaAmount()+dueAmount;\r\n\t\treceipt.setTotaAmount(currentTotalAmount);\r\n\r\n\t\tem.persist(receipt);\r\n\t\tem.getTransaction().commit();\r\n\r\n\t}",
"public void setOtherLockNum(Long otherLockNum) {\n this.otherLockNum = otherLockNum;\n }",
"public Long getReceiveNum() {\r\n return receiveNum;\r\n }",
"public void setSERIAL_NO(BigDecimal SERIAL_NO) {\r\n this.SERIAL_NO = SERIAL_NO;\r\n }",
"public void setSERIAL_NO(BigDecimal SERIAL_NO) {\r\n this.SERIAL_NO = SERIAL_NO;\r\n }",
"public void setAccountNo(int number){\n\t\taccountNo = number;\n\t}",
"public void setRecreateIndexes(java.lang.Long value);",
"public void setUserSeqNbr(Long userSeqNbr) \n\t{\n\t\tthis.userSeqNbr = userSeqNbr;\n\t}",
"public void setTransNo (java.lang.Long transNo) {\r\n\t\tthis.transNo = transNo;\r\n\t\tthis.hashCode = Integer.MIN_VALUE;\r\n\t}",
"@Override\n\tpublic void updateJoinUserRefuse(int joinNumber) {\n\t\tuserInfoDAO.updateJoinUserRefuse(joinNumber);\n\t}",
"public boolean lockRecord(LeaveEncashmentProcess leaveEncashProcess, String empCode[], \r\n\t\t\tString encashAmount[], String tds[]) {\n\t\tboolean result = false;\r\n\t\ttry {\r\n\t\t\tString month = leaveEncashProcess.getSalarymonth();\r\n\t\t\tString fromYear = leaveEncashProcess.getSalaryyear();\r\n\t\t\tString toYear = \"\";\r\n\t\t\tif(Integer.parseInt(month) < 4){\r\n\t\t\t\ttoYear = fromYear;\r\n\t\t\t\tfromYear = String.valueOf((Integer.parseInt(fromYear) - 1));\r\n\t\t\t} else{\r\n\t\t\t\ttoYear = String.valueOf((Integer.parseInt(fromYear) + 1));\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\tString TDS_DEBIT_CODE=\"\";\r\n\t\t\tString query = \" SELECT NVL(TDS_DEBIT_CODE,0) FROM HRMS_TAX_PARAMETER\"\r\n\t\t\t\t\t+ \" WHERE TDS_FINANCIALYEAR_FROM = \"\r\n\t\t\t\t\t+ fromYear\r\n\t\t\t\t\t+ \" AND TDS_FINANCIALYEAR_TO = \"\r\n\t\t\t\t\t+ toYear;\r\n\t\t\tObject [][] tdsDebitCodeObj=getSqlModel().getSingleResult(query)\t;\r\n\t\t\tif(tdsDebitCodeObj!=null && tdsDebitCodeObj.length>0){\r\n\t\t\t\tTDS_DEBIT_CODE=String.valueOf(tdsDebitCodeObj[0][0]);\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\t\r\n\t\t\tquery = \" UPDATE HRMS_ENCASHMENT_PROCESS_HDR \"\r\n\t\t\t\t\t+ \" SET ENCASHMENT_PROCESS_FLAG='Y' WHERE ENCASHMENT_PROCESS_CODE=\"\r\n\t\t\t\t\t+ leaveEncashProcess.getProcessCode();\r\n\t\t\tresult = getSqlModel().singleExecute(query);\r\n\t\t\t\r\n\t\t\tif (empCode != null && empCode.length > 0 \r\n\t\t\t\t&& !leaveEncashProcess.getSalarymonth().equals(\"\") \r\n\t\t\t\t&& !leaveEncashProcess.getSalaryyear().equals(\"\")) {\r\n\t\t\t\tquery = \"DELETE FROM HRMS_MISC_SALARY_UPLOAD WHERE APPL_CODE = \"\r\n\t\t\t\t\t\t+ leaveEncashProcess.getProcessCode()\r\n\t\t\t\t\t\t+ \" AND APPL_TYPE = 'L'\"\r\n\t\t\t\t\t\t+ \" AND MONTH = \"\r\n\t\t\t\t\t\t+ leaveEncashProcess.getSalarymonth()\r\n\t\t\t\t\t\t+ \" AND YEAR = \"\r\n\t\t\t\t\t\t+ leaveEncashProcess.getSalaryyear();\r\n\r\n\t\t\t\tresult = getSqlModel().singleExecute(query);\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\tif(leaveEncashProcess.getSalaryCheck().equals(\"true\")){\r\n\t\t\t\tif(empCode != null && empCode.length > 0 && encashAmount != null && encashAmount.length > 0 ){\r\n\t\t\t\t\tfor (int i = 0; i < empCode.length; i++) {\r\n\t\t\t\t\t\tquery = \"INSERT INTO HRMS_MISC_SALARY_UPLOAD (EMP_ID, MONTH, YEAR, UPLOAD_PAY_TYPE, \" +\r\n\t\t\t\t\t\t\t\t\"SALARY_CODE, SALARY_AMOUNT, UPLOAD_IS_OVERWRITE, APPL_CODE, \" +\r\n\t\t\t\t\t\t\t\t\"APPL_TYPE, DISPLAY_FLAG, COMMENTS) \" +\r\n\t\t\t\t\t\t\t\t\"VALUES ( \" + empCode[i] + \r\n\t\t\t\t\t\t\t\t\",\" + leaveEncashProcess.getSalarymonth() + \r\n\t\t\t\t\t\t\t\t\",\" + leaveEncashProcess.getSalaryyear() + \r\n\t\t\t\t\t\t\t\t\",'C',\" + leaveEncashProcess.getCreditCode() + \r\n\t\t\t\t\t\t\t\t\",\" + encashAmount[i] + \r\n\t\t\t\t\t\t\t\t\",'Y'\" +\r\n\t\t\t\t\t\t\t\t\",\" + leaveEncashProcess.getProcessCode() +\r\n\t\t\t\t\t\t\t\t\",'L','Y','LEAVE ENCASHMENT AMOUNT')\" ;\r\n\t\t\t\r\n\t\t\t\t\t\tresult = getSqlModel().singleExecute(query);\t\t\t\t\t\t\r\n\t\t\t\t\t\t\r\n\t\t\t\t\t\tif(!TDS_DEBIT_CODE.equals(\"\")){\r\n\t\t\t\t\t\t\tquery = \"INSERT INTO HRMS_MISC_SALARY_UPLOAD (EMP_ID, MONTH, YEAR, UPLOAD_PAY_TYPE, \" +\r\n\t\t\t\t\t\t\t\t\"SALARY_CODE, SALARY_AMOUNT, UPLOAD_IS_OVERWRITE, APPL_CODE, \" +\r\n\t\t\t\t\t\t\t\t\"APPL_TYPE, DISPLAY_FLAG, COMMENTS) \" +\r\n\t\t\t\t\t\t\t\t\"VALUES ( \" + empCode[i] + \r\n\t\t\t\t\t\t\t\t\",\" + leaveEncashProcess.getSalarymonth() + \r\n\t\t\t\t\t\t\t\t\",\" + leaveEncashProcess.getSalaryyear() + \r\n\t\t\t\t\t\t\t\t\",'D',\" + TDS_DEBIT_CODE + \r\n\t\t\t\t\t\t\t\t\",\" + tds[i] + \r\n\t\t\t\t\t\t\t\t\",'Y'\" +\r\n\t\t\t\t\t\t\t\t\",\" + leaveEncashProcess.getProcessCode() +\r\n\t\t\t\t\t\t\t\t\",'L','N','LEAVE ENCASHMENT AMOUNT')\" ;\r\n\t\t\t\t\t\t}\r\n\t\r\n\t\t\t\t\t\tresult = getSqlModel().singleExecute(query);\t\t\t\t\t\t\r\n\t\t\t\t\t\t\r\n\t\t\t\t\t\tquery = \"UPDATE HRMS_SALARY_\" +leaveEncashProcess.getSalaryyear() \r\n\t\t\t\t\t\t\t+ \" SET EMP_MISC_UPLOAD_FLAG='Y' \"\r\n\t\t\t\t\t\t\t+ \" WHERE EMP_ID = \" + empCode[i]\r\n\t\t\t\t\t\t\t+ \" AND SAL_MONTH=\" + leaveEncashProcess.getSalarymonth() \r\n\t\t\t\t\t\t\t+ \" AND SAL_YEAR =\" + leaveEncashProcess.getSalaryyear();\r\n\t\t\t\t\t\tresult = getSqlModel().singleExecute(query);\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\t\r\n\t\t} catch (Exception e) {\r\n\t\t\t// TODO: handle exception\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t\treturn result;\r\n\t}",
"public void setReparentTransactionRecordId( int reparentTransactionRecordId )\n{\n\tm_reparentTransactionRecordId = reparentTransactionRecordId;\n}",
"public void setUserSeqNbr(Long userSeqNbr)\n\t{\n\t\tthis.userSeqNbr = userSeqNbr;\n\t}",
"public void setp_recpt_no(String value) {\n setNamedWhereClauseParam(\"p_recpt_no\", value);\n }",
"public void setNumToProcess(long aNumToProcess) {\n numToProcess = aNumToProcess;\n }",
"protected void setLeaveDurationHour(EmployeeLeave employeeLeave, ResultSet rs, int rowNumber) throws SQLException{\n\t\tInteger leaveDurationHour = rs.getInt(EmployeeLeaveTable.COLUMN_LEAVE_DURATION_HOUR);\n\t\tif(leaveDurationHour == null){\n\t\t\t//do nothing when nothing found in database\n\t\t\treturn;\n\t\t}\n\t\n\t\temployeeLeave.setLeaveDurationHour(leaveDurationHour);\n\t}",
"public void setNUM_DB(int NUM_DB) \r\n {\r\n if(NUM_DB > 0)\r\n this.NUM_DB = NUM_DB;\r\n }",
"public void setSeqNo (java.lang.Integer seqNo) {\n\t\tthis.seqNo = seqNo;\n\t}",
"private Long modificarCorreoElectronico(CorreoElectronico correo) {\n\t\ttry {\n\t\t\t gCorreoElectronico.modify(correo);\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn correo.getIdCorreoElectronico();\n\t}",
"public void setChangeNum(Long changeNum) {\n this.changeNum = changeNum;\n }",
"public int getM_Requisition_ID() {\n\t\tInteger ii = (Integer) get_Value(\"M_Requisition_ID\");\n\t\tif (ii == null)\n\t\t\treturn 0;\n\t\treturn ii.intValue();\n\t}",
"public void setLBR_DIFAL_TaxAmtICMSUFRemet (BigDecimal LBR_DIFAL_TaxAmtICMSUFRemet);",
"public void setReceivalMonth(int receivalMonth){\n\t\tthis.receivalMonth = receivalMonth;\n\t}",
"public void setHistoryRebate(BigDecimal historyRebate) {\n this.historyRebate = historyRebate;\n }",
"public void setLBR_TaxReliefAmt (BigDecimal LBR_TaxReliefAmt);",
"public Long getLockNum() {\n return lockNum;\n }",
"public void setOrderNo (Long orderNo) {\r\n\t\tthis.orderNo = orderNo;\r\n\t}",
"public int getReceivalMonth(){\n\t\treturn this.receivalMonth;\n\t}",
"@Accessor(qualifier = \"redemptionQuantityLimit\", type = Accessor.Type.SETTER)\n\tpublic void setRedemptionQuantityLimit(final Integer value)\n\t{\n\t\tgetPersistenceContext().setPropertyValue(REDEMPTIONQUANTITYLIMIT, value);\n\t}",
"public long getSeqNo() {\n return seqNo;\n }",
"public long getContainNReadNum() {\n return containNReadNum;\n }",
"protected void setId(EmployeeLeave employeeLeave, ResultSet rs, int rowNumber) throws SQLException{\n\t\tString id = rs.getString(EmployeeLeaveTable.COLUMN_ID);\n\t\tif(id == null){\n\t\t\t//do nothing when nothing found in database\n\t\t\treturn;\n\t\t}\n\t\n\t\temployeeLeave.setId(id);\n\t}",
"@Accessor(qualifier = \"redemptionQuantityLimit\", type = Accessor.Type.GETTER)\n\tpublic Integer getRedemptionQuantityLimit()\n\t{\n\t\treturn getPersistenceContext().getPropertyValue(REDEMPTIONQUANTITYLIMIT);\n\t}",
"@Override\n\tpublic void setMaxnum(long maxnum) {\n\t\t_esfTournament.setMaxnum(maxnum);\n\t}",
"public void recuperarNumReg() throws BaseDeDatosExcepcion, ConexionExcepcion {\n\t\tif (logger.isDebugEnabled()) {\n\t\t\tlogger.debug(\"recuperarNumReg() - start\");\n\t\t}\n\n\t\tnumRegistro--;\n\t\tMediadorBD.actualizarRegistroCaja(numRegistro);\n\n\t\tif (logger.isDebugEnabled()) {\n\t\t\tlogger.debug(\"recuperarNumReg() - end\");\n\t\t}\n\t}",
"public void setPeti_numero(java.lang.Long newPeti_numero);",
"public void setPeti_numero(java.lang.Long newPeti_numero);",
"public void setLBR_SeqNumberInBank_ID (int LBR_SeqNumberInBank_ID)\n\t{\n\t\tif (LBR_SeqNumberInBank_ID < 1) \n\t\t\tset_Value (COLUMNNAME_LBR_SeqNumberInBank_ID, null);\n\t\telse \n\t\t\tset_Value (COLUMNNAME_LBR_SeqNumberInBank_ID, Integer.valueOf(LBR_SeqNumberInBank_ID));\n\t}",
"public final void setNum_emp(String val) {\n setString(getNum_empAttribute(getMtDatabase()), val);\n }",
"public void setCedulaPersonaRecido(long cedulaPersonaRecido) {\r\n\t\tthis.cedulaPersonaRecive = cedulaPersonaRecido;\r\n\t}",
"public String getRemasterCatalogueNumber() {\r\n\t\treturn this.remasterCatalogueNumber;\r\n\t}",
"public java.lang.Long getRelateTransno () {\r\n\t\treturn relateTransno;\r\n\t}",
"@Override\n\tpublic int updateRoleInfo(FRoleCustom fRoleCustom) throws Exception {\n\t\tDBContextHolder.setDBType(\"0\");\n\t\treturn froleMapper.updateRoleInfo(fRoleCustom);\n\t}",
"@Test\n public void revNum() throws Exception {\n Document doc = new Document();\n DocumentBuilder builder = new DocumentBuilder(doc);\n\n builder.write(\"Current revision #\");\n\n // Insert a REVNUM field, which displays the document's current revision number property.\n FieldRevNum field = (FieldRevNum) builder.insertField(FieldType.FIELD_REVISION_NUM, true);\n\n Assert.assertEquals(\" REVNUM \", field.getFieldCode());\n Assert.assertEquals(\"1\", field.getResult());\n Assert.assertEquals(1, doc.getBuiltInDocumentProperties().getRevisionNumber());\n\n // This property counts how many times a document has been saved in Microsoft Word,\n // and is unrelated to tracked revisions. We can find it by right clicking the document in Windows Explorer\n // via Properties -> Details. We can update this property manually.\n doc.getBuiltInDocumentProperties().setRevisionNumber(doc.getBuiltInDocumentProperties().getRevisionNumber() + 1)/*Property++*/;\n Assert.assertEquals(\"1\", field.getResult()); //ExSkip\n field.update();\n\n Assert.assertEquals(\"2\", field.getResult());\n //ExEnd\n\n doc = DocumentHelper.saveOpen(doc);\n Assert.assertEquals(2, doc.getBuiltInDocumentProperties().getRevisionNumber());\n\n TestUtil.verifyField(FieldType.FIELD_REVISION_NUM, \" REVNUM \", \"2\", doc.getRange().getFields().get(0));\n }",
"public void setNumRespAtracc(int num);",
"public void setreceiptnum(String value) {\n setAttributeInternal(RECEIPTNUM, value);\n }",
"public void setAccNo(int accNo) {\r\n\t\tthis.accNo = accNo+1;\r\n\t}",
"public void xsetPaymentRefNo(x0401.oecdStandardAuditFileTaxPT1.PaymentRefNoDocument.PaymentRefNo paymentRefNo)\n {\n synchronized (monitor())\n {\n check_orphaned();\n x0401.oecdStandardAuditFileTaxPT1.PaymentRefNoDocument.PaymentRefNo target = null;\n target = (x0401.oecdStandardAuditFileTaxPT1.PaymentRefNoDocument.PaymentRefNo)get_store().find_element_user(PAYMENTREFNO$0, 0);\n if (target == null)\n {\n target = (x0401.oecdStandardAuditFileTaxPT1.PaymentRefNoDocument.PaymentRefNo)get_store().add_element_user(PAYMENTREFNO$0);\n }\n target.set(paymentRefNo);\n }\n }",
"public void updateReadCount(String num){\r\n\t\tString sql=\"update board_notice set readcount=readcount+1 where num=?\";\r\n\t\tConnection conn=null;\r\n\t\tPreparedStatement pstmt=null;\r\n\t\ttry{\r\n\t\t\tconn=DBManager.getConnection();\r\n\t\t\tpstmt=conn.prepareStatement(sql);\r\n\t\t\tpstmt.setString(1, num);\r\n\t\t\tpstmt.executeUpdate();\r\n\t\t}catch(Exception e){\r\n\t\t\te.printStackTrace();\r\n\t\t}finally{\r\n\t\t\tDBManager.close(conn,pstmt);\r\n\t\t}\r\n\t}",
"public final void setRowLimit(int newObj)throws SL_Exception\n {\n setRowLimit(newObj, null);\n }",
"@ApiModelProperty(required = true, value = \"A value used to tie together service calls related to a single financial transaction. When passing Account Funding Transaction (AFT) and an Original Credit Transaction (OCT) methods, this value must differ between the two methods. When passing the Account Funding Transaction Reversal (AFTR) method, this value must match the retrievalReferenceNumber previously passed with the AFT method for this transaction.<br><br> Recommended Format : ydddhhnnnnnn<br><br>The first fours digits must be a valid yddd date in the Julian date format, where the first digit = 0-9 (last digit of current year) and the next three digits = 001-366 (number of the day in the year). hh can be the two digit hour in a 24 hour clock (00-23) during which the transaction is performed.<br><br> nnnnnn can be the systemsTraceAuditNumber or any 6 digit number.\")\n public String getRetrievalReferenceNumber() {\n return retrievalReferenceNumber;\n }",
"public BigDecimal getREF_NO() {\r\n return REF_NO;\r\n }"
]
| [
"0.52816343",
"0.52800834",
"0.52531654",
"0.5001064",
"0.49810743",
"0.49596703",
"0.4943315",
"0.4911607",
"0.49018863",
"0.4842746",
"0.48055297",
"0.47948027",
"0.47866198",
"0.47835502",
"0.47774133",
"0.47707185",
"0.47640657",
"0.47640657",
"0.47337753",
"0.4689714",
"0.46892604",
"0.46753404",
"0.46648258",
"0.46495867",
"0.46495867",
"0.4630319",
"0.46297243",
"0.4615075",
"0.46089602",
"0.45985106",
"0.45960176",
"0.45803392",
"0.45788223",
"0.4578124",
"0.4571838",
"0.4537204",
"0.45369345",
"0.45185405",
"0.45130986",
"0.45076475",
"0.45069343",
"0.44735438",
"0.44700468",
"0.4468642",
"0.44631693",
"0.4453897",
"0.44511124",
"0.44480264",
"0.44421068",
"0.44312748",
"0.4424328",
"0.4404762",
"0.4404762",
"0.44022578",
"0.43914393",
"0.43863454",
"0.43854883",
"0.43716714",
"0.43630567",
"0.4362152",
"0.4360772",
"0.43537116",
"0.43536562",
"0.43478101",
"0.43475235",
"0.43463203",
"0.4343618",
"0.43402418",
"0.43377927",
"0.4334016",
"0.4331564",
"0.43312564",
"0.4327969",
"0.43273205",
"0.4322795",
"0.43213895",
"0.43173972",
"0.43145713",
"0.43142506",
"0.43127492",
"0.43085134",
"0.43045437",
"0.42992494",
"0.42947826",
"0.42947826",
"0.42942137",
"0.42914072",
"0.42910784",
"0.42822263",
"0.4269141",
"0.42669135",
"0.42657968",
"0.4265339",
"0.42652047",
"0.4263089",
"0.42568967",
"0.4255783",
"0.42547086",
"0.42537227",
"0.42491683"
]
| 0.5937892 | 0 |
This method was generated by MyBatis Generator. This method returns the value of the database column TFC_USE_LOCK_DETAIL.OTHER_LOCK_NUM | public Long getOtherLockNum() {
return otherLockNum;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setOtherLockNum(Long otherLockNum) {\n this.otherLockNum = otherLockNum;\n }",
"public Long getLockNum() {\n return lockNum;\n }",
"public int getOtherId() {\n return instance.getOtherId();\n }",
"public int getOtherId() {\n return otherId_;\n }",
"public Integer getgOtherId() {\n return gOtherId;\n }",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"public java.lang.String getZTEL_NUMBER2()\n {\n \n return __ZTEL_NUMBER2;\n }",
"public java.math.BigDecimal getOtherPayoutAmount() {\r\n return otherPayoutAmount;\r\n }",
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"@TableElement(index = 3, name = \"Other Component\")\n public @Nullable Formula getOtherComponent() {\n return otherComponent;\n }",
"public Long getTwoagent() {\n return twoagent;\n }",
"public Long getOrderNo () {\r\n\t\treturn orderNo;\r\n\t}",
"public String getNumberOfOther() {\n return numberOfOther;\n }",
"public Integer getgOtherPayTypeId() {\n return gOtherPayTypeId;\n }",
"public String getOther2() {\n return other2;\n }",
"@Override\n public int getTxTimeoutInMillis() {\n return Globals.lockingTimeout;\n }",
"public int getLockon() {\r\n return lockon;\r\n }",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"public gov.nih.nlm.ncbi.www.SeqIdDocument.SeqId.Other getOther()\r\n {\r\n synchronized (monitor())\r\n {\r\n check_orphaned();\r\n gov.nih.nlm.ncbi.www.SeqIdDocument.SeqId.Other target = null;\r\n target = (gov.nih.nlm.ncbi.www.SeqIdDocument.SeqId.Other)get_store().find_element_user(OTHER$18, 0);\r\n if (target == null)\r\n {\r\n return null;\r\n }\r\n return target;\r\n }\r\n }",
"public Long getOrdermoney() {\n return ordermoney;\n }",
"public String getLoyaltyNumber() {\n if (compositePOSTransaction.getLoyaltyCard() != null)\n return compositePOSTransaction.getLoyaltyCard().getLoyaltyNumber();\n else\n return null;\n }",
"public String getLockId() {\n return lockId;\n }",
"public void setOrderNo (Long orderNo) {\r\n\t\tthis.orderNo = orderNo;\r\n\t}",
"@Override\n public boolean equals(Object that) {\n if (this == that) {\n return true;\n }\n if (that == null) {\n return false;\n }\n if (getClass() != that.getClass()) {\n return false;\n }\n TFCUseLockDetail other = (TFCUseLockDetail) that;\n return (this.getRowId() == null ? other.getRowId() == null : this.getRowId().equals(other.getRowId()))\n && (this.getCoinTypeId() == null ? other.getCoinTypeId() == null : this.getCoinTypeId().equals(other.getCoinTypeId()))\n && (this.getRecTime() == null ? other.getRecTime() == null : this.getRecTime().equals(other.getRecTime()))\n && (this.getActiontype() == null ? other.getActiontype() == null : this.getActiontype().equals(other.getActiontype()))\n && (this.getLockId() == null ? other.getLockId() == null : this.getLockId().equals(other.getLockId()))\n && (this.getUserId() == null ? other.getUserId() == null : this.getUserId().equals(other.getUserId()))\n && (this.getServerIp() == null ? other.getServerIp() == null : this.getServerIp().equals(other.getServerIp()))\n && (this.getGameId() == null ? other.getGameId() == null : this.getGameId().equals(other.getGameId()))\n && (this.getServerName() == null ? other.getServerName() == null : this.getServerName().equals(other.getServerName()))\n && (this.getLockNum() == null ? other.getLockNum() == null : this.getLockNum().equals(other.getLockNum()))\n && (this.getChangeNum() == null ? other.getChangeNum() == null : this.getChangeNum().equals(other.getChangeNum()))\n && (this.getRemainNum() == null ? other.getRemainNum() == null : this.getRemainNum().equals(other.getRemainNum()))\n && (this.getOtherLockNum() == null ? other.getOtherLockNum() == null : this.getOtherLockNum().equals(other.getOtherLockNum()));\n }",
"private String getDoubleLockSBRStmt() {\n\n if (null == mDoubleLockStmt) {\n initClauses();\n mDoubleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE ( s.EUID = ? AND s.REVISIONNUMBER = ?) OR ( s.EUID = ? AND s.REVISIONNUMBER = ?)\" + mForUpdateClause;\n }\n\n return mDoubleLockStmt;\n }",
"public String getOtherinfo() {\n return otherinfo;\n }",
"public void setOrdermoney(Long ordermoney) {\n this.ordermoney = ordermoney;\n }",
"public Long getLock_latency() {\n return lock_latency;\n }",
"public int getLockAddress() {\n\t\treturn 0;\n\t}",
"public String getLockUser() {\n return lockUser;\n }",
"@Transient\n\tpublic long getTransactionIdLong() {\n\t\treturn mTransactionIdLong;\n\t}",
"public int getNum2() {\r\n\t\t\t\treturn num2_;\r\n\t\t\t}",
"public void setNumberOfOther(String numberOfOther) {\n this.numberOfOther = numberOfOther;\n }",
"public int getNum2() {\r\n\t\t\treturn num2_;\r\n\t\t}",
"public long getUnknown2() {\n return unknown2_;\n }",
"final long internalLongLock() {\n return byteBase.longLockPointer();\n }",
"public String getLockedUserId() {\n\t\treturn lockedUserId;\n\t}",
"public long getUnknown2() {\n return unknown2_;\n }",
"public Long getBillDtlNo() {\n return billDtlNo;\n }",
"protected String getLockManagerName() {\n return getName();\n }",
"public String getBuild2Number() {\n\t\treturn \"\"+nb_build2;\n\t}",
"public String getOutAccountNo() {\r\n return outAccountNo;\r\n }",
"public void setOtherPayoutAmount(java.math.BigDecimal otherPayoutAmount) {\r\n this.otherPayoutAmount = otherPayoutAmount;\r\n }",
"public long getOrderNumber()\n {\n return _orderNumber;\n }",
"public int getMyOtherInt() {\n return myOtherInt;\n }",
"public int getLuckyTicket() {\n return luckyTicket_;\n }",
"public java.lang.Long getTransNo () {\r\n\t\treturn transNo;\r\n\t}",
"public jkt.hms.masters.business.MasUnit getOtherUnit () {\n\t\treturn otherUnit;\n\t}",
"public BookingLockDetails getBookingLockDetails(com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.bookinglockdetails.v1.BookingLockDetails res){\n\t\tBookingLockDetails bookingLockDetails = new BookingLockDetails();\n\t\t\n\t\tbookingLockDetails.setBookingNo( res.getBookingNo() );\n\t\tbookingLockDetails.setLockId( res.getLockId() );\n\t\tbookingLockDetails.setLockMessage( res.getLockMessage() );\n\t\tif( res.isAlreadyLocked() != null ){\n\t\t\tbookingLockDetails.setAlreadyLocked( res.isAlreadyLocked().booleanValue() );\n\t\t}\n\t\tif( res.isAdmin() != null ){\n\t\t\tbookingLockDetails.setAdmin( res.isAdmin().booleanValue() );\n\t\t}\n\t\t\n\t\treturn bookingLockDetails;\n\t}",
"public int getLuckyTicket() {\n return luckyTicket_;\n }",
"public BigDecimal getLstCustManagerId() {\n return lstCustManagerId;\n }",
"long getInvalidLoginLockoutTime();",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public static Value makeAnyNumOther() {\n return theNumOther;\n }",
"public int getAccountNo()\r\n\t{\r\n\t\t\r\n\t\treturn accountNo;\r\n\t\t\r\n\t}",
"public Long getBillNo() {\n return billNo;\n }",
"public static String getOracleUserId(ASPManager mgr) {\n\t\tASPContext aspCtx = mgr.getASPContext();\n\t\t\n\t\tString oracle_user_id = aspCtx.findGlobal(CURRENT_FND_USER_ID);\n\t\tif(false == mgr.isEmpty(oracle_user_id)){\n\t\t\treturn oracle_user_id;\n\t\t}\n\t\tASPTransactionBuffer trans = mgr.newASPTransactionBuffer();\n//\t\tString sql = \"SELECT PERSON_INFO_API.Get_Id_For_User(Fnd_Session_API.Get_Fnd_User) USERID FROM DUAL\";\n\t\tString sql = \"SELECT Fnd_Session_API.Get_Fnd_User USERID FROM DUAL\";\n\t\ttrans.addQuery(\"USER\", sql);\n\t\ttrans = mgr.perform(trans);\n\t\toracle_user_id = trans.getValue(\"USER/DATA/USERID\").toLowerCase();\n\t\taspCtx.setGlobal(CURRENT_FND_USER_ID, oracle_user_id);\n\t\tcom.horizon.todo.grdb.GrdbUtil d;\n\t\treturn oracle_user_id;\n\t}",
"public int getCurrentNumberOfPaymentsOtherLoans() throws SQLException{\n\t\tConnection conn = DataSource.getConnection();\n\t\ttry{\n\t\t\t\n\t\t\tString query = \"SELECT current_payment_counter FROM loan \"\n\t\t\t\t\t\t+ \" WHERE client_id = '\"+this.client_id+\"' AND start_date = '\"+this.start_date+\"';\";\n\t\t\n\t\t\tStatement stat = conn.createStatement();\n\t\t\tResultSet rs = stat.executeQuery(query);\n\t\t\tif (rs.next())\n\t\t\t\treturn rs.getInt(1);\n\t\t\treturn 0;\n\t\t}finally{\n\t\t\tconn.close();\n\t\t}\n\t}",
"public static long m33346a(AtomicLong atomicLong, long j) {\n long j2;\n do {\n j2 = atomicLong.get();\n if (j2 == Long.MAX_VALUE) {\n return Long.MAX_VALUE;\n }\n } while (!atomicLong.compareAndSet(j2, m33345a(j2, j)));\n return j2;\n }",
"@Transient\n\tpublic long getRefundPaymentTransactionIdLong() {\n\t\tif (mRefundPaymentTransactionIdLong == -1) {\n\t\t\tif (mRefundPaymentTransactionId != null) {\n\t\t\t\ttry {\n\t\t\t\t\tmRefundPaymentTransactionIdLong = Long.parseLong(mRefundPaymentTransactionId);\n\t\t\t\t}\n\t\t\t\tcatch (NumberFormatException ne) {\n\t\t\t\t\t// nothing\n\t\t\t\t\tmRefundPaymentTransactionIdLong = -2;\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn mRefundPaymentTransactionIdLong;\n\t}",
"public void setgOtherId(Integer gOtherId) {\n this.gOtherId = gOtherId;\n }",
"public int getAccountNo() {\n return accountNo;\n }",
"public Integer getgOtherGroupsId() {\n return gOtherGroupsId;\n }",
"public long getNumber(){\n return number;\r\n }",
"public long getMyLong() {\n return myLong;\n }",
"public int getProperty2() {\n return property2_;\n }",
"@gw.internal.gosu.parser.ExtendedProperty\n public java.lang.Long getInstrumentedWorkExecutorID() {\n return (java.lang.Long)__getInternalInterface().getFieldValue(INSTRUMENTEDWORKEXECUTORID_PROP.get());\n }",
"public long gettNum() {\n return tNum;\n }",
"public int getProperty2() {\n return property2_;\n }",
"public java.lang.String getHOUSE_NUM2()\n {\n \n return __HOUSE_NUM2;\n }",
"public String getOldNum(){\n return cal.getOldNum();\n }",
"public long getOrderNumber() {\n return (long) (Math.random() * 999999999999L);\n }",
"public String getOthers1() {\n return others1;\n }",
"public long getLockStatus() {\r\n return lockStatus;\r\n }",
"public int getAccountNo() {\n\t\treturn this.accountNo;\r\n\t}",
"public String getAdminOther() {\n return adminOther;\n }",
"String getLockOwner();",
"private Integer getLockFromId(long lockId)\n throws IOException {\n if(lockId == -1L) {\n return null;\n }\n String lockName = String.valueOf(lockId);\n Integer rl = null;\n synchronized(rowlocks) {\n rl = rowlocks.get(lockName);\n }\n if(rl == null) {\n throw new IOException(\"Invalid row lock\");\n }\n this.leases.renewLease(lockName);\n return rl;\n }",
"public final OpLockDetails getOpLock() {\n\t\treturn m_oplock;\n\t}",
"@gw.internal.gosu.parser.ExtendedProperty\n public java.lang.Long getInstrumentedWorkExecutorID() {\n return (java.lang.Long)__getInternalInterface().getFieldValue(INSTRUMENTEDWORKEXECUTORID_PROP.get());\n }",
"public String getLstCustNo() {\n return lstCustNo;\n }",
"public String getOther() {\n return other;\n }",
"public String getOther() {\n return other;\n }",
"public void setTwoagent(Long twoagent) {\n this.twoagent = twoagent;\n }",
"public java.lang.String getTicketNo () {\r\n\t\treturn ticketNo;\r\n\t}",
"@Override\n protected Integer getTicketNumber() {\n return null;\n }",
"public void addColumnDdcTissueFindingOther() {\n addColumnInPrimarySection(ColumnMetaData.KEY_SECTION_TISSUE_FINDING_OTHER);\n }",
"public int getCPTLNO() {\n return cptlno;\n }",
"final public Lock test_get_lock() {\r\n\t\treturn lock_;\r\n\t}",
"private void setOtherId(int value) {\n \n otherId_ = value;\n }",
"@Override\n\tpublic String getWaybillNo(String originalWaybillNo) {\n\t\treturn null;\n\t}",
"public int getUser2_ID() {\n\t\tInteger ii = (Integer) get_Value(\"User2_ID\");\n\t\tif (ii == null)\n\t\t\treturn 0;\n\t\treturn ii.intValue();\n\t}",
"public NM getSessionNo() { \r\n\t\tNM retVal = this.getTypedField(28, 0);\r\n\t\treturn retVal;\r\n }",
"public java.lang.Long getColumnLong() {\n\t throw new java.lang.UnsupportedOperationException(\"Get is not supported on tombstones\");\n\t }",
"public String getLockType() {\n return this.lockType;\n }",
"public void setZTEL_NUMBER2(java.lang.String value)\n {\n if ((__ZTEL_NUMBER2 == null) != (value == null) || (value != null && ! value.equals(__ZTEL_NUMBER2)))\n {\n _isDirty = true;\n }\n __ZTEL_NUMBER2 = value;\n }",
"private String getSingleLockSBRStmt() {\n\n if (null == mSingleLockStmt) {\n initClauses();\n mSingleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE s.EUID = ? AND s.REVISIONNUMBER = ? \" + mForUpdateClause;\n }\n\n return mSingleLockStmt;\n }",
"public Number getWork2()\r\n {\r\n return (m_work2);\r\n }"
]
| [
"0.69708025",
"0.5749135",
"0.52739215",
"0.52601445",
"0.5176651",
"0.51173246",
"0.51015407",
"0.50854945",
"0.50379694",
"0.49945197",
"0.49288952",
"0.49072376",
"0.48617375",
"0.48553622",
"0.48158973",
"0.47906172",
"0.47816512",
"0.47796702",
"0.47367346",
"0.4720073",
"0.471829",
"0.47067693",
"0.46878135",
"0.46438488",
"0.4638399",
"0.46383885",
"0.463228",
"0.46282664",
"0.459997",
"0.459268",
"0.45847794",
"0.45746258",
"0.45645404",
"0.45472395",
"0.45459324",
"0.45274714",
"0.45198476",
"0.45155635",
"0.45118526",
"0.45113575",
"0.45080256",
"0.44973755",
"0.44973248",
"0.44967782",
"0.44941267",
"0.44900262",
"0.44804493",
"0.44545165",
"0.4451376",
"0.4442707",
"0.44417244",
"0.44272718",
"0.44269696",
"0.44269696",
"0.44269696",
"0.44250277",
"0.44213435",
"0.44053608",
"0.440457",
"0.43979397",
"0.43950844",
"0.4393103",
"0.43895522",
"0.43844306",
"0.43598863",
"0.43517417",
"0.43498158",
"0.434918",
"0.43461052",
"0.43441436",
"0.4342102",
"0.43382633",
"0.4329869",
"0.43242466",
"0.4324208",
"0.43192688",
"0.4319238",
"0.4314852",
"0.43134752",
"0.43098843",
"0.4309866",
"0.43086946",
"0.43075997",
"0.4297088",
"0.4297088",
"0.4293313",
"0.42913345",
"0.42876473",
"0.42802712",
"0.42796677",
"0.42766818",
"0.4267928",
"0.42658666",
"0.42651558",
"0.42650208",
"0.42645997",
"0.4263523",
"0.4258664",
"0.42557797",
"0.4255733"
]
| 0.7515522 | 0 |
This method was generated by MyBatis Generator. This method sets the value of the database column TFC_USE_LOCK_DETAIL.OTHER_LOCK_NUM | public void setOtherLockNum(Long otherLockNum) {
this.otherLockNum = otherLockNum;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Long getOtherLockNum() {\n return otherLockNum;\n }",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"private void setOtherId(int value) {\n \n otherId_ = value;\n }",
"public void setOther(gov.nih.nlm.ncbi.www.SeqIdDocument.SeqId.Other other)\r\n {\r\n synchronized (monitor())\r\n {\r\n check_orphaned();\r\n gov.nih.nlm.ncbi.www.SeqIdDocument.SeqId.Other target = null;\r\n target = (gov.nih.nlm.ncbi.www.SeqIdDocument.SeqId.Other)get_store().find_element_user(OTHER$18, 0);\r\n if (target == null)\r\n {\r\n target = (gov.nih.nlm.ncbi.www.SeqIdDocument.SeqId.Other)get_store().add_element_user(OTHER$18);\r\n }\r\n target.set(other);\r\n }\r\n }",
"public void setOrderNo (Long orderNo) {\r\n\t\tthis.orderNo = orderNo;\r\n\t}",
"public final void setOrderNumber(Long ordernumber)\r\n\t{\r\n\t\tsetOrderNumber(getContext(), ordernumber);\r\n\t}",
"public void setZTEL_NUMBER2(java.lang.String value)\n {\n if ((__ZTEL_NUMBER2 == null) != (value == null) || (value != null && ! value.equals(__ZTEL_NUMBER2)))\n {\n _isDirty = true;\n }\n __ZTEL_NUMBER2 = value;\n }",
"public void setOrdermoney(Long ordermoney) {\n this.ordermoney = ordermoney;\n }",
"public void setNumberOfOther(String numberOfOther) {\n this.numberOfOther = numberOfOther;\n }",
"public Long getLockNum() {\n return lockNum;\n }",
"public void setLockKey( Long lockKey ) {\n this.lockKey = lockKey;\n }",
"public void setOtherPayoutAmount(java.math.BigDecimal otherPayoutAmount) {\r\n this.otherPayoutAmount = otherPayoutAmount;\r\n }",
"public abstract void setCntOther(int cntOther);",
"public static void setLockManagerActorRef(ActorRef lockManager) {\n\t\tglobalLockManagerActorRef = lockManager;\n\t}",
"public void setTwoagent(Long twoagent) {\n this.twoagent = twoagent;\n }",
"public void setOtherUnit (jkt.hms.masters.business.MasUnit otherUnit) {\n\t\tthis.otherUnit = otherUnit;\n\t}",
"public void setgOtherId(Integer gOtherId) {\n this.gOtherId = gOtherId;\n }",
"public void setComNumber(long value) {\r\n this.comNumber = value;\r\n }",
"public int getOtherId() {\n return otherId_;\n }",
"@Override\n public void setTxTimeoutInMillis(int ms) {\n Globals.lockingTimeout = ms;\n }",
"@Override\n public void setAtomicNumber(int atomicNumber) {\n }",
"public final synchronized void setOpLock(OpLockDetails oplock)\n\t\tthrows ExistingOpLockException {\n\n\t\tif ( m_oplock == null)\n\t\t\tm_oplock = oplock;\n\t\telse\n\t\t\tthrow new ExistingOpLockException();\n\t}",
"public final native void setOrdnum(int ordnum) /*-{\n\t\tthis.ordnum = ordnum;\n\t}-*/;",
"public void setOtherinfo(String otherinfo) {\n this.otherinfo = otherinfo;\n }",
"public void setLockFlag(Integer aLockFlag) {\n lockFlag = aLockFlag;\n }",
"public void setLockFlag(Integer aLockFlag) {\n lockFlag = aLockFlag;\n }",
"public void setLockFlag(Integer aLockFlag) {\n lockFlag = aLockFlag;\n }",
"public void setTestNo(Long testNo) {\n this.testNo = testNo;\n }",
"public void setInstrumentedWorkExecutorID(java.lang.Long value) {\n __getInternalInterface().setFieldValue(INSTRUMENTEDWORKEXECUTORID_PROP.get(), value);\n }",
"public void setCreditNum(Long creditNum) {\n this.creditNum = creditNum;\n }",
"@Override\n public void setLockOwner(Object lockOwner) {\n }",
"public void setInstrumentedWorkExecutorID(java.lang.Long value) {\n __getInternalInterface().setFieldValue(INSTRUMENTEDWORKEXECUTORID_PROP.get(), value);\n }",
"public synchronized void setOpLock(OpLockDetails oplock)\n\t\tthrows ExistingOpLockException {\n\n\t\tsuper.setOpLock( oplock);\n\n\t\t// Set the state cache for the remote oplock\n\t\t\n\t\tif ( oplock instanceof RemoteOpLockDetails) {\n\t\t\tRemoteOpLockDetails remoteOplock = (RemoteOpLockDetails) getOpLock();\n\t\t\tremoteOplock.setStateCache( getStateCache());\n\t\t}\n\t}",
"public void setOther( Node other ) {\n Change change;\n if ( other.isConnector() && getFlow().hasConnector() ) {\n Connector connector = (Connector) other;\n Flow need = isSend() ? connector.getInnerFlow() : getFlow();\n Flow capability = isSend() ? getFlow() : connector.getInnerFlow();\n change = doCommand( new SatisfyNeed( getUser().getUsername(), need,\n capability,\n SatisfyNeed.KEEP_CAPABILITY,\n SatisfyNeed.KEEP_NEED ) );\n } else {\n change = doCommand( new RedirectFlow( getUser().getUsername(), getFlow(), other, isSend() ) );\n }\n Flow newFlow = (Flow) change.getSubject( getQueryService() );\n if ( newFlow != null ) { // TODO Find out why this has happened...\n // requestLockOn( newFlow );\n setFlow( newFlow );\n }\n }",
"public void setLstCustManagerId(BigDecimal lstCustManagerId) {\n this.lstCustManagerId = lstCustManagerId;\n }",
"public void setWork2(Number work2)\r\n {\r\n m_work2 = work2;\r\n }",
"@Override\n public boolean equals(Object that) {\n if (this == that) {\n return true;\n }\n if (that == null) {\n return false;\n }\n if (getClass() != that.getClass()) {\n return false;\n }\n TFCUseLockDetail other = (TFCUseLockDetail) that;\n return (this.getRowId() == null ? other.getRowId() == null : this.getRowId().equals(other.getRowId()))\n && (this.getCoinTypeId() == null ? other.getCoinTypeId() == null : this.getCoinTypeId().equals(other.getCoinTypeId()))\n && (this.getRecTime() == null ? other.getRecTime() == null : this.getRecTime().equals(other.getRecTime()))\n && (this.getActiontype() == null ? other.getActiontype() == null : this.getActiontype().equals(other.getActiontype()))\n && (this.getLockId() == null ? other.getLockId() == null : this.getLockId().equals(other.getLockId()))\n && (this.getUserId() == null ? other.getUserId() == null : this.getUserId().equals(other.getUserId()))\n && (this.getServerIp() == null ? other.getServerIp() == null : this.getServerIp().equals(other.getServerIp()))\n && (this.getGameId() == null ? other.getGameId() == null : this.getGameId().equals(other.getGameId()))\n && (this.getServerName() == null ? other.getServerName() == null : this.getServerName().equals(other.getServerName()))\n && (this.getLockNum() == null ? other.getLockNum() == null : this.getLockNum().equals(other.getLockNum()))\n && (this.getChangeNum() == null ? other.getChangeNum() == null : this.getChangeNum().equals(other.getChangeNum()))\n && (this.getRemainNum() == null ? other.getRemainNum() == null : this.getRemainNum().equals(other.getRemainNum()))\n && (this.getOtherLockNum() == null ? other.getOtherLockNum() == null : this.getOtherLockNum().equals(other.getOtherLockNum()));\n }",
"public void setBillNo(Long billNo) {\n this.billNo = billNo;\n }",
"public void setLock_latency(Long lock_latency) {\n this.lock_latency = lock_latency;\n }",
"public void setLong(String parName, long parVal) throws HibException;",
"public void setLockoutManager(@Nullable final AccountLockoutManager manager) {\n checkSetterPreconditions();\n lockoutManager = manager;\n }",
"public void setReceiveNum(Long receiveNum) {\r\n this.receiveNum = receiveNum;\r\n }",
"public void setApsOthers( Long apsOthers ) {\n this.apsOthers = apsOthers;\n }",
"public void setTransNo (java.lang.Long transNo) {\r\n\t\tthis.transNo = transNo;\r\n\t\tthis.hashCode = Integer.MIN_VALUE;\r\n\t}",
"public void setBillDtlNo(Long billDtlNo) {\n this.billDtlNo = billDtlNo;\n }",
"public void setTransactionID(long value) {\r\n this.transactionID = value;\r\n }",
"void setLong(int index, long value) throws SQLException;",
"public void setAmount(long value) {\r\n this.amount = value;\r\n }",
"public void setSale_num(Integer sale_num) {\n this.sale_num = sale_num;\n }",
"public void setLockStatus(long lockStatus) {\r\n this.lockStatus = lockStatus;\r\n }",
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"public void setAmount(Long amount) {\n this.amount = amount;\n }",
"public void setAmount(Long amount) {\n this.amount = amount;\n }",
"public void setAmount(Long amount) {\n this.amount = amount;\n }",
"public void setAmount(Long amount) {\n this.amount = amount;\n }",
"public void setPeti_numero(java.lang.Long newPeti_numero);",
"public void setPeti_numero(java.lang.Long newPeti_numero);",
"public void setMyOtherInt(int myOtherIntIn) {\n myOtherInt = myOtherIntIn;\n }",
"public void setHOUSE_NUM2(java.lang.String value)\n {\n if ((__HOUSE_NUM2 == null) != (value == null) || (value != null && ! value.equals(__HOUSE_NUM2)))\n {\n _isDirty = true;\n }\n __HOUSE_NUM2 = value;\n }",
"public void setNumToProcess(long aNumToProcess) {\n numToProcess = aNumToProcess;\n }",
"public final void setOrderNumber(com.mendix.systemwideinterfaces.core.IContext context, Long ordernumber)\r\n\t{\r\n\t\tgetMendixObject().setValue(context, MemberNames.OrderNumber.toString(), ordernumber);\r\n\t}",
"public void setOrderNumber(int value) {\n this.orderNumber = value;\n }",
"public void setChangeNum(Long changeNum) {\n this.changeNum = changeNum;\n }",
"public void setAccountNo(int number){\n\t\taccountNo = number;\n\t}",
"public void seti_ordertrx_temp_ID (int i_ordertrx_temp_ID);",
"void set_num(ThreadContext tc, RakudoObject classHandle, double Value);",
"public void setDefaultLocked(boolean systemLocked)\n\t{\n\t\tthis.defaultLocked = systemLocked;\n\t}",
"public void setOther2(String other2) {\n this.other2 = other2 == null ? null : other2.trim();\n }",
"public void setReservationroomid(Long newVal) {\n if ((newVal != null && this.reservationroomid != null && (newVal.compareTo(this.reservationroomid) == 0)) || \n (newVal == null && this.reservationroomid == null && reservationroomid_is_initialized)) {\n return; \n } \n this.reservationroomid = newVal; \n reservationroomid_is_modified = true; \n reservationroomid_is_initialized = true; \n }",
"public static long m33346a(AtomicLong atomicLong, long j) {\n long j2;\n do {\n j2 = atomicLong.get();\n if (j2 == Long.MAX_VALUE) {\n return Long.MAX_VALUE;\n }\n } while (!atomicLong.compareAndSet(j2, m33345a(j2, j)));\n return j2;\n }",
"public void setTransactionid(long value) {\n this.transactionid = value;\n }",
"public int getOtherId() {\n return instance.getOtherId();\n }",
"public Integer getgOtherId() {\n return gOtherId;\n }",
"public Builder setOtherId(int value) {\n copyOnWrite();\n instance.setOtherId(value);\n return this;\n }",
"public void setMyLong(long myLongIn) {\n myLong = myLongIn;\n }",
"public void setPassengerNumber(long passengerNumber) {\n\t\t_tempNoTiceShipMessage.setPassengerNumber(passengerNumber);\n\t}",
"public void setMgrOwnFlag(String mgrOwnFlag) {\r\n this.mgrOwnFlag = mgrOwnFlag == null ? null : mgrOwnFlag.trim();\r\n }",
"public void setZEXT_NUM2(java.lang.String value)\n {\n if ((__ZEXT_NUM2 == null) != (value == null) || (value != null && ! value.equals(__ZEXT_NUM2)))\n {\n _isDirty = true;\n }\n __ZEXT_NUM2 = value;\n }",
"public void setAmount(long amount);",
"public void setAdminOther(String adminOther) {\n this.adminOther = adminOther == null ? null : adminOther.trim();\n }",
"@Override\n public int getTxTimeoutInMillis() {\n return Globals.lockingTimeout;\n }",
"@Override public void checkpointReadLockTimeout(long val) {\n checkpointReadLockTimeout = val;\n }",
"@Override\n\tprotected void unLockNbr() {\n\t\t\n\t}",
"public void setAmount (java.lang.Long amount) {\r\n\t\tthis.amount = amount;\r\n\t}",
"public void setSettlementmoney(Long settlementmoney) {\n this.settlementmoney = settlementmoney;\n }",
"public void setTicketNo (java.lang.String ticketNo) {\r\n\t\tthis.ticketNo = ticketNo;\r\n\t}",
"public void setOrdernum(String ordernum) {\n this.ordernum = ordernum == null ? null : ordernum.trim();\n }",
"@Override\r\n\tpublic void addLockToken(String lt) {\n\t\t\r\n\t}",
"void setNumber(int num) {\r\n\t\tnumber = num;\r\n\t}",
"public void setSpecialHandlingAmount(MMDecimal specialHandlingAmount) {\r\n this.specialHandlingAmount = specialHandlingAmount;\r\n }",
"@Override\n\tpublic void updateJoinUserRefuse(int joinNumber) {\n\t\tuserInfoDAO.updateJoinUserRefuse(joinNumber);\n\t}",
"public void setOtherStatus(java.lang.String newOtherStatus) {\n\totherStatus = newOtherStatus;\n}",
"public void setLockUser(String lockUser) {\n this.lockUser = lockUser == null ? null : lockUser.trim();\n }",
"void lock(Connection con, EnterpriseObject eo, String revisionNumber,\n boolean lock) throws DataModifiedException {\n try {\n if ((!lock) || (eo == null) || (con.getAutoCommit())) {\n return; // no locking, no revision update\n\n }\n SBR sbr = eo.getSBR();\n String euid = eo.getEUID();\n if (revisionNumber != null) {\n lockSBR(con, euid, revisionNumber);\n } else {\n Integer curRevisionNumber = sbr.getRevisionNumber();\n lockSBR(con, euid, curRevisionNumber);\n }\n sbr.setRevisionNumber(sbr.getRevisionNumber().intValue() + 1);\n } catch (ObjectException ex) {\n throw new DataModifiedException(mLocalizer.t(\"OPS525: Could not lock \" +\n \"EnterpriseObject: {0}\", ex));\n } catch (SQLException se) {\n throw new DataModifiedException(mLocalizer.t(\"OPS526: Could not lock \" +\n \"EnterpriseObject: {0}\", se));\n }\n }",
"public Long getOrderNo () {\r\n\t\treturn orderNo;\r\n\t}",
"public abstract void setCod_actividad(java.lang.Long newCod_actividad);",
"public void set_long(long param) {\n this.local_long = param;\n }",
"public void setNUM_DB(int NUM_DB) \r\n {\r\n if(NUM_DB > 0)\r\n this.NUM_DB = NUM_DB;\r\n }",
"void lock(Connection con, EnterpriseObject eo1, EnterpriseObject eo2,\n String srcRevisionNumber, String destRevisionNumber)\n throws DataModifiedException {\n try {\n if ((eo1 == null && eo2 == null) || (con.getAutoCommit())) {\n return;\n } else if (eo1 == null) {\n lock(con, eo2, srcRevisionNumber, true);\n return;\n } else if (eo2 == null) {\n lock(con, eo1, destRevisionNumber, true);\n return;\n }\n SBR sbr1 = eo1.getSBR();\n String euid1 = eo1.getEUID();\n SBR sbr2 = eo2.getSBR();\n String euid2 = eo2.getEUID();\n\n if (srcRevisionNumber != null && destRevisionNumber != null) {\n lockSBR(con, euid1, destRevisionNumber, euid2,\n srcRevisionNumber);\n sbr1.setRevisionNumber(Integer.parseInt(destRevisionNumber) + 1);\n sbr2.setRevisionNumber(Integer.parseInt(srcRevisionNumber) + 1);\n } else {\n Integer revisionNumber1 = sbr1.getRevisionNumber();\n sbr2 = eo2.getSBR();\n euid2 = eo2.getEUID();\n Integer revisionNumber2 = sbr2.getRevisionNumber();\n lockSBR(con, euid1, revisionNumber1, euid2, revisionNumber2);\n sbr1.setRevisionNumber(sbr1.getRevisionNumber().intValue() + 1);\n sbr2.setRevisionNumber(sbr2.getRevisionNumber().intValue() + 1);\n }\n } catch (ObjectException ex) {\n throw new DataModifiedException(mLocalizer.t(\"OPS527: Could not lock \" +\n \"one or more EnterpriseObjects: {0}\", ex));\n } catch (SQLException se) {\n throw new DataModifiedException(mLocalizer.t(\"OPS528: Could not lock \" +\n \"one or more EnterpriseObjects: {0}\", se));\n }\n }",
"private void clearOtherId() {\n \n otherId_ = 0;\n }"
]
| [
"0.67239463",
"0.60641944",
"0.5641735",
"0.5625648",
"0.5338621",
"0.52553684",
"0.51670456",
"0.5108475",
"0.50557554",
"0.5045666",
"0.49501523",
"0.49490616",
"0.49446896",
"0.49213964",
"0.49127313",
"0.48350212",
"0.48088726",
"0.47932288",
"0.47480384",
"0.47231382",
"0.4710014",
"0.47076035",
"0.4692911",
"0.46798077",
"0.46743292",
"0.46743292",
"0.46743292",
"0.4667586",
"0.46553668",
"0.46460035",
"0.46385577",
"0.46360517",
"0.46180272",
"0.46140558",
"0.46015167",
"0.4601302",
"0.46011665",
"0.45956254",
"0.459181",
"0.45796156",
"0.45775422",
"0.45653614",
"0.45533645",
"0.4538256",
"0.4536017",
"0.45313817",
"0.45255047",
"0.45091552",
"0.45008814",
"0.44990438",
"0.4475645",
"0.44723007",
"0.44723007",
"0.44723007",
"0.44723007",
"0.44674733",
"0.44674733",
"0.44666016",
"0.4452965",
"0.44518298",
"0.44479075",
"0.44473472",
"0.44454893",
"0.44402674",
"0.44346437",
"0.4415653",
"0.44130012",
"0.4410249",
"0.44032314",
"0.44015375",
"0.43902946",
"0.4384094",
"0.43771696",
"0.43726563",
"0.43651953",
"0.43585536",
"0.43563074",
"0.435438",
"0.4344621",
"0.4343028",
"0.43406585",
"0.43343762",
"0.43328327",
"0.43306094",
"0.4329936",
"0.43283808",
"0.43229067",
"0.43195802",
"0.43164247",
"0.43162084",
"0.43060383",
"0.4297747",
"0.42974198",
"0.4296085",
"0.42900035",
"0.4282359",
"0.4281253",
"0.42774007",
"0.42725927",
"0.42719465"
]
| 0.7824385 | 0 |
This method was generated by MyBatis Generator. This method corresponds to the database table TFC_USE_LOCK_DETAIL | @Override
public boolean equals(Object that) {
if (this == that) {
return true;
}
if (that == null) {
return false;
}
if (getClass() != that.getClass()) {
return false;
}
TFCUseLockDetail other = (TFCUseLockDetail) that;
return (this.getRowId() == null ? other.getRowId() == null : this.getRowId().equals(other.getRowId()))
&& (this.getCoinTypeId() == null ? other.getCoinTypeId() == null : this.getCoinTypeId().equals(other.getCoinTypeId()))
&& (this.getRecTime() == null ? other.getRecTime() == null : this.getRecTime().equals(other.getRecTime()))
&& (this.getActiontype() == null ? other.getActiontype() == null : this.getActiontype().equals(other.getActiontype()))
&& (this.getLockId() == null ? other.getLockId() == null : this.getLockId().equals(other.getLockId()))
&& (this.getUserId() == null ? other.getUserId() == null : this.getUserId().equals(other.getUserId()))
&& (this.getServerIp() == null ? other.getServerIp() == null : this.getServerIp().equals(other.getServerIp()))
&& (this.getGameId() == null ? other.getGameId() == null : this.getGameId().equals(other.getGameId()))
&& (this.getServerName() == null ? other.getServerName() == null : this.getServerName().equals(other.getServerName()))
&& (this.getLockNum() == null ? other.getLockNum() == null : this.getLockNum().equals(other.getLockNum()))
&& (this.getChangeNum() == null ? other.getChangeNum() == null : this.getChangeNum().equals(other.getChangeNum()))
&& (this.getRemainNum() == null ? other.getRemainNum() == null : this.getRemainNum().equals(other.getRemainNum()))
&& (this.getOtherLockNum() == null ? other.getOtherLockNum() == null : this.getOtherLockNum().equals(other.getOtherLockNum()));
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"private String getSingleLockSBRStmt() {\n\n if (null == mSingleLockStmt) {\n initClauses();\n mSingleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE s.EUID = ? AND s.REVISIONNUMBER = ? \" + mForUpdateClause;\n }\n\n return mSingleLockStmt;\n }",
"public LocksRecord() {\n\t\tsuper(org.jooq.example.gradle.db.information_schema.tables.Locks.LOCKS);\n\t}",
"@DefaultMessage(\"Locking record for Update...\")\n @Key(\"gen.lockForUpdate\")\n String gen_lockForUpdate();",
"public void viewListofLocks() {\n\t\ttry {\n\t\t\t\n\t\t}catch(Exception e) {\n\t\t\tLog.addMessage(\"Failed to get list of locks\");\n\t\t\tSystem.out.println(e.getMessage().toString());\n\t\t\tAssert.assertTrue(false, \"Failed to get list of locks\");\n\t\t}\n\t}",
"public RuntimeExceptionDao<Lock, Integer> getLockDataDao() {\n\t\tif (lockRuntimeDao == null) {\n\t\t\tlockRuntimeDao = getRuntimeExceptionDao(Lock.class);\n\t\t}\n\t\treturn lockRuntimeDao;\n\t}",
"public Dao<Lock, Integer> getLockDao() throws SQLException {\n\t\tif (lockDao == null) {\n\t\t\tlockDao = getDao(Lock.class);\n\t\t}\n\t\treturn lockDao;\n\t}",
"public Long getLockNum() {\n return lockNum;\n }",
"private String getDoubleLockSBRStmt() {\n\n if (null == mDoubleLockStmt) {\n initClauses();\n mDoubleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE ( s.EUID = ? AND s.REVISIONNUMBER = ?) OR ( s.EUID = ? AND s.REVISIONNUMBER = ?)\" + mForUpdateClause;\n }\n\n return mDoubleLockStmt;\n }",
"public String getLockType() {\n return this.lockType;\n }",
"long getLockOwnersID(String uuid) throws DatabaseException;",
"public void dataBaseLocked();",
"public String getLockId() {\n return lockId;\n }",
"public Lock getLock();",
"public String appendLockHint(LockOptions lockOptions, String tableName){\n \t\treturn tableName;\n \t}",
"static int OPL_LockTable() {\n num_lock++;\n if (num_lock > 1) {\n return 0;\n }\n /* first time */\n cur_chip = null;\n /* allocate total level table (128kb space) */\n if (OPLOpenTable() == 0) {\n num_lock--;\n return -1;\n }\n return 0;\n }",
"ManagementLockObjectInner innerModel();",
"protected String applyLocks(String sql, LockOptions lockOptions, Dialect dialect) throws HibernateException {\n \t\treturn sql;\n \t}",
"public Object getLock() {\n return dataLock;\n }",
"final public Lock test_get_lock() {\r\n\t\treturn lock_;\r\n\t}",
"protected String applyLocks(String sql, LockOptions lockOptions, Dialect dialect) throws QueryException {\n \n \t\tif ( lockOptions == null ||\n \t\t\t( lockOptions.getLockMode() == LockMode.NONE && lockOptions.getAliasLockCount() == 0 ) ) {\n \t\t\treturn sql;\n \t\t}\n \n \t\t// we need both the set of locks and the columns to reference in locks\n \t\t// as the ultimate output of this section...\n \t\tfinal LockOptions locks = new LockOptions( lockOptions.getLockMode() );\n \t\tfinal Map keyColumnNames = dialect.forUpdateOfColumns() ? new HashMap() : null;\n \n \t\tlocks.setScope( lockOptions.getScope() );\n \t\tlocks.setTimeOut( lockOptions.getTimeOut() );\n \n \t\tfinal Iterator itr = sqlAliasByEntityAlias.entrySet().iterator();\n \t\twhile ( itr.hasNext() ) {\n \t\t\tfinal Map.Entry entry = (Map.Entry) itr.next();\n \t\t\tfinal String userAlias = (String) entry.getKey();\n \t\t\tfinal String drivingSqlAlias = (String) entry.getValue();\n \t\t\tif ( drivingSqlAlias == null ) {\n \t\t\t\tthrow new IllegalArgumentException( \"could not locate alias to apply lock mode : \" + userAlias );\n \t\t\t}\n \t\t\t// at this point we have (drivingSqlAlias) the SQL alias of the driving table\n \t\t\t// corresponding to the given user alias. However, the driving table is not\n \t\t\t// (necessarily) the table against which we want to apply locks. Mainly,\n \t\t\t// the exception case here is joined-subclass hierarchies where we instead\n \t\t\t// want to apply the lock against the root table (for all other strategies,\n \t\t\t// it just happens that driving and root are the same).\n \t\t\tfinal QueryNode select = ( QueryNode ) queryTranslator.getSqlAST();\n \t\t\tfinal Lockable drivingPersister = ( Lockable ) select.getFromClause()\n \t\t\t\t\t.findFromElementByUserOrSqlAlias( userAlias, drivingSqlAlias )\n \t\t\t\t\t.getQueryable();\n \t\t\tfinal String sqlAlias = drivingPersister.getRootTableAlias( drivingSqlAlias );\n \n \t\t\tfinal LockMode effectiveLockMode = lockOptions.getEffectiveLockMode( userAlias );\n \t\t\tlocks.setAliasSpecificLockMode( sqlAlias, effectiveLockMode );\n \n \t\t\tif ( keyColumnNames != null ) {\n \t\t\t\tkeyColumnNames.put( sqlAlias, drivingPersister.getRootTableIdentifierColumnNames() );\n \t\t\t}\n \t\t}\n \n \t\t// apply the collected locks and columns\n \t\treturn dialect.applyLocksToSql( sql, locks, keyColumnNames );\n \t}",
"protected String getLockManagerName() {\n return getName();\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsInJhd0tleVZhbHVlcyI6WyIxIiwiMSJdLCJyYXdLZXlUeXBlTmFtZXMiOlsiamF2YS5sYW5nLkludGVnZXIiLCJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tMasterBEnt masterBEnt = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\t\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\t\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29tcCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAiLCJyYXdLZXlWYWx1ZXMiOlsiMSIsIjEiXSwicmF3S2V5VHlwZU5hbWVzIjpbImphdmEubGFuZy5JbnRlZ2VyIiwiamF2YS5sYW5nLkludGVnZXIiXX0\");\r\n\t\t\t\tMasterBComp masterBComp = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAuZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIiwiMSJdLCJyYXdLZXlUeXBlTmFtZXMiOlsiamF2YS5sYW5nLkludGVnZXIiLCJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> compDetailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29tcCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAubWFzdGVyQkNvbXBDb21wIiwicmF3S2V5VmFsdWVzIjpbIjEiLCIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciIsImphdmEubGFuZy5JbnRlZ2VyIl19\");\r\n\t\t\t\tMasterBCompComp masterBCompComp = PlayerManagerTest.this.manager.getBySignature(signatureBean);\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAubWFzdGVyQkNvbXBDb21wLmRldGFpbEFFbnRDb2wiLCJyYXdLZXlWYWx1ZXMiOlsiMSIsIjEiXSwicmF3S2V5VHlwZU5hbWVzIjpbImphdmEubGFuZy5JbnRlZ2VyIiwiamF2YS5sYW5nLkludGVnZXIiXX0\");\r\n\t\t\t\tCollection<DetailAEnt> compCompDetailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\tAssert.assertThat(\"masterBEnt.getMasterBComp(), sameInstance(masterBComp)\", masterBEnt.getMasterBComp(), sameInstance(masterBComp));\r\n\t\t\t\tAssert.assertThat(\"masterBEnt.getMasterBComp().getMasterBCompComp(), sameInstance(masterBCompComp)\", masterBEnt.getMasterBComp().getMasterBCompComp(), sameInstance(masterBCompComp));\r\n\t\t\t\t\r\n\t\t\t\tAssert.assertThat(\"masterBComp.getMasterBCompComp(), sameInstance(masterBCompComp)\", masterBComp.getMasterBCompComp(), sameInstance(masterBCompComp));\r\n\t\t\t\tAssert.assertThat(\"detailAEntCol, not(sameInstance(compDetailAEntCol))\", detailAEntCol, not(sameInstance(compDetailAEntCol)));\r\n\t\t\t\tAssert.assertThat(\"detailAEntCol, not(sameInstance(compCompDetailAEntCol))\", detailAEntCol, not(sameInstance(compCompDetailAEntCol)));\r\n\t\t\t\tAssert.assertThat(\"compDetailAEntCol, not(sameInstance(compCompDetailAEntCol))\", compDetailAEntCol, not(sameInstance(compCompDetailAEntCol)));\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"protected RowLock getUpdateLockType() \n {\n\t\treturn(RowLock.RU3);\n }",
"@Override\n public int getTxTimeoutInMillis() {\n return Globals.lockingTimeout;\n }",
"@Override\n\tpublic List<LockRecordVo> getLockRecord(String sn) {\n\t\tLockServerApi.Iface lockServerApi =(LockServerApi.Iface) thriftClientProxy.getClient(LockServerApi.class);\n\t\tString message = null;\n\t\ttry{\n\t\t\t message = lockServerApi.getLockRecord(sn);\n\t\t}catch(Exception e){\n\t\t\te.printStackTrace();\n\t\t}\n\t\tif(message == null){\n\t\t\tthrow new RuntimeException(\"访问请求异常\");\n\t\t}\n\t\t JSONObject json = JSONObject.parseObject(message);\n\t\tif(json.getIntValue(\"code\") !=200){\n \t\tthrow new RuntimeException(\"查询锁失败\");\n \t}\n\t\tlog.info(message);\n\t\t/**\n\t\t * 取得历史记录\n\t\t * */\n\t\tList<LockRecord> lockRecordList = JSONObject.parseArray(json.getString(\"data\"), LockRecord.class);\n\t\tList<LockRecordVo> lockRecordVoList = new LinkedList<LockRecordVo>();\n\t\tif(lockRecordList !=null){\n\t\t\tlockRecordList.forEach(lockRecord -> {\n\t\t\t\tlockRecordVoList.add(new LockRecordVo(lockRecord.getSlaveId(),lockRecord.getOpenState(),lockRecord.getDealDate(),lockRecord.getVoltage(),lockRecord.getUserName()));\n\t\t\t});\n\t\t}\n\t\t\n\t\treturn lockRecordVoList;\n\t}",
"public interface LockDAO\n{\n /**\n * Aquire a given exclusive lock, assigning it (and any implicitly shared locks) a\n * timeout. All shared locks are implicitly taken as well.\n * <p>\n * A lock can be re-taken if it has expired and if the lock token has not changed\n * \n * @param lockQName the unique name of the lock to acquire\n * @param lockToken the potential lock token (max 36 chars)\n * @param timeToLive the time (in milliseconds) that the lock must remain \n * @return Returns <tt>true</tt> if the lock was taken, \n * otherwise <tt>false</tt>\n * @throws LockAcquisitionException on failure\n */\n void getLock(QName lockQName, String lockToken, long timeToLive);\n\n /**\n * Refresh a held lock. This is successful if the lock in question still exists\n * and if the lock token has not changed. Lock expiry does not prevent the lock\n * from being refreshed.\n * \n * @param lockQName the unique name of the lock to update\n * @param lockToken the lock token for the lock held\n * @param timeToLive the new time to live (in milliseconds)\n * @return Returns <tt>true</tt> if the lock was updated,\n * otherwise <tt>false</tt>\n * @throws LockAcquisitionException on failure\n */\n void refreshLock(QName lockQName, String lockToken, long timeToLive);\n \n /**\n * Release a lock. The lock token must still apply and all the shared and exclusive\n * locks need to still be present. Lock expiration does not prevent this operation\n * from succeeding.\n * <p>\n * Note: Failure to release a lock due to a exception condition is dealt with by\n * passing the exception out.\n * \n * @param lockQName the unique name of the lock to release\n * @param lockToken the current lock token\n * @return Returns <tt>true</tt> if all the required locks were\n * (still) held under the lock token and were\n * valid at the time of release, otherwise <tt>false</tt>\n */\n void releaseLock(QName lockQName, String lockToken);\n}",
"@Override\n public void onCreate(SQLiteDatabase db) {\n Log.e(\"zhangcy\", \"-------->AppLockDBlite onCreate\");\n db.execSQL(\"create table if not exists \" + AppLockUntil.TNAME + \"(\" + AppLockUntil.TID\n + \" integer primary key autoincrement,\" + AppLockUntil.PKGNAME + \" text,\"\n + AppLockUntil.LOCK + \" interger);\");\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompComp> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getDetailAComp().getDetailACompComp());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(\r\n\t\t\t\t\t\t\tDetailAEnt.class, \r\n\t\t\t\t\t\t\tdetailAEnt.getDetailAComp().getDetailACompComp(),\r\n\t\t\t\t\t\t\td -> d.getDetailAComp().getDetailACompComp());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompComp>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompComp> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getDetailAComp().getDetailACompComp());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(detailAEnt, d -> d.getDetailAComp());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(detailAEnt.getDetailAComp(), dc -> dc.getDetailACompComp());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompComp>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@ManyToOne\n\t@JoinColumn(name=\"LockStatus\", nullable=false)\n\t@Fetch(FetchMode.SELECT)\n\t@NotFound(action=NotFoundAction.IGNORE)\n\tpublic AccessStatus getLockStatus() {\n\t\treturn this.lockStatus;\n\t}",
"String getLockOwner();",
"public long getLockStatus() {\r\n return lockStatus;\r\n }",
"public String isLockedFor() {\n return (lockId == null ? \"\" : lockId);\n }",
"final Object getLockObject() {\n return timeManager;\n }",
"void addRowsLock();",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompId> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getCompId());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(DetailAEnt.class, detailAEnt.getCompId(), d -> d.getCompId());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompId>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"public void setLockKey( Long lockKey ) {\n this.lockKey = lockKey;\n }",
"@Test\n\tpublic void testFuncionamentoUpdateVersionLockOtimista(){\n \n\t\tdoInTransaction( session -> {\n\t\t\tArtista roberto = session.get(Artista.class, 3L);\n\t\t\troberto.getDetalhes().setBiografia(\"Biografia alterada...\");\n\t\t\tsession.update(roberto);\n\t\t});\n\t\t \n\t}",
"@Version\r\n @Column(name=\"optlock\")\r\n public Integer getVersion()\r\n {\r\n return version;\r\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompId> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getCompId());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(detailAEnt, d -> d.getCompId());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompId>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"private void demonstrateLockExpiry(final StandardJanusGraph graph, final boolean useNativeLocking, final long waitMillis) throws TemporaryLockingException, InterruptedException {\n graph.addVertex(T.label, DATABASE_METADATA_LABEL).property(VERSION_PROPERTY, VERSION_ONE);\n if(useNativeLocking) {\n System.out.println(\"regular tx one \" + getTxFromGraph(graph).toString() + \" \" + System.currentTimeMillis());\n }\n graph.tx().commit();\n\n final GraphTraversalSource g = graph.traversal();\n g.V().hasLabel(DATABASE_METADATA_LABEL).has(VERSION_PROPERTY, VERSION_ONE).property(VERSION_PROPERTY, VERSION_TWO).next();\n if(useNativeLocking) {\n System.out.println(\"regular tx two \" + getTxFromGraph(graph).toString() + \" \" + System.currentTimeMillis());\n }\n g.tx().commit();\n\n Thread.sleep(waitMillis); //wait for the lock to expire\n g.V().hasLabel(DATABASE_METADATA_LABEL).has(VERSION_PROPERTY, VERSION_TWO).property(VERSION_PROPERTY, VERSION_THREE).next();\n if(useNativeLocking) {\n System.out.println(\"regular tx three \" + getTxFromGraph(graph).toString() + \" \" + System.currentTimeMillis());\n }\n g.tx().commit();\n //END code from first code listing\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\tMasterAEnt masterAEnt = (MasterAEnt) ss.get(MasterAEnt.class, 1);\r\n\t\t\t\t//doing lazy-load\r\n\t\t\t\tmasterAEnt.getDetailAEntCol().size();\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest.this\r\n\t\t\t\t\t.manager\r\n\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\tArrayList<DetailAEnt> detailAEntCuttedCol = new ArrayList<>();\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(1));\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(2));\r\n\t\t\t\tPlayerSnapshot<Collection<DetailAEnt>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailAEntCuttedCol);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\t\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Select({\n \"select\",\n \"JNLNO, TRANDATE, ACCOUNTDATE, CHECKTYPE, STATUS, DONETIME, FILENAME\",\n \"from B_UMB_CHECKING_LOG\",\n \"where JNLNO = #{jnlno,jdbcType=VARCHAR}\"\n })\n @Results({\n @Result(column=\"JNLNO\", property=\"jnlno\", jdbcType=JdbcType.VARCHAR, id=true),\n @Result(column=\"TRANDATE\", property=\"trandate\", jdbcType=JdbcType.VARCHAR),\n @Result(column=\"ACCOUNTDATE\", property=\"accountdate\", jdbcType=JdbcType.VARCHAR),\n @Result(column=\"CHECKTYPE\", property=\"checktype\", jdbcType=JdbcType.CHAR),\n @Result(column=\"STATUS\", property=\"status\", jdbcType=JdbcType.CHAR),\n @Result(column=\"DONETIME\", property=\"donetime\", jdbcType=JdbcType.VARCHAR),\n @Result(column=\"FILENAME\", property=\"filename\", jdbcType=JdbcType.VARCHAR)\n })\n BUMBCheckingLog selectByPrimaryKey(BUMBCheckingLogKey key);",
"public Long getOtherLockNum() {\n return otherLockNum;\n }",
"public Long getLock_latency() {\n return lock_latency;\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\tMasterAEnt masterAEnt = (MasterAEnt) ss.get(MasterAEnt.class, 1);\r\n\t\t\t\t//doing lazy-load\r\n\t\t\t\tmasterAEnt.getDetailAEntCol().size();\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest.this\r\n\t\t\t\t\t.manager\r\n\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\tArrayList<DetailAEnt> detailAEntCuttedCol = new ArrayList<>();\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(0));\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(1));\r\n\t\t\t\tPlayerSnapshot<Collection<DetailAEnt>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailAEntCuttedCol);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\t\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"ManagementLockObject.Update update();",
"public BookingLockDetails getBookingLockDetails(com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.bookinglockdetails.v1.BookingLockDetails res){\n\t\tBookingLockDetails bookingLockDetails = new BookingLockDetails();\n\t\t\n\t\tbookingLockDetails.setBookingNo( res.getBookingNo() );\n\t\tbookingLockDetails.setLockId( res.getLockId() );\n\t\tbookingLockDetails.setLockMessage( res.getLockMessage() );\n\t\tif( res.isAlreadyLocked() != null ){\n\t\t\tbookingLockDetails.setAlreadyLocked( res.isAlreadyLocked().booleanValue() );\n\t\t}\n\t\tif( res.isAdmin() != null ){\n\t\t\tbookingLockDetails.setAdmin( res.isAdmin().booleanValue() );\n\t\t}\n\t\t\n\t\treturn bookingLockDetails;\n\t}",
"Lock getLock(String lockName);",
"public SystemMetadataDaoMetacatImpl(DataSource dataSource) {\n jdbcTemplate = new JdbcTemplate(dataSource);\n txManager = new DataSourceTransactionManager(dataSource);\n txTemplate = new TransactionTemplate(txManager);\n txTemplate.setIsolationLevel(TransactionDefinition.ISOLATION_READ_COMMITTED);\n }",
"public int getLockAddress() {\n\t\treturn 0;\n\t}",
"String getStartTransactionSql();",
"Boolean isConsumeLockEntity();",
"@Override\n protected String applyLocks(String sql, LockOptions lockOptions, Dialect dialect) throws QueryException {\n \t\tfinal String result;\n \t\tif ( lockOptions == null ||\n \t\t\t( lockOptions.getLockMode() == LockMode.NONE && lockOptions.getAliasLockCount() == 0 ) ) {\n \t\t\treturn sql;\n \t\t}\n \t\telse {\n \t\t\tLockOptions locks = new LockOptions();\n \t\t\tlocks.setLockMode(lockOptions.getLockMode());\n \t\t\tlocks.setTimeOut(lockOptions.getTimeOut());\n \t\t\tlocks.setScope(lockOptions.getScope());\n \t\t\tIterator iter = lockOptions.getAliasLockIterator();\n \t\t\twhile ( iter.hasNext() ) {\n \t\t\t\tMap.Entry me = ( Map.Entry ) iter.next();\n \t\t\t\tlocks.setAliasSpecificLockMode( getAliasName( ( String ) me.getKey() ), (LockMode) me.getValue() );\n \t\t\t}\n \t\t\tMap keyColumnNames = null;\n \t\t\tif ( dialect.forUpdateOfColumns() ) {\n \t\t\t\tkeyColumnNames = new HashMap();\n \t\t\t\tfor ( int i = 0; i < names.length; i++ ) {\n \t\t\t\t\tkeyColumnNames.put( names[i], persisters[i].getIdentifierColumnNames() );\n \t\t\t\t}\n \t\t\t}\n \t\t\tresult = dialect.applyLocksToSql( sql, locks, keyColumnNames );\n \t\t}\n \t\tlogQuery( queryString, result );\n \t\treturn result;\n \t}",
"@Test(expected=OptimisticLockException.class)\n\tpublic void testColisaoLockOtimista(){\n\t\tArtista artista = doWithSession( session -> {\n\t\t\t\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\treturn roberto;\n\t\t});\n\t\t\n\t\t// Lido e escrito pelo User B\n\t\tdoInTransaction( session -> {\n\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\troberto.getDetalhes().setBiografia(\"Biografia alterada...\");\n\t\t\tsession.update(roberto);\n\t\t});\n\t\t\n\t\t// Escrito pelo User A // javax.persistence.OptimisticLockException: -> org.hibernate.StaleStateException:\n\t\tdoInTransaction( session -> {\n\t\t\tartista.getDetalhes().setBiografia(\"Conlisão!!!\");\n\t\t\tsession.update(artista);\n\t\t});\n\t}",
"@Test(timeout = 4000)\n public void test16() throws Throwable {\n Object object0 = new Object();\n Integer integer0 = RawTransaction.LOCK_ESCALATE;\n DBColumn[] dBColumnArray0 = new DBColumn[2];\n String string0 = SQLUtil.substituteMarkers(\"create materialized view\", \"create materialized view\", integer0);\n assertEquals(\"3\", string0);\n }",
"@Select({\n \"select\",\n \"code, statistic_code, periods, line_code, material_type, element_type, material_requisitions, \",\n \"current_goods_in_process, last_goods_in_process, product_storage, intermediate_products_variation, \",\n \"unit_consumption\",\n \"from cost_accounting_statistic_by_line_detail\",\n \"where code = #{code,jdbcType=BIGINT}\"\n })\n @ResultMap(\"BaseResultMap\")\n CostAccountingStatisticByLineDetail selectByPrimaryKey(Long code);",
"@Override\n\tpublic LockModeType getLockMode(Object entity) {\n\t\treturn null;\n\t}",
"@Override\r\n\tpublic void addLockToken(String lt) {\n\t\t\r\n\t}",
"public String getLockUser() {\n return lockUser;\n }",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"private void RecordStoreLockFactory() {\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<MasterAEnt> masterAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, MasterAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"id\")).list();\r\n\t\t\t\tList<MasterAWrapper> masterAWrapperList = new ArrayList<>();\r\n\t\t\t\tfor (MasterAEnt masterAEnt : masterAEntList) {\r\n\t\t\t\t\tMasterAWrapper masterAWrapper = new MasterAWrapper();\r\n\t\t\t\t\tmasterAWrapper.setMasterA(masterAEnt);\r\n\t\t\t\t\tmasterAWrapper.setDetailAWrapperList(new ArrayList<>());\r\n\t\t\t\t\tmasterAWrapper.setDetailAEntCol(new ArrayList<>(masterAEnt.getDetailAEntCol()));\r\n\t\t\t\t\tfor (DetailAEnt detailAEnt : masterAEnt.getDetailAEntCol()) {\r\n\t\t\t\t\t\tDetailAWrapper detailAWrapper = new DetailAWrapper();\r\n\t\t\t\t\t\tdetailAWrapper.setDetailA(detailAEnt);\r\n\t\t\t\t\t\tmasterAWrapper.getDetailAWrapperList().add(detailAWrapper);\r\n\t\t\t\t\t}\r\n\t\t\t\t\tmasterAWrapperList.add(masterAWrapper);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<MasterAWrapper>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(masterAWrapperList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<MasterBEnt> masterBEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, MasterBEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.idA\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.idB\")).list();\r\n\t\t\t\tList<Map<String, Map<String, MasterBEnt>>> masterBEntBizarreList = new ArrayList<>();\r\n\t\t\t\t\r\n\t\t\t\tfor (MasterBEnt masterB : masterBEntList) {\r\n\t\t\t\t\tSignatureBean signBean = ((IPlayerManagerImplementor) PlayerManagerTest.this.manager).generateSignature(masterB);\r\n\t\t\t\t\tString signStr = PlayerManagerTest.this.manager.serializeSignature(signBean);\r\n\t\t\t\t\tMap<String, Map<String, MasterBEnt>> mapItem = new LinkedHashMap<>();\r\n\t\t\t\t\tPlayerSnapshot<MasterBEnt> masterBPS = PlayerManagerTest.this.manager.createPlayerSnapshot(masterB);\r\n\t\t\t\t\tMap<String, MasterBEnt> mapMapItem = new LinkedHashMap<>();\r\n\t\t\t\t\tmapMapItem.put(\"wrappedSnapshot\", masterB);\r\n\t\t\t\t\tmapItem.put(signStr, mapMapItem);\r\n\t\t\t\t\tmasterBEntBizarreList.add(mapItem);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<Map<String, Map<String, MasterBEnt>>>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(masterBEntBizarreList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Pointcut(value = \"@annotation(lock)\", argNames = \"lock\")\n public void lockPointcut(Lock lock) {\n }",
"public Date getLockTime() {\n\t\treturn lockTime;\n\t}",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\tMasterAEnt masterAEnt = (MasterAEnt) ss.get(MasterAEnt.class, 1);\r\n\t\t\t\t//doing lazy-load\r\n\t\t\t\tmasterAEnt.getDetailAEntCol().size();\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest.this\r\n\t\t\t\t\t.manager\r\n\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\tPlayerSnapshot<Collection<DetailAEnt>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailAEntCol);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\t\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"public interface CounterRepository extends CrudRepository<Counter,Integer> {\n\n @Query(value = \"SELECT * FROM counter c WHERE c.id = ?1 for UPDATE\",\n nativeQuery = true)\n Counter findByIdWithLock(int id);\n\n\n}",
"public Lock getLock() {\n return lock;\n }",
"interface WithOwners {\n /**\n * Specifies the owners property: The owners of the lock..\n *\n * @param owners The owners of the lock.\n * @return the next definition stage.\n */\n Update withOwners(List<ManagementLockOwner> owners);\n }",
"@Insert({\n \"insert into SWMS_stock_out_record_detail (stock_out_record_id, stock_out_record_head_id, \",\n \"stock_out_record_head_code, group_name, \",\n \"stock_in_record_account_id, material_code, \",\n \"material_batch, material_type_id, \",\n \"material_sub_type_id, material_workshop_id, \",\n \"material_name_code, material_supplier_code, \",\n \"material_name, bag_num, \",\n \"weight, measure_unit, \",\n \"created_time, completion_flag)\",\n \"values (#{stockOutRecordId,jdbcType=BIGINT}, #{stockOutRecordHeadId,jdbcType=BIGINT}, \",\n \"#{stockOutRecordHeadCode,jdbcType=BIGINT}, #{groupName,jdbcType=VARCHAR}, \",\n \"#{stockInRecordAccountId,jdbcType=BIGINT}, #{materialCode,jdbcType=VARCHAR}, \",\n \"#{materialBatch,jdbcType=VARCHAR}, #{materialTypeId,jdbcType=INTEGER}, \",\n \"#{materialSubTypeId,jdbcType=INTEGER}, #{materialWorkshopId,jdbcType=INTEGER}, \",\n \"#{materialNameCode,jdbcType=INTEGER}, #{materialSupplierCode,jdbcType=INTEGER}, \",\n \"#{materialName,jdbcType=VARCHAR}, #{bagNum,jdbcType=INTEGER}, \",\n \"#{weight,jdbcType=REAL}, #{measureUnit,jdbcType=VARCHAR}, \",\n \"#{createdTime,jdbcType=TIMESTAMP}, #{completionFlag,jdbcType=BIT})\"\n })\n @SelectKey(statement=\"SELECT LAST_INSERT_ID()\", keyProperty=\"id\", before=false, resultType=Long.class)\n int insert(SwmsStockOutRecordDetail record);",
"ManagementLockObject refresh(Context context);",
"@Override\n\tpublic void lock(Object entity, LockModeType lockMode, Map<String, Object> properties) {\n\t\t\n\t}",
"protected boolean upgradeLocks() {\n \t\treturn false;\n \t}",
"public Collection<IgniteTxEntry> optimisticLockEntries();",
"public void setLockStatus(long lockStatus) {\r\n this.lockStatus = lockStatus;\r\n }",
"@Override\n\tpublic Lock getLock() {\n\t\treturn this.lock;\n\t}",
"public LockOnChange getLockOnChangeMode(){\r\n return this.lockOnChangeMode;\r\n }",
"@Override\n public void setLockOwner(Object lockOwner) {\n }",
"public interface ManagementLockObject {\n /**\n * Gets the id property: Fully qualified resource Id for the resource.\n *\n * @return the id value.\n */\n String id();\n\n /**\n * Gets the name property: The name of the resource.\n *\n * @return the name value.\n */\n String name();\n\n /**\n * Gets the type property: The type of the resource.\n *\n * @return the type value.\n */\n String type();\n\n /**\n * Gets the level property: The level of the lock. Possible values are: NotSpecified, CanNotDelete, ReadOnly.\n * CanNotDelete means authorized users are able to read and modify the resources, but not delete. ReadOnly means\n * authorized users can only read from a resource, but they can't modify or delete it.\n *\n * @return the level value.\n */\n LockLevel level();\n\n /**\n * Gets the notes property: Notes about the lock. Maximum of 512 characters.\n *\n * @return the notes value.\n */\n String notes();\n\n /**\n * Gets the owners property: The owners of the lock.\n *\n * @return the owners value.\n */\n List<ManagementLockOwner> owners();\n\n /**\n * Gets the inner com.azure.resourcemanager.locks.fluent.models.ManagementLockObjectInner object.\n *\n * @return the inner object.\n */\n ManagementLockObjectInner innerModel();\n\n /** The entirety of the ManagementLockObject definition. */\n interface Definition\n extends DefinitionStages.Blank,\n DefinitionStages.WithResourceGroup,\n DefinitionStages.WithLevel,\n DefinitionStages.WithCreate {\n }\n /** The ManagementLockObject definition stages. */\n interface DefinitionStages {\n /** The first stage of the ManagementLockObject definition. */\n interface Blank extends WithResourceGroup {\n }\n /** The stage of the ManagementLockObject definition allowing to specify parent resource. */\n interface WithResourceGroup {\n /**\n * Specifies resourceGroupName.\n *\n * @param resourceGroupName The name of the resource group to lock.\n * @return the next definition stage.\n */\n WithLevel withExistingResourceGroup(String resourceGroupName);\n }\n /** The stage of the ManagementLockObject definition allowing to specify level. */\n interface WithLevel {\n /**\n * Specifies the level property: The level of the lock. Possible values are: NotSpecified, CanNotDelete,\n * ReadOnly. CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it..\n *\n * @param level The level of the lock. Possible values are: NotSpecified, CanNotDelete, ReadOnly.\n * CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it.\n * @return the next definition stage.\n */\n WithCreate withLevel(LockLevel level);\n }\n /**\n * The stage of the ManagementLockObject definition which contains all the minimum required properties for the\n * resource to be created, but also allows for any other optional properties to be specified.\n */\n interface WithCreate extends DefinitionStages.WithNotes, DefinitionStages.WithOwners {\n /**\n * Executes the create request.\n *\n * @return the created resource.\n */\n ManagementLockObject create();\n\n /**\n * Executes the create request.\n *\n * @param context The context to associate with this operation.\n * @return the created resource.\n */\n ManagementLockObject create(Context context);\n }\n /** The stage of the ManagementLockObject definition allowing to specify notes. */\n interface WithNotes {\n /**\n * Specifies the notes property: Notes about the lock. Maximum of 512 characters..\n *\n * @param notes Notes about the lock. Maximum of 512 characters.\n * @return the next definition stage.\n */\n WithCreate withNotes(String notes);\n }\n /** The stage of the ManagementLockObject definition allowing to specify owners. */\n interface WithOwners {\n /**\n * Specifies the owners property: The owners of the lock..\n *\n * @param owners The owners of the lock.\n * @return the next definition stage.\n */\n WithCreate withOwners(List<ManagementLockOwner> owners);\n }\n }\n /**\n * Begins update for the ManagementLockObject resource.\n *\n * @return the stage of resource update.\n */\n ManagementLockObject.Update update();\n\n /** The template for ManagementLockObject update. */\n interface Update extends UpdateStages.WithLevel, UpdateStages.WithNotes, UpdateStages.WithOwners {\n /**\n * Executes the update request.\n *\n * @return the updated resource.\n */\n ManagementLockObject apply();\n\n /**\n * Executes the update request.\n *\n * @param context The context to associate with this operation.\n * @return the updated resource.\n */\n ManagementLockObject apply(Context context);\n }\n /** The ManagementLockObject update stages. */\n interface UpdateStages {\n /** The stage of the ManagementLockObject update allowing to specify level. */\n interface WithLevel {\n /**\n * Specifies the level property: The level of the lock. Possible values are: NotSpecified, CanNotDelete,\n * ReadOnly. CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it..\n *\n * @param level The level of the lock. Possible values are: NotSpecified, CanNotDelete, ReadOnly.\n * CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it.\n * @return the next definition stage.\n */\n Update withLevel(LockLevel level);\n }\n /** The stage of the ManagementLockObject update allowing to specify notes. */\n interface WithNotes {\n /**\n * Specifies the notes property: Notes about the lock. Maximum of 512 characters..\n *\n * @param notes Notes about the lock. Maximum of 512 characters.\n * @return the next definition stage.\n */\n Update withNotes(String notes);\n }\n /** The stage of the ManagementLockObject update allowing to specify owners. */\n interface WithOwners {\n /**\n * Specifies the owners property: The owners of the lock..\n *\n * @param owners The owners of the lock.\n * @return the next definition stage.\n */\n Update withOwners(List<ManagementLockOwner> owners);\n }\n }\n /**\n * Refreshes the resource to sync with Azure.\n *\n * @return the refreshed resource.\n */\n ManagementLockObject refresh();\n\n /**\n * Refreshes the resource to sync with Azure.\n *\n * @param context The context to associate with this operation.\n * @return the refreshed resource.\n */\n ManagementLockObject refresh(Context context);\n}",
"@Test\n public void testFailLock() {\n if (getConnection().isNis()) {\n // TODO Workaround on Solaris NIS: there doesn't seem to be a way\n // how to handle user locks on NIS.\n log.info(\"skipping test 'testLock', as LOCK attribute is not supported by the connector on NIS.\");\n return;\n }\n try {\n getFacade().update(ObjectClass.ACCOUNT, new Uid(getUsername()),\n CollectionUtil.newSet(AttributeBuilder.build(AccountAttribute.LOCK.getName())),\n null);\n AssertJUnit\n .fail(\"passing null option to Lock should cause failure. It must have a boolean value.\");\n } catch (Exception ex) {\n // OK\n }\n try {\n getFacade().create(\n ObjectClass.ACCOUNT,\n CollectionUtil.newSet(AttributeBuilder.build(Name.NAME, \"fooconn\"),\n AttributeBuilder.buildPassword(\"foo134\".toCharArray()),\n AttributeBuilder.build(AccountAttribute.LOCK.getName())), null);\n AssertJUnit\n .fail(\"passing null option to Lock should cause failure. It must have a boolean value.\");\n } catch (Exception ex) {\n // OK\n } finally {\n try {\n getFacade().delete(ObjectClass.ACCOUNT, new Uid(\"foo134\"), null);\n } catch (Exception ex) {\n // OK\n }\n }\n }",
"public DBMaker disableLocking(){\n this.lockingDisabled = true;\n return this;\n }",
"@Override\n\tpublic LockThreadInfo mapRow(ResultSet rs, int rowNum) throws SQLException {\n\t\tLockThreadInfo lockThreadInfo = new LockThreadInfo(rs.getString(\"tid\"), rs.getString(\"nid\"), rs.getString(\"state\"));\n\t\treturn lockThreadInfo;\n\t}",
"public void openLock(){\n /*Code to send an unlocking signal to the physical device Gate*/\n }",
"void getLock(QName lockQName, String lockToken, long timeToLive);",
"public final OpLockDetails getOpLock() {\n\t\treturn m_oplock;\n\t}",
"CamelJpaConsumerBindingModel setConsumeLockEntity(Boolean consumeLockEntity);",
"public int getLockon() {\r\n return lockon;\r\n }",
"Miss_control_log selectByPrimaryKey(String loginuuid);",
"public Expression getWriteLockUpdateExpression(ExpressionBuilder builder, AbstractSession session) {\r\n return ExpressionMath.add(builder.getField(writeLockField.getName()), 1);\r\n }",
"protected final Object getTreeLock() {\n return Component.LOCK;\n }",
"@Test(expected=OptimisticLockException.class)\n\tpublic void testColisaoCamposDiferentesLockOtimista(){\n\t\t// Detached Artista (Lido pelo User A)\n\t\tArtista artista = doWithSession( session -> {\n\t\t\t\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\treturn roberto;\n\t\t});\n\t\t\n\t\t// Lido e escrito pelo User B\n\t\tdoInTransaction( session -> {\n\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\troberto.getDetalhes().setBiografia(\"Biografia alterada...\");\n\t\t\tsession.update(roberto);\n\t\t});\n\t\t\n\t\t// Escrito pelo User A // javax.persistence.OptimisticLockException: -> org.hibernate.StaleStateException:\n\t\tdoInTransaction( session -> {\n\t\t\tartista.getDetalhes().setDataNascimento(new Date());\n\t\t\tsession.update(artista);\n\t\t});\n\t}",
"String[] getTimeToExpirationLock(String uuid) throws DatabaseException;",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"@Override\r\n\tpublic List<PayRollLock> findpayRollLock(String processMonth) {\n\t\t\r\n\t\treturn payRollLockRepository.findpayRollLock(processMonth);\r\n\t}",
"@Override\n public boolean tryLock(long timeout, TimeUnit unit) {\n Preconditions.checkState(connection != null);\n checkThread();\n Monitoring.increment(callCounter.name(), (KeyValuePair<String, String>[]) null);\n try {\n return lockLatency.record(() -> {\n long start = System.currentTimeMillis();\n long period = DateTimeUtils.period(timeout, unit);\n if (super.tryLock(timeout, unit)) {\n if (locked) return true;\n while (true) {\n if ((System.currentTimeMillis() - start) > period) break;\n Transaction tnx = session.beginTransaction();\n try {\n DbLockRecord record = checkExpiry(fetch(session, true, true));\n if (record.isLocked() && instanceId().compareTo(record.getInstanceId()) == 0) {\n session.save(record);\n tnx.commit();\n locked = true;\n lockedTime = System.currentTimeMillis();\n break;\n } else if (!record.isLocked()) {\n record.setLocked(true);\n record.setInstanceId(instanceId());\n record.setTimestamp(System.currentTimeMillis());\n session.update(record);\n tnx.commit();\n locked = true;\n lockedTime = System.currentTimeMillis();\n break;\n }\n tnx.rollback();\n } catch (Exception ex) {\n tnx.rollback();\n throw ex;\n }\n Thread.sleep(DEFAULT_SLEEP_INTERVAL);\n }\n }\n return locked;\n });\n } catch (Throwable t) {\n Monitoring.increment(errorCounter.name(), (KeyValuePair<String, String>[]) null);\n throw new LockException(t);\n }\n }"
]
| [
"0.5928134",
"0.5616077",
"0.54742384",
"0.54019105",
"0.5378169",
"0.52734303",
"0.52687484",
"0.52197796",
"0.52122426",
"0.51818174",
"0.5144744",
"0.51289",
"0.50960714",
"0.5094976",
"0.5019889",
"0.500352",
"0.5001865",
"0.49933517",
"0.4990437",
"0.49866778",
"0.49834853",
"0.49749285",
"0.49700233",
"0.49651745",
"0.49643496",
"0.49590057",
"0.49589488",
"0.49582094",
"0.4942917",
"0.49281234",
"0.49107912",
"0.48987284",
"0.4870289",
"0.4866687",
"0.48627532",
"0.48589087",
"0.48573694",
"0.48554522",
"0.48527935",
"0.48393682",
"0.48358318",
"0.4830519",
"0.483046",
"0.4829144",
"0.48238328",
"0.48227644",
"0.48223028",
"0.48182708",
"0.48028415",
"0.47959155",
"0.47876665",
"0.4775016",
"0.47722045",
"0.47651634",
"0.4752327",
"0.47494102",
"0.4747336",
"0.4744395",
"0.474367",
"0.47329235",
"0.47145095",
"0.471248",
"0.47064945",
"0.4702003",
"0.46958888",
"0.46834007",
"0.46787557",
"0.46739298",
"0.4673426",
"0.4670993",
"0.46664828",
"0.46606198",
"0.4655758",
"0.46511015",
"0.46385413",
"0.463647",
"0.4628614",
"0.46234635",
"0.46220225",
"0.46187574",
"0.46048912",
"0.4599883",
"0.45986673",
"0.4598242",
"0.4589727",
"0.45809197",
"0.45727283",
"0.4570461",
"0.4570014",
"0.45652744",
"0.45454302",
"0.45388773",
"0.4536584",
"0.45350513",
"0.45289353",
"0.4528372",
"0.4528372",
"0.4528372",
"0.45278513",
"0.45140734"
]
| 0.5114017 | 12 |
This method was generated by MyBatis Generator. This method corresponds to the database table TFC_USE_LOCK_DETAIL | @Override
public int hashCode() {
final int prime = 31;
int result = 1;
result = prime * result + ((getRowId() == null) ? 0 : getRowId().hashCode());
result = prime * result + ((getCoinTypeId() == null) ? 0 : getCoinTypeId().hashCode());
result = prime * result + ((getRecTime() == null) ? 0 : getRecTime().hashCode());
result = prime * result + ((getActiontype() == null) ? 0 : getActiontype().hashCode());
result = prime * result + ((getLockId() == null) ? 0 : getLockId().hashCode());
result = prime * result + ((getUserId() == null) ? 0 : getUserId().hashCode());
result = prime * result + ((getServerIp() == null) ? 0 : getServerIp().hashCode());
result = prime * result + ((getGameId() == null) ? 0 : getGameId().hashCode());
result = prime * result + ((getServerName() == null) ? 0 : getServerName().hashCode());
result = prime * result + ((getLockNum() == null) ? 0 : getLockNum().hashCode());
result = prime * result + ((getChangeNum() == null) ? 0 : getChangeNum().hashCode());
result = prime * result + ((getRemainNum() == null) ? 0 : getRemainNum().hashCode());
result = prime * result + ((getOtherLockNum() == null) ? 0 : getOtherLockNum().hashCode());
return result;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"private String getSingleLockSBRStmt() {\n\n if (null == mSingleLockStmt) {\n initClauses();\n mSingleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE s.EUID = ? AND s.REVISIONNUMBER = ? \" + mForUpdateClause;\n }\n\n return mSingleLockStmt;\n }",
"public LocksRecord() {\n\t\tsuper(org.jooq.example.gradle.db.information_schema.tables.Locks.LOCKS);\n\t}",
"@DefaultMessage(\"Locking record for Update...\")\n @Key(\"gen.lockForUpdate\")\n String gen_lockForUpdate();",
"public void viewListofLocks() {\n\t\ttry {\n\t\t\t\n\t\t}catch(Exception e) {\n\t\t\tLog.addMessage(\"Failed to get list of locks\");\n\t\t\tSystem.out.println(e.getMessage().toString());\n\t\t\tAssert.assertTrue(false, \"Failed to get list of locks\");\n\t\t}\n\t}",
"public RuntimeExceptionDao<Lock, Integer> getLockDataDao() {\n\t\tif (lockRuntimeDao == null) {\n\t\t\tlockRuntimeDao = getRuntimeExceptionDao(Lock.class);\n\t\t}\n\t\treturn lockRuntimeDao;\n\t}",
"public Dao<Lock, Integer> getLockDao() throws SQLException {\n\t\tif (lockDao == null) {\n\t\t\tlockDao = getDao(Lock.class);\n\t\t}\n\t\treturn lockDao;\n\t}",
"public Long getLockNum() {\n return lockNum;\n }",
"private String getDoubleLockSBRStmt() {\n\n if (null == mDoubleLockStmt) {\n initClauses();\n mDoubleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE ( s.EUID = ? AND s.REVISIONNUMBER = ?) OR ( s.EUID = ? AND s.REVISIONNUMBER = ?)\" + mForUpdateClause;\n }\n\n return mDoubleLockStmt;\n }",
"public String getLockType() {\n return this.lockType;\n }",
"long getLockOwnersID(String uuid) throws DatabaseException;",
"public void dataBaseLocked();",
"@Override\n public boolean equals(Object that) {\n if (this == that) {\n return true;\n }\n if (that == null) {\n return false;\n }\n if (getClass() != that.getClass()) {\n return false;\n }\n TFCUseLockDetail other = (TFCUseLockDetail) that;\n return (this.getRowId() == null ? other.getRowId() == null : this.getRowId().equals(other.getRowId()))\n && (this.getCoinTypeId() == null ? other.getCoinTypeId() == null : this.getCoinTypeId().equals(other.getCoinTypeId()))\n && (this.getRecTime() == null ? other.getRecTime() == null : this.getRecTime().equals(other.getRecTime()))\n && (this.getActiontype() == null ? other.getActiontype() == null : this.getActiontype().equals(other.getActiontype()))\n && (this.getLockId() == null ? other.getLockId() == null : this.getLockId().equals(other.getLockId()))\n && (this.getUserId() == null ? other.getUserId() == null : this.getUserId().equals(other.getUserId()))\n && (this.getServerIp() == null ? other.getServerIp() == null : this.getServerIp().equals(other.getServerIp()))\n && (this.getGameId() == null ? other.getGameId() == null : this.getGameId().equals(other.getGameId()))\n && (this.getServerName() == null ? other.getServerName() == null : this.getServerName().equals(other.getServerName()))\n && (this.getLockNum() == null ? other.getLockNum() == null : this.getLockNum().equals(other.getLockNum()))\n && (this.getChangeNum() == null ? other.getChangeNum() == null : this.getChangeNum().equals(other.getChangeNum()))\n && (this.getRemainNum() == null ? other.getRemainNum() == null : this.getRemainNum().equals(other.getRemainNum()))\n && (this.getOtherLockNum() == null ? other.getOtherLockNum() == null : this.getOtherLockNum().equals(other.getOtherLockNum()));\n }",
"public String getLockId() {\n return lockId;\n }",
"public Lock getLock();",
"public String appendLockHint(LockOptions lockOptions, String tableName){\n \t\treturn tableName;\n \t}",
"static int OPL_LockTable() {\n num_lock++;\n if (num_lock > 1) {\n return 0;\n }\n /* first time */\n cur_chip = null;\n /* allocate total level table (128kb space) */\n if (OPLOpenTable() == 0) {\n num_lock--;\n return -1;\n }\n return 0;\n }",
"ManagementLockObjectInner innerModel();",
"protected String applyLocks(String sql, LockOptions lockOptions, Dialect dialect) throws HibernateException {\n \t\treturn sql;\n \t}",
"public Object getLock() {\n return dataLock;\n }",
"protected String applyLocks(String sql, LockOptions lockOptions, Dialect dialect) throws QueryException {\n \n \t\tif ( lockOptions == null ||\n \t\t\t( lockOptions.getLockMode() == LockMode.NONE && lockOptions.getAliasLockCount() == 0 ) ) {\n \t\t\treturn sql;\n \t\t}\n \n \t\t// we need both the set of locks and the columns to reference in locks\n \t\t// as the ultimate output of this section...\n \t\tfinal LockOptions locks = new LockOptions( lockOptions.getLockMode() );\n \t\tfinal Map keyColumnNames = dialect.forUpdateOfColumns() ? new HashMap() : null;\n \n \t\tlocks.setScope( lockOptions.getScope() );\n \t\tlocks.setTimeOut( lockOptions.getTimeOut() );\n \n \t\tfinal Iterator itr = sqlAliasByEntityAlias.entrySet().iterator();\n \t\twhile ( itr.hasNext() ) {\n \t\t\tfinal Map.Entry entry = (Map.Entry) itr.next();\n \t\t\tfinal String userAlias = (String) entry.getKey();\n \t\t\tfinal String drivingSqlAlias = (String) entry.getValue();\n \t\t\tif ( drivingSqlAlias == null ) {\n \t\t\t\tthrow new IllegalArgumentException( \"could not locate alias to apply lock mode : \" + userAlias );\n \t\t\t}\n \t\t\t// at this point we have (drivingSqlAlias) the SQL alias of the driving table\n \t\t\t// corresponding to the given user alias. However, the driving table is not\n \t\t\t// (necessarily) the table against which we want to apply locks. Mainly,\n \t\t\t// the exception case here is joined-subclass hierarchies where we instead\n \t\t\t// want to apply the lock against the root table (for all other strategies,\n \t\t\t// it just happens that driving and root are the same).\n \t\t\tfinal QueryNode select = ( QueryNode ) queryTranslator.getSqlAST();\n \t\t\tfinal Lockable drivingPersister = ( Lockable ) select.getFromClause()\n \t\t\t\t\t.findFromElementByUserOrSqlAlias( userAlias, drivingSqlAlias )\n \t\t\t\t\t.getQueryable();\n \t\t\tfinal String sqlAlias = drivingPersister.getRootTableAlias( drivingSqlAlias );\n \n \t\t\tfinal LockMode effectiveLockMode = lockOptions.getEffectiveLockMode( userAlias );\n \t\t\tlocks.setAliasSpecificLockMode( sqlAlias, effectiveLockMode );\n \n \t\t\tif ( keyColumnNames != null ) {\n \t\t\t\tkeyColumnNames.put( sqlAlias, drivingPersister.getRootTableIdentifierColumnNames() );\n \t\t\t}\n \t\t}\n \n \t\t// apply the collected locks and columns\n \t\treturn dialect.applyLocksToSql( sql, locks, keyColumnNames );\n \t}",
"final public Lock test_get_lock() {\r\n\t\treturn lock_;\r\n\t}",
"protected String getLockManagerName() {\n return getName();\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsInJhd0tleVZhbHVlcyI6WyIxIiwiMSJdLCJyYXdLZXlUeXBlTmFtZXMiOlsiamF2YS5sYW5nLkludGVnZXIiLCJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tMasterBEnt masterBEnt = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\t\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\t\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29tcCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAiLCJyYXdLZXlWYWx1ZXMiOlsiMSIsIjEiXSwicmF3S2V5VHlwZU5hbWVzIjpbImphdmEubGFuZy5JbnRlZ2VyIiwiamF2YS5sYW5nLkludGVnZXIiXX0\");\r\n\t\t\t\tMasterBComp masterBComp = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAuZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIiwiMSJdLCJyYXdLZXlUeXBlTmFtZXMiOlsiamF2YS5sYW5nLkludGVnZXIiLCJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> compDetailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29tcCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAubWFzdGVyQkNvbXBDb21wIiwicmF3S2V5VmFsdWVzIjpbIjEiLCIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciIsImphdmEubGFuZy5JbnRlZ2VyIl19\");\r\n\t\t\t\tMasterBCompComp masterBCompComp = PlayerManagerTest.this.manager.getBySignature(signatureBean);\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAubWFzdGVyQkNvbXBDb21wLmRldGFpbEFFbnRDb2wiLCJyYXdLZXlWYWx1ZXMiOlsiMSIsIjEiXSwicmF3S2V5VHlwZU5hbWVzIjpbImphdmEubGFuZy5JbnRlZ2VyIiwiamF2YS5sYW5nLkludGVnZXIiXX0\");\r\n\t\t\t\tCollection<DetailAEnt> compCompDetailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\tAssert.assertThat(\"masterBEnt.getMasterBComp(), sameInstance(masterBComp)\", masterBEnt.getMasterBComp(), sameInstance(masterBComp));\r\n\t\t\t\tAssert.assertThat(\"masterBEnt.getMasterBComp().getMasterBCompComp(), sameInstance(masterBCompComp)\", masterBEnt.getMasterBComp().getMasterBCompComp(), sameInstance(masterBCompComp));\r\n\t\t\t\t\r\n\t\t\t\tAssert.assertThat(\"masterBComp.getMasterBCompComp(), sameInstance(masterBCompComp)\", masterBComp.getMasterBCompComp(), sameInstance(masterBCompComp));\r\n\t\t\t\tAssert.assertThat(\"detailAEntCol, not(sameInstance(compDetailAEntCol))\", detailAEntCol, not(sameInstance(compDetailAEntCol)));\r\n\t\t\t\tAssert.assertThat(\"detailAEntCol, not(sameInstance(compCompDetailAEntCol))\", detailAEntCol, not(sameInstance(compCompDetailAEntCol)));\r\n\t\t\t\tAssert.assertThat(\"compDetailAEntCol, not(sameInstance(compCompDetailAEntCol))\", compDetailAEntCol, not(sameInstance(compCompDetailAEntCol)));\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"protected RowLock getUpdateLockType() \n {\n\t\treturn(RowLock.RU3);\n }",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"@Override\n\tpublic List<LockRecordVo> getLockRecord(String sn) {\n\t\tLockServerApi.Iface lockServerApi =(LockServerApi.Iface) thriftClientProxy.getClient(LockServerApi.class);\n\t\tString message = null;\n\t\ttry{\n\t\t\t message = lockServerApi.getLockRecord(sn);\n\t\t}catch(Exception e){\n\t\t\te.printStackTrace();\n\t\t}\n\t\tif(message == null){\n\t\t\tthrow new RuntimeException(\"访问请求异常\");\n\t\t}\n\t\t JSONObject json = JSONObject.parseObject(message);\n\t\tif(json.getIntValue(\"code\") !=200){\n \t\tthrow new RuntimeException(\"查询锁失败\");\n \t}\n\t\tlog.info(message);\n\t\t/**\n\t\t * 取得历史记录\n\t\t * */\n\t\tList<LockRecord> lockRecordList = JSONObject.parseArray(json.getString(\"data\"), LockRecord.class);\n\t\tList<LockRecordVo> lockRecordVoList = new LinkedList<LockRecordVo>();\n\t\tif(lockRecordList !=null){\n\t\t\tlockRecordList.forEach(lockRecord -> {\n\t\t\t\tlockRecordVoList.add(new LockRecordVo(lockRecord.getSlaveId(),lockRecord.getOpenState(),lockRecord.getDealDate(),lockRecord.getVoltage(),lockRecord.getUserName()));\n\t\t\t});\n\t\t}\n\t\t\n\t\treturn lockRecordVoList;\n\t}",
"@Override\n public int getTxTimeoutInMillis() {\n return Globals.lockingTimeout;\n }",
"public interface LockDAO\n{\n /**\n * Aquire a given exclusive lock, assigning it (and any implicitly shared locks) a\n * timeout. All shared locks are implicitly taken as well.\n * <p>\n * A lock can be re-taken if it has expired and if the lock token has not changed\n * \n * @param lockQName the unique name of the lock to acquire\n * @param lockToken the potential lock token (max 36 chars)\n * @param timeToLive the time (in milliseconds) that the lock must remain \n * @return Returns <tt>true</tt> if the lock was taken, \n * otherwise <tt>false</tt>\n * @throws LockAcquisitionException on failure\n */\n void getLock(QName lockQName, String lockToken, long timeToLive);\n\n /**\n * Refresh a held lock. This is successful if the lock in question still exists\n * and if the lock token has not changed. Lock expiry does not prevent the lock\n * from being refreshed.\n * \n * @param lockQName the unique name of the lock to update\n * @param lockToken the lock token for the lock held\n * @param timeToLive the new time to live (in milliseconds)\n * @return Returns <tt>true</tt> if the lock was updated,\n * otherwise <tt>false</tt>\n * @throws LockAcquisitionException on failure\n */\n void refreshLock(QName lockQName, String lockToken, long timeToLive);\n \n /**\n * Release a lock. The lock token must still apply and all the shared and exclusive\n * locks need to still be present. Lock expiration does not prevent this operation\n * from succeeding.\n * <p>\n * Note: Failure to release a lock due to a exception condition is dealt with by\n * passing the exception out.\n * \n * @param lockQName the unique name of the lock to release\n * @param lockToken the current lock token\n * @return Returns <tt>true</tt> if all the required locks were\n * (still) held under the lock token and were\n * valid at the time of release, otherwise <tt>false</tt>\n */\n void releaseLock(QName lockQName, String lockToken);\n}",
"@Override\n public void onCreate(SQLiteDatabase db) {\n Log.e(\"zhangcy\", \"-------->AppLockDBlite onCreate\");\n db.execSQL(\"create table if not exists \" + AppLockUntil.TNAME + \"(\" + AppLockUntil.TID\n + \" integer primary key autoincrement,\" + AppLockUntil.PKGNAME + \" text,\"\n + AppLockUntil.LOCK + \" interger);\");\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompComp> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getDetailAComp().getDetailACompComp());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(\r\n\t\t\t\t\t\t\tDetailAEnt.class, \r\n\t\t\t\t\t\t\tdetailAEnt.getDetailAComp().getDetailACompComp(),\r\n\t\t\t\t\t\t\td -> d.getDetailAComp().getDetailACompComp());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompComp>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompComp> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getDetailAComp().getDetailACompComp());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(detailAEnt, d -> d.getDetailAComp());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(detailAEnt.getDetailAComp(), dc -> dc.getDetailACompComp());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompComp>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@ManyToOne\n\t@JoinColumn(name=\"LockStatus\", nullable=false)\n\t@Fetch(FetchMode.SELECT)\n\t@NotFound(action=NotFoundAction.IGNORE)\n\tpublic AccessStatus getLockStatus() {\n\t\treturn this.lockStatus;\n\t}",
"String getLockOwner();",
"public long getLockStatus() {\r\n return lockStatus;\r\n }",
"public String isLockedFor() {\n return (lockId == null ? \"\" : lockId);\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompId> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getCompId());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(DetailAEnt.class, detailAEnt.getCompId(), d -> d.getCompId());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompId>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"final Object getLockObject() {\n return timeManager;\n }",
"void addRowsLock();",
"public void setLockKey( Long lockKey ) {\n this.lockKey = lockKey;\n }",
"@Test\n\tpublic void testFuncionamentoUpdateVersionLockOtimista(){\n \n\t\tdoInTransaction( session -> {\n\t\t\tArtista roberto = session.get(Artista.class, 3L);\n\t\t\troberto.getDetalhes().setBiografia(\"Biografia alterada...\");\n\t\t\tsession.update(roberto);\n\t\t});\n\t\t \n\t}",
"@Version\r\n @Column(name=\"optlock\")\r\n public Integer getVersion()\r\n {\r\n return version;\r\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompId> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getCompId());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(detailAEnt, d -> d.getCompId());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompId>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\tMasterAEnt masterAEnt = (MasterAEnt) ss.get(MasterAEnt.class, 1);\r\n\t\t\t\t//doing lazy-load\r\n\t\t\t\tmasterAEnt.getDetailAEntCol().size();\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest.this\r\n\t\t\t\t\t.manager\r\n\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\tArrayList<DetailAEnt> detailAEntCuttedCol = new ArrayList<>();\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(1));\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(2));\r\n\t\t\t\tPlayerSnapshot<Collection<DetailAEnt>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailAEntCuttedCol);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\t\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"private void demonstrateLockExpiry(final StandardJanusGraph graph, final boolean useNativeLocking, final long waitMillis) throws TemporaryLockingException, InterruptedException {\n graph.addVertex(T.label, DATABASE_METADATA_LABEL).property(VERSION_PROPERTY, VERSION_ONE);\n if(useNativeLocking) {\n System.out.println(\"regular tx one \" + getTxFromGraph(graph).toString() + \" \" + System.currentTimeMillis());\n }\n graph.tx().commit();\n\n final GraphTraversalSource g = graph.traversal();\n g.V().hasLabel(DATABASE_METADATA_LABEL).has(VERSION_PROPERTY, VERSION_ONE).property(VERSION_PROPERTY, VERSION_TWO).next();\n if(useNativeLocking) {\n System.out.println(\"regular tx two \" + getTxFromGraph(graph).toString() + \" \" + System.currentTimeMillis());\n }\n g.tx().commit();\n\n Thread.sleep(waitMillis); //wait for the lock to expire\n g.V().hasLabel(DATABASE_METADATA_LABEL).has(VERSION_PROPERTY, VERSION_TWO).property(VERSION_PROPERTY, VERSION_THREE).next();\n if(useNativeLocking) {\n System.out.println(\"regular tx three \" + getTxFromGraph(graph).toString() + \" \" + System.currentTimeMillis());\n }\n g.tx().commit();\n //END code from first code listing\n }",
"@Select({\n \"select\",\n \"JNLNO, TRANDATE, ACCOUNTDATE, CHECKTYPE, STATUS, DONETIME, FILENAME\",\n \"from B_UMB_CHECKING_LOG\",\n \"where JNLNO = #{jnlno,jdbcType=VARCHAR}\"\n })\n @Results({\n @Result(column=\"JNLNO\", property=\"jnlno\", jdbcType=JdbcType.VARCHAR, id=true),\n @Result(column=\"TRANDATE\", property=\"trandate\", jdbcType=JdbcType.VARCHAR),\n @Result(column=\"ACCOUNTDATE\", property=\"accountdate\", jdbcType=JdbcType.VARCHAR),\n @Result(column=\"CHECKTYPE\", property=\"checktype\", jdbcType=JdbcType.CHAR),\n @Result(column=\"STATUS\", property=\"status\", jdbcType=JdbcType.CHAR),\n @Result(column=\"DONETIME\", property=\"donetime\", jdbcType=JdbcType.VARCHAR),\n @Result(column=\"FILENAME\", property=\"filename\", jdbcType=JdbcType.VARCHAR)\n })\n BUMBCheckingLog selectByPrimaryKey(BUMBCheckingLogKey key);",
"public Long getLock_latency() {\n return lock_latency;\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\tMasterAEnt masterAEnt = (MasterAEnt) ss.get(MasterAEnt.class, 1);\r\n\t\t\t\t//doing lazy-load\r\n\t\t\t\tmasterAEnt.getDetailAEntCol().size();\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest.this\r\n\t\t\t\t\t.manager\r\n\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\tArrayList<DetailAEnt> detailAEntCuttedCol = new ArrayList<>();\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(0));\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(1));\r\n\t\t\t\tPlayerSnapshot<Collection<DetailAEnt>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailAEntCuttedCol);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\t\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"public Long getOtherLockNum() {\n return otherLockNum;\n }",
"ManagementLockObject.Update update();",
"public BookingLockDetails getBookingLockDetails(com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.bookinglockdetails.v1.BookingLockDetails res){\n\t\tBookingLockDetails bookingLockDetails = new BookingLockDetails();\n\t\t\n\t\tbookingLockDetails.setBookingNo( res.getBookingNo() );\n\t\tbookingLockDetails.setLockId( res.getLockId() );\n\t\tbookingLockDetails.setLockMessage( res.getLockMessage() );\n\t\tif( res.isAlreadyLocked() != null ){\n\t\t\tbookingLockDetails.setAlreadyLocked( res.isAlreadyLocked().booleanValue() );\n\t\t}\n\t\tif( res.isAdmin() != null ){\n\t\t\tbookingLockDetails.setAdmin( res.isAdmin().booleanValue() );\n\t\t}\n\t\t\n\t\treturn bookingLockDetails;\n\t}",
"Lock getLock(String lockName);",
"public SystemMetadataDaoMetacatImpl(DataSource dataSource) {\n jdbcTemplate = new JdbcTemplate(dataSource);\n txManager = new DataSourceTransactionManager(dataSource);\n txTemplate = new TransactionTemplate(txManager);\n txTemplate.setIsolationLevel(TransactionDefinition.ISOLATION_READ_COMMITTED);\n }",
"public int getLockAddress() {\n\t\treturn 0;\n\t}",
"String getStartTransactionSql();",
"@Override\n protected String applyLocks(String sql, LockOptions lockOptions, Dialect dialect) throws QueryException {\n \t\tfinal String result;\n \t\tif ( lockOptions == null ||\n \t\t\t( lockOptions.getLockMode() == LockMode.NONE && lockOptions.getAliasLockCount() == 0 ) ) {\n \t\t\treturn sql;\n \t\t}\n \t\telse {\n \t\t\tLockOptions locks = new LockOptions();\n \t\t\tlocks.setLockMode(lockOptions.getLockMode());\n \t\t\tlocks.setTimeOut(lockOptions.getTimeOut());\n \t\t\tlocks.setScope(lockOptions.getScope());\n \t\t\tIterator iter = lockOptions.getAliasLockIterator();\n \t\t\twhile ( iter.hasNext() ) {\n \t\t\t\tMap.Entry me = ( Map.Entry ) iter.next();\n \t\t\t\tlocks.setAliasSpecificLockMode( getAliasName( ( String ) me.getKey() ), (LockMode) me.getValue() );\n \t\t\t}\n \t\t\tMap keyColumnNames = null;\n \t\t\tif ( dialect.forUpdateOfColumns() ) {\n \t\t\t\tkeyColumnNames = new HashMap();\n \t\t\t\tfor ( int i = 0; i < names.length; i++ ) {\n \t\t\t\t\tkeyColumnNames.put( names[i], persisters[i].getIdentifierColumnNames() );\n \t\t\t\t}\n \t\t\t}\n \t\t\tresult = dialect.applyLocksToSql( sql, locks, keyColumnNames );\n \t\t}\n \t\tlogQuery( queryString, result );\n \t\treturn result;\n \t}",
"Boolean isConsumeLockEntity();",
"@Test(expected=OptimisticLockException.class)\n\tpublic void testColisaoLockOtimista(){\n\t\tArtista artista = doWithSession( session -> {\n\t\t\t\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\treturn roberto;\n\t\t});\n\t\t\n\t\t// Lido e escrito pelo User B\n\t\tdoInTransaction( session -> {\n\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\troberto.getDetalhes().setBiografia(\"Biografia alterada...\");\n\t\t\tsession.update(roberto);\n\t\t});\n\t\t\n\t\t// Escrito pelo User A // javax.persistence.OptimisticLockException: -> org.hibernate.StaleStateException:\n\t\tdoInTransaction( session -> {\n\t\t\tartista.getDetalhes().setBiografia(\"Conlisão!!!\");\n\t\t\tsession.update(artista);\n\t\t});\n\t}",
"@Select({\n \"select\",\n \"code, statistic_code, periods, line_code, material_type, element_type, material_requisitions, \",\n \"current_goods_in_process, last_goods_in_process, product_storage, intermediate_products_variation, \",\n \"unit_consumption\",\n \"from cost_accounting_statistic_by_line_detail\",\n \"where code = #{code,jdbcType=BIGINT}\"\n })\n @ResultMap(\"BaseResultMap\")\n CostAccountingStatisticByLineDetail selectByPrimaryKey(Long code);",
"@Test(timeout = 4000)\n public void test16() throws Throwable {\n Object object0 = new Object();\n Integer integer0 = RawTransaction.LOCK_ESCALATE;\n DBColumn[] dBColumnArray0 = new DBColumn[2];\n String string0 = SQLUtil.substituteMarkers(\"create materialized view\", \"create materialized view\", integer0);\n assertEquals(\"3\", string0);\n }",
"@Override\n\tpublic LockModeType getLockMode(Object entity) {\n\t\treturn null;\n\t}",
"@Override\r\n\tpublic void addLockToken(String lt) {\n\t\t\r\n\t}",
"public String getLockUser() {\n return lockUser;\n }",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"private void RecordStoreLockFactory() {\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<MasterAEnt> masterAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, MasterAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"id\")).list();\r\n\t\t\t\tList<MasterAWrapper> masterAWrapperList = new ArrayList<>();\r\n\t\t\t\tfor (MasterAEnt masterAEnt : masterAEntList) {\r\n\t\t\t\t\tMasterAWrapper masterAWrapper = new MasterAWrapper();\r\n\t\t\t\t\tmasterAWrapper.setMasterA(masterAEnt);\r\n\t\t\t\t\tmasterAWrapper.setDetailAWrapperList(new ArrayList<>());\r\n\t\t\t\t\tmasterAWrapper.setDetailAEntCol(new ArrayList<>(masterAEnt.getDetailAEntCol()));\r\n\t\t\t\t\tfor (DetailAEnt detailAEnt : masterAEnt.getDetailAEntCol()) {\r\n\t\t\t\t\t\tDetailAWrapper detailAWrapper = new DetailAWrapper();\r\n\t\t\t\t\t\tdetailAWrapper.setDetailA(detailAEnt);\r\n\t\t\t\t\t\tmasterAWrapper.getDetailAWrapperList().add(detailAWrapper);\r\n\t\t\t\t\t}\r\n\t\t\t\t\tmasterAWrapperList.add(masterAWrapper);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<MasterAWrapper>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(masterAWrapperList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<MasterBEnt> masterBEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, MasterBEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.idA\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.idB\")).list();\r\n\t\t\t\tList<Map<String, Map<String, MasterBEnt>>> masterBEntBizarreList = new ArrayList<>();\r\n\t\t\t\t\r\n\t\t\t\tfor (MasterBEnt masterB : masterBEntList) {\r\n\t\t\t\t\tSignatureBean signBean = ((IPlayerManagerImplementor) PlayerManagerTest.this.manager).generateSignature(masterB);\r\n\t\t\t\t\tString signStr = PlayerManagerTest.this.manager.serializeSignature(signBean);\r\n\t\t\t\t\tMap<String, Map<String, MasterBEnt>> mapItem = new LinkedHashMap<>();\r\n\t\t\t\t\tPlayerSnapshot<MasterBEnt> masterBPS = PlayerManagerTest.this.manager.createPlayerSnapshot(masterB);\r\n\t\t\t\t\tMap<String, MasterBEnt> mapMapItem = new LinkedHashMap<>();\r\n\t\t\t\t\tmapMapItem.put(\"wrappedSnapshot\", masterB);\r\n\t\t\t\t\tmapItem.put(signStr, mapMapItem);\r\n\t\t\t\t\tmasterBEntBizarreList.add(mapItem);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<Map<String, Map<String, MasterBEnt>>>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(masterBEntBizarreList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Pointcut(value = \"@annotation(lock)\", argNames = \"lock\")\n public void lockPointcut(Lock lock) {\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\tMasterAEnt masterAEnt = (MasterAEnt) ss.get(MasterAEnt.class, 1);\r\n\t\t\t\t//doing lazy-load\r\n\t\t\t\tmasterAEnt.getDetailAEntCol().size();\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest.this\r\n\t\t\t\t\t.manager\r\n\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\tPlayerSnapshot<Collection<DetailAEnt>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailAEntCol);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\t\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"public Date getLockTime() {\n\t\treturn lockTime;\n\t}",
"public interface CounterRepository extends CrudRepository<Counter,Integer> {\n\n @Query(value = \"SELECT * FROM counter c WHERE c.id = ?1 for UPDATE\",\n nativeQuery = true)\n Counter findByIdWithLock(int id);\n\n\n}",
"public Lock getLock() {\n return lock;\n }",
"interface WithOwners {\n /**\n * Specifies the owners property: The owners of the lock..\n *\n * @param owners The owners of the lock.\n * @return the next definition stage.\n */\n Update withOwners(List<ManagementLockOwner> owners);\n }",
"@Insert({\n \"insert into SWMS_stock_out_record_detail (stock_out_record_id, stock_out_record_head_id, \",\n \"stock_out_record_head_code, group_name, \",\n \"stock_in_record_account_id, material_code, \",\n \"material_batch, material_type_id, \",\n \"material_sub_type_id, material_workshop_id, \",\n \"material_name_code, material_supplier_code, \",\n \"material_name, bag_num, \",\n \"weight, measure_unit, \",\n \"created_time, completion_flag)\",\n \"values (#{stockOutRecordId,jdbcType=BIGINT}, #{stockOutRecordHeadId,jdbcType=BIGINT}, \",\n \"#{stockOutRecordHeadCode,jdbcType=BIGINT}, #{groupName,jdbcType=VARCHAR}, \",\n \"#{stockInRecordAccountId,jdbcType=BIGINT}, #{materialCode,jdbcType=VARCHAR}, \",\n \"#{materialBatch,jdbcType=VARCHAR}, #{materialTypeId,jdbcType=INTEGER}, \",\n \"#{materialSubTypeId,jdbcType=INTEGER}, #{materialWorkshopId,jdbcType=INTEGER}, \",\n \"#{materialNameCode,jdbcType=INTEGER}, #{materialSupplierCode,jdbcType=INTEGER}, \",\n \"#{materialName,jdbcType=VARCHAR}, #{bagNum,jdbcType=INTEGER}, \",\n \"#{weight,jdbcType=REAL}, #{measureUnit,jdbcType=VARCHAR}, \",\n \"#{createdTime,jdbcType=TIMESTAMP}, #{completionFlag,jdbcType=BIT})\"\n })\n @SelectKey(statement=\"SELECT LAST_INSERT_ID()\", keyProperty=\"id\", before=false, resultType=Long.class)\n int insert(SwmsStockOutRecordDetail record);",
"ManagementLockObject refresh(Context context);",
"@Override\n\tpublic void lock(Object entity, LockModeType lockMode, Map<String, Object> properties) {\n\t\t\n\t}",
"protected boolean upgradeLocks() {\n \t\treturn false;\n \t}",
"public Collection<IgniteTxEntry> optimisticLockEntries();",
"public void setLockStatus(long lockStatus) {\r\n this.lockStatus = lockStatus;\r\n }",
"@Override\n\tpublic Lock getLock() {\n\t\treturn this.lock;\n\t}",
"public LockOnChange getLockOnChangeMode(){\r\n return this.lockOnChangeMode;\r\n }",
"@Override\n public void setLockOwner(Object lockOwner) {\n }",
"@Test\n public void testFailLock() {\n if (getConnection().isNis()) {\n // TODO Workaround on Solaris NIS: there doesn't seem to be a way\n // how to handle user locks on NIS.\n log.info(\"skipping test 'testLock', as LOCK attribute is not supported by the connector on NIS.\");\n return;\n }\n try {\n getFacade().update(ObjectClass.ACCOUNT, new Uid(getUsername()),\n CollectionUtil.newSet(AttributeBuilder.build(AccountAttribute.LOCK.getName())),\n null);\n AssertJUnit\n .fail(\"passing null option to Lock should cause failure. It must have a boolean value.\");\n } catch (Exception ex) {\n // OK\n }\n try {\n getFacade().create(\n ObjectClass.ACCOUNT,\n CollectionUtil.newSet(AttributeBuilder.build(Name.NAME, \"fooconn\"),\n AttributeBuilder.buildPassword(\"foo134\".toCharArray()),\n AttributeBuilder.build(AccountAttribute.LOCK.getName())), null);\n AssertJUnit\n .fail(\"passing null option to Lock should cause failure. It must have a boolean value.\");\n } catch (Exception ex) {\n // OK\n } finally {\n try {\n getFacade().delete(ObjectClass.ACCOUNT, new Uid(\"foo134\"), null);\n } catch (Exception ex) {\n // OK\n }\n }\n }",
"public interface ManagementLockObject {\n /**\n * Gets the id property: Fully qualified resource Id for the resource.\n *\n * @return the id value.\n */\n String id();\n\n /**\n * Gets the name property: The name of the resource.\n *\n * @return the name value.\n */\n String name();\n\n /**\n * Gets the type property: The type of the resource.\n *\n * @return the type value.\n */\n String type();\n\n /**\n * Gets the level property: The level of the lock. Possible values are: NotSpecified, CanNotDelete, ReadOnly.\n * CanNotDelete means authorized users are able to read and modify the resources, but not delete. ReadOnly means\n * authorized users can only read from a resource, but they can't modify or delete it.\n *\n * @return the level value.\n */\n LockLevel level();\n\n /**\n * Gets the notes property: Notes about the lock. Maximum of 512 characters.\n *\n * @return the notes value.\n */\n String notes();\n\n /**\n * Gets the owners property: The owners of the lock.\n *\n * @return the owners value.\n */\n List<ManagementLockOwner> owners();\n\n /**\n * Gets the inner com.azure.resourcemanager.locks.fluent.models.ManagementLockObjectInner object.\n *\n * @return the inner object.\n */\n ManagementLockObjectInner innerModel();\n\n /** The entirety of the ManagementLockObject definition. */\n interface Definition\n extends DefinitionStages.Blank,\n DefinitionStages.WithResourceGroup,\n DefinitionStages.WithLevel,\n DefinitionStages.WithCreate {\n }\n /** The ManagementLockObject definition stages. */\n interface DefinitionStages {\n /** The first stage of the ManagementLockObject definition. */\n interface Blank extends WithResourceGroup {\n }\n /** The stage of the ManagementLockObject definition allowing to specify parent resource. */\n interface WithResourceGroup {\n /**\n * Specifies resourceGroupName.\n *\n * @param resourceGroupName The name of the resource group to lock.\n * @return the next definition stage.\n */\n WithLevel withExistingResourceGroup(String resourceGroupName);\n }\n /** The stage of the ManagementLockObject definition allowing to specify level. */\n interface WithLevel {\n /**\n * Specifies the level property: The level of the lock. Possible values are: NotSpecified, CanNotDelete,\n * ReadOnly. CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it..\n *\n * @param level The level of the lock. Possible values are: NotSpecified, CanNotDelete, ReadOnly.\n * CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it.\n * @return the next definition stage.\n */\n WithCreate withLevel(LockLevel level);\n }\n /**\n * The stage of the ManagementLockObject definition which contains all the minimum required properties for the\n * resource to be created, but also allows for any other optional properties to be specified.\n */\n interface WithCreate extends DefinitionStages.WithNotes, DefinitionStages.WithOwners {\n /**\n * Executes the create request.\n *\n * @return the created resource.\n */\n ManagementLockObject create();\n\n /**\n * Executes the create request.\n *\n * @param context The context to associate with this operation.\n * @return the created resource.\n */\n ManagementLockObject create(Context context);\n }\n /** The stage of the ManagementLockObject definition allowing to specify notes. */\n interface WithNotes {\n /**\n * Specifies the notes property: Notes about the lock. Maximum of 512 characters..\n *\n * @param notes Notes about the lock. Maximum of 512 characters.\n * @return the next definition stage.\n */\n WithCreate withNotes(String notes);\n }\n /** The stage of the ManagementLockObject definition allowing to specify owners. */\n interface WithOwners {\n /**\n * Specifies the owners property: The owners of the lock..\n *\n * @param owners The owners of the lock.\n * @return the next definition stage.\n */\n WithCreate withOwners(List<ManagementLockOwner> owners);\n }\n }\n /**\n * Begins update for the ManagementLockObject resource.\n *\n * @return the stage of resource update.\n */\n ManagementLockObject.Update update();\n\n /** The template for ManagementLockObject update. */\n interface Update extends UpdateStages.WithLevel, UpdateStages.WithNotes, UpdateStages.WithOwners {\n /**\n * Executes the update request.\n *\n * @return the updated resource.\n */\n ManagementLockObject apply();\n\n /**\n * Executes the update request.\n *\n * @param context The context to associate with this operation.\n * @return the updated resource.\n */\n ManagementLockObject apply(Context context);\n }\n /** The ManagementLockObject update stages. */\n interface UpdateStages {\n /** The stage of the ManagementLockObject update allowing to specify level. */\n interface WithLevel {\n /**\n * Specifies the level property: The level of the lock. Possible values are: NotSpecified, CanNotDelete,\n * ReadOnly. CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it..\n *\n * @param level The level of the lock. Possible values are: NotSpecified, CanNotDelete, ReadOnly.\n * CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it.\n * @return the next definition stage.\n */\n Update withLevel(LockLevel level);\n }\n /** The stage of the ManagementLockObject update allowing to specify notes. */\n interface WithNotes {\n /**\n * Specifies the notes property: Notes about the lock. Maximum of 512 characters..\n *\n * @param notes Notes about the lock. Maximum of 512 characters.\n * @return the next definition stage.\n */\n Update withNotes(String notes);\n }\n /** The stage of the ManagementLockObject update allowing to specify owners. */\n interface WithOwners {\n /**\n * Specifies the owners property: The owners of the lock..\n *\n * @param owners The owners of the lock.\n * @return the next definition stage.\n */\n Update withOwners(List<ManagementLockOwner> owners);\n }\n }\n /**\n * Refreshes the resource to sync with Azure.\n *\n * @return the refreshed resource.\n */\n ManagementLockObject refresh();\n\n /**\n * Refreshes the resource to sync with Azure.\n *\n * @param context The context to associate with this operation.\n * @return the refreshed resource.\n */\n ManagementLockObject refresh(Context context);\n}",
"public DBMaker disableLocking(){\n this.lockingDisabled = true;\n return this;\n }",
"@Override\n\tpublic LockThreadInfo mapRow(ResultSet rs, int rowNum) throws SQLException {\n\t\tLockThreadInfo lockThreadInfo = new LockThreadInfo(rs.getString(\"tid\"), rs.getString(\"nid\"), rs.getString(\"state\"));\n\t\treturn lockThreadInfo;\n\t}",
"public void openLock(){\n /*Code to send an unlocking signal to the physical device Gate*/\n }",
"void getLock(QName lockQName, String lockToken, long timeToLive);",
"CamelJpaConsumerBindingModel setConsumeLockEntity(Boolean consumeLockEntity);",
"public final OpLockDetails getOpLock() {\n\t\treturn m_oplock;\n\t}",
"public int getLockon() {\r\n return lockon;\r\n }",
"Miss_control_log selectByPrimaryKey(String loginuuid);",
"public Expression getWriteLockUpdateExpression(ExpressionBuilder builder, AbstractSession session) {\r\n return ExpressionMath.add(builder.getField(writeLockField.getName()), 1);\r\n }",
"@Test(expected=OptimisticLockException.class)\n\tpublic void testColisaoCamposDiferentesLockOtimista(){\n\t\t// Detached Artista (Lido pelo User A)\n\t\tArtista artista = doWithSession( session -> {\n\t\t\t\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\treturn roberto;\n\t\t});\n\t\t\n\t\t// Lido e escrito pelo User B\n\t\tdoInTransaction( session -> {\n\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\troberto.getDetalhes().setBiografia(\"Biografia alterada...\");\n\t\t\tsession.update(roberto);\n\t\t});\n\t\t\n\t\t// Escrito pelo User A // javax.persistence.OptimisticLockException: -> org.hibernate.StaleStateException:\n\t\tdoInTransaction( session -> {\n\t\t\tartista.getDetalhes().setDataNascimento(new Date());\n\t\t\tsession.update(artista);\n\t\t});\n\t}",
"protected final Object getTreeLock() {\n return Component.LOCK;\n }",
"String[] getTimeToExpirationLock(String uuid) throws DatabaseException;",
"@Override\r\n\tpublic List<PayRollLock> findpayRollLock(String processMonth) {\n\t\t\r\n\t\treturn payRollLockRepository.findpayRollLock(processMonth);\r\n\t}",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"@Override\n public boolean tryLock(long timeout, TimeUnit unit) {\n Preconditions.checkState(connection != null);\n checkThread();\n Monitoring.increment(callCounter.name(), (KeyValuePair<String, String>[]) null);\n try {\n return lockLatency.record(() -> {\n long start = System.currentTimeMillis();\n long period = DateTimeUtils.period(timeout, unit);\n if (super.tryLock(timeout, unit)) {\n if (locked) return true;\n while (true) {\n if ((System.currentTimeMillis() - start) > period) break;\n Transaction tnx = session.beginTransaction();\n try {\n DbLockRecord record = checkExpiry(fetch(session, true, true));\n if (record.isLocked() && instanceId().compareTo(record.getInstanceId()) == 0) {\n session.save(record);\n tnx.commit();\n locked = true;\n lockedTime = System.currentTimeMillis();\n break;\n } else if (!record.isLocked()) {\n record.setLocked(true);\n record.setInstanceId(instanceId());\n record.setTimestamp(System.currentTimeMillis());\n session.update(record);\n tnx.commit();\n locked = true;\n lockedTime = System.currentTimeMillis();\n break;\n }\n tnx.rollback();\n } catch (Exception ex) {\n tnx.rollback();\n throw ex;\n }\n Thread.sleep(DEFAULT_SLEEP_INTERVAL);\n }\n }\n return locked;\n });\n } catch (Throwable t) {\n Monitoring.increment(errorCounter.name(), (KeyValuePair<String, String>[]) null);\n throw new LockException(t);\n }\n }"
]
| [
"0.59257936",
"0.56153053",
"0.54717666",
"0.5399092",
"0.5375427",
"0.5271206",
"0.5267385",
"0.5215647",
"0.52116454",
"0.5177909",
"0.514263",
"0.51257724",
"0.5113672",
"0.50925803",
"0.50902885",
"0.50189716",
"0.500118",
"0.49987784",
"0.499427",
"0.4985887",
"0.49845806",
"0.49829754",
"0.4971757",
"0.49707723",
"0.4962846",
"0.4962247",
"0.4958546",
"0.4957097",
"0.4954251",
"0.49417287",
"0.49290666",
"0.49117908",
"0.4897265",
"0.48666286",
"0.48631832",
"0.48598412",
"0.48564294",
"0.4855154",
"0.4854867",
"0.4850757",
"0.4839831",
"0.48329404",
"0.4831431",
"0.4829812",
"0.4829589",
"0.48274457",
"0.48200557",
"0.48189107",
"0.48188677",
"0.4799352",
"0.4794433",
"0.47836405",
"0.47750866",
"0.47679383",
"0.47658828",
"0.47504258",
"0.47498798",
"0.47475025",
"0.47463942",
"0.47456858",
"0.47316477",
"0.47114757",
"0.47094572",
"0.4703897",
"0.46999753",
"0.4697164",
"0.46846908",
"0.46770313",
"0.4673695",
"0.46706903",
"0.4670481",
"0.4662448",
"0.46583822",
"0.465819",
"0.4647779",
"0.46371153",
"0.46345297",
"0.46274364",
"0.46219042",
"0.46178052",
"0.4616605",
"0.4602074",
"0.45975223",
"0.45965677",
"0.45965168",
"0.4589654",
"0.4578076",
"0.45695147",
"0.45677972",
"0.45674157",
"0.4562018",
"0.45479298",
"0.45378706",
"0.4535208",
"0.45328468",
"0.45279312",
"0.45269975",
"0.45253378",
"0.45253378",
"0.45253378",
"0.45122442"
]
| 0.0 | -1 |
This method was generated by MyBatis Generator. This method corresponds to the database table TFC_USE_LOCK_DETAIL | @Override
public String toString() {
StringBuilder sb = new StringBuilder();
sb.append(getClass().getSimpleName());
sb.append(" [");
sb.append("Hash = ").append(hashCode());
sb.append(", coinTypeId=").append(coinTypeId);
sb.append(", recTime=").append(recTime);
sb.append(", actiontype=").append(actiontype);
sb.append(", lockId=").append(lockId);
sb.append(", userId=").append(userId);
sb.append(", serverIp=").append(serverIp);
sb.append(", gameId=").append(gameId);
sb.append(", serverName=").append(serverName);
sb.append(", lockNum=").append(lockNum);
sb.append(", changeNum=").append(changeNum);
sb.append(", remainNum=").append(remainNum);
sb.append(", otherLockNum=").append(otherLockNum);
sb.append("]");
return sb.toString();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Long getLockTypeId()\n/* */ {\n/* 58 */ return this.lockTypeId;\n/* */ }",
"private String getSingleLockSBRStmt() {\n\n if (null == mSingleLockStmt) {\n initClauses();\n mSingleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE s.EUID = ? AND s.REVISIONNUMBER = ? \" + mForUpdateClause;\n }\n\n return mSingleLockStmt;\n }",
"public LocksRecord() {\n\t\tsuper(org.jooq.example.gradle.db.information_schema.tables.Locks.LOCKS);\n\t}",
"@DefaultMessage(\"Locking record for Update...\")\n @Key(\"gen.lockForUpdate\")\n String gen_lockForUpdate();",
"public void viewListofLocks() {\n\t\ttry {\n\t\t\t\n\t\t}catch(Exception e) {\n\t\t\tLog.addMessage(\"Failed to get list of locks\");\n\t\t\tSystem.out.println(e.getMessage().toString());\n\t\t\tAssert.assertTrue(false, \"Failed to get list of locks\");\n\t\t}\n\t}",
"public RuntimeExceptionDao<Lock, Integer> getLockDataDao() {\n\t\tif (lockRuntimeDao == null) {\n\t\t\tlockRuntimeDao = getRuntimeExceptionDao(Lock.class);\n\t\t}\n\t\treturn lockRuntimeDao;\n\t}",
"public Dao<Lock, Integer> getLockDao() throws SQLException {\n\t\tif (lockDao == null) {\n\t\t\tlockDao = getDao(Lock.class);\n\t\t}\n\t\treturn lockDao;\n\t}",
"public Long getLockNum() {\n return lockNum;\n }",
"private String getDoubleLockSBRStmt() {\n\n if (null == mDoubleLockStmt) {\n initClauses();\n mDoubleLockStmt = \"SELECT s.EUID FROM SBYN_SYSTEMSBR s \" + mWithClause + \" WHERE ( s.EUID = ? AND s.REVISIONNUMBER = ?) OR ( s.EUID = ? AND s.REVISIONNUMBER = ?)\" + mForUpdateClause;\n }\n\n return mDoubleLockStmt;\n }",
"public String getLockType() {\n return this.lockType;\n }",
"long getLockOwnersID(String uuid) throws DatabaseException;",
"public void dataBaseLocked();",
"@Override\n public boolean equals(Object that) {\n if (this == that) {\n return true;\n }\n if (that == null) {\n return false;\n }\n if (getClass() != that.getClass()) {\n return false;\n }\n TFCUseLockDetail other = (TFCUseLockDetail) that;\n return (this.getRowId() == null ? other.getRowId() == null : this.getRowId().equals(other.getRowId()))\n && (this.getCoinTypeId() == null ? other.getCoinTypeId() == null : this.getCoinTypeId().equals(other.getCoinTypeId()))\n && (this.getRecTime() == null ? other.getRecTime() == null : this.getRecTime().equals(other.getRecTime()))\n && (this.getActiontype() == null ? other.getActiontype() == null : this.getActiontype().equals(other.getActiontype()))\n && (this.getLockId() == null ? other.getLockId() == null : this.getLockId().equals(other.getLockId()))\n && (this.getUserId() == null ? other.getUserId() == null : this.getUserId().equals(other.getUserId()))\n && (this.getServerIp() == null ? other.getServerIp() == null : this.getServerIp().equals(other.getServerIp()))\n && (this.getGameId() == null ? other.getGameId() == null : this.getGameId().equals(other.getGameId()))\n && (this.getServerName() == null ? other.getServerName() == null : this.getServerName().equals(other.getServerName()))\n && (this.getLockNum() == null ? other.getLockNum() == null : this.getLockNum().equals(other.getLockNum()))\n && (this.getChangeNum() == null ? other.getChangeNum() == null : this.getChangeNum().equals(other.getChangeNum()))\n && (this.getRemainNum() == null ? other.getRemainNum() == null : this.getRemainNum().equals(other.getRemainNum()))\n && (this.getOtherLockNum() == null ? other.getOtherLockNum() == null : this.getOtherLockNum().equals(other.getOtherLockNum()));\n }",
"public String getLockId() {\n return lockId;\n }",
"public Lock getLock();",
"public String appendLockHint(LockOptions lockOptions, String tableName){\n \t\treturn tableName;\n \t}",
"static int OPL_LockTable() {\n num_lock++;\n if (num_lock > 1) {\n return 0;\n }\n /* first time */\n cur_chip = null;\n /* allocate total level table (128kb space) */\n if (OPLOpenTable() == 0) {\n num_lock--;\n return -1;\n }\n return 0;\n }",
"ManagementLockObjectInner innerModel();",
"protected String applyLocks(String sql, LockOptions lockOptions, Dialect dialect) throws HibernateException {\n \t\treturn sql;\n \t}",
"public Object getLock() {\n return dataLock;\n }",
"final public Lock test_get_lock() {\r\n\t\treturn lock_;\r\n\t}",
"protected String applyLocks(String sql, LockOptions lockOptions, Dialect dialect) throws QueryException {\n \n \t\tif ( lockOptions == null ||\n \t\t\t( lockOptions.getLockMode() == LockMode.NONE && lockOptions.getAliasLockCount() == 0 ) ) {\n \t\t\treturn sql;\n \t\t}\n \n \t\t// we need both the set of locks and the columns to reference in locks\n \t\t// as the ultimate output of this section...\n \t\tfinal LockOptions locks = new LockOptions( lockOptions.getLockMode() );\n \t\tfinal Map keyColumnNames = dialect.forUpdateOfColumns() ? new HashMap() : null;\n \n \t\tlocks.setScope( lockOptions.getScope() );\n \t\tlocks.setTimeOut( lockOptions.getTimeOut() );\n \n \t\tfinal Iterator itr = sqlAliasByEntityAlias.entrySet().iterator();\n \t\twhile ( itr.hasNext() ) {\n \t\t\tfinal Map.Entry entry = (Map.Entry) itr.next();\n \t\t\tfinal String userAlias = (String) entry.getKey();\n \t\t\tfinal String drivingSqlAlias = (String) entry.getValue();\n \t\t\tif ( drivingSqlAlias == null ) {\n \t\t\t\tthrow new IllegalArgumentException( \"could not locate alias to apply lock mode : \" + userAlias );\n \t\t\t}\n \t\t\t// at this point we have (drivingSqlAlias) the SQL alias of the driving table\n \t\t\t// corresponding to the given user alias. However, the driving table is not\n \t\t\t// (necessarily) the table against which we want to apply locks. Mainly,\n \t\t\t// the exception case here is joined-subclass hierarchies where we instead\n \t\t\t// want to apply the lock against the root table (for all other strategies,\n \t\t\t// it just happens that driving and root are the same).\n \t\t\tfinal QueryNode select = ( QueryNode ) queryTranslator.getSqlAST();\n \t\t\tfinal Lockable drivingPersister = ( Lockable ) select.getFromClause()\n \t\t\t\t\t.findFromElementByUserOrSqlAlias( userAlias, drivingSqlAlias )\n \t\t\t\t\t.getQueryable();\n \t\t\tfinal String sqlAlias = drivingPersister.getRootTableAlias( drivingSqlAlias );\n \n \t\t\tfinal LockMode effectiveLockMode = lockOptions.getEffectiveLockMode( userAlias );\n \t\t\tlocks.setAliasSpecificLockMode( sqlAlias, effectiveLockMode );\n \n \t\t\tif ( keyColumnNames != null ) {\n \t\t\t\tkeyColumnNames.put( sqlAlias, drivingPersister.getRootTableIdentifierColumnNames() );\n \t\t\t}\n \t\t}\n \n \t\t// apply the collected locks and columns\n \t\treturn dialect.applyLocksToSql( sql, locks, keyColumnNames );\n \t}",
"protected String getLockManagerName() {\n return getName();\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsInJhd0tleVZhbHVlcyI6WyIxIiwiMSJdLCJyYXdLZXlUeXBlTmFtZXMiOlsiamF2YS5sYW5nLkludGVnZXIiLCJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tMasterBEnt masterBEnt = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\t\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\t\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29tcCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAiLCJyYXdLZXlWYWx1ZXMiOlsiMSIsIjEiXSwicmF3S2V5VHlwZU5hbWVzIjpbImphdmEubGFuZy5JbnRlZ2VyIiwiamF2YS5sYW5nLkludGVnZXIiXX0\");\r\n\t\t\t\tMasterBComp masterBComp = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAuZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIiwiMSJdLCJyYXdLZXlUeXBlTmFtZXMiOlsiamF2YS5sYW5nLkludGVnZXIiLCJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> compDetailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29tcCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAubWFzdGVyQkNvbXBDb21wIiwicmF3S2V5VmFsdWVzIjpbIjEiLCIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciIsImphdmEubGFuZy5JbnRlZ2VyIl19\");\r\n\t\t\t\tMasterBCompComp masterBCompComp = PlayerManagerTest.this.manager.getBySignature(signatureBean);\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\tsignatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQkVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoibWFzdGVyQkNvbXAubWFzdGVyQkNvbXBDb21wLmRldGFpbEFFbnRDb2wiLCJyYXdLZXlWYWx1ZXMiOlsiMSIsIjEiXSwicmF3S2V5VHlwZU5hbWVzIjpbImphdmEubGFuZy5JbnRlZ2VyIiwiamF2YS5sYW5nLkludGVnZXIiXX0\");\r\n\t\t\t\tCollection<DetailAEnt> compCompDetailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\tAssert.assertThat(\"masterBEnt.getMasterBComp(), sameInstance(masterBComp)\", masterBEnt.getMasterBComp(), sameInstance(masterBComp));\r\n\t\t\t\tAssert.assertThat(\"masterBEnt.getMasterBComp().getMasterBCompComp(), sameInstance(masterBCompComp)\", masterBEnt.getMasterBComp().getMasterBCompComp(), sameInstance(masterBCompComp));\r\n\t\t\t\t\r\n\t\t\t\tAssert.assertThat(\"masterBComp.getMasterBCompComp(), sameInstance(masterBCompComp)\", masterBComp.getMasterBCompComp(), sameInstance(masterBCompComp));\r\n\t\t\t\tAssert.assertThat(\"detailAEntCol, not(sameInstance(compDetailAEntCol))\", detailAEntCol, not(sameInstance(compDetailAEntCol)));\r\n\t\t\t\tAssert.assertThat(\"detailAEntCol, not(sameInstance(compCompDetailAEntCol))\", detailAEntCol, not(sameInstance(compCompDetailAEntCol)));\r\n\t\t\t\tAssert.assertThat(\"compDetailAEntCol, not(sameInstance(compCompDetailAEntCol))\", compDetailAEntCol, not(sameInstance(compCompDetailAEntCol)));\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"protected RowLock getUpdateLockType() \n {\n\t\treturn(RowLock.RU3);\n }",
"public void setLockNum(Long lockNum) {\n this.lockNum = lockNum;\n }",
"@Override\n\tpublic List<LockRecordVo> getLockRecord(String sn) {\n\t\tLockServerApi.Iface lockServerApi =(LockServerApi.Iface) thriftClientProxy.getClient(LockServerApi.class);\n\t\tString message = null;\n\t\ttry{\n\t\t\t message = lockServerApi.getLockRecord(sn);\n\t\t}catch(Exception e){\n\t\t\te.printStackTrace();\n\t\t}\n\t\tif(message == null){\n\t\t\tthrow new RuntimeException(\"访问请求异常\");\n\t\t}\n\t\t JSONObject json = JSONObject.parseObject(message);\n\t\tif(json.getIntValue(\"code\") !=200){\n \t\tthrow new RuntimeException(\"查询锁失败\");\n \t}\n\t\tlog.info(message);\n\t\t/**\n\t\t * 取得历史记录\n\t\t * */\n\t\tList<LockRecord> lockRecordList = JSONObject.parseArray(json.getString(\"data\"), LockRecord.class);\n\t\tList<LockRecordVo> lockRecordVoList = new LinkedList<LockRecordVo>();\n\t\tif(lockRecordList !=null){\n\t\t\tlockRecordList.forEach(lockRecord -> {\n\t\t\t\tlockRecordVoList.add(new LockRecordVo(lockRecord.getSlaveId(),lockRecord.getOpenState(),lockRecord.getDealDate(),lockRecord.getVoltage(),lockRecord.getUserName()));\n\t\t\t});\n\t\t}\n\t\t\n\t\treturn lockRecordVoList;\n\t}",
"@Override\n public int getTxTimeoutInMillis() {\n return Globals.lockingTimeout;\n }",
"public interface LockDAO\n{\n /**\n * Aquire a given exclusive lock, assigning it (and any implicitly shared locks) a\n * timeout. All shared locks are implicitly taken as well.\n * <p>\n * A lock can be re-taken if it has expired and if the lock token has not changed\n * \n * @param lockQName the unique name of the lock to acquire\n * @param lockToken the potential lock token (max 36 chars)\n * @param timeToLive the time (in milliseconds) that the lock must remain \n * @return Returns <tt>true</tt> if the lock was taken, \n * otherwise <tt>false</tt>\n * @throws LockAcquisitionException on failure\n */\n void getLock(QName lockQName, String lockToken, long timeToLive);\n\n /**\n * Refresh a held lock. This is successful if the lock in question still exists\n * and if the lock token has not changed. Lock expiry does not prevent the lock\n * from being refreshed.\n * \n * @param lockQName the unique name of the lock to update\n * @param lockToken the lock token for the lock held\n * @param timeToLive the new time to live (in milliseconds)\n * @return Returns <tt>true</tt> if the lock was updated,\n * otherwise <tt>false</tt>\n * @throws LockAcquisitionException on failure\n */\n void refreshLock(QName lockQName, String lockToken, long timeToLive);\n \n /**\n * Release a lock. The lock token must still apply and all the shared and exclusive\n * locks need to still be present. Lock expiration does not prevent this operation\n * from succeeding.\n * <p>\n * Note: Failure to release a lock due to a exception condition is dealt with by\n * passing the exception out.\n * \n * @param lockQName the unique name of the lock to release\n * @param lockToken the current lock token\n * @return Returns <tt>true</tt> if all the required locks were\n * (still) held under the lock token and were\n * valid at the time of release, otherwise <tt>false</tt>\n */\n void releaseLock(QName lockQName, String lockToken);\n}",
"@Override\n public void onCreate(SQLiteDatabase db) {\n Log.e(\"zhangcy\", \"-------->AppLockDBlite onCreate\");\n db.execSQL(\"create table if not exists \" + AppLockUntil.TNAME + \"(\" + AppLockUntil.TID\n + \" integer primary key autoincrement,\" + AppLockUntil.PKGNAME + \" text,\"\n + AppLockUntil.LOCK + \" interger);\");\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompComp> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getDetailAComp().getDetailACompComp());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(\r\n\t\t\t\t\t\t\tDetailAEnt.class, \r\n\t\t\t\t\t\t\tdetailAEnt.getDetailAComp().getDetailACompComp(),\r\n\t\t\t\t\t\t\td -> d.getDetailAComp().getDetailACompComp());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompComp>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompComp> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getDetailAComp().getDetailACompComp());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(detailAEnt, d -> d.getDetailAComp());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(detailAEnt.getDetailAComp(), dc -> dc.getDetailACompComp());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompComp>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@ManyToOne\n\t@JoinColumn(name=\"LockStatus\", nullable=false)\n\t@Fetch(FetchMode.SELECT)\n\t@NotFound(action=NotFoundAction.IGNORE)\n\tpublic AccessStatus getLockStatus() {\n\t\treturn this.lockStatus;\n\t}",
"String getLockOwner();",
"public long getLockStatus() {\r\n return lockStatus;\r\n }",
"public String isLockedFor() {\n return (lockId == null ? \"\" : lockId);\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompId> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getCompId());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(DetailAEnt.class, detailAEnt.getCompId(), d -> d.getCompId());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompId>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"void addRowsLock();",
"final Object getLockObject() {\n return timeManager;\n }",
"public void setLockKey( Long lockKey ) {\n this.lockKey = lockKey;\n }",
"@Test\n\tpublic void testFuncionamentoUpdateVersionLockOtimista(){\n \n\t\tdoInTransaction( session -> {\n\t\t\tArtista roberto = session.get(Artista.class, 3L);\n\t\t\troberto.getDetalhes().setBiografia(\"Biografia alterada...\");\n\t\t\tsession.update(roberto);\n\t\t});\n\t\t \n\t}",
"@Version\r\n @Column(name=\"optlock\")\r\n public Integer getVersion()\r\n {\r\n return version;\r\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<DetailAEnt> detailAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, DetailAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.masterA.id\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.subId\")).list();\r\n\t\t\t\t\r\n\t\t\t\tList<DetailACompId> detailACompIdList = new ArrayList<>();\r\n\t\t\t\tfor (DetailAEnt detailAEnt : detailAEntList) {\r\n\t\t\t\t\tdetailACompIdList.add(detailAEnt.getCompId());\r\n\t\t\t\t\tPlayerManagerTest.this.manager.registerComponentOwner(detailAEnt, d -> d.getCompId());\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<DetailACompId>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailACompIdList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\tMasterAEnt masterAEnt = (MasterAEnt) ss.get(MasterAEnt.class, 1);\r\n\t\t\t\t//doing lazy-load\r\n\t\t\t\tmasterAEnt.getDetailAEntCol().size();\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest.this\r\n\t\t\t\t\t.manager\r\n\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\tArrayList<DetailAEnt> detailAEntCuttedCol = new ArrayList<>();\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(1));\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(2));\r\n\t\t\t\tPlayerSnapshot<Collection<DetailAEnt>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailAEntCuttedCol);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\t\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"private void demonstrateLockExpiry(final StandardJanusGraph graph, final boolean useNativeLocking, final long waitMillis) throws TemporaryLockingException, InterruptedException {\n graph.addVertex(T.label, DATABASE_METADATA_LABEL).property(VERSION_PROPERTY, VERSION_ONE);\n if(useNativeLocking) {\n System.out.println(\"regular tx one \" + getTxFromGraph(graph).toString() + \" \" + System.currentTimeMillis());\n }\n graph.tx().commit();\n\n final GraphTraversalSource g = graph.traversal();\n g.V().hasLabel(DATABASE_METADATA_LABEL).has(VERSION_PROPERTY, VERSION_ONE).property(VERSION_PROPERTY, VERSION_TWO).next();\n if(useNativeLocking) {\n System.out.println(\"regular tx two \" + getTxFromGraph(graph).toString() + \" \" + System.currentTimeMillis());\n }\n g.tx().commit();\n\n Thread.sleep(waitMillis); //wait for the lock to expire\n g.V().hasLabel(DATABASE_METADATA_LABEL).has(VERSION_PROPERTY, VERSION_TWO).property(VERSION_PROPERTY, VERSION_THREE).next();\n if(useNativeLocking) {\n System.out.println(\"regular tx three \" + getTxFromGraph(graph).toString() + \" \" + System.currentTimeMillis());\n }\n g.tx().commit();\n //END code from first code listing\n }",
"@Select({\n \"select\",\n \"JNLNO, TRANDATE, ACCOUNTDATE, CHECKTYPE, STATUS, DONETIME, FILENAME\",\n \"from B_UMB_CHECKING_LOG\",\n \"where JNLNO = #{jnlno,jdbcType=VARCHAR}\"\n })\n @Results({\n @Result(column=\"JNLNO\", property=\"jnlno\", jdbcType=JdbcType.VARCHAR, id=true),\n @Result(column=\"TRANDATE\", property=\"trandate\", jdbcType=JdbcType.VARCHAR),\n @Result(column=\"ACCOUNTDATE\", property=\"accountdate\", jdbcType=JdbcType.VARCHAR),\n @Result(column=\"CHECKTYPE\", property=\"checktype\", jdbcType=JdbcType.CHAR),\n @Result(column=\"STATUS\", property=\"status\", jdbcType=JdbcType.CHAR),\n @Result(column=\"DONETIME\", property=\"donetime\", jdbcType=JdbcType.VARCHAR),\n @Result(column=\"FILENAME\", property=\"filename\", jdbcType=JdbcType.VARCHAR)\n })\n BUMBCheckingLog selectByPrimaryKey(BUMBCheckingLogKey key);",
"public Long getLock_latency() {\n return lock_latency;\n }",
"public Long getOtherLockNum() {\n return otherLockNum;\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\tMasterAEnt masterAEnt = (MasterAEnt) ss.get(MasterAEnt.class, 1);\r\n\t\t\t\t//doing lazy-load\r\n\t\t\t\tmasterAEnt.getDetailAEntCol().size();\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest.this\r\n\t\t\t\t\t.manager\r\n\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\tArrayList<DetailAEnt> detailAEntCuttedCol = new ArrayList<>();\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(0));\r\n\t\t\t\tdetailAEntCuttedCol.add(new ArrayList<>(detailAEntCol).get(1));\r\n\t\t\t\tPlayerSnapshot<Collection<DetailAEnt>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailAEntCuttedCol);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\t\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"ManagementLockObject.Update update();",
"public BookingLockDetails getBookingLockDetails(com.kcdataservices.partners.kcdebdmnlib_hva.businessobjects.bookinglockdetails.v1.BookingLockDetails res){\n\t\tBookingLockDetails bookingLockDetails = new BookingLockDetails();\n\t\t\n\t\tbookingLockDetails.setBookingNo( res.getBookingNo() );\n\t\tbookingLockDetails.setLockId( res.getLockId() );\n\t\tbookingLockDetails.setLockMessage( res.getLockMessage() );\n\t\tif( res.isAlreadyLocked() != null ){\n\t\t\tbookingLockDetails.setAlreadyLocked( res.isAlreadyLocked().booleanValue() );\n\t\t}\n\t\tif( res.isAdmin() != null ){\n\t\t\tbookingLockDetails.setAdmin( res.isAdmin().booleanValue() );\n\t\t}\n\t\t\n\t\treturn bookingLockDetails;\n\t}",
"Lock getLock(String lockName);",
"public SystemMetadataDaoMetacatImpl(DataSource dataSource) {\n jdbcTemplate = new JdbcTemplate(dataSource);\n txManager = new DataSourceTransactionManager(dataSource);\n txTemplate = new TransactionTemplate(txManager);\n txTemplate.setIsolationLevel(TransactionDefinition.ISOLATION_READ_COMMITTED);\n }",
"public int getLockAddress() {\n\t\treturn 0;\n\t}",
"String getStartTransactionSql();",
"Boolean isConsumeLockEntity();",
"@Override\n protected String applyLocks(String sql, LockOptions lockOptions, Dialect dialect) throws QueryException {\n \t\tfinal String result;\n \t\tif ( lockOptions == null ||\n \t\t\t( lockOptions.getLockMode() == LockMode.NONE && lockOptions.getAliasLockCount() == 0 ) ) {\n \t\t\treturn sql;\n \t\t}\n \t\telse {\n \t\t\tLockOptions locks = new LockOptions();\n \t\t\tlocks.setLockMode(lockOptions.getLockMode());\n \t\t\tlocks.setTimeOut(lockOptions.getTimeOut());\n \t\t\tlocks.setScope(lockOptions.getScope());\n \t\t\tIterator iter = lockOptions.getAliasLockIterator();\n \t\t\twhile ( iter.hasNext() ) {\n \t\t\t\tMap.Entry me = ( Map.Entry ) iter.next();\n \t\t\t\tlocks.setAliasSpecificLockMode( getAliasName( ( String ) me.getKey() ), (LockMode) me.getValue() );\n \t\t\t}\n \t\t\tMap keyColumnNames = null;\n \t\t\tif ( dialect.forUpdateOfColumns() ) {\n \t\t\t\tkeyColumnNames = new HashMap();\n \t\t\t\tfor ( int i = 0; i < names.length; i++ ) {\n \t\t\t\t\tkeyColumnNames.put( names[i], persisters[i].getIdentifierColumnNames() );\n \t\t\t\t}\n \t\t\t}\n \t\t\tresult = dialect.applyLocksToSql( sql, locks, keyColumnNames );\n \t\t}\n \t\tlogQuery( queryString, result );\n \t\treturn result;\n \t}",
"@Select({\n \"select\",\n \"code, statistic_code, periods, line_code, material_type, element_type, material_requisitions, \",\n \"current_goods_in_process, last_goods_in_process, product_storage, intermediate_products_variation, \",\n \"unit_consumption\",\n \"from cost_accounting_statistic_by_line_detail\",\n \"where code = #{code,jdbcType=BIGINT}\"\n })\n @ResultMap(\"BaseResultMap\")\n CostAccountingStatisticByLineDetail selectByPrimaryKey(Long code);",
"@Test(expected=OptimisticLockException.class)\n\tpublic void testColisaoLockOtimista(){\n\t\tArtista artista = doWithSession( session -> {\n\t\t\t\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\treturn roberto;\n\t\t});\n\t\t\n\t\t// Lido e escrito pelo User B\n\t\tdoInTransaction( session -> {\n\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\troberto.getDetalhes().setBiografia(\"Biografia alterada...\");\n\t\t\tsession.update(roberto);\n\t\t});\n\t\t\n\t\t// Escrito pelo User A // javax.persistence.OptimisticLockException: -> org.hibernate.StaleStateException:\n\t\tdoInTransaction( session -> {\n\t\t\tartista.getDetalhes().setBiografia(\"Conlisão!!!\");\n\t\t\tsession.update(artista);\n\t\t});\n\t}",
"@Test(timeout = 4000)\n public void test16() throws Throwable {\n Object object0 = new Object();\n Integer integer0 = RawTransaction.LOCK_ESCALATE;\n DBColumn[] dBColumnArray0 = new DBColumn[2];\n String string0 = SQLUtil.substituteMarkers(\"create materialized view\", \"create materialized view\", integer0);\n assertEquals(\"3\", string0);\n }",
"@Override\n\tpublic LockModeType getLockMode(Object entity) {\n\t\treturn null;\n\t}",
"@Override\r\n\tpublic void addLockToken(String lt) {\n\t\t\r\n\t}",
"public String getLockUser() {\n return lockUser;\n }",
"public String getLockUserid() {\n\t\treturn lockUserid;\n\t}",
"private void RecordStoreLockFactory() {\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<MasterAEnt> masterAEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, MasterAEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"id\")).list();\r\n\t\t\t\tList<MasterAWrapper> masterAWrapperList = new ArrayList<>();\r\n\t\t\t\tfor (MasterAEnt masterAEnt : masterAEntList) {\r\n\t\t\t\t\tMasterAWrapper masterAWrapper = new MasterAWrapper();\r\n\t\t\t\t\tmasterAWrapper.setMasterA(masterAEnt);\r\n\t\t\t\t\tmasterAWrapper.setDetailAWrapperList(new ArrayList<>());\r\n\t\t\t\t\tmasterAWrapper.setDetailAEntCol(new ArrayList<>(masterAEnt.getDetailAEntCol()));\r\n\t\t\t\t\tfor (DetailAEnt detailAEnt : masterAEnt.getDetailAEntCol()) {\r\n\t\t\t\t\t\tDetailAWrapper detailAWrapper = new DetailAWrapper();\r\n\t\t\t\t\t\tdetailAWrapper.setDetailA(detailAEnt);\r\n\t\t\t\t\t\tmasterAWrapper.getDetailAWrapperList().add(detailAWrapper);\r\n\t\t\t\t\t}\r\n\t\t\t\t\tmasterAWrapperList.add(masterAWrapper);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<MasterAWrapper>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(masterAWrapperList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\t@SuppressWarnings(\"unchecked\")\r\n\t\t\t\tList<MasterBEnt> masterBEntList = \r\n\t\t\t\t\t\thbSupport.createCriteria(ss, MasterBEnt.class)\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.idA\"))\r\n\t\t\t\t\t\t\t.addOrder(OrderCompat.asc(\"compId.idB\")).list();\r\n\t\t\t\tList<Map<String, Map<String, MasterBEnt>>> masterBEntBizarreList = new ArrayList<>();\r\n\t\t\t\t\r\n\t\t\t\tfor (MasterBEnt masterB : masterBEntList) {\r\n\t\t\t\t\tSignatureBean signBean = ((IPlayerManagerImplementor) PlayerManagerTest.this.manager).generateSignature(masterB);\r\n\t\t\t\t\tString signStr = PlayerManagerTest.this.manager.serializeSignature(signBean);\r\n\t\t\t\t\tMap<String, Map<String, MasterBEnt>> mapItem = new LinkedHashMap<>();\r\n\t\t\t\t\tPlayerSnapshot<MasterBEnt> masterBPS = PlayerManagerTest.this.manager.createPlayerSnapshot(masterB);\r\n\t\t\t\t\tMap<String, MasterBEnt> mapMapItem = new LinkedHashMap<>();\r\n\t\t\t\t\tmapMapItem.put(\"wrappedSnapshot\", masterB);\r\n\t\t\t\t\tmapItem.put(signStr, mapMapItem);\r\n\t\t\t\t\tmasterBEntBizarreList.add(mapItem);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t.this\r\n\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(false));\r\n\t\t\t\t\r\n\t\t\t\tPlayerSnapshot<List<Map<String, Map<String, MasterBEnt>>>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(masterBEntBizarreList);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"@Pointcut(value = \"@annotation(lock)\", argNames = \"lock\")\n public void lockPointcut(Lock lock) {\n }",
"@Override\r\n\t\t\tpublic Object doInTransaction(TransactionStatus arg0) {\n\t\t\t\t\r\n\t\t\t\tSqlLogInspetor sqlLogInspetor = new SqlLogInspetor();\r\n\t\t\t\tsqlLogInspetor.enable();\r\n\t\t\t\t\r\n\t\t\t\tMasterAEnt masterAEnt = (MasterAEnt) ss.get(MasterAEnt.class, 1);\r\n\t\t\t\t//doing lazy-load\r\n\t\t\t\tmasterAEnt.getDetailAEntCol().size();\r\n\t\t\t\t\r\n\t\t\t\tPlayerManagerTest.this\r\n\t\t\t\t\t.manager\r\n\t\t\t\t\t.overwriteConfigurationTemporarily(\r\n\t\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t\t.clone()\r\n\t\t\t\t\t\t\t\t\t\t.configSerialiseBySignatureAllRelationship(true));\r\n\t\t\t\t\r\n\t\t\t\tSignatureBean signatureBean = PlayerManagerTest.this.manager.deserializeSignature(\"eyJjbGF6ek5hbWUiOiJvcmcuanNvbnBsYXliYWNrLnBsYXllci5oaWJlcm5hdGUuZW50aXRpZXMuTWFzdGVyQUVudCIsImlzQ29sbCI6dHJ1ZSwicHJvcGVydHlOYW1lIjoiZGV0YWlsQUVudENvbCIsInJhd0tleVZhbHVlcyI6WyIxIl0sInJhd0tleVR5cGVOYW1lcyI6WyJqYXZhLmxhbmcuSW50ZWdlciJdfQ\");\r\n\t\t\t\tCollection<DetailAEnt> detailAEntCol = PlayerManagerTest.this.manager.getBySignature(signatureBean);\r\n\t\t\t\tPlayerSnapshot<Collection<DetailAEnt>> playerSnapshot = PlayerManagerTest.this.manager.createPlayerSnapshot(detailAEntCol);\r\n\t\t\t\t\r\n\t\t\t\tFileOutputStream fos;\r\n\t\t\t\t\r\n\t\t\t\ttry {\r\n\t\t\t\t\tfos = new FileOutputStream(generatedFileResult);\r\n\t\t\t\t\tPlayerManagerTest\r\n\t\t\t\t\t\t.this\r\n\t\t\t\t\t\t\t.manager\r\n\t\t\t\t\t\t\t\t.getConfig()\r\n\t\t\t\t\t\t\t\t\t.getObjectMapper()\r\n\t\t\t\t\t\t\t\t\t\t.writerWithDefaultPrettyPrinter()\r\n\t\t\t\t\t\t\t\t\t\t\t.writeValue(fos, playerSnapshot);\r\n\t\t\t\t\t\r\n\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\tthrow new RuntimeException(\"Unexpected\", e);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tsqlLogInspetor.disable();\r\n\t\t\t\t\r\n\t\t\t\treturn null;\r\n\t\t\t}",
"public Date getLockTime() {\n\t\treturn lockTime;\n\t}",
"public interface CounterRepository extends CrudRepository<Counter,Integer> {\n\n @Query(value = \"SELECT * FROM counter c WHERE c.id = ?1 for UPDATE\",\n nativeQuery = true)\n Counter findByIdWithLock(int id);\n\n\n}",
"public Lock getLock() {\n return lock;\n }",
"interface WithOwners {\n /**\n * Specifies the owners property: The owners of the lock..\n *\n * @param owners The owners of the lock.\n * @return the next definition stage.\n */\n Update withOwners(List<ManagementLockOwner> owners);\n }",
"@Insert({\n \"insert into SWMS_stock_out_record_detail (stock_out_record_id, stock_out_record_head_id, \",\n \"stock_out_record_head_code, group_name, \",\n \"stock_in_record_account_id, material_code, \",\n \"material_batch, material_type_id, \",\n \"material_sub_type_id, material_workshop_id, \",\n \"material_name_code, material_supplier_code, \",\n \"material_name, bag_num, \",\n \"weight, measure_unit, \",\n \"created_time, completion_flag)\",\n \"values (#{stockOutRecordId,jdbcType=BIGINT}, #{stockOutRecordHeadId,jdbcType=BIGINT}, \",\n \"#{stockOutRecordHeadCode,jdbcType=BIGINT}, #{groupName,jdbcType=VARCHAR}, \",\n \"#{stockInRecordAccountId,jdbcType=BIGINT}, #{materialCode,jdbcType=VARCHAR}, \",\n \"#{materialBatch,jdbcType=VARCHAR}, #{materialTypeId,jdbcType=INTEGER}, \",\n \"#{materialSubTypeId,jdbcType=INTEGER}, #{materialWorkshopId,jdbcType=INTEGER}, \",\n \"#{materialNameCode,jdbcType=INTEGER}, #{materialSupplierCode,jdbcType=INTEGER}, \",\n \"#{materialName,jdbcType=VARCHAR}, #{bagNum,jdbcType=INTEGER}, \",\n \"#{weight,jdbcType=REAL}, #{measureUnit,jdbcType=VARCHAR}, \",\n \"#{createdTime,jdbcType=TIMESTAMP}, #{completionFlag,jdbcType=BIT})\"\n })\n @SelectKey(statement=\"SELECT LAST_INSERT_ID()\", keyProperty=\"id\", before=false, resultType=Long.class)\n int insert(SwmsStockOutRecordDetail record);",
"ManagementLockObject refresh(Context context);",
"@Override\n\tpublic void lock(Object entity, LockModeType lockMode, Map<String, Object> properties) {\n\t\t\n\t}",
"protected boolean upgradeLocks() {\n \t\treturn false;\n \t}",
"public Collection<IgniteTxEntry> optimisticLockEntries();",
"public void setLockStatus(long lockStatus) {\r\n this.lockStatus = lockStatus;\r\n }",
"@Override\n\tpublic Lock getLock() {\n\t\treturn this.lock;\n\t}",
"public LockOnChange getLockOnChangeMode(){\r\n return this.lockOnChangeMode;\r\n }",
"@Override\n public void setLockOwner(Object lockOwner) {\n }",
"@Test\n public void testFailLock() {\n if (getConnection().isNis()) {\n // TODO Workaround on Solaris NIS: there doesn't seem to be a way\n // how to handle user locks on NIS.\n log.info(\"skipping test 'testLock', as LOCK attribute is not supported by the connector on NIS.\");\n return;\n }\n try {\n getFacade().update(ObjectClass.ACCOUNT, new Uid(getUsername()),\n CollectionUtil.newSet(AttributeBuilder.build(AccountAttribute.LOCK.getName())),\n null);\n AssertJUnit\n .fail(\"passing null option to Lock should cause failure. It must have a boolean value.\");\n } catch (Exception ex) {\n // OK\n }\n try {\n getFacade().create(\n ObjectClass.ACCOUNT,\n CollectionUtil.newSet(AttributeBuilder.build(Name.NAME, \"fooconn\"),\n AttributeBuilder.buildPassword(\"foo134\".toCharArray()),\n AttributeBuilder.build(AccountAttribute.LOCK.getName())), null);\n AssertJUnit\n .fail(\"passing null option to Lock should cause failure. It must have a boolean value.\");\n } catch (Exception ex) {\n // OK\n } finally {\n try {\n getFacade().delete(ObjectClass.ACCOUNT, new Uid(\"foo134\"), null);\n } catch (Exception ex) {\n // OK\n }\n }\n }",
"public interface ManagementLockObject {\n /**\n * Gets the id property: Fully qualified resource Id for the resource.\n *\n * @return the id value.\n */\n String id();\n\n /**\n * Gets the name property: The name of the resource.\n *\n * @return the name value.\n */\n String name();\n\n /**\n * Gets the type property: The type of the resource.\n *\n * @return the type value.\n */\n String type();\n\n /**\n * Gets the level property: The level of the lock. Possible values are: NotSpecified, CanNotDelete, ReadOnly.\n * CanNotDelete means authorized users are able to read and modify the resources, but not delete. ReadOnly means\n * authorized users can only read from a resource, but they can't modify or delete it.\n *\n * @return the level value.\n */\n LockLevel level();\n\n /**\n * Gets the notes property: Notes about the lock. Maximum of 512 characters.\n *\n * @return the notes value.\n */\n String notes();\n\n /**\n * Gets the owners property: The owners of the lock.\n *\n * @return the owners value.\n */\n List<ManagementLockOwner> owners();\n\n /**\n * Gets the inner com.azure.resourcemanager.locks.fluent.models.ManagementLockObjectInner object.\n *\n * @return the inner object.\n */\n ManagementLockObjectInner innerModel();\n\n /** The entirety of the ManagementLockObject definition. */\n interface Definition\n extends DefinitionStages.Blank,\n DefinitionStages.WithResourceGroup,\n DefinitionStages.WithLevel,\n DefinitionStages.WithCreate {\n }\n /** The ManagementLockObject definition stages. */\n interface DefinitionStages {\n /** The first stage of the ManagementLockObject definition. */\n interface Blank extends WithResourceGroup {\n }\n /** The stage of the ManagementLockObject definition allowing to specify parent resource. */\n interface WithResourceGroup {\n /**\n * Specifies resourceGroupName.\n *\n * @param resourceGroupName The name of the resource group to lock.\n * @return the next definition stage.\n */\n WithLevel withExistingResourceGroup(String resourceGroupName);\n }\n /** The stage of the ManagementLockObject definition allowing to specify level. */\n interface WithLevel {\n /**\n * Specifies the level property: The level of the lock. Possible values are: NotSpecified, CanNotDelete,\n * ReadOnly. CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it..\n *\n * @param level The level of the lock. Possible values are: NotSpecified, CanNotDelete, ReadOnly.\n * CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it.\n * @return the next definition stage.\n */\n WithCreate withLevel(LockLevel level);\n }\n /**\n * The stage of the ManagementLockObject definition which contains all the minimum required properties for the\n * resource to be created, but also allows for any other optional properties to be specified.\n */\n interface WithCreate extends DefinitionStages.WithNotes, DefinitionStages.WithOwners {\n /**\n * Executes the create request.\n *\n * @return the created resource.\n */\n ManagementLockObject create();\n\n /**\n * Executes the create request.\n *\n * @param context The context to associate with this operation.\n * @return the created resource.\n */\n ManagementLockObject create(Context context);\n }\n /** The stage of the ManagementLockObject definition allowing to specify notes. */\n interface WithNotes {\n /**\n * Specifies the notes property: Notes about the lock. Maximum of 512 characters..\n *\n * @param notes Notes about the lock. Maximum of 512 characters.\n * @return the next definition stage.\n */\n WithCreate withNotes(String notes);\n }\n /** The stage of the ManagementLockObject definition allowing to specify owners. */\n interface WithOwners {\n /**\n * Specifies the owners property: The owners of the lock..\n *\n * @param owners The owners of the lock.\n * @return the next definition stage.\n */\n WithCreate withOwners(List<ManagementLockOwner> owners);\n }\n }\n /**\n * Begins update for the ManagementLockObject resource.\n *\n * @return the stage of resource update.\n */\n ManagementLockObject.Update update();\n\n /** The template for ManagementLockObject update. */\n interface Update extends UpdateStages.WithLevel, UpdateStages.WithNotes, UpdateStages.WithOwners {\n /**\n * Executes the update request.\n *\n * @return the updated resource.\n */\n ManagementLockObject apply();\n\n /**\n * Executes the update request.\n *\n * @param context The context to associate with this operation.\n * @return the updated resource.\n */\n ManagementLockObject apply(Context context);\n }\n /** The ManagementLockObject update stages. */\n interface UpdateStages {\n /** The stage of the ManagementLockObject update allowing to specify level. */\n interface WithLevel {\n /**\n * Specifies the level property: The level of the lock. Possible values are: NotSpecified, CanNotDelete,\n * ReadOnly. CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it..\n *\n * @param level The level of the lock. Possible values are: NotSpecified, CanNotDelete, ReadOnly.\n * CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it.\n * @return the next definition stage.\n */\n Update withLevel(LockLevel level);\n }\n /** The stage of the ManagementLockObject update allowing to specify notes. */\n interface WithNotes {\n /**\n * Specifies the notes property: Notes about the lock. Maximum of 512 characters..\n *\n * @param notes Notes about the lock. Maximum of 512 characters.\n * @return the next definition stage.\n */\n Update withNotes(String notes);\n }\n /** The stage of the ManagementLockObject update allowing to specify owners. */\n interface WithOwners {\n /**\n * Specifies the owners property: The owners of the lock..\n *\n * @param owners The owners of the lock.\n * @return the next definition stage.\n */\n Update withOwners(List<ManagementLockOwner> owners);\n }\n }\n /**\n * Refreshes the resource to sync with Azure.\n *\n * @return the refreshed resource.\n */\n ManagementLockObject refresh();\n\n /**\n * Refreshes the resource to sync with Azure.\n *\n * @param context The context to associate with this operation.\n * @return the refreshed resource.\n */\n ManagementLockObject refresh(Context context);\n}",
"public DBMaker disableLocking(){\n this.lockingDisabled = true;\n return this;\n }",
"@Override\n\tpublic LockThreadInfo mapRow(ResultSet rs, int rowNum) throws SQLException {\n\t\tLockThreadInfo lockThreadInfo = new LockThreadInfo(rs.getString(\"tid\"), rs.getString(\"nid\"), rs.getString(\"state\"));\n\t\treturn lockThreadInfo;\n\t}",
"public void openLock(){\n /*Code to send an unlocking signal to the physical device Gate*/\n }",
"void getLock(QName lockQName, String lockToken, long timeToLive);",
"public final OpLockDetails getOpLock() {\n\t\treturn m_oplock;\n\t}",
"CamelJpaConsumerBindingModel setConsumeLockEntity(Boolean consumeLockEntity);",
"public int getLockon() {\r\n return lockon;\r\n }",
"Miss_control_log selectByPrimaryKey(String loginuuid);",
"public Expression getWriteLockUpdateExpression(ExpressionBuilder builder, AbstractSession session) {\r\n return ExpressionMath.add(builder.getField(writeLockField.getName()), 1);\r\n }",
"@Test(expected=OptimisticLockException.class)\n\tpublic void testColisaoCamposDiferentesLockOtimista(){\n\t\t// Detached Artista (Lido pelo User A)\n\t\tArtista artista = doWithSession( session -> {\n\t\t\t\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\treturn roberto;\n\t\t});\n\t\t\n\t\t// Lido e escrito pelo User B\n\t\tdoInTransaction( session -> {\n\n\t\t\tArtista roberto = session.createNamedQuery(\"findByNome\", Artista.class)\n\t\t\t\t\t.setParameter(\"nome\", \"Roberto Carlos\")\n\t\t\t\t\t.getSingleResult(); \n\t\t\troberto.getDetalhes().setBiografia(\"Biografia alterada...\");\n\t\t\tsession.update(roberto);\n\t\t});\n\t\t\n\t\t// Escrito pelo User A // javax.persistence.OptimisticLockException: -> org.hibernate.StaleStateException:\n\t\tdoInTransaction( session -> {\n\t\t\tartista.getDetalhes().setDataNascimento(new Date());\n\t\t\tsession.update(artista);\n\t\t});\n\t}",
"protected final Object getTreeLock() {\n return Component.LOCK;\n }",
"String[] getTimeToExpirationLock(String uuid) throws DatabaseException;",
"@Override\r\n\tpublic List<PayRollLock> findpayRollLock(String processMonth) {\n\t\t\r\n\t\treturn payRollLockRepository.findpayRollLock(processMonth);\r\n\t}",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"public Integer getLockFlag() {\n return lockFlag;\n }",
"interface WithLevel {\n /**\n * Specifies the level property: The level of the lock. Possible values are: NotSpecified, CanNotDelete,\n * ReadOnly. CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it..\n *\n * @param level The level of the lock. Possible values are: NotSpecified, CanNotDelete, ReadOnly.\n * CanNotDelete means authorized users are able to read and modify the resources, but not delete.\n * ReadOnly means authorized users can only read from a resource, but they can't modify or delete it.\n * @return the next definition stage.\n */\n Update withLevel(LockLevel level);\n }"
]
| [
"0.59261245",
"0.561519",
"0.54722834",
"0.5398858",
"0.53774863",
"0.5272275",
"0.52670324",
"0.5216222",
"0.52121407",
"0.5178578",
"0.5143294",
"0.51265365",
"0.511341",
"0.50923073",
"0.50901824",
"0.50195044",
"0.5001683",
"0.49991024",
"0.49925548",
"0.4987129",
"0.49827468",
"0.49826866",
"0.49717528",
"0.49701723",
"0.49627373",
"0.49623987",
"0.49586397",
"0.49567938",
"0.4955042",
"0.49417666",
"0.49279878",
"0.49104887",
"0.48977268",
"0.48671985",
"0.4864205",
"0.48607093",
"0.48553768",
"0.4854858",
"0.4854677",
"0.4850107",
"0.48393634",
"0.48334968",
"0.48303083",
"0.4828974",
"0.48287117",
"0.48267722",
"0.48204896",
"0.48200697",
"0.48180944",
"0.47995982",
"0.47964242",
"0.47836053",
"0.4774408",
"0.4769917",
"0.47649273",
"0.47501138",
"0.4748313",
"0.47472453",
"0.47471723",
"0.47458023",
"0.47301102",
"0.47097814",
"0.47094092",
"0.47034258",
"0.4699878",
"0.46957165",
"0.46833235",
"0.467428",
"0.4673156",
"0.46707335",
"0.4669751",
"0.46618927",
"0.46590188",
"0.4657458",
"0.4647687",
"0.46351394",
"0.46334088",
"0.46279693",
"0.46215802",
"0.4617594",
"0.46157277",
"0.46009436",
"0.45968646",
"0.4596109",
"0.45951927",
"0.4589584",
"0.4577961",
"0.45687574",
"0.4567713",
"0.45673075",
"0.45625073",
"0.45472822",
"0.45374236",
"0.4535417",
"0.45320913",
"0.45275185",
"0.4526019",
"0.4525753",
"0.4525753",
"0.4525753",
"0.45108876"
]
| 0.0 | -1 |
Creates the boxes. Only creates alpha box if needed. | public ChannelPanel(boolean hasAlpha) {
this.hasAlpha = hasAlpha;
int boxCount = hasAlpha ? 4:3;
boxList = new ChannelPanelBox[boxCount];
for (int i = 0; i < boxCount; i++) {
boxList[i] = new ChannelPanelBox(i, hasAlpha);
}
moveBox = new ChannelPanelBox(4, hasAlpha);
setPreferredSize(new Dimension(50 * boxCount, 50));
ChannelPanelListener listener = new ChannelPanelListener();
addMouseListener(listener);
addMouseMotionListener(listener);
setCursor(Cursor.getPredefinedCursor(Cursor.HAND_CURSOR));
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void boxCreator(int[] pos, int width, int height) {\n for (int x = pos[0]; x < pos[0] + width; x++) {\n tiles[x][pos[1]] = Tileset.WALL;\n }\n for (int y = pos[1]; y < pos[1] + height; y++) {\n tiles[pos[0]][y] = Tileset.WALL;\n }\n for (int x = pos[0]; x < pos[0] + width; x++) {\n tiles[x][pos[1] + height] = Tileset.WALL;\n }\n for (int y = pos[1]; y < pos[1] + height + 1; y++) {\n tiles[pos[0] + width][y] = Tileset.WALL;\n }\n for (int y = pos[1] + 1; y < pos[1] + height; y++) {\n for (int x = pos[0] + 1; x < pos[0] + width; x++) {\n tiles[x][y] = Tileset.FLOWER;\n }\n }\n }",
"void addBoxObject() {\n\t\tint boxObjectX = random.nextInt(ScreenManager.getWindowWidth());\n\t\tint boxObjectY = random.nextInt(ScreenManager.getWindowHeight());\n\t\tint boxObjectWidth = ScreenManager.getSizeFromPercentageOfWindowY((float) 24);\n\t\tint boxObjectHeight = ScreenManager.getSizeFromPercentageOfWindowY(18);\n\t\tint boxObjectHitsToDestroy = random.nextInt(9)+1;\n\t\t\n\t\tboxObjects.add(new BoxObject(boxObjectX, boxObjectY, boxObjectWidth, boxObjectHeight, boxObjectHitsToDestroy, true));\n\t}",
"private static native long createEdgeBoxes_0(float alpha, float beta, float eta, float minScore, int maxBoxes, float edgeMinMag, float edgeMergeThr, float clusterMinMag, float maxAspectRatio, float minBoxArea, float gamma, float kappa);",
"private void makeCubes(int number) {\n for (int i = 0; i < number; i++) {\n // randomize 3D coordinates\n Vector3f loc = new Vector3f(\n FastMath.nextRandomInt(-20, 20),\n FastMath.nextRandomInt(-20, 20),\n FastMath.nextRandomInt(-20, 20));\n rootNode.attachChild(\n myBox(\"Cube\" + i, loc, ColorRGBA.randomColor()));\n }\n }",
"public void addBox()\n {\n if(Student.sittingRia==false) {\n box = new BoxRia(\"chalkboard.png\",4,2);\n addObject(box,box.myRow,box.mySeat);\n chalk = new BoxRia(\"chalk.png\",0,0);\n addObject(chalk,2,3);\n }\n }",
"private void generateBoxGeom()\n {\n // textures all share the same array, so process separately.\n textureBuffer = createBuffer(BOX_TEX_COORDS.length);\n textureBuffer.put(BOX_TEX_COORDS);\n textureBuffer.rewind();\n\n vertexBuffer = new FloatBuffer[6];\n normalBuffer = new FloatBuffer[6];\n\n for(int i = 0; i < 6; i++)\n {\n vertexBuffer[i] = createBuffer(12);\n normalBuffer[i] = createBuffer(12);\n }\n\n vertexBuffer[POSITIVE_X].put(RIGHT_BOX_COORDS);\n normalBuffer[POSITIVE_X].put(RIGHT_BOX_NORMALS);\n\n vertexBuffer[NEGATIVE_X].put(LEFT_BOX_COORDS);\n normalBuffer[NEGATIVE_X].put(LEFT_BOX_NORMALS);\n\n vertexBuffer[POSITIVE_Y].put(TOP_BOX_COORDS);\n normalBuffer[POSITIVE_Y].put(TOP_BOX_NORMALS);\n\n vertexBuffer[NEGATIVE_Y].put(BOTTOM_BOX_COORDS);\n normalBuffer[NEGATIVE_Y].put(BOTTOM_BOX_NORMALS);\n\n vertexBuffer[POSITIVE_Z].put(BACK_BOX_COORDS);\n normalBuffer[POSITIVE_Z].put(BACK_BOX_NORMALS);\n\n vertexBuffer[NEGATIVE_Z].put(FRONT_BOX_COORDS);\n normalBuffer[NEGATIVE_Z].put(FRONT_BOX_NORMALS);\n\n for(int i = 0; i < 6; i++)\n {\n vertexBuffer[i].rewind();\n normalBuffer[i].rewind();\n }\n }",
"private void createBoard() {\n\t// An array of rows containing rows with squares are made\n\t\tfor (int i = 0; i < squares.length; i++) {\n\t \trows[i] = new Row(squares[i]);\n\t\t}\n\n\n\t// An array of columns containing columns with squares are made\n\t\tSquare[] columnArray = new Square[size];\n\t\tfor (int i = 0; i < size; i++) {\n\t\t for (int row = 0; row < size; row++) {\n\t\t\t\tcolumnArray[row] = squares[row][i];\n\t\t }\n\t\t columns[i] = new Column(columnArray);\n\t\t columnArray = new Square[size];\n\t\t}\n\n\n\t\tSquare[] boxArray;\n\t\tint counter;\n\t\t// Box nr i\n\t\tfor (int i = 0; i < size; i = i + height) {\n\t\t // Box nr j\n\t\t for (int j = 0; j < size; j = j + length) {\n\t\t\t\tcounter = 0;\n\t\t\t\tboxArray = new Square[size];\n\t\t\t\tint rowIndex = (i / height) * height;\n\t\t\t\tint columnIndex = (j / length) * length;\n\t\t\t\t// Row nr k\n\t\t\t\tfor (int k = rowIndex; k < rowIndex + height; k++) {\n\t\t\t\t // Column nr l\n\t\t\t\t for (int l = columnIndex; l < columnIndex + length; l++) {\n\t\t\t\t\t\tboxArray[counter] = squares[k][l];\n\t\t\t\t\t\tcounter++;\n\t\t\t\t }\n\t\t\t\t}\n\t\t\t\tboxes[j/length][i/height] = new Box(boxArray);\n\t\t }\n\t\t}\t\n\t\tcreatePointers();\n }",
"private void createComponentBox() {\r\n\t\tthis.componentBox = new Vector<String>();\r\n\t\tthis.componentBox.add(\"Sword\");\r\n\t\tthis.componentBox.add(\"Two-handed Sword\");\r\n\t\tthis.componentBox.add(\"Staff\");\r\n\t\tthis.componentBox.add(\"Axe\");\r\n\t\tthis.componentBox.add(\"Hammer\");\r\n\t\tthis.componentBox.add(\"Bow\");\r\n\t\tthis.componentBox.add(\"Crossbow\");\r\n\t\tthis.componentBox.add(\"Wand\");\r\n\t\tthis.componentBox.add(\"Spear\");\r\n\t\tthis.componentBox.add(\"Bottle\");\r\n\t}",
"private void generateBoxes(int height, int length) {\n\t\tint boxId;\n\t\t\n\t\tfor (int i=0; i<squares.length; i++) {\n\t\t\tfor (int j=0; j<squares[i].length; j++) {\n\t\t\t\tboxId=j/length+((i/height)*height);\n\t\t\t\t\n\t\t\t\tif (boxes[boxId]==null)\n\t\t\t\t\tboxes[boxId]=new Box(height*length);\n\t\t\t\tboxes[boxId].add(squares[i][j]);\n\t\t\t}\n\t\t}\n\t\t\n\t\tfor (int i=0; i<boxes.length; i++) {\n\t\t\tboxes[i].setInitials();\n\t\t}\n\t}",
"public void createMinimap() {\n if (gameField.getFields().size() == 1024) {\n rootSize = 32;\n blockSize = 8;\n } else { //if size == 64^2 == 4096\n rootSize = 64;\n blockSize = 4;\n }\n int magnification = gameFieldController.getMagnification();\n if (AdvancedWarsApplication.getInstance().getGameScreenCon().base.getScene() != null) {\n positionBoxSizeX = blockSize *\n (AdvancedWarsApplication.getInstance().getGameScreenCon().base.getScene().getWidth() / (rootSize * magnification));\n\n positionBoxSizeY = blockSize *\n (AdvancedWarsApplication.getInstance().getGameScreenCon().base.getScene().getHeight() / (rootSize * magnification));\n } else {\n //for offline test\n positionBoxSizeX = (blockSize * 1920) / (rootSize * magnification);\n positionBoxSizeY = (blockSize * 1080) / (rootSize * magnification);\n }\n\n for (int i = 0; i < rootSize; ++i) {\n for (int j = 0; j < rootSize; ++j) {\n Field currentField = gameField.getFields().get(i * rootSize + j);\n Rectangle rectangle = new Rectangle(blockSize, blockSize);\n if (!currentField.getType().equals(\"Grass\")) {\n if (currentField.getType().equals(\"Water\")) {\n rectangle.setFill(Color.rgb(11, 89, 139));\n } else if (currentField.getType().equals(\"Forest\")) {\n rectangle.setFill(Color.rgb(38, 106, 0));\n } else { //if currentField equals Mountain\n rectangle.setFill(Color.rgb(95, 111, 54));\n }\n rectangle.relocate((i * blockSize) + 1, (j * blockSize) + 1);\n drawPane.getChildren().add(rectangle);\n }\n }\n }\n Rectangle rect = new Rectangle(positionBoxSizeX, positionBoxSizeY);\n Rectangle clip = new Rectangle(1, 1, positionBoxSizeX - 2, positionBoxSizeY - 2);\n positionBox = Shape.subtract(rect, clip);\n positionBox.setFill(Color.WHITE);\n drawPane.getChildren().add(positionBox);\n isCreated = true;\n }",
"@Override\r\n public void getBoxes(IPartCollisionHelper box) {\n box.addBox(4, 4, 12, 12, 12, 14);\r\n box.addBox(6, 6, 11, 10, 10, 12);\r\n }",
"private void calcBoxVerts() {\n\t\tif (verts != null) {\n\t\t\tdouble minX = verts[0].getElement(0);\n\t\t\tdouble maxX = minX;\n\t\t\tdouble minY = verts[0].getElement(1);\n\t\t\tdouble maxY = minY;\n\t\t\tdouble minZ = verts[0].getElement(2);\n\t\t\tdouble maxZ = minZ;\n\t\t\tfor (int i = 1; i < verts.length; i++) {\n\t\t\t\tif (verts[i].getElement(0) < minX) {\n\t\t\t\t\tminX = verts[i].getElement(0);\n\t\t\t\t} else if (verts[i].getElement(0) > maxX) {\n\t\t\t\t\tmaxX = verts[i].getElement(0);\n\t\t\t\t}\n\t\t\t\tif (verts[i].getElement(1) < minY) {\n\t\t\t\t\tminY = verts[i].getElement(1);\n\t\t\t\t} else if (verts[i].getElement(1) > maxY) {\n\t\t\t\t\tmaxY = verts[i].getElement(1);\n\t\t\t\t}\n\t\t\t\tif (verts[i].getElement(2) < minZ) {\n\t\t\t\t\tminZ = verts[i].getElement(2);\n\t\t\t\t} else if (verts[i].getElement(2) > maxZ) {\n\t\t\t\t\tmaxZ = verts[i].getElement(2);\n\t\t\t\t}\n\t\t\t}\n\t\t\tVector[] boxVerts = new Vector[8];\n\t\t\tboxVerts[0] = new Vector(3);\n\t\t\tboxVerts[0].setElements(new double[] {minX, minY, minZ});\n\t\t\tboxVerts[1] = new Vector(3);\n\t\t\tboxVerts[1].setElements(new double[] {maxX, minY, minZ});\n\t\t\tboxVerts[2] = new Vector(3);\n\t\t\tboxVerts[2].setElements(new double[] {minX, minY, maxZ});\n\t\t\tboxVerts[3] = new Vector(3);\n\t\t\tboxVerts[3].setElements(new double[] {maxX, minY, maxZ});\n\t\t\tboxVerts[4] = new Vector(3);\n\t\t\tboxVerts[4].setElements(new double[] {minX, maxY, minZ});\n\t\t\tboxVerts[5] = new Vector(3);\n\t\t\tboxVerts[5].setElements(new double[] {maxX, maxY, minZ});\n\t\t\tboxVerts[6] = new Vector(3);\n\t\t\tboxVerts[6].setElements(new double[] {minX, maxY, maxZ});\n\t\t\tboxVerts[7] = new Vector(3);\n\t\t\tboxVerts[7].setElements(new double[] {maxX, maxY, maxZ});\n\t\t\tthis.boxVerts = boxVerts;\n\t\t} else {\n\t\t\tthis.boxVerts = null;\n\t\t}\n\t}",
"public DrawGraphics() {\r\n box = new BouncingBox(200, 50, Color.RED);\r\n\tbox.setMovementVector(1,1);\r\n\r\n\tboxes = new ArrayList<BouncingBox>();\r\n\tboxes.add(new BouncingBox(35,40, Color.BLUE));\r\n\tboxes.get(0).setMovementVector(2,-1);\r\n\tboxes.add(new BouncingBox(120,80, Color.GREEN));\r\n\tboxes.get(1).setMovementVector(-1,2);\r\n\tboxes.add(new BouncingBox(500,80, Color.PINK));\r\n\tboxes.get(2).setMovementVector(-2,-2);\r\n }",
"public void constructBoundingBox()\r\n\t{\n\t\tdouble a = m_Qmin.x;\r\n\t\tdouble b = m_Qmin.y;\r\n\t\tdouble c = m_Qmin.z;\r\n\r\n\t\tdouble d = m_Qmax.x;\r\n\t\tdouble e = m_Qmax.y;\r\n\t\tdouble f = m_Qmax.z;\r\n\r\n\t\t//constructing the vertexes of the bounding box\r\n\t\tSceneVertex A = new SceneVertex( new Vector3d(a, b, c));\r\n\t\tSceneVertex B = new SceneVertex( new Vector3d(d, b, c));\r\n\t\tSceneVertex C = new SceneVertex( new Vector3d(d, b, f));\r\n\t\tSceneVertex D = new SceneVertex( new Vector3d(d, e, f));\r\n\t\tSceneVertex E = new SceneVertex( new Vector3d(a, e, f));\r\n\t\tSceneVertex F = new SceneVertex( new Vector3d(a, e, c));\r\n\t\tSceneVertex G = new SceneVertex( new Vector3d(d, e, c));\r\n\t\tSceneVertex H = new SceneVertex( new Vector3d(a, b, f));\r\n\r\n\r\n\t\t// building the vertices arrays for the faces\r\n\t\tArrayList<SceneVertex> verArrP0front = new ArrayList<SceneVertex>(4);\r\n\t\tverArrP0front.add(A);\r\n\t\tverArrP0front.add(B);\r\n\t\tverArrP0front.add(G);\r\n\t\tverArrP0front.add(F);\r\n\t\t\r\n\t\tArrayList<SceneVertex> verArrP1left = new ArrayList<SceneVertex>(4);\r\n\t\tverArrP1left.add(A);\r\n\t\tverArrP1left.add(F);\r\n\t\tverArrP1left.add(E);\r\n\t\tverArrP1left.add(H);\r\n\t\t\r\n\t\tArrayList<SceneVertex> verArrP2back = new ArrayList<SceneVertex>(4);\r\n\t\tverArrP2back.add(H);\r\n\t\tverArrP2back.add(C);\r\n\t\tverArrP2back.add(D);\r\n\t\tverArrP2back.add(E);\r\n\t\t\r\n\t\tArrayList<SceneVertex> verArrP3right = new ArrayList<SceneVertex>(4);\r\n\t\tverArrP3right.add(G);\r\n\t\tverArrP3right.add(D);\r\n\t\tverArrP3right.add(C);\r\n\t\tverArrP3right.add(B);\r\n\t\t\r\n\t\tArrayList<SceneVertex> verArrP4bottom = new ArrayList<SceneVertex>(4);\r\n\t\tverArrP4bottom.add(A);\r\n\t\tverArrP4bottom.add(H);\r\n\t\tverArrP4bottom.add(C);\r\n\t\tverArrP4bottom.add(B);\r\n\r\n\t\tArrayList<SceneVertex> verArrP5top = new ArrayList<SceneVertex>(4);\r\n\t\tverArrP5top.add(F);\r\n\t\tverArrP5top.add(G);\r\n\t\tverArrP5top.add(D);\r\n\t\tverArrP5top.add(E);\r\n\t\t\r\n\t\t// creating BoundingBox\r\n\t\tm_BoundingBox = new SceneNode(DrawingMode.GL_LINE, \"BoundingBox\", null);\r\n\t\tm_BoundingBox.addChild( new ScenePolygon(verArrP0front, \"FRONT\"));\r\n\t\tm_BoundingBox.addChild( new ScenePolygon(verArrP1left, \"LEFT\"));\r\n\t\tm_BoundingBox.addChild( new ScenePolygon(verArrP2back, \"BACK\"));\r\n\t\tm_BoundingBox.addChild( new ScenePolygon(verArrP3right, \"RIGHT\"));\r\n\t\tm_BoundingBox.addChild( new ScenePolygon(verArrP4bottom, \"BOTTOM\"));\r\n\t\tm_BoundingBox.addChild( new ScenePolygon(verArrP5top, \"TOP\"));\r\n\r\n\t\t\r\n\t}",
"private void createBorders() {\r\n // Upper border rectangle\r\n Rectangle topRecFrame = new Rectangle(new Point(0, 0), WITH, SIZE + 20);\r\n // Left border rectangle\r\n Rectangle leftRecFrame = new Rectangle(new Point(0, SIZE + 21), SIZE, HEIGHT);\r\n // Right border rectangle\r\n Rectangle rightRecFrame = new Rectangle(new Point(WITH - SIZE, SIZE + 21), SIZE, HEIGHT);\r\n // Rectangle for block on top of upper block for the score\r\n Rectangle topRecScore = new Rectangle(new Point(0, 0), WITH, 20);\r\n Block topScore = new Block(topRecScore, Color.LIGHT_GRAY, 0);\r\n Block topFrame = new Block(topRecFrame, Color.GRAY, 0);\r\n Block leftFrame = new Block(leftRecFrame, Color.gray, 0);\r\n Block rightFrame = new Block(rightRecFrame, Color.gray, 0);\r\n topFrame.addToGame(this);\r\n leftFrame.addToGame(this);\r\n rightFrame.addToGame(this);\r\n topScore.addToGame(this);\r\n\r\n }",
"private TransformGroup createBox(\n\t\tfloat x,\n\t\tfloat z,\n\t\tfloat size,\n\t\tfloat height,\n\t\tColor3f col) {\n\n\t\t//quadrilatere\n\t\tQuadArray quad =\n\t\t\tnew QuadArray(24, QuadArray.COORDINATES | QuadArray.COLOR_3);\n\t\tquad.setCoordinate(0, new Point3f(0.001f, height - 0.001f, 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t1,\n\t\t\tnew Point3f(size - 0.001f, height - 0.001f, 0.001f));\n\t\tquad.setCoordinate(2, new Point3f(size - 0.001f, 0.001f, 0.001f));\n\t\tquad.setCoordinate(3, new Point3f(0.001f, 0.001f, 0.001f));\n\n\t\tquad.setCoordinate(4, new Point3f(0.001f, 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t5,\n\t\t\tnew Point3f(size - 0.001f, 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t6,\n\t\t\tnew Point3f(size - 0.001f, height - 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t7,\n\t\t\tnew Point3f(0.001f, height - 0.001f, size - 0.001f));\n\n\t\tquad.setCoordinate(8, new Point3f(0.001f, 0.001f, 0.001f));\n\t\tquad.setCoordinate(9, new Point3f(0.001f, 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t10,\n\t\t\tnew Point3f(0.001f, height - 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(11, new Point3f(0.001f, height - 0.001f, 0.001f));\n\n\t\tquad.setCoordinate(\n\t\t\t12,\n\t\t\tnew Point3f(size - 0.001f, height - 0.001f, 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t13,\n\t\t\tnew Point3f(size - 0.001f, height - 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t14,\n\t\t\tnew Point3f(size - 0.001f, 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(15, new Point3f(size - 0.001f, 0.001f, 0.001f));\n\n\t\tquad.setCoordinate(16, new Point3f(size - 0.001f, 0.001f, 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t17,\n\t\t\tnew Point3f(size - 0.001f, 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(18, new Point3f(0.001f, 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(19, new Point3f(0.001f, 0.001f, 0.001f));\n\n\t\tquad.setCoordinate(20, new Point3f(0.001f, height - 0.001f, 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t21,\n\t\t\tnew Point3f(0.001f, height - 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t22,\n\t\t\tnew Point3f(size - 0.001f, height - 0.001f, size - 0.001f));\n\t\tquad.setCoordinate(\n\t\t\t23,\n\t\t\tnew Point3f(size - 0.001f, height - 0.001f, 0.001f));\n\n\t\tfor (int i = 0; i < 24; i++)\n\t\t\tquad.setColor(i, col);\n\n\t\t//dessine les aretes\n\n\t\t//quadrilatere\n\t\tQuadArray aretes =\n\t\t\tnew QuadArray(24, QuadArray.COORDINATES | QuadArray.COLOR_3);\n\t\taretes.setCoordinate(0, new Point3f(0.0f, 0.0f, 0.0f));\n\t\taretes.setCoordinate(1, new Point3f(size, 0.0f, 0.0f));\n\t\taretes.setCoordinate(2, new Point3f(size, height, 0.0f));\n\t\taretes.setCoordinate(3, new Point3f(0.0f, height, 0.0f));\n\n\t\taretes.setCoordinate(4, new Point3f(0.0f, 0.0f, size));\n\t\taretes.setCoordinate(5, new Point3f(size, 0.0f, size));\n\t\taretes.setCoordinate(6, new Point3f(size, height, size));\n\t\taretes.setCoordinate(7, new Point3f(0.0f, height, size));\n\n\t\taretes.setCoordinate(8, new Point3f(0.0f, 0.0f, 0.0f));\n\t\taretes.setCoordinate(9, new Point3f(0.0f, 0.0f, size));\n\t\taretes.setCoordinate(10, new Point3f(0.0f, height, size));\n\t\taretes.setCoordinate(11, new Point3f(0.0f, height, 0.0f));\n\n\t\taretes.setCoordinate(12, new Point3f(size, 0.0f, 0.0f));\n\t\taretes.setCoordinate(13, new Point3f(size, 0.0f, size));\n\t\taretes.setCoordinate(14, new Point3f(size, height, size));\n\t\taretes.setCoordinate(15, new Point3f(size, height, 0.0f));\n\n\t\tfor (int i = 0; i < 24; i++)\n\t\t\taretes.setColor(i, new Color3f(1f, 1f, 1f));\n\n\t\t// move the box\n\t\tTransform3D translate = new Transform3D();\n\t\ttranslate.set(new Vector3f(x, 0.0f, z));\n\n\t\tTransformGroup tg = new TransformGroup(translate);\n\n\t\t// create the box\n\t\ttg.addChild(new Shape3D(quad));\n\t\ttg.addChild(new Shape3D(aretes, lineApp()));\n\t\treturn tg;\n\t}",
"public void create() {\n\t\t// setup Chess board\n\t\tthis.removeAll();\n\t\tthis.layout = new GridLayout(this.startupBoardSize, this.startupBoardSize);\n\t\tthis.squares = new SquarePanel[this.startupBoardSize][this.startupBoardSize];\n\t\t\n\t\tsetLayout(layout);\n\t\tsetPreferredSize(new Dimension(600, 600));\n\t\tsetBorder(new LineBorder(new Color(0, 0, 0)));\n\n\t\t//paint the chess board\n\n\t\tfor (int i = 0; i < this.startupBoardSize; i++) \n\t\t{\n\t\t\tfor (int j = 0; j < this.startupBoardSize; j++) \n\t\t\t{\n\t\t\t\tsquares[i][j] = new SquarePanel(j, i);\n\t\t\t\tsquares[i][j].setPreferredSize(new Dimension(600 / this.startupBoardSize - 5, 600 / this.startupBoardSize - 5));\n\n\n\t\t\t\tsquares[i][j].setBackground(Color.WHITE);\n\t\t\t\t\n\t\t\t\tif (((i + j) % 2) == 0) \n\t\t\t\t{\n\t\t\t\t\tsquares[i][j].setBackground(Color.DARK_GRAY);\n\t\t\t\t}\n\t\t\t\tadd(squares[i][j]);\n\t\t\t}\n\t\t}\n\t}",
"private void makeLeftBox() {\n\t\tgamePanel = new JPanel();\n\t\tgamePanel.setLayout(new BorderLayout());\n\t\tgamePanel.setBackground(Color.GRAY);\n\t\tgamePanel.setOpaque(true);\n\t\tleft = new JPanel();\n\t\tleft.setLayout(new GridLayout(1,1));\n\t\tleft.setBackground(Color.GRAY);\n\t\tbanner = new JLabel(\"Jeopardy\", SwingConstants.CENTER);\n\t\tbanner.setBorder(new EmptyBorder(10,10,10,10));\n\t\tbanner.setHorizontalAlignment(SwingConstants.CENTER);\n\t\tbanner.setForeground(Color.GRAY);\n\t\tbanner.setBackground(lightRed);\n\t\tbanner.setFont(new Font(\"TimesRoman\", Font.BOLD, 30));\n\t\tbanner.setOpaque(true);\n\t\tmakeGameBoard();\n\t\t\n\t\tgamePanel.add(banner, BorderLayout.NORTH);\n\t\tgamePanel.add(board, BorderLayout.CENTER);\n\t\tleft.setOpaque(false);\n\t\tJPanel space = new JPanel();\n\t\tspace.setOpaque(false);\n\t\tgamePanel.add(space, BorderLayout.SOUTH);\n\t\tleft.add(gamePanel);\n\t\t\n\t}",
"private void setUpCollisionBox()\n {\n \txLeftOffsetCollisionBox = width/COLLISION_WIDTH_DIV;\n \tcollisionBoxHeight = height - COLLISION_BOX_H_OFFSET;\n \n \tcollisionBox = new Rectangle(\n\t\t\t\t \t\txPos, \n\t\t\t\t \t\tyPos, \n\t\t\t\t \t\t(int)width / 2,\n\t\t\t\t \t\tcollisionBoxHeight);\n }",
"private void createSwitchSpace() {\n\t\t// create constraints for switchPanel layout (required)\n\t\tGridBagConstraints constraints = new GridBagConstraints();\n\t\t\n\t\t// display the image icon for the box as empty or not depending on whether the player has already found the paper\n\t\tif (boxOpen && eventsMain.getEventsLogic().getPaperFound()) {\n\t\t\tboxImage.setIcon(switchIconEmpty);\n\t\t} else if (boxOpen && !eventsMain.getEventsLogic().getPaperFound()) {\n\t\t\tboxImage.setIcon(switchIconOpen);\n\t\t} else if (!boxOpen) {\n\t\t\tboxImage.setIcon(switchIconClosed);\n\t\t}\n\t\t\n\t\t// display the image icon as on or off depending on its current state before being clicked again\n\t\tif (eventsMain.getEventsLogic().getSwitchSetting()) {\n\t\t\tswitchImage.setIcon(switchIconOn);\n\t\t} else {\n\t\t\tswitchImage.setIcon(switchIconOff);\n\t\t}\n\t\t\n\t\t// add listeners to the container\n\t\tswitchImage.addMouseListener(eventsMain);\n\t\tboxImage.addMouseListener(eventsMain);\n\t\tboxImage.addMouseMotionListener(eventsMain);\n\t\t\n\t\t// add each image to the container\n\t\tconstraints.gridy = 0;\n\t\tswitchPanel.add(boxImage, constraints);\n\t\t\n\t\tconstraints.gridy = 1;\n\t\tswitchPanel.add(switchImage, constraints);\n\t\t\n\t\tswitchPanel.setOpaque(false);\n\t}",
"private void createRectangles() {\r\n rectangles.clear();\r\n for (int i = 0; i < gridSize * gridSize; i++) {\r\n Rectangle r = new Rectangle(rectangleSize, rectangleSize, Color.BLUE);\r\n r.setStroke(Color.BLACK);\r\n rectangles.add(r);\r\n }\r\n }",
"private VBox createBottomOrderBox() {\n\t\tVBox v = new VBox();\n\t\tVBox.setMargin(v, new Insets(5));\n\t\tv.setStyle(\"-fx-border-color: black; \"\n\t\t\t\t+ \"-fx-background-color: gainsboro\");\n\t\tLabel l1 = new Label(\"Please Check Applicable Storage Shelves\");\n\t\tv.getChildren().add(l1);\n\t\t//Iterate into lines of 5 lables and checkboxes\n\t\tfor (int i = 0; i < cf.getShelf().size(); i += 5) {\n\t\t\t\n\t\t\t/*\n\t\t\t * Create the HBox to store up to 5\n\t\t\t * CheckBoxes. Align its contents to the center.\n\t\t\t */\n\t\t\tHBox h = new HBox();\n\t\t\th.setSpacing(10);\n\t\t\tHBox.setMargin(h, new Insets(5));\n\t\t\th.setPadding(new Insets(5));\n\t\t\th.setAlignment(Pos.CENTER);\n\t\t\t/*\n\t\t\t * Decide what to iterate on:\n\t\t\t * If there are >= 5 shelves remaining, \n\t\t\t * iterate against 5. If there are less than 5 \n\t\t\t * shelves, iterate against no.Shelves remaining.\n\t\t\t * This allows blocks of 5 checkboxes and a final\n\t\t\t * dynamicly sized block for the remaining amount.\n\t\t\t */\n\t\t\tif ((cf.getShelf().size()-i) >= 5) {\n\t\t\t\t//For the next 5 StorageShelves\n\t\t\t\tfor (int j = i; j < i+5; j++) {\n\t\t\t\t\tCheckBox cb = new CheckBox();\n\t\t\t\t\t//Set the CheckBox's text to the Shelf it represents.\n\t\t\t\t\tcb.setText(cf.getShelf().get(j).getuID());\n\n\t\t\t\t\t// Add the checkbox to currentOrder's array to be referenced later.\n\t\t\t\t\tcurrentOrder.addBox(cb);\n\t\t\t\t\t\n\t\t\t\t\t//Add checkbox to Hbox for displaying\n\t\t\t\t\th.getChildren().add(cb);\n\t\t\t\t}\n\t\t\t} else if ((cf.getShelf().size()-i) < 5) {\n\t\t\t\t//For the remaining number of shelves\n\t\t\t\tfor (int j = i; j < cf.getShelf().size(); j++) {\n\t\t\t\t\tCheckBox cb = new CheckBox();\n\t\t\t\t\t//Set the CheckBox's text to the Shelf it represents.\n\t\t\t\t\tcb.setText(cf.getShelf().get(j).getuID());\n\n\t\t\t\t\t// Add the checkbox to currentOrder's array to be referenced later.\n\t\t\t\t\tcurrentOrder.addBox(cb);\n\t\t\t\t\t//Add checkbox to Hbox for displaying\n\t\t\t\t\th.getChildren().add(cb);\n\t\t\t\t}\n\t\t\t} else {\n\t\t\t\tSystem.out.println(\"OrderBox Error Found!\");\n\t\t\t\treturn null;\n\t\t\t}\n\t\t\t//Add HBox and its contents into the VBox\n\t\t\tv.getChildren().add(h);\n\t\t}\n\t\treturn v;\n\t}",
"Box(){\n System.out.println(\"constructing box\");\n width = 10;\n height = 10;\n depth = 10;\n}",
"public void createSideBlocks() {\n Fill fill = new FillColor(Color.darkGray);\n Block topB = new Block(new Rectangle(new Point(0, 0), 800, 45), fill);\n Block rightB = new Block(new Rectangle(new Point(775, 25), 25, 576), fill);\n Block leftB = new Block(new Rectangle(new Point(0, 25), 25, 576), fill);\n //add each screen-side block to game and set 1 hitpoint.\n topB.addToGame(this);\n topB.setHitPoints(1);\n rightB.addToGame(this);\n rightB.setHitPoints(1);\n leftB.addToGame(this);\n leftB.setHitPoints(1);\n }",
"private void createLevelBoxes() {\n int totalRows = (LEVELS / LEVEL_COLUMNS_PER_SCREEN) + 1;\n \n // Calculate space between each level square\n int spaceBetweenRows = (CAMERA_HEIGHT / LEVEL_ROWS_PER_SCREEN) - LEVEL_PADDING;\n int spaceBetweenColumns = (CAMERA_WIDTH / LEVEL_COLUMNS_PER_SCREEN) - LEVEL_PADDING;\n \n //Current Level Counter\n int iLevel = 1;\n //Create the Level selectors, one row at a time.\n int boxX = LEVEL_PADDING, boxY = LEVEL_PADDING;\n for (int y = 0; y < totalRows; y++) {\n for (int x = 0; x < LEVEL_COLUMNS_PER_SCREEN; x++) {\n \n //On Touch, save the clicked level in case it's a click and not a scroll.\n final int levelToLoad = iLevel;\n \n if(iLevel >= mMaxLevelReached) {\n \t dotLevel = new Sprite(boxX, boxY, resourcesManager.level_dot_red_region, vbom) {\n @Override\n public boolean onAreaTouched(final TouchEvent pSceneTouchEvent, final float pTouchAreaLocalX, final float pTouchAreaLocalY) {\n if (levelToLoad >= mMaxLevelReached)\n iLevelClicked = -1;\n else\n iLevelClicked = levelToLoad;\n return false;\n }\n };\n }\n else {\n \tdotLevel = new Sprite(boxX, boxY, resourcesManager.level_dot_green_region, vbom) {\n @Override\n public boolean onAreaTouched(final TouchEvent pSceneTouchEvent, final float pTouchAreaLocalX, final float pTouchAreaLocalY) {\n if (levelToLoad >= mMaxLevelReached)\n iLevelClicked = -1;\n else\n iLevelClicked = levelToLoad;\n return false;\n }\n };\n }\n \n this.attachChild(dotLevel);\n \n this.attachChild(new Text(boxX, boxY - 5, resourcesManager.font, String.valueOf(iLevel), vbom));\n \n \n this.registerTouchArea(dotLevel);\n \n iLevel++;\n boxX += spaceBetweenColumns + LEVEL_PADDING;\n \n if (iLevel > LEVELS)\n break;\n }\n \n if (iLevel > LEVELS)\n break;\n \n boxY += spaceBetweenRows + LEVEL_PADDING;\n boxX = 50;\n }\n }",
"public void displayInnerBoxes() {\n for (Box box : boxes)\r\n box.display();\r\n }",
"public void makeWindows()\r\n {\r\n int spacingX = random.nextInt( 3 ) + 3;\r\n int spacingY = random.nextInt( 5 ) + 3;\r\n int windowsX = random.nextInt( 3 ) + 4;\r\n int windowsY = random.nextInt( 3 ) + 5;\r\n int sizeX = ( building.getWidth() - spacingX * ( windowsX + 1 ) ) / windowsX;\r\n int sizeY = ( building.getHeight() - spacingY * ( windowsY + 1 ) ) / windowsY;\r\n \r\n \r\n for( int i = 1; i <= windowsX; i++ )\r\n {\r\n for( int k = 1; k <= windowsY; k++ )\r\n {\r\n \r\n Rectangle r = new Rectangle( building.getXLocation() + ( spacingX / 2 + spacingX * i ) + sizeX * ( i - 1 ), \r\n building.getYLocation() + ( spacingY / 2 + spacingY * k ) + sizeY * ( k - 1 ) );\r\n r.setSize( sizeX, sizeY );\r\n r.setColor( new Color( 254, 254, 34 ) );\r\n add( r );\r\n }\r\n }\r\n }",
"private Board()\r\n {\r\n this.grid = new Box[Config.GRID_SIZE][Config.GRID_SIZE];\r\n \r\n for(int i = 0; i < Config.NB_WALLS; i++)\r\n {\r\n this.initBoxes(Wall.ID);\r\n }\r\n \r\n for(int i = 0; i < Config.NB_CHAIR; i++)\r\n {\r\n this.initBoxes(Chair.ID);\r\n }\r\n \r\n for(int i = 0; i < Config.NB_PLAYER; i++)\r\n {\r\n this.initBoxes(Chair.ID);\r\n }\r\n }",
"private void createComponents() {\n\t\tbuttons = new Button[9];\r\n\t\tfor (int i = 0; i < 9; i++) {\r\n\t\t\tbuttons[i] = new Button();\r\n\t\t}\r\n\r\n\t\t// Initialize components\r\n\t\tplayAgainButton = new Button(\"Play Again\");\r\n\t\tquitButton = new Button(\"Quit\");\r\n\r\n\t\t// Initialize layouts\r\n\t\tgameButtonGrid = new GridPane();\r\n\t\tgameButtonGrid.setStyle(\"-fx-background-color:Aquamarine;\");\r\n\t\tbottomButtonsHBox = new HBox();\r\n\t\tbottomButtonsHBox.setStyle(\"-fx-background-color:LightSlateGray;\");\r\n\t\tsceneVBox = new VBox();\r\n\t\t\r\n\t\t//Game components\r\n\t\tgameInfo = new GameInfo();\r\n\t}",
"private static ArrayList<Box> generateBoxes(ArrayList<String[]> arr){\r\n ArrayList<Box> result = new ArrayList<>();\r\n for (String[] box : arr) {\r\n result.add(new Box(box));\r\n }\r\n\r\n Collections.sort(result);\r\n\r\n return result;\r\n }",
"Box()\n\t{\n\t\twidth = -1; //use -1 to indicate an uninitialized box\n\t\theight = -1;\n\t\tdepth = -1;\n\t\t\n\t\t\n\t}",
"private void setBox(){\n\t\tif((this.row >= 0 && this.row <= 2) && \n\t\t (this.column >= 0 && this.column <= 2)){\n\t\t\t\t\tthis.box = 1;\n\t\t\t\t\treturn;\n\t\t}\n\t\tif((this.row >= 0 && this.row <= 2) && \n\t\t (this.column >= 3 && this.column <= 5)){\n\t\t\t\t\tthis.box = 2;\n\t\t\t\t\treturn;\n\t\t}\n\t\tif((this.row >= 0 && this.row <= 2) && \n\t\t (this.column >= 6 && this.column <= 8)){\n\t\t\t\t\tthis.box = 3;\n\t\t\t\t\treturn;\n\t\t}\n\t\tif((this.row >= 3 && this.row <= 5) && \n\t\t (this.column >= 0 && this.column <= 2)){\n\t\t\t\t\tthis.box = 4;\n\t\t\t\t\treturn;\n\t\t}\n\t\tif((this.row >= 3 && this.row <= 5) && \n\t\t (this.column >= 3 && this.column <= 5)){\n\t\t\t\t\tthis.box = 5;\n\t\t\t\t\treturn;\n\t\t}\n\t\tif((this.row >= 3 && this.row <= 5) && \n\t\t (this.column >= 6 && this.column <= 8)){\n\t\t\t\t\tthis.box = 6;\n\t\t\t\t\treturn;\n\t\t}\n\t\tif((this.row >= 6 && this.row <= 8) && \n\t\t (this.column >= 0 && this.column <= 2)){\n\t\t\t\t\tthis.box = 7;\n\t\t\t\t\treturn;\n\t\t}\n\t\tif((this.row >= 6 && this.row <= 8) && \n\t\t (this.column >= 3 && this.column <= 5)){\n\t\t\t\t\tthis.box = 8;\n\t\t\t\t\treturn;\n\t\t}\n\t\tif((this.row >= 6 && this.row <= 8) && \n\t\t (this.column >= 6 && this.column <= 8)){\n\t\t\t\t\tthis.box = 9;\n\t\t\t\t\treturn;\n\t\t}\n\t}",
"@Test\n\tvoid testBoxCollision() {\n\t\tStage stage = new Stage();\n\t\tstage.initStage();\n\t\tstage.getCat().setX(100);\n\t\tint Y = stage.getCat().getY();\n\t\tBox box = new Box(100, Y);\n\t\tstage.getBoxes().add(box);\n\t\tstage.checkCollisions();\n\t\t\n\t\tassertEquals(2, stage.getStageOfGame());\n\t}",
"public String[] creationBox(String title, String message, String button1, String button2) {\n //isCancel is used to know if the cancel button was clicked on\n final int[] isCancel = new int[1];\n //Creating the GUI for the box\n Stage window = new Stage();\n //Ensuring that other windows cannot but used while this one is still up\n window.initModality((Modality.APPLICATION_MODAL));\n window.setTitle(title);\n\n\n //Creating and modifying the layout\n GridPane grid = new GridPane();\n grid.setPadding(new Insets(10, 10, 10, 10));\n grid.setVgap(8);\n grid.setHgap(10);\n\n //components and adding them to the layout\n Label messageToDisplay = new Label(message);\n TextField creationNameField = new TextField();\n creationNameField.setPromptText(\"Characters Not allowed:!@#$%^&*()+{}[]\\\\.\");\n Button okButton = new Button(button1);\n Button cancelButton = new Button(button2);\n grid.maxHeight(700);\n grid.maxWidth(300);\n GridPane.setConstraints(messageToDisplay, 5, 5);\n GridPane.setConstraints(creationNameField, 5, 6);\n GridPane.setConstraints(okButton, 6, 6);\n GridPane.setConstraints(cancelButton, 7, 6);\n grid.getChildren().setAll(messageToDisplay, okButton, cancelButton, creationNameField);\n\n Creations creation = new Creations();\n\n //Setting up event handlers\n cancelButton.setOnAction(e -> {\n isCancel[0] = 1;\n window.close();\n\n });\n okButton.setOnAction(e -> {\n isCancel[0] = 0;\n boolean isInvalidCharacters = creation.reggexChecker(creationNameField.getText());\n int fieldLength= creationNameField.getText().length()-1;\n String fieldInput=creationNameField.getText();\n if (creationNameField.getText() == null || creationNameField.getText().equals(\"\") || isInvalidCharacters || creationNameField.getText().length() > 20 || creationNameField.getText().trim().isEmpty() || fieldInput.charAt(fieldLength)==' ' || fieldInput.charAt(0)==' ') {\n AlertBox(\"Invalid Input\", \"Please enter a valid creation name:\\nWithout special characters, non-empty,not just a space,\\nno space at the end of the name and less than 20 characters long\\n\", 580, 100);\n } else {\n window.close();\n }\n\n });\n\n Scene scene = new Scene(grid, 580, 130);\n window.setScene(scene);\n window.setResizable(false);\n window.centerOnScreen();\n window.showAndWait();\n //Setting up the return array, which returns the boolean if the cancel button was placed and the input to the\n //textfield.\n String[] combinedOutput = new String[2];\n combinedOutput[0] = creationNameField.getText();\n combinedOutput[1] = String.valueOf(isCancel[0]);\n return combinedOutput;\n\n }",
"private void createLayers() {\n mAktieCubeLayers[kUp] = new AktieCubeLayer(AktieCubeLayer.kAxisY);\n mAktieCubeLayers[kDown] = new AktieCubeLayer(AktieCubeLayer.kAxisY);\n mAktieCubeLayers[kLeft] = new AktieCubeLayer(AktieCubeLayer.kAxisX);\n mAktieCubeLayers[kRight] = new AktieCubeLayer(AktieCubeLayer.kAxisX);\n mAktieCubeLayers[kFront] = new AktieCubeLayer(AktieCubeLayer.kAxisZ);\n mAktieCubeLayers[kBack] = new AktieCubeLayer(AktieCubeLayer.kAxisZ);\n mAktieCubeLayers[kMiddle] = new AktieCubeLayer(AktieCubeLayer.kAxisX);\n mAktieCubeLayers[kEquator] = new AktieCubeLayer(AktieCubeLayer.kAxisY);\n mAktieCubeLayers[kSide] = new AktieCubeLayer(AktieCubeLayer.kAxisZ);\n }",
"private void drawBox(Graphics window, int hsBtoRGB, int x, int y) {\n\t\t\n\t}",
"public static EdgeBoxes createEdgeBoxes(float alpha, float beta, float eta, float minScore, int maxBoxes, float edgeMinMag, float edgeMergeThr, float clusterMinMag, float maxAspectRatio, float minBoxArea, float gamma, float kappa)\r\n {\r\n \r\n EdgeBoxes retVal = EdgeBoxes.__fromPtr__(createEdgeBoxes_0(alpha, beta, eta, minScore, maxBoxes, edgeMinMag, edgeMergeThr, clusterMinMag, maxAspectRatio, minBoxArea, gamma, kappa));\r\n \r\n return retVal;\r\n }",
"@SuppressWarnings(\"unchecked\")\n private void create() {\n components.clear();\n\n if (content != null) {\n content.clearChildren();\n }\n else {\n content = new Container();\n content.setInsets(INSETS);\n }\n\n GuiComponent guiComponent = (GuiComponent) getReflectedItem().getValue();\n\n // let the user choose which type of backgroundComponent they want.\n Label label = content.addChild(new Label(\"Type\"), 0, 0);\n label.setTextHAlignment(HAlignment.Right);\n label.setInsets(INSETS);\n Container backgroundTypeContainer = content.addChild(new Container(), 0, 1);\n\n ColorRGBA oldColor = BackgroundUtils.getBackgroundColor(guiComponent);\n\n Button colorOnlyBgButton = backgroundTypeContainer.addChild(new Button(\"Color Only\"), 0, 0);\n colorOnlyBgButton.addClickCommands(source -> {\n if (!(guiComponent instanceof QuadBackgroundComponent)) {\n setValue(new QuadBackgroundComponent(oldColor));\n create();\n }\n });\n\n Button colorAndImageBgButton = backgroundTypeContainer.addChild(new Button(\"Color and Image\"), 0, 1);\n colorAndImageBgButton.addClickCommands(source -> {\n if (!(guiComponent instanceof TbtQuadBackgroundComponent)) {\n setValue(BackgroundComponents.gradient(oldColor));\n create();\n }\n });\n\n if (guiComponent instanceof QuadBackgroundComponent) {\n\n try {\n\n Method getter = QuadBackgroundComponent.class.getDeclaredMethod(\"getColor\");\n Method setter = QuadBackgroundComponent.class.getDeclaredMethod(\"setColor\", ColorRGBA.class);\n\n label = content.addChild(new Label(\"Color\"), 1, 0);\n label.setTextHAlignment(HAlignment.Right);\n label.setInsets(INSETS);\n\n ColorRGBAComponent bgColorComponent = new ColorRGBAComponent(guiComponent, getter, setter);\n content.addChild(bgColorComponent.getPanel(), 1, 1);\n components.add(bgColorComponent);\n\n // margin\n getter = QuadBackgroundComponent.class.getDeclaredMethod(\"getMargin\");\n setter = QuadBackgroundComponent.class.getDeclaredMethod(\"setMargin\", Vector2f.class);\n\n label = content.addChild(new Label(\"Margin\"), 2, 0);\n Vector2fComponent marginComponent = new Vector2fComponent(guiComponent, getter, setter);\n content.addChild(marginComponent.getPanel(), 2, 1);\n components.add(marginComponent);\n\n } catch (NoSuchMethodException e) {\n e.printStackTrace();\n }\n\n }\n else if (guiComponent instanceof TbtQuadBackgroundComponent) {\n\n TbtQuadBackgroundComponent backgroundComponent = (TbtQuadBackgroundComponent) guiComponent;\n\n try {\n Method getter = TbtQuadBackgroundComponent.class.getDeclaredMethod(\"getColor\");\n Method setter = TbtQuadBackgroundComponent.class.getDeclaredMethod(\"setColor\", ColorRGBA.class);\n\n label = content.addChild(new Label(\"Color\"), 1, 0);\n label.setTextHAlignment(HAlignment.Right);\n label.setInsets(INSETS);\n\n ColorRGBAComponent bgColorComponent = new ColorRGBAComponent(guiComponent, getter, setter);\n content.addChild(bgColorComponent.getPanel(), 1, 1);\n components.add(bgColorComponent);\n\n label = content.addChild(new Label(\"Image\"), 2, 0);\n label.setTextHAlignment(HAlignment.Right);\n label.setInsets(INSETS);\n\n Button browseImageButton = content.addChild(new Button(\"Select Background Image...\"), 2, 1);\n browseImageButton.setTextVAlignment(VAlignment.Center);\n browseImageButton.addClickCommands(source -> {\n\n JFileChooser jfc = new JFileChooser(FileSystemView.getFileSystemView().getHomeDirectory());\n jfc.setDialogTitle(\"Select a Background Image...\");\n jfc.setMultiSelectionEnabled(false);\n jfc.setFileSelectionMode(JFileChooser.FILES_ONLY);\n jfc.setAcceptAllFileFilterUsed(false);\n FileNameExtensionFilter filter = new FileNameExtensionFilter(\"PNG Images\", \"png\");\n jfc.addChoosableFileFilter(filter);\n int returnValue = jfc.showOpenDialog(null);\n\n if (returnValue == JFileChooser.APPROVE_OPTION) {\n\n File file = jfc.getSelectedFile();\n\n\n try {\n\n byte[] imageData = Files.readAllBytes(file.toPath());\n byte[] stringData = Base64.getEncoder().encode(imageData);\n\n String imageString = new String(stringData);\n\n // PanelBackground panelBackground = (PanelBackground) getReflectedProperty().getValue();\n // panelBackground.setBase64Image(imageString);\n\n Texture texture = new TextureUtils().fromBase64(imageString);\n\n backgroundComponent.setTexture(texture);\n\n\n } catch (IOException e) {\n e.printStackTrace();\n }\n }\n\n });\n\n // margin\n getter = TbtQuadBackgroundComponent.class.getDeclaredMethod(\"getMargin\");\n setter = TbtQuadBackgroundComponent.class.getDeclaredMethod(\"setMargin\", Vector2f.class);\n\n label = content.addChild(new Label(\"Margin\"), 3, 0);\n Vector2fComponent marginComponent = new Vector2fComponent(guiComponent, getter, setter);\n content.addChild(marginComponent.getPanel(), 3, 1);\n components.add(marginComponent);\n\n\n } catch (NoSuchMethodException e) {\n e.printStackTrace();\n }\n\n }\n\n//\n// this.content = new RollupPanel(\"\", contentContainer, null);\n// this.content.setOpen(false);\n//\n// // background Image\n// Container bgImageContainer = contentContainer.addChild(new Container(new SpringGridLayout(Axis.Y, Axis.X, FillMode.Last, FillMode.Last)), 0, 0);\n// Label bgImageLabel = bgImageContainer.addChild(new Label(\"Background Image\"), 0, 0);\n// bgImageLabel.setTextVAlignment(VAlignment.Center);\n// bgImageLabel.setInsets(new Insets3f(0.0F, 2.0F, 0.0F, 5.0F));\n// Button browseImageButton = bgImageContainer.addChild(new Button(\"Browse...\"), 0, 1);\n// Button removeImageButton = bgImageContainer.addChild(new Button(\"Remove\"), 0, 2);\n// bgImageContainer.addChild(new Container(), 0, 3);\n//\n// browseImageButton.addClickCommands(source -> {\n//\n// JFileChooser jfc = new JFileChooser(FileSystemView.getFileSystemView().getHomeDirectory());\n// jfc.setDialogTitle(\"Select a Background Image...\");\n// jfc.setMultiSelectionEnabled(false);\n// jfc.setFileSelectionMode(JFileChooser.FILES_ONLY);\n// jfc.setAcceptAllFileFilterUsed(false);\n// FileNameExtensionFilter filter = new FileNameExtensionFilter(\"PNG Images\", \"png\");\n// jfc.addChoosableFileFilter(filter);\n// int returnValue = jfc.showOpenDialog(null);\n//\n// if (returnValue == JFileChooser.APPROVE_OPTION) {\n//\n// File file = jfc.getSelectedFile();\n//\n// try {\n// byte[] imageData = Files.readAllBytes(file.toPath());\n// byte[] stringData = Base64.getEncoder().encode(imageData);\n//\n// String imageString = new String(stringData);\n//\n// PanelBackground panelBackground = (PanelBackground) getReflectedProperty().getValue();\n// panelBackground.setBase64Image(imageString);\n//\n// } catch (IOException e) {\n// e.printStackTrace();\n// }\n// }\n//\n// });\n//\n// removeImageButton.addClickCommands(source -> {\n// PanelBackground panelBackground = (PanelBackground) getReflectedProperty().getValue();\n// panelBackground.setBase64Image(\"\");\n// });\n//\n//\n// try {\n//\n// // color\n// Method get = PanelBackground.class.getMethod(\"getColor\");\n// Method set = PanelBackground.class.getMethod(\"setColor\", ColorRGBA.class);\n//\n// ColorRGBAComponent bgColorComponent = new ColorRGBAComponent(getReflectedProperty().getValue(), get, set);\n// bgColorComponent.setPropertyName(\"Color\");\n// contentContainer.addChild(bgColorComponent.getPanel());\n// components.add(bgColorComponent);\n//\n// // insetTop\n// get = PanelBackground.class.getMethod(\"getInsetTop\");\n// set = PanelBackground.class.getMethod(\"setInsetTop\", int.class);\n//\n// IntComponent insetTopComponent = new IntComponent(getReflectedProperty().getValue(), get, set);\n// insetTopComponent.setPropertyName(\"Inset Top\");\n// contentContainer.addChild(insetTopComponent.getPanel());\n// components.add(insetTopComponent);\n//\n// // insetLeft\n// get = PanelBackground.class.getMethod(\"getInsetLeft\");\n// set = PanelBackground.class.getMethod(\"setInsetLeft\", int.class);\n//\n// IntComponent insetLeftComponent = new IntComponent(getReflectedProperty().getValue(), get, set);\n// insetLeftComponent.setPropertyName(\"Inset Left\");\n// contentContainer.addChild(insetLeftComponent.getPanel());\n// components.add(insetLeftComponent);\n//\n// // insetBottom\n// get = PanelBackground.class.getMethod(\"getInsetBottom\");\n// set = PanelBackground.class.getMethod(\"setInsetBottom\", int.class);\n//\n// IntComponent insetBottomComponent = new IntComponent(getReflectedProperty().getValue(), get, set);\n// insetBottomComponent.setPropertyName(\"Inset Bottom\");\n// contentContainer.addChild(insetBottomComponent.getPanel());\n// components.add(insetBottomComponent);\n//\n// // insetRight\n// get = PanelBackground.class.getMethod(\"getInsetRight\");\n// set = PanelBackground.class.getMethod(\"setInsetRight\", int.class);\n//\n// IntComponent insetRightComponent = new IntComponent(getReflectedProperty().getValue(), get, set);\n// insetRightComponent.setPropertyName(\"Inset Right\");\n// contentContainer.addChild(insetRightComponent.getPanel());\n// components.add(insetRightComponent);\n//\n// // zOffset\n// get = PanelBackground.class.getMethod(\"getzOffset\");\n// set = PanelBackground.class.getMethod(\"setzOffset\", float.class);\n//\n// FloatComponent zOffsetComponent = new FloatComponent(getReflectedProperty().getValue(), get, set);\n// zOffsetComponent.setPropertyName(\"Z-Offset\");\n// contentContainer.addChild(zOffsetComponent.getPanel());\n// components.add(zOffsetComponent);\n//\n// } catch (NoSuchMethodException e) {\n// e.printStackTrace();\n// }\n\n\n }",
"protected void boxOfMortys() {\n Triple pos1, pos2, pos3, pos4, pos5, pos6, pos7, pos8, col1, col2, col3, col4;\n\n pos1 = new Triple(-10, -10, 0);\n pos2 = new Triple(110, -10, 0);\n pos3 = new Triple(110, -10, 120);\n pos4 = new Triple(-10, -10, 120);\n pos5 = new Triple(-10, 110, 0);\n pos6 = new Triple(110, 110, 0);\n pos7 = new Triple(110, 110, 120);\n pos8 = new Triple(-10, 110, 120);\n\n // Front Triangles\n frozenSoups.addTri( new Triangle(new Vertex(pos1, 0, 0),\n new Vertex(pos2, 1, 0),\n new Vertex(pos3, 1, 1),\n 22 ) );\n\n frozenSoups.addTri( new Triangle(new Vertex(pos3, 1, 1),\n new Vertex(pos4, 0, 1),\n new Vertex(pos1, 0, 0),\n 22 ) );\n\n // Left Triangles\n frozenSoups.addTri( new Triangle(new Vertex(pos1, 0, 0),\n new Vertex(pos5, 1, 0),\n new Vertex(pos8, 1, 1),\n 22 ) );\n\n frozenSoups.addTri( new Triangle(new Vertex(pos8, 1, 1),\n new Vertex(pos4, 0, 1),\n new Vertex(pos1, 0, 0),\n 22 ) );\n\n // Right Triangles\n frozenSoups.addTri( new Triangle(new Vertex(pos2, 0, 0),\n new Vertex(pos6, 1, 0),\n new Vertex(pos7, 1, 1),\n 22 ) );\n\n frozenSoups.addTri( new Triangle(new Vertex(pos7, 1, 1),\n new Vertex(pos3, 0, 1),\n new Vertex(pos2, 0, 0),\n 22 ) );\n\n // Back Triangles\n frozenSoups.addTri( new Triangle(new Vertex(pos5, 0, 0),\n new Vertex(pos6, 1, 0),\n new Vertex(pos7, 1, 1),\n 22 ) );\n\n frozenSoups.addTri( new Triangle(new Vertex(pos7, 1, 1),\n new Vertex(pos8, 0, 1),\n new Vertex(pos5, 0, 0),\n 22 ) );\n\n // Top Triangles\n// frozenSoups.addTri( new Triangle(new Vertex(pos4, 0, 0),\n// new Vertex(pos3, 0, 1),\n// new Vertex(pos7, 1, 1),\n// 20 ) );\n\n// frozenSoups.addTri( new Triangle(new Vertex(pos7, 0, 0),\n// new Vertex(pos8, 1, 0),\n// new Vertex(pos4, 1, 1),\n// 20 ) );\n }",
"Box(){\r\n Height = -1; // Used -1 to initiate an uninitialized Box. \r\n Width = -1;\r\n Depth = -1;\r\n }",
"private void drawBox(Graphics2D g2d, int y, int wid, int hei) {\n g2d.setColor(Dark_Gray);\n Triangle triangle1 = new Triangle(new Point(wid / 3, y), new Point(2 * wid / 3, y), new Point(wid / 3, y + hei / 10));\n triangle1.fill(g2d);\n g2d.setColor(Light_Gray);\n Triangle triangle2 = new Triangle(new Point(2 * wid / 3, y + hei / 10), new Point(2 * wid / 3, y), new Point(wid / 3, y + hei / 10));\n triangle2.fill(g2d);\n Triangle triangle3 = new Triangle(new Point(wid / 3, y + hei / 10), new Point(wid / 3 + 8, y + hei / 10), new Point(wid / 3 + 8, y + hei / 10 - 8));\n triangle3.fill(g2d);\n g2d.setColor(Dark_Gray);\n Triangle triangle4 = new Triangle(new Point(2 * wid / 3, y), new Point(2 * wid / 3 - 8, y), new Point(2 * wid / 3 - 8, y + 8));\n triangle4.fill(g2d);\n g2d.setColor(Color.BLACK);\n g2d.fillRect(wid / 3 + 4, y + 4, wid / 3 - 8, hei / 10 - 8);\n }",
"private void drawBox() {\n GLES20.glEnable(GLES20.GL_SCISSOR_TEST);\n GLES20.glScissor(0, 0, 100, 100);\n GLES20.glClearColor(1.0f, 0.0f, 0.0f, 1.0f);\n GLES20.glClear(GLES20.GL_COLOR_BUFFER_BIT);\n GLES20.glDisable(GLES20.GL_SCISSOR_TEST);\n }",
"void createRectangles();",
"public void createCollections() {\n \n\t\t//Creating columns for the collection\n collectionToolName = new VBox();\n collectionPurchaseDate = new VBox();\n collectionReturnButtons = new VBox();\n \n //Creating columns for the owned tools section\n ownedToolName = new VBox();\n ownedPurchaseDate = new VBox();\n ownedLendable = new VBox();\n \n collectionList.getChildren().add(collectionToolName);\n collectionList.getChildren().add(new Separator());\n collectionList.getChildren().add(collectionPurchaseDate);\n collectionList.getChildren().add(new Separator());\n collectionList.getChildren().add(collectionReturnButtons);\n \n \n ownedList.getChildren().add(ownedToolName);\n ownedList.getChildren().add(new Separator());\n ownedList.getChildren().add(ownedPurchaseDate);\n ownedList.getChildren().add(new Separator());\n ownedList.getChildren().add(ownedLendable);\n \n\t}",
"public List<Box> packThings (List<Thing> things){\n List<Box> boxes = new ArrayList<Box>();\r\n \r\n for (Thing thing : things){\r\n Box box = new Box(boxesVolume); //creates new box with specified volume\r\n box.addThing(thing); //adds things to the Box\r\n boxes.add(box); //adds box to list of boxes\r\n }\r\n \r\n return boxes;\r\n }",
"private void insert(){\r\n leftVBox.getChildren().addAll(left1HintButton,left2Button,left3Button,left4Button,left5Button,leftRestLabel);\r\n upperHBox.getChildren().addAll(upperLeftButton,upper1Label,upper2Label,upper3Label,upperRestLabel);//upperBoundLabel should not be visible since no text added to it\r\n canvasStackPane.getChildren().addAll(canvas,pane);\r\n mainVBox.getChildren().addAll(upperHBox,canvasStackPane);\r\n stackPane.getChildren().add(mainVBox);\r\n //new GameMode stuff\r\n newGamemodeHBox.getChildren().addAll(newGamemodebutton1,newGamemodebutton2,newGamemodebutton3);\r\n //Back button\r\n backPane.getChildren().add(backButton);\r\n //new GraphMode\r\n newGraphModeHBox.getChildren().addAll(newGraphModebutton1,newGraphModebutton2,newGraphModebutton3);\r\n //new Graph\r\n newGraphHBox.getChildren().addAll(newGraphButtonYes,newGraphButtonNo);\r\n gameWinHBox.getChildren().addAll(gameWinButton1,gameWinButton2);\r\n hBoxWin.getChildren().add(viewer);\r\n vBoxWin.getChildren().addAll(abstand,hBoxWin,gameWinHBox);\r\n gameWinStackPane.getChildren().add(vBoxWin);\r\n\r\n\t//add objects to Hboxes, Vboxes etc\r\n sMBHBox.getChildren().addAll(smallButton,middleButton,bigButton);\r\n textFieldHBox.getChildren().addAll(textFieldVertices,textFieldEdges,buttonTextfield);\r\n listViewVBox.getChildren().addAll(listView,submit2);\r\n gameEnd.getChildren().addAll(gameEndTop,gameEndButton);\r\n gameEndStackPane.getChildren().add(gameEnd);\r\n vBoxHint.getChildren().addAll(hintButton1,hintButton2,hintButton3);\r\n vBoxHint2.getChildren().addAll(hintButton4,hintButton5,hintButton6);\r\n vBoxHint3.getChildren().addAll(hintButton7,hintButton8,hintButton9);\r\n hintMenu.getChildren().addAll(vBoxHint,vBoxHint2,vBoxHint3);\r\n hintMenuStack.getChildren().add(hintMenu);\r\n\r\n }",
"private void create() {\n\t\tGridLayout grid = new GridLayout(3,2);\n\t\tthis.setLayout(grid);\n\t\tthis.setBackground(Color.WHITE);\n\t\t\n\t\tadd(new JLabel(\"Username/Library Card #:\", SwingConstants.LEFT), grid);\n\t\tusername.setPreferredSize(new Dimension(1, 12));\n\t\tadd(username,grid);\n\t\t\n\t\tadd(new JLabel(\"Password:\", SwingConstants.LEFT), grid);\n\t\tadd(password, grid);\n\t\t\n\t\tLoginAction();\n\t\tadd(submit, grid);\n\t}",
"private List<Box> initBoxes(List<Integer> deadBoxes){\n List<Box> boxes = new ArrayList<>();\n\n for(int x=0;x<16;x++){\n boxes.add(new Box(x + 1, grid[x]));\n }\n\n\n /**\n * 1 2 3 4\n * 5 6 7 8\n * 9 10 11 12\n * 13 14 15 16\n */\n\n //first row\n addNeighbours(1, new int[]{2,5,6}, boxes);\n addNeighbours(2,new int[]{1,3,5,6,7}, boxes);\n addNeighbours(3,new int[]{2,4,6,7,8}, boxes);\n addNeighbours(4,new int[]{3,7,8}, boxes);\n addNeighbours(5,new int[]{1,2,6,9,10}, boxes);\n addNeighbours(6,new int[]{1,2,3,5,7,9,10,11}, boxes);\n addNeighbours(7,new int[]{2,3,4,6,8,10,11,12}, boxes);\n addNeighbours(8,new int[]{3,4,7,11,12}, boxes);\n addNeighbours(9,new int[]{5,6,10,13,14}, boxes);\n addNeighbours(10,new int[]{5,6,7,9,11,13,14,15}, boxes);\n addNeighbours(11,new int[]{6,7,8,10,12,14,15,16}, boxes);\n addNeighbours(12,new int[]{7,8,11,15,16}, boxes);\n addNeighbours(13,new int[]{9,10,14}, boxes);\n addNeighbours(14,new int[]{9,10,11,13,15}, boxes);\n addNeighbours(15,new int[]{10,11,12,14,16}, boxes);\n addNeighbours(16,new int[]{11,12,15}, boxes);\n\n return removeBoxes(boxes,deadBoxes);\n }",
"BigBox(float x, float y, float w, float h, float strokeWeight, Box... littleBoxes) {\r\n super(x, y, w, h, strokeWeight);\r\n boxes = littleBoxes;\r\n shadow = new Box(x + 2.5f, y + 2.5f, w, h, 0, Colour.GREY);\r\n group();\r\n }",
"private void createGraySquares() {\n for (int x = 0; x < 16; x ++)\n for (int y = 0; y < 16; y ++)\n // If the area is not explored, creates a gray square at that point.\n if (!storage.explored[x][y]) {\n GraySquare square = new GraySquare(screen.miscAtlases.get(2));\n // Uses the x and y integers to set the corresponding position in the grid.\n square.setPosition(x * 20, y * 20 + 19);\n // Adds to the rendering list.\n squares.add(square);\n }\n }",
"private StressBox(int count, Supplier<ICube> supplier)\n {\n cubes_ = new ICube[count];\n for(int i = 0; i < count; ++i)\n {\n cubes_[i] = supplier.get();\n }\n }",
"static void createCubes(double width, double height) {\n \t\r\n \tmaxY=f(startingBound);\r\n \tmaxX=startingBound;\r\n \t\r\n \t//need a function to find the max\r\n \tfor(double i=startingBound; i<=endingBound; i=i+dx) {\r\n \t\tif(f(i)>maxY)\r\n \t\t\tmaxY=f(i);\r\n \t\t\r\n \t\tif(i>maxX)\r\n \t\t\tmaxX=i;\r\n \t}\r\n \tdouble size=height/2-100;\r\n \tSystem.out.println(size);\r\n \tscaleY=maxY/(size);\r\n \tscaleX=(width-100)/maxX;\r\n \t\r\n \tfor(double x=startingBound; x<=endingBound; x=x+dx) {\r\n \t\t//System.out.println(x+\", \"+f(x));\r\n \t\tcubes.add(new Cube(x*scaleX, -f(x)/scaleY, 0, f(x)/scaleY, dx*scaleX));\r\n \t\t//cubes.add(new Cube(x, 100, 0, 100, 100));\r\n \t}\r\n \t\r\n \t\r\n }",
"void buildRectangles(){\n background(255);\n for(int i=0;i<arr.length;i++){\n noStroke();\n Rect r=new Rect(40+i*80,400,75,-arr[i]*20,color1);\n createRectangle(r,color1);\n }\n }",
"public void makeTriangleBox(int offsetX, int offsetY, int myWidth, int myHeight, int numTriHorizontal, int numTriVertical, int collRect, float[][] verts) {\n //Top Triangles\n for (int i = 0; i < numTriHorizontal; i++) {\n verts[i][0] = (i*myWidth/numTriHorizontal) + offsetX;\n verts[i][1] = offsetY;\n verts[i][2] = ((i+1)*(myWidth/numTriHorizontal)) + offsetX;\n verts[i][3] = offsetY;\n verts[i][4] = (myWidth/(2*numTriHorizontal)) + (i*myWidth/numTriHorizontal) + offsetX;\n if(i%2==0) {\n verts[i][5] = (float) ((Math.sqrt(3) / 2) * (myWidth / numTriHorizontal)) + offsetY;\n } else {\n verts[i][5] = (float)((Math.sqrt(3) / 2) * (myWidth / numTriHorizontal)) + offsetY;\n }\n\n }\n\n //Left Triangles\n\n for (int i = numTriHorizontal; i < (numTriVertical + numTriHorizontal); i++) {\n verts[i][0] = offsetX;\n verts[i][1] = offsetY + ((i-numTriHorizontal) * (myWidth/numTriHorizontal));\n verts[i][2] = offsetX;\n verts[i][3] = offsetY + ((i-(numTriHorizontal-1)) * (myWidth/numTriHorizontal));\n if(i%2==0) {\n verts[i][4] = offsetX + (float) ((Math.sqrt(3) / 2) * (myWidth / numTriHorizontal));\n } else {\n verts[i][4] = offsetX + (float) ((Math.sqrt(3) / 2) * (myWidth / numTriHorizontal));\n }\n verts[i][5] = offsetY + ((i-numTriHorizontal) * (myWidth/numTriHorizontal)) + myWidth/(2*numTriHorizontal);\n\n }\n\n\n //Right Triangles\n for(int i=numTriVertical+numTriHorizontal; i<(2*numTriVertical)+numTriHorizontal; i++) {\n verts[i][0] = width-offsetX;\n verts[i][1] = offsetY + ((i-(numTriVertical+numTriHorizontal)) * (myWidth/numTriHorizontal));\n verts[i][2] = width-offsetX;\n verts[i][3] = offsetY + ((i-(numTriVertical+(numTriHorizontal-1))) * (myWidth/numTriHorizontal));\n if(i%2==0) {\n verts[i][4] = width-(offsetX + (float) ((Math.sqrt(3) / 2) * (myWidth / numTriHorizontal)));\n } else {\n verts[i][4] = width-(offsetX + (float) ((Math.sqrt(3) / 2) * (myWidth / numTriHorizontal)));\n }\n verts[i][5] = offsetY + ((i-(numTriVertical+numTriHorizontal)) * (myWidth/numTriHorizontal)) + myWidth/(2*numTriHorizontal);\n\n }\n\n //Bottom Triangles\n for(int i=(2*numTriVertical)+numTriHorizontal; i<(2*numTriVertical)+(2*numTriHorizontal); i++) {\n verts[i][0] = ((i-((2*numTriVertical)+numTriHorizontal))*myWidth/numTriHorizontal) + offsetX;\n verts[i][1] = (height-100) - offsetY;\n verts[i][2] = ((i-((2*numTriVertical)+numTriHorizontal) +1)*(myWidth/numTriHorizontal)) + offsetX;\n verts[i][3] = (height-100) - offsetY;\n verts[i][4] = (myWidth/(2*numTriHorizontal)) + ((i-((2*numTriVertical)+numTriHorizontal))*myWidth/numTriHorizontal) + offsetX;\n if(i%2==0) {\n verts[i][5] = (float)((height-100) - ( ((Math.sqrt(3) / 2) * (myWidth / numTriHorizontal)) + offsetY));\n } else {\n verts[i][5] = (float)((height-100) - ( ((Math.sqrt(3) / 2) * (myWidth / numTriHorizontal)) + offsetY));\n }\n\n }\n\n }",
"public Box()\n\t{\n\t\t\n\t\ttopLeftX = 50;\n\t\ttopLeftY = 50;\n\t\twidth = 50;\n\t\theight = 25;\n\t\t\n\t}",
"public static void main(String[] args) {\n int[] boxcap = {100,100,50,200,250};\n int[] items = {10,25,50,50,30,30,50,40,10,50,10,50,40};\n int i, j;\n\n // // create boxes\n // Box[] boxes = new Box[boxcap.length];\n // for (i = 0; i <= boxcap.length; i++) {\n // try{\n // boxes[i] = new Box(boxcap[i]);\n // throw new BoxFullException(\"Array Index Out of Bounds Exception!\");\n // //boxes[i] = new Box(boxcap[i]);\n //\n // } catch (BoxFullException e){\n // System.out.println(\"Caught Exception in method: \"+e);\n //\n // }\n // }\n\n\n // create boxes\n \tBox[] boxes = new Box[boxcap.length];\n \tfor (i = 0; i <= boxcap.length; i++) {\n try {\n \t boxes[i] = new Box(boxcap[i]);\n } catch (ArrayIndexOutOfBoundsException e){\n System.out.println(\"Caught exception in main: \"+e);\n }\n \t}\n\n // add items to boxes\n i = 0; // box index\n j = 0; // item index\n try{\n while (j < items.length) {\n boxes[i].add(items[j]);\n j++;\n }\n }catch (BoxFullException e){\n System.out.println(\"Caught exception in WHILE: \"+e);\n }\n\n\n // print items in boxes\n for (i = 0; i < boxes.length; i++) {\n for (j = 0; j < items.length; j++) {\n try{\n System.out.printf(\"Box %d item %d: size %d.\\n\",\n i,j,boxes[i].getItem(j));\n } catch (IndexOutOfBoundsException e){\n System.out.println(\"Caught exception in PRINT BOX: \"+e);\n\n\n }\n }\n }\n }",
"public void initProductionSpaces(){\n\n if (productionSpaces != null){\n for(int i = 0;i<3;i++){\n if (productionSpaces[i] != null)\n this.remove(productionSpaces[i]);\n }\n }\n\n productionSpaces = new JLayeredPane[3];\n productionCards = new JLabel[3][3];\n for(int i = 0;i<3;i++){\n productionSpaces[i] = new JLayeredPane();\n\n productionSpaces[i].setSize(psWidth,psHeight);\n productionSpaces[i].setBounds(psx[i],psy,psWidth,psHeight);\n\n //productionSpaces[i].setBackground(Color.WHITE);\n productionSpaces[i].setOpaque(false);\n add(productionSpaces[i]);\n\n }\n\n }",
"static JPanel createContainers()\n\t{\n\t\tscore.setFont(new Font(\"Arial\", 0, 14));\n\t\tscore.setForeground(Color.RED);\n\n\t\tJPanel mainPanel = createMainPanel();\n\t\tmainPanel.setBackground(Color.black);\n\t\tJPanel scoringPanel = createScoringPanel(score);\n\t\tJPanel gamePanel = createGamePanel();\n\n\t\tPortfolio1.gameCards = Portfolio1.createGameCards();\n\n\t\tfor (GameCard card : Portfolio1.gameCards)\n\t\t{\n\t\t\tgamePanel.add(card);\n\t\t}\n\n\t\tmainPanel.add(Box.createVerticalStrut(25));\n\t\tmainPanel.add(scoringPanel);\n\t\tmainPanel.add(Box.createVerticalStrut(25));\n\t\tmainPanel.add(gamePanel);\n\n\t\treturn mainPanel;\n\t}",
"private void makeControls() {\n Label label1 = new Label(\"Placement:\");\n textField = new TextField ();\n textField.setPrefWidth(300);\n\n // Task8 Start the game with the randomly selected piece placement\n textField.setText(\"AAO\");\n makePlacement(\"AAO\");\n\n Button button = new Button(\"Refresh\");\n button.setOnAction(new EventHandler<ActionEvent>() {\n @Override\n public void handle(ActionEvent e) {\n makePlacement(textField.getText());\n // Task8 Do not clear the textField in order to place pieces step by step.\n // textField.clear();\n }\n });\n HBox hb = new HBox();\n hb.getChildren().addAll(label1, textField, button);\n hb.setSpacing(10);\n hb.setLayoutX(130);\n hb.setLayoutY(VIEWER_HEIGHT - 50);\n controls.getChildren().add(hb);\n }",
"private BioMightBoundBoxes setupDefaultBoundBoxes() \r\n\t{\r\n\t\t// Set up the collection to hold the Bounding Boxes\r\n\t\tBioMightBoundBoxes bioBoundBoxes = null;\r\n\t\r\n\t\t// Initialize the position of the bounding box vars\r\n\t\tBigDecimal xPos = new BigDecimal(0.0);\r\n\t\tBigDecimal yPos = new BigDecimal(0.0);\r\n\t\tBigDecimal zPos= new BigDecimal(0.0);\r\n\t\t\r\n\t\t// Set to base 1x1x1 cube\r\n\t\tBigDecimal xVector= new BigDecimal(1.0);\r\n\t\tBigDecimal yVector= new BigDecimal(1.0); \r\n\t\tBigDecimal zVector= new BigDecimal(1.0);\r\n\t\r\n\t\t// Initialize a BoundBox\r\n\t\tBioMightBoundBox bioBoundBox = null;\r\n\t\r\n\t\t// Initialize Connectors \r\n\t\tBioMightConnectors bioMightConnectors = null; \r\n\r\n\t\t// Initialize a Connector \r\n\t\tBioMightConnector bioMightConnector= null;\r\n\t\r\n\t\tdouble circumference = 0.0;\r\n\t\tdouble[] startPos = {0.0, 0.0, 0.0};\r\n\t\tdouble[][] startPoints = null;\r\n\t\r\n\t\t//********************************************************************* \r\n\t\t// LEFT FOOT BOUNDBOX\r\n\t\t// Set up the Bounding Box for the Feet\r\n\t\t// The connector for this will come from the incoming Bound Box\r\n\t\t// Both are defined like and bolt and they lock into position at the\r\n\t\t// interestion of both connectors\r\n\t\t//**********************************************************************\r\n\t\txPos = new BigDecimal(0.0);\r\n\t\tyPos = new BigDecimal(-65.0);\r\n\t\tzPos= new BigDecimal(3.0);\r\n\t\r\n\t\txVector= new BigDecimal(1.0);\r\n\t\tyVector= new BigDecimal(4.0); \r\n\t\tzVector= new BigDecimal(1.0);\r\n\r\n\t\tbioBoundBox = new BioMightBoundBox(xPos, yPos, zPos, xVector, yVector, zVector);\r\n\t\tbioMightConnectors = new BioMightConnectors();\r\n\t\r\n\t\t// Feet Epithelium Connector\r\n\t\tcircumference = 0.3;\r\n\t\tstartPos = getStartPoints(-2.0, -65.0, -1.0);\r\n\t\tstartPoints = BioGraphics.octogonYPlane(startPos, circumference);\r\n\t\tbioMightConnector = new BioMightConnector(startPoints, Constants.FootEpitheliumRef,\"connType\");\r\n\t\tbioMightConnectors.setBioMightConnector(Constants.FootEpitheliumRef, bioMightConnector);\r\n\t\t\r\n\t\t// Associate the connector on the Box\r\n\t\tbioBoundBox.setBioMightConnectors(bioMightConnectors);\r\n\t\t\r\n\t\t// Put the Bounding Box in the collection\r\n\t\tbioBoundBoxes.setBoundingBox(Constants.LeftFootRef, bioBoundBox);\r\n\t\r\n\t\r\n\t\t//********************************************************************* er\r\n\t\t// RIGHT CNEMES BOUNDBOX\r\n\t\t// Set up the Bounding Box for the Foot\r\n\t\t// On a porportioned human, the \r\n\t\t//**********************************************************************\r\n\t\txPos = new BigDecimal(0.0);\r\n\t\tyPos = new BigDecimal(-14.0);\r\n\t\tzPos= new BigDecimal(-3.0);\r\n\t\r\n\t\txVector= new BigDecimal(1.0);\r\n\t\tyVector= new BigDecimal(4.0); \r\n\t\tzVector= new BigDecimal(1.0);\r\n\r\n\t\tbioBoundBox = new BioMightBoundBox(xPos, yPos, zPos, xVector, yVector, zVector);\r\n\t\tbioMightConnectors = new BioMightConnectors();\r\n\t\t\r\n\t\t// Foot Epithelium Connector\r\n\t\tcircumference = 0.3;\r\n\t\tstartPos = getStartPoints(2.0, -65.0, -1.0);\r\n\t\tstartPoints = BioGraphics.octogonYPlane(startPos, circumference);\r\n\t\tbioMightConnector = new BioMightConnector(startPoints, Constants.FootEpitheliumRef,\"connType\");\r\n\t\tbioMightConnectors.setBioMightConnector(Constants.FootEpitheliumRef, bioMightConnector);\r\n\t\r\n\t\t// Associate the connector on the Box\r\n\t\tbioBoundBox.setBioMightConnectors(bioMightConnectors);\r\n\t\t\r\n\t\t// Put the Bounding Box in the collection\r\n\t\tbioBoundBoxes.setBoundingBox(Constants.RightFootRef, bioBoundBox);\r\n\t\r\n\t\t// return the collection that holds both foot bound boxes\r\n\t\treturn (bioBoundBoxes);\r\n\t}",
"public void preSetup(){\n // Any of your pre setup before the loop starts should go here\n \n // border\n blocks[0] = new Rectangle(0, 0, 25, 600);\n blocks[1] = new Rectangle(775, 0, 25, 600);\n blocks[2] = new Rectangle(0, 0, 800, 25);\n blocks[3] = new Rectangle(0, 575, 800, 25);\n \n // starting room\n // right wall\n blocks[5] = new Rectangle(WIDTH / 2 + 75, 400, 25, 150);\n // left wall\n blocks[10] = new Rectangle(WIDTH / 2 - 100, 400, 25, 150);\n // centre\n blocks[7] = new Rectangle(WIDTH / 2 - 10, 450, 20, 150);\n // top wall\n blocks[11] = new Rectangle(WIDTH / 2 - 50, 400, 100, 25);\n \n \n // remember to copy to the other side\n // cover (west)\n blocks[4] = new Rectangle(200, 200, 25, 75);\n blocks[6] = new Rectangle(200 , 400, 25, 75);\n blocks[8] = new Rectangle(200, 310, 25, 50);\n blocks[9] = new Rectangle(200, 0, 25, 170);\n blocks[17] = new Rectangle(200 - 50, 145, 70, 25);\n blocks[23] = new Rectangle(0, 60, 100, 24);\n blocks[24] = new Rectangle(70, 500, 24, 100);\n blocks[25] = new Rectangle(70, 500, 80, 24);\n blocks[26] = new Rectangle();\n \n \n // cover (east)\n blocks[15] = new Rectangle(WIDTH - 225, 200, 25, 75);\n blocks[14] = new Rectangle(WIDTH - 225 , 400, 25, 75);\n blocks[13] = new Rectangle(WIDTH - 225, 310, 25, 50);\n blocks[12] = new Rectangle(WIDTH - 225, 0, 25, 170);\n blocks[16] = new Rectangle(WIDTH - 225, 145, 70, 25);\n blocks[27] = new Rectangle(WIDTH - 100, 60, 100, 24);\n blocks[28] = new Rectangle(WIDTH - 94, 500, 24, 100);\n blocks[29] = new Rectangle(WIDTH - 94 - (80-24), 500, 80, 24);\n blocks[30] = new Rectangle();\n \n // cover (middle)\n // vertical\n blocks[18] = new Rectangle(WIDTH/ 2 - 10, 150, 20, 125);\n blocks[22] = new Rectangle(WIDTH/ 2 - 10, 300, 20, 50);\n // horizontal\n blocks[19] = new Rectangle(WIDTH/ 2 - 100, 175, 200, 20);\n blocks[20] = new Rectangle(WIDTH/ 2 - 100, 225, 200, 20);\n blocks[21] = new Rectangle(WIDTH/ 2 - 100, 350, 200, 20);\n \n \n // extras\n blocks[31] = new Rectangle();\n blocks[32] = new Rectangle();\n \n // flag on the level\n flag[0] = new Rectangle((int)(Math.random()*((WIDTH - 40) - 40 + 1)) + 40, (int)(Math.random()*((HEIGHT - 40) - 40 + 1)) + 40, 35, 26);\n flagPole[0] = new Rectangle(flag[0].x, flag[0].y, 4, 45);\n flagLogo[0] = new Rectangle(flag[0].x + 15, flag[0].y + (13/2), 20, 15);\n \n }",
"private void builder(){\r\n //Objects\r\n //Left\r\n canvasStackPane.setAlignment(Pos.TOP_LEFT);\r\n left1HintButton = new Button(\"Hint\");\r\n left2Button = new Button(\"New Graph\");\r\n left3Button = new Button(\"New GameMode\");\r\n left4Button = new Button(\"New GraphMode\");\r\n left5Button = new Button(\"Finished\");\r\n leftRestLabel = new Label();\r\n //Up\r\n upperLeftButton = new Label(\"Menu\");\r\n upperLeftButton.setAlignment(Pos.CENTER);\r\n upper1Label = new Label();\r\n upper2Label = new Label();\r\n upper3Label = new Label();\r\n upperRestLabel = new Label();\r\n //calculateVectors\r\n backPane.setPickOnBounds(false);\r\n textFieldVertices.setPromptText(\"Vertices\");\r\n textFieldEdges.setPromptText(\"Edges\");\r\n gameEnd.setSpacing(30);\r\n gameEnd.setAlignment(Pos.CENTER);\r\n gameWinStackPane.setAlignment(Pos.CENTER);\r\n hBoxWin.setAlignment(Pos.CENTER);\r\n hBoxWin.setSpacing(30);\r\n canvasStackPane.setPickOnBounds(true);\r\n canvas.setPickOnBounds(true);\r\n canvas.getGraphicsContext2D().setLineWidth(2.5);\r\n }",
"private Parent createSetGame(){\n\n BorderPane setGame = new BorderPane(); //create BorderPane for the root\n setGame.setPrefSize(1200, 900);\n\n Label user = new Label(\"User\");\n Label computer = new Label(\"Computer\");\n\n VBox vert1 = vertNum();\n VBox vert2 = vertNum();\n\n HBox hor1 = horNum();\n HBox hor2 = horNum();\n\n Label row = new Label(\"Row\");\n Label column = new Label(\"Column\");\n Label direction = new Label(\"Direction\");\n Label table = new Label(\"Prepare Your Table!\");\n Button submit = new Button(\"Submit\");\n Text isOccupied = new Text(); //prints message if position is already occupied\n Text pieceName = new Text(); //prints out the piece name for the user to enter\n\n TextField rows = new TextField();\n TextField columns = new TextField();\n ToggleButton vertical = new ToggleButton(\"Vertical\");\n ToggleButton horizontal = new ToggleButton(\"Horizontal\");\n nextScene.setDisable(true);\n\n //let the user choose the direction of the game pieces to be places on the board\n ToggleGroup group = new ToggleGroup();\n vertical.setToggleGroup(group);\n horizontal.setToggleGroup(group);\n vertical.setSelected(true);\n\n HBox hbox1 = new HBox(500, user, computer);\n\n HBox hbox3 = new HBox(40, vert1, humanBoard);\n HBox hbox4 = new HBox(40, vert2, computerBoard);\n\n VBox human = new VBox(40, hor1, hbox3);\n VBox comp = new VBox(40, hor2, hbox4);\n\n HBox sidebyside = new HBox(100, human, comp);\n\n hbox1.setAlignment(Pos.CENTER);\n hor1.setAlignment(Pos.CENTER);\n hor2.setAlignment(Pos.CENTER);\n human.setAlignment(Pos.CENTER);\n comp.setAlignment(Pos.CENTER);\n sidebyside.setAlignment(Pos.CENTER);\n\n\n\n HBox input1 = new HBox(10, row, rows);\n HBox input2 = new HBox(10, column, columns);\n HBox input3 = new HBox(10, direction, vertical, horizontal);\n HBox input = new HBox(50, input1, input2, input3, submit);\n\n //print the name of the first piece: Carrot\n pieceName.setText(arr[piece].getName());\n\n submit.setOnAction(e -> {\n\n try { //catch if input is not a number\n\n int y = Integer.parseInt(rows.getText());\n int x = Integer.parseInt(columns.getText());\n\n if (vertical.isSelected()) { //if toggle is vertical\n arr[piece].setDirection(\"VERTICAL\");\n\n } else if (horizontal.isSelected()) { //if toggle is horizontal\n arr[piece].setDirection(\"HORIZONTAL\");\n }\n\n\n try { //catch if input is out of range\n\n if (!humanBoard.setPiece(x, y, arr[piece].getDirection(), arr[piece])) { //if attack was not successful, print message\n isOccupied.setText(\"Invalid Location\");\n } else {\n isOccupied.setText(\"\"); //else print nothing\n piece++; //increment index\n if (piece < 4) {\n pieceName.setText(arr[piece].getName()); //print piece name\n }\n }\n } catch (IndexOutOfBoundsException err) { //print message if out of range\n isOccupied.setText(\"Invalid Location\");\n }\n if (piece == 4) { //if final piece, disable submit and enable nextScene for the user to start the game\n submit.setDisable(true);\n vertical.setDisable(true);\n horizontal.setDisable(true);\n rows.setDisable(true);\n columns.setDisable(true);\n piece = 0;\n nextScene.setDisable(false);\n\n }\n }\n catch (NumberFormatException e1) { //print message if input is not a number\n isOccupied.setText(\"Invalid Location\");\n }\n });\n\n\n input1.setAlignment(Pos.CENTER);\n input2.setAlignment(Pos.CENTER);\n input.setAlignment(Pos.CENTER);\n\n HBox buttons = new HBox(40, nextScene, exit);\n\n buttons.setAlignment(Pos.CENTER);\n\n setGame.setStyle(\"-fx-background-color: #B5D3E7\");\n\n VBox vbox = new VBox(30, table, hbox1, sidebyside, pieceName, input, buttons, isOccupied);\n vbox.setAlignment(Pos.CENTER);\n setGame.setCenter(vbox);\n return setGame; //return root\n }",
"private Parent createGame() {\n\n nextScene.setDisable(true); //disable the button. prevent user from switching scenes\n\n //set the computer pieces using random coordinates generator\n int loop = 0; //index. Increment only if setting the piece was successful\n while(loop != 4) {\n try { //check if it goes out of bounds\n int CX = ((int) (Math.random() * (10)) - 0); //random from 0 to 9\n int CY = ((int) (Math.random() * (10)) - 0); //random from 0 to 9\n int rand = ((int) (Math.random() * (5)) - 0); //random from 0 to 5\n String CDIR = direc[rand]; //add random direction\n if (CDIR == \"VERTICAL\") { //if vertical\n arr1[loop].setDirection(\"VERTICAL\"); //sets direction vertical\n\n } else if (CDIR == \"HORIZONTAL\") { //if horizontal\n arr1[loop].setDirection(\"HORIZONTAL\"); //sets direction to horizontal\n }\n if (computerBoard.setPiece(CX, CY, arr1[loop].getDirection(), arr1[loop])) { //sets the piece on board\n loop++; //if successful increment\n }\n }\n catch(IndexOutOfBoundsException err1) { //catch if out of index\n continue; //continue --> try different coordinates until setting piece is successful\n }\n }\n\n BorderPane game = new BorderPane(); //create new BorderPane root\n game.setPrefSize(1200, 900); //set resolution\n\n Label user = new Label(\"User\"); //user label\n Label computer = new Label(\"Computer\"); //computer label\n\n VBox vert1 = vertNum(); //get vertical grid label\n VBox vert2 = vertNum();\n\n HBox hor1 = horNum(); //get horizontal grid label\n HBox hor2 = horNum();\n\n Label row = new Label(\"Row\"); //Row\n Label column = new Label(\"Column\"); //Column\n Button submit = new Button(\"Submit\"); //Submit coordinates\n Text Miss = new Text(); //text used to print if user missed\n Text isWin = new Text(); //text used to print if user/computer won\n\n TextField rows = new TextField(); //rows input\n TextField columns = new TextField(); //columns input\n\n HBox hbox1 = new HBox(500, user, computer); //put user and computer label in HBox\n\n //add number labels with the board grid\n HBox hbox3 = new HBox(40, vert1, humanBoard);\n HBox hbox4 = new HBox(40, vert2, computerBoard);\n\n //put them in VBox\n VBox human = new VBox(40, hor1, hbox3);\n VBox comp = new VBox(40, hor2, hbox4);\n\n //then put then in HBox side by side\n HBox sidebyside = new HBox(100, human, comp);\n\n //center align all grids present\n hbox1.setAlignment(Pos.CENTER);\n hor1.setAlignment(Pos.CENTER);\n hor2.setAlignment(Pos.CENTER);\n human.setAlignment(Pos.CENTER);\n comp.setAlignment(Pos.CENTER);\n sidebyside.setAlignment(Pos.CENTER);\n\n //put all input together\n HBox input1 = new HBox(10, row, rows);\n HBox input2 = new HBox(10, column, columns);\n HBox input = new HBox(50, input1, input2, submit);\n\n //event handle for submit button\n submit.setOnAction(e -> {\n int turn = 1; //turns between computer and player. 1 = player 0 = computer.\n if(humanBoard.getAddPiece() != 0 && turn == 1) { //if user didn't lose all his pieces, game keeps going.\n try { //catch non-numeric input\n try { //catch out of bounds input\n int y, x, attack; //x > rows, y > cols, attack > return value. 1 > hit, 2 > already guess, 3 > missed, 0 > program failure\n y = Integer.parseInt(rows.getText()); //convert text into int\n x = Integer.parseInt(columns.getText());\n attack = humanBoard.attack(x, y, computerBoard); //perform the attack\n if (attack == 3) { //missed\n Miss.setText(\"Miss!\");\n turn = 0;\n } else if (attack == 1) { //hit\n Miss.setText(\"Hit!\");\n turn = 0;\n } else if (attack == 2) {\n Miss.setText((\"Already Guess!\")); //already guessed\n turn = 1; //user still plays if already guessed\n } else if (attack == 0) {\n System.exit(-1); //exit with status -1\n }\n } catch (IndexOutOfBoundsException err) { //catch and print message\n Miss.setText(\"Invalid Location\");\n }\n } catch (NumberFormatException e1) { //catch and print message\n Miss.setText(\"Invalid Location\");\n }\n }\n\n if(computerBoard.getAddPiece() != 0 && turn == 0) { //same process for computer as human, except input is random generated\n turn = 1; //Computer only attacks when successful, therefore turn = 1.\n int attack = 0, choose = 0;\n if(DIFFICULTY == 2) {\n do {\n try {\n if (TCX == -1) { //if temporary is empty, normal attack\n CXG = ((int) (Math.random() * (10)) - 0); //random number between 0 and 9\n CYG = ((int) (Math.random() * (10)) - 0);\n attack = computerBoard.attack(CYG, CXG, humanBoard); //computer attack\n\n } else { //else, add 1 to temporary to up, down, right or left. Randomly selected\n choose = 0;\n if (((CXG + 1) <= 9)) {//down\n if (!(humanBoard.getPosition(CYG, CXG + 1).isGuess())) {\n System.out.println(\"Down\");\n positionArrayList.add(humanBoard.getPosition(CYG, CXG + 1));\n choose = 1;\n } else if (!(humanBoard.getPosition(CYG, CXG + 1).getHitOrMiss()) || (humanBoard.getPosition(CYG, CXG + 1).getHitOrMiss())) {\n choose = 1;\n } else {\n TCX = -1;\n TCY = -1;\n }\n } else {\n choose = 1;\n }\n if (((CXG - 1) > -1) && choose == 1) {//up\n if (!(humanBoard.getPosition(CYG, CXG - 1).isGuess())) {\n System.out.println(\"Up\");\n positionArrayList.add(humanBoard.getPosition(CYG, CXG - 1));\n choose = 2;\n } else if (!(humanBoard.getPosition(CYG, CXG - 1).getHitOrMiss()) || (humanBoard.getPosition(CYG, CXG - 1).getHitOrMiss())) {\n choose = 2;\n } else {\n TCX = -1;\n TCY = -1;\n }\n } else {\n choose = 2;\n }\n if (((CYG + 1) <= 9) && choose == 2) {//right\n if (!(humanBoard.getPosition(CYG + 1, CXG).isGuess())) {\n System.out.println(\"Right\");\n positionArrayList.add(humanBoard.getPosition(CYG + 1, CXG));\n choose = 3;\n } else if (!(humanBoard.getPosition(CYG + 1, CXG).getHitOrMiss()) || (humanBoard.getPosition(CYG + 1, CXG).getHitOrMiss())) {\n choose = 3;\n } else {\n TCX = -1;\n TCY = -1;\n }\n } else {\n choose = 3;\n }\n if (((CYG - 1) > -1) && choose == 3) {//left\n if (!(humanBoard.getPosition(CYG - 1, CXG).isGuess())) {\n System.out.println(\"Left\");\n positionArrayList.add(humanBoard.getPosition(CYG - 1, CXG));\n } else if (!(humanBoard.getPosition(CYG - 1, CXG).getHitOrMiss()) || (humanBoard.getPosition(CYG - 1, CXG).getHitOrMiss())) {\n choose = 4;\n } else {\n TCX = -1;\n TCY = -1;\n }\n }\n if (positionArrayList.size() == 0) {\n TCX = -1;\n TCY = -1;\n } else {\n int index = rand.nextInt(positionArrayList.size());\n System.out.println(index);\n for (int i = 0; i < positionArrayList.size(); i++) {\n System.out.println(positionArrayList.get(i));\n }\n if (((CXG + 1) <= 9)) {//down\n if (positionArrayList.get(index) == humanBoard.getPosition(CYG, CXG + 1)) {\n System.out.println(\"down\");\n CXG = TCX + 1;\n CYG = TCY;\n }\n }\n if (((CXG - 1) > -1)) {\n if (positionArrayList.get(index) == humanBoard.getPosition(CYG, CXG - 1)) {\n System.out.println(\"up\");\n CXG = TCX - 1;\n CYG = TCY;\n }\n }\n if (((CYG + 1) <= 9)) {\n if (positionArrayList.get(index) == humanBoard.getPosition(CYG + 1, CXG)) {\n System.out.println(\"right\");\n CXG = TCX;\n CYG = TCY + 1;\n }\n }\n if (((CYG - 1) > -1)) {\n if (positionArrayList.get(index) == humanBoard.getPosition(CYG - 1, CXG)) {\n System.out.println(\"left\");\n CXG = TCX;\n CYG = TCY - 1;\n }\n }\n positionArrayList.removeAll(positionArrayList);\n }\n if (TCY != -1) {\n attack = computerBoard.attack(CYG, CXG, humanBoard); //attack\n } else {\n attack = 2;\n }\n\n }\n } catch (IndexOutOfBoundsException err1) { //catch index out of bounds, do nothing\n TCY = -1;\n TCX = -1;\n continue;\n }\n } while (attack == 2); //since computer can't guess already guessed grid, computer keeps choosing until either hitting or missing\n\n if (attack == 1) { //if hit, memorize x and y\n TCX = CXG;\n TCY = CYG;\n } else {\n TCX = -1;\n TCY = -1;\n }\n }\n else if(DIFFICULTY == 1){\n\n do {\n try {\n CXG = ((int) (Math.random() * (10)) - 0); //random number between 0 and 9\n CYG = ((int) (Math.random() * (10)) - 0);\n attack = computerBoard.attack(CYG, CXG, humanBoard); //computer attack\n }catch(IndexOutOfBoundsException err1){\n attack = 2;\n }\n } while (attack == 2);\n\n }\n if(humanBoard.getAddPiece() == 0) {\n isWin.setText(\"Computer is the winner!\"); //print winner message\n nextScene.setText(\"Play Again!\"); //change text to Play Again. Refer to line 471\n rows.setDisable(true);\n columns.setDisable(true);\n nextScene.setDisable(false); //enable button\n submit.setDisable(true); //disable button\n }\n\n\n }\n else if(turn != 1) { //if user choose all the correct, human wins\n isWin.setText(\"Human is the winner!\");\n nextScene.setText(\"Play Again!\");\n rows.setDisable(true);\n columns.setDisable(true);\n nextScene.setDisable(false);\n submit.setDisable(true);\n }\n\n\n });\n\n //center align input\n input1.setAlignment(Pos.CENTER);\n input2.setAlignment(Pos.CENTER);\n input.setAlignment(Pos.CENTER);\n\n //add buttons in HBox\n HBox buttons = new HBox(40, nextScene, exit);\n\n //center align buttons\n buttons.setAlignment(Pos.CENTER);\n\n //set background color to light blue\n game.setStyle(\"-fx-background-color: #B5D3E7\");\n\n //add everything in VBox and center align them\n VBox vbox = new VBox(30,hbox1, sidebyside, input, isWin, buttons, Miss);\n vbox.setAlignment(Pos.CENTER);\n game.setCenter(vbox); //center align the VBox in root\n return game; //return root\n\n\n }",
"public Kal()\n {\n setDefaultCloseOperation( EXIT_ON_CLOSE );\n \n setLayout( new FlowLayout() );\n \n allTheShapes = new Shape[1000];\n \n boxButton = new JButton(\"box\");\n add(boxButton);\n boxButton.addActionListener(this);\n \n addMouseListener(this);\n addMouseMotionListener(this);\n \n setSize( 500,500);\n setVisible( true);\n \n theColorPicker = new ColorPicker3();\n \n }",
"private void makeContainer(){\n Container X = (Container) ((SpringGridLayout) headlineContainer.getLayout()).getChild(1, 0);\n if (!(X == null)) headlineContainer.removeChild(X);\n\n Container sub = new Container(new SpringGridLayout(Axis.X,Axis.Y,FillMode.Last,FillMode.None));\n sub.setBackground(null); // just in case style sets an bg here\n Container sub1 = new Container();\n sub1.setBackground(null);\n Container sub2 = new Container();\n sub2.setBackground(null);\n Container sub3 = new Container();\n sub3.setBackground(null);\n\n sub.addChild(sub1);\n sub.addChild(sub2);\n sub.addChild(sub3);\n\n headlineContainer.addChild(sub ,1,0);\n/*\n sub2.setName(\"TEST\");\n sub3.setBackground(new QuadBackgroundComponent(ColorRGBA.Pink));\n\n // sub1.setPreferredSize(new Vector3f(25,50,0));\n sub1.setBackground(new QuadBackgroundComponent(ColorRGBA.Green));\n */\n }",
"private VBox makeUIElements() {\r\n\t\t\r\n\t\tVBox vBox = new VBox();\r\n\t\tvBox.setPadding(new Insets(16));\r\n\t\tvBox.setSpacing(25);\r\n\t\tvBox.setAlignment(Pos.CENTER);\r\n\t\t\r\n\t\tHBox sortingAlgorithmHBox = new HBox();\r\n\t\tsortingAlgorithmHBox.setSpacing(5);\r\n\t\tsortingAlgorithmHBox.setAlignment(Pos.BASELINE_LEFT);\r\n\t\tLabel sortingAlgorithmLabel = new Label(\"Sorting Algorithm:\");\r\n\t\tComboBox<String> sortingAlgorithmComboBox = new ComboBox<>();\r\n\t\tfor (String s : Settings.algorithms) {\r\n\t\t\tsortingAlgorithmComboBox.getItems().add(s);\r\n\t\t}\r\n\t\tsortingAlgorithmComboBox.getSelectionModel().selectFirst();\r\n\t\tsortingAlgorithmHBox.getChildren().addAll(sortingAlgorithmLabel, sortingAlgorithmComboBox);\r\n\t\t\r\n\t\t\r\n\t\tHBox arraySizeHBox = new HBox();\r\n\t\tarraySizeHBox.setSpacing(5);\r\n\t\tarraySizeHBox.setAlignment(Pos.BASELINE_LEFT);\r\n\t\tLabel arraySizeLabel = new Label(\"Array Size:\");\r\n\t\tfinal TextField arraySizeInput = new TextField(\"100\");\r\n\t\tarraySizeInput.setPrefWidth(70);\r\n\t\tarraySizeInput.textProperty().addListener(new ChangeListener<String>() {\r\n\t\t @Override\r\n\t\t public void changed(ObservableValue<? extends String> observable, String oldValue, \r\n\t\t String newValue) {\r\n\t\t if (!newValue.matches(\"\\\\d*\")) {\r\n\t\t \tarraySizeInput.setText(newValue.replaceAll(\"[^\\\\d]\", \"\"));\r\n\t\t }\r\n\t\t }\r\n\t\t});\r\n\t\tarraySizeHBox.getChildren().addAll(arraySizeLabel, arraySizeInput);\r\n\t\t\r\n\t\t\r\n\t\tHBox delayHBox = new HBox();\r\n\t\tdelayHBox.setSpacing(5);\r\n\t\tdelayHBox.setAlignment(Pos.BASELINE_LEFT);\r\n\t\tLabel delayLabel = new Label(\"Step Delay:\");\r\n\t\tSlider delaySlider = new Slider(1, 1000, 1);\r\n\t\tdelaySlider.setPrefWidth(200);\r\n\t\tLabel delayValue = new Label(\"1\");\r\n\t\tdelayValue.setPrefWidth(45);\r\n\t\tdelaySlider.valueProperty().addListener(new ChangeListener<Number>() {\r\n\t public void changed(ObservableValue<? extends Number> ov,\r\n\t Number oldVal, Number newVal) {\r\n\t \tlong val = 5*(Math.round(newVal.doubleValue()/5));\r\n\t \t\r\n\t \tval = Math.max(val, 1);\r\n\t \t\r\n\t \tdelaySlider.setValue(val);\r\n\t \tdelayValue.setText(Long.toString(val) + \" ms\");\r\n\t \tif (CurrentSortStratergy.getInstance().getCurrentStratergy() != null)\r\n\t \t\tCurrentSortStratergy.getInstance().getCurrentStratergy().setDelay(val);\r\n\t }\r\n \t});\r\n\t\tdelayHBox.getChildren().addAll(delayLabel, delaySlider, delayValue);\r\n\t\t\r\n\t\t\r\n\t\tHBox showGenerationBox = new HBox();\r\n\t\tshowGenerationBox.setSpacing(5);\r\n\t\tshowGenerationBox.setAlignment(Pos.BASELINE_LEFT);\r\n\t\tLabel showGenerationLabel = new Label(\"Show Array Generation: \");\r\n\t\tCheckBox showGenerationCheckBox = new CheckBox();\r\n\t\tshowGenerationBox.getChildren().addAll(showGenerationLabel, showGenerationCheckBox);\r\n\t\t\r\n\t\tHBox buttonHBox = new HBox();\r\n\t\tbuttonHBox.setSpacing(5);\r\n\t\tbuttonHBox.setAlignment(Pos.CENTER);\r\n\t\tButton generateButton = new Button(\"Generate Array\");\r\n\t\tgenerateButton.setOnAction(new GenerateButtonHandler(this.canvasPanel, arraySizeInput, showGenerationCheckBox));\r\n\t\tButton sortButton = new Button(\"Start Sort\");\r\n\t\tsortButton.setOnAction(new SortButtonHandler(this.canvasPanel, sortingAlgorithmComboBox, arraySizeInput, delaySlider, showGenerationCheckBox));\r\n\t\tButton stopButton = new Button(\"Stop Sort\");\r\n\t\tstopButton.setOnAction(new StopButtonHandler());\r\n\t\tbuttonHBox.getChildren().addAll(generateButton, sortButton, stopButton);\r\n\t\t\r\n\t\tvBox.getChildren().addAll(sortingAlgorithmHBox, arraySizeHBox, delayHBox, showGenerationBox, buttonHBox);\r\n\t\treturn vBox;\r\n\t\t\r\n\t}",
"Box(double len){\r\n Height = Width = Depth = len;\r\n\r\n }",
"public void createComponents()\n {\n VBox col = new VBox(SPACING);\n\n Label lblStatus = new Label(\"Machine Status\");\n lblStatus.getStyleClass().add(\"bordered-titled-title\");\n\n lblCurrFile = new Label(\"No File Currently Loaded\");\n lblConnection = new Label(\"Not Connected\");\n\n btnConnect = new Button(\"Connect to Machine\");\n btnConnect.setOnAction(new ConnectEventHandler());\n //btnConnect.getStyleClass().add(\"glass-grey\");\n\n ivConnection = new ImageView(\n new Image(getClass().getResourceAsStream(\"/Resources/Not Connected.png\")));\n\n lblMachineStatus = new Label(\"Status: Good\");\n HBox r1 = new HBox(SPACING);\n r1.getChildren().addAll(lblConnection, ivConnection);\n\n col.getChildren().addAll(btnConnect, r1, lblCurrFile, lblMachineStatus);\n getChildren().addAll(lblStatus, col);\n\n }",
"private void createWidgets() {\n\t\tgrid = new GridPane();\n\t\ttxtNickname = new TextField();\n\t\ttxtPort = new TextField();\n\t\ttxtAdress = new TextField();\n\n\t\tlblNick = new Label(\"Nickname\");\n\t\tlblNickTaken = new Label();\n\t\tlblPort = new Label(\"Port\");\n\t\tlblAdress = new Label(\"Adress\");\n\t\tlblCardDesign = new Label(\"Carddesign\");\n\n\t\tbtnLogin = new Button(\"\");\n\t\timageStart = new Image(BTNSTARTWOOD, 85, 35, true, true);\n\t\timvStart = new ImageView();\n\n\t\tcardDesignOptions = FXCollections.observableArrayList(\n\t\t\t\t\"original design\", \"pirate design\", \"graveyard design\");\n\t\tcomboBoxCardDesign = new ComboBox<String>(cardDesignOptions);\n\n\t\tcomboBoxCardDesign\n\t\t\t\t.setCellFactory(new Callback<ListView<String>, ListCell<String>>() {\n\t\t\t\t\t@Override\n\t\t\t\t\tpublic ListCell<String> call(ListView<String> list) {\n\t\t\t\t\t\treturn new ExtCell();\n\t\t\t\t\t}\n\n\t\t\t\t});\n\t}",
"public static void main(String[] args) {\n\t\tJPanel panel = new JPanel();\r\n\t\tpanel.setLayout(new BoxLayout(panel, BoxLayout.Y_AXIS));\r\n\t\t\r\n\t\tJLabel welcome = new JLabel(\"WELCOME\");\r\n\t\twelcome.setAlignmentX(Component.CENTER_ALIGNMENT);\r\n\t\twelcome.setFont(welcome.getFont().deriveFont(25.0f));\r\n panel.add(welcome);\r\n \r\n JLabel toThe = new JLabel(\"to the\");\r\n toThe.setAlignmentX(Component.CENTER_ALIGNMENT);\r\n \t \ttoThe.setFont(toThe.getFont().deriveFont(17.0f));\r\n \t \tpanel.add(toThe);\r\n \t \t\r\n \t \tJLabel colourGame = new JLabel(\"Colour Game\");\r\n \t colourGame.setAlignmentX(Component.CENTER_ALIGNMENT);\r\n \t \tcolourGame.setFont(colourGame.getFont().deriveFont(25.0f));\r\n \t \tcolourGame.setForeground(Color.RED);\r\n \t \tpanel.add(colourGame);\r\n \t \t\r\n \t \t// Adds empty space to the panel\r\n \t panel.add(Box.createRigidArea(new Dimension(0, 100)));\r\n \t \r\n \t JLabel text = new JLabel(\"> Choose the colour of the provided items\");\r\n\t text.setAlignmentX(Component.CENTER_ALIGNMENT);\r\n\t panel.add(text);\r\n\t \r\n\t panel.add(Box.createRigidArea(new Dimension(0, 40)));\r\n\t\t\r\n\t JButton startButton = new JButton(\"Start\");\r\n startButton.setAlignmentX(Component.CENTER_ALIGNMENT);\r\n startButton.setMaximumSize(new Dimension(600, 60));\r\n startButton.setBackground(Color.WHITE);\r\n panel.add(startButton);\r\n\r\n // Set up frame\r\n\t\tJFrame frame = new JFrame(\"Colour Game\");\r\n frame.setDefaultCloseOperation(JFrame.EXIT_ON_CLOSE);\r\n \r\n //Set up content pane\r\n frame.getContentPane().add(panel);\r\n \r\n //Display window\r\n frame.setVisible(true);\r\n frame.setResizable(false);\r\n frame.setSize(700, 360);\r\n frame.setLocationRelativeTo(null);\r\n\t}",
"public BoxBackground(float[] c)\n {\n super(c);\n\n texture = new TextureComponent2D[6];\n\n stateChanged = false;\n textureIdMap = new HashMap[6];\n\n for(int i = 0; i < 6; i++)\n textureIdMap[i] = new HashMap<GL, Integer>();\n\n generateBoxGeom();\n }",
"private void updateBoxes(){\n if(model.getMap() != null) {\n DoubleVec position = invModelToView(new DoubleVec(canvas.getWidth()*0.5,canvas.getHeight()*0.5));\n inner = new Rectangle(position, 1.0/zoomFactor * fi * canvas.getWidth(), 1.0/zoomFactor * fi * canvas.getHeight(), 0);\n outer = new Rectangle(position, 1.0/zoomFactor * fo * canvas.getWidth(), 1.0/zoomFactor * fo * canvas.getHeight(), 0);\n }\n }",
"private Parent create() {\n root.setPrefSize(600,600);\r\n\r\n for(int i = 0; i < 3; ++i) {\r\n for(int j = 0; j < 3; ++j) {\r\n Tile tile = new Tile();\r\n tile.setTranslateX(j * 200);\r\n tile.setTranslateY(i * 200);\r\n\r\n root.getChildren().add(tile);\r\n board[j][i] = tile;\r\n }\r\n }\r\n\r\n // horizontal strikes\r\n for(int i = 0; i < 3; ++i) {\r\n comboList.add(new Combination(board[0][i], board[1][i], board[2][i]));\r\n }\r\n\r\n // vertical strikes\r\n for(int j = 0; j < 3; ++j) {\r\n comboList.add(new Combination(board[j][0], board[j][1], board[j][2]));\r\n }\r\n\r\n // diagonal strikes\r\n comboList.add(new Combination(board[0][0], board[1][1], board[2][2]));\r\n comboList.add(new Combination(board[2][0], board[1][1], board[0][2]));\r\n\r\n return root;\r\n }",
"private void testBoardCreation() {\n for (int r = 0; r < Constants.BOARD_GRID_ROWS; r++) {\n for (int c = 0; c < Constants.BOARD_GRID_COLUMNS; c++) {\n Vector2 tokenLocation = this.mBoardLevel.getCenterOfLocation(r, c);\n Image tokenImage = new Image(this.mResources.getToken(PlayerType.RED));\n tokenImage.setPosition(tokenLocation.x, tokenLocation.y);\n this.mStage.addActor(tokenImage);\n }\n }\n }",
"private TilePane createGrid() {\n\t\tTilePane board = new TilePane();\n\t\tboard.setPrefRows(9);\n\t\tboard.setPrefColumns(9);\n\t\tboard.setPadding(new Insets(3,3,3,3));\n\t\tboard.setHgap(3); //Horisontal gap between tiles\n\t\tboard.setVgap(3); //Vertical gap between tiles\n\t\t\n\t\t//Creates and colors tiles\n\t\tfor(int i = 0; i < 9; i++){\n\t\t\tfor(int k = 0; k < 9; k++){\n\t\t\t\tLetterTextField text = new LetterTextField();\n\t\t\t\ttext.setPrefColumnCount(1);\n\t\t\t\t\n\t\t\t\tif(!(i/3 == 1 || k/3 == 1) || (i/3 == 1 && k/3 == 1)){\n\t\t\t\t\ttext.setStyle(\"-fx-background-color: #daa520;\");\t\n\t\t\t\t}\n\t\t\t\t\n\t\t\t\tfield[i][k] = text;\n\t\t\t\tboard.getChildren().add(text);\n\t\t\t}\n\t\t}\t\t\n\t\treturn board;\n\t}",
"private void prepare()\n {\n Block block = new Block(10);\n addObject(block,372,150);\n Wall wall = new Wall();\n addObject(wall,52,167);\n Wall wall2 = new Wall();\n addObject(wall2,160,167);\n Wall wall3 = new Wall();\n addObject(wall3,550,167);\n Wall wall4 = new Wall();\n addObject(wall4,650,167);\n Wall wall5 = new Wall();\n addObject(wall5,750,167);\n block.setLocation(306,171);\n Robot robot = new Robot();\n addObject(robot,48,51);\n Pizza pizza = new Pizza();\n addObject(pizza,550,60);\n Pizza pizza2 = new Pizza();\n addObject(pizza2,727,53);\n Pizza pizza3 = new Pizza();\n addObject(pizza3,364,303);\n Pizza pizza4 = new Pizza();\n addObject(pizza4,224,400);\n Pizza pizza5 = new Pizza();\n addObject(pizza5,622,395);\n ScorePanel scorePanel = new ScorePanel();\n addObject(scorePanel,106,525);\n Home home = new Home();\n addObject(home,717,521);\n\n block.setLocation(344,173);\n pizza3.setLocation(394,297);\n Pizza pizza6 = new Pizza();\n addObject(pizza6,711,265);\n Pizza pizza7 = new Pizza();\n addObject(pizza7,68,276);\n\n }",
"void setBox();",
"public static void main(String[] args){\n Box[] boxes = {new Box1(),new Box2(), new Box3(),new Box4(),new Box5() };\n int length =15;\n int width =20;\n int height =25;\n for (Box box:boxes\n ) {if(box.validate(length,width,height)){\n System.out.println(box.name );\n break;\n }\n\n }\n\n\n\n\n /*Scanner scan = new Scanner(System.in);\n System.out.println(\"Please enter a number:\");\n int length = Integer.parseInt(scan.next());\n System.out.println(\"Please enter a number:\");\n int width = Integer.parseInt(scan.next());\n System.out.println(\"Please enter a number:\");\n int height = Integer.parseInt(scan.next());\n System.out.println(\"length: \" + length + \", width: \" + width + \", height: \" + height);\n if (box3.validate(length, width, height)) {\n System.out.println(box3.getName());\n }*/\n\n\n }",
"public Stage() {\n\n for (int i = 0; i < 20; i++) { // Generate the basic grid array\n ArrayList<Cell> cellList = new ArrayList<Cell>();\n cells.add(cellList);\n for (int j = 0; j < 20; j++) {\n cells.get(i).add(new Cell(10 + 35 * i, 10 + 35 * j));\n }\n }\n\n for (int i = 0; i < cells.size(); i++) { // Generate the list of environment blocks\n ArrayList<Environment> envList = new ArrayList<Environment>();\n environment.add(envList);\n for (int j = 0; j < cells.size(); j++) {\n int cellGenerator = (int) (Math.random() * 100) + 1;\n environment.get(i).add(generateCell(cellGenerator, cells.get(i).get(j)));\n }\n }\n\n grid = new Grid(cells, environment); // Initialise the grid with the generated cells array\n }",
"protected void skybox() {\n Triple pos1, pos2, pos3, pos4, pos5, pos6, pos7, pos8, col1, col2, col3, col4;\n\n pos1 = new Triple(0, 0, 0);\n pos2 = new Triple(100, 0, 0);\n pos3 = new Triple(100, 0, 100);\n pos4 = new Triple(0, 0, 100);\n pos5 = new Triple(0, 100, 0);\n pos6 = new Triple(100, 100, 0);\n pos7 = new Triple(100, 100, 100);\n pos8 = new Triple(0, 100, 100);\n\n // Front Triangles\n frozenSoups.addTri( new Triangle(new Vertex(pos1, 0, 0),\n new Vertex(pos2, .25, 0),\n new Vertex(pos3, .25, 1),\n 21 ) );\n\n frozenSoups.addTri( new Triangle(new Vertex(pos3, .25, 1),\n new Vertex(pos4, 0, 1),\n new Vertex(pos1, 0, 0),\n 21 ) );\n\n // Left Triangles\n frozenSoups.addTri( new Triangle(new Vertex(pos1, 1, 0),\n new Vertex(pos5, .75, 0),\n new Vertex(pos8, .75, 1),\n 21 ) );\n\n frozenSoups.addTri( new Triangle(new Vertex(pos8, .75, 1),\n new Vertex(pos4, 1, 1),\n new Vertex(pos1, 1, 0),\n 21 ) );\n\n // Right Triangles\n frozenSoups.addTri( new Triangle(new Vertex(pos2, .25, 0),\n new Vertex(pos6, .5, 0),\n new Vertex(pos7, .5, 1),\n 21 ) );\n\n frozenSoups.addTri( new Triangle(new Vertex(pos7, .5, 1),\n new Vertex(pos3, .25, 1),\n new Vertex(pos2, .25, 0),\n 21 ) );\n\n // Back Triangles\n frozenSoups.addTri( new Triangle(new Vertex(pos5, .75, 0),\n new Vertex(pos6, .5, 0),\n new Vertex(pos7, .5, 1),\n 21 ) );\n\n frozenSoups.addTri( new Triangle(new Vertex(pos7, .5, 1),\n new Vertex(pos8, .75, 1),\n new Vertex(pos5, .75, 0),\n 21 ) );\n\n // Top Triangles\n// frozenSoups.addTri( new Triangle(new Vertex(pos4, 0, 0),\n// new Vertex(pos3, 0, 1),\n// new Vertex(pos7, 1, 1),\n// 20 ) );\n\n// frozenSoups.addTri( new Triangle(new Vertex(pos7, 0, 0),\n// new Vertex(pos8, 1, 0),\n// new Vertex(pos4, 1, 1),\n// 20 ) );\n }",
"private void inicialitzarComponents() {\n\t\tsetLayout(new BorderLayout(0, 0));\n\n\t\tJPanel panel = new JPanel();\n\t\tpanel.setOpaque(false);\n\t\tadd(panel, BorderLayout.NORTH);\n\n\t\tBox verticalBox = Box.createVerticalBox();\n\t\tverticalBox.setOpaque(false);\n\t\tpanel.add(verticalBox);\n\n\t\tJPanel panel_2 = new JPanel();\n\t\tpanel_2.setOpaque(false);\n\t\tverticalBox.add(panel_2);\n\n\t\tJPanel panel_3 = new JPanel();\n\t\tpanel_3.setOpaque(false);\n\t\tverticalBox.add(panel_3);\n\n\t\tJLabel lblNewLabel = new JLabel(nomUsuari);\n\t\tlblNewLabel.setFont(lblNewLabel.getFont().deriveFont(30f));\n\t\tpanel_3.add(lblNewLabel);\n\n\t\tJPanel panel_1 = new JPanel();\n\t\tpanel_1.setOpaque(false);\n\t\tadd(panel_1, BorderLayout.CENTER);\n\n\t\tBox verticalBox_1 = Box.createVerticalBox();\n\t\tverticalBox_1.setOpaque(false);\n\t\tpanel_1.add(verticalBox_1);\n\n\t\tJPanel panel_4 = new JPanel();\n\t\tpanel_4.setOpaque(false);\n\t\tverticalBox_1.add(panel_4);\n\n\t\tJLabel lblNewLabel_1 = new JLabel(\"Peces girades:\");\n\t\tpanel_4.add(lblNewLabel_1);\n\n\t\tJLabel lblNewLabel_2 = new JLabel(String.valueOf(records.get(\"pecesGirades\")));\n\t\tpanel_4.add(lblNewLabel_2);\n\n\t\tJPanel panel_5 = new JPanel();\n\t\tpanel_5.setOpaque(false);\n\t\tverticalBox_1.add(panel_5);\n\n\t\tJLabel lblNewLabel_3 = new JLabel(\"Partides blanques guanyades:\");\n\t\tpanel_5.add(lblNewLabel_3);\n\n\t\tJLabel lblNewLabel_4 = new JLabel(String.valueOf(records.get(\"partidesBlanquesGuanyades\")));\n\t\tpanel_5.add(lblNewLabel_4);\n\n\t\tJPanel panel_6 = new JPanel();\n\t\tpanel_6.setOpaque(false);\n\t\tverticalBox_1.add(panel_6);\n\n\t\tJLabel lblNewLabel_5 = new JLabel(\"Partides negres guanyades:\");\n\t\tpanel_6.add(lblNewLabel_5);\n\n\t\tJLabel lblNewLabel_6 = new JLabel(String.valueOf(records.get(\"partidesNegresGuanyades\")));\n\t\tpanel_6.add(lblNewLabel_6);\n\n\t\tpanellRanking.setLayout(new BorderLayout());\n\t\tpanellRanking.add(menu, BorderLayout.NORTH);\n\t\tpanellRanking.add(taulaHoritzontal, BorderLayout.CENTER);\n\t\tpanellRanking.setBorder(BorderFactory.createLineBorder(Color.white, 4));\n\t\tJPanel panel_7 = new JPanel();\n\t\tpanel_7.setOpaque(false);\n\t\tpanel_7.setSize(20, 20);\n\t\tpanel_7.add(panellRanking);\n\t\tverticalBox_1.add(panel_7);\n\t}",
"Box(double w, double h, double d) {\n\n widgh =w;\n height =h;\n depth =d;\n\n}",
"private void initialiseBags() {\r\n\t\t//Player one bag\r\n\t\taddToBag1(GridSquare.Type.a, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag1(GridSquare.Type.b, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag1(GridSquare.Type.c, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD);\r\n\t\taddToBag1(GridSquare.Type.d, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY);\r\n\t\taddToBag1(GridSquare.Type.e, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY);\r\n\t\taddToBag1(GridSquare.Type.f, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag1(GridSquare.Type.g, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.HORIZONTAL_SWORD, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag1(GridSquare.Type.h, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD);\r\n\t\taddToBag1(GridSquare.Type.i, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY);\r\n\t\taddToBag1(GridSquare.Type.j, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD);\r\n\t\taddToBag1(GridSquare.Type.k, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag1(GridSquare.Type.l, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY);\r\n\t\taddToBag1(GridSquare.Type.m, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY);\r\n\t\taddToBag1(GridSquare.Type.n, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY);\r\n\t\taddToBag1(GridSquare.Type.o, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD);\r\n\t\taddToBag1(GridSquare.Type.p, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag1(GridSquare.Type.q, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD);\r\n\t\taddToBag1(GridSquare.Type.r, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD);\r\n\t\taddToBag1(GridSquare.Type.s, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD);\r\n\t\taddToBag1(GridSquare.Type.t, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY);\r\n\t\taddToBag1(GridSquare.Type.u, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag1(GridSquare.Type.v, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY);\r\n\t\taddToBag1(GridSquare.Type.w, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD);\r\n\t\taddToBag1(GridSquare.Type.x, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD);\r\n\t\t\r\n\t\t//Player two bag\r\n\t\taddToBag2(GridSquare.Type.A, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag2(GridSquare.Type.B, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag2(GridSquare.Type.C, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD);\r\n\t\taddToBag2(GridSquare.Type.D, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY);\r\n\t\taddToBag2(GridSquare.Type.E, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY);\r\n\t\taddToBag2(GridSquare.Type.F, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag2(GridSquare.Type.G, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.HORIZONTAL_SWORD, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag2(GridSquare.Type.H, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD);\r\n\t\taddToBag2(GridSquare.Type.I, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY);\r\n\t\taddToBag2(GridSquare.Type.J, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD);\r\n\t\taddToBag2(GridSquare.Type.K, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag2(GridSquare.Type.L, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY);\r\n\t\taddToBag2(GridSquare.Type.M, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY);\r\n\t\taddToBag2(GridSquare.Type.N, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY);\r\n\t\taddToBag2(GridSquare.Type.O, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD);\r\n\t\taddToBag2(GridSquare.Type.P, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag2(GridSquare.Type.Q, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD);\r\n\t\taddToBag2(GridSquare.Type.R, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD);\r\n\t\taddToBag2(GridSquare.Type.S, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD);\r\n\t\taddToBag2(GridSquare.Type.T, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY);\r\n\t\taddToBag2(GridSquare.Type.U, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY, GridSquare.Type.HORIZONTAL_SWORD);\r\n\t\taddToBag2(GridSquare.Type.V, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.EMPTY, GridSquare.Type.EMPTY);\r\n\t\taddToBag2(GridSquare.Type.W, GridSquare.Type.VERTICAL_SWORD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD);\r\n\t\taddToBag2(GridSquare.Type.X, GridSquare.Type.EMPTY, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD, GridSquare.Type.SHIELD);\r\n\t}",
"public Box() {\n \tsuper();\n \tthis.max = new Point3d( 1, 1, 1 );\n \tthis.min = new Point3d( -1, -1, -1 );\n }",
"public void initPieces() {\r\n\t\tfor (int i = 0; i < 64; i++) {\r\n\t\t\tif (i < 12) {\r\n\t\t\t\tblackPieces[i] = new ChessPiece(\"black\", \"\");\r\n\t\t\t\tblackPieces[i].setBackground(Color.BLACK);\r\n\t\t\t\tblackPieces[i].addMouseMotionListener(this);\r\n\t\t\t\tblackPieces[i].addMouseListener(this);\r\n\t\t\t\tblackPieces[i].setText(null);\r\n\t\t\t\twhitePieces[i] = new ChessPiece(\"white\", \"\");\r\n\t\t\t\twhitePieces[i].setBackground(Color.WHITE);\r\n\t\t\t\twhitePieces[i].addMouseMotionListener(this);\r\n\t\t\t\twhitePieces[i].addMouseListener(this);\r\n\t\t\t\twhitePieces[i].setText(null);\r\n\t\t\t}\r\n\t\t\tspacePieces[i] = new ChessPiece(\"empty\", \"\");\r\n\t\t\tspacePieces[i].setEnabled(false);\r\n\t\t\tspacePieces[i].setVisible(false);\r\n\t\t\tspacePieces[i].setText(null);\r\n\t\t}\r\n\t}",
"private void creatingElements() {\n\t\ttf1 = new JTextField(20);\n\t\ttf2 = new JTextField(20);\n\t\ttf3 = new JTextField(20);\n\t\tJButton btn = new JButton(\"Add\");\n\t\tbtn.addActionListener(control);\n\t\tbtn.setActionCommand(\"add\");\n\t\t\n\t\tJPanel panel = new JPanel();\n\t\tpanel.add(tf1);\n\t\tpanel.add(tf2);\n\t\tpanel.add(btn);\n\t\tpanel.add(tf3);\n\t\t\n\t\tthis.add(panel);\n\t\t\n\t\tthis.validate();\n\t\tthis.repaint();\t\t\n\t\t\n\t}",
"FlexBox createFlexBox();",
"@Override\n public List<FreeSpace3D> segmentSpace(Box box){\n ArrayList<FreeSpace3D> newFreeSpace3DS = new ArrayList<>();\n ArrayList<Surface> newSurfaces = new ArrayList();\n if(box.getZBottom() > position.getZ())\n {\n //the bottom of physical box is a separating plane\n FreeSpace3D fs = new FreeSpace3D(width, depth, box.getZBottom() - position.getZ(), position, this.pallet, supportingSurfaces);\n newFreeSpace3DS.add(fs);\n }\n\n if(box.getZTop() < getZTop())\n {\n // the top of the physical box is a separating plane\n // determine the intersecting area\n PositionedRectangle intersectingArea = box.getTop().getHorizontalIntersection(this.getPositionedBottom());\n Surface sf = new Surface(intersectingArea);\n FreeSpace3D fs = new FreeSpace3D(width, depth,position.getZ() + height - box.getZTop(),\n new Vector3D(position.getX(), position.getY(),box.getZTop()), this.pallet, sf);\n newFreeSpace3DS.add(fs);\n }\n\n if(box.getXLeft() > getXLeft())\n {\n //the left side of physical box is a separating plane\n ArrayList<Surface> remainingSupportingSurfaces = updateSurfaces(new PositionedRectangle(box.getXLeft() - getXLeft(), depth, position));\n if(!remainingSupportingSurfaces.isEmpty()){\n FreeSpace3D fs = new FreeSpace3D(box.getXLeft() - getXLeft(), depth, height, position, this.pallet, remainingSupportingSurfaces);\n newFreeSpace3DS.add(fs);\n }\n }\n\n if(box.getXRight() < getXRight())\n {\n // the right of the physical box is a separating plane\n ArrayList<Surface> remainingSupportingSurfaces = updateSurfaces(new PositionedRectangle(getXRight() - box.getXRight(), depth, new Vector3D(box.getXRight(), position.getY(), position.getZ())));\n if(!remainingSupportingSurfaces.isEmpty()){\n FreeSpace3D fs = new FreeSpace3D(getXRight() - box.getXRight(), depth,\n height, new Vector3D(box.getXRight(), position.getY(), position.getZ()), this.pallet, remainingSupportingSurfaces);\n newFreeSpace3DS.add(fs);\n }\n }\n\n if(box.getYFront() > getYFront())\n {\n // the front of the physical box is a separating plane\n ArrayList<Surface> remainingSupportingSurfaces = updateSurfaces(new PositionedRectangle(width, box.getYFront() - getYFront(), position));\n if(!remainingSupportingSurfaces.isEmpty()){\n FreeSpace3D fs = new FreeSpace3D(width, box.getYFront() - getYFront(), height, position, this.pallet, remainingSupportingSurfaces);\n newFreeSpace3DS.add(fs);\n }\n }\n\n if(box.getYBack() < getYBack())\n {\n // the back of the physical box is a separating plane\n ArrayList<Surface> remainingSupportingSurfaces = updateSurfaces(new PositionedRectangle(width, getYBack() - box.getYBack(), new Vector3D(position.getX(), box.getYBack(), position.getZ())));\n if(!remainingSupportingSurfaces.isEmpty()){\n FreeSpace3D fs = new FreeSpace3D(width, getYBack() - box.getYBack(),\n height, new Vector3D(position.getX(), box.getYBack(), position.getZ()), this.pallet, remainingSupportingSurfaces);\n newFreeSpace3DS.add(fs);\n }\n }\n\n return newFreeSpace3DS;\n }",
"public void create3(){\n\t\t//creating board to keep track of player postion with 1 or 0. 0 if not there 1 if they are there\n\t\tfor(int i = 0; i <this.position.length; i++){\n\t\t\tfor(int p = 0; p < this.position.length; p++){\n\t\t\t\tthis.position[i][p] = 0;//filling with zero\n\t\t\t}\n\t\t}//end of position making board\n\n\n\t\t//creating stairs to connect rooms\n\t\tfor(int i = 0; i <this.Stairs.length; i++){\n\t\t\tfor(int p = 0; p < this.Stairs.length; p++){\n\t\t\t\tthis.Stairs[i][p] = 0;//filling with zero\n\t\t\t}\n\t\t}\n\t\tthis.Stairs[1][1] = 1;\n\n\t\t//creating board to keep track of garret\n\t\tfor(int i = 0; i <this.Garret.length; i++){\n\t\t\tfor(int p = 0; p < this.Garret.length; p++){\n\t\t\t\tthis.Garret[i][p] = 0;//filling with zero\n\t\t\t}\n\t\t}//end of garret board\n\t\tthis.Garret[18][10] = 1;//putts garret there\n\n\t\t//makes board that tells if item is there\n\t\tfor(int i = 0; i <this.Items.length; i++){\n\t\t\tfor(int p = 0; p < this.Items.length; p++){\n\t\t\t\tthis.Items[i][p] = null;//filling with null\n\t\t\t}\n\t\t}//end of filling board that has items\n\n\t\t//makes border of room\n\t\tfor(int i = 0; i < this.area.length; i++){\n\t\t\tfor(int p = 0; p<this.area.length; p++){\n\t\t\t\tif(i==0){\n\t\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t\t}\n\t\t\t\telse if (p==0 || p==19){\n\t\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t\t}\n\t\t\t\telse if(i==19){\n\t\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t\t}\n\t\t\t\telse{\n\t\t\t\t\tthis.area[i][p] = \" \";\n\t\t\t\t}\n\t\t\t}//end of innner for\n\t\t}//end of outter for\n\t\tfor(int i = 1; i< 6 ; i++){\n\t\t\tfor(int p = 7; p < 8; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 6; i< 7 ; i++){\n\t\t\tfor(int p = 7; p > 4; p--){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 6; i< 11 ; i++){\n\t\t\tfor(int p = 4; p < 5; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 10; i< 11 ; i++){\n\t\t\tfor(int p = 5; p < 8; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 11; i< 15 ; i++){\n\t\t\tfor(int p = 7; p < 8; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 15; i< 16 ; i++){\n\t\t\tfor(int p = 7; p > 3; p--){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 13; i< 14 ; i++){\n\t\t\tfor(int p = 1; p < 4; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 4; i< 5 ; i++){\n\t\t\tfor(int p = 12; p < 17; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 5; i< 9 ; i++){\n\t\t\tfor(int p = 12; p < 13; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 13; i< 14 ; i++){\n\t\t\tfor(int p = 7; p < 12; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 13; i< 16 ; i++){\n\t\t\tfor(int p = 12; p < 13; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t}\n\t\tfor(int i = 9; i< 10 ; i++){\n\t\t\tfor(int p = 12; p < 19; p++){\n\t\t\t\tthis.area[i][p] = \"[ ]\";\n\t\t\t}\n\t\t\tSystem.out.println(\" \");\n\t\t}//end of for that creates walls\n\n\t\t//for loop that distributes items\n\t\tint y = 0;\n\t\tint x = 0;\n\t\tfor(int i = 0;i<10;i++){\n\t\t\tItem thing = ItemGenerator.generate();//making an item\n\t\t\tboolean good = false;\n\t\t\twhile(!good){//makes coordates until there is nothing in the way\n\t\t\t\ty = fate.nextInt(20);//getting coordiantaes\n\t\t\t\tx = fate.nextInt(20);\n\t\t\t\tif(this.Items[y][x]==null && this.area[y][x] != \"[ ]\"){\n\t\t\t\t\tgood = true;\n\t\t\t\t}//end of if\n\t\t\t\telse{\n\t\t\t\t\tgood = false;\n\t\t\t\t}\n\t\t\t}//end of while\n\t\t\tItems[y][x] = thing;\n\t\t}//end of for that distributes items on board\n\n\t}",
"public Vbox(ImagePane a, ImagePane b,ImagePane c){\r\n\t\tsuper();\r\n\t\tAppMenuBar menuBar = new AppMenuBar(a,b,c);\r\n\t\t\r\n\t\tHBox hb1 = new HBox();\r\n\t hb1.getChildren().add(menuBar);\r\n\t \t \r\n\t HBox hb2 = new HBox();\r\n\t Button button1 = new Button(\"Checkers\");\r\n\t Button button2 = new Button(\"Horizontal Stripes\");\r\n\t Button button3 = new Button(\"Vertical Stripes\");\r\n\t button1.setOnAction(event ->{\r\n\t \tdoChecker(a,b,c);\t \t\r\n\t });\r\n\t button2.setOnAction(event ->{\t\t\t\r\n\t \thorizontal(a,b,c); \t\r\n\t });\r\n\t \r\n\t button3.setOnAction(event ->{\r\n\t \tvertical(a,b,c);\r\n\t });\r\n\t \r\n\t \r\n\t hb2.setSpacing(10); \r\n\t button1.setPrefSize(100,1);\r\n\t button2.setPrefSize(150,1);\r\n\t button3.setPrefSize(150,1);\r\n\t hb2.getChildren().addAll(button1,button2,button3);\t \r\n\t getChildren().addAll(hb1,hb2);\t\t\r\n\t}",
"private void boxCorners() {\n\t\tint tileTL = Track.getTiles()[(int) ((x + bounds.x) / Tile.TILEWIDTH)][(int) ((y + bounds.y)/ Tile.TILEHEIGHT)];\n\t\tint tileTR = Track.getTiles()[(int) ((x + bounds.x + bounds.width) / Tile.TILEWIDTH)][(int) ((y + bounds.y)/ Tile.TILEHEIGHT)];\n\t\tint tileBL = Track.getTiles()[(int) ((x + bounds.x) / Tile.TILEWIDTH)][(int) ((y + bounds.y + bounds.height)/ Tile.TILEHEIGHT)];\n\t\tint tileBR = Track.getTiles()[(int) ((x + bounds.x + bounds.width) / Tile.TILEWIDTH)][(int) ((y + bounds.y + bounds.height)/ Tile.TILEHEIGHT)];\n\t\tif(vector[0] == 0 && ((tileTL == 2 && tileTR == 3 && tileBL == 5 && tileBR == 4)||\n\t\t\t\t(tileTL == 21 && tileTR == 22 && tileBL == 24 && tileBR == 23) || \n\t\t\t\t(SettingsNdAudio.isHandicap() && tileTL == 25 && tileTR == 26 && tileBL == 28 && tileBR == 27) ||\n\t\t\t\t(SettingsNdAudio.isHandicap() && tileTL == 29 && tileTR == 30 && tileBL == 32 && tileBR == 31)\n\t\t\t\t)) {\n\t\t\tif(!hasReset) {\n\t\t\t\tticker = 0;\n\t\t\t\thasReset = true;\n\t\t\t}\n\t\t\tif(GameState.getGameActive() == 0) {\n\t\t\t\tGameState.setGameActive(2);\n\t\t\t}else if(GameState.getGameActive() == 4) {\n\t\t\t\tif(GameState.getLevel() + 1 < 10) {\n\t\t\t\t\tGameState.setLevel(GameState.getLevel() + 1);\n\t\t\t\t\tGameState newLv = new GameState(handler, GameState.getLevel());\n\t\t\t\t\tState.setState(newLv);\n\t\t\t\t} else\n\t\t\t\t\tGameState.setGameActive(2);\n\t\t\t}\n\t\t}\n\t}",
"public Box2DCollisionCreator(GameScreen screen) {\n world = screen.getWorld(); //Sets world to the GameScreen's World instance.\n\n\n //Sets map to the correct TiledMap instance, based on whether the Box2D boundaries are being created for\n // Level1 or Level2\n if (screen instanceof Level1Screen)\n map = ((Level1Screen) screen).getMap();\n else\n map = ((Level3Screen) screen).getMap();\n\n //Creates body and fixture variables which assign Objects their states within the world\n BodyDef bdef = new BodyDef();\n PolygonShape shape = new PolygonShape();\n FixtureDef fdef = new FixtureDef();\n Body body;\n\n //Sets body and fixture variables to it's respective values based on the TiledMap's MapObject instance's information.\n for (MapObject object : map.getLayers().get(3).getObjects().getByType(RectangleMapObject.class)) {\n Rectangle rect = ((RectangleMapObject) object).getRectangle();\n\n //The static bodies that represent the ground are made\n bdef.type = BodyDef.BodyType.StaticBody;\n bdef.position.set((rect.getX() + rect.getWidth() / 2) / Safety4Kids.PPM, (rect.getY() + rect.getHeight() / 2) / Safety4Kids.PPM);\n //the bodies are added to the game world\n body = world.createBody(bdef);\n\n shape.setAsBox(rect.getWidth() / 2 / Safety4Kids.PPM, rect.getHeight() / 2 / Safety4Kids.PPM);\n fdef.shape = shape;\n fdef.filter.categoryBits = B2DConstants.BIT_OBJECT;\n body.createFixture(fdef);\n }\n\n }",
"public void createBike(){\n createFrame();\n addWheels();\n addPedals();\n getPrice();\n }",
"private void agregarBloquesPredeterminados(){\n ImageView imagenBloqueMoverDerecha = new ImageView(new Image(\"file:src/main/java/com/vista/imagenes/bloqueImagenes/bloqueMoverDerecha.jpeg\"));\n ImageView imagenMoverIzquierda = new ImageView(new Image(\"file:src/main/java/com/vista/imagenes/bloqueImagenes/bloqueMoverIzquierda.jpeg\"));\n ImageView imagenMoverArriba = new ImageView(new Image(\"file:src/main/java/com/vista/imagenes/bloqueImagenes/bloqueMoverArriba.jpeg\"));\n ImageView imagenMoverAbajo = new ImageView(new Image(\"file:src/main/java/com/vista/imagenes/bloqueImagenes/bloqueMoverAbajo.jpeg\"));\n ImageView imagenBajarLapiz = new ImageView(new Image(\"file:src/main/java/com/vista/imagenes/bloqueImagenes/bloqueBajarLapiz.jpg\"));\n ImageView imagenLevantarLapiz = new ImageView(new Image(\"file:src/main/java/com/vista/imagenes/bloqueImagenes/bloqueLevantarLapiz.jpg\"));\n ImageView imagenRepetir2 = new ImageView(new Image(\"file:src/main/java/com/vista/imagenes/bloqueImagenes/bloqueRepetir2.jpeg\"));\n ImageView imagenRepetir3 = new ImageView(new Image(\"file:src/main/java/com/vista/imagenes/bloqueImagenes/bloqueRepetir3.jpeg\"));\n ImageView imagenInvertir = new ImageView(new Image(\"file:src/main/java/com/vista/imagenes/bloqueImagenes/bloqueInvertir.png\"));\n\n //creo contenedores para los bloques de seccion bloque\n VBox contenedorBloqueMoverDerecha = new VBox();\n VBox contenedorBloqueMoverIzquierda = new VBox();\n VBox contenedorBloqueMoverArriba = new VBox();\n VBox contenedorBloqueMoverAbajo = new VBox();\n VBox contenedorBloqueLevantarLapiz = new VBox();\n VBox contenedorBloqueBajarLapiz = new VBox();\n VBox contenedorBloqueRepetir2 = new VBox();\n VBox contenedorBloqueRepetir3 = new VBox();\n VBox contenedorBloqueInvertir = new VBox();\n\n\n //creo los bloques de seccion bloque y los agrego a sus respectivos contenedores\n contenedorBloqueMoverDerecha.getChildren().add(new VistaBloqueDisponible(new Contenido(imagenBloqueMoverDerecha), contenedorBloqueMoverDerecha, tablero, \"MoverDerecha\", false));\n contenedorBloqueMoverIzquierda.getChildren().add(new VistaBloqueDisponible(new Contenido(imagenMoverIzquierda), contenedorBloqueMoverIzquierda, tablero, \"MoverIzquierda\", false));\n contenedorBloqueMoverArriba.getChildren().add(new VistaBloqueDisponible(new Contenido(imagenMoverArriba), contenedorBloqueMoverArriba, tablero, \"MoverArriba\", false));\n contenedorBloqueMoverAbajo.getChildren().add(new VistaBloqueDisponible(new Contenido(imagenMoverAbajo), contenedorBloqueMoverAbajo, tablero, \"MoverAbajo\", false));\n contenedorBloqueLevantarLapiz.getChildren().add(new VistaBloqueDisponible(new Contenido(imagenLevantarLapiz), contenedorBloqueLevantarLapiz, tablero, \"LevantarLapiz\", false));\n contenedorBloqueBajarLapiz.getChildren().add(new VistaBloqueDisponible(new Contenido(imagenBajarLapiz), contenedorBloqueBajarLapiz, tablero, \"BajarLapiz\", false));\n contenedorBloqueRepetir2.getChildren().add(new VistaBloqueDisponible(new Contenido(imagenRepetir2), contenedorBloqueRepetir2, tablero, \"RepetirDoble\", true));\n contenedorBloqueRepetir3.getChildren().add(new VistaBloqueDisponible(new Contenido(imagenRepetir3), contenedorBloqueRepetir3, tablero, \"RepetirTriple\", true));\n contenedorBloqueInvertir.getChildren().add(new VistaBloqueDisponible(new Contenido(imagenInvertir), contenedorBloqueInvertir, tablero, \"Invertir\", true));\n\n //agrego de manera ordenada los contenedores de bloques de seccion bloque\n this.getChildren().add(contenedorBloqueMoverDerecha);\n this.getChildren().add(contenedorBloqueMoverIzquierda);\n this.getChildren().add(contenedorBloqueMoverArriba);\n this.getChildren().add(contenedorBloqueMoverAbajo);\n this.getChildren().add(contenedorBloqueLevantarLapiz);\n this.getChildren().add(contenedorBloqueBajarLapiz);\n this.getChildren().add(contenedorBloqueRepetir2);\n this.getChildren().add(contenedorBloqueRepetir3);\n this.getChildren().add(contenedorBloqueInvertir);\n }",
"@Override\n\t\tpublic void create() {\n\t\t\tcannon = new CannonLogic();\n\t\t\tlines = new LineLogic();\n\t\t\tboxes = new BoxLogic();\n\t\t\tcontroller = new PlayerController();\n\t\t\tshapeList = new ArrayList<Shape>();\n\t\t\t\n\t\t\tGdx.gl11.glEnableClientState(GL11.GL_VERTEX_ARRAY);\n\t\t\tGdx.gl11.glClearColor(0.4f, 0.6f, 1.0f, 1.0f);\n\t\t\tvertexBuffer = BufferUtils.newFloatBuffer(8);\n\t\t\tvertexBuffer.put(new float[] {-50,-50, -50,50, 50,-50, 50,50});\n\t\t\tvertexBuffer.rewind();\n\t\t}",
"public Box() {\t\t\t\t\n\t\tCrayon box[] = {new Crayon(10,Color.RED),new Crayon(10,Color.ORANGE),new Crayon(10,Color.YELLOW),new Crayon(10,Color.GREEN),new Crayon(10,Color.BLUE),new Crayon(10,Color.VIOLET),new Crayon(10,Color.BROWN),new Crayon(10,Color.BLACK)};\n\t\tcrayons = box;\n\t}",
"private void initVariablesVBox()\n {\n variablesVBox = new VBox();\n variablesVBox.setPrefSize(DEFAULT_WIDTH, DEFAULT_HEIGHT);\n variablesVBox.setAlignment(Pos.TOP_LEFT);\n variablesVBox.getStyleClass().add(CLASS_BOX_ELEMENTS);\n }",
"private HBox createSortingDisplay() {\n HBox sortingDisplay = new HBox();\n sortingDisplay.setPadding(new Insets(0, 0, 50, 0));\n sortingDisplay.setSpacing(2);\n sortingDisplay.setMaxHeight(MAX_HEIGHT);\n sortingDisplay.setAlignment(Pos.BASELINE_CENTER);\n\n for(int i = 0; i < arrSize; i++) {\n Rectangle rec = new Rectangle(width, heights[i], DEFAULT_COLOR);\n sortingDisplay.getChildren().add(rec);\n }\n\n return sortingDisplay;\n }",
"public void initializeEditingBox() {\r\n //editing mode elements\r\n editBox.setWidth(200);\r\n editBox.setHeight(380);\r\n editBox.setArcHeight(10);\r\n editBox.setArcWidth(10);\r\n editBox.setFill(Color.WHITESMOKE);\r\n editBox.setStroke(Color.BLACK);\r\n editBox.setOpacity(0.98);\r\n\r\n DiverseUtils.initializeTextField(nameField, editBox, 10, 30, nameText, 0, -5, state.getName());\r\n nameField.textProperty().addListener(nameChangeListener);\r\n nameField.setOnAction(nameChangeEventHandler);\r\n nameField.focusedProperty().addListener(nameFocusChangeListener);\r\n\r\n DiverseUtils.initializeTextField(commentField, editBox, 10, 90, commentText, 0, -5, state.getComment(), state.commentProperty());\r\n\r\n DiverseUtils.initializeTextField(enterField, editBox, 10, 150, enterText, 0, -5, state.getEnter(), state.enterProperty());\r\n\r\n DiverseUtils.initializeTextField(leaveField, editBox, 10, 210, leaveText, 0, -5, state.getLeave(), state.leaveProperty());\r\n\r\n //TODO use the mousewheel for changing elements in comboboxes\r\n typeComboBox.getItems().addAll(\"Normal\", \"Final\", \"Initial\");\r\n typeComboBox.setValue(\"Normal\");\r\n DiverseUtils.initializeComboBox(typeComboBox, editBox, 50, 330, typeText, 0, -5);\r\n typeComboBox.valueProperty().addListener(typeChangeListener);\r\n\r\n colorComboBox.getItems().addAll(\"Blue\", \"Green\", \"Red\", \"Yellow\", \"Orange\", \"Brown\");\r\n colorComboBox.setValue(\"Blue\");\r\n DiverseUtils.initializeComboBox(colorComboBox, editBox, 10, 270, colorText, 0, -5);\r\n colorComboBox.valueProperty().addListener(colorChangeListener);\r\n\r\n sizeComboBox.getItems().addAll(40, 50, 60, 75, 90, 120);\r\n sizeComboBox.setValue((int) state.getSize());\r\n DiverseUtils.initializeComboBox(sizeComboBox, editBox, 120, 270, sizeText, 0, -5);\r\n sizeComboBox.valueProperty().addListener(sizeChangeListener);\r\n\r\n editingPane.getChildren().add(editBox);\r\n editingPane.getChildren().add(nameField);\r\n editingPane.getChildren().add(nameText);\r\n editingPane.getChildren().add(commentField);\r\n editingPane.getChildren().add(commentText);\r\n editingPane.getChildren().add(enterField);\r\n editingPane.getChildren().add(enterText);\r\n editingPane.getChildren().add(leaveField);\r\n editingPane.getChildren().add(leaveText);\r\n editingPane.getChildren().add(colorComboBox);\r\n editingPane.getChildren().add(colorText);\r\n editingPane.getChildren().add(sizeComboBox);\r\n editingPane.getChildren().add(sizeText);\r\n editingPane.getChildren().add(typeComboBox);\r\n editingPane.getChildren().add(typeText);\r\n }",
"public void begin() throws Exception {\n\t\t\n\t\tAnchorPane ap = new AnchorPane();\n\t\tap.getChildren().addAll(titleBox);\n\t\tlist.prefWidthProperty().bind(root.widthProperty());\n titleBox.prefWidthProperty().bind(root.widthProperty());\n infoBox.prefWidthProperty().bind(root.widthProperty());\n \n titleBox.setPadding(new Insets(INSET_TOP, INSET_RIGHT, INSET_BOTTOM, INSET_LEFT)); \n \ttitleBox.setAlignment(Pos.BASELINE_CENTER);\n \ttitleBox.setStyle(\"-fx-background-color: #2A363B;\");\n \t\n \tColor green = Color.web(\"99B898\");\n \ttitle.setFont(Font.loadFont(getClass().getResourceAsStream(\"/fonts/Roboto-Black.ttf\"), 25));\n \ttitle.setFill(green);\n \t\n \tinfoBox.setPadding(new Insets(INSET_TOP, INSET_RIGHT, INSET_BOTTOM, INSET_LEFT)); \n \tinfoBox.setAlignment(Pos.BASELINE_CENTER);\n \tinfoBox.setStyle(\"-fx-background-color: #99B898;\");\n \t\n \tColor navy = Color.web(\"2A363B\");\n \tinfo.setFont(Font.loadFont(getClass().getResourceAsStream(\"/fonts/Roboto-Italic.ttf\"), 15));\n \tinfo.setFill(navy);\n \t\n \ttitleBox.getChildren().add(title);\n \tinfoBox.getChildren().add(info);\n \t\t\n \troot.setTop(ap);\n \troot.setCenter(infoPane);\n \tinfoPane.setTop(infoBox);\n \tinfoPane.setCenter(list);\t\n\t}"
]
| [
"0.6965729",
"0.67040825",
"0.6663669",
"0.66132385",
"0.6596136",
"0.6360793",
"0.63328075",
"0.6291506",
"0.6287855",
"0.6285107",
"0.6248398",
"0.62386006",
"0.6166337",
"0.6153905",
"0.6128005",
"0.61035585",
"0.6071007",
"0.60657644",
"0.6042698",
"0.6038186",
"0.6023886",
"0.60052425",
"0.59875363",
"0.5987078",
"0.5969912",
"0.59618795",
"0.59574354",
"0.59201497",
"0.5916904",
"0.5912546",
"0.5875556",
"0.587341",
"0.5868996",
"0.58320713",
"0.5831362",
"0.5825771",
"0.5822338",
"0.5819063",
"0.5816632",
"0.5813951",
"0.5803326",
"0.57844675",
"0.57814133",
"0.57642865",
"0.5754246",
"0.5749707",
"0.5729559",
"0.57107073",
"0.57076305",
"0.5702479",
"0.56908584",
"0.56806004",
"0.5674116",
"0.56737304",
"0.566522",
"0.5662059",
"0.5660233",
"0.5659198",
"0.5648402",
"0.56472135",
"0.5640131",
"0.5639708",
"0.56052387",
"0.56041795",
"0.5599393",
"0.5595156",
"0.5583954",
"0.5582768",
"0.5582052",
"0.55729973",
"0.5557617",
"0.5549773",
"0.55476546",
"0.554282",
"0.55414397",
"0.5541134",
"0.553979",
"0.5535264",
"0.552683",
"0.5519266",
"0.55120194",
"0.5507246",
"0.5499351",
"0.54945767",
"0.5490067",
"0.54864603",
"0.54854995",
"0.54785484",
"0.5470057",
"0.5468682",
"0.54641473",
"0.54608923",
"0.5458581",
"0.54584044",
"0.5451952",
"0.5439588",
"0.5436601",
"0.54347974",
"0.5426594",
"0.54248595",
"0.54220474"
]
| 0.0 | -1 |
checks whether a highlight should be drawn | private void checkHighlight(Point p) {
for (ChannelPanelBox box : boxList) {
if (box.contains(p))
box.highlight(true);
else
box.highlight(false);
}
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"boolean isHighlighted();",
"public boolean getHighlight();",
"public boolean isHighlight() {\r\n\t\treturn _highlight;\r\n\t}",
"public void highlightEnable() {\n actualFillColor = new Color(0, 255, 0, 150);\n repaint();\n revalidate();\n }",
"public void setHighlight(boolean high);",
"public boolean isHighlighted() {\n\t\treturn highlighted;\n\t}",
"protected boolean mustDrawInterior()\n {\n return this.getActiveAttributes().isDrawInterior();\n }",
"public boolean isHighlighted() {\r\n\t\treturn view.isHighlighted();\r\n\t}",
"private boolean checkIfHighlighted() {\n int i = 0;\n for (Node node : routeList) {\n if (node.getXPixels() != getHighlightGroup().getChildren().get(i).getTranslateX() ||\n node.getYPixels() != getHighlightGroup().getChildren().get(i).getTranslateY()) {\n return false;\n }\n i++;\n }\n return true;\n }",
"public boolean isHighlighted() {\n return _isHighlighted;\n }",
"public void assertHighlight(boolean shouldHighlight) {\n if (shouldHighlight) {\n this.cylinder.setMaterial(new PhongMaterial(Color.LIMEGREEN));\n return;\n }\n\n this.cylinder.setMaterial(this.getMaterial());\n }",
"public void highlight(){\n myRectangle.setFill(HIGHLIGHT);\n }",
"private boolean shouldBeHighlighted(Object annotationType) {\n \t\treturn contains(annotationType, fAllowedHighlightAnnotationTypes, fConfiguredHighlightAnnotationTypes);\n \t}",
"public Color getHighlight();",
"public boolean shouldHighlight(WorldEvent anEvent)\n\t\t{\n\t\t\treturn false;\n\t\t}",
"public void setLineHighlightEnabled(boolean highlight) {\n }",
"public void highlightStop() {\n actualFillColor = new Color(0, 0, 0, 150);\n repaint();\n revalidate();\n }",
"public void highlightTile() {\n\t\tclearHighlightTile();\n\t\trectangle.setStrokeType(StrokeType.INSIDE);\n\t\trectangle.setStrokeWidth(2.0);\n\t\trectangle.setStroke(Color.RED);\n\t}",
"public boolean isVerticalHighlightIndicatorEnabled() { return this.mDrawVerticalHighlightIndicator; }",
"public void setDrawHighlightIndicators(boolean enabled) {\n/* 51 */ setDrawVerticalHighlightIndicator(enabled);\n/* 52 */ setDrawHorizontalHighlightIndicator(enabled);\n/* */ }",
"public void setHighlight(boolean shouldHighlight) {\n this.setHighlight(shouldHighlight, Color.web(\"green\"));\n }",
"public boolean isFullyExplored();",
"boolean isDrawInterior(DrawContext dc, Object shape);",
"private void initHighlightLines()\r\n\t{\t\t\r\n\t\tfofHighlightRect = lang.newRect(new Offset(-2, -2, \"sourceCode\", AnimalScript.DIRECTION_NW), new Offset(2, 13*21, \"sourceCode\", AnimalScript.DIRECTION_NE), \"fofHighlightRect\", null, fofSourceCodeHighlightRect);\r\n\t\taddAdjHighlightRect = lang.newRect(new Offset(0, 5, \"fofHighlightRect\", AnimalScript.DIRECTION_SW), new Offset(2, 2, \"sourceCode\", AnimalScript.DIRECTION_SE), \"addAdjHighlightRect\", null, addAdjSourceCodeHighlightRect);\r\n\t\t\r\n\t\tfofHighlightRect.hide();\r\n\t\taddAdjHighlightRect.hide();\r\n\t}",
"public Paint getPaintHighlight() {\n return mHighlightPaint;\n }",
"public void setHighlight(boolean highlight) {\r\n\t\tthis._highlight = highlight;\r\n\t}",
"@Override\n\tpublic void highlight(boolean highlight) {\n\t\tif (JGraphRendering.erroneousStyle.updateStyle(visualization, highlight))\n\t\t\tgetObservable().notify(new MarkChangedEvent<Cell>(this));\n\n\t}",
"public boolean isDrawn();",
"boolean isMarkedIndicator();",
"public void highlight(boolean highlighted) {\n\n if (highlighted) {\n objCanvas.setCursor(Cursor.HAND);\n if (curObjLabel != null) {\n curObjLabel.setStroke(Color.KHAKI);\n curObjLabel.setHighlighted(highlighted);\n oldStroke = curObjLabel.initStroke();\n }\n\n //make sure do de hightlight the previous label if over bound\n if (preObjLabel != null) {\n preObjLabel.setStroke(preObjLabel.initStroke());\n preObjLabel.setHighlighted(false);\n preObjLabel.getTreeItem().setExpanded(false);\n }\n } else {\n objCanvas.setCursor(Cursor.DEFAULT);\n if (curObjLabel != null) {\n curObjLabel.setStroke(oldStroke);\n curObjLabel.setHighlighted(highlighted);\n }\n\n //make sure to de hightlight the previous label\n if (preObjLabel != null) {\n preObjLabel.setStroke(preObjLabel.initStroke());\n preObjLabel.setHighlighted(highlighted);\n }\n }\n }",
"private static void highlight(Graphics2D g, int x, int y, int startX){\r\n g.setColor(Color.RED);\r\n g.fillRect(startX * x + 1, startX * y + 1, startX - 1, startX - 1);\r\n }",
"public boolean isHorizontalHighlightIndicatorEnabled() { return this.mDrawHorizontalHighlightIndicator; }",
"public void highlight(Graphics g) {\n\t\tg.setColor(Color.CYAN);\n\t\tg.fillRect(column * CELL_WIDTH, row * CELL_HEIGHT, CELL_WIDTH, CELL_HEIGHT);\n\t\tg.setColor(Color.BLACK);\n\t\tg.drawRect(column * CELL_WIDTH, row * CELL_HEIGHT, CELL_WIDTH, CELL_HEIGHT);\n\t}",
"protected boolean mustDrawOutline()\n {\n return this.getActiveAttributes().isDrawOutline();\n }",
"public void setDrawsLayeredHighlights(final boolean b) {\n drawsLayeredHighlights = b;\n }",
"private void highlightText(Text text){\r\n\t text.changeColor(AnimalScript.COLORCHANGE_COLOR, Color.RED, new TicksTiming(0), new TicksTiming(0));\r\n\t }",
"void highlightCheckSquare(boolean highlight, Button button, int row, int column, CenterPiece piece);",
"public boolean tileHighlighted(float xTile, float yTile)\r\n/* 222: */ {\r\n/* 223:246 */ return (tileInBounds(xTile, yTile)) && \r\n/* 224:247 */ (this.highlight[((int)xTile)][((int)yTile)] != 0);\r\n/* 225: */ }",
"public boolean isDashedHighlightLineEnabled() { return !(this.mHighlightDashPathEffect == null); }",
"public JAnnotationCheckBox(){\n super();\n this.setOpaque(true);\n /*//this.setVerticalTextPosition(0);\n selectionBorderColor = UIManager.getColor(\"Tree.selectionBorderColor\");\n selectionForeground = UIManager.getColor(\"Tree.selectionForeground\");\n selectionBackground = UIManager.getColor(\"Tree.selectionBackground\");\n textForeground = UIManager.getColor(\"Tree.textForeground\");\n textBackground = UIManager.getColor(\"Tree.textBackground\");\n\n if (isHighlighted){\n\n this.setForeground(selectionForeground);\n this.setBackground(selectionBackground);\n } else {\n this.setForeground(textForeground);\n this.setBackground(textBackground);\n }*/\n\n }",
"Shape getHighlightShape();",
"protected void doToggleTextBackgrounds() {\r\n\t\trenderer.textBackgrounds = ui.viewTextBackgrounds.isSelected();\r\n\t\trenderer.repaint();\r\n\t}",
"public boolean isPaintingAnnotations() {\n \t\treturn !fConfiguredAnnotationTypes.isEmpty() || !fConfiguredHighlightAnnotationTypes.isEmpty();\n \t}",
"public void highlight(){\n\t\tbutton.addActionListener(new ActionListener() {\n\t\t\t@Override\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\n\t\t\t//if(!clicked){\t\n\t\t\t\t\n\t\t\t\tfirsttime=true;\n\t\t\t\tclicked=true;\n\t\t\t\tif(piece!=null){\n\t\t\t\t\txyMovment=piece.xyPossibleMovments(xPosition, yPosition);\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\t\t\n\t}",
"private void checkSelection() {\n \t\tboolean oldIsSelection = isSelection;\n \t\tisSelection = text.getSelectionCount() > 0;\n \t\tif (oldIsSelection != isSelection) {\n \t\t\tfireEnablementChanged(COPY);\n \t\t\tfireEnablementChanged(CUT);\n \t\t}\n \t}",
"private void highlight(final CellView cellView) {\r\n if (cellView != null) {\r\n highlight.setBounds(getHighlightBounds(cellView));\r\n if (highlight.getParent() == null) {\r\n GraphComponent.this.add(highlight);\r\n highlight.setVisible(true);\r\n }\r\n } else {\r\n if (highlight.getParent() != null) {\r\n highlight.setVisible(false);\r\n highlight.getParent().remove(highlight);\r\n }\r\n }\r\n }",
"public void setHighlight() {\n _highlight = HighlightMode.NORMAL;\n \n _input.setHighlightIntern();\n _output.setHighlightIntern();\n \n _isHighlighted = true;\n \n }",
"public SmartHighlightPainter() {\n\t\tsuper(DEFAULT_HIGHLIGHT_COLOR);\n\t}",
"public static void toggleHighlightState() {\n toggleHighlightState(!highlighted.getValue());\n }",
"public void highlightChanged(HighlightChangedEvent highlightChangedEvent)\r\n {\r\n // get the currently highlighted state id, \r\n // get the x and y of the point with this id\r\n // repaint the corresponding portion of the component\r\n int hiliteID = highlightManager_.getHighlight();\r\n SPlotPoint thePoint;\r\n \r\n // The x and y coordinates of the point to be highlighted\r\n int x,y;\r\n \r\n if (hiliteID > 0)\r\n {\r\n // The -1 is there to compensate for vectors starting at index 0\r\n thePoint = (SPlotPoint)pointVector_.elementAt(hiliteID -1);\r\n thePoint.setIsHilited(true);\r\n currHilitePoint_ = thePoint;\r\n \r\n // Get the x and y coordinates of the point\r\n x = (int)thePoint.x;\r\n y = (int)thePoint.y;\r\n \r\n // Only repaint the point if it has valid data (in this case >0)\r\n if ((x > INVALID_VALUE) || (y > INVALID_VALUE))\r\n {\r\n repaint( ((int)(x) - (OVAL_RADIUS)), \r\n ((int)(y) - (OVAL_RADIUS)), \r\n OVAL_REPAINT_SIZE, \r\n OVAL_REPAINT_SIZE );\r\n\r\n\r\n if (prevHilitePoint_ != null)\r\n {\r\n prevHilitePoint_.setIsHilited(false);\r\n\r\n\r\n repaint( ((int)prevHilitePoint_.x - (OVAL_RADIUS)), \r\n ((int)prevHilitePoint_.y - (OVAL_RADIUS)), \r\n OVAL_REPAINT_SIZE, \r\n OVAL_REPAINT_SIZE );\r\n }\r\n }\r\n prevHilitePoint_ = currHilitePoint_;\r\n \r\n }\r\n\r\n\r\n // If cursor is over a state (and the corresponding plot point is\r\n // highlighted), and then the cursor leaves the map area and enters the\r\n // white area around it (with value -1 in this case), \r\n // we want the highlighted scatter plot point to return to its normal color.\r\n if (hiliteID < INVALID_VALUE)\r\n {\r\n // Unhighlight any highlighted scatter plot point when the cursor\r\n // leaves the map and enters the surrounding white area around it\r\n if (currHilitePoint_ != null)\r\n {\r\n currHilitePoint_.setIsHilited(false);\r\n\r\n\r\n repaint( ((int)currHilitePoint_.x - (OVAL_RADIUS)), \r\n ((int)currHilitePoint_.y - (OVAL_RADIUS)), \r\n OVAL_REPAINT_SIZE, \r\n OVAL_REPAINT_SIZE );\r\n } \r\n }\r\n }",
"public boolean isUnderlined() { return false; }",
"void highlightSquare(boolean highlight, Button button, int row, int column, ChessPiece piece);",
"public boolean isHighlightCurrentBlock(){\n return mHighlightCurrentBlock;\n }",
"public boolean isHovered();",
"public boolean checkMouseOver(Rectangle selectionBox) {\n\t\tdouble zoom = editor.control.viewControl.zoom;\n\t\treturn (tool.mousePosition.distanceTo(getDrawPosition(selectionBox)) < Tool.DISTANCE_SELECT_HANDLE / zoom);\n\t}",
"public void setDrawVerticalHighlightIndicator(boolean enabled) { this.mDrawVerticalHighlightIndicator = enabled; }",
"public abstract boolean hasSelection();",
"public abstract boolean isInterior();",
"public boolean isPaintable() {\n return modifiedEditor.isPaintable ();\n }",
"public boolean isSimple() {\r\n return this.mTextBackgroundColor == 1 && this.mTextSelectionStart == 0 && this.mTextSelectionEnd == 0 && this.mLineCharOffsets == null && this.mLineBaselines == null && this.mHint == null;\r\n }",
"private void paint(Graphics g, boolean clicked, boolean highlight) {\n\t\t\tif (!(pixx > 0 && pixx < getWidth() && pixy > 0 && pixy < getHeight()))\n\t\t\t\treturn;\n\t\t\tint raddif = clicked ? 10 : (highlight ? CIRCLERAD * 2 / 3 : 0);\n\t\t\tint diadif = raddif * 2;\n\t\t\tg.fillOval(pixx - CIRCLERAD - raddif, pixy - CIRCLERAD - raddif, CIRCLEDIA + diadif, CIRCLEDIA + diadif);\n\n\t\t\t// drawing the box\n\t\t\tString toDraw = valx + \", \" + valy;\n\t\t\tint boxw = toDraw.length() * (xoffset - 1) + 8;\n\t\t\tint boxh = yoffset + 6;\n\t\t\tg.clearRect(pixx + 7, pixy - 10 - yoffset, boxw, boxh);\n\t\t\tg.drawRect(pixx + 7, pixy - 10 - yoffset, boxw, boxh);\n\t\t\tg.drawString(toDraw, pixx + 10, pixy - 10);\n\t\t}",
"public void setCanHighlight(boolean canHighlight) {\n this.canHighlight = canHighlight;\n\n if (!canHighlight) {\n if(this.kingCylinder != null) {\n this.kingCylinder.setMaterial(new PhongMaterial(Color.GRAY));\n }\n\n this.cylinder.setMaterial(new PhongMaterial(Color.GRAY));\n return;\n }\n\n if(this.kingCylinder != null) {\n this.kingCylinder.setMaterial(this.getMaterial());\n }\n\n this.cylinder.setMaterial(this.getMaterial());\n }",
"protected final boolean shouldClearRectBeforePaint() {\n // TODO: sun.awt.noerasebackground\n return true;\n }",
"BalloonAttributes getHighlightAttributes();",
"boolean isDrawState()\n\t{\n\t\treturn !state.contains(0);\n\t}",
"public void setHighlight(TileStatus highlight){\r\n highLight = highlight;\r\n }",
"private void highlightCircle(Node node) {\n Circle temp = (Circle) node;\n\n if (temp != lastHighlight) {\n temp.setStrokeWidth(4.5);\n temp.setStroke(Paint.valueOf(\"Aqua\"));\n lastHighlight.setStroke(Paint.valueOf(\"black\"));\n lastHighlight.setStrokeWidth(1);\n }\n lastHighlight = temp;\n }",
"@Override\n\tvoid draw(Graphics g) {\n\t\tg.setColor(needsHighlight() ? selectColor : Color.GRAY);\n\t\tsetBbox(x, y, x2, y2);\n\t\tif (x < x2 && y < y2)\n\t\t\tg.fillRect(x, y, x2 - x, y2 - y);\n\t\telse if (x > x2 && y < y2)\n\t\t\tg.fillRect(x2, y, x - x2, y2 - y);\n\t\telse if (x < x2 && y > y2)\n\t\t\tg.fillRect(x, y2, x2 - x, y - y2);\n\t\telse\n\t\t\tg.fillRect(x2, y2, x - x2, y - y2);\n\t}",
"public float getHighlightLineWidth() { return this.mHighlightLineWidth; }",
"public abstract Rect getRectForNodeHighlight();",
"@Override\n public void removeHighlight()\n {\n }",
"void setAddHighlightListener(AddHighlightListener listener);",
"public ColorUIResource getPrimaryControlHighlight() { return fPrimaryHighlight;}",
"@Override\n\tboolean isClicked(double x, double y) {\n\n\t\tif (segment.ptLineDist(x, y) < 10 && segment.ptLineDist(x, y) > -10) {\n\t\t\tthis.setColor(Color.BLUE);\n\t\t\tAssignment.frame.repaint();\n\t\t\treturn true;\n\t\t} else {\n\t\t\tthis.setColor(Color.BLACK);\n\t\t\tAssignment.frame.repaint();\n\t\t\treturn false;\n\t\t}\n\t}",
"boolean checkBorders();",
"private boolean isRed(Point pos){\r\n Cells aux = model.getValueAt(pos);\r\n return (aux == Cells.RED || aux == Cells.RED_QUEEN);\r\n }",
"public boolean isDraw() {\n\t\tif (!h1.isAlive() && !h2.isAlive())\n\t\t\treturn true;\n\t\treturn false;\n\t}",
"public void setHighlightCPU(boolean shouldHighlight) {\n this.setHighlight(shouldHighlight, Color.web(\"blue\"));\n }",
"public Object addHighlight(int p0, int p1, Highlighter.HighlightPainter p)\n/* */ throws BadLocationException\n/* */ {\n/* 64 */ return new Object();\n/* */ }",
"public boolean isTextPainted() {\r\n return textPainted;\r\n }",
"public boolean isTextPainted() {\r\n return textPainted;\r\n }",
"private boolean selectionFound(JTextPane pane) {\r\n\t\tfinal int selectionStart = pane.getSelectionStart();\r\n\t\tfinal int selectionEnd = pane.getSelectionEnd();\r\n\t\treturn selectionStart != selectionEnd;\r\n\t}",
"public boolean isMouseOver(){\n\t\treturn this.contains(Main.camera.getMousePos());\n\t}",
"public void removeHighlight() {\n if (highlightWord == null) {\r\n return;\r\n }\r\n \r\n for (int i = 0; i < highlightWord.length(); i++) {\r\n if (hightlightDir == Ranker.RIGHT) {\r\n cells[highlightX][highlightY + i].highlight((char) 0);\r\n } else {\r\n cells[highlightX + i][highlightY].highlight((char) 0);\r\n }\r\n }\r\n repaint();\r\n }",
"@Override\n public boolean shouldPaint() {\n return false;\n }",
"public DefaultHighlighter() {\n setDrawsLayeredHighlights(true);\n }",
"public void testStyleWhenSelectionIsInsideText()\n {\n deferTest(new Command()\n {\n public void execute()\n {\n doTestStyleWhenSelectionIsInsideText();\n }\n });\n }",
"@Override\n public boolean isGoodForInterior()\n {\n return false;\n }",
"boolean isDrawTicks();",
"public boolean isBackgroundPainted() {\r\n return backPainted;\r\n }",
"@Override\n public Color getHighlightedColor() { return getLine().getMapColor(); }",
"public Boolean compare(Highlight theOtherHighlight){\n return myText.equals(theOtherHighlight.getText());\n }",
"public boolean isSetColor() {\n return this.color != null;\n }",
"default void highlight()\n {\n JavascriptExecutor executor = (JavascriptExecutor) environment().getDriver();\n\n executor\n .executeScript(\"arguments[0].setAttribute('style', 'background: yellow; border: 2px solid red;'); \"\n + \"arguments[0].setAttribute('highlighted', 'true')\", element());\n }",
"@Override\n public void mouseEntered(MouseEvent e) {\n setBorderPainted(true);\n setForeground(Color.RED);\n }",
"public boolean isRed()\n {\n // TODO: replace this line with your code\n }",
"public void removeAllHighlights() {}",
"public void highlightDrawerSelection() {\n if (this.groups.isEmpty()) {\n Log.i(tag, \"highlightDrawerSelection, groups empty, returning\");\n return;\n }\n if (this.currentLight == null) {\n Iterator it = this.groups.iterator();\n while (true) {\n if (!it.hasNext()) {\n break;\n }\n LinkedList<Light> group = (LinkedList) it.next();\n if (!group.isEmpty() && ((Light) group.getFirst()).getGroupNumber() != 0) {\n this.currentLight = (Light) group.getFirst();\n this.broadcastingToGroup = true;\n startDreamScreenFragment();\n break;\n }\n }\n if (this.currentLight == null && !((LinkedList) this.groups.getFirst()).isEmpty()) {\n this.currentLight = (Light) ((LinkedList) this.groups.getFirst()).getFirst();\n this.broadcastingToGroup = false;\n startDreamScreenFragment();\n }\n if (this.currentLight == null) {\n Log.i(tag, \"highlightDrawerSelection currentlight is null, not highlighting\");\n return;\n } else if (this.reattemptJumpToWidgetSettingsFlag) {\n this.reattemptJumpToWidgetSettingsFlag = false;\n attemptToJumpToWidgetSettings();\n }\n }\n if (this.currentLight.getGroupNumber() == 0 && this.broadcastingToGroup) {\n Log.i(tag, \"highlightDrawer, currentlight in unassigned was broadcasting to group, setting false \");\n this.broadcastingToGroup = false;\n }\n for (int i = 0; i < this.drawerLinearLayout.getChildCount(); i++) {\n ViewGroup drawerEntry = (ViewGroup) this.drawerLinearLayout.getChildAt(i);\n if (drawerEntry.getTag() != null) {\n if (drawerEntry.getTag() instanceof Light) {\n if (drawerEntry.getTag() == this.currentLight && !this.broadcastingToGroup) {\n drawerEntry.setBackgroundColor(ContextCompat.getColor(getApplicationContext(), R.color.colorDrawerItemSelected));\n }\n } else if (((LinkedList) drawerEntry.getTag()).contains(this.currentLight) && this.broadcastingToGroup) {\n drawerEntry.setBackgroundColor(ContextCompat.getColor(getApplicationContext(), R.color.colorDrawerItemSelected));\n }\n }\n }\n }",
"public boolean isSetColor() {\r\n return this.color != null;\r\n }",
"@Override\n protected boolean canHighlight(Component component,\n ComponentAdapter adapter) {\n return component instanceof JComponent;\n }"
]
| [
"0.7875646",
"0.7495592",
"0.7254078",
"0.7223895",
"0.69905454",
"0.69596106",
"0.6957528",
"0.68418455",
"0.67356306",
"0.6729636",
"0.66835886",
"0.66381264",
"0.6579753",
"0.6504736",
"0.6494656",
"0.6440815",
"0.6427222",
"0.64081794",
"0.64007556",
"0.63357025",
"0.632471",
"0.62923795",
"0.62497103",
"0.6232839",
"0.6230555",
"0.62107736",
"0.6182483",
"0.61784834",
"0.6148968",
"0.6147473",
"0.6130561",
"0.61226416",
"0.60771525",
"0.6072637",
"0.6068426",
"0.6066799",
"0.6040312",
"0.6035121",
"0.59940743",
"0.59838057",
"0.59718406",
"0.59608805",
"0.5939814",
"0.59119844",
"0.58970046",
"0.5896904",
"0.58868873",
"0.5864533",
"0.5863522",
"0.5861542",
"0.58421665",
"0.5836064",
"0.58354723",
"0.58318216",
"0.58309525",
"0.58124095",
"0.58114433",
"0.5802748",
"0.5795491",
"0.57845515",
"0.5769324",
"0.57453024",
"0.573044",
"0.57264173",
"0.5725357",
"0.571963",
"0.57179505",
"0.5717317",
"0.5715307",
"0.571174",
"0.57054126",
"0.57042867",
"0.57021415",
"0.5693775",
"0.56888247",
"0.56839603",
"0.5683474",
"0.56560254",
"0.5655329",
"0.5651809",
"0.5651809",
"0.56356484",
"0.5631862",
"0.5620006",
"0.5615985",
"0.56126416",
"0.56078863",
"0.55929595",
"0.55886114",
"0.55864125",
"0.55773157",
"0.5566424",
"0.55623436",
"0.5557439",
"0.5552409",
"0.5549825",
"0.55386776",
"0.553485",
"0.553463",
"0.55341876"
]
| 0.63519174 | 19 |
Creates new form combinacion | public combinacion() {
initComponents();
eventos();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"FORM createFORM();",
"public static Result newForm() {\n return ok(newForm.render(palletForm, setOfArticleForm));\n }",
"public FormInserir() {\n initComponents();\n }",
"public static void create(Formulario form){\n daoFormulario.create(form);\n }",
"public SalidaCajaForm() {\n\t\tinicializarComponentes();\n }",
"public abstract void addSelectorForm();",
"private void azzeraInsertForm() {\n\t\tviewInserimento.getCmbbxTipologia().setSelectedIndex(-1);\n\t\tviewInserimento.getTxtFieldDataI().setText(\"\");\n\t\tviewInserimento.getTxtFieldValore().setText(\"\");\n\t\tviewInserimento.getTxtFieldDataI().setBackground(Color.white);\n\t\tviewInserimento.getTxtFieldValore().setBackground(Color.white);\n\t}",
"protected abstract void addFormComponents(final Form<T> form);",
"public creacionempresa() {\n initComponents();\n mostrardatos();\n }",
"private void creatingElements() {\n\t\ttf1 = new JTextField(20);\n\t\ttf2 = new JTextField(20);\n\t\ttf3 = new JTextField(20);\n\t\tJButton btn = new JButton(\"Add\");\n\t\tbtn.addActionListener(control);\n\t\tbtn.setActionCommand(\"add\");\n\t\t\n\t\tJPanel panel = new JPanel();\n\t\tpanel.add(tf1);\n\t\tpanel.add(tf2);\n\t\tpanel.add(btn);\n\t\tpanel.add(tf3);\n\t\t\n\t\tthis.add(panel);\n\t\t\n\t\tthis.validate();\n\t\tthis.repaint();\t\t\n\t\t\n\t}",
"@GetMapping(\"/createRegistro\")\n\tpublic String crearValidacion(Model model) {\n\t\tList<Barrio> localidades = barrioService.obtenerBarrios();\n\t\tmodel.addAttribute(\"localidades\",localidades);\n\t\tmodel.addAttribute(\"persona\",persona);\n\t\tmodel.addAttribute(\"validacion\",validacion);\n\t\tmodel.addAttribute(\"registro\",registro);\n\t\tmodel.addAttribute(\"barrio\",barrio);\n\t\treturn \"RegistroForm\";\n\t}",
"public Form_soal() {\n initComponents();\n tampil_soal();\n }",
"public Formulario() {\n initComponents();\n }",
"public GestaoFormando() {\n \n initComponents();\n listarEquipamentos();\n listarmapainscritos();\n }",
"public Form getCreationForm() throws ProcessManagerException {\r\n try {\r\n Action creation = processModel.getCreateAction();\r\n return processModel.getPublicationForm(creation.getName(), currentRole,\r\n getLanguage());\r\n } catch (WorkflowException e) {\r\n throw new ProcessManagerException(\"SessionController\",\r\n \"processManager.ERR_NO_CREATION_FORM\", e);\r\n }\r\n }",
"public FormCadastroAutomovel() {\n initComponents();\n }",
"public void onNew() {\t\t\n\t\tdesignWidget.addNewForm();\n\t}",
"public CrearProductos() {\n initComponents();\n }",
"@GetMapping(\"/add\")\n public String showSocioForm(Model model, Persona persona) {\n List<Cargo> cargos = cargoService.getCargos();\n model.addAttribute(\"cargos\", cargos);\n return \"/backoffice/socioForm\";\n }",
"public void limpiarCamposFormBusqueda() {\n\t}",
"public static Result startNewForm() {\r\n\t\tString formName = ChangeOrderForm.NAME;\r\n\t\tDecision firstDecision = CMSGuidedFormFill.startNewForm(formName,\r\n\t\t\t\tCMSSession.getEmployeeName(), CMSSession.getEmployeeId());\r\n\t\treturn ok(backdrop.render(firstDecision));\r\n\t}",
"@RequestMapping(value={\"/projects/add\"}, method= RequestMethod.GET)\r\n\tpublic String createProjectForm(Model model) {\r\n\t\tUser loggedUser= sessionData.getLoggedUser();\r\n\t\tmodel.addAttribute(\"loggedUser\", loggedUser);\r\n\t\tmodel.addAttribute(\"projectForm\", new Project());\r\n\t\treturn \"addProject\";\r\n\t}",
"@Command\n\tpublic void nuevoAnalista(){\n\t\tMap<String, Object> parametros = new HashMap<String, Object>();\n\n\t\t//parametros.put(\"recordMode\", \"NEW\");\n\t\tllamarFormulario(\"formularioAnalistas.zul\", null);\n\t}",
"public Form(){\n\t\ttypeOfLicenseApp = new TypeOfLicencsApplication();\n\t\toccupationalTrainingList = new ArrayList<OccupationalTraining>();\n\t\taffiadavit = new Affidavit();\n\t\tapplicationForReciprocity = new ApplicationForReciprocity();\n\t\teducationBackground = new EducationBackground();\n\t\toccupationalLicenses = new OccupationalLicenses();\n\t\tofficeUseOnlyInfo = new OfficeUseOnlyInfo();\n\t}",
"public Result inicioGenerarLibro(){\n ContabilidadDTO dto = new ContabilidadDTO();\n dto.tipoLibro = new Parametro(\"\",\"LVEN\",\"\");\n //dto.tipoLibro.id.codigo =\"LVEN\";\n dto.anio = new Parametro(\"\",\"2018\",\"\");\n //dto.anio.id.codigo =\"2018\";\n dto.mes = new Parametro(\"\",\"3\",\"\");\n //dto.mes.id.codigo =\"3\"; //Simpre debe ser el mes anterior al actual\n\n Form<ContabilidadDTO> contabilidadDTOForm = formFactory.form(ContabilidadDTO.class).fill(dto);\n\n/*\n EbeanServer db = DBConnectionUtil.getDBServerFacturador();\n List<BandejaFactura> lista = db.find(BandejaFactura.class).findList();; //BandejaFactura.find.all();//obtenerTodos();\n for (BandejaFactura x:lista) {\n System.out.println(x);\n }\n*/\n/*\n EbeanServer db = DBConnectionUtil.getDBServerSGV();\n List<ControlVenta> lista = db.find(ControlVenta.class)\n .where().ilike(\"CVNT_NUM_DOCUMENTO\", \"F002-00000213\")\n .findList();\n for (ControlVenta x:lista) {\n System.out.println(\"*********** \"+x);\n }\n*/\n/*\n EbeanServer db = DBConnectionUtil.getDBServerSGV();\n List<ControlVenta> lista = db.find(ControlVenta.class).findList();; //BandejaFactura.find.all();//obtenerTodos();\n for (ControlVenta x:lista) {\n System.out.println(x);\n }\n*/\n\n return ok(generadorLibrosContables.render(contabilidadDTOForm));\n }",
"public Gui_lectura_consumo() {\n initComponents();\n centrarform();\n consumo_capturado.setEditable(false);\n limpiarCajas();\n \n \n }",
"public String nuevo() {\n\n\t\tLOG.info(\"Submitado formulario, accion nuevo\");\n\t\tString view = \"/alumno/form\";\n\n\t\t// las validaciones son correctas, por lo cual los datos del formulario estan en\n\t\t// el atributo alumno\n\n\t\t// TODO simular index de la bbdd\n\t\tint id = this.alumnos.size();\n\t\tthis.alumno.setId(id);\n\n\t\tLOG.debug(\"alumno: \" + this.alumno);\n\n\t\t// TODO comprobar edad y fecha\n\n\t\talumnos.add(alumno);\n\t\tview = VIEW_LISTADO;\n\t\tmockAlumno();\n\n\t\t// mensaje flash\n\t\tFacesContext facesContext = FacesContext.getCurrentInstance();\n\t\tExternalContext externalContext = facesContext.getExternalContext();\n\t\texternalContext.getFlash().put(\"alertTipo\", \"success\");\n\t\texternalContext.getFlash().put(\"alertMensaje\", \"Alumno \" + this.alumno.getNombre() + \" creado con exito\");\n\n\t\treturn view + \"?faces-redirect=true\";\n\t}",
"@Override\n\tpublic void onFormCreate(AbstractForm arg0, DataMsgBus arg1) {\n\t}",
"public Form(){ \n\t\tsuper(tag(Form.class)); \n\t}",
"@GetMapping(\"/add\")\n\tpublic String showFormForAdd(Model model) {\n\t\tMemo memo = new Memo();\n\t\t\n\t\t// load categories for select options\n\t\tMap<String, String> mapCategories = generateMapCategories();\n\t\t\n\t\t// add to the model\n\t\tmodel.addAttribute(\"memo\", memo);\n\t\tmodel.addAttribute(\"categories\", mapCategories);\n\t\t\n\t\treturn \"add\";\n\t}",
"public CadastroProdutoNew() {\n initComponents();\n }",
"public frm_tutor_subida_prueba() {\n }",
"private void createForm(ArrayList<HashMap<String, String>> data) {\n\t\tLayoutInflater inflater = LayoutInflater.from(IPropertyRegistrationActivity.this);\n\t\tLinearLayout.LayoutParams params = new LinearLayout.LayoutParams(android.widget.LinearLayout.LayoutParams.MATCH_PARENT,\n\t\t\t\tandroid.widget.LinearLayout.LayoutParams.WRAP_CONTENT);\n\t\tparams.topMargin = 10;\n\n\t\tfields = data;\n\t\tLinearLayout layout = null;\n\t\tint len = fields.size();\n\t\tfor (int j = 0; j < len; j++) {\n\t\t\tfinal HashMap<String, String> field = fields.get(j);\n\t\t\tView fieldView = inflater.inflate(R.layout.iproperty_registration_dynamic_view_item, null);\n\n\t\t\tif (field.get(TYPE).equals(LABEL)) {\n\t\t\t\tfinal IjoomerEditText edit;\n\t\t\t\tlayout = ((LinearLayout) fieldView.findViewById(R.id.lnrLabel));\n\t\t\t\tlayout.setVisibility(View.VISIBLE);\n\t\t\t\tedit = ((IjoomerEditText) layout.findViewById(R.id.txtValue));\n\t\t\t} else if (field.get(TYPE).equals(PASSWORD)) {\n\t\t\t\tfinal IjoomerEditText edit;\n\t\t\t\tlayout = ((LinearLayout) fieldView.findViewById(R.id.lnrEdit));\n\t\t\t\tlayout.setVisibility(View.VISIBLE);\n\t\t\t\tedit = ((IjoomerEditText) layout.findViewById(R.id.txtValue));\n\t\t\t\tif (field.get(NAME).contains(getString(R.string.phone)) || field.get(NAME).contains(getString(R.string.year))) {\n\t\t\t\t\tedit.setInputType(InputType.TYPE_CLASS_NUMBER);\n\t\t\t\t} else if (field.get(NAME).contains(getString(R.string.website)) || field.get(NAME).contains(getString(R.string.email))) {\n\t\t\t\t\tedit.setInputType(InputType.TYPE_TEXT_VARIATION_EMAIL_ADDRESS);\n\t\t\t\t}\n\t\t\t} else if (field.get(TYPE).equals(TEXT)) {\n\t\t\t\tfinal IjoomerEditText edit;\n\t\t\t\tlayout = ((LinearLayout) fieldView.findViewById(R.id.lnrEdit));\n\t\t\t\tlayout.setVisibility(View.VISIBLE);\n\t\t\t\tedit = ((IjoomerEditText) layout.findViewById(R.id.txtValue));\n\t\t\t\tif (field.get(NAME).contains(getString(R.string.phone)) || field.get(NAME).contains(getString(R.string.year))) {\n\t\t\t\t\tedit.setInputType(InputType.TYPE_CLASS_NUMBER);\n\t\t\t\t} else if (field.get(NAME).contains(getString(R.string.website)) || field.get(NAME).contains(getString(R.string.email))) {\n\t\t\t\t\tedit.setInputType(InputType.TYPE_TEXT_VARIATION_EMAIL_ADDRESS);\n\t\t\t\t}\n\t\t\t} else if (field.get(TYPE).equals(TEXTAREA)) {\n\t\t\t\tfinal IjoomerEditText edit;\n\t\t\t\tlayout = ((LinearLayout) fieldView.findViewById(R.id.lnrEditArea));\n\t\t\t\tlayout.setVisibility(View.VISIBLE);\n\t\t\t\tedit = ((IjoomerEditText) layout.findViewById(R.id.txtValue));\n\n\t\t\t\tif (field.get(VALUE).toString().trim().length() > 0) {\n\t\t\t\t\tedit.setText(field.get(VALUE));\n\t\t\t\t} else {\n\t\t\t\t}\n\n\t\t\t} else if (field.get(TYPE).equals(MAP)) {\n\t\t\t\tfinal IjoomerEditText edit;\n\t\t\t\tfinal ImageView imgMap;\n\t\t\t\tlayout = ((LinearLayout) fieldView.findViewById(R.id.lnrEditMap));\n\t\t\t\tlayout.setVisibility(View.VISIBLE);\n\t\t\t\tedit = ((IjoomerEditText) layout.findViewById(R.id.txtValue));\n\t\t\t\timgMap = ((ImageView) layout.findViewById(R.id.imgMap));\n\t\t\t\tif (field.get(NAME).equalsIgnoreCase(getString(R.string.state))) {\n\t\t\t\t\ttry {\n\t\t\t\t\t\tAddress address = IjoomerUtilities.getAddressFromLatLong(0, 0);\n\t\t\t\t\t\tedit.setText(address.getAdminArea().replace(address.getCountryName() == null ? \"\" : address.getCountryName(), \"\")\n\t\t\t\t\t\t\t\t.replace(address.getPostalCode() == null ? \"\" : address.getPostalCode(), \"\"));\n\t\t\t\t\t} catch (Throwable e) {\n\t\t\t\t\t\tedit.setText(\"\");\n\t\t\t\t\t}\n\t\t\t\t} else if (field.get(NAME).equalsIgnoreCase(getString(R.string.city_town))) {\n\t\t\t\t\ttry {\n\t\t\t\t\t\tAddress address = IjoomerUtilities.getAddressFromLatLong(0, 0);\n\t\t\t\t\t\tedit.setText(address.getSubAdminArea());\n\t\t\t\t\t} catch (Throwable e) {\n\t\t\t\t\t\tedit.setText(\"\");\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t\timgMap.setOnClickListener(new OnClickListener() {\n\n\t\t\t\t\t@Override\n\t\t\t\t\tpublic void onClick(View v) {\n\t\t\t\t\t\teditMap = edit;\n\t\t\t\t\t\tIntent intent = new Intent(IPropertyRegistrationActivity.this, IjoomerMapAddress.class);\n\t\t\t\t\t\tstartActivityForResult(intent, GET_ADDRESS_FROM_MAP);\n\t\t\t\t\t}\n\t\t\t\t});\n\n\t\t\t} else if (field.get(TYPE).equals(SELECT)) {\n\t\t\t\tlayout = ((LinearLayout) fieldView.findViewById(R.id.lnrSpin));\n\t\t\t\tlayout.setVisibility(View.VISIBLE);\n\t\t\t\tfinal Spinner spn;\n\t\t\t\tspn = ((Spinner) layout.findViewById(R.id.txtValue));\n\t\t\t\tspn.setAdapter(IjoomerUtilities.getSpinnerAdapter(field));\n\t\t\t\tif (field.get(NAME).equalsIgnoreCase(getString(R.string.country))) {\n\n\t\t\t\t\ttry {\n\t\t\t\t\t\tAddress address = IjoomerUtilities.getAddressFromLatLong(0, 0);\n\t\t\t\t\t\tString country = address.getCountryName();\n\t\t\t\t\t\tint selectedIndex = 0;\n\t\t\t\t\t\tJSONArray jsonArray = null;\n\n\t\t\t\t\t\tjsonArray = new JSONArray(field.get(OPTIONS));\n\t\t\t\t\t\tint optionSize = jsonArray.length();\n\t\t\t\t\t\tfor (int k = 0; k < optionSize; k++) {\n\t\t\t\t\t\t\tJSONObject options = (JSONObject) jsonArray.get(k);\n\n\t\t\t\t\t\t\tif (options.getString(VALUE).equalsIgnoreCase(country)) {\n\t\t\t\t\t\t\t\tselectedIndex = k;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\tspn.setSelection(selectedIndex);\n\t\t\t\t\t} catch (Throwable e) {\n\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t\tspn.setSelection(0);\n\t\t\t\t\t}\n\n\t\t\t\t}\n\n\t\t\t} else if (field.get(TYPE).equals(DATE)) {\n\t\t\t\tfinal IjoomerEditText edit;\n\t\t\t\tlayout = ((LinearLayout) fieldView.findViewById(R.id.lnrEditClickable));\n\t\t\t\tlayout.setVisibility(View.VISIBLE);\n\t\t\t\tedit = ((IjoomerEditText) layout.findViewById(R.id.txtValue));\n\t\t\t\tedit.setOnClickListener(new OnClickListener() {\n\n\t\t\t\t\t@Override\n\t\t\t\t\tpublic void onClick(final View v) {\n\t\t\t\t\t\tIjoomerUtilities.getDateDialog(((IjoomerEditText) v).getText().toString(), true, new CustomClickListner() {\n\n\t\t\t\t\t\t\t@Override\n\t\t\t\t\t\t\tpublic void onClick(String value) {\n\t\t\t\t\t\t\t\t((IjoomerEditText) v).setText(value);\n\t\t\t\t\t\t\t\t((IjoomerEditText) v).setError(null);\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t});\n\n\t\t\t\t\t}\n\t\t\t\t});\n\n\t\t\t} else if (field.get(TYPE).equals(TIME)) {\n\t\t\t\tfinal IjoomerEditText edit;\n\t\t\t\tlayout = ((LinearLayout) fieldView.findViewById(R.id.lnrEditClickable));\n\t\t\t\tlayout.setVisibility(View.VISIBLE);\n\t\t\t\tedit = ((IjoomerEditText) layout.findViewById(R.id.txtValue));\n\t\t\t\tedit.setOnClickListener(new OnClickListener() {\n\n\t\t\t\t\t@Override\n\t\t\t\t\tpublic void onClick(final View v) {\n\t\t\t\t\t\tIjoomerUtilities.getTimeDialog(((IjoomerEditText) v).getText().toString(), new CustomClickListner() {\n\n\t\t\t\t\t\t\t@Override\n\t\t\t\t\t\t\tpublic void onClick(String value) {\n\t\t\t\t\t\t\t\t((IjoomerEditText) v).setText(value);\n\t\t\t\t\t\t\t\t((IjoomerEditText) v).setError(null);\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t});\n\n\t\t\t\t\t}\n\t\t\t\t});\n\n\t\t\t} else if (field.get(TYPE).equals(MULTIPLESELECT)) {\n\t\t\t\tfinal IjoomerEditText edit;\n\t\t\t\tlayout = ((LinearLayout) fieldView.findViewById(R.id.lnrEditClickable));\n\t\t\t\tlayout.setVisibility(View.VISIBLE);\n\t\t\t\tedit = ((IjoomerEditText) layout.findViewById(R.id.txtValue));\n\t\t\t\tedit.setOnClickListener(new OnClickListener() {\n\n\t\t\t\t\t@Override\n\t\t\t\t\tpublic void onClick(final View v) {\n\t\t\t\t\t\tIjoomerUtilities.getMultiSelectionDialog(field.get(NAME), field.get(OPTIONS), ((IjoomerEditText) v).getText().toString(), new CustomClickListner() {\n\n\t\t\t\t\t\t\t@Override\n\t\t\t\t\t\t\tpublic void onClick(String value) {\n\t\t\t\t\t\t\t\t((IjoomerEditText) v).setText(value);\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t});\n\n\t\t\t\t\t}\n\t\t\t\t});\n\t\t\t}\n\n\t\t\tif (field.get(REQUIRED).equalsIgnoreCase(\"1\")) {\n\t\t\t\t((IjoomerTextView) layout.findViewById(R.id.txtLable)).setText(field.get(NAME) + \" *\");\n\t\t\t} else {\n\t\t\t\t((IjoomerTextView) layout.findViewById(R.id.txtLable)).setText(field.get(NAME));\n\t\t\t}\n\n\t\t\t((LinearLayout) fieldView.findViewById(R.id.lnrEdit)).setVisibility(View.GONE);\n\t\t\t((LinearLayout) fieldView.findViewById(R.id.lnrEditArea)).setVisibility(View.GONE);\n\t\t\t((LinearLayout) fieldView.findViewById(R.id.lnrSpin)).setVisibility(View.GONE);\n\t\t\t((LinearLayout) fieldView.findViewById(R.id.lnrEditClickable)).setVisibility(View.GONE);\n\t\t\t((LinearLayout) fieldView.findViewById(R.id.lnrLabel)).setVisibility(View.GONE);\n\n\t\t\tlayout = ((LinearLayout) fieldView.findViewById(R.id.lnrReadOnly));\n\t\t\tlayout.setVisibility(View.VISIBLE);\n\n\t\t\t((IjoomerTextView) layout.findViewById(R.id.txtLable)).setText(field.get(NAME));\n\t\t\t((IjoomerEditText) layout.findViewById(R.id.txtValue)).setText(field.get(VALUE));\n\t\t\tfieldView.setTag(field);\n\t\t\tlnr_form.addView(fieldView, params);\n\t\t}\n\t}",
"public frmAfiliado() {\n initComponents();\n \n }",
"public abstract void addEditorForm();",
"public FormularioP() {\n initComponents();\n }",
"public CrearPedidos() {\n initComponents();\n }",
"public FormCompra() {\n initComponents();\n }",
"public FrmInsertar() {\n initComponents();\n }",
"public FormularioPregunta() {\n initComponents();\n \n setLocationRelativeTo(this);\n }",
"@RequestMapping(value = \"/newrecipe\", method = RequestMethod.GET)\n\tpublic String newRecipeForm(Model model) {\n\t\tmodel.addAttribute(\"recipe\", new Recipe()); //empty recipe object\n\t\tmodel.addAttribute(\"categories\", CatRepo.findAll());\n\t\treturn \"newrecipe\";\n\t}",
"Compuesta createCompuesta();",
"@RequestMapping(params = \"new\", method = RequestMethod.GET)\n\t@PreAuthorize(\"hasRole('ADMIN')\")\n\tpublic String createProductForm(Model model) { \t\n \t\n\t\t//Security information\n\t\tmodel.addAttribute(\"admin\",security.isAdmin()); \n\t\tmodel.addAttribute(\"loggedUser\", security.getLoggedInUser());\n\t\t\n\t model.addAttribute(\"product\", new Product());\n\t return \"products/newProduct\";\n\t}",
"public Ventaform() {\n initComponents();\n }",
"public TorneoForm() {\n initComponents();\n }",
"private void initFormCreateMode() {\n initSpinnerSelectionChamps();\n //TODO\n }",
"@Override\n\tpublic void createForm(ERForm form) {\n\t\t\tString sql = \"insert into project1.reimbursementInfo (userName, fullName, thedate, eventstartdate, thelocation, description, thecost, gradingformat, passingpercentage, eventtype, filename,status,reason) values (?,?,?,?,?,?,?,?,?,?,?,?,?);\";\n\t\t\ttry {PreparedStatement stmt = conn.prepareCall(sql);\n\t\t\t//RID should auto increment, so this isnt necessary\n\t\t\t\n\t\t\tstmt.setString(1, form.getUserName());\n\t\t\tstmt.setString(2, form.getFullName());\n\t\t\tstmt.setDate(3, Date.valueOf(form.getTheDate()));\n\t\t\tstmt.setDate(4, Date.valueOf(form.getEventStartDate()));\n\t\t\tstmt.setString(5, form.getTheLocation());\n\t\t\tstmt.setString(6, form.getDescription());\n\t\t\tstmt.setDouble(7, form.getTheCost());\n\t\t\tstmt.setString(8, form.getGradingFormat());\n\t\t\tstmt.setString(9, form.getPassingPercentage());\n\t\t\tstmt.setString(10, form.getEventType());\n\t\t\tstmt.setString(11, form.getFileName());\n\t\t\tstmt.setString(12, \"pending\");\n\t\t\tstmt.setString(13, \"\");\n\t\t\tstmt.executeUpdate();\n\t\t\t\n\t\t} catch (SQLException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public FormImportar() {\n initComponents();\n }",
"public void registrarMateria() {\n materia.setIdDepartamento(departamento);\n ejbFacade.create(materia);\n RequestContext requestContext = RequestContext.getCurrentInstance();\n requestContext.execute(\"PF('MateriaCreateDialog').hide()\");\n items = ejbFacade.findAll();\n departamento = new Departamento();\n materia = new Materia();\n\n FacesMessage msg = new FacesMessage(FacesMessage.SEVERITY_INFO, \"Información\", \"La materia se registró con éxito\");\n FacesContext.getCurrentInstance().addMessage(null, msg);\n requestContext.update(\"msg\");//Actualiza la etiqueta growl para que el mensaje pueda ser mostrado\n\n requestContext.update(\"MateriaListForm\");\n requestContext.update(\"MateriaCreateForm\");\n }",
"public FormUtama() {\n initComponents();\n }",
"@GetMapping(\"/addPharmacist\")\n public String pharmacistForm(Model model) {\n model.addAttribute(\"pharmacist\", new Pharmacist());\n return \"addPharmacist\";\n }",
"public void crearAbonar(){\n \t\n getContentPane().setLayout(new BorderLayout());\n \n p1 = new JPanel();\n\t\tp2 = new JPanel();\n \n\t\t// Not used anymore\n\t\t//String[] a={\"Regresar\",\"Continuar\"},c={\"Cuenta\",\"Monto\"};\n \n\t\t// Layout : # row, # columns\n\t\tp1.setLayout(new GridLayout(1,2));\n \n\t\t// Create the JTextField : Cuenta\n\t\t// And add it to the panel\n tf = new JTextField(\"Cuenta\");\n textos.add(tf);\n tf.setPreferredSize(new Dimension(10,100));\n p1.add(tf);\n\n\t\t// Create the JTextField : Monto\n\t\t// And add it to the panel\n tf = new JTextField(\"Monto\");\n textos.add(tf);\n tf.setPreferredSize(new Dimension(10,100));\n p1.add(tf);\n \n // Add the panel to the Frame layout\n add(p1, BorderLayout.NORTH);\n \n // Create the button Regresar\n buttonRegresar = new JButton(\"Regresar\");\n botones.add(buttonRegresar);\n\n // Create the button Continuar\n buttonContinuar = new JButton(\"Continuar\");\n botones.add(buttonContinuar);\n \n // Layout : 1 row, 2 columns\n p2.setLayout(new GridLayout(1,2));\n \n // Add the buttons to the layout\n for(JButton x:botones){\n x.setPreferredSize(new Dimension(110,110));\n p2.add(x);\n }\n \n // Add the panel to the Frame layout\n add(p2, BorderLayout.SOUTH);\n }",
"@GetMapping(\"/producto/nuevo\")\n\tpublic String nuevoProductoForm(Model model) {\n\t\tmodel.addAttribute(\"producto\", new Producto());\n\t\treturn \"app/producto/form\";\n\t}",
"public CreateAccount() {\n initComponents();\n selectionall();\n }",
"private void initFormulario() {\n btnCadastro = findViewById(R.id.btnCadastro);\n editNome = findViewById(R.id.editNome);\n editEmail = findViewById(R.id.editEmail);\n editSenhaA = findViewById(R.id.editSenha);\n editSenhaB = findViewById(R.id.editSenhaB);\n chTermo = findViewById(R.id.chTermos);\n isFormOk = false;\n }",
"public FormularioCliente() {\n initComponents();\n }",
"public void CrearNew(ActionEvent e) {\n List<Pensum> R = ejbFacade.existePensumID(super.getSelected().getIdpensum());\n if(R.isEmpty()){\n super.saveNew(e);\n }else{\n new Auxiliares().setMsj(3,\"PENSUM ID YA EXISTE\");\n }\n }",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents() {\n\n jLabelMatricula = new javax.swing.JLabel();\n jTextFieldAtividadesMatricula = new javax.swing.JTextField();\n jLabelNome = new javax.swing.JLabel();\n jTextFieldAtividadesNome = new javax.swing.JTextField();\n jComboBoxAtividadesTipo = new javax.swing.JComboBox<>();\n jLabelData = new javax.swing.JLabel();\n jLabelTipo = new javax.swing.JLabel();\n jTextFieldAtividadesData = new javax.swing.JFormattedTextField();\n jLabelLocal = new javax.swing.JLabel();\n jTextFieldAtividadesLocal = new javax.swing.JTextField();\n jLabelDescricao = new javax.swing.JLabel();\n jButtonAtividadesInserir = new javax.swing.JButton();\n jScrollPane1 = new javax.swing.JScrollPane();\n jTextAreaAtividadesDescricao = new javax.swing.JTextArea();\n jButtonLimpar = new javax.swing.JButton();\n\n setClosable(true);\n setIconifiable(true);\n setMaximizable(true);\n setResizable(true);\n setTitle(\"Inserir Atividades\");\n addInternalFrameListener(new javax.swing.event.InternalFrameListener() {\n public void internalFrameActivated(javax.swing.event.InternalFrameEvent evt) {\n formInternalFrameActivated(evt);\n }\n public void internalFrameClosed(javax.swing.event.InternalFrameEvent evt) {\n }\n public void internalFrameClosing(javax.swing.event.InternalFrameEvent evt) {\n }\n public void internalFrameDeactivated(javax.swing.event.InternalFrameEvent evt) {\n }\n public void internalFrameDeiconified(javax.swing.event.InternalFrameEvent evt) {\n }\n public void internalFrameIconified(javax.swing.event.InternalFrameEvent evt) {\n }\n public void internalFrameOpened(javax.swing.event.InternalFrameEvent evt) {\n formInternalFrameOpened(evt);\n }\n });\n\n jLabelMatricula.setText(\"Matrícula:*\");\n\n jLabelNome.setText(\"Nome:*\");\n\n jComboBoxAtividadesTipo.setModel(new javax.swing.DefaultComboBoxModel<>(new String[] { \"Selecione\", \"Lazer\", \"Trabalho\", \"Escola\", \"Faculdade\", \"Física\" }));\n jComboBoxAtividadesTipo.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n jComboBoxAtividadesTipoActionPerformed(evt);\n }\n });\n\n jLabelData.setText(\"Data:*\");\n\n jLabelTipo.setText(\"Tipo: *\");\n\n try {\n jTextFieldAtividadesData.setFormatterFactory(new javax.swing.text.DefaultFormatterFactory(new javax.swing.text.MaskFormatter(\"##/##/####\")));\n } catch (java.text.ParseException ex) {\n ex.printStackTrace();\n }\n\n jLabelLocal.setText(\"Local:*\");\n\n jLabelDescricao.setText(\"Descrição:\");\n\n jButtonAtividadesInserir.setText(\"Inserir\");\n jButtonAtividadesInserir.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n jButtonAtividadesInserirActionPerformed(evt);\n }\n });\n\n jTextAreaAtividadesDescricao.setColumns(20);\n jTextAreaAtividadesDescricao.setRows(5);\n jScrollPane1.setViewportView(jTextAreaAtividadesDescricao);\n\n jButtonLimpar.setText(\"Limpar\");\n jButtonLimpar.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n jButtonLimparActionPerformed(evt);\n }\n });\n\n javax.swing.GroupLayout layout = new javax.swing.GroupLayout(getContentPane());\n getContentPane().setLayout(layout);\n layout.setHorizontalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addComponent(jLabelMatricula)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addComponent(jTextFieldAtividadesMatricula, javax.swing.GroupLayout.PREFERRED_SIZE, 110, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addGap(18, 18, 18)\n .addComponent(jLabelNome)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addComponent(jTextFieldAtividadesNome))\n .addGroup(javax.swing.GroupLayout.Alignment.TRAILING, layout.createSequentialGroup()\n .addContainerGap(javax.swing.GroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)\n .addComponent(jButtonAtividadesInserir)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addComponent(jButtonLimpar))\n .addGroup(layout.createSequentialGroup()\n .addGap(2, 2, 2)\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addComponent(jLabelTipo)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addComponent(jComboBoxAtividadesTipo, javax.swing.GroupLayout.PREFERRED_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.UNRELATED)\n .addComponent(jLabelData)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addComponent(jTextFieldAtividadesData, javax.swing.GroupLayout.PREFERRED_SIZE, 87, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.UNRELATED)\n .addComponent(jLabelLocal)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addComponent(jTextFieldAtividadesLocal, javax.swing.GroupLayout.DEFAULT_SIZE, 149, Short.MAX_VALUE))\n .addGroup(layout.createSequentialGroup()\n .addComponent(jLabelDescricao)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addComponent(jScrollPane1)))))\n .addContainerGap())\n );\n layout.setVerticalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addContainerGap()\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(jTextFieldAtividadesNome, javax.swing.GroupLayout.PREFERRED_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addComponent(jLabelNome))\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(jLabelMatricula)\n .addComponent(jTextFieldAtividadesMatricula, javax.swing.GroupLayout.PREFERRED_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.PREFERRED_SIZE)))\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.UNRELATED)\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(jComboBoxAtividadesTipo, javax.swing.GroupLayout.PREFERRED_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addComponent(jLabelData)\n .addComponent(jLabelTipo)\n .addComponent(jTextFieldAtividadesData, javax.swing.GroupLayout.PREFERRED_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addComponent(jLabelLocal)\n .addComponent(jTextFieldAtividadesLocal, javax.swing.GroupLayout.PREFERRED_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.PREFERRED_SIZE))\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(jScrollPane1, javax.swing.GroupLayout.DEFAULT_SIZE, 221, Short.MAX_VALUE)\n .addGroup(layout.createSequentialGroup()\n .addComponent(jLabelDescricao)\n .addGap(0, 0, Short.MAX_VALUE)))\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(jButtonAtividadesInserir)\n .addComponent(jButtonLimpar))\n .addGap(1, 1, 1))\n );\n\n pack();\n }",
"public TelaCadastrarProduto() {\n initComponents();\n entidade = new Produto();\n setRepositorio(RepositorioBuilder.getProdutoRepositorio());\n grupo.add(jRadioButton1);\n grupo.add(jRadioButton2);\n }",
"public ServerskaForma() {\n initComponents();\n \n \n \n }",
"public FormPpal() {\n initComponents();\n setIconImage(Toolkit.getDefaultToolkit().getImage(this.getClass().getResource(\"Imagenes/icon.png\")));\n setLocationRelativeTo(null);\n setTitle(\"Men\\372 principal\");\n setResizable(false);\n formBackUp = null;\n formBuscador = null;\n fb1 = null;\n fb2 = null;\n formListado = null;\n conn = new Conn();\n pacientesCumpleanos = new LinkedList();\n pacientesControl = new LinkedList();\n cargarCumpleanos();\n cargarControlesHoy();\n }",
"@RequestMapping(\"/save\")\n\tpublic String createProjectForm(Project project, Model model) {\n\t\t\n\tproRep.save(project);\n\tList<Project> getall = (List<Project>) proRep.getAll();\n\tmodel.addAttribute(\"projects\", getall);\n\t\n\treturn \"listproject\";\n\t\t\n\t}",
"@RequestMapping(method = RequestMethod.POST, value = {\"\",\"/\"})\r\n\tpublic ResponseEntity<FormularioDTO> add(@RequestBody @Valid Formulario formulario) throws AuthenticationException {\r\n\t\tformulario.setInstituicao(new Instituicao(authService.getDados().getInstituicaoId()));\r\n\t\treturn new ResponseEntity<>(formularioService.create(formulario), HttpStatus.CREATED);\r\n\t}",
"public PDMRelationshipForm() {\r\n initComponents();\r\n }",
"private void submitNewUser() {\n\t\tboolean validationFlag = true;\n\t\tArrayList<HashMap<String, String>> signUpFields = new ArrayList<HashMap<String, String>>();\n\t\tint size = lnr_form.getChildCount();\n\t\tfor (int i = 0; i < size; i++) {\n\t\t\tLinearLayout v = (LinearLayout) lnr_form.getChildAt(i);\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tHashMap<String, String> field = (HashMap<String, String>) v.getTag();\n\n\t\t\tIjoomerEditText edtValue = null;\n\t\t\tSpinner spnrValue = null;\n\n\t\t\tif (field != null) {\n\t\t\t\tif (field.get(TYPE).equals(TEXT)) {\n\t\t\t\t\tedtValue = (IjoomerEditText) ((LinearLayout) v.findViewById(R.id.lnrEdit)).findViewById(R.id.txtValue);\n\t\t\t\t} else if (field.get(TYPE).equals(TEXTAREA)) {\n\t\t\t\t\tedtValue = (IjoomerEditText) ((LinearLayout) v.findViewById(R.id.lnrEditArea)).findViewById(R.id.txtValue);\n\t\t\t\t} else if (field.get(TYPE).equals(PASSWORD)) {\n\t\t\t\t\tedtValue = (IjoomerEditText) ((LinearLayout) v.findViewById(R.id.lnrPassword)).findViewById(R.id.txtValue);\n\t\t\t\t} else if (field.get(TYPE).equals(MAP)) {\n\t\t\t\t\tedtValue = (IjoomerEditText) ((LinearLayout) v.findViewById(R.id.lnrEditMap)).findViewById(R.id.txtValue);\n\t\t\t\t} else if (field.get(\"type\").equals(LABEL)) {\n\t\t\t\t\tedtValue = (IjoomerEditText) ((LinearLayout) v.findViewById(R.id.lnrLabel)).findViewById(R.id.txtValue);\n\t\t\t\t} else if (field.get(TYPE).equals(DATE)) {\n\t\t\t\t\tedtValue = (IjoomerEditText) ((LinearLayout) v.findViewById(R.id.lnrEditClickable)).findViewById(R.id.txtValue);\n\n\t\t\t\t\tif (edtValue.getText().toString().trim().length() > 0) {\n\t\t\t\t\t\tif (!IjoomerUtilities.birthdateValidator(edtValue.getText().toString().trim())) {\n\t\t\t\t\t\t\tedtValue.setFocusable(true);\n\t\t\t\t\t\t\tedtValue.setError(getString(R.string.validation_invalid_birth_date));\n\t\t\t\t\t\t\tvalidationFlag = false;\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t} else if (field.get(TYPE).equals(MULTIPLESELECT)) {\n\t\t\t\t\tedtValue = (IjoomerEditText) ((LinearLayout) v.findViewById(R.id.lnrEditClickable)).findViewById(R.id.txtValue);\n\t\t\t\t}\n\t\t\t\tif (field.get(TYPE).equals(TIME)) {\n\t\t\t\t\tedtValue = (IjoomerEditText) ((LinearLayout) v.findViewById(R.id.lnrEditClickable)).findViewById(R.id.txtValue);\n\t\t\t\t}\n\n\t\t\t\tif (field.get(TYPE).equals(SELECT)) {\n\t\t\t\t\tspnrValue = (Spinner) ((LinearLayout) v.findViewById(R.id.lnrSpin)).findViewById(R.id.txtValue);\n\t\t\t\t\tfield.put(VALUE, spnrValue.getSelectedItem().toString());\n\t\t\t\t\tsignUpFields.add(field);\n\t\t\t\t} else if (field.get(TYPE).equals(PASSWORD) && field.get(NAME).equals(\"Retype Password\")) {\n\t\t\t\t\tint len = lnr_form.getChildCount();\n\t\t\t\t\tfor (int j = 0; j < len; j++) {\n\t\t\t\t\t\tLinearLayout view = (LinearLayout) lnr_form.getChildAt(i);\n\t\t\t\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\t\t\t\tHashMap<String, String> row = (HashMap<String, String>) view.getTag();\n\t\t\t\t\t\tif (row.get(TYPE).equals(PASSWORD) && field.get(NAME).equals(\"Password\")) {\n\t\t\t\t\t\t\tString password = ((IjoomerEditText) ((LinearLayout) v.findViewById(R.id.lnrPassword)).findViewById(R.id.txtValue)).getText().toString();\n\t\t\t\t\t\t\tif (password.equals(edtValue.getText().toString())) {\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\t\tedtValue.setError(getString(R.string.validation_password_not_match));\n\t\t\t\t\t\t\t\tvalidationFlag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t} else if (edtValue != null && edtValue.getText().toString().trim().length() <= 0 && (field.get(REQUIRED).equals(\"1\"))) {\n\t\t\t\t\tedtValue.setError(getString(R.string.validation_value_required));\n\t\t\t\t\tvalidationFlag = false;\n\t\t\t\t} else {\n\t\t\t\t\tfield.put(VALUE, edtValue.getText().toString().trim());\n\t\t\t\t\tsignUpFields.add(field);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\n\t\tif (validationFlag) {\n\t\t\tfinal SeekBar proSeekBar = IjoomerUtilities.getLoadingDialog(getString(R.string.dialog_loading_register_newuser));\n\t\t\tnew IjoomerRegistration(this).submitNewUser(signUpFields, new WebCallListener() {\n\n\t\t\t\t@Override\n\t\t\t\tpublic void onProgressUpdate(int progressCount) {\n\t\t\t\t\tproSeekBar.setProgress(progressCount);\n\t\t\t\t}\n\n\t\t\t\t@Override\n\t\t\t\tpublic void onCallComplete(final int responseCode, String errorMessage, ArrayList<HashMap<String, String>> data1, Object data2) {\n\t\t\t\t\tif (responseCode == 200) {\n\t\t\t\t\t\tIjoomerUtilities.getCustomOkDialog(getString(R.string.dialog_loading_profile), getString(R.string.registration_successfully), getString(R.string.ok),\n\t\t\t\t\t\t\t\tR.layout.ijoomer_ok_dialog, new CustomAlertNeutral() {\n\n\t\t\t\t\t\t\t\t\t@Override\n\t\t\t\t\t\t\t\t\tpublic void NeutralMethod() {\n\n\t\t\t\t\t\t\t\t\t\tIntent intent = new Intent(\"clearStackActivity\");\n\t\t\t\t\t\t\t\t\t\tintent.setType(\"text/plain\");\n\t\t\t\t\t\t\t\t\t\tsendBroadcast(intent);\n\t\t\t\t\t\t\t\t\t\tIjoomerWebService.cookies = null;\n\n\t\t\t\t\t\t\t\t\t\tloadNew(IjoomerLoginActivity.class, IPropertyRegistrationActivity.this, true);\n\t\t\t\t\t\t\t\t\t\tfinish();\n\t\t\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\t\t});\n\n\t\t\t\t\t} else {\n\t\t\t\t\t\tIjoomerUtilities.getCustomOkDialog(getString(R.string.dialog_loading_profile),\n\t\t\t\t\t\t\t\tgetString(getResources().getIdentifier(\"code\" + responseCode, \"string\", getPackageName())), getString(R.string.ok), R.layout.ijoomer_ok_dialog,\n\t\t\t\t\t\t\t\tnew CustomAlertNeutral() {\n\n\t\t\t\t\t\t\t\t\t@Override\n\t\t\t\t\t\t\t\t\tpublic void NeutralMethod() {\n\n\t\t\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\t\t});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t});\n\t\t}\n\t}",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents() {\n\n grup1 = new javax.swing.ButtonGroup();\n labInstruccion = new javax.swing.JLabel();\n jLabel3 = new javax.swing.JLabel();\n jLabel4 = new javax.swing.JLabel();\n jLabel5 = new javax.swing.JLabel();\n jLabel6 = new javax.swing.JLabel();\n jLabel7 = new javax.swing.JLabel();\n jLabel8 = new javax.swing.JLabel();\n jLabel9 = new javax.swing.JLabel();\n jLabel10 = new javax.swing.JLabel();\n txtDescripcion = new javax.swing.JTextField();\n txtColor = new javax.swing.JTextField();\n txtPrecioCosto = new javax.swing.JTextField();\n txtCodigo = new javax.swing.JTextField();\n txtMarca = new javax.swing.JTextField();\n txtPrecioVenta = new javax.swing.JTextField();\n txtImpuesto = new javax.swing.JTextField();\n txtEmpresa = new javax.swing.JTextField();\n btnAtras = new javax.swing.JButton();\n btnAgregar = new javax.swing.JButton();\n txtFechaIngreso = new com.toedter.calendar.JDateChooser();\n rdbBolso = new javax.swing.JRadioButton();\n rdbZapato = new javax.swing.JRadioButton();\n jLabel1 = new javax.swing.JLabel();\n cmbGenero = new javax.swing.JComboBox();\n jLabel11 = new javax.swing.JLabel();\n cmbCategoria = new javax.swing.JComboBox();\n jLabel12 = new javax.swing.JLabel();\n txtTalla = new javax.swing.JTextField();\n txtCantidad = new javax.swing.JSpinner();\n jLabel13 = new javax.swing.JLabel();\n btnGenerarCodigo = new javax.swing.JButton();\n jLabel2 = new javax.swing.JLabel();\n jPanel1 = new javax.swing.JPanel();\n\n setDefaultCloseOperation(javax.swing.WindowConstants.DISPOSE_ON_CLOSE);\n setTitle(\"Agregar Producto\");\n setMinimumSize(new java.awt.Dimension(590, 430));\n setPreferredSize(new java.awt.Dimension(590, 430));\n getContentPane().setLayout(new org.netbeans.lib.awtextra.AbsoluteLayout());\n\n labInstruccion.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 16)); // NOI18N\n labInstruccion.setForeground(new java.awt.Color(102, 102, 102));\n labInstruccion.setText(\"Ingrese los datos del nuevo producto:\");\n getContentPane().add(labInstruccion, new org.netbeans.lib.awtextra.AbsoluteConstraints(10, 11, -1, -1));\n\n jLabel3.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel3.setForeground(new java.awt.Color(102, 102, 102));\n jLabel3.setText(\"Descripción:\");\n getContentPane().add(jLabel3, new org.netbeans.lib.awtextra.AbsoluteConstraints(10, 96, -1, -1));\n\n jLabel4.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel4.setForeground(new java.awt.Color(102, 102, 102));\n jLabel4.setText(\"Fecha de Ingreso:\");\n getContentPane().add(jLabel4, new org.netbeans.lib.awtextra.AbsoluteConstraints(290, 60, -1, -1));\n\n jLabel5.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel5.setForeground(new java.awt.Color(102, 102, 102));\n jLabel5.setText(\"Color:\");\n getContentPane().add(jLabel5, new org.netbeans.lib.awtextra.AbsoluteConstraints(440, 180, -1, -1));\n\n jLabel6.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel6.setForeground(new java.awt.Color(102, 102, 102));\n jLabel6.setText(\"Marca:\");\n getContentPane().add(jLabel6, new org.netbeans.lib.awtextra.AbsoluteConstraints(210, 180, -1, -1));\n\n jLabel7.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel7.setForeground(new java.awt.Color(102, 102, 102));\n jLabel7.setText(\"Precio a costo:\");\n getContentPane().add(jLabel7, new org.netbeans.lib.awtextra.AbsoluteConstraints(10, 260, -1, -1));\n\n jLabel8.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel8.setForeground(new java.awt.Color(102, 102, 102));\n jLabel8.setText(\"Precio de venta:\");\n getContentPane().add(jLabel8, new org.netbeans.lib.awtextra.AbsoluteConstraints(330, 260, -1, -1));\n\n jLabel9.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel9.setForeground(new java.awt.Color(102, 102, 102));\n jLabel9.setText(\"Empresa:\");\n getContentPane().add(jLabel9, new org.netbeans.lib.awtextra.AbsoluteConstraints(10, 220, -1, -1));\n\n jLabel10.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel10.setForeground(new java.awt.Color(102, 102, 102));\n jLabel10.setText(\"Impuesto:\");\n getContentPane().add(jLabel10, new org.netbeans.lib.awtextra.AbsoluteConstraints(420, 220, -1, -1));\n\n txtDescripcion.setBackground(new java.awt.Color(237, 237, 237));\n txtDescripcion.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n getContentPane().add(txtDescripcion, new org.netbeans.lib.awtextra.AbsoluteConstraints(80, 93, 480, -1));\n\n txtColor.setBackground(new java.awt.Color(237, 237, 237));\n txtColor.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n txtColor.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n txtColorActionPerformed(evt);\n }\n });\n getContentPane().add(txtColor, new org.netbeans.lib.awtextra.AbsoluteConstraints(480, 180, 80, -1));\n\n txtPrecioCosto.setBackground(new java.awt.Color(237, 237, 237));\n txtPrecioCosto.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n txtPrecioCosto.addKeyListener(new java.awt.event.KeyAdapter() {\n public void keyTyped(java.awt.event.KeyEvent evt) {\n txtPrecioCostoKeyTyped(evt);\n }\n });\n getContentPane().add(txtPrecioCosto, new org.netbeans.lib.awtextra.AbsoluteConstraints(90, 260, 109, -1));\n\n txtCodigo.setEditable(false);\n txtCodigo.setBackground(new java.awt.Color(237, 237, 237));\n txtCodigo.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n txtCodigo.setEnabled(false);\n getContentPane().add(txtCodigo, new org.netbeans.lib.awtextra.AbsoluteConstraints(55, 45, 220, 30));\n\n txtMarca.setBackground(new java.awt.Color(237, 237, 237));\n txtMarca.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n getContentPane().add(txtMarca, new org.netbeans.lib.awtextra.AbsoluteConstraints(260, 180, 130, -1));\n\n txtPrecioVenta.setBackground(new java.awt.Color(237, 237, 237));\n txtPrecioVenta.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n txtPrecioVenta.addKeyListener(new java.awt.event.KeyAdapter() {\n public void keyTyped(java.awt.event.KeyEvent evt) {\n txtPrecioVentaKeyTyped(evt);\n }\n });\n getContentPane().add(txtPrecioVenta, new org.netbeans.lib.awtextra.AbsoluteConstraints(430, 260, 130, -1));\n\n txtImpuesto.setBackground(new java.awt.Color(237, 237, 237));\n txtImpuesto.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n txtImpuesto.addKeyListener(new java.awt.event.KeyAdapter() {\n public void keyTyped(java.awt.event.KeyEvent evt) {\n txtImpuestoKeyTyped(evt);\n }\n });\n getContentPane().add(txtImpuesto, new org.netbeans.lib.awtextra.AbsoluteConstraints(480, 220, 80, -1));\n\n txtEmpresa.setBackground(new java.awt.Color(237, 237, 237));\n txtEmpresa.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n getContentPane().add(txtEmpresa, new org.netbeans.lib.awtextra.AbsoluteConstraints(60, 220, 346, -1));\n\n btnAtras.setBackground(new java.awt.Color(177, 177, 177));\n btnAtras.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n btnAtras.setForeground(new java.awt.Color(51, 51, 51));\n btnAtras.setText(\"Atrás\");\n btnAtras.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n btnAtrasActionPerformed(evt);\n }\n });\n getContentPane().add(btnAtras, new org.netbeans.lib.awtextra.AbsoluteConstraints(10, 329, -1, 40));\n\n btnAgregar.setBackground(new java.awt.Color(177, 177, 177));\n btnAgregar.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n btnAgregar.setForeground(new java.awt.Color(51, 51, 51));\n btnAgregar.setText(\"Agregar\");\n btnAgregar.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n btnAgregarActionPerformed(evt);\n }\n });\n getContentPane().add(btnAgregar, new org.netbeans.lib.awtextra.AbsoluteConstraints(481, 328, -1, 40));\n\n txtFechaIngreso.setBackground(new java.awt.Color(237, 237, 237));\n getContentPane().add(txtFechaIngreso, new org.netbeans.lib.awtextra.AbsoluteConstraints(386, 45, 170, 30));\n\n rdbBolso.setBackground(new java.awt.Color(175, 201, 201));\n grup1.add(rdbBolso);\n rdbBolso.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n rdbBolso.setText(\"Bolso\");\n rdbBolso.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n rdbBolsoActionPerformed(evt);\n }\n });\n getContentPane().add(rdbBolso, new org.netbeans.lib.awtextra.AbsoluteConstraints(505, 11, -1, -1));\n\n rdbZapato.setBackground(new java.awt.Color(175, 201, 201));\n grup1.add(rdbZapato);\n rdbZapato.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n rdbZapato.setText(\"Zapato\");\n rdbZapato.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n rdbZapatoActionPerformed(evt);\n }\n });\n getContentPane().add(rdbZapato, new org.netbeans.lib.awtextra.AbsoluteConstraints(445, 11, -1, -1));\n\n jLabel1.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel1.setForeground(new java.awt.Color(102, 102, 102));\n jLabel1.setText(\"Género:\");\n getContentPane().add(jLabel1, new org.netbeans.lib.awtextra.AbsoluteConstraints(10, 135, -1, -1));\n\n cmbGenero.setModel(new javax.swing.DefaultComboBoxModel(new String[] { \"M\", \"F\" }));\n getContentPane().add(cmbGenero, new org.netbeans.lib.awtextra.AbsoluteConstraints(55, 132, -1, -1));\n\n jLabel11.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel11.setForeground(new java.awt.Color(102, 102, 102));\n jLabel11.setText(\"Categoría:\");\n getContentPane().add(jLabel11, new org.netbeans.lib.awtextra.AbsoluteConstraints(210, 130, -1, -1));\n\n cmbCategoria.setModel(new javax.swing.DefaultComboBoxModel(new String[] { \"Ninos\", \"Jovenes\", \"Adulto\" }));\n getContentPane().add(cmbCategoria, new org.netbeans.lib.awtextra.AbsoluteConstraints(270, 130, 115, -1));\n\n jLabel12.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel12.setForeground(new java.awt.Color(102, 102, 102));\n jLabel12.setText(\"Talla:\");\n getContentPane().add(jLabel12, new org.netbeans.lib.awtextra.AbsoluteConstraints(450, 130, -1, -1));\n\n txtTalla.setBackground(new java.awt.Color(237, 237, 237));\n txtTalla.setFont(new java.awt.Font(\"Yu Gothic UI\", 0, 11)); // NOI18N\n txtTalla.addKeyListener(new java.awt.event.KeyAdapter() {\n public void keyTyped(java.awt.event.KeyEvent evt) {\n txtTallaKeyTyped(evt);\n }\n });\n getContentPane().add(txtTalla, new org.netbeans.lib.awtextra.AbsoluteConstraints(480, 130, 80, -1));\n\n txtCantidad.setModel(new javax.swing.SpinnerNumberModel(Integer.valueOf(1), Integer.valueOf(1), null, Integer.valueOf(1)));\n getContentPane().add(txtCantidad, new org.netbeans.lib.awtextra.AbsoluteConstraints(60, 180, 70, -1));\n\n jLabel13.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel13.setForeground(new java.awt.Color(102, 102, 102));\n jLabel13.setText(\"Cantidad:\");\n getContentPane().add(jLabel13, new org.netbeans.lib.awtextra.AbsoluteConstraints(10, 179, -1, -1));\n\n btnGenerarCodigo.setBackground(new java.awt.Color(177, 177, 177));\n btnGenerarCodigo.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n btnGenerarCodigo.setForeground(new java.awt.Color(51, 51, 51));\n btnGenerarCodigo.setText(\"Generear código\");\n btnGenerarCodigo.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n btnGenerarCodigoActionPerformed(evt);\n }\n });\n getContentPane().add(btnGenerarCodigo, new org.netbeans.lib.awtextra.AbsoluteConstraints(440, 290, -1, -1));\n\n jLabel2.setFont(new java.awt.Font(\"Yu Gothic UI\", 1, 12)); // NOI18N\n jLabel2.setForeground(new java.awt.Color(102, 102, 102));\n jLabel2.setText(\"Código:\");\n getContentPane().add(jLabel2, new org.netbeans.lib.awtextra.AbsoluteConstraints(10, 56, -1, -1));\n\n jPanel1.setBackground(new java.awt.Color(175, 201, 201));\n getContentPane().add(jPanel1, new org.netbeans.lib.awtextra.AbsoluteConstraints(0, 0, 600, 390));\n\n getAccessibleContext().setAccessibleDescription(\"\");\n\n pack();\n setLocationRelativeTo(null);\n }",
"public Create_Course() {\n initComponents();\n comboBoxLec();\n comboBoxDep();\n }",
"public MostraVenta(String idtrasp, Object[][] clienteM1, Object[][] vendedorM1, String idmarc, String responsable,ListaTraspaso panel)\n{\n this.padre = panel;\n this.clienteM = clienteM1;\n this.vendedorM = vendedorM1;\n this.idtraspaso= idtrasp;\n this.idmarca=idmarc;\n//this.tipoenvioM = new String[]{\"INGRESO\", \"TRASPASO\"};\n String tituloTabla =\"Detalle Venta\";\n // padre=panel;\n String nombreBoton1 = \"Registrar\";\n String nombreBoton2 = \"Cancelar\";\n // String nombreBoton3 = \"Eliminar Empresa\";\n\n setId(\"win-NuevaEmpresaForm1\");\n setTitle(tituloTabla);\n setWidth(400);\n setMinWidth(ANCHO);\n setHeight(250);\n setLayout(new FitLayout());\n setPaddings(WINDOW_PADDING);\n setButtonAlign(Position.CENTER);\n setCloseAction(Window.CLOSE);\n setPlain(true);\n\n but_aceptar = new Button(nombreBoton1);\n but_cancelar = new Button(nombreBoton2);\n // addButton(but_aceptarv);\n addButton(but_aceptar);\n addButton(but_cancelar);\n\n formPanelCliente = new FormPanel();\n formPanelCliente.setBaseCls(\"x-plain\");\n //formPanelCliente.setLabelWidth(130);\n formPanelCliente.setUrl(\"save-form.php\");\n formPanelCliente.setWidth(ANCHO);\n formPanelCliente.setHeight(ALTO);\n formPanelCliente.setLabelAlign(Position.LEFT);\n\n formPanelCliente.setAutoWidth(true);\n\n\ndat_fecha1 = new DateField(\"Fecha\", \"d-m-Y\");\n fechahoy = new Date();\n dat_fecha1.setValue(fechahoy);\n dat_fecha1.setReadOnly(true);\n\ncom_vendedor = new ComboBox(\"Vendedor al que enviamos\", \"idempleado\");\ncom_cliente = new ComboBox(\"Clientes\", \"idcliente\");\n//com_tipo = new ComboBox(\"Tipo Envio\", \"idtipo\");\n initValues1();\n\n\n\n formPanelCliente.add(dat_fecha1);\n// formPanelCliente.add(com_tipo);\n// formPanelCliente.add(tex_nombreC);\n// formPanelCliente.add(tex_codigoBarra);\n // formPanelCliente.add(tex_codigoC);\nformPanelCliente.add(com_vendedor);\n formPanelCliente.add(com_cliente);\n add(formPanelCliente);\nanadirListenersTexfield();\n addListeners();\n\n }",
"@RequestMapping(value = \"/add\")\n public String addForm(Model model) {\n model.addAttribute(\"service\",fservice.findAllServices());\n model.addAttribute(\"customer\", mservice.findAllCustomer());\n model.addAttribute(\"customer\", new Customer());\n return \"customer-form\";\n }",
"public frmAddIncidencias() {\n initComponents();\n }",
"Compleja createCompleja();",
"public frmCadastrarProduto() {\n initComponents();\n\n this.cmbCategoria.setEnabled(false);\n this.cmbFornecedor.setEnabled(false);\n this.txtNome.setEnabled(false);\n this.txtDescricao.setEnabled(false);\n this.txtEstoque.setEnabled(false);\n this.txtId.setEnabled(false);\n this.txtPreco.setEnabled(false);\n this.txtPrecoCusto.setEnabled(false);\n this.txtCodBarras.setEnabled(false);\n\n }",
"private void creerMethode() {\n if (estValide()) {\n methode = new Methode();\n methode.setNom(textFieldNom.getText());\n methode.setVisibilite(comboBoxVisibilite.getValue());\n methode.setType(comboBoxType.getValue());\n ArrayList<Parametre> temp = new ArrayList<>();\n for (Parametre parametre : parametreListView.getItems())\n temp.add(parametre);\n methode.setParametres(temp);\n close();\n }\n }",
"public void crearComPag(){\n \n \tgetContentPane().setLayout(new BorderLayout());\n \n \tp1 = new JPanel();\n\t\tp2 = new JPanel();\n \n\t\tString[] a = {\"Regresar\",\"Pagar/Comprar\"}, c = {\"Cuenta\",\"Monto/Cuotas\",\"Descripcion\"}; \n \n\t\tp1.setLayout(new GridLayout(1,2));\n \n\t\tfor (int x=0; x<2; x++) {\n b = new JButton(a[x]);\n botones.add(b);\n }\n for (JButton x:botones) {\n x.setPreferredSize(new Dimension(110,110));\n p1.add(x);\n }\n \n add(p1, BorderLayout.SOUTH);\n \n p2.setLayout(new GridLayout(1,3)); // TO CHANGE?\n \n for (int x=0; x<3; x++) {\n tf = new JTextField(c[x]);\n tf.setPreferredSize(new Dimension(10,100));\n textos.add(tf);\n }\n for (JTextField x:textos) {\n p2.add(x);\n }\n \n add(p2, BorderLayout.NORTH);\n }",
"private void createInputBloodDonationForm( HttpServletRequest req, HttpServletResponse resp )\n throws ServletException, IOException {\n String path = req.getServletPath();\n req.setAttribute( \"path\", path );\n req.setAttribute( \"title\", path.substring( 1 ) );\n \n BloodDonationLogic logic = LogicFactory.getFor(\"BloodDonation\");\n req.setAttribute( \"bloodDonationColumnNames\", logic.getColumnNames().subList(1, logic.getColumnNames().size()));\n req.setAttribute( \"bloodDonationColumnCodes\", logic.getColumnCodes().subList(1, logic.getColumnCodes().size()));\n req.setAttribute(\"bloodGroupList\", Arrays.asList(BloodGroup.values()));\n req.setAttribute(\"rhdList\", Arrays.asList(RhesusFactor.values()));\n BloodBankLogic bloodBankLogic = LogicFactory.getFor(\"BloodBank\");\n List<String> bloodBankIDs = new ArrayList<>();\n bloodBankIDs.add(\"\");\n for (BloodBank bb : bloodBankLogic.getAll()) {\n bloodBankIDs.add(bb.getId().toString());\n }\n req.setAttribute( \"bloodBankIDs\", bloodBankIDs);\n req.setAttribute( \"request\", toStringMap( req.getParameterMap() ) );\n \n if (errorMessage != null && !errorMessage.isEmpty()) {\n req.setAttribute(\"errorMessage\", errorMessage);\n }\n //clear the error message if when reload the page\n errorMessage = \"\";\n \n req.getRequestDispatcher( \"/jsp/CreateRecord-BloodDonation.jsp\" ).forward( req, resp );\n }",
"@GetMapping(\"/create\")\n public ModelAndView create(@ModelAttribute(\"form\") final CardCreateForm form) {\n return getCreateForm(form);\n }",
"public MechanicForm() {\n initComponents();\n }",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents() {\n\n jLabel1 = new javax.swing.JLabel();\n campoNombre = new javax.swing.JTextField();\n jLabel2 = new javax.swing.JLabel();\n campoDescripcion = new javax.swing.JTextField();\n comboCategoria = new javax.swing.JComboBox();\n labelCategoria = new javax.swing.JLabel();\n botonCancelar = new javax.swing.JButton();\n botonAceptar = new javax.swing.JButton();\n\n setDefaultCloseOperation(javax.swing.WindowConstants.DISPOSE_ON_CLOSE);\n setName(\"Form\"); // NOI18N\n\n org.jdesktop.application.ResourceMap resourceMap = org.jdesktop.application.Application.getInstance(gestiontipocampo.GestionTipoCampoApp.class).getContext().getResourceMap(frameTermino.class);\n jLabel1.setText(resourceMap.getString(\"jLabel1.text\")); // NOI18N\n jLabel1.setName(\"jLabel1\"); // NOI18N\n\n campoNombre.setText(resourceMap.getString(\"campoNombre.text\")); // NOI18N\n campoNombre.setName(\"campoNombre\"); // NOI18N\n\n jLabel2.setText(resourceMap.getString(\"jLabel2.text\")); // NOI18N\n jLabel2.setName(\"jLabel2\"); // NOI18N\n\n campoDescripcion.setText(resourceMap.getString(\"campoDescripcion.text\")); // NOI18N\n campoDescripcion.setName(\"campoDescripcion\"); // NOI18N\n\n comboCategoria.setModel(new javax.swing.DefaultComboBoxModel(new String[] { \"Item 1\", \"Item 2\", \"Item 3\", \"Item 4\" }));\n comboCategoria.setName(\"comboCategoria\"); // NOI18N\n\n labelCategoria.setText(resourceMap.getString(\"labelCategoria.text\")); // NOI18N\n labelCategoria.setName(\"labelCategoria\"); // NOI18N\n\n botonCancelar.setText(resourceMap.getString(\"botonCancelar.text\")); // NOI18N\n botonCancelar.setName(\"botonCancelar\"); // NOI18N\n botonCancelar.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n botonCancelarActionPerformed(evt);\n }\n });\n\n botonAceptar.setText(resourceMap.getString(\"botonAceptar.text\")); // NOI18N\n botonAceptar.setName(\"botonAceptar\"); // NOI18N\n botonAceptar.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n botonAceptarActionPerformed(evt);\n }\n });\n\n javax.swing.GroupLayout layout = new javax.swing.GroupLayout(getContentPane());\n getContentPane().setLayout(layout);\n layout.setHorizontalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addGap(182, 182, 182)\n .addComponent(botonAceptar)\n .addGap(18, 18, 18)\n .addComponent(botonCancelar))\n .addGroup(layout.createSequentialGroup()\n .addContainerGap()\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(labelCategoria)\n .addGroup(layout.createSequentialGroup()\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.TRAILING)\n .addGroup(javax.swing.GroupLayout.Alignment.LEADING, layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addComponent(jLabel1)\n .addGap(42, 42, 42))\n .addComponent(campoNombre, javax.swing.GroupLayout.DEFAULT_SIZE, 79, Short.MAX_VALUE))\n .addComponent(comboCategoria, javax.swing.GroupLayout.Alignment.LEADING, javax.swing.GroupLayout.PREFERRED_SIZE, 78, javax.swing.GroupLayout.PREFERRED_SIZE))\n .addGap(10, 10, 10)\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(jLabel2)\n .addComponent(campoDescripcion, javax.swing.GroupLayout.DEFAULT_SIZE, 249, Short.MAX_VALUE))))))\n .addGap(54, 54, 54))\n );\n layout.setVerticalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(javax.swing.GroupLayout.Alignment.TRAILING, layout.createSequentialGroup()\n .addContainerGap()\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(jLabel1)\n .addComponent(jLabel2))\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(campoNombre, javax.swing.GroupLayout.PREFERRED_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addComponent(campoDescripcion, javax.swing.GroupLayout.PREFERRED_SIZE, 20, javax.swing.GroupLayout.PREFERRED_SIZE))\n .addGap(18, 18, 18)\n .addComponent(labelCategoria)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addComponent(comboCategoria, javax.swing.GroupLayout.PREFERRED_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED, 43, Short.MAX_VALUE)\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(botonAceptar)\n .addComponent(botonCancelar))\n .addContainerGap())\n );\n\n pack();\n }",
"protected RespostaFormularioPreenchido() {\n // for ORM\n }",
"public GUI_Tipo_Cadastro() {\n initComponents();\n \n buttonGroup1.add(jRadioButton_Cliente);\n buttonGroup1.add(jRadioButton_Profissional);\n buttonGroup1.add(jRadioButton_Admin);\n \n // Centraliza o JFrame na tela\n this.setLocationRelativeTo(null);\n }",
"public Result addNewRoomType() {\n\n DynamicForm dynamicform = Form.form().bindFromRequest();\n if (dynamicform.get(\"AdminAddRoom\") != null) {\n\n return ok(views.html.AddRoomType.render());\n }\n\n\n return ok(\"Something went wrong\");\n }",
"private void addCom() {\n\n cons = new GridBagConstraints();\n cons.gridx = 0;\n cons.gridy = 0;\n cons.gridwidth = 1;\n cons.fill = GridBagConstraints.HORIZONTAL;\n panelFormulario.add(lbNome, cons);\n\n cons = new GridBagConstraints();\n cons.gridx = 1;\n cons.gridy = 0;\n cons.gridwidth = 2;\n cons.ipadx = 100;\n cons.fill = GridBagConstraints.HORIZONTAL;\n panelFormulario.add(txNome, cons);\n\n //------------------\n cons = new GridBagConstraints();\n cons.gridx = 0;\n cons.gridy = 1;\n cons.gridwidth = 1;\n cons.fill = GridBagConstraints.HORIZONTAL;\n panelFormulario.add(lbSenha, cons);\n\n cons = new GridBagConstraints();\n cons.gridx = 1;\n cons.gridy = 1;\n cons.gridwidth = 2;\n cons.ipadx = 100;\n cons.fill = GridBagConstraints.HORIZONTAL;\n panelFormulario.add(txSenha, cons);\n\n super.add(panelFormulario);\n\n }",
"@GetMapping(value = \"/create\") // https://localhost:8080/etiquetasTipoDisenio/create\n\tpublic String create(Model model) {\n\t\tetiquetasTipoDisenio etiquetasTipoDisenio = new etiquetasTipoDisenio();\n\t\tmodel.addAttribute(\"title\", \"Registro de una nuev entrega\");\n\t\tmodel.addAttribute(\"etiquetasTipoDisenio\", etiquetasTipoDisenio); // similar al ViewBag\n\t\treturn \"etiquetasTipoDisenio/form\"; // la ubicacion de la vista\n\t}",
"public CARGOS_REGISTRO() {\n initComponents();\n InputMap map2 = txtNombre.getInputMap(JTextField.WHEN_FOCUSED); \n map2.put(KeyStroke.getKeyStroke(KeyEvent.VK_V, Event.CTRL_MASK), \"null\");\n InputMap maps = TxtSue.getInputMap(JTextField.WHEN_FOCUSED); \n maps.put(KeyStroke.getKeyStroke(KeyEvent.VK_V, Event.CTRL_MASK), \"null\");\n InputMap map3 = txtFun.getInputMap(JTextField.WHEN_FOCUSED); \n map3.put(KeyStroke.getKeyStroke(KeyEvent.VK_V, Event.CTRL_MASK), \"null\");\n this.setLocationRelativeTo(null);\n this.txtFun.setLineWrap(true);\n this.lblId.setText(Funciones.extraerIdMax());\n\t\tsexo.addItem(\"Administrativo\");\n\t\tsexo.addItem(\"Operativo\");\n sexo.addItem(\"Tecnico\");\n sexo.addItem(\"Servicios\");\n \n }",
"public FormEmpresa() {\n initComponents();\n this.getComboBox();\n this.buscaDadosEmpresa();\n \n }",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents() {\n\n jPanel1 = new javax.swing.JPanel();\n jblDato = new javax.swing.JLabel();\n jblAutor = new javax.swing.JLabel();\n jLabel1 = new javax.swing.JLabel();\n tfApellido = new javax.swing.JTextField();\n tfNombre = new javax.swing.JTextField();\n bntAgregar = new javax.swing.JButton();\n jComboBoxLista = new javax.swing.JComboBox<>();\n tfAnio = new javax.swing.JTextField();\n jblAnio = new javax.swing.JLabel();\n jblTitulo = new javax.swing.JLabel();\n tfTitulo = new javax.swing.JTextField();\n jblLugar = new javax.swing.JLabel();\n tfLugar = new javax.swing.JTextField();\n jblEditorial = new javax.swing.JLabel();\n tfEditorial = new javax.swing.JTextField();\n btnGenerar = new javax.swing.JButton();\n jScrollPane1 = new javax.swing.JScrollPane();\n jtResultado = new javax.swing.JTextArea();\n jLabel2 = new javax.swing.JLabel();\n btnBorrar = new javax.swing.JButton();\n\n setDefaultCloseOperation(javax.swing.WindowConstants.DISPOSE_ON_CLOSE);\n\n jPanel1.setBackground(new java.awt.Color(204, 255, 255));\n\n jblDato.setBackground(new java.awt.Color(0, 51, 204));\n jblDato.setFont(new java.awt.Font(\"Vani\", 1, 12)); // NOI18N\n jblDato.setText(\"DATOS DE BIBLIOGRAFIA\");\n\n jblAutor.setFont(new java.awt.Font(\"Tahoma\", 1, 11)); // NOI18N\n jblAutor.setText(\"Autor:\");\n\n jLabel1.setFont(new java.awt.Font(\"Tahoma\", 1, 11)); // NOI18N\n jLabel1.setText(\"Apellidos\");\n\n tfApellido.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n tfApellidoActionPerformed(evt);\n }\n });\n\n bntAgregar.setFont(new java.awt.Font(\"Tahoma\", 1, 11)); // NOI18N\n bntAgregar.setForeground(new java.awt.Color(102, 102, 102));\n bntAgregar.setText(\"AGREGAR\");\n bntAgregar.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n bntAgregarActionPerformed(evt);\n }\n });\n\n tfAnio.addKeyListener(new java.awt.event.KeyAdapter() {\n public void keyTyped(java.awt.event.KeyEvent evt) {\n tfAnioKeyTyped(evt);\n }\n });\n\n jblAnio.setFont(new java.awt.Font(\"Tahoma\", 1, 11)); // NOI18N\n jblAnio.setText(\"Año de publicación: \");\n\n jblTitulo.setFont(new java.awt.Font(\"Tahoma\", 1, 11)); // NOI18N\n jblTitulo.setText(\"Titulo:\");\n\n jblLugar.setFont(new java.awt.Font(\"Tahoma\", 1, 11)); // NOI18N\n jblLugar.setText(\"Lugar de publicación\");\n\n tfLugar.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n tfLugarActionPerformed(evt);\n }\n });\n\n jblEditorial.setFont(new java.awt.Font(\"Tahoma\", 1, 11)); // NOI18N\n jblEditorial.setText(\"Editorial\");\n\n btnGenerar.setFont(new java.awt.Font(\"Tahoma\", 1, 12)); // NOI18N\n btnGenerar.setForeground(new java.awt.Color(51, 51, 51));\n btnGenerar.setText(\"GENERAR\");\n btnGenerar.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n btnGenerarActionPerformed(evt);\n }\n });\n\n jtResultado.setColumns(20);\n jtResultado.setRows(5);\n jScrollPane1.setViewportView(jtResultado);\n\n jLabel2.setFont(new java.awt.Font(\"Tahoma\", 1, 11)); // NOI18N\n jLabel2.setText(\"Nombre\");\n\n btnBorrar.setFont(new java.awt.Font(\"Tahoma\", 1, 12)); // NOI18N\n btnBorrar.setForeground(new java.awt.Color(255, 0, 51));\n btnBorrar.setText(\"BORRAR\");\n btnBorrar.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n btnBorrarActionPerformed(evt);\n }\n });\n\n javax.swing.GroupLayout jPanel1Layout = new javax.swing.GroupLayout(jPanel1);\n jPanel1.setLayout(jPanel1Layout);\n jPanel1Layout.setHorizontalGroup(\n jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addGap(28, 28, 28)\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(jblEditorial)\n .addComponent(jblLugar)\n .addComponent(jblAnio)\n .addComponent(jblTitulo))\n .addGap(18, 18, 18)\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(tfEditorial)\n .addComponent(tfTitulo)\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addComponent(tfAnio, javax.swing.GroupLayout.PREFERRED_SIZE, 129, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addGap(0, 0, Short.MAX_VALUE))\n .addComponent(tfLugar)))\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addComponent(jblAutor, javax.swing.GroupLayout.PREFERRED_SIZE, 65, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addGap(64, 64, 64)\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(jComboBoxLista, 0, javax.swing.GroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addComponent(tfApellido, javax.swing.GroupLayout.PREFERRED_SIZE, 138, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.UNRELATED)\n .addComponent(tfNombre)))))\n .addGap(18, 18, 18)\n .addComponent(bntAgregar)\n .addGap(54, 54, 54))\n .addGroup(javax.swing.GroupLayout.Alignment.TRAILING, jPanel1Layout.createSequentialGroup()\n .addContainerGap(javax.swing.GroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)\n .addComponent(jLabel1)\n .addGap(127, 127, 127)\n .addComponent(jLabel2)\n .addGap(209, 209, 209))\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addGap(220, 220, 220)\n .addComponent(jblDato, javax.swing.GroupLayout.PREFERRED_SIZE, 175, javax.swing.GroupLayout.PREFERRED_SIZE))\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addContainerGap()\n .addComponent(jScrollPane1, javax.swing.GroupLayout.PREFERRED_SIZE, 561, javax.swing.GroupLayout.PREFERRED_SIZE)))\n .addContainerGap(21, Short.MAX_VALUE))\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addGap(82, 82, 82)\n .addComponent(btnBorrar, javax.swing.GroupLayout.PREFERRED_SIZE, 97, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED, javax.swing.GroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)\n .addComponent(btnGenerar, javax.swing.GroupLayout.PREFERRED_SIZE, 116, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addGap(44, 44, 44))\n );\n jPanel1Layout.setVerticalGroup(\n jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addGap(23, 23, 23)\n .addComponent(jblDato, javax.swing.GroupLayout.PREFERRED_SIZE, 29, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(jLabel1)\n .addComponent(jLabel2))\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addGap(11, 11, 11)\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(tfApellido, javax.swing.GroupLayout.PREFERRED_SIZE, 30, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addComponent(tfNombre, javax.swing.GroupLayout.PREFERRED_SIZE, 32, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addComponent(jblAutor, javax.swing.GroupLayout.PREFERRED_SIZE, 22, javax.swing.GroupLayout.PREFERRED_SIZE))\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED, 11, Short.MAX_VALUE)\n .addComponent(jComboBoxLista, javax.swing.GroupLayout.PREFERRED_SIZE, 28, javax.swing.GroupLayout.PREFERRED_SIZE))\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addGap(34, 34, 34)\n .addComponent(bntAgregar)))\n .addGap(18, 18, 18)\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(jblAnio)\n .addComponent(tfAnio, javax.swing.GroupLayout.PREFERRED_SIZE, 30, javax.swing.GroupLayout.PREFERRED_SIZE))\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.UNRELATED)\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(tfTitulo, javax.swing.GroupLayout.PREFERRED_SIZE, 31, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addComponent(jblTitulo))\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)\n .addComponent(tfLugar, javax.swing.GroupLayout.PREFERRED_SIZE, 31, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addComponent(jblLugar))\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(jblEditorial)\n .addComponent(tfEditorial, javax.swing.GroupLayout.PREFERRED_SIZE, 32, javax.swing.GroupLayout.PREFERRED_SIZE))\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)\n .addGroup(jPanel1Layout.createParallelGroup(javax.swing.GroupLayout.Alignment.TRAILING)\n .addComponent(btnGenerar, javax.swing.GroupLayout.PREFERRED_SIZE, 35, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addGroup(jPanel1Layout.createSequentialGroup()\n .addComponent(btnBorrar, javax.swing.GroupLayout.PREFERRED_SIZE, 30, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addGap(5, 5, 5)))\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.UNRELATED)\n .addComponent(jScrollPane1, javax.swing.GroupLayout.PREFERRED_SIZE, 67, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addGap(6, 6, 6))\n );\n\n javax.swing.GroupLayout layout = new javax.swing.GroupLayout(getContentPane());\n getContentPane().setLayout(layout);\n layout.setHorizontalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(jPanel1, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)\n );\n layout.setVerticalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(jPanel1, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)\n );\n\n pack();\n }",
"public ProductCreate() {\n initComponents();\n }",
"public form() {\n initComponents();\n }",
"@Override\n\tprotected Fragment createFragment() {\n\t\treturn new FormFragment();\n\t}",
"public FormFuncionario(FormMenu telaPai) {\n initComponents();\n this.telaPai = telaPai;\n\n txtNome.setText(\"Nome\");\n lblNome.setVisible(false);\n txtSobrenome.setText(\"Sobrenome\");\n lblSobrenome.setVisible(false);\n campoMensagem.setVisible(false);\n lblMensagem.setVisible(false);\n\n }",
"@GetMapping(\"/directorForm\")\n public String addDirectors(Model model) {\n\n model.addAttribute(\"newDirector\", new Director());\n return \"directorForm\";\n }",
"@Override\n\tprotected BaseProcesoForm devuelveFormProceso() throws Exception {\n\t\tProcesoBASLoggerForm objForm = new ProcesoBASLoggerForm();\n\t\treturn objForm;\n\t}",
"@RequestMapping(\"/new\")\n\tpublic String displayProjectForm(Model model) {\n\t\tProject aproject = new Project();\n\t//Iterable<Employee> employees = \tpro.getall();\n\t\n\t\tmodel.addAttribute(\"project\", aproject);\n\n\t\t//model.addAttribute(\"allEmployees\", employees);\n\t\t\n\t\t\n\t\treturn \"newproject\";\n\t\t\n\t}",
"public FormPemilihan() {\n initComponents();\n }",
"@Override\r\n protected void createDbContentCreateEdit() {\n DbContentCreateEdit dbContentCreateEdit = new DbContentCreateEdit();\r\n dbContentCreateEdit.init(null);\r\n form.getModelObject().setDbContentCreateEdit(dbContentCreateEdit);\r\n dbContentCreateEdit.setParent(form.getModelObject());\r\n ruServiceHelper.updateDbEntity(form.getModelObject()); \r\n }",
"@GetMapping(\"/students/new\")\r\n\tpublic String createStudentForm(Model model) {\n\t\tStudent student =new Student();\r\n\t\tmodel.addAttribute(\"student\",student);\r\n\t\treturn \"create_student\";\r\n\t}",
"public ViewCreatePagamento() {\n initComponents();\n clientesDAO cDAO = DaoFactory.createClientesDao(); \n matriculaDAO mDAO = DaoFactory.createMatriculaDao();\n \n cmbIDClientes.addItem(null);\n cDAO.findAll().forEach((p) -> {\n cmbIDClientes.addItem(p.getNome());\n });\n \n \n txtDataAtual.setText(DateFormat.getDateInstance().format(new Date()));\n }",
"@Override public SnpAssociationForm createForm(Association association) {\n\n\n SnpAssociationStandardMultiForm form = new SnpAssociationStandardMultiForm();\n\n // Set association ID\n form.setAssociationId(association.getId());\n form.setAssociationExtension(association.getAssociationExtension());\n\n // Set simple string and float association attributes\n form.setRiskFrequency(association.getRiskFrequency());\n form.setPvalueDescription(association.getPvalueDescription());\n form.setSnpType(association.getSnpType());\n form.setMultiSnpHaplotype(association.getMultiSnpHaplotype());\n form.setSnpApproved(association.getSnpApproved());\n form.setPvalueMantissa(association.getPvalueMantissa());\n form.setPvalueExponent(association.getPvalueExponent());\n form.setStandardError(association.getStandardError());\n form.setRange(association.getRange());\n form.setDescription(association.getDescription());\n\n // Set OR/Beta values\n form.setOrPerCopyNum(association.getOrPerCopyNum());\n form.setOrPerCopyRecip(association.getOrPerCopyRecip());\n form.setOrPerCopyRecipRange(association.getOrPerCopyRecipRange());\n form.setBetaNum(association.getBetaNum());\n form.setBetaUnit(association.getBetaUnit());\n form.setBetaDirection(association.getBetaDirection());\n\n // Add collection of Efo traits\n form.setEfoTraits(association.getEfoTraits());\n\n // For each locus get genes and risk alleles\n Collection<Locus> loci = association.getLoci();\n Collection<Gene> locusGenes = new ArrayList<>();\n Collection<RiskAllele> locusRiskAlleles = new ArrayList<RiskAllele>();\n\n // For multi-snp and standard snps we assume their is only one locus\n for (Locus locus : loci) {\n locusGenes.addAll(locus.getAuthorReportedGenes());\n locusRiskAlleles.addAll(locus.getStrongestRiskAlleles()\n .stream()\n .sorted((v1, v2) -> Long.compare(v1.getId(), v2.getId()))\n .collect(Collectors.toList()));\n\n // There should only be one locus thus should be safe to set these here\n form.setMultiSnpHaplotypeNum(locus.getHaplotypeSnpCount());\n form.setMultiSnpHaplotypeDescr(locus.getDescription());\n }\n\n\n // Get name of gene and add to form\n Collection<String> authorReportedGenes = new ArrayList<>();\n for (Gene locusGene : locusGenes) {\n authorReportedGenes.add(locusGene.getGeneName());\n }\n form.setAuthorReportedGenes(authorReportedGenes);\n\n // Handle snp rows\n Collection<GenomicContext> snpGenomicContexts = new ArrayList<GenomicContext>();\n Collection<SingleNucleotidePolymorphism> snps = new ArrayList<>();\n List<SnpFormRow> snpFormRows = new ArrayList<SnpFormRow>();\n List<SnpMappingForm> snpMappingForms = new ArrayList<SnpMappingForm>();\n for (RiskAllele riskAllele : locusRiskAlleles) {\n SnpFormRow snpFormRow = new SnpFormRow();\n snpFormRow.setStrongestRiskAllele(riskAllele.getRiskAlleleName());\n\n SingleNucleotidePolymorphism snp = riskAllele.getSnp();\n snps.add(snp);\n String rsID = snp.getRsId();\n snpFormRow.setSnp(rsID);\n\n Collection<Location> locations = snp.getLocations();\n for (Location location : locations) {\n SnpMappingForm snpMappingForm = new SnpMappingForm(rsID, location);\n snpMappingForms.add(snpMappingForm);\n }\n\n // Set proxy if one is present\n Collection<String> proxySnps = new ArrayList<>();\n if (riskAllele.getProxySnps() != null) {\n for (SingleNucleotidePolymorphism riskAlleleProxySnp : riskAllele.getProxySnps()) {\n proxySnps.add(riskAlleleProxySnp.getRsId());\n }\n }\n snpFormRow.setProxySnps(proxySnps);\n\n snpGenomicContexts.addAll(genomicContextRepository.findBySnpId(snp.getId()));\n snpFormRows.add(snpFormRow);\n }\n\n form.setSnpMappingForms(snpMappingForms);\n form.setGenomicContexts(snpGenomicContexts);\n form.setSnps(snps);\n form.setSnpFormRows(snpFormRows);\n return form;\n }",
"@Override\n\tprotected JPanel renderForm(AddWindow window) {\n\n\t\tthis.panel = new JPanel(new FlowLayout(FlowLayout.LEADING));\n\n\t\tthis.nameLabel = new JLabel(\"Nom de la catégorie\");\n\t\tthis.nameInput = new TabbedTextField(null, \"name\", 19);\n\t\tthis.components.add(this.nameInput);\n\n\t\tthis.gameLabel = new JLabel(\"Jeu parent\");\n\t\tthis.gamesList = new TabbedComboBox(\"game\", this.getGamesList());\n\t\tthis.components.add(this.gamesList);\n\n\t\tTabbedButton cancel = new TabbedButton(\"Annuler\", \"cancel\");\n\t\tcancel.addActionListener(window);\n\n\t\tTabbedButton submit = new TabbedButton(\"Enregistrer\", \"submit\");\n\t\tsubmit.addActionListener(window);\n\n\t\tthis.panel.add(this.nameLabel);\n\t\tthis.panel.add(this.nameInput);\n\t\tthis.panel.add(this.gameLabel);\n\t\tthis.panel.add(this.gamesList);\n\t\tthis.panel.add(cancel);\n\t\tthis.panel.add(submit);\n\n\t\tthis.panel.validate();\n\n\t\treturn panel;\n\n\t}",
"public quanlixe_form() {\n initComponents();\n }",
"@GetMapping(\"/showFormForAdd\")\n public String showFormForAdd(Model theModel) {\n Categories theCategories = new Categories();\n theModel.addAttribute(\"categories\", theCategories);\n //theModel.addAttribute(\"update\", false);\n return \"loaisanpham-form\"; }"
]
| [
"0.7645561",
"0.7226992",
"0.67805517",
"0.6628898",
"0.65278614",
"0.63073295",
"0.6294699",
"0.6143657",
"0.61142033",
"0.6072567",
"0.6043203",
"0.603391",
"0.6026939",
"0.60196984",
"0.6008899",
"0.59998643",
"0.5998477",
"0.5977184",
"0.5961461",
"0.59514165",
"0.59435827",
"0.59409696",
"0.593676",
"0.5918913",
"0.59080136",
"0.5903841",
"0.59024465",
"0.59022933",
"0.5887478",
"0.5877986",
"0.5871071",
"0.5853629",
"0.58534443",
"0.5844238",
"0.58285433",
"0.5818665",
"0.58180636",
"0.5817512",
"0.5805839",
"0.5804076",
"0.5800444",
"0.57998353",
"0.57902217",
"0.57858866",
"0.5785518",
"0.5782392",
"0.5772346",
"0.57657623",
"0.57579786",
"0.5757621",
"0.5756583",
"0.5753915",
"0.574893",
"0.57483447",
"0.5742347",
"0.57379454",
"0.5733006",
"0.57323295",
"0.5731435",
"0.5700346",
"0.5699866",
"0.56977856",
"0.56961364",
"0.5693026",
"0.5689286",
"0.56775963",
"0.56707954",
"0.56670016",
"0.5666793",
"0.5664615",
"0.5661512",
"0.56605726",
"0.5657848",
"0.5651373",
"0.5637494",
"0.5636429",
"0.5635732",
"0.5634139",
"0.5627309",
"0.5621621",
"0.5614313",
"0.560755",
"0.56046253",
"0.55980396",
"0.5597697",
"0.5592475",
"0.55920553",
"0.5586858",
"0.55859506",
"0.55757827",
"0.5575558",
"0.5574507",
"0.5571361",
"0.55707985",
"0.5568712",
"0.55685365",
"0.5562074",
"0.55593765",
"0.5553838",
"0.55530125",
"0.5552841"
]
| 0.0 | -1 |
Metodo para la creacion de los eventos. | public void eventos() {
btnAbrir.addActionListener(new ActionListener() {
@Override
public void actionPerformed(ActionEvent evt) {
btnAbrirActionPerformed(evt);
}
});
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void createEvents() {\n\t}",
"private void createEvents()\r\n\t{\r\n\t\teventsCount.add(new Event(RequestMethod.PUT, 0));\r\n\t\teventsCount.add(new Event(RequestMethod.GET, 0));\r\n\t\teventsCount.add(new Event(RequestMethod.POST, 0));\r\n\t}",
"BasicEvents createBasicEvents();",
"private void initEvents(){\n ArrayList<Event> en = new ArrayList();\n en.add(new Event_MessangerOfGods(this.village));\n en.add(new Event_PaganPriest(this.village));\n this.events = en;\n }",
"public\n CreateEvent()\n {}",
"public void crear_un_evento_recurrente_para_el_dia_de_hoy() {\n\t\t\n\t}",
"private void initializeEvents() {\r\n\t}",
"public LecturaPorEvento() \r\n {\r\n }",
"Event createEvent();",
"Event createEvent();",
"@Override\r\n\tprotected void initEvents() {\n\t\t\r\n\t}",
"EventUse createEventUse();",
"public Eventd() {\n }",
"public void ingresar_a_la_Opcion_de_eventos() {\n\t\t\n\t}",
"public Event() {\r\n\r\n\t}",
"@Override\n protected void initEventAndData() {\n }",
"public void setEventCreated() {\n Date now = new Date();\n this.eventCreated = now;\n }",
"public void initEventsAndProperties() {\r\n }",
"public Evento getEvento() { \n\t\t Evento evento = new Evento();\n\t\t List<Prenda> Lprendas = new ArrayList<Prenda>();\n\t\t Sugerencia sug = new Sugerencia();\n\t Prenda prend = new Prenda();\n Categoria categoria = new Categoria();\n\n categoria.setCodCategoria(1);\n categoria.setDescripcion(\"Zapatillas\");\n TipoPrenda tp = new TipoPrenda();\n tp.setDescripcion(\"lalal\");\n tp.setCategoria(categoria);\n tp.setCodTipoPrenda(1);\n \n \n Guardarropa guard = new Guardarropa();\n guard.setCompartido(false);\n guard.setDescripcion(\"guardarropa\");\n guard.setId(0); \n prend.setGuardarropa(guard);\n prend.setColorPrimario(\"rojo\");\n prend.setTipoPrenda(tp);\n prend.setColorSecundario(\"azul\");\n prend.setDescripcion(\"prenda 1\");\n prend.setNumeroDeCapa(EnumCapa.Primera);\n \tfor( int i = 0 ; i <= 4; i++) {\n prend.setCodPrenda(i);\n\t\t\tLprendas.add(prend);\t\t\t\n\t\t}\n \tsug.setIdSugerencia(1);\n \tsug.setMaxCapaInferior(0);\n \tsug.setMaxCapaSuperior(2);\t\n \tsug.setUsuario(new Usuario());\n \tsug.setListaPrendasSugeridas(Lprendas);\n \tevento.AgregarSugerenciaAEvento(sug);\n \tevento.AgregarSugerenciaAEvento(sug);\n \tevento.AgregarSugerenciaAEvento(sug);\n \tevento.AgregarSugerenciaAEvento(sug);\n \tevento.AgregarSugerenciaAEvento(sug);\n\n \t return evento;\n\t }",
"private void createEvents() {\n\t\taddBtn.addActionListener(new ActionListener(){\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tbuildOutput();\n\t\t\t}\n\t\t});\n\t}",
"public Event() {\n\t}",
"EventUses createEventUses();",
"com.walgreens.rxit.ch.cda.EIVLEvent addNewEvent();",
"public Event() {\n }",
"public Event() {\n }",
"public Event() {}",
"public void createGenesisEvent() {\n handleNewEvent(buildEvent(null, null));\n }",
"public AutoEvents() {\n super();\n _autoEventList = new ArrayList();\n }",
"public Event() {\n\n }",
"@Override //to be moved to Cloud service\r\n\tpublic void createEvent(String eventName) {\n\t\t\r\n\t}",
"protected abstract void createHistoryEvents();",
"EventChannel create();",
"@Override\n protected void initializeEventList()\n {\n }",
"private void createEvents() {\n\t\tbtnRetour.addActionListener(new ActionListener() {\r\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\r\n\t\t\t\tdispose();\r\n\t\t\t\tDashboard_Preteur dashboard_Preteur = new Dashboard_Preteur(currentPreteur);\r\n\t\t\t\tdashboard_Preteur.setVisible(true);\r\n\t\t\t\tdashboard_Preteur.setResizable(false);\r\n\t\t\t}\r\n\t\t});\r\n\t}",
"private void createEvents() {\n\t\tbtnPushTheButton.addActionListener(new ActionListener() {\n\t\t\t\n\t\t\t\n\t\t\tprivate List<String> b;\n\n\t\n\t\t\t//@SuppressWarnings(\"unchecked\")\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tact = true;\n\t\t\t\t\n//\t\t\t\tb = new ArrayList<String>();\n//\t\t\t\t\n//\t\t\t\tthis.b= (List<String>) ((List<Object>) (agent.v.getData())).stream().map(item -> {\n//\t\t\t\t\treturn (String) item;\n//\t\t\t\t});\n//\t\t\t\tString c = String.join(\", \", b);\n//\t\t\t\tclassTextArea.setText(c);\n//\t\t\t\n//\t\t\t\tclassTextArea.setText(b.toString());\n//\t\t\t\t\n//\t\t\t\treturn;\n\t\t\t\t\n\t\t\t}\n\t\t\t\n\t\t\t\n\t\t\t\n\t\t});\n\t\t\n\t}",
"protected ICEvent() {}",
"BasicEvent createBasicEvent();",
"private IEvent createEvent() throws RodinDBException {\n\t\tfinal IMachineRoot mch = createMachine(\"mch\");\n\t\treturn mch.createChild(IEvent.ELEMENT_TYPE, null, null);\n\t}",
"EventManager()\n {\n }",
"private void initEvents() {\r\n\t\teventPool = new EventPool();\r\n\t\teventPool.addEvent(new BlockGeneratorEvent(this));\r\n\t\teventPool.addEvent(new BlockOffScreenEvent(this));\r\n\t\teventPool.addEvent(new DeathEvent(myDropThis, this));\r\n\t}",
"public ScheduleEvent()\n\t{\n\n\t}",
"public static void create() {\n\t\tScanner sc = new Scanner(System.in);\n\t\tString title = \"\";\n\t\tString date = \"\";\n\t\tString startTime = \"\";\n\t\tString endTime = \"\";\n\t\tSystem.out.println(\"Enter the title of the event you would like to create: \");\n\t\tif (sc.hasNextLine()) {\n\t\t\ttitle = sc.nextLine().toLowerCase();\n\t\t}\n\t\tSystem.out.println(\"Enter the date on MM/DD/YYYY format: \");\n\t\tif (sc.hasNextLine()) {\n\t\t\tdate = sc.nextLine().toLowerCase();\n\t\t}\n\t\tSystem.out.println(\"Enter the starting time in 24 hour format (ex 15:30): \");\n\t\tif (sc.hasNextLine()) {\n\t\t\tstartTime = sc.nextLine().toLowerCase();\n\t\t}\n\t\tSystem.out.println(\"Enter the ending time: in 24 hour format (ex 15:30): \"); // if there's no end time set the\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// end time to the start time.\n\t\tif (sc.hasNextLine()) {\n\t\t\tendTime = sc.nextLine().toLowerCase();\n\t\t\tif (endTime.equals(\"\")) {\n\t\t\t\tendTime = startTime;\n\t\t\t}\n\t\t}\n\t\tEvent toAdd = new Event(title, date, startTime, endTime);\n\n\t\tGregorianCalendar calendar = new GregorianCalendar(toAdd.getYear(), toAdd.getMonth(), toAdd.getDay());\n\t\tif (calendarToEvent.get(calendar) == null) { // there are no events under this date\n\t\t\tTreeSet<Event>treeSetForMap = new TreeSet<Event>();\n\t\t\ttreeSetForMap.add(toAdd);\n\t\t\tcalendarToEvent.put(calendar, treeSetForMap);\n\t\t} else { // there are already events, add event to the treeset\n\t\t\tboolean canAdd = true;\n\t\t\tfor (Event e : calendarToEvent.get(calendar)) {\n\t\t\t\tif (e.conflictCheck(toAdd)) { //check this (e.getIntEndTime()) < (toAdd.getIntStartTime()) ////return true if there is a conflict, false if there isn't\n\t\t\t\t\tSystem.out.println(\"Sorry can't add that event, there is a conflict\");\n\t\t\t\t\tcanAdd = false;\n\t\t\t\t}\n\t\t\t}\n\t\t\tif (canAdd) {\n\t\t\t\tcalendarToEvent.get(calendar).add(toAdd); // THAT'S WHAT IT USED TO BE calendarToEvent.get(toAdd.getDate()).add(toAdd);\n\t\t\t}\n\t\t}\n\t}",
"public Event(){\n \n }",
"public Event(){\n\n }",
"StartEvent createStartEvent();",
"private void creatBirth(){\n\n for (int i = 0; i < repeatLunar.size() - 1; i++) {\n mLunar = repeatLunar.get(i);\n mLunarDay = mLunar.getLunarDay();\n mLunarMonth = mLunar.getLunarMonth();\n mLunarYear = mLunar.getLunarYear();\n mRepeat = mLunar.getRepeat();\n\n createEvent(getDate(mLunarYear, mLunarMonth, mLunarDay));\n\n\n }\n\n\n\n }",
"public Event() {\n this.name = null;\n this.description = null;\n this.date = new GregorianCalendar();\n }",
"private void configurarEventos() {\n\n btnVoltar.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n //OBJETIVO: fecha a tela atual\n VerPessoaActivity.this.finish();\n }\n });\n }",
"public ServiceEvent() {\n // eventSenderID and eventSenderClass are initialized by the OperatingSystem! \n }",
"private EventsCollector() {\n\t\tsuper();\n\t}",
"public static void createEvent(String token){\n ensureGraphClient(token);\n\n LinkedList<Option> requestOptions = new LinkedList<Option>();\n //requestOptions.add(new HeaderOption(\"Authorization\", \"Bearer nupl9.C5rb]aO5:yvT:3L.TKcH7tB1Im\" ));\n\n // Participantes:\n LinkedList<Attendee> attendeesList = new LinkedList<Attendee>();\n Attendee mentor = new Attendee();\n Attendee mentorado = new Attendee();\n\n EmailAddress mentorMail = new EmailAddress();\n mentorMail.address = \"[email protected]\";\n mentorMail.name = \"Daniell Wagner\";\n mentor.emailAddress = mentorMail;\n\n EmailAddress mentoradoMail = new EmailAddress();\n mentoradoMail.address = \"[email protected]\";\n mentoradoMail.name = \"Guilherme Carneiro\";\n mentorado.emailAddress = mentoradoMail;\n\n mentor.type = AttendeeType.REQUIRED;\n mentorado.type = AttendeeType.REQUIRED;\n\n attendeesList.add(mentor);\n attendeesList.add(mentorado);\n\n // Evento:\n Event event = new Event();\n event.subject = \"Mentoria com \" + mentor.emailAddress.name;\n\n ItemBody body = new ItemBody();\n body.contentType = BodyType.HTML;\n body.content = \"\" +\n \"<b>Mentoria sobre SCRUM</b> <br>\" +\n \"Olá, \" + mentorado.emailAddress.name + \" <br> \" +\n \"Você tem uma mentoria marcada com o mentor \"\n + mentor.emailAddress.name + \"!!\";\n\n event.body = body;\n\n DateTimeTimeZone start = new DateTimeTimeZone();\n start.dateTime = \"2020-03-26T16:00:00\";\n start.timeZone = \"Bahia Standard Time\";\n event.start = start;\n\n DateTimeTimeZone end = new DateTimeTimeZone();\n end.dateTime = \"2020-03-26T18:00:00\";\n end.timeZone = \"Bahia Standard Time\";\n event.end = end;\n\n Location location = new Location();\n location.displayName = \"Stefanini Campina Grande\";\n event.location = location;\n\n event.attendees = attendeesList;\n\n try {\n graphClient.me().calendar().events()\n .buildRequest()\n .post(event);\n }catch(Exception e) {\n\n System.out.println(\"Deu águia: \");\n e.printStackTrace();\n }\n }",
"public void setMarioEvents() {\n\t\tCollisionEvent event1, event2, event4, event98, event6, event7, event8, event9;\n\t\tAdvancedCollisionEvent event_1LandsTop4, event_1Touches4NotTop, event5;\n\t\ttry {\n\t\t\t// player with block\n\t\t\tevent1 = new CollisionEvent(\n\t\t\t\t\tArrays.asList(new String[] { \"0\", \"1\" }),\n\t\t\t\t\tPLAYER_LANDING_ON_BLOCK_STRING);\n\t\t\t// enemy with block\n\t\t\tevent2 = new CollisionEvent(Arrays.asList(\"1\", \"2\"),\n\t\t\t\t\tENEMY_ON_BLOCK_STRING);\n\t\t\t// player killing enemy\n\t\t\tevent_1LandsTop4 = new AdvancedCollisionEvent(Arrays.asList(\"0\",\n\t\t\t\t\t\"2\", \"true\", \"false\", \"false\", \"false\", \"false\"),\n\t\t\t\t\tPLAYER_JUMPING_ON_ENEMY_STRING);\n\t\t\t// enemy kills player\n\t\t\tevent_1Touches4NotTop = new AdvancedCollisionEvent(Arrays.asList(\n\t\t\t\t\t\"0\", \"2\", \"false\", \"true\", \"true\", \"true\", \"false\"),\n\t\t\t\t\tENEMY_KILLING_PLAYER_STRING);\n\t\t\t// player reaches goal\n\t\t\tevent4 = new CollisionEvent(Arrays.asList(\"0\", \"3\"),\n\t\t\t\t\tPLAYER_HITTING_GOAL_STRING);\n\t\t\t// player collects coin\n\t\t\tevent98 = new CollisionEvent(Arrays.asList(\"0\", \"5\"),\n\t\t\t\t\tPLAYER_COLLECTING_COIN_STRING);\n\t\t\t// bullet hits enemy\n\t\t\tevent5 = new AdvancedCollisionEvent(Arrays.asList(\"2\", \"150\",\n\t\t\t\t\t\"true\", \"true\", \"true\", \"true\", \"true\"),\n\t\t\t\t\tBULLET_HITTING_ENEMY_STRING);\n\t\t\t// player gets gun power up\n\t\t\tevent6 = new CollisionEvent(Arrays.asList(\"0\", \"6\"),\n\t\t\t\t\tPLAYER_HITS_GUN_POWERUP_STRING);\n\t\t\t// player gets invincibility power up\n\t\t\tevent7 = new CollisionEvent(Arrays.asList(\"0\", \"7\"),\n\t\t\t\t\tPLAYER_HITS_INVINCIBILITY_POWERUP_STRING);\n\t\t\t// player gets size power up\n\t\t\tevent8 = new CollisionEvent(Arrays.asList(\"0\", \"8\"),\n\t\t\t\t\tPLAYER_HITS_SIZE_POWER_UP_STRING);\n\t\t\t// player gets speed power up\n\t\t\tevent9 = new CollisionEvent(Arrays.asList(\"0\", \"9\"),\n\t\t\t\t\tPLAYER_HITS_SPEED_POWERUP_STRING);\n\t\t\tAddPowerUpAction action13 = new AddPowerUpAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"0\", \"8\",\n\t\t\t\t\t\t\tSIZE_POWER_UP_STRING, \"10\", \"mario\")));\n\t\t\tAddPowerUpAction action12 = new AddPowerUpAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"0\", \"9\",\n\t\t\t\t\t\t\tSPEED_POWER_UP_STRING, \"10\", \"bullet\")));\n\n\t\t\tDecreaseObjectHitPointsByCollisionAction action14 = new DecreaseObjectHitPointsByCollisionAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"8\", \"0\")));\n\t\t\tDecreaseObjectHitPointsByCollisionAction action15 = new DecreaseObjectHitPointsByCollisionAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"9\", \"0\")));\n\t\t\tDecreaseObjectHitPointsByCollisionAction action9 = new DecreaseObjectHitPointsByCollisionAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"6\", \"0\")));\n\t\t\tDecreaseObjectHitPointsByCollisionAction action11 = new DecreaseObjectHitPointsByCollisionAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"7\", \"0\")));\n\t\t\tAddPowerUpAction action7 = new AddPowerUpAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"0\", \"6\",\n\t\t\t\t\t\t\tGUN_POWERUP_STRING, \"10\", \"mario\")));\n\t\t\tAddPowerUpAction action8 = new AddPowerUpAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"0\", \"7\",\n\t\t\t\t\t\t\tINVINCIBILITY_POWERUP_STRING, \"10\", \"mobile\")));\n\t\t\tCollideSolidAction action = new CollideSolidAction(\n\t\t\t\t\tnew Tuple<Integer>(0, 1).toListString());\n\t\t\tCollideSolidAction action2 = new CollideSolidAction(\n\t\t\t\t\tnew Tuple<Integer>(2, 1).toListString());\n\t\t\tKillPlayerAction action3 = new KillPlayerAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"0\")));\n\n\t\t\tDecreaseObjectHitPointsByCollisionAction action10 = new DecreaseObjectHitPointsByCollisionAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"5\", \"0\")));\n\t\t\tDecreaseObjectHitPointsByCollisionAction action5 = new DecreaseObjectHitPointsByCollisionAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"150\", \"2\")));\n\t\t\tDecreaseObjectHitPointsByCollisionAction action6 = new DecreaseObjectHitPointsByCollisionAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"2\", \"150\")));\n\t\t\tEndLevelAction action4 = new EndLevelAction(new ArrayList<String>());\n\n\t\t\tChangeScoreAction action98 = new ChangeScoreAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"5\")));\n\t\t\tDecreaseObjectHitPointsByCollisionAction action_1Kills4 = new DecreaseObjectHitPointsByCollisionAction(\n\t\t\t\t\tnew ArrayList<String>(Arrays.asList(\"2\", \"0\")));\n\n\t\t\tevent1.addAction(action);\n\t\t\tevent2.addAction(action2);\n\t\t\tevent_1Touches4NotTop.addAction(action3);\n\t\t\tevent_1LandsTop4.addAction(action_1Kills4);\n\t\t\tevent4.addAction(action4);\n\t\t\tevent98.addAction(action98);\n\t\t\tevent98.addAction(action10);\n\t\t\tevent5.addAction(action5, action6);\n\t\t\tevent6.addAction(action7, action9);\n\t\t\tevent7.addAction(action8, action11);\n\t\t\tevent9.addAction(action12, action15);\n\t\t\tevent8.addAction(action13, action14);\n\t\t\tmyLevel.addEvent(event1, event2, event_1Touches4NotTop, event4,\n\t\t\t\t\tevent98, event_1LandsTop4, event5, event6, event7, event8,\n\t\t\t\t\tevent9);\n\t\t\tmyLevelObjectBar.initializeEventsMap(myLevel.getEvents());\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"protected abstract Set<Event> createEvents(String[] dataset);",
"public abstract void onCreate(MessageCreateEvent e, List<String> args);",
"private List<Event> generateEvents() {\n\t\tList<Event> events = new ArrayList<Event>();\n\t\tint numEvents = random.nextInt(2) + 1;\n\t\tfor (int i = 0; i < numEvents; i++) {\n\t\t\tEvent newEvent = null;\n\t\t\tdo {\n\t\t\t\tnewEvent = new Event(db);\n\t\t\t} while (events.contains(newEvent)); // make sure only one instance of an event occurs per turn\n\t\t\tevents.add(newEvent);\t\t\t\n\t\t}\n\t\treturn events;\n\t}",
"@Override\n\tpublic void loadEvents() {\n\t\t\n\t}",
"public void createEvents(){\r\n\t\tbtnCurrent.addActionListener((ActionEvent e) -> JLabelDialog.run());\r\n\t}",
"public Event(int type) {\n this.type=type;\n this.arg=null;\n }",
"CreateEventViewModelFactory() {\n super(Storage.class, Authenticator.class);\n }",
"public QPEvent() {}",
"private void crearVista() {\n\t\tVista vista = Vista.getInstancia();\n\t\tvista.addObservador(this);\n\n\t}",
"private EventController()\n {\n events = new ArrayList<>();\n currentCalendar = Calendar.getInstance();\n }",
"public AmishMart()\n {\n super(\"PokeMart\");\n\n eventArray[20][14] = new Teleport();\n eventArray[20][14].setCoord(5, 2, 18, 17);\n\n eventArray[15][13] = new ShopKeep();\n }",
"private LogEvent()\n\t{\n\t\tsuper();\n\t}",
"public void init() {\r\n setEventType(4);\r\n }",
"public void makeEvent(String type) {\n\t\teventName = type;\n\t}",
"public void createEvent(Event e) {\n\t\tLocalDate date = e.sDate;\n\t\tif(!map.containsKey(date)) {\n\t\t\tArrayList<Event> newList = new ArrayList<>();\n\t\t\tnewList.add(e);\n\t\t\tmap.put(date, newList);\n\t\t}\n\t\telse {\n\t\t\tmap.get(date).add(e);\n\n\t\t}\n\t}",
"public Event createEvent(String name) {\r\n\t\tEvent newEvent = new Event(this.GID, name);\r\n\t\tevents.add(newEvent);\r\n\t\treturn newEvent;\r\n\t}",
"public EventHandlerRegistry() {\n }",
"public static void created() {\n\t\t// TODO\n\t}",
"@Override\n\tpublic void createEvent(CalendarCreate calendar) {\n\t\tprojectDao.createEvent(calendar);\n\t\t\n\t}",
"public ArticleSearchDoneEvent() {\n\n }",
"private void registerGlobalEvents() {\n\t\tsubmit(new CycleEvent());\n\t\tsubmit(new CleanupEvent());\n\t\tsubmit(new FloorItemEvent());\n\t}",
"@Test\n public void createManyEventsTest() {\n int numEvents = 8;\n Set<Long> eventSet = new HashSet<>();\n try (Context context = GrCUDATestUtil.buildTestContext().build()) {\n Value createEvent = context.eval(\"grcuda\", \"cudaEventCreate\");\n IntStream.range(0, numEvents).forEach(i -> {\n Value event = createEvent.execute();\n eventSet.add(event.asNativePointer());\n assertNotNull(event);\n assertTrue(event.isNativePointer());\n });\n assertEquals(numEvents, eventSet.size());\n }\n }",
"public AddEvent() {\n initComponents();\n }",
"void onNewEvent(Event event);",
"private void setUpEventManager() {\n // Register the actionEventListener1 to MockUndoableAction class\n eventManager.addActionEventListener(actionEventListener1, MockAddClassDiagramAction.class);\n // Register the actionEventListener2 to all Action class\n eventManager.addActionEventListener(actionEventListener2);\n // Register the actionEventListener3 to simple Action Class\n eventManager.addActionEventListener(actionEventListener3, Action.class);\n\n // Register the validators to UndoableAction.class\n eventManager.addEventValidator(successEventValidator, UndoableAction.class);\n // Register the validators to all Action class\n eventManager.addEventValidator(modifiedEventValidator);\n // Register the validators to simple Action Class\n eventManager.addEventValidator(deniedEventValidator, Action.class);\n\n // Register the gUIEventListener1 to 'RedoChangesEvent'\n eventManager.addGUIEventListener(gUIEventListener1, RedoChangesEvent.class);\n // Register the gUIEventListener2 to all EventObject\n eventManager.addGUIEventListener(gUIEventListener2);\n // Register the gUIEventListener3 to 'UndoChangesEvent'\n eventManager.addGUIEventListener(gUIEventListener3, UndoChangesEvent.class);\n }",
"private void addEvent() {\n String name = selectString(\"What is the name of this event?\");\n ReferenceFrame frame = selectFrame(\"Which frame would you like to define the event in?\");\n double time = selectDouble(\"When does the event occur (in seconds)?\");\n double x = selectDouble(\"Where does the event occur (in light-seconds)?\");\n world.addEvent(new Event(name, time, x, frame));\n System.out.println(\"Event added!\");\n }",
"public void consulterEvent() {\n\t\t\n\t}",
"public WriteMetadataEvent() {\n }",
"private void crearObjetos() {\n // crea los botones\n this.btnOK = new CCButton(this.OK);\n this.btnOK.setActionCommand(\"ok\");\n this.btnOK.setToolTipText(\"Confirmar la Operación\");\n \n this.btnCancel = new CCButton(this.CANCEL);\n this.btnCancel.setActionCommand(\"cancel\");\n this.btnCancel.setToolTipText(\"Cancelar la Operación\");\n \n // Agregar los eventos a los botones\n this.btnOK.addActionListener(this);\n this.btnCancel.addActionListener(this);\n }",
"public SoundEvent() \n\t{\n\tsuper(GAME_SOUND_EVENT);\n\t}",
"public final void loadEvents() {\n\n if (selectedUser == null || selectedUser.equals(\"All\")) {\n for (Absence a : AbsenceService.getAllUnacknowledged()) {\n\n AbsenceEvent e = new AbsenceEvent(a.getUser().getUsername() + \" \" + a.getAbsenceType(), TimeConverterService.convertLocalDateTimeToDate(a.getStartTime()), TimeConverterService.convertLocalDateTimeToDate(a.getEndTime()), a);\n\n switch (e.getAbsence().getAbsenceType()) {\n\n case MEDICAL_LEAVE:\n e.setStyleClass(\"medical_leave\");\n break;\n case HOLIDAY:\n e.setStyleClass(\"holiday\");\n e.setAllDay(true);\n break;\n case TIME_COMPENSATION:\n e.setStyleClass(\"time_compensation\");\n break;\n case BUSINESSRELATED_ABSENCE:\n e.setStyleClass(\"business-related_absence\");\n break;\n default:\n }\n\n this.addEvent(e);\n }\n } else {\n for (Absence a : AbsenceService.getAbsenceByUserAndUnacknowledged(BenutzerverwaltungService.getUser(selectedUser))) {\n\n AbsenceEvent e = new AbsenceEvent(a.getUser().getUsername() + \" \" + a.getAbsenceType() + \" \" + a.getReason(), TimeConverterService.convertLocalDateTimeToDate(a.getStartTime()), TimeConverterService.convertLocalDateTimeToDate(a.getEndTime()), a);\n\n switch (e.getAbsence().getAbsenceType()) {\n\n case MEDICAL_LEAVE:\n e.setStyleClass(\"medical_leave\");\n break;\n case HOLIDAY:\n e.setStyleClass(\"holiday\");\n e.setAllDay(true);\n break;\n case TIME_COMPENSATION:\n e.setStyleClass(\"time_compensation\");\n break;\n case BUSINESSRELATED_ABSENCE:\n e.setStyleClass(\"business-related_absence\");\n break;\n default:\n }\n\n this.addEvent(e);\n }\n }\n\n DefaultScheduleEvent holidayevent;\n\n for (Holiday h : HolidayService.getList()) {\n holidayevent = new DefaultScheduleEvent(h.getHolidayComment(), TimeConverterService.convertLocalDateToDate(h.getHolidayDate()), TimeConverterService.convertLocalDateToDate(h.getHolidayDate()));\n holidayevent.setAllDay(true);\n holidayevent.setStyleClass(\"feiertag\");\n\n this.addEvent(holidayevent);\n }\n }",
"public abstract Event[] getInitialEvents();",
"public DetalleEvento(String titulo, int duracion, int borrado, int evento, int bloequeo) {\n this.titulo = titulo;\n this.duracion = duracion;\n this.borrado = borrado;\n this.evento = evento;\n this.bloequeo = bloequeo;\n }",
"public void registerEvents()\n {\n \t\tfinal pchestPlayerListener playerListener = new pchestPlayerListener(this, chestManager);\n \t\tfinal pchestEntityListener entityListener = new pchestEntityListener(this, chestManager);\n \t\tfinal pchestBlockListener blockListener = new pchestBlockListener(this, chestManager);\n \t\t\n \t\t\n pm = getServer().getPluginManager();\n \n /* Entity events */\n pm.registerEvent(Type.ENTITY_EXPLODE, entityListener, Event.Priority.Normal, this);\n \n /* Player events */\n pm.registerEvent(Type.PLAYER_INTERACT, playerListener, Event.Priority.Normal, this);\n \n /* Block events */\n \t\tpm.registerEvent(Type.BLOCK_PLACE, blockListener, Event.Priority.Normal, this);\n \t\tpm.registerEvent(Type.BLOCK_BREAK, blockListener, Event.Priority.Normal, this);\n \n \t\t\n /* Spout Required events */\n \t\tif(SpoutLoaded)\n \t\t{\n \t\t\tfinal pchestInventoryListener inventoryListener = new pchestInventoryListener(this, chestManager);\n \n \t /* Inventory events */\n \t\t\tpm.registerEvent(Type.CUSTOM_EVENT, inventoryListener, Event.Priority.Normal, this);\n \t\t}\n }",
"public MainEvent() {\n super.register(new HelloWorld());\n }",
"@Override\r\n public void createEvent(EventBean event) throws BusinessLogicException {\n }",
"@Override\r\n\tpublic void startEvent() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void startEvent() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void crearVehiculo() {\n\t\t\r\n\t}",
"private void registerEvents() {\n createRoomBTN.addActionListener(actionEvent -> {\n chatController.createRoom(roomNameIF.getText());\n roomNameIF.setText(\"\");\n });\n\n backBTN.addActionListener(actionEvent -> {\n if (chatController.getJoinedRooms().size() > 0) chatView.renderChatPanel();\n });\n }",
"private void initializeEventControllers() {\n trNewPersonalEvent = EventControllersFactory.createTrNewPersonalEvent();\n trDeletePersonalEvent = EventControllersFactory.createTrDeletePersonalEvent();\n trNewPeriodicNotification = EventControllersFactory.createTrNewPeriodicNotification();\n trDeletePeriodicNotification = EventControllersFactory.createTrDeletePeriodicNotification();\n }",
"public Evento(String nom, String lug, String desc){\n\t\tthis.nombre=nom;\n\t\tthis.lugar=lug;\n\t\tthis.descripcion=desc;\t\t\n\t}",
"@EventName(\"targetCreated\")\n EventListener onTargetCreated(EventHandler<TargetCreated> eventListener);",
"public WorkTimeEvent() {\r\n super();\r\n }",
"@Override\r\n\tpublic void initEvent() {\n\r\n\t}",
"public PersistentLogEventListener() {\n\t\tthis(new EventDAO());\n\t}",
"public ManipularEstudiantes() {\n initComponents();\n cme = new Control_Mantenimiento_Estudiante(this);\n this.gUI_botones2.agregar_eventos(cme);\n }",
"public VentanaEventos(String categoria) {\n //usuarioMostrar = ControladorUsuario.buscarUsuario(nickUsuario);\n categoriaActual=categoria;\n initComponents();\n mostrarTabla();\n\n\n }",
"private void createFrame() {\n\t\tEventQueue.invokeLater(new Runnable() {\n\t\t\t@Override\n\t\t\tpublic void run() {\n\t\t\t\tfinal JFrame frame = new JFrame(\"Create Event\");\n\t\t\t\tframe.setDefaultCloseOperation(JFrame.DISPOSE_ON_CLOSE);\n\t\t\t\ttry {\n\t\t\t\t\tUIManager.setLookAndFeel(UIManager.getSystemLookAndFeelClassName());\n\t\t\t\t} catch (Exception e) {\n\t\t\t\t\te.printStackTrace();\n\t\t\t\t}\n\t\t\t\tfinal JTextArea textArea = new JTextArea(15, 50);\n\t\t\t\ttextArea.setText(\"Untitled Event\");\n\t\t\t\ttextArea.setWrapStyleWord(true);\n\t\t\t\ttextArea.setEditable(true);\n\t\t\t\ttextArea.setFont(Font.getFont(Font.SANS_SERIF));\n\n\t\t\t\tJPanel panel = new JPanel();\n\t\t\t\tpanel.setLayout(new GridLayout(1, 4));\n\t\t\t\tfinal JTextField d = new JTextField(\"\" + year + \"/\" + month + \"/\" + day);\n\t\t\t\tfinal JTextField startTime = new JTextField(\"1:00am\");\n\t\t\t\tJTextField t = new JTextField(\"to\");\n\t\t\t\tt.setEditable(false);\n\t\t\t\tfinal JTextField endTime = new JTextField(\"2:00am\");\n\t\t\t\tJButton save = new JButton(\"Save\");\n\t\t\t\tpanel.add(d);\n\t\t\t\tpanel.add(startTime);\n\t\t\t\tpanel.add(t);\n\t\t\t\tpanel.add(endTime);\n\t\t\t\tpanel.add(save);\n\n\t\t\t\tsave.addActionListener(new ActionListener() {\n\n\t\t\t\t\t@Override\n\t\t\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\t\t\ttry {\n\t\t\t\t\t\t\teventsData.addEvent(new Event(YYYYMMDD(d.getText().trim()), startTime.getText(),\n\t\t\t\t\t\t\t\t\tendTime.getText(), textArea.getText()));\n\t\t\t\t\t\t\tupdateEventsView(eventsRender);\n\t\t\t\t\t\t} catch (Exception ex) {\n\t\t\t\t\t\t\tif (ex instanceof IllegalArgumentException)\n\t\t\t\t\t\t\t\tpromptMsg(ex.getMessage(), \"Error\");\n\t\t\t\t\t\t\telse promptMsg(ex.getMessage(), \"Error\");\n\t\t\t\t\t\t}\n\t\t\t\t\t\tframe.dispatchEvent(new WindowEvent(frame, WindowEvent.WINDOW_CLOSING));\n\t\t\t\t\t}\n\t\t\t\t});\n\n\t\t\t\tframe.setSize(500, 100);\n\t\t\t\tframe.setLayout(new GridLayout(2, 1));\n\t\t\t\tframe.add(textArea);\n\t\t\t\tframe.add(panel);\n\t\t\t\tframe.setLocationByPlatform(true);\n\t\t\t\tframe.setVisible(true);\n\t\t\t}\n\t\t});\n\t}"
]
| [
"0.84884614",
"0.75155926",
"0.73397565",
"0.6993198",
"0.6940482",
"0.6693163",
"0.66661835",
"0.66538733",
"0.6647964",
"0.6647964",
"0.6646281",
"0.6557526",
"0.65385467",
"0.65254277",
"0.651942",
"0.65115637",
"0.64877844",
"0.64834636",
"0.648085",
"0.64396614",
"0.64004624",
"0.6386789",
"0.63771105",
"0.63741016",
"0.63741016",
"0.6373006",
"0.63683254",
"0.63440055",
"0.6328144",
"0.6309547",
"0.6298409",
"0.62880504",
"0.62865514",
"0.6280088",
"0.627444",
"0.62425363",
"0.62250787",
"0.62072426",
"0.6174614",
"0.6162305",
"0.6152786",
"0.6136586",
"0.6134731",
"0.6122777",
"0.60969746",
"0.60894716",
"0.6058897",
"0.602056",
"0.60053366",
"0.59995425",
"0.5984309",
"0.5980972",
"0.59600157",
"0.59477735",
"0.5937164",
"0.5889036",
"0.5879479",
"0.58357465",
"0.58300966",
"0.5829814",
"0.582626",
"0.5825125",
"0.58070594",
"0.5799973",
"0.5797344",
"0.5796556",
"0.5796218",
"0.5793692",
"0.5775249",
"0.5774315",
"0.5774243",
"0.5771361",
"0.5766373",
"0.5747616",
"0.57396275",
"0.5736866",
"0.5735842",
"0.5730364",
"0.5722409",
"0.57131",
"0.5699006",
"0.5669133",
"0.56649864",
"0.5664347",
"0.56594163",
"0.5654258",
"0.56520766",
"0.5641976",
"0.56404614",
"0.56404614",
"0.56397015",
"0.56386065",
"0.56352454",
"0.5625175",
"0.56243384",
"0.5619812",
"0.56189597",
"0.5618804",
"0.5615934",
"0.5612885",
"0.5606694"
]
| 0.0 | -1 |
Meotodo para buscar que sean iguales | public void calcular() {
int validar, c, d, u;
int contrasena = 246;
c = Integer.parseInt(spiCentenas.getValue().toString());
d = Integer.parseInt(spiDecenas.getValue().toString());
u = Integer.parseInt(spiUnidades.getValue().toString());
validar = c * 100 + d * 10 + u * 1;
//Si es igual se abre.
if (contrasena == validar) {
etiResultado.setText("Caja Abierta");
}
//Si es menor nos indica que es mas grande
if (validar < contrasena) {
etiResultado.setText("El número secreto es mayor");
}
//Si es mayot nos indica que es mas pequeño.
if (validar > contrasena) {
etiResultado.setText("El número secreto es menor");
}
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private boolean iguales(Pares f){\n\t\t\tboolean devolucion = false;\n\t\t\t\n\t\t\tif(f!=null){\n\t\t\t\tif(primero.iguales(f.getSegundo())){\n\t\t\t\t\tif(segundo.iguales(f.getPrimero())){\n\t\t\t\t\t\tif(distancia==f.getDistancia()){\n\t\t\t\t\t\t\tdevolucion=true;\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t\t\n\t\t\t\n\t\t\treturn devolucion;\n\t\t}",
"private ArrayList<Pelicula> busquedaPorGenero(ArrayList<Pelicula> peliculas, String genero){\r\n\r\n ArrayList<Pelicula> peliculasPorGenero = new ArrayList<>();\r\n\r\n\r\n\r\n for(Pelicula unaPelicula:peliculas){\r\n\r\n if(unaPelicula.getGenre().contains(genero)){\r\n\r\n peliculasPorGenero.add(unaPelicula);\r\n }\r\n }\r\n\r\n return peliculasPorGenero;\r\n }",
"String getOne_or_more();",
"public void resolver(){\n\t\tfor(int i = 0 ; i < tablero.getTamanio(); i++){\n\t\t\tfor(int j = 0 ; j < diccionario.getCantPalabras(); j++){\n\t\t\t\tif(tablero.getTablero()[i].contains(diccionario.getPalabra()[j].getPalabra()) && !diccionario.getPalabra()[j].isEncontrada()){\n\t\t\t\t\tdiccionario.getPalabra()[j].setEncontrada(true);\n\t\t\t\t\trespuesta.add(Integer.toString(j+1) + \"\\tE\");\n\t\t\t\t} else if (tablero.getTablero()[i].contains(diccionario.getPalabra()[j].invertirPalabra()) && !diccionario.getPalabra()[j].isEncontrada()){\n\t\t\t\t\tdiccionario.getPalabra()[j].setEncontrada(true);\n\t\t\t\t\trespuesta.add(Integer.toString(j+1) + \"\\tO\");\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t//Busca sentido Norte y Sur\n\t\tString aux = \"\";\n\t\tfor(int i = 0 ; i < tablero.getTamanio(); i++){\n\t\t\tfor(int j = 0 ; j < tablero.getTamanio(); j++){\n\t\t\t\taux += tablero.getTablero()[j].charAt(i);\n\t\t\t}\n\t\t\tfor(int j = 0 ; j < diccionario.getCantPalabras() ; j++){\n\t\t\t\tif(aux.contains(diccionario.getPalabra()[j].getPalabra()) && !diccionario.getPalabra()[j].isEncontrada()){\n\t\t\t\t\tdiccionario.getPalabra()[j].setEncontrada(true);\n\t\t\t\t\trespuesta.add(Integer.toString(j+1) + \"\\tS\");\n\t\t\t\t} else if(aux.contains(diccionario.getPalabra()[j].invertirPalabra()) && !diccionario.getPalabra()[j].isEncontrada()){\n\t\t\t\t\tdiccionario.getPalabra()[j].setEncontrada(true);\n\t\t\t\t\trespuesta.add(Integer.toString(j+1) + \"\\tN\");\n\t\t\t\t}\n\t\t\t}\n\t\t\taux = \"\";\n\t\t}\n\t\t\n\t\ttry{\n\t\t\tPrintWriter pw = new PrintWriter(new File(\"Rapigrama1.out\"));\n\t\t\tfor(int i = 0 ; i < respuesta.size(); i++){\n\t\t\t\tpw.println(respuesta.get(i));\n\t\t\t}\n\t\t\tpw.close();\n\t\t} catch (Exception e){\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public boolean iguales(Sector s){\n\t\tboolean devolucion=false;\n\t\t\n\t\tif((this.coordenada.getCoordenadas()[0]==s.getCoordenada().getCoordenadas()[0]) && (this.coordenada.getCoordenadas()[1]==s.getCoordenada().getCoordenadas()[1]) && (this.coordenada.getCoordenadas()[2]==s.getCoordenada().getCoordenadas()[2])){\n\t\t\tfor (int i = 0; i < almacen.length; i++) {\n\t\t\t\tif(this.almacen[i].iguales(s.getAlmacen()[i])){\n\t\t\t\t\tif(this.existencias[i]==s.getExistencias()[i]){\n\t\t\t\t\t\tdevolucion=true;\n\t\t\t\t\t}else{\n\t\t\t\t\t\tdevolucion=false;\n\t\t\t\t\t\ti=almacen.length;\n\t\t\t\t\t}\n\t\t\t\t}else{\n\t\t\t\t\tdevolucion=false;\n\t\t\t\t\ti=almacen.length;\n\t\t\t\t}\n\t\t\t}\n\t\t}else{\n\t\t\tdevolucion=false;\n\t\t}\n\t\t\n\t\treturn devolucion;\n\t}",
"Set<String> getGameShortcodes();",
"public boolean allAre(ISelect s){\r\n return true; \r\n }",
"@In String search();",
"static Producto busqueda(int codigo, Vector productos){ \r\n \tboolean band = false;\r\n \t//si return no es igual a null nos regresara el codigo\r\n Producto p,retornP = null; \r\n //For para comparar todos los codigos del vector que digitamos\r\n for(int x = 0; x < productos.size(); x++){ \r\n \tp = (Producto) productos.elementAt(x);\r\n \t//si el codigo es el mismo regresamos el producto que encontramos\r\n if(p.getCodigo() == codigo) \r\n \tretornP = p;\r\n }\r\n return retornP;\r\n }",
"private String getContainsList(){\n\t\t\n\t\tArrayList<String> containsList = new ArrayList<String>();\n\t\t\n\t\tIterator<String> it = tagArray.iterator();\n\t\tString tag;\n\t\t\n\t\twhile (it.hasNext()) {\n\t\t\t\n\t\t\ttag = it.next();\n\t\t\t\n\t\t\tString containsClause = \"PrimaryTag='\" + \n\t\t\t tag + \"'\";\n\t\t\t \n\t\t\tcontainsList.add(containsClause);\n\t\t\t\n\t\t}\n\t\t\n\t\tString retVal = StringUtils.join(containsList, \" or \");\n\n\t\treturn retVal;\n\t}",
"public boolean buscar(String referencia){\n Nodo aux = inicio;\r\n // Bandera para indicar si el valor existe.\r\n boolean encontrado = false;\r\n // Recorre la lista hasta encontrar el elemento o hasta \r\n // llegar al final de la lista.\r\n while(aux != null && encontrado != true){\r\n // Consulta si el valor del nodo es igual al de referencia.\r\n if (referencia == aux.getValor()){\r\n // Canbia el valor de la bandera.\r\n encontrado = true;\r\n }\r\n else{\r\n // Avansa al siguiente. nodo.\r\n aux = aux.getSiguiente();\r\n }\r\n }\r\n // Retorna el resultado de la bandera.\r\n return encontrado;\r\n }",
"public List<Cuenta> buscarCuentasList(Map filtro);",
"String getANY_OTHER();",
"private void buscar(final String filtro) {\n refAnimales.addListenerForSingleValueEvent(new ValueEventListener() {\n @Override\n public void onDataChange(@NonNull DataSnapshot dataSnapshot) {\n long size = dataSnapshot.getChildrenCount();\n ArrayList<String> animalesFirebase = new ArrayList<>();\n for (int i = 0; i < size; i++) {\n\n String code = dataSnapshot.child(\"\" + i).child(\"codigo\").getValue(String.class);\n String nombre = dataSnapshot.child(\"\" + i).child(\"nombre\").getValue(String.class);\n String tipo = dataSnapshot.child(\"\" + i).child(\"tipo\").getValue(String.class);\n String raza = dataSnapshot.child(\"\" + i).child(\"raza\").getValue(String.class);\n String animal = code + \" | \" + nombre + \" | \" + tipo + \" | \" + raza;\n\n if (code.equalsIgnoreCase(filtro) || nombre.equalsIgnoreCase(filtro) || tipo.equalsIgnoreCase(filtro) || raza.equalsIgnoreCase(filtro)) {\n animalesFirebase.add(animal);\n }\n }\n if (animalesFirebase.size() == 0) {\n animalesFirebase.add(\"No se encuentran animales con ese código\");\n }\n adaptar(animalesFirebase);\n }\n\n @Override\n public void onCancelled(@NonNull DatabaseError databaseError) {\n\n }\n });\n }",
"java.lang.String getResidues();",
"@Override \n public Set<String> keySet() {\n \n \n // definido um set onde colocar o resultado\n Set<String> r = new HashSet<>();\n \n try {\n \n // abre uma conecção\n conn = Connect.connect();\n \n // abrir um statment com a querie que temos de executar\n PreparedStatement stm = conn.prepareStatement(\"SELECT nome FROM Componente WHERE visivel=TRUE;\");\n \n \n // o resultado colocado em rs\n ResultSet rs = stm.executeQuery();\n \n while (rs.next()) // enquanto existir o next\n r.add(rs.getString(\"nome\")); // adiciona o aluno\n } catch (SQLException | ClassNotFoundException e) {\n e.printStackTrace();\n } finally {\n Connect.close(conn);\n }\n return r;\n }",
"public static void main(String[] args) {\n\t\tSet<String> nomes = new HashSet<String>();\n\t\tnomes.add(\"Mauricio\");\n\t\tnomes.add(\"Guilherme\");\n\t\tnomes.add(\"Guilherme\");\n\t\t\n\t\tSystem.out.println(nomes.size());\n\t\t\n\t\t/*System.out.println(nomes.get(0));\n\t\tSystem.out.println(nomes.contains(\"Guilherme\"));*/\n\t\t\n\t\t/*for(int i = 0; i < nomes.size(); i++){\n\t\t\tSystem.out.println(nomes.get(i));\n\t\t}*/\n\t/*\t\n\t\tfor(String nome : nomes){\n\t\t\tSystem.out.println(nome);\n\t\t}\n\t\t\n\t\t//Collections.sort(nomes);\n\t\t\n\t\tSystem.out.println(\"Ordenado: \");\n\t\t\n\t\tfor(String nome : nomes){\n\t\t\tSystem.out.println(nome);\n\t\t}\n\t\t\n\t\tArrayList<Conta> contas = new ArrayList<Conta>();\n\t\tConta c1 = new Conta(1500.0);\n\t\tConta c2 = new Conta(700.0);\n\t\tcontas.add(c1);\n\t\tcontas.add(c2);\n\t\t\n\t\tCollections.sort(contas);\n\t\t\n\t\tfor(Conta c : contas){\n\t\t\tSystem.out.println(c);\n\t\t}\n\t\t\n\t\t//System.out.println(contas.get(1));\n\t\t*/\n\t\t\n\t\t/*Set<Conta> contas = new HashSet<Conta>();\n\t\tConta c1 = new Conta(200.0);\n\t\tConta c2 = new Conta(200.0);\n\t\tcontas.add(c1);\n\t\tcontas.add(c1);\n\t\tcontas.add(c2);\n\t\t\n\t\tSystem.out.println(contas.size());*/\n\t\t\n\t\tMap<String, Conta> contas = new HashMap<String, Conta>();\n\t\tConta c1 = new Conta(200.0);\n\t\tConta c2 = new Conta(500.0);\n\t\tcontas.put(\"Diretor\", c1);\n\t\tcontas.put(\"Gerente\", c2);\n\t\t\n\t\tSystem.out.println(contas.get(\"Diretor\").getSaldo());\n\t\tSystem.out.println(contas.get(\"Gerente\").getSaldo());\n\t\tSystem.out.println(contas.size());\n\t\t\n\t}",
"private Set<Glyph> retrieveFlags ()\r\n {\r\n Set<Glyph> foundFlags = new HashSet<>();\r\n\r\n for (Glyph glyph : getSystem().getInfo().getGlyphs()) {\r\n Shape shape = glyph.getShape();\r\n\r\n if (ShapeSet.Flags.contains(shape)) {\r\n if (glyph.getTranslations().contains(this)) {\r\n foundFlags.add(glyph);\r\n }\r\n }\r\n }\r\n\r\n return foundFlags;\r\n }",
"private static final String FIND_ALL() {\r\n\t\treturn \"from Shipping3VO vo \";\r\n\t}",
"@Override\n\tpublic String getSearchkeys() {\n\t\treturn matricule+\",\"+nom;\n\t}",
"public static void main(String[] args) {\n\r\n\t\tString [] conArr = {\"아시아_서울\",\"아시아_북경\",\"아시아_타이페이\",\r\n\t\t\t\t\"아메리카_뉴욕\",\"아메리카_시카고\",\"유럽_이스탄불\",\r\n\t\t\t\t\"유럽_런던\",\"아메리카_상파올로\",\"아프리카_아크라\"};\r\n\t\tList conti = new ArrayList<>();\r\n\t\tList conData = new ArrayList<>();\r\n\t\tfor (String cc : conArr) {\r\n\t\t\tString [] ccArr = cc.split(\"_\");\r\n\t\t\tArrayList now;\r\n\t\t\tif(conti.contains(ccArr[0]))\r\n\t\t\t{\r\n\t\t\t\tnow = (ArrayList)(conData.get(conti.indexOf(ccArr[0])));\r\n\t\t\t}else{\r\n\t\t\t\tnow = new ArrayList();\r\n\t\t\t\tconti.add(ccArr[0]);\r\n\t\t\t\tconData.add(now);\r\n\t\t\t}\r\n\t\t\tnow.add(ccArr[1]);\r\n\t\t\t\t\r\n\t\t}\r\n\t\t\r\n\t\tSystem.out.println(conti);\r\n\t\tSystem.out.println(conData);\r\n\t\t\r\n\t\tSetTvl [] arr = {\r\n\t\t\t\tnew SetTvl(\"뉴욕\", 7, 500),\r\n\t\t\t\tnew SetTvl(\"이스탄불\", 3, 300),\r\n\t\t\t\tnew SetTvl(\"타이페이\", 2, 100),\r\n\t\t\t\tnew SetTvl(\"서울\", 1, 80),\r\n\t\t\t\tnew SetTvl(\"이스탄불\", 3, 260),\r\n\t\t\t\tnew SetTvl(\"런던\", 6, 400),\r\n\t\t\t\tnew SetTvl(\"상파울로\", 6, 600)\r\n\t\t};\r\n\t\t\r\n\t\tSet index = new HashSet<>();\r\n\t\r\n\t\tfor (SetTvl tvl : arr) {\r\n\t\t\tIterator it = index.iterator();\r\n\t\t\t\r\n\t\t\tboolean res = true;\r\n\t\t\twhile(it.hasNext())\r\n\t\t\t{\r\n\t\t\t\tSetTvl com = (SetTvl)it.next();\r\n\t\t\t\tif(com.name.equals(tvl.name))\r\n\t\t\t\t{\r\n\t\t\t\t\tres = false;\r\n\t\t\t\t\t\r\n\t\t\t\t\tif(com.money>tvl.money)\r\n\t\t\t\t\t{\r\n\t\t\t\t\t\tit.remove();\r\n\t\t\t\t\t\tres = true;\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\tif(res)\r\n\t\t\t\tindex.add(tvl);\r\n\t\t\t\r\n\t\t}\r\n\t\tSystem.out.println(index);\r\n\t\t\r\n\t\tString [] gogo = {\"이스탄불\",\"타이페이\",\"상파울로\",\"런던\"};\r\n\t\t\r\n\t\tArrayList goList = new ArrayList<>();\r\n\t\t\r\n\t\t\r\n\t\tfor (Object conDataList : conData) {\r\n\t\t\tArrayList ar = new ArrayList();\r\n\t\t\tgoList.add(ar);\r\n\t\t\tfor (Object con: (ArrayList)conDataList) {\r\n\t\t\t\tString sss = (String)con;\r\n\t\t\t\tfor (String gg : gogo) {\r\n\t\t\t\t\tif(sss.equals(gg))\r\n\t\t\t\t\t\tar.add(sss);\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\tif(ar.size()==0)\r\n\t\t\t\tgoList.remove(ar);\r\n\t\t}\r\n\t\t\r\n\t\tSystem.out.println(goList);\r\n\t\t\r\n\t\tint ttMoney=0,ttday=0;\r\n\t\t\r\n\t\tfor (Object ggList : goList) {\r\n\t\t\tfor (Object obj : (ArrayList)ggList) {\r\n\t\t\t\t\r\n\t\t\t\tIterator it = index.iterator();\r\n\t\t\t\twhile(it.hasNext())\r\n\t\t\t\t{\r\n\t\t\t\t\tSetTvl com = (SetTvl)it.next();\r\n\t\t\t\t\tif(com.name.equals(obj))\r\n\t\t\t\t\t{\r\n\t\t\t\t\t\tttMoney+=com.money;\r\n\t\t\t\t\t\tttday+=com.day;\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\tttday++;\r\n\t\t}\r\n\t\t\r\n\t\tttday--;\r\n\t\tSystem.out.println(\"총경비:\"+ttMoney);\r\n\t\tSystem.out.println(\"총여행일:\"+ttday);\r\n\t\t\t\r\n\t}",
"private static Sintoma sintomaPorNombre(String nomSintoma) {\n return sintomas.stream().filter(s -> s.getTipo().equalsIgnoreCase(nomSintoma)).findAny().orElse(null);\n }",
"private static boolean fun3(List<String> res, List<String> ac1) {\n\t\tHashSet<String> hs=new HashSet<String>();\r\n\t\tfor(int i=0;i<res.size();i++){\r\n\t\t\ths.add(res.get(i));\r\n\t\t}\r\n\t\tfor(int i=0;i<ac1.size();i++){\r\n\t\t\tif(hs.contains(ac1.get(i)))\r\n\t\t\treturn true;\r\n\t\t}\r\n\t\treturn false;\r\n\t}",
"static public ArrayList<Mascota> filtroLugar(String pLugar){\n ArrayList<Mascota> resul = new ArrayList<>(); \n for(Mascota mascota : mascotas){\n if(mascota.getUbicacion().equals(pLugar)){\n resul.add(mascota); \n }\n }\n return resul;\n }",
"public void sensibleMatches2() \n { \n Map<String, Set<String>> clientMap = new HashMap<>();\n Set<String> interests = new HashSet<>();\n\n interests.add(\"Food\");\n interests.add(\"Wine\");\n interests.add(\"Tandems\");\n clientMap.put(\"Hal\", interests);\n\t \n interests = new HashSet<>();\n interests.add(\"Food\");\n interests.add(\"Walking\");\n interests.add(\"Welding\");\n clientMap.put(\"Gemma\", interests);\n\n interests = new HashSet<>();\n interests.add(\"Food\");\n interests.add(\"Cinema\");\n interests.add(\"Wine\");\n clientMap.put(\"Caroline\", interests);\n\n Set<String> halsInterests = clientMap.get(\"Hal\");\n String outputString;\n Set<String> eachClientInterests;\n Set<String> intersection ;\n\n for (String eachClient : clientMap.keySet()) \n {\n if (!eachClient.equals(\"Hal\")) \n {\n eachClientInterests = clientMap.get(eachClient);\n intersection = new HashSet<>(halsInterests);\n intersection.retainAll(eachClientInterests);\n outputString = \"Hal and \" + eachClient \n + \" have common interests: \"\n + intersection;\n System.out.println(outputString);\n }\n }\n }",
"private boolean cursoAsignado(Curso curso, Curso[] cursoAsignado) {\n\n for (int i = 0; i < cursoAsignado.length; i++) {\n\n if (cursoAsignado[i] != null) {\n if (curso.getNombre().equals(cursoAsignado[i].getNombre())) {\n return true;\n }\n }\n }\n return false;\n }",
"@Override \n public Set<String> keySet() {\n \n \n // definido um set onde colocar o resultado\n Set<String> r = new HashSet<>();\n \n try {\n \n // abre uma conecção\n conn = Connect.connect();\n \n // abrir um statment com a querie que temos de executar\n PreparedStatement stm = conn.prepareStatement(\"SELECT nomePacote FROM Pacote WHERE visivel=TRUE;\");\n \n \n // o resultado colocado em rs\n ResultSet rs = stm.executeQuery();\n \n while (rs.next()) // enquanto existir o next\n r.add(rs.getString(\"nomePacote\")); \n } catch (SQLException | ClassNotFoundException e) {\n e.printStackTrace();\n } finally {\n Connect.close(conn);\n }\n return r;\n }",
"public ArrayList<String> findPossibleCorridors(String corridorX);",
"private boolean buscarUnidadMedida(String valor) {\n\t\ttry {\n\t\t\tlistUnidadMedida = unidadMedidaI.getAll(Unidadmedida.class);\n\t\t} catch (Exception e) {\n\t\n\t\t}\n\n\t\tboolean resultado = false;\n\t\tfor (Unidadmedida tipo : listUnidadMedida) {\n\t\t\tif (tipo.getMedidaUm().equals(valor)) {\n\t\t\t\tresultado = true;\n\t\t\t\tbreak;\n\t\t\t} else {\n\t\t\t\tresultado = false;\n\t\t\t}\n\t\t}\n\n\t\treturn resultado;\n\t}",
"public static void main (String[]args){\n String[] test = {\"1, 3, 4, 7, 13\", \"1, 2, 4, 13, 15\"};\n Stream<String> testStrings = Arrays.stream(test);\n testStrings.map(s -> s.split(\",\"))\n .flatMap(Arrays::stream).distinct()\n .collect(Collectors.toList())\n .forEach(System.out::print);\n //FindIntersection(test);\n //System.out.println(LongWord(test));\n\n }",
"private String[] condicionGeneral(String condicion) {\n String retorno[] = new String[2];\n try {\n String[] simbolos = {\"<=\", \">=\", \"==\", \"!=\", \"<\", \">\"};\n String simbolo = \"0\";\n\n if (condicion.length() > 3) {\n condicion = condicion.substring(1, condicion.length());\n for (int i = 0; i < simbolos.length; i++) {//selecciona el simbolo de la condicion\n if (condicion.contains(simbolos[i])) {\n simbolo = simbolos[i];\n break;\n }\n }\n if (simbolo.equals(\"0\")) {\n retorno[0] = \"0\";\n retorno[1] = \"mala construcción de la sentencia.\";\n } else {\n String var[] = condicion.split(simbolo);\n if (var.length == 2) {\n if (esNumero(var[0])) {\n if (esNumero(var[1])) {\n retorno[0] = \"1\";\n retorno[1] = \"\";\n } else {\n if (var[1].matches(\"[a-zA-Z]*\")) { //comprueba que solo contenga letas \n byte aux = 0;\n\n for (int i = 0; i < codigo.size(); i++) {\n if (var[1].equals(codigo.get(i).toString())) {\n aux++;\n }\n }\n if (aux > 0) {\n retorno[0] = \"1\";\n retorno[1] = \"\";\n } else {\n retorno[0] = \"0\";\n retorno[1] = \"no se reconoce la variable \" + var[1] + \".\";\n }\n } else {\n retorno[0] = \"0\";\n retorno[1] = \"mala construcción de la sentencia.\";\n }\n }\n } else {\n if (var[0].matches(\"[a-zA-Z]*\")) { //comprueba que solo contenga letras \n byte aux = 0;\n for (int i = 0; i < codigo.size(); i++) {\n if (var[0].equals(codigo.get(i).toString())) {\n aux++;\n }\n }\n if (aux > 0) {\n if (esNumero(var[1])) {\n retorno[0] = \"1\";\n retorno[1] = \"\";\n } else {\n if (var[0].matches(\"[a-zA-Z]*\")) { //comprueba que solo contenga letas \n aux = 0;\n\n for (int i = 0; i < codigo.size(); i++) {\n if (var[1].equals(codigo.get(i).toString())) {\n aux++;\n }\n }\n if (aux > 0) {\n retorno[0] = \"1\";\n retorno[1] = \"\";\n } else {\n retorno[0] = \"0\";\n retorno[1] = \"no se reconoce la variable \" + var[1] + \".\";\n }\n } else {\n retorno[0] = \"0\";\n retorno[1] = \"mala construcción de la sentencia.\";\n }\n }\n } else {\n retorno[0] = \"0\";\n retorno[1] = \"no se reconoce la variable \" + var[0] + \".\";\n }\n } else {\n retorno[0] = \"0\";\n retorno[1] = \"mala construcción de la sentencia.\";\n }\n\n }\n } else {\n retorno[0] = \"0\";\n retorno[1] = \"mala construcción de la sentencia.\";\n }\n }\n } else {\n retorno[0] = \"0\";\n retorno[1] = \"mala construcción de la sentencia.\";\n }\n\n\n\n } catch (Exception e) {\n System.out.println(\"Error en condicion \" + e.getClass());\n } finally {\n return retorno;\n }\n }",
"private ArrayList<String> findChampions() {\n\t\tString searchContents = search.getText();\n\t\tArrayList<String> result = new ArrayList<String>();\n\t\tfor (String c : CHAMPIONLIST) {\n\t\t\tif (c.toLowerCase().contains(searchContents.toLowerCase())) {\n\t\t\t\tresult.add(c);\n\t\t\t}\n\t\t}\n\t\treturn result;\n\t}",
"public void busqueda_Aestrella(Estado estado_inicial, Estado estado_final) {\r\n\t\tabiertos.add(estado_inicial); // Añado como nodo abierto el punto de partida del laberinto\r\n\t\tEstado actual = abiertos.get(0); // Selecciono como punto actual el primero de los nodos abiertos (el punto de partida)\r\n\t\ttrata_repe = 1; // Variable para indicar al switch como tiene que tratar los repetidos en el switch del metodo tratar_repetidos\r\n\t\twhile (actual != estado_final && !abiertos.isEmpty()) { // Mientras que actual no sea el punto final y haya nodos abiertos\r\n\t\t\titeraciones++; // Contador de iteraciones del bucle while\r\n\t\t\tabiertos.remove(0); // Elimino el nodo actual de la lista de abiertos\r\n\t\t\tcerrados.add(actual); // Y lo añado a nodos cerrados\t\t\t\r\n\t\t\testados_cerrados = cerrados.size(); // Contador para estados cerrados\r\n\r\n\t\t\thijos = generar_sucesores(actual); // Genero los hijos del punto actual (Limpio de muros o punto de inicio)\r\n\t\t\thijos = tratar_repetidos(cerrados, abiertos, hijos); // Trato los repetidos\r\n\t\t\tinsertar(hijos); // Acolo los hijos en la lista de abiertos\r\n\t\t\testados_visitados += hijos.size(); // Contador para estados visitados\r\n\r\n\t\t\tCollections.sort(abiertos, getCompHeuristicaMasProf()); // Ordeno por heuristica Manhattan + Profundidad la cola de abiertos\r\n\r\n\t\t\tactual = abiertos.get(0); // Selecciono como actual el primero en la cola de abiertos\r\n\r\n\t\t\tif (actual.equals(estado_final)) { //Compruebo si estamos en el estado final\r\n\t\t\t\tmostrarcamino(actual, estado_final); // Muestro el camino solucion\r\n\t\t\t\tbreak; //Salgo del bucle while\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"public HashSet<Position> casesAutour()\n {\n HashSet<Position> s = new HashSet<Position>();\n\n for (Direction d : Direction.values())\n s.add(this.relativePos(d));\n\n return s;\n }",
"Set<String> getInterpetAsTrueStrings(int columnIndex);",
"public Set<String> honorifics();",
"public List<TagPregunta> findMatchingTags(String parcial);",
"public void findBigsWhoRankedLittle(String selectedLittle){\n ArrayList<String> bigsWhoWant = new ArrayList<>();\n for (Map.Entry big: matching.bigsPreferences.entrySet()){\n String aBig = big.getKey().toString();\n ArrayList<String> prefLittles = matching.bigsPreferences.get(aBig);\n if (prefLittles.contains(selectedLittle)){\n bigsWhoWant.add(aBig);\n }\n }\n whoRanksLittleResultsLabel.setText(bigsWhoWant.toString());\n setLinedText(whoRanksLittleResultsLabel, bigsWhoWant);\n\n }",
"private int transita(int q, char s) {\n\n\tint qf = 0;\n\tfor(Transicion t : d)\n\t if((qf = t.obtenerEstadoSiguiente(q, s)) != 0)\n\t\testadosAuxiliar.add(qf);\n\n\treturn qf;\n }",
"protected String comprobarConsumoEnergetico(Letra letra){\r\n if(getConsumoEnergetico() == Letra.A | getConsumoEnergetico() == Letra.B | getConsumoEnergetico() == Letra.C \r\n | getConsumoEnergetico() == Letra.D | getConsumoEnergetico() == Letra.E | getConsumoEnergetico() == Letra.F){\r\n return \"Consumo energetico correcto; letra correcta\";\r\n }\r\n else{\r\n return \"Consumo energetico incorrecto; letra erronea\";\r\n }\r\n}",
"public Set<Integer> want() {\n Set<Integer> wanted = new HashSet<>();\n if (incomplete[0] == incomplete[1]) {\n wanted.add(incomplete[0]);\n } else if (Math.abs(incomplete[0] - incomplete[1]) == 1) {\n int left = Math.min(incomplete[0], incomplete[1]);\n if (left - 1 >= 0) wanted.add(left - 1);\n if (left + 2 <= 8) wanted.add(left + 2);\n } else if (Math.abs(incomplete[0] - incomplete[1]) == 2) {\n wanted.add(Math.min(incomplete[0], incomplete[1]) + 1);\n }\n return wanted;\n }",
"private void mostrarPorMarca() {\n Scanner leer = new Scanner(System.in);\n String marca; //marca a buscar\n int cont = 0;\n System.out.print(\"Introduce la marca de coche a buscar: \");\n marca = leer.next();\n\n System.out.print(\"Las posiciones con coches con esa marca son: \");\n\n for (int i = 0; i < this.coches.size(); i++) {\n if (coches.get(i).getMarca().equalsIgnoreCase(marca)) {\n if (cont != 0) {\n System.out.print(\", \");\n }\n System.out.print(i);\n cont = 1;\n }\n }\n System.out.println();\n }",
"List<T> buscarTodosComNomeLower();",
"private static ArrayList<String> getAllKeyWord(String [] lignes){\n ArrayList<String> res= new ArrayList<>();\n\n // La recherche dans le pdf\n for(String ligne : lignes){\n for(String mot : ligne.split(\" |/|-|\\\\(|\\\\)|,\")){\n\n try{\n if(mot.toLowerCase(Locale.ENGLISH).equals(\"c#\".toLowerCase(Locale.ENGLISH)))\n res.add(\"csharp\");\n else\n if(mot.toLowerCase(Locale.ENGLISH).equals(\"c++\".toLowerCase(Locale.ENGLISH)))\n res.add(\"cpp\");\n else\n if(!mot.toLowerCase(Locale.ENGLISH).matches(\"| |à|de|je|un|et|une|en|d'un|d'une|le|la|avec|:|\\\\|\"))\n res.add(mot.toLowerCase(Locale.ENGLISH));\n }catch (IllegalArgumentException e){\n //System.out.println(e.getMessage());\n continue;\n }\n }\n //System.out.println(\"line: \"+s);\n }\n return (ArrayList) res.stream().distinct().collect(Collectors.toList());\n }",
"public void sensibleMatches1() \n { \n Map<String, Set<String>> clientMap = new HashMap<>();\n Set<String> interests = new HashSet<>();\n\n interests.add(\"Food\");\n interests.add(\"Wine\");\n interests.add(\"Tandems\");\n clientMap.put(\"Hal\", interests);\n\t \n interests = new HashSet<>();\n interests.add(\"Food\");\n interests.add(\"Walking\");\n interests.add(\"Welding\");\n clientMap.put(\"Gemma\", interests);\n\t \n interests = new HashSet<>();\n interests.add(\"Food\");\n interests.add(\"Cinema\");\n interests.add(\"Wine\");\n clientMap.put(\"Caroline\", interests);\n\n Set<String> halsInterests = clientMap.get(\"Hal\");\n String outputString;\n Set<String> eachClientInterests;\n Set<String> intersection ;\n\n Map<String, Set<String>> mapWithoutHal = new HashMap<>(clientMap);\n mapWithoutHal.remove(\"Hal\");\n for (String eachClient : mapWithoutHal.keySet()) \n {\n eachClientInterests = clientMap.get(eachClient);\n intersection = new HashSet<>(halsInterests);\n intersection.retainAll(eachClientInterests);\n outputString = \"Hal and \" + eachClient \n + \" have common interests: \"\n + intersection;\n System.out.println(outputString);\n }\n }",
"public void matchesDemo() \n {\n Map<String, Set<String>> clientMap = new HashMap<>();\n Set<String> interests = new HashSet<>();\n\n interests.add(\"Food\");\n interests.add(\"Wine\");\n interests.add(\"Tandems\");\n clientMap.put(\"Hal\", interests);\n\t \n interests = new HashSet<>();\n interests.add(\"Food\");\n interests.add(\"Walking\");\n interests.add(\"Welding\");\n clientMap.put(\"Gemma\", interests);\n\t \n interests = new HashSet<>();\n interests.add(\"Food\");\n interests.add(\"Cinema\");\n interests.add(\"Wine\");\n clientMap.put(\"Caroline\", interests);\n\n Set<String> halsInterests = clientMap.get(\"Hal\");\n String outputString;\n Set<String> eachClientInterests;\n Set<String> intersection;\n\n for (String eachClient : clientMap.keySet()) \n {\n eachClientInterests = clientMap.get(eachClient);\n intersection = new HashSet<>(halsInterests);\n intersection.retainAll(eachClientInterests);\n outputString = \"Hal and \" + eachClient \n + \" have common interests: \"\n + intersection;\n System.out.println(outputString) ;\n }\n }",
"boolean getMultiple();",
"void findMatchings(boolean isProtein) {\n\n GraphDatabaseFactory dbFactory = new GraphDatabaseFactory();\n HashSet<String > searchSpaceList = new HashSet<>();\n GraphDatabaseService databaseService = dbFactory.newEmbeddedDatabase(graphFile);\n for (int id: queryGraphNodes.keySet()) {\n if(isProtein)\n searchSpaceList.add(queryGraphNodes.get(id).label);\n else\n searchSpaceList.add(String.valueOf(queryGraphNodes.get(id).labels.get(0)));\n }\n for(String x: searchSpaceList) {\n ResourceIterator<Node> xNodes;\n try(Transaction tx = databaseService.beginTx()) {\n xNodes = databaseService.findNodes(Label.label(x));\n tx.success();\n }\n\n while (xNodes.hasNext()) {\n Node node = xNodes.next();\n if (searchSpaceProtein.containsKey(x))\n searchSpaceProtein.get(x).add(node.getId());\n else {\n HashSet<Long> set = new HashSet<>();\n set.add(node.getId());\n searchSpaceProtein.put(x, set);\n }\n }\n\n }\n\n if(isProtein)\n search(0, databaseService, true);\n else\n search(0, databaseService, false);\n databaseService.shutdown();\n }",
"public Archangel buscarName(String name){\n\tboolean val = false;\n Archangel angel = null;\n\tfor(int i =0;i<arch.length && !val;i++){\n\t\tif(arch[i]!=null){\n\t\tif(arch[i].getName().equalsIgnoreCase(name)){\n\t\t\tangel = arch[i];\n\t\t\tval = true;\n\t\t}\n\t}\n\t\telse{\n\t\t\tval=true;\n\t\t}\n\t\t}\n\t\nreturn angel;\n\n}",
"public void consultasSeguimiento() {\r\n try {\r\n switch (opcionMostrarAnalistaSeguim) {\r\n case \"Cita\":\r\n ListSeguimientoRadicacionesConCita = Rad.ConsultasRadicacionYSeguimiento(2, mBsesion.codigoMiSesion());\r\n break;\r\n case \"Entrega\":\r\n ListSeguimientoRadicacionesConCita = Rad.ConsultasRadicacionYSeguimiento(3, mBsesion.codigoMiSesion());\r\n break;\r\n }\r\n } catch (Exception e) {\r\n mbTodero.setMens(\"Error en el metodo '\" + this.getClass() + \".consultasSeguimiento()' causado por: \" + e.getMessage());\r\n mbTodero.error();\r\n }\r\n\r\n }",
"private String idsConstrain(ArrayList <String> uids){\n String query = \"\";\n if(uids.size() > 0){\n query = \" ( \" \n // If uids used are PMC ids, remove PMC part - not recognized by Entrez utilites! \n + uids.get(0).replace(\"PMC\", \"\") \n + \"[UID] \";\n\n for(int i = 1; i < uids.size() ; i++){\n query += \"OR \" \n // If uids used are PMC ids, remove PMC part - not recognized by Entrez utilites! \n + uids.get(i).replace(\"PMC\", \"\") \n + \"[UID] \";\n }\n query += \") \"; \n }\n return query; \n }",
"private ArrayList<String> translateGoodsList(List<TradeGood> goodList) {\n ArrayList<String> cargoNames = new ArrayList<>();\n for (int i = 0; i < goodList.size(); i++) {\n for (int j = 0; j < TradeGood.values().length; j++) {\n if (goodList.get(i) != null && goodList.get(i) == (TradeGood.values()[j])) {\n cargoNames.add(this.getApplication().getResources().getStringArray(R.array.goodNames)[j]);\n }\n }\n\n }\n return cargoNames;\n }",
"protected void evento_cambioEstadoFiltrosLocales() {\r\n\t\tfinal List<PataBidireccional> allPatas = getPatas();\r\n\t\tfor (final PataBidireccional pataConectora : allPatas) {\r\n\t\t\tfinal Condicion nuevoFiltro = calcularFiltroDeEntradaPara(pataConectora);\r\n\t\t\tpataConectora.actualizarFiltroDeEntrada(nuevoFiltro);\r\n\t\t}\r\n\t}",
"private void many(Set<String> s) {\n\t\twhile (!done() && s.contains(program.charAt(pos)+\"\"))\n\t\t\tpos++;\n }",
"@Override\n\tpublic Set<T> valeurs() {\n\t\treturn Set.of(val);\n\t}",
"private void searchFunction() {\n\t\t\r\n\t}",
"public List<LocalCentroComercial> consultarLocalesCentroComercialRegistrados();",
"private int verificarIguales(int[] Teclas)\n\t{\n\t\tint contador = 0;\n\t\ttry\n\t\t{\n\t\t\tfor (int i = 0; i < Teclas.length; i++)\n\t\t\t{\n\t\t\t\tfor (int j = i + 1; j < Teclas.length; j++)\n\t\t\t\t{\n\t\t\t\t\tif (Teclas[j] == Teclas[i])\n\t\t\t\t\t{\n\t\t\t\t\t\tcontador++;\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\tcatch (NullPointerException error)\n\t\t{\n\t\t\tJOptionPane.showMessageDialog(null, \"Faltan Opciones!!\");\n\t\t}\n\t\treturn contador;\n\t}",
"public static int BuscarPerrox(Perro BaseDeDatosPerros[], String razas[], int codPerro) {\n int cont = 0;\r\n boolean condicion = false;\r\n char generoPerro, generoPerr, generPerro = 'd';\r\n String razaPerr, tipoRaza;\r\n do {\r\n System.out.println(\"Ingrese el Genero de perro : Macho(M),Hembra (H)\");\r\n generoPerro = TecladoIn.readLineNonwhiteChar();\r\n\r\n if (ValidacionDeGenero(generoPerro)) {\r\n generPerro = generoPerro;\r\n condicion = true;\r\n } else {\r\n System.out.println(\".......................................................\");\r\n System.out.println(\"Ingrese un Genero Correcto: Macho('M') o Hembra ('H')\");\r\n System.out.println(\".......................................................\");\r\n condicion = false;\r\n }\r\n } while (condicion != true);\r\n \r\n tipoRaza=IngresarRazaCorrecta();\r\n \r\n for (int i = 0; i < codPerro; i++) {\r\n razaPerr = BaseDeDatosPerros[i].getRaza();\r\n generoPerr = BaseDeDatosPerros[i].getGenero();\r\n\r\n if (tipoRaza.equals(razaPerr) && (generPerro == generoPerr)) {\r\n cont++;\r\n }\r\n\r\n }\r\n\r\n \r\n\r\n return cont;}",
"public int[] contarCodons(String seq){\n int [] countCodons=new int[65];\n for (int i=0;i<seq.length()-2;i=i+3){\n String c=seq.substring(i, i+3);\n int j=0;\n while (j<nameCodon.length && nameCodon[j].compareTo(c)!=0) j++;\n if (j<nameCodon.length)\n countCodons[j]++;\n else\n countCodons[64]++;\n }\n return countCodons;\n\n }",
"public static void checkMagazine(String[] magazine, String[] ransom) {\n HashMap<String, Integer> usableWords = makeMap(magazine);\n for (int i = 0; i < ransom.length; i++) {\n if (usableWords.containsKey(ransom[i]) && usableWords.get(ransom[i]) > 0) {\n usableWords.merge(ransom[i], -1, Integer::sum); // uses the word\n } else {\n System.out.println(\"No\");\n return;\n }\n }\n System.out.println(\"Yes\");\n}",
"private void getBuildingNames(ArrayList<Item> items) {\n for(Item i: items) {\n String building = i.getBuilding();\n if(!set.contains(building)) {\n set.add(building);\n buildings.add(building);\n }\n }\n }",
"public int[] choisir(int[] coord)\r\n {\r\n int[] res = new int[3]; //tableau a rendre\r\n int x = coord[0];\r\n int y = coord[1]; //récupération des coordonnées\r\n int[] voisinage= new int[4]; //tableau qui regardera les cases adjacentes à la case cherchée\r\n voisinage[0] = getValHaut(x,y);\r\n voisinage[1] = getValDroite(x,y);\r\n voisinage[2] = getValBas(x,y);\r\n voisinage[3] = getValGauche(x,y);\r\n System.out.println(\"je choisis la case \"+x+\" \"+y+\"\");\r\n for(int i = 0; i<voisinage.length; i++ ) //parcours des possibilités si on joue sans créer d'opportunités adverses\r\n {\r\n if (Vision[x][y][i+1] == 0) //si il n'y a pas de trait déja tracé\r\n {\r\n if (voisinage[i] != 2) //si la case adjacente n'a pas déja deux traits dessinés\r\n {\r\n switch (i) //switch pour réagir selon la case a jouer\r\n {\r\n case 0:\r\n res[0]=x;\r\n res[1]=y;\r\n break;\r\n\r\n case 1:\r\n res[0]=x+1;\r\n res[1]=y;\r\n break;\r\n\r\n case 2:\r\n res[0]=x;\r\n res[1]=y+1;\r\n break;\r\n\r\n case 3:\r\n res[0]=x;\r\n res[1]=y;\r\n break;\r\n }\r\n //fin du switch sur i\r\n\r\n res[2]=i%2;\r\n return res;\r\n }\r\n //fin du si la case adjacente a déja 2 traits dessinés\r\n }\r\n //si il n'y a pas de trait déja tracé\r\n }\r\n //fin du for de parcours des possibilités de jouers sans créer d'opportunités adverses\r\n\r\n for(int i=0; i<voisinage.length ; i++ ) //Parcours des possibilités sans recherche d'opportunités\r\n {\r\n if (Vision[x][y][i+1] == 0) {\r\n switch (i) //switch pour réagir selon la case a jouer\r\n {\r\n case 0:\r\n res[0]=x;\r\n res[1]=y;\r\n break;\r\n\r\n case 1:\r\n res[0]=x+1;\r\n res[1]=y;\r\n break;\r\n\r\n case 2:\r\n res[0]=x;\r\n res[1]=y+1;\r\n break;\r\n\r\n case 3:\r\n res[0]=x;\r\n res[1]=y;\r\n break;\r\n }\r\n //fin du switch sur i\r\n\r\n res[2]=i%2;\r\n return res;\r\n }\r\n }\r\n //fin du parcours de possibilité sans recherche\r\n return tabVide;\r\n }",
"private Texture mapaAleatorio(int noAleatorio) {\n if (estadoMapa == EstadoMapa.RURAL){\n if(noAleatorio == 1){\n return texturaFondo1_1;\n }\n if(noAleatorio == 2){\n return texturaFondo1_2;\n }\n if(noAleatorio == 3){\n return texturaFondo1_3;\n }\n if(noAleatorio == 4){\n return texturaFondo1_4;\n }\n if(noAleatorio == 5){\n return texturaFondo1_5;\n }\n } else\n if (estadoMapa == EstadoMapa.URBANO) {\n if(noAleatorio == 1){\n return texturaFondo2_1;\n }\n if(noAleatorio == 2){\n return texturaFondo2_2;\n }\n if(noAleatorio == 3){\n return texturaFondo2_3;\n }\n if(noAleatorio == 4){\n return texturaFondo2_4;\n }\n if(noAleatorio == 5){\n return texturaFondo2_5;\n }\n } else if (estadoMapa == EstadoMapa.UNIVERSIDAD) {\n if(noAleatorio == 1){\n return texturaFondo3_1;\n }\n if(noAleatorio == 2){\n return texturaFondo3_2;\n }\n if(noAleatorio == 3){\n return texturaFondo3_3;\n }\n if(noAleatorio == 4){\n return texturaFondo3_4;\n }\n if(noAleatorio == 5){\n return texturaFondo3_5;\n }\n }else if (estadoMapa == EstadoMapa.SALONES) {\n if (noAleatorio == 1) {\n return texturaFondo4_1;\n }\n if (noAleatorio == 2) {\n return texturaFondo4_2;\n }\n if (noAleatorio == 3) {\n return texturaFondo4_3;\n }\n if (noAleatorio == 4) {\n return texturaFondo4_4;\n }\n if (noAleatorio == 5) {\n return texturaFondo4_5;\n }\n } else if (estadoMapa == EstadoMapa.RURALURBANO) { //Trancisiones\n return texturaRuralUrbano;\n } else if (estadoMapa == EstadoMapa.URBANOUNIVERSIDAD) {\n return texturaUrbanoUniversidad;\n } else if (estadoMapa == EstadoMapa.UNIVERSIDADSALONES) {\n return texturaUniversidadSalones;\n }\n return null;\n }",
"Match getMatches();",
"private Equipo buscarEquipoPorNombre(String buscado) {\n for (int i = 0; i < equipos.size(); i++) {\n if (equipos.get(i).getNombre().equalsIgnoreCase(buscado)) {\n return equipos.get(i);\n }\n }\n return null;\n }",
"private Collection<String[]> findPrefixPairMatches(String unitNameWithPrefix, boolean constrainBasedOnValidUnitNames, boolean onlyFirstMatch) {\n Collection<String[]> prefixMatches = new ArrayList<>();\n\n String[] prefixMatchByValue = findPrefixMatchByValue(unitNameWithPrefix, constrainBasedOnValidUnitNames);\n if(prefixMatchByValue != NO_PREFIX_MATCH_ARRAY)\n prefixMatches.add(prefixMatchByValue);\n\n prefixMatches.addAll(findPrefixMatchesByName(unitNameWithPrefix, constrainBasedOnValidUnitNames, onlyFirstMatch));\n\n for(String[] prefixMatch:prefixMatches)\n setProperlyOrderedPrefixNamePairs(prefixMatch);\n\n return prefixMatches;\n }",
"private boolean comandosNoPermitidos(String comandos){\n \tboolean encontrado = false;\n \tString iniciar = \"INICIAR\".toUpperCase();\n \tString paso = \"paso\".toUpperCase();\n \tString vaciar = \"vaciar\".toUpperCase();\n \tString crearCelula = \"crearCelula\".toUpperCase();\n \tString eliminarCelula = \"eliminarCelula\".toUpperCase();\n\n \t\n \tcomandos = comandos.toUpperCase();\n \tString[] words = comandos.split(\" \");\n \tif(words[0].equals(iniciar)){\n \t\tencontrado = true;\n \t}\n \telse if(words[0].equals(paso)){\n \t\tencontrado = true;\n \t}\n \telse if(words[0].equals(vaciar)){\n \t\tencontrado = true;\n \t}\n \telse if(words[0].equals(crearCelula)){\n \t\tencontrado = true;\n \t}\n \telse if(words[0].equals(eliminarCelula)){\n \t\tencontrado = true;\n \t}\n \t\n \treturn encontrado;\n }",
"public String askArrFilter();",
"private static List<String> getCandidates(String w, Set<String> words) {\n List<String> result = new LinkedList<>();\n for (int i = 0; i < w.length(); i++) {\n char[] chars = w.toCharArray();\n for (char ch = 'A'; ch <= 'Z'; ch++) {\n chars[i] = ch;\n String candidate = new String(chars);\n if (words.contains(candidate)) {\n result.add(candidate);\n }\n }\n }\n return result;\n }",
"@Override\n\tpublic Ingrediente buscarIngredientePorNombre(String nombre) {\n\t\t\n\t final Session session = this.sessionFactory.getCurrentSession();\n\t return (Ingrediente) session.createCriteria(Ingrediente.class)\n\t .add(Restrictions.eq(\"nombre\",nombre) )\n\t .uniqueResult();\n\t \n \n \n\t\t//\n\n\t/*\t\n\t\t//1.native query CASO DONDE SOLO PUEDO USARLO? \n\tSQLQuery query =\tsessionFactory.getCurrentSession().createSQLQuery(\"SELECT * FROM ingrediente where nombre like '%\"+nombre+\"%'\");\n\t List <Ingrediente> ingredientes = query.list();\n\t\n\t //2.queries no se si importe bien el query\n\t\n\t \tQuery query2 =\tsessionFactory.getCurrentSession().createQuery(\"from auto where id=:id\");\n\t\tquery2.setString(\"id\",nombre);\n\t\t\n\t\tIngrediente ingredientes2 =(Ingrediente) query.uniqueResult();\n\t\t\t\n\t\tDIO VERDE\n\t\t\n\t\treturn null;*/\n\t}",
"boolean hasAll();",
"boolean hasAll();",
"Set<String> getRangeLocalNames();",
"String getPais();",
"@Override\n\tpublic Map<IAlgo, Integer> recommandAlgosContained() {\n\t\treturn Collections.EMPTY_MAP;\n\t}",
"@Override\r\n /**\r\n * *\r\n *Primero revisa si los apellidos con iguales, en el caso de que sean iguales\r\n *entra al if y compara por nombres, de lo contrario nunca entra al if y \r\n * compara normalmente por apellido\r\n * \r\n */ \r\n public void ordenarPersonas (){\r\n Comparator<Persona> comparacionPersona= (Persona persona1,Persona persona2)->{\r\n \r\n if(persona1.getApellidos().compareToIgnoreCase(persona2.getApellidos())==0){\r\n return persona1.getNombres().compareToIgnoreCase(persona2.getNombres());}\r\n return persona1.getApellidos().compareToIgnoreCase(persona2.getApellidos());\r\n }; \r\n\r\n listaPersona.sort(comparacionPersona);\r\n }",
"boolean hasResidues();",
"Map getAll();",
"public List<LocalCentroComercial> consultarLocalesCentroComercialPorParametro(Map<String, String> filtros);",
"private void carregaAvisosGerais() {\r\n\t\tif (codWcagEmag == WCAG) {\r\n\t\t\t/*\r\n\t\t\t * Mudan�as de idioma\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"4.1\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Ignorar arte ascii\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"13.10\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Utilizar a linguagem mais clara e simples poss�vel\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"14.1\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * navega��o de maneira coerente\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"13.4\", AVISO, codWcagEmag, \"\"));\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"14.2\", AVISO, codWcagEmag, \"\"));\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"11.4\", AVISO, codWcagEmag, \"\"));\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"14.3\", AVISO, codWcagEmag, \"\"));\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"12.3\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Fornecer mapa\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"13.3\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Abreviaturas\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"4.2\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Fornecer atalho\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"9.5\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Prefer�ncias (por ex., por idioma ou por tipo de conte�do).\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"11.3\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * BreadCrumb\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"13.5\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * fun��es de pesquisa\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"13.7\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * front-loading\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"13.8\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Documentos compostos por mais de uma p�gina\r\n\t\t\t */\r\n\t\t\t// comentado por n�o ter achado equi\r\n\t\t\t// erroOuAviso.add(new ArmazenaErroOuAviso(\"3.10\", AVISO,\r\n\t\t\t// codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Complementar o texto com imagens, etc.\r\n\t\t\t */\r\n\t\t\t// erroOuAviso.add(new ArmazenaErroOuAviso(\"3.11\", AVISO,\r\n\t\t\t// codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Forne�a metadados.\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"13.2\", AVISO, codWcagEmag, \"\"));\r\n\t\t} else if (codWcagEmag == EMAG) {\r\n\t\t\t/*\r\n\t\t\t * Mudan�as de idioma\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"1.2\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Ignorar arte ascii\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"1.3\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Utilizar a linguagem mais clara e simples poss�vel\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"1.9\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * navega��o de maneira coerente\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"1.10\", AVISO, codWcagEmag, \"\"));\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"1.21\", AVISO, codWcagEmag, \"\"));\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"1.24\", AVISO, codWcagEmag, \"\"));\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"2.9\", AVISO, codWcagEmag, \"\"));\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"2.11\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Fornecer mapa\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"2.17\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Abreviaturas\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"3.2\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Fornecer atalho\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"3.3\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Prefer�ncias (por ex., por idioma ou por tipo de conte�do).\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"3.5\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * BreadCrumb\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"3.6\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * fun��es de pesquisa\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"3.8\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * front-loading\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"3.9\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Documentos compostos por mais de uma p�gina\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"3.10\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Complementar o texto com imagens, etc.\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"3.11\", AVISO, codWcagEmag, \"\"));\r\n\t\t\t/*\r\n\t\t\t * Forne�a metadados.\r\n\t\t\t */\r\n\t\t\terroOuAviso.add(new ArmazenaErroOuAviso(\"3.14\", AVISO, codWcagEmag, \"\"));\r\n\t\t}\r\n\r\n\t}",
"void findInGoods(String str) {\n Iterator<Map.Entry<SportEquipment, Integer>> i = goods.entrySet().iterator();\n int count = 1;\n boolean flag = false; //indicates whether sequences were found or not\n\n while (i.hasNext()) {\n\n Map.Entry<SportEquipment, Integer> pair = i.next();\n SportEquipment seq = pair.getKey();\n String category = seq.getCategory().toString();\n String name = seq.getTitle();\n if (category.contains(str.toUpperCase()) || name.contains(str.toLowerCase())) {\n System.out.println(Integer.toString(count) + Strings.DROP + category + Strings.SEPARATOR2 +\n name + Strings.CURRENCY + seq.getPrice() + Strings.SEPARATOR + pair.getValue());\n flag = true;\n }\n count++;\n }\n if (!flag) System.out.println(Strings.ITEM_IS_NOT_FOUND);\n\n }",
"public Set<String>[] getFollow();",
"List<Videogioco> retriveByGenere(String genere);",
"public int hayGanador() {\n\t\tif(marcador1==2) {\n\t\t\tresultado=1;\n\t\t\treturn 1;\n\t\t}\n\t\telse if(marcador2==2) {\n\t\t\tresultado=2;\n\t\t\treturn 2;\n\t\t}\n\t\telse {\n\t\t\treturn 0;\n\t\t}\n\t}",
"public String generateStringCamposFiltro() {\r\n\t\treturn inicializarCamposComunes();\r\n\t}",
"public List<Madeira> buscaCidadesEstado(String estado);",
"public List<ConceptoRetencionSRI> autocompletarConceptoRetencionIVASRI(String consulta)\r\n/* 550: */ {\r\n/* 551:583 */ String consultaMayuscula = consulta.toUpperCase();\r\n/* 552:584 */ List<ConceptoRetencionSRI> lista = new ArrayList();\r\n/* 553:586 */ for (ConceptoRetencionSRI conceptoRetencionSRI : getListaConceptoRetencionSRI()) {\r\n/* 554:587 */ if (((conceptoRetencionSRI.getCodigo().toUpperCase().contains(consultaMayuscula)) || \r\n/* 555:588 */ (conceptoRetencionSRI.getNombre().toUpperCase().contains(consultaMayuscula))) && \r\n/* 556:589 */ (conceptoRetencionSRI.getTipoConceptoRetencion().equals(TipoConceptoRetencion.IVA))) {\r\n/* 557:590 */ lista.add(conceptoRetencionSRI);\r\n/* 558: */ }\r\n/* 559: */ }\r\n/* 560:594 */ return lista;\r\n/* 561: */ }",
"public String[] getVariants_ru(int[] randIds){\n Cursor crs;\n String[] variants_ru = new String[4];\n for(int i = 0; i< 4; i++){\n String[] args = new String[1];\n args[0] = Integer.toString(randIds[i]+1);\n crs = aniDB.getReadableDatabase().rawQuery(\"SELECT name_ru FROM titles WHERE id = ?\",args);\n if(crs.moveToFirst()) {\n variants_ru[i] = crs.getString(crs.getColumnIndex(\"name_ru\"));\n }\n crs.close();\n }\n return variants_ru;\n }",
"public Set<PrepSelRelType> selectionalRes(boolean valid) {\n return DefaultVnRestrictions.map(prep.restrictions(), PrepSelRelType::fromString).stream()\n .map(valid ? VnRestrictions::include : VnRestrictions::exclude)\n .flatMap(Set::stream)\n .collect(Collectors.toSet());\n }",
"List<Oficios> buscarActivas();",
"public HashSet<Integer> mesesComprou(){\n HashSet<Integer> hs = new HashSet<>();\n produtosComprados.keySet().stream().forEach(x->hs.add(x.getMes()));\n return hs;\n }",
"public List<DadosDiariosVO> validaSelecionaAcumuladoDadosDiarios(String ano) {\n\n\t\tList<DadosDiariosVO> listaDadosDiarios = validaSelecionaDetalhesDadosDiarios(ano);\n\n\t\tList<DadosDiariosVO> listaFiltradaDadosDiarios = new ArrayList<DadosDiariosVO>();\n\t\tList<DadosDiariosVO> listaFaturamentoDiario = new ArrayList<DadosDiariosVO>();\n\t\tList<DadosDiariosVO> listaFaturamentoAcumulado = new ArrayList<DadosDiariosVO>();\n\n\t\t/* Ordena a lista em EMITIDOS;EMITIDOS CANCELADOS;EMITIDOS RESTITUIDOS */\n\n\t\tfor (int i = 0; i < listaDadosDiarios.size(); i++) {\n\t\t\tString dataParaComparacao = listaDadosDiarios.get(i).getAnoMesDia();\n\n\t\t\tfor (int j = 0; j < listaDadosDiarios.size(); j++) {\n\n\t\t\t\tif (dataParaComparacao.equals(listaDadosDiarios.get(j).getAnoMesDia())) {\n\t\t\t\t\tDadosDiariosVO dados = new DadosDiariosVO();\n\t\t\t\t\tdados.setAnoMesDia(listaDadosDiarios.get(j).getAnoMesDia());\n\t\t\t\t\tdados.setProduto(listaDadosDiarios.get(j).getProduto());\n\t\t\t\t\tdados.setTipo(listaDadosDiarios.get(j).getTipo());\n\t\t\t\t\tdados.setValorDoDia(listaDadosDiarios.get(j).getValorDoDia());\n\n\t\t\t\t\tlistaFiltradaDadosDiarios.add(dados);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\n\t\touter: for (int i = listaFiltradaDadosDiarios.size() - 1; i >= 0; i--) {\n\t\t\tfor (int j = 0; j < listaFiltradaDadosDiarios.size(); j++) {\n\t\t\t\tif (listaFiltradaDadosDiarios.get(i).getAnoMesDia()\n\t\t\t\t\t\t.equalsIgnoreCase(listaFiltradaDadosDiarios.get(j).getAnoMesDia())\n\t\t\t\t\t\t&& listaFiltradaDadosDiarios.get(i).getProduto()\n\t\t\t\t\t\t\t\t.equalsIgnoreCase(listaFiltradaDadosDiarios.get(j).getProduto())\n\t\t\t\t\t\t&& listaFiltradaDadosDiarios.get(i).getTipo()\n\t\t\t\t\t\t\t\t.equalsIgnoreCase(listaFiltradaDadosDiarios.get(j).getTipo())\n\t\t\t\t\t\t&& listaFiltradaDadosDiarios.get(i).getValorDoDia()\n\t\t\t\t\t\t\t\t.equalsIgnoreCase(listaFiltradaDadosDiarios.get(j).getValorDoDia())) {\n\t\t\t\t\tif (i != j) {\n\n\t\t\t\t\t\tlistaFiltradaDadosDiarios.remove(i);\n\t\t\t\t\t\tcontinue outer;\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\n\t\t/* Ordena por data */\n\t\tCollections.sort(listaFiltradaDadosDiarios, DadosDiariosVO.anoMesDiaCoparator);\n\n\t\tString dataTemp = \"\";\n\t\tBigDecimal somaAcumulada = new BigDecimal(\"0.0\");\n\n\t\t/* abaixo a visao da faturamento de cada dia */\n\t\tDadosDiariosVO faturamentoDiario = new DadosDiariosVO();\n\n\t\ttry {\n\n\t\t\tfor (int i = 0; i <= listaFiltradaDadosDiarios.size(); i++) {\n\n\t\t\t\tif (i == 0) {\n\t\t\t\t\tdataTemp = listaFiltradaDadosDiarios.get(i).getAnoMesDia();\n\n\t\t\t\t\tfaturamentoDiario.setAnoMesDia(listaFiltradaDadosDiarios.get(i).getAnoMesDia());\n\t\t\t\t\tfaturamentoDiario.setProduto(listaFiltradaDadosDiarios.get(i).getProduto());\n\t\t\t\t\tfaturamentoDiario.setTipo(\"FATURAMENTO\");\n\t\t\t\t}\n\n\t\t\t\tif ((i != listaFiltradaDadosDiarios.size())\n\t\t\t\t\t\t&& dataTemp.equals(listaFiltradaDadosDiarios.get(i).getAnoMesDia())) {\n\n\t\t\t\t\tsomaAcumulada = new BigDecimal(listaFiltradaDadosDiarios.get(i).getValorDoDia()).add(somaAcumulada);\n\n\t\t\t\t} else {\n\t\t\t\t\tif (listaFiltradaDadosDiarios.size() == i) {\n\t\t\t\t\t\tfaturamentoDiario.setValorDoDia(somaAcumulada.toString());\n\t\t\t\t\t\tlistaFaturamentoDiario.add(faturamentoDiario);\n\t\t\t\t\t\tbreak;\n\t\t\t\t\t} else {\n\t\t\t\t\t\tfaturamentoDiario.setValorDoDia(somaAcumulada.toString());\n\t\t\t\t\t\tlistaFaturamentoDiario.add(faturamentoDiario);\n\t\t\t\t\t}\n\n\t\t\t\t\tdataTemp = listaFiltradaDadosDiarios.get(i).getAnoMesDia();\n\t\t\t\t\tsomaAcumulada = new BigDecimal(listaFiltradaDadosDiarios.get(i).getValorDoDia());\n\n\t\t\t\t\tfaturamentoDiario = new DadosDiariosVO();\n\t\t\t\t\tfaturamentoDiario.setAnoMesDia(listaFiltradaDadosDiarios.get(i).getAnoMesDia());\n\t\t\t\t\tfaturamentoDiario.setProduto(listaFiltradaDadosDiarios.get(i).getProduto());\n\t\t\t\t\tfaturamentoDiario.setTipo(\"FATURAMENTO\");\n\t\t\t\t}\n\t\t\t}\n\t\t} catch (IndexOutOfBoundsException ioobe) {\n\t\t\tSystem.err.println(\n\t\t\t\t\t\"VisãoExecutiva_Diaria_BO - método validaSelecionaAcumuladoDadosDiarios - adicionando dados fictícios...\");\n\t\t\tDadosDiariosVO dados = new DadosDiariosVO();\n\t\t\tdados.setAnoMesDia(\"2015-10-02\");\n\t\t\tdados.setProduto(\"TESTE\");\n\t\t\tdados.setTipo(\"FATURAMENTO\");\n\t\t\tdados.setValorDoDia(\"0.0\");\n\t\t\tlistaFaturamentoDiario.add(dados);\n\t\t\tSystem.err.println(\"... dados inseridos\");\n\t\t}\n\n\t\t/* abaixo construimos a visao acumulada */\n\t\tBigDecimal somaAnterior = new BigDecimal(\"0.0\");\n\t\tint quantidadeDias = 0;\n\t\tfor (int i = 0; i < listaFaturamentoDiario.size(); i++) {\n\n\t\t\tDadosDiariosVO faturamentoDiarioAcumulado = new DadosDiariosVO();\n\t\t\tif (i == 0) {\n\t\t\t\tfaturamentoDiarioAcumulado.setAnoMesDia(listaFaturamentoDiario.get(i).getAnoMesDia());\n\t\t\t\tfaturamentoDiarioAcumulado.setProduto(listaFaturamentoDiario.get(i).getProduto());\n\t\t\t\tfaturamentoDiarioAcumulado.setTipo(listaFaturamentoDiario.get(i).getTipo());\n\t\t\t\tfaturamentoDiarioAcumulado.setValorDoDia(listaFaturamentoDiario.get(i).getValorDoDia());\n\n\t\t\t\tsomaAnterior = somaAnterior.add(new BigDecimal(listaFaturamentoDiario.get(i).getValorDoDia()));\n\t\t\t\tquantidadeDias++;\n\t\t\t\tlistaFaturamentoAcumulado.add(faturamentoDiarioAcumulado);\n\n\t\t\t} else {\n\t\t\t\tfaturamentoDiarioAcumulado.setAnoMesDia(listaFaturamentoDiario.get(i).getAnoMesDia());\n\t\t\t\tfaturamentoDiarioAcumulado.setProduto(listaFaturamentoDiario.get(i).getProduto());\n\t\t\t\tfaturamentoDiarioAcumulado.setTipo(listaFaturamentoDiario.get(i).getTipo());\n\t\t\t\tfaturamentoDiarioAcumulado.setValorDoDia(\n\t\t\t\t\t\tsomaAnterior.add(new BigDecimal(listaFaturamentoDiario.get(i).getValorDoDia())).toString());\n\n\t\t\t\tsomaAnterior = somaAnterior.add(new BigDecimal(listaFaturamentoDiario.get(i).getValorDoDia()));\n\t\t\t\tquantidadeDias++;\n\t\t\t\tlistaFaturamentoAcumulado.add(faturamentoDiarioAcumulado);\n\t\t\t}\n\t\t}\n\n\t\tUteis uteis = new Uteis();\n\t\tString dataAtualSistema = new SimpleDateFormat(\"dd/MM/yyyy\").format(new Date(System.currentTimeMillis()));\n\t\tString dataCut[] = dataAtualSistema.split(\"/\");\n\t\tString mes_SO;\n\t\tmes_SO = dataCut[1];\n\n\t\t/* BP */\n\t\tList<FaturamentoVO> listaBP = dadosFaturamentoDetalhado;\n\t\tint mes_SO_int = Integer.parseInt(mes_SO);\n\t\tString bpMes = listaBP.get(0).getMeses()[mes_SO_int - 1];\n\t\tint diasUteis = uteis.retornaDiasUteisMes(mes_SO_int - 1);\n\t\tBigDecimal bpPorDia = new BigDecimal(bpMes).divide(new BigDecimal(diasUteis), 6, RoundingMode.HALF_DOWN);\n\n\t\tBigDecimal somaAnteriorBp = new BigDecimal(\"0.0\");\n\t\tfor (int i = 0; i < quantidadeDias; i++) {\n\t\t\tDadosDiariosVO faturamentoDiarioAcumulado = new DadosDiariosVO();\n\t\t\tif (i == 0) {\n\t\t\t\tfaturamentoDiarioAcumulado.setAnoMesDia(listaFaturamentoAcumulado.get(i).getAnoMesDia());\n\t\t\t\tfaturamentoDiarioAcumulado.setProduto(listaFaturamentoAcumulado.get(i).getProduto());\n\t\t\t\tfaturamentoDiarioAcumulado.setTipo(\"BP\");\n\t\t\t\tfaturamentoDiarioAcumulado.setValorDoDia(bpPorDia.toString());\n\n\t\t\t\tsomaAnteriorBp = somaAnteriorBp.add(bpPorDia);\n\t\t\t\tlistaFaturamentoAcumulado.add(faturamentoDiarioAcumulado);\n\n\t\t\t} else {\n\t\t\t\tfaturamentoDiarioAcumulado.setAnoMesDia(listaFaturamentoAcumulado.get(i).getAnoMesDia());\n\t\t\t\tfaturamentoDiarioAcumulado.setProduto(listaFaturamentoAcumulado.get(i).getProduto());\n\t\t\t\tfaturamentoDiarioAcumulado.setTipo(\"BP\");\n\n\t\t\t\tsomaAnteriorBp = somaAnteriorBp.add(bpPorDia);\n\n\t\t\t\tfaturamentoDiarioAcumulado.setValorDoDia(somaAnteriorBp.toString());\n\n\t\t\t\tlistaFaturamentoAcumulado.add(faturamentoDiarioAcumulado);\n\t\t\t}\n\t\t}\n\n\t\treturn listaFaturamentoAcumulado;\n\t}",
"private String getPossibleDirections() {\n\t\t\n\t\tString directionsToReturn=\"\";\n\t\t\n\t\tif(entity.getFrontCell() != null) {\n\t\t\t\n\t\tHashSet<E_Direction> possibleDirections = entity.getFrontCell().getPossibleDirections();\n\t\tint size=possibleDirections.size();\n\t\t\n\t\tE_Direction[] directions = new E_Direction[size];\n\t\tdirections = possibleDirections.toArray(directions);\n\t\t\n\t\tif(size > 1) directionsToReturn = directions[0].toString()+\",\"+directions[1].toString(); \n\t\n\t\telse\n directionsToReturn = directions[0].toString();\n\t\n\t\t}\n\t\t\n\t\t\n\t\treturn directionsToReturn; // the directons text to string\n\t\t\n\t}",
"public void colorearSecuencial() {\n\t\t// Collections.shuffle(nodos);\n\t\tcolorearSecuencialAlternativo();\n\t}",
"List<PilotContainer> Search(String cas, String word);",
"@NotNull\n @Override\n public Object[] getVariants() {\n final Set<String> alreadySeen = ContainerUtil.newHashSet();\n final List<LookupElement> results = ContainerUtil.newArrayList();\n ResolveUtil.treeWalkUp(myElement, new FrogBaseScopeProcessor() {\n @Override\n public boolean execute(@NotNull PsiElement element, ResolveState state) {\n if (element instanceof FrogNamedElement) {\n FrogNamedElement namedElement = (FrogNamedElement) element;\n String name = namedElement.getName();\n if (!alreadySeen.contains(name)) {\n alreadySeen.add(name);\n results.add(buildLookupElement(namedElement));\n }\n }\n return true;\n }\n });\n return ArrayUtil.toObjectArray(results);\n }",
"private List<String> retrieveObjectsInRoom(Room room) {\n List<String> retirevedInRoom = new ArrayList<>();\n for (String object : room.getObjects()) {\n if (wantedObjects.contains(object)) {\n retirevedInRoom.add(object);\n }\n }\n return retirevedInRoom;\n }",
"Set<Eid> aliases();",
"public static Set<String> getEnglishWords()\n{\n return english_words;\n}",
"private static Vuelo[] partidas(Vuelo [] vuelosArray){\n Ciudad concordia = new Ciudad(\"CON\",\"Concordia\");\n\n Vuelo[] listado = new Vuelo[0];\n for (Vuelo vuelo: vuelosArray) {\n if (vuelo.getCiudadOrigen().equals(concordia)) {\n listado = agregarVuelo(listado, vuelo);\n }\n }\n return listado;\n }"
]
| [
"0.5775896",
"0.56371665",
"0.5438555",
"0.53862697",
"0.5367793",
"0.53406376",
"0.5326582",
"0.5236973",
"0.5226738",
"0.5222249",
"0.52213806",
"0.5214605",
"0.51457363",
"0.51288074",
"0.51231134",
"0.51087856",
"0.51000553",
"0.5072616",
"0.50640166",
"0.5061144",
"0.5054182",
"0.5051377",
"0.504922",
"0.5047149",
"0.50392956",
"0.50304484",
"0.5030439",
"0.50019705",
"0.49995732",
"0.49875683",
"0.49863493",
"0.49823636",
"0.49822342",
"0.4971754",
"0.4965496",
"0.496003",
"0.49480143",
"0.4946452",
"0.49423486",
"0.4932417",
"0.49304092",
"0.4923201",
"0.4913789",
"0.49137753",
"0.49029103",
"0.48974484",
"0.4893074",
"0.48742875",
"0.48712927",
"0.48700762",
"0.48603582",
"0.4846789",
"0.4837529",
"0.48314142",
"0.4828992",
"0.48256147",
"0.48230562",
"0.48218992",
"0.4820205",
"0.48136187",
"0.48097736",
"0.48065805",
"0.48059624",
"0.48047993",
"0.48021534",
"0.4797462",
"0.47934422",
"0.47924203",
"0.47903007",
"0.4786233",
"0.47841683",
"0.47802302",
"0.47802302",
"0.47794175",
"0.4775298",
"0.4773835",
"0.4773042",
"0.47659203",
"0.4765907",
"0.47579646",
"0.47574273",
"0.4756612",
"0.4755819",
"0.47551993",
"0.4752843",
"0.47523788",
"0.47501734",
"0.4748261",
"0.47439507",
"0.47439077",
"0.474304",
"0.47415894",
"0.47410506",
"0.47403425",
"0.47341746",
"0.4732731",
"0.47300062",
"0.4729659",
"0.47294775",
"0.47293508",
"0.47293058"
]
| 0.0 | -1 |
Evento de nuestro boton. | public void btnAbrirActionPerformed(ActionEvent evt) {
calcular();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void ingresar_a_la_Opcion_de_eventos() {\n\t\t\n\t}",
"abstract void botonRecibir_actionPerformed(ActionEvent e);",
"@Override\n\t\t\t\t\tpublic void onEvent(Event event) throws Exception {\n\t\t\t\t\t\tMessagebox.Button button = (Messagebox.Button) event.getData();\n\t\t\t\t\t\tif (button == Messagebox.Button.YES) {\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tanalista.setiEstatus(EstatusPersonaFactory.getEstatusActivo());\n\t\t\t\t\t\t\t\t//EL METODO DICE ACTUTALIZARPERSONA\n\t\t\t\t\t\t\t\tsMaestros.acutalizarPersona(analista);\n\t\t\t\t\t\t\t\tcambiarAnalistas(0, null, null);\n\t\t\t\t\t\t\t\tnotifyChange(\"analistas\");\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\t\n\t\t\t\t}",
"abstract void botonEnviar_actionPerformed(ActionEvent e);",
"public void definirActionBoton(ActionEvent e) {\n CommandButton btnSelect = (CommandButton) e.getSource();\n\n //System.out.println(\"boton id: \" + btnSelect.getId());\n //this.getCbAction().setDisabled(false);\n if (btnSelect.getId().equals(\"btnEdit\")) {\n this.getCbActionTelefonos().setValue(\"Editar\");\n this.getListadoTelefonosBean().setiTipoBoton(1);\n //System.out.println(\"Entro al Edit\");\n }\n if (btnSelect.getId().equals(\"btnDelete\")) {\n this.getCbActionTelefonos().setValue(\"Eliminar\");\n this.getListadoTelefonosBean().setiTipoBoton(2);\n //System.out.println(\"Entro al Delete\");\n }\n\n if (btnSelect.getId().equals(\"btnCreateTelefonos\")) {\n //System.out.println(\"Entro al if : \" + this.getPersona());\n // this.getCbAction().setValue(\"Guardar\");\n //System.out.println(\"Despues del if\");\n this.getListadoTelefonosBean().setiTipoBoton(0);\n System.out.println(\"Get Tipo boton\" + this.getListadoEmailBean().getiTipoBoton());\n }//fin if\n\n //System.out.println(\"termino el definir: \" + this.getPersona());\n }",
"private void defineBotonBuscar() {\r\n tf_buscar.setVisible(false); //establece el textField como oculto al iniciarse la Pantalla\r\n //Manejador del Evento\r\n \r\n EventHandler eh = new EventHandler<KeyEvent>(){\r\n @Override\r\n public void handle(KeyEvent ke){\r\n //SI es presionado ENTER o TAB entonces\r\n if (ke.getCode().equals(KeyCode.ENTER) || ke.getCode().equals(KeyCode.TAB)){ \r\n //Valida que el evento se haya generado en el campo de busqueda\r\n if(((Node)ke.getSource()).getId().equals(\"tf_buscar\")){ \r\n //Solicita los datos y envia la Respuesta a imprimirse en la Pantalla\r\n Datos.setLog_cguias(new log_CGuias()); \r\n boolean boo = Ln.getInstance().check_log_CGuias_caja(tf_buscar.getText()); \r\n numGuias = 0;\r\n if(boo){\r\n Datos.setRep_log_cguias(Ln.getInstance().find_log_CGuias(tf_buscar.getText(), \"\", \"ncaja\", Integer.parseInt(rows)));\r\n loadTable(Datos.getRep_log_cguias()); \r\n }\r\n else{\r\n change_im_val(0, im_checkg); \r\n Gui.getInstance().showMessage(\"El Nro. Guia NO existe en la \" + ScreenName, \"A\");\r\n tf_nroguia.requestFocus();\r\n }\r\n tf_buscar.setVisible(false); //establece el textField como oculto al finalizar\r\n }\r\n }\r\n }\r\n };\r\n //Se asigna el manejador a ejecutarse cuando se suelta una tecla\r\n tf_buscar.setOnKeyReleased(eh);\r\n }",
"abstract void botonAyuda_actionPerformed(ActionEvent e);",
"public void TopDreiEvent();",
"@Override\n\tpublic void botonInicio(VideoJuego juego) {\n\t\t\n\t}",
"@Override\n\tpublic void mouseClicked(MouseEvent e) {\n\t\tSystem.out.println(\"Botón pulsado\");\n\t\tObject o = e.getSource();\n\t\tif((JButton) o instanceof JButton) {\n\t\t\tJButton a = (JButton) o;\n\t\t\tif(a.equals(panel.getEnviarMensaje())) {\n\t\t\t\tint rec = 2 ; //En principio\n\t\t\t\tif(this.receptor instanceof ONG) {\n\t\t\t\t\tSystem.out.println(\"Es una ONG\");\n\t\t\t\t}else if(this.receptor instanceof Usuario ) {\n\t\t\t\t\tSystem.out.println(\"Es un participante\");\n\t\t\t\t}else {\n\t\t\t\t\tSystem.out.println(\"Es un gestor\");\n\t\t\t\t}\n\t\t\t\tSystem.out.println(\"Mensaje aún no enviado\");\n\t\t\t\tMensaje.enviarMensaje(emisor.getEmail(), receptor.getEmail(), panel.getMensaje().getText(), rec);\n\t\t\t\tSystem.out.println(\"Mensaje enviado\");\n\t\t\t\t\n\t\t\t\tpanel.dispose();\n\t\t\t\tJFrame t =new Toast(\"Mensaje enviado correctamente\", true);\n\t\t\t\tt.setVisible(true);\n\t\t\t}\n\t\t}\n\t}",
"public void actionPerformed(ActionEvent evento){//este es el unico metodo que hay que implementer de la interfaz actionlistener\n\t\t\t//lo siguiente es el evento que se desencadena cada ves que se cumpla e tiempo del temporizador\n\t\t\tDate hora=new Date();//se crea un objeto de tipo date\n\t\t\t\n\t\t\tSystem.out.println(\"la hora del sistema es: \" + hora);\n\t\t\t\n\t\t\tif(sonido){//se evalua el valor de la variable booleana, no es necesario realizar comparacion en las variables booleanas\n\t\t\t\t\n\t\t\t\tToolkit.getDefaultToolkit().beep(); //esta metodo ejecuta un bip\n\t\t\t}\n\t\t}",
"abstract void botonDemo_actionPerformed(ActionEvent e);",
"@Override\n\t\t\t\t\tpublic void onEvent(Event event) throws Exception {\n\t\t\t\t\t\tMessagebox.Button button = (Messagebox.Button) event.getData();\n\t\t\t\t\t\tif (button == Messagebox.Button.YES) {\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tanalista.setiEstatus(EstatusPersonaFactory.getEstatusInactivo());\n\t\t//\t\t\t\tEL METODO DICE ACTUTALIZARPERSONA\n\t\t\t\t\t\tsMaestros.acutalizarPersona(analista);\n\t\t\t\t\t\tcambiarAnalistas(0, null, null);\n\t\t\t\t\t\tnotifyChange(\"analistas\");\n\t\t\t\t\t\t\n//\t\t\t\t\t\t\t\t\t\tif (sTransaccion.validarAnalistaEnRequerimientos(analista)){\n//\t\t\t\t\t\t\t\t\t\t\tanalista.setiEstatus(EstatusPersonaFactory.getEstatusInactivo());\n//\t\t\t\t\t\t\t\t\t\t\t//EL METODO DICE ACTUTALIZARPERSONA\n//\t\t\t\t\t\t\t\t\t\t\tsMaestros.acutalizarPersona(analista);\n//\t\t\t\t\t\t\t\t\t\t\tcambiarAnalistas(0, null, null);\n//\t\t\t\t\t\t\t\t\t\t\tnotifyChange(\"analistas\");\n//\t\t\t\t\t\t\t\t\t\t}\n//\t\t\t\t\t\t\t\t\t\telse\n//\t\t\t\t\t\t\t\t\t\t\tmostrarMensaje(\"Informacion\", \"No se Puede eliminar el analista, esta asignado a un requerimiento que esta activo\", Messagebox.EXCLAMATION, null, null, null);\n//\t\t\t\t\t\t\t\t\t\t}\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t}\n\t\t\t\t\t}",
"private void enableBotonAceptar()\r\n\t{\r\n\t\t\r\n\t}",
"abstract void boton1Jugador_actionPerformed(ActionEvent e);",
"abstract void botonDescargaSobre_actionPerformed(ActionEvent e);",
"@Override\r\n\tpublic void novo(ActionEvent actionEvent) {\n\t\t\r\n\t}",
"public void mniBuscarPrestamoActionPerformed(ActionEvent e) {\n }",
"public void definirActionBotonEmail(ActionEvent e) {\n CommandButton btnSelect = (CommandButton) e.getSource();\n\n //System.out.println(\"boton id: \" + btnSelect.getId());\n //this.getCbAction().setDisabled(false);\n if (btnSelect.getId().equals(\"btnEdit\")) {\n this.getCbActionEmail().setValue(\"Editar\");\n this.getListadoEmailBean().setiTipoBoton(1);\n }\n if (btnSelect.getId().equals(\"btnDelete\")) {\n this.getCbActionEmail().setValue(\"Eliminar\");\n this.getListadoEmailBean().setiTipoBoton(2);\n }\n\n if (btnSelect.getId().equals(\"btnCreateTelefonos\")) {\n //System.out.println(\"Entro al if : \" + this.getPersona());\n // this.getCbAction().setValue(\"Guardar\");\n\n this.getListadoEmailBean().setiTipoBoton(0);\n\n }//fin if\n\n //System.out.println(\"termino el definir: \" + this.getPersona());\n }",
"@Override\n\t\t\tpublic void actionPerformed(ActionEvent event) {\n\t\t\t\tgetControleur(). saisirOuvrage() ;}",
"public MyButton getBoton() {\n\t\treturn boton;\n\t}",
"Event () {\n // Nothing to do here.\n }",
"public JButton getBoton() {\n return boton;\n }",
"private void configurarEventos() {\n\n btnVoltar.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n //OBJETIVO: fecha a tela atual\n VerPessoaActivity.this.finish();\n }\n });\n }",
"private void botonFuncional(JButton Boton){\n \n if(!caraUp){\n Boton.setEnabled(false);\n imagen1 =(ImageIcon) Boton.getDisabledIcon();\n v[0] = Boton;\n caraUp = true;\n cara1 = false;\n }\n else {\n Boton.setEnabled(false); \n imagen2 =(ImageIcon) Boton.getDisabledIcon();\n v[1]= Boton;\n cara1 = true;\n ganar();\n }\n }",
"@Override\n\tpublic void handleEvent(Event event) {\n\t\t\n\t\tSystem.out.println(\"NOMBRE EVENTO RECIBIDO : \" + event.getProperty(\"TITLE\"));\n\t\tSystem.out.println(\"RECIBIDO EVENTO \"+event.getTopic() + \"en tiempo = \" + event.getProperty(\"TIME\")+\"\");\n\t\tSystem.out.println(\"PROPERTIES LUZ = \"+ event.getProperty(\"LUZ\") +\"\");\n\t\tString luz = (String) event.getProperty(\"LUZ\");\n\t\tSystem.out.println(\"MI STRING DE LUZ VALOR =\"+ luz);\n\t\t\n\t\tboolean favs_recibidos_emisor_evento = false;\n\t\t\n\t\tif(luz.equals(\"true\")){\n\t\t\tfavs_recibidos_emisor_evento = true;\n\t\t}else if(luz.equals(\"false\")){\n\t\t favs_recibidos_emisor_evento = false;\n\t\t}else{\n\t\t\tSystem.out.println(\"VALOR RARO EN LUZ PROPERTIES ¿?¿???¿??¿?¿?¿?\");\n\t\t}\n\t\t\n\t//favs_recibidos_emisor_evento = (boolean) event.getProperty(\"LUZ\");\n\n\t\tif(favs_recibidos_emisor_evento == true){\n\t\t\tSystem.out.println(\"Se recibio el evento con LUZ = TRUE\");\n\t\t\t\n\t\t\t//LED ,, LED.ENCENDER\n\t\t\tLeds tuiter_on = new Leds();\n\t\t\t//azul 59 131 189\n\t\t\ttuiter_on.setColorPlug(59,'r');\n\t\t\ttuiter_on.setColorPlug(131,'g');\n\t\t\ttuiter_on.setColorPlug(189.0,'b');\n\t\t\tdouble rold,gold,bold;\n\t\t\trold = tuiter_on.getColorPLug('r');\n\t\t\tgold = tuiter_on.getColorPLug('g');\n\t\t\tbold = tuiter_on.getColorPLug('b');\n\t\t\tSystem.out.println(\"ENCIENDO LED TUITER ------> AZUL \");\n\t\t\ttuiter_on.EncenderRGB2(0, 59, 131, 189, tuiter_on.getIntensidad());\n\t\t\ttry {\n\t\t\t\tThread.currentThread().sleep(2500);\n\t\t\t} catch (InterruptedException e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t\ttuiter_on.EncenderRGB2(0, rold, gold, bold, tuiter_on.getIntensidad());\n\n\n\n\t\t}else if(favs_recibidos_emisor_evento == false){\n\t\t\tSystem.out.println(\" SE HA RECIBIDO EL EVENTO CON LUZ = FALSE , NO CAMBIOS\");\n\t\t}else{\n\t\t\tSystem.out.println(\" SE HA RECIBIDO EL EVENTO CON LUZ = ¿?¿?¿? --> EXCEPCION \");\n\t\t}\n\t\t\n\t}",
"abstract void botonJuegoRed_actionPerformed(ActionEvent e);",
"abstract void botonReglas_actionPerformed(ActionEvent e);",
"public void consulterEvent() {\n\t\t\n\t}",
"Message buidMessage(CommandEvent event);",
"public BotonMoneda(VentanaCobrar ventanaCobrar,int valor) {\n this.ventanaCobrar = ventanaCobrar;\n this.valor = valor;\n this.boton = new JButton(String.format(\"%.2f\",(double) valor/100)+\"€\");\n this.boton.addActionListener(e-> this.ventanaCobrar.anyade(valor));\n disenyaBoton();\n }",
"@Override\n public void mousePressed(MouseEvent e){\n String boton = W.detClick( e.getButton() );\n \n //System.out.println(\"->Mouse: Presionando Click \" + boton );\n }",
"@Override\r\n\tpublic void mouseReleased(MouseEvent e) {\n\t\t\r\n\r\n\t\tBotaoJogo botao = (BotaoJogo) e.getSource();\r\n\r\n\t\tif (SwingUtilities.isRightMouseButton(e)) {//SE FOR O BOTAO DIREITO DO MOUSE\r\n\r\n\t\t\tif (celulaEscolhida(botao).isBandeira() == false) {//SE NAO FOR UMA BANDEIRA\r\n\t\t\t\tif (this.numeroBombas > 0) {//CHECA SE PODE COLOCAR BANDEIRA\r\n\t\t\t\t\tcelulaEscolhida(botao).setBandeira(true);//COLOCA BANDEIRA E IMPEDE DE ESCOLHER O BOTAO E SUBTRAI DO NUMEROBOMBAS\r\n\t\t\t\t\tbotao.setEnabled(false);\r\n\t\t\t\t\tthis.numeroBombas--;\r\n\t\t\t\t}\r\n\r\n\t\t\t} else {//O CONTRARIO DO DE CIMA\r\n\t\t\t\tcelulaEscolhida(botao).setBandeira(false);\r\n\t\t\t\tbotao.setEnabled(true);\r\n\t\t\t\tthis.numeroBombas++;\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\tthis.atualizarNumeroBombas();//ATUALIZA O LABEL QUE TEM O CONTADOR DE BOMBAS\r\n\t\t\t\r\n\t\t}\r\n\t}",
"@Override\r\n public void actionPerformed(ActionEvent nomeDoEvento) {\n }",
"@Override\n public void onBoomButtonClick(int index) {\n }",
"public ObservadorMenu(Boton b) {\n boton = b;//inicializa el boton\n boton.setObservador(this); //le añadimos al boton el observador\n }",
"@Override\n\t\t\tpublic void buttonClick(ClickEvent event) {\n\t\t\t\t\n\t\t\t\t\n\t\t\t\t\n\t\t\t\tConfirmDialog.show(UI.getCurrent(), MESSAGE_1,\"\",\"Aceptar\",\"Crear mas Usuarios\",\n\t\t\t\t new ConfirmDialog.Listener() {\n\n\t\t\t\t public void onClose(ConfirmDialog dialog) {\t\n\t\t\t\t \tent= false;\n\t\t\t\t if (dialog.isConfirmed()) {\n\t\t\t\t // Confirmed to continue\t\n\t\t\t\t \tc.navegar((StartView.VIEW_NAME));\n\t\t\t\t } else {\n\t\t\t\t // User did not confirm\t\t\t \n\t\t\t\t \t//c.crearWindow(RegistrarUser.VIEW_NAME);\n\t\t\t\t \tc.navegar((StartView.VIEW_NAME));\n\t\t\t\t \n\t\t\t\t }\n\t\t\t\t \n\t\t\t\t }\n\t\t\t\t \n\t\t\t\t });\n\t\t\t\t\n\t\t\t\t//Notification nota= new Notification(\"Registro Exitoso!\",Notification.Type.HUMANIZED_MESSAGE);\n\t\t\t\t//nota.setDelayMsec(-1);\n\t\t\t\t//nota.show(Page.getCurrent());\t\n\t\t\t\t\n\t\t\t\tclose();\t\t\t\n\t\t\t}",
"@Override\n public void pulsarRaton(MouseEvent e) {\n pararCancion();\n //CAMBIAMOS LA PANTALLA\n PantallaNivel1 pantallaJuego = new PantallaNivel1(p);\n pantallaJuego.inicializarPantalla();\n p.cambiarPantalla(pantallaJuego);\n \n }",
"protected void CriarEventos() {\r\n\r\n\r\n //CRIANDO EVENTO NO BOTÃO SALVAR\r\n buttonSalvar.setOnClickListener(new View.OnClickListener() {\r\n\r\n @Override\r\n public void onClick(View v) {\r\n\r\n Salvar_onClick();\r\n }\r\n });\r\n\r\n //CRIANDO EVENTO NO BOTÃO VOLTAR\r\n buttonVoltar.setOnClickListener(new View.OnClickListener() {\r\n\r\n @Override\r\n public void onClick(View v) {\r\n\r\n Intent intentMainActivity = new Intent(getApplicationContext(), CadastrarActivity.class);\r\n startActivity(intentMainActivity);\r\n finish();\r\n }\r\n });\r\n }",
"public void emitirSaludo()\n {\n // borrarPantalla();\n System.out.println(mensaje);\n }",
"@Override\n\t\t\tpublic void onEvent(ObjectEvent event) {\n\t\t\t\t\n\t\t\t\tRankTempInfo rankInfo = RankServerManager.getInstance().getRankTempInfo(player.getPlayerId());\n\t\t\t\tif(rankInfo!=null){\n\t\t\t\t\tgetTask().updateProcess((int)rankInfo.getSoul());\n\t\t\t\t}\n\t\t\n\t\t\t\t\n\t\t\t}",
"public void crear_un_evento_recurrente_para_el_dia_de_hoy() {\n\t\t\n\t}",
"private void createEvents() {\n\t\tbtnRetour.addActionListener(new ActionListener() {\r\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\r\n\t\t\t\tdispose();\r\n\t\t\t\tDashboard_Preteur dashboard_Preteur = new Dashboard_Preteur(currentPreteur);\r\n\t\t\t\tdashboard_Preteur.setVisible(true);\r\n\t\t\t\tdashboard_Preteur.setResizable(false);\r\n\t\t\t}\r\n\t\t});\r\n\t}",
"public void ajouHandler(ActionEvent event) throws Exception\n\t{\n\t\tString id= new String();\n\t\tfor (Button bouton : list_bouton)\n\t\t{\n\t\t\tif(event.getSource()==bouton)\n\t\t\t{\n\t\t bouton.setOnAction(new EventHandler<ActionEvent>() {\n @Override\n\t\t public void handle(ActionEvent arg0) {\n\t\t\t\t try {\n\t\t\t\t\t \n\t\t\t\t aj = new Ajouter();\n\t\t\t\t \n\t\t\t\t ((Node) event.getSource()).getScene().getWindow().hide(); \n\t\t\t\t} catch (Exception e) {e.printStackTrace();} \n\t\t\t\t\t}});\n\t\t ChoixControler.selectedDomaine=bouton.getId();\n\t\t }\n\t\t }\n\t }",
"public LecturaPorEvento() \r\n {\r\n }",
"@Override\r\n\tpublic void onEvent(Object e) {\n\t}",
"public void eventos() {\n btnAbrir.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent evt) {\n btnAbrirActionPerformed(evt);\n }\n });\n }",
"@Override\n public void onClick(View view) {\n IdEvento = obtenerEmegencia().get(recyclerViewEmergencia.getChildAdapterPosition(view)).getId();\n\n //Se muestra un mensaje en pantalla de lo que seleciono\n Next();\n }",
"@Override\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tMain.buscarAFondo();\n\t\t\t}",
"@Override\r\n\tpublic void onAyuda() {\n\t\t\r\n\t}",
"public void setNombreEvento(String nombreEvento) {\n this.nombreEvento = nombreEvento;\n }",
"public void onDocumentoSubidoEventListener(DocumentoSubidoEvent event){}",
"public void actionPerformed(ActionEvent e) {\n\t\t\t\t\t ctrl.setJogadores(2);\r\n\t\t\t\t\t t.criaPinos();\r\n\t\t\t\t\t m.atualizaBotoess(ctrl,t,men);\r\n\t\t\t\t }",
"public void notifyJoueurActif();",
"@Override\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tgetControleur(). ConsultOuvrage() ;}",
"@Override\n\t\t\tpublic void handle(ActionEvent event) {\n\t\t\t\t\n\t\t\t}",
"@Override\n\t\t\tpublic void handle(ActionEvent event) {\n\t\t\t\t\n\t\t\t}",
"protected void actionPerformedBtnProcesarVenta(ActionEvent e) {\n\t}",
"@Override\n public void actionPerformed(ActionEvent e) {\n fenetre.getClient().envoyerMessage(getMessage(), optionEnvoi); // Envoie du message\n saisieMessage.setText(\"\"); // On supprime le texte de la saisie message\n }",
"@FXML\n private void handleBtnNovoAction (ActionEvent event) { \n \n //passa um ModelCliente vazio para limpar os campos\n setModelProdutosBinds( new ModelClientes() );\n \n //Retira o bind do modelProdutos com esse ModelProduto vazio\n setModelProdutosBinds(null);\n \n //Comfiguração dos componentes da tela\n edtNome.requestFocus();\n \n //No próximo click o botao executa a ação \"Cancelar\"\n btnNovo.setOnAction((e) -> { handleBtnCancelarAction(e); });\n }",
"@Override\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tgetControleur(). saisirParution() ;}",
"@Override\n public void actionPerformed(ActionEvent e) {\n client.sendMessage(new BuzzInMessage(teamIndex));\n }",
"@Override\n public void eventoCargarData() {\n }",
"@FXML\n private void boton_nuevoPuesto(ActionEvent event) throws IOException {\n FXMLLoader fxmlLoader = new FXMLLoader(getClass().getClassLoader().getResource(\"Views/Puestos/puestos_nuevo.fxml\"));\n Parent root = fxmlLoader.load(); \n Puestos_nuevoController puestosNuevo = fxmlLoader.getController();\n\n \n puestosNuevo.setIdArea(idArea);\n puestosNuevo.setNombreArea(nombreArea);\n \n Scene scene = new Scene(root);\n Stage stage = (Stage) ((Node) event.getSource()).getScene().getWindow();\n stage.setScene(scene);\n stage.show();\n }",
"public void controlloEventiGestione() {\n\t\t/**\n\t\t * Evento eliminazione Versamento \n\t\t */\n\t\tviewGestione.getBtnElimina().addMouseListener(new MouseAdapter() {\n\t\t\t@Override\n\t\t\tpublic void mouseClicked(MouseEvent e) {\n\t\t\t\tif (JOptionPane.showConfirmDialog(null, \"Eliminare la quota?\") == 0\n\t\t\t\t\t\t&& viewGestione.getTable().getSelectedRow() != -1) {\n\t\t\t\t\tboolean esito = model.deleteQuota(quote.get(viewGestione.getTable().getSelectedRow()).getId());\n\t\t\t\t\tquote.remove(viewGestione.getTable().getSelectedRow());\n\t\t\t\t\tif (esito) {\n\t\t\t\t\t\tJOptionPane.showMessageDialog(viewGestione.getFrameGestQuote().getContentPane(),\n\t\t\t\t\t\t\t\t\"Versamento eliminato\");\n\t\t\t\t\t\tviewGestione.getFrameGestQuote().dispose();\n\t\t\t\t\t\tmostraGestioneQuote();\n\t\t\t\t\t} else {\n\t\t\t\t\t\tJOptionPane.showMessageDialog(viewGestione.getFrameGestQuote().getContentPane(),\n\t\t\t\t\t\t\t\t\"Versamento non eliminato\");\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\n\t\t/* \n\t\t *Evento ritorno all'AdminView\n\t\t */\n\t\tviewGestione.getBtnDashboard().addMouseListener(new MouseAdapter() {\n\t\t\t@Override\n\t\t\tpublic void mouseClicked(MouseEvent e) {\n\t\t\t\tAdminController adminController = new AdminController();\n\t\t\t\tadminController.controlloEvento();\n\t\t\t\tviewGestione.getFrameGestQuote().dispose();\n\t\t\t}\n\t\t});\n\t}",
"@Override\n\t\t\t\tpublic void handle(ActionEvent event) {\n\t\t\t\t}",
"@Override\r\n\tpublic void keyPressed(KeyEvent e) {\n\t\tactivarBoton();\r\n\t}",
"@Override\n\t\t\t\tpublic void handle(ActionEvent event) {\n\n\t\t\t\t}",
"@Override\n\t\t\tpublic void handle(ActionEvent event) {\n\t\t\t}",
"private void announcementBtnListener() {\n announcementBtn.addListener(new ClickListener(){\n public void clicked(InputEvent event, float x, float y){\n ChessGame.client.ingame = false;\n game.setScreen(new AnnouncementsScreen(game));\n }\n });\n }",
"@Override\n\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t//Lo pongo a la escucha, y cuando llamo al constructor, quiero que me\n\t\t\t//cree un marco, creado previamente creada la CLASE\n\t\t\tMarco_Emergente marco= new Marco_Emergente(boton_cerrar);\n\t\t\tmarco.setVisible(true);\n\t\t}",
"@Override\n public void mouseClicked(MouseEvent e) {\n System.out.println(\"Evento click ratón\");\n }",
"public void setTipoDeBoton(int iTipoDeBoton) {\r\n this.iTipoDeBoton = iTipoDeBoton;\r\n }",
"@Override\r\n\tprotected void onGuiEvent(GuiEvent arg0) {\n\t\taddBehaviour(new SendMessage());\r\n\r\n\t}",
"@Override\n\tprotected void onEventComming(EventCenter eventCenter) {\n\t}",
"@FXML private void manejadorBotonAceptar() {\n\t\tif (this.validarDatos()) {\n\t\t\tif (this.opcion == CREAR) {\n\t\t\t\tthis.usuario.setUsuario(this.campoTextoNombreUsuario.getText());\n\t\t\t\tthis.usuario.setContrasena(this.campoContrasena.getText());\n\t\t\t\tthis.usuario.setCorreoElectronico(this.campoCorreo.getText());\n\t\t\t\tif (comboStatus.getSelectionModel().getSelectedItem() == \"Bloqueado\")\n\t\t\t\t\tthis.usuario.setStatus(0);\n\t\t\t\tif (comboStatus.getSelectionModel().getSelectedItem() == \"Activo\")\n\t\t\t\t\tthis.usuario.setStatus(1);\n\t\t\t\tif (comboStatus.getSelectionModel().getSelectedItem() == \"Baja\")\n\t\t\t\t\tthis.usuario.setStatus(2);\n\t\t\t\tthis.usuario.setGrupoUsuarioFk(listaGrupoUsuario.get(comboGrupoUsuario.getSelectionModel().getSelectedIndex()).getSysPk());\n\t\t\t\tthis.usuario.setEmpleadoFK(EmpleadoDAO.readEmpleadoPorNombre(this.mainApp.getConnection(), comboEmpleados.getSelectionModel().getSelectedItem()).getSysPK());\n\n\t\t\t\tif (UsuarioDAO.crear(this.mainApp.getConnection(), this.usuario)) {\n\t\t\t\t\tmanejadorBotonCerrar();\n\t\t\t\t\tNotificacion.dialogoAlerta(AlertType.INFORMATION, \"\", \"El registro se creo correctamente\");\n\t\t\t\t} else {\n\t\t\t\t\tNotificacion.dialogoAlerta(AlertType.INFORMATION, \"\", \"No se pudo crear el registro\");\n\t\t\t\t}//FIN IF-ELSE\n\t\t\t} else if (this.opcion == EDITAR) {\n\t\t\t\tthis.usuario.setUsuario(this.campoTextoNombreUsuario.getText());\n\t\t\t\tthis.usuario.setContrasena(this.campoContrasena.getText());\n\t\t\t\tthis.usuario.setCorreoElectronico(this.campoCorreo.getText());\n\t\t\t\tif (comboStatus.getSelectionModel().getSelectedItem() == \"Bloqueado\")\n\t\t\t\t\tthis.usuario.setStatus(0);\n\t\t\t\tif (comboStatus.getSelectionModel().getSelectedItem() == \"Activo\")\n\t\t\t\t\tthis.usuario.setStatus(1);\n\t\t\t\tif (comboStatus.getSelectionModel().getSelectedItem() == \"Baja\")\n\t\t\t\t\tthis.usuario.setStatus(2);\n\t\t\t\tthis.usuario.setGrupoUsuarioFk(listaGrupoUsuario.get(comboGrupoUsuario.getSelectionModel().getSelectedIndex()).getSysPk());\n\t\t\t\tthis.usuario.setEmpleadoFK(EmpleadoDAO.readEmpleadoPorNombre(this.mainApp.getConnection(), comboEmpleados.getSelectionModel().getSelectedItem()).getSysPK());\n\n\t\t\t\tif (UsuarioDAO.update(this.mainApp.getConnection(), this.usuario)) {\n\t\t\t\t\tmanejadorBotonCerrar();\n\t\t\t\t\tNotificacion.dialogoAlerta(AlertType.INFORMATION, \"\", \"El registro se modifico correctamente\");\n\t\t\t\t} else {\n\t\t\t\t\tNotificacion.dialogoAlerta(AlertType.INFORMATION, \"\", \"No se pudo modificar el registro, revisa la información sea correcta\");\n\t\t\t\t}//FIN IF-ELSE\n\t\t\t} else if (this.opcion == VER) {\n\t\t\t\tmanejadorBotonCerrar();\n\t\t\t}//FIN IF ELSE\n\t\t}//FIN METODO\n\t}",
"public void actionPerformed(ActionEvent e) {\n\t\tCalendar fecha = new GregorianCalendar();\n\t\tint hora = fecha.get(Calendar.HOUR_OF_DAY);\n\t\tint minutos = fecha.get(Calendar.MINUTE);\n\t\tString salida = \"\";\n\t\tif(hora<12){\n\t\t\tsalida = \"Buenos Dias \";\n\t\t}else if(hora<20){\n\t\t\tsalida = \"Buenas Tardes \";\n\t\t}else{\n\t\t\tsalida = \"Buenas Noches \";\n\t\t}\n\t\ttfmensaje.setText(salida+\"la hora es: \"+hora+\" \"+minutos);\n\t}",
"public void MostrarNotificacion(Boolean estado, int cancelar){\n //hora del evento\n long hora = System.currentTimeMillis();\n\n NotificationCompat.Builder builder = new NotificationCompat.Builder(getApplicationContext(), CHANNEL_ID);\n builder.setSmallIcon(R.drawable.ic_launcher_background);\n builder.setContentTitle(\"Titulo\");\n builder.setContentText(\"Cuerpo\");\n builder.setWhen(hora);\n builder.setPriority(NotificationCompat.PRIORITY_DEFAULT);\n\n //para poner la notificacion permanente\n builder.setOngoing(estado);\n\n //construir la notificacion\n NotificationManagerCompat notificationManagerCompat = NotificationManagerCompat.from(getApplicationContext());\n notificationManagerCompat.notify(NOTIFICACION_ID, builder.build());\n\n //para quitar la notificacion\n notificationManagerCompat.cancel(cancelar);\n\n\n\n }",
"@Override\n\tpublic void handleEvent(EnOceanMessage data) {\n\t}",
"private void btnbuscardni_actionPerformed(ActionEvent e) {\n String pDNI = txtdni.getText();\n if(pDNI.trim().length()>0){\n if(UtilityFotos.cargaDatosDNI(pDNI)){\n txtdatos.append(\"DNI:\"+pDNI+\"\\n\");\n txtdatos.append(\"Nombre :\"+VariablesFotos.pVal_Nombre+\"\\n\");\n txtdatos.append(\"Ape.Paterno :\"+VariablesFotos.pVal_ApePat+\"\\n\");\n txtdatos.append(\"Ape.Materno :\"+VariablesFotos.pVal_ApeMat+\"\\n\");\n btnbuscardni.setEnabled(false);\n btnadelante.setEnabled(true);\n btnatras.setEnabled(true);\n btnLimpiar_Vizor.setEnabled(true);\n cargaImagenesDNI(pDNI);\n FarmaUtility.showMessage(this,\"Se cargaron las imagenes que se tienen del DNI Ingresado.\", txtdni);\n }\n else\n FarmaUtility.showMessage(this,\"No se pudo cargar los datos del cliente.\\n\" +\n \"Puede no existir en el sistema como atención\", txtDNI_SUBIR);\n }\n else{\n FarmaUtility.showMessage(this,\"Debe de ingresar el DNI \", txtDNI_SUBIR);\n }\n \n }",
"@Override\r\n\tpublic void onEvent(Event arg0) {\n\r\n\t}",
"public void eventos()\n\t{\n\t\tvuelos.addActionListener(new ActionListener()\n\t\t{\n\n\t\t\t@Override\n\t\t\tpublic void actionPerformed(ActionEvent arg0)\n\t\t\t{\n\t\t\t\tVuelo v = (Vuelo) vuelos.getSelectedItem();\n\t\t\t\tif(v!=null)\n\t\t\t\t{\n\t\t\t\t\tllenarPasabordos(v.getId());\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\n\t}",
"public void crearManoObra(ActionEvent actionEvent) {\r\n manoobraDao manobraDao = new manoobraDaoImpl();\r\n String msg;\r\n this.manoobra.setNombreManob(this.manoobra.getNombreManob());\r\n this.manoobra.setCostojrhManob(this.manoobra.getCostojrhManob());\r\n \r\n if (manobraDao.crearManoObra(this.manoobra)) {\r\n msg = \"Mano de Obra creada correctamente\";\r\n FacesMessage message1 = new FacesMessage(FacesMessage.SEVERITY_INFO,msg , null);\r\n FacesContext.getCurrentInstance().addMessage(null, message1);\r\n } else {\r\n msg = \"No se creo la Mano de Obra\";\r\n FacesMessage message2 = new FacesMessage(FacesMessage.SEVERITY_ERROR, msg, null);\r\n FacesContext.getCurrentInstance().addMessage(null, message2);\r\n }\r\n \r\n }",
"@Override\n\tvoid postarComentario() {\n\n\t}",
"@Override\n public void mouseClicked(MouseEvent e){\n String boton = W.detClick( e.getButton() );\n \n System.out.println(\" Mouse: Click \" + boton ); \n }",
"public Punto_venta() {\n initComponents();\n }",
"@Override\n public void actionPerformed(ActionEvent e) {\n if(e.getActionCommand() == \"Iniciar sesión\" ){\n this.mostrarDatosUsuario();\n this.entrar();\n }\n if(e.getActionCommand() == \"Registrate\" ){\n JOptionPane.showMessageDialog(null, \"Oprimió botón registrarse\" , \"Advertencia\", 1);\n }\n if(e.getActionCommand() == \"¿Olvidaste tu contraseña?\" ){\n JOptionPane.showMessageDialog(null, \"Oprimió botón recuperar contraseña\" , \"Advertencia\", 1);\n }\n if(e.getSource() == logintemplate.getBVerContraseña()){\n JOptionPane.showMessageDialog(null, \"Oprimido botón ver contraseña\" , \"Advertencia\", 1);\n }\n if(e.getSource() == logintemplate.getBVerMas()){\n JOptionPane.showMessageDialog(null, \"Oprimido botón ver mas\" , \"Advertencia\", 1);\n }\n }",
"@Override\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tgetControleur(). saisirPeriodique() ;}",
"@FXML\n\tpublic void buscarProcessoAberto(ActionEvent event) {\n\t\t// TODO Autogenerated\n\t}",
"public DetalleEvento(String titulo, int duracion, int borrado, int evento, int bloequeo) {\n this.titulo = titulo;\n this.duracion = duracion;\n this.borrado = borrado;\n this.evento = evento;\n this.bloequeo = bloequeo;\n }",
"public void modifHandler(ActionEvent event) throws Exception\n\t{\n\t\t\n\t\t String id= new String();\n\t\t\tfor (Button bouton : list_bouton)\n\t\t\t{\n\t\t\t\tif(event.getSource()==bouton)\n\t\t\t\t{\n\t\t\t bouton.setOnAction(new EventHandler<ActionEvent>() {\n\t private String args;\n\n\t\t\t\t@Override\n\t\t\t public void handle(ActionEvent arg0) {\n\t\t\t\t\t try {\n\t\t\t\t\t\t//choisir l'activité à modifier\n\t\t\t\t\t mod= new ChoixActiviteModif();\n\t\t\t\t\t} catch (Exception e) {e.printStackTrace();} \n\t\t\t\t\t\t}});\n\t\t\t ChoixControler.selectedDomaine=bouton.getId();\n\t\t\t }\n\t\t\t }\n\t\t\n }",
"@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\tString ev = e.getActionCommand();\n\t\tif(ev.equals(\"Buscar Influyentes\")) {\n\t\t\tprincipal.buscarInfluyentes();\n\n\t\t}\n\t\telse if(ev.equals(\"Nivel De Alcance\")){\n\t\t\tprincipal.nivelDeAlcance();\n\t\t}\n\t\t\t\t\n\t\t\n\t}",
"@Override\n public void mouseClicked(MouseEvent evt) {\n if (evt.getButton() == MouseEvent.BUTTON1 && parent.getExtendedState() == JFrame.ICONIFIED) {\n MensajeTrayIcon(\"Modulo Envio ejecutandose en segundo plano\", TrayIcon.MessageType.INFO);\n }\n }",
"@Override\n\t\t\tpublic void mouseClicked(MouseEvent e) {\n\t\t\t\tSystem.out.println(\"vai ficar clikando ai a toa? PATETA\");\n\t\t\t\t\n\t\t\t}",
"@FXML\r\n void handleNuova(ActionEvent event) {\r\n \t\r\n \tmodel.newGame();\r\n \t\r\n \t\r\n \tbtnNuova.setDisable(true);\r\n \tboxGioco.setDisable(false);\r\n \t// txtCurr.setText(\"\"+this.model.getTentativi()); questo non mi serve più perche ho modificato (sotto sotto) che txtCurr è legato al IntegeProperty\r\n \ttxtMax.setText(String.format(\"%d\", this.model.getTMAX()));\r\n \ttxtProva.clear();\r\n \ttxtLog.clear();\r\n \ttxtLog.setText(\"Indovina un numero compreso tra 1 e \"+this.model.getNMAX()+\"\\n\");\r\n \t\r\n }",
"public void actionPerformed(java.awt.event.ActionEvent e) {\n\t\t\t\t\tif (e.getActionCommand().equals(\"Nouvelle Fiche\")) {\r\n\t\t\t\t\t\ttry {\r\n\t\t\t\t\t\t\tHistorique.ecrire(\"Ouverture de : \"+e);\r\n\t\t\t\t\t\t} catch (IOException e1) {\r\n\t\t\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\t\t\te1.printStackTrace();\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t\tnew FEN_Ajout();\r\n\t\t\t\t\t\t}\r\n\t\t\t\t}",
"public void onNo();",
"public void actionPerformed(java.awt.event.ActionEvent e) {\n\t\t\t\t\tif (e.getActionCommand().equals(\"Nouvelle Fiche\")) {\r\n\t\t\t\t\t\ttry {\r\n\t\t\t\t\t\t\tHistorique.ecrire(\"Ouverture de : \"+e);\r\n\t\t\t\t\t\t} catch (IOException e1) {\r\n\t\t\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\t\t\te1.printStackTrace();\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t\tnew FEN_Ajout();\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t}",
"@Override\r\n\tpublic void actionPerformed(ActionEvent e) {\n\t\tif (e.getSource() == jb)// 发送消息\r\n\t\t{\r\n\t\t\tMessage m = new Message();\r\n\t\t\tm.setMesType(\"20\");// MessageType.message_comm_mes\r\n\t\t\tm.setSender(this.ownerId);\r\n\t\t\tm.setGetter(\"\");\r\n\t\t\tm.setCon(jtf.getText());\r\n\t\t\tthis.jta.append(\"我说:\" + jtf.getText() + \"\\r\\n\");\r\n\t\t\ttry {\r\n\t\t\t\tObjectOutputStream oos = new ObjectOutputStream(\r\n\t\t\t\t\t\tManageClientConServerThread\r\n\t\t\t\t\t\t\t\t.getClientConServerThread(ownerId).getS()\r\n\t\t\t\t\t\t\t\t.getOutputStream());\r\n\t\t\t\toos.writeObject(m);\r\n\t\t\t} catch (Exception e1) {\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t}\r\n\r\n\t\t}\r\n\r\n\t}",
"public String getNombreEvento() {\n return nombreEvento;\n }",
"@Override\r\n\tpublic void actionPerformed(ActionEvent e) {\n\r\n\t\tString comando = e.getActionCommand();\r\n\t\tif (comando.equalsIgnoreCase(START)) {\r\n\t\t\tprincipal.getModelo().darVehiculo().setDetenido(false);\r\n\t\t\tprincipal.getModelo().darVehiculo().setPosX(0);\r\n\t\t\tprincipal.moverVehiculo();\r\n\r\n\t\t}\r\n\t\tif (comando.equalsIgnoreCase(STOP)) {\r\n\t\t\tprincipal.getModelo().darVehiculo().setDetenido(true);\r\n\t\t\tSystem.out.println(principal.getModelo().darVehiculo().getPosX());\r\n\t\t\tSystem.out.println(principal.getPanelVia().getDistancia());\r\n\r\n\t\t}\r\n\t\tif (comando.equalsIgnoreCase(DATOS)) {\r\n\t\t\tprincipal.getModelo().generarCertificado();\r\n\t\t\t\r\n\t\t}\r\n\t}"
]
| [
"0.686689",
"0.66840005",
"0.66582257",
"0.6638055",
"0.6615583",
"0.65838283",
"0.65418375",
"0.64480364",
"0.6371924",
"0.63373965",
"0.62931424",
"0.6286831",
"0.6269416",
"0.62341565",
"0.62207156",
"0.62200403",
"0.6191564",
"0.61650914",
"0.6152389",
"0.6146391",
"0.6100986",
"0.60867786",
"0.6077267",
"0.6053213",
"0.60383236",
"0.60327876",
"0.6031254",
"0.60280424",
"0.6021813",
"0.6003075",
"0.59986717",
"0.598943",
"0.59847337",
"0.597411",
"0.59705967",
"0.5966323",
"0.59295857",
"0.59275615",
"0.5890553",
"0.5885994",
"0.5862221",
"0.5861003",
"0.58590525",
"0.5856258",
"0.58551866",
"0.5850427",
"0.58460104",
"0.5838829",
"0.5825346",
"0.582194",
"0.5815468",
"0.5809087",
"0.58065534",
"0.5800783",
"0.5785437",
"0.5784159",
"0.5784159",
"0.57800984",
"0.5776081",
"0.57600933",
"0.57594776",
"0.5758006",
"0.5754582",
"0.57515794",
"0.574902",
"0.57469004",
"0.57419515",
"0.5736987",
"0.5735177",
"0.5732888",
"0.5708804",
"0.57055277",
"0.5705471",
"0.570438",
"0.57009935",
"0.57001823",
"0.5699916",
"0.5697904",
"0.569753",
"0.5690794",
"0.5689084",
"0.5687584",
"0.5687526",
"0.56620854",
"0.5660781",
"0.56540805",
"0.56496495",
"0.56474215",
"0.56444156",
"0.5643214",
"0.5638371",
"0.5630061",
"0.5625988",
"0.56225693",
"0.5621828",
"0.5617613",
"0.56149393",
"0.5611458",
"0.5607707",
"0.5603631",
"0.5602533"
]
| 0.0 | -1 |
This method is called from within the constructor to initialize the form. WARNING: Do NOT modify this code. The content of this method is always regenerated by the Form Editor. | @SuppressWarnings("unchecked")
// <editor-fold defaultstate="collapsed" desc="Generated Code">//GEN-BEGIN:initComponents
private void initComponents() {
spiCentenas = new javax.swing.JSpinner();
spiDecenas = new javax.swing.JSpinner();
spiUnidades = new javax.swing.JSpinner();
btnAbrir = new javax.swing.JButton();
etiResultado = new javax.swing.JLabel();
setDefaultCloseOperation(javax.swing.WindowConstants.EXIT_ON_CLOSE);
spiCentenas.setModel(new javax.swing.SpinnerNumberModel(0, 0, 9, 1));
spiCentenas.setMaximumSize(new java.awt.Dimension(9, 9));
spiDecenas.setModel(new javax.swing.SpinnerNumberModel(0, 0, 9, 1));
spiUnidades.setModel(new javax.swing.SpinnerNumberModel(0, 0, 9, 1));
btnAbrir.setText("Abrir");
etiResultado.setBorder(javax.swing.BorderFactory.createLineBorder(new java.awt.Color(0, 0, 0)));
javax.swing.GroupLayout layout = new javax.swing.GroupLayout(getContentPane());
getContentPane().setLayout(layout);
layout.setHorizontalGroup(
layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)
.addGroup(layout.createSequentialGroup()
.addGap(37, 37, 37)
.addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING, false)
.addComponent(etiResultado, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)
.addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.TRAILING, false)
.addComponent(btnAbrir, javax.swing.GroupLayout.Alignment.LEADING, javax.swing.GroupLayout.DEFAULT_SIZE, javax.swing.GroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)
.addGroup(javax.swing.GroupLayout.Alignment.LEADING, layout.createSequentialGroup()
.addComponent(spiCentenas, javax.swing.GroupLayout.PREFERRED_SIZE, 50, javax.swing.GroupLayout.PREFERRED_SIZE)
.addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)
.addComponent(spiDecenas, javax.swing.GroupLayout.PREFERRED_SIZE, 50, javax.swing.GroupLayout.PREFERRED_SIZE)
.addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)
.addComponent(spiUnidades, javax.swing.GroupLayout.PREFERRED_SIZE, 50, javax.swing.GroupLayout.PREFERRED_SIZE))))
.addContainerGap(50, Short.MAX_VALUE))
);
layout.setVerticalGroup(
layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)
.addGroup(layout.createSequentialGroup()
.addGap(38, 38, 38)
.addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.BASELINE)
.addComponent(spiCentenas, javax.swing.GroupLayout.PREFERRED_SIZE, 35, javax.swing.GroupLayout.PREFERRED_SIZE)
.addComponent(spiDecenas, javax.swing.GroupLayout.PREFERRED_SIZE, 34, javax.swing.GroupLayout.PREFERRED_SIZE)
.addComponent(spiUnidades, javax.swing.GroupLayout.PREFERRED_SIZE, 36, javax.swing.GroupLayout.PREFERRED_SIZE))
.addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.UNRELATED)
.addComponent(btnAbrir)
.addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED)
.addComponent(etiResultado, javax.swing.GroupLayout.PREFERRED_SIZE, 23, javax.swing.GroupLayout.PREFERRED_SIZE)
.addContainerGap(43, Short.MAX_VALUE))
);
pack();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public Form() {\n initComponents();\n }",
"public MainForm() {\n initComponents();\n }",
"public MainForm() {\n initComponents();\n }",
"public MainForm() {\n initComponents();\n }",
"public frmRectangulo() {\n initComponents();\n }",
"public form() {\n initComponents();\n }",
"public AdjointForm() {\n initComponents();\n setDefaultCloseOperation(HIDE_ON_CLOSE);\n }",
"public FormListRemarking() {\n initComponents();\n }",
"public MainForm() {\n initComponents();\n \n }",
"public FormPemilihan() {\n initComponents();\n }",
"public GUIForm() { \n initComponents();\n }",
"public FrameForm() {\n initComponents();\n }",
"public TorneoForm() {\n initComponents();\n }",
"public FormCompra() {\n initComponents();\n }",
"public muveletek() {\n initComponents();\n }",
"public Interfax_D() {\n initComponents();\n }",
"public quanlixe_form() {\n initComponents();\n }",
"public SettingsForm() {\n initComponents();\n }",
"public RegistrationForm() {\n initComponents();\n this.setLocationRelativeTo(null);\n }",
"public Soru1() {\n initComponents();\n }",
"public FMainForm() {\n initComponents();\n this.setResizable(false);\n setLocationRelativeTo(null);\n }",
"public soal2GUI() {\n initComponents();\n }",
"public EindopdrachtGUI() {\n initComponents();\n }",
"public MechanicForm() {\n initComponents();\n }",
"public AddDocumentLineForm(java.awt.Frame parent) {\n super(parent);\n initComponents();\n myInit();\n }",
"public BloodDonationGUI() {\n initComponents();\n }",
"public quotaGUI() {\n initComponents();\n }",
"public PatientUI() {\n initComponents();\n }",
"public Customer_Form() {\n initComponents();\n setSize(890,740);\n \n \n }",
"public Oddeven() {\n initComponents();\n }",
"public myForm() {\n\t\t\tinitComponents();\n\t\t}",
"public Magasin() {\n initComponents();\n }",
"public intrebarea() {\n initComponents();\n }",
"public RadioUI()\n {\n initComponents();\n }",
"public NewCustomerGUI() {\n initComponents();\n }",
"public ZobrazUdalost() {\n initComponents();\n }",
"public FormUtama() {\n initComponents();\n }",
"public p0() {\n initComponents();\n }",
"public INFORMACION() {\n initComponents();\n this.setLocationRelativeTo(null); \n }",
"public ProgramForm() {\n setLookAndFeel();\n initComponents();\n }",
"public AmountReleasedCommentsForm() {\r\n initComponents();\r\n }",
"public form2() {\n initComponents();\n }",
"public MainForm() {\n\t\tsuper(\"Hospital\", List.IMPLICIT);\n\n\t\tstartComponents();\n\t}",
"public kunde() {\n initComponents();\n }",
"public LixeiraForm() {\n initComponents();\n setLocationRelativeTo(null);\n }",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents() {\n\n setName(\"Form\"); // NOI18N\n setRequestFocusEnabled(false);\n setVerifyInputWhenFocusTarget(false);\n\n javax.swing.GroupLayout layout = new javax.swing.GroupLayout(this);\n this.setLayout(layout);\n layout.setHorizontalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGap(0, 465, Short.MAX_VALUE)\n );\n layout.setVerticalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGap(0, 357, Short.MAX_VALUE)\n );\n }",
"public MusteriEkle() {\n initComponents();\n }",
"public frmMain() {\n initComponents();\n }",
"public frmMain() {\n initComponents();\n }",
"public DESHBORDPANAL() {\n initComponents();\n }",
"public frmVenda() {\n initComponents();\n }",
"public GUIForm() {\n initComponents();\n inputField.setText(NO_FILE_SELECTED);\n outputField.setText(NO_FILE_SELECTED);\n progressLabel.setBackground(INFO);\n progressLabel.setText(SELECT_FILE);\n }",
"public Botonera() {\n initComponents();\n }",
"public FrmMenu() {\n initComponents();\n }",
"public OffertoryGUI() {\n initComponents();\n setTypes();\n }",
"public JFFornecedores() {\n initComponents();\n }",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents()\n {\n\n setDefaultCloseOperation(javax.swing.WindowConstants.EXIT_ON_CLOSE);\n setBackground(new java.awt.Color(255, 255, 255));\n\n javax.swing.GroupLayout layout = new javax.swing.GroupLayout(getContentPane());\n getContentPane().setLayout(layout);\n layout.setHorizontalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGap(0, 983, Short.MAX_VALUE)\n );\n layout.setVerticalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGap(0, 769, Short.MAX_VALUE)\n );\n\n pack();\n }",
"public EnterDetailsGUI() {\n initComponents();\n }",
"public vpemesanan1() {\n initComponents();\n }",
"public Kost() {\n initComponents();\n }",
"public FormHorarioSSE() {\n initComponents();\n }",
"public frmacceso() {\n initComponents();\n }",
"public UploadForm() {\n initComponents();\n }",
"public HW3() {\n initComponents();\n }",
"public Managing_Staff_Main_Form() {\n initComponents();\n }",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents()\n {\n\n setDefaultCloseOperation(javax.swing.WindowConstants.EXIT_ON_CLOSE);\n getContentPane().setLayout(null);\n\n pack();\n }",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents() {\n\n setName(\"Form\"); // NOI18N\n\n javax.swing.GroupLayout layout = new javax.swing.GroupLayout(this);\n this.setLayout(layout);\n layout.setHorizontalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGap(0, 400, Short.MAX_VALUE)\n );\n layout.setVerticalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGap(0, 300, Short.MAX_VALUE)\n );\n }",
"public sinavlar2() {\n initComponents();\n }",
"public P0405() {\n initComponents();\n }",
"public IssueBookForm() {\n initComponents();\n }",
"public MiFrame2() {\n initComponents();\n }",
"public Choose1() {\n initComponents();\n }",
"public MainForm() {\n initComponents();\n\n String oldAuthor = prefs.get(\"AUTHOR\", \"\");\n if(oldAuthor != null) {\n this.authorTextField.setText(oldAuthor);\n }\n String oldBook = prefs.get(\"BOOK\", \"\");\n if(oldBook != null) {\n this.bookTextField.setText(oldBook);\n }\n String oldDisc = prefs.get(\"DISC\", \"\");\n if(oldDisc != null) {\n try {\n int oldDiscNum = Integer.parseInt(oldDisc);\n oldDiscNum++;\n this.discNumberTextField.setText(Integer.toString(oldDiscNum));\n } catch (Exception ex) {\n this.discNumberTextField.setText(oldDisc);\n }\n this.bookTextField.setText(oldBook);\n }\n\n\n }",
"public GUI_StudentInfo() {\n initComponents();\n }",
"public Lihat_Dokter_Keseluruhan() {\n initComponents();\n }",
"public JFrmPrincipal() {\n initComponents();\n }",
"public bt526() {\n initComponents();\n }",
"public Pemilihan_Dokter() {\n initComponents();\n }",
"public Ablak() {\n initComponents();\n }",
"@Override\n\tprotected void initUi() {\n\t\t\n\t}",
"@SuppressWarnings(\"unchecked\")\n\t// <editor-fold defaultstate=\"collapsed\" desc=\"Generated\n\t// Code\">//GEN-BEGIN:initComponents\n\tprivate void initComponents() {\n\n\t\tlabel1 = new java.awt.Label();\n\t\tlabel2 = new java.awt.Label();\n\t\tlabel3 = new java.awt.Label();\n\t\tlabel4 = new java.awt.Label();\n\t\tlabel5 = new java.awt.Label();\n\t\tlabel6 = new java.awt.Label();\n\t\tlabel7 = new java.awt.Label();\n\t\tlabel8 = new java.awt.Label();\n\t\tlabel9 = new java.awt.Label();\n\t\tlabel10 = new java.awt.Label();\n\t\ttextField1 = new java.awt.TextField();\n\t\ttextField2 = new java.awt.TextField();\n\t\tlabel14 = new java.awt.Label();\n\t\tlabel15 = new java.awt.Label();\n\t\tlabel16 = new java.awt.Label();\n\t\ttextField3 = new java.awt.TextField();\n\t\ttextField4 = new java.awt.TextField();\n\t\ttextField5 = new java.awt.TextField();\n\t\tlabel17 = new java.awt.Label();\n\t\tlabel18 = new java.awt.Label();\n\t\tlabel19 = new java.awt.Label();\n\t\tlabel20 = new java.awt.Label();\n\t\tlabel21 = new java.awt.Label();\n\t\tlabel22 = new java.awt.Label();\n\t\ttextField6 = new java.awt.TextField();\n\t\ttextField7 = new java.awt.TextField();\n\t\ttextField8 = new java.awt.TextField();\n\t\tlabel23 = new java.awt.Label();\n\t\ttextField9 = new java.awt.TextField();\n\t\ttextField10 = new java.awt.TextField();\n\t\ttextField11 = new java.awt.TextField();\n\t\ttextField12 = new java.awt.TextField();\n\t\tlabel24 = new java.awt.Label();\n\t\tlabel25 = new java.awt.Label();\n\t\tlabel26 = new java.awt.Label();\n\t\tlabel27 = new java.awt.Label();\n\t\tlabel28 = new java.awt.Label();\n\t\tlabel30 = new java.awt.Label();\n\t\tlabel31 = new java.awt.Label();\n\t\tlabel32 = new java.awt.Label();\n\t\tjButton1 = new javax.swing.JButton();\n\n\t\tlabel1.setFont(new java.awt.Font(\"Segoe UI Semibold\", 0, 18)); // NOI18N\n\t\tlabel1.setText(\"It seems that some of the buttons on the ATM machine are not working!\");\n\n\t\tlabel2.setFont(new java.awt.Font(\"Segoe UI Semibold\", 0, 18)); // NOI18N\n\t\tlabel2.setText(\"Unfortunately these numbers are exactly what Professor has to use to type in his password.\");\n\n\t\tlabel3.setFont(new java.awt.Font(\"Segoe UI Semibold\", 0, 18)); // NOI18N\n\t\tlabel3.setText(\n\t\t\t\t\"If you want to eat tonight, you have to help him out and construct the numbers of the password with the working buttons and math operators.\");\n\n\t\tlabel4.setFont(new java.awt.Font(\"Segoe UI Semibold\", 0, 14)); // NOI18N\n\t\tlabel4.setText(\"Denver's Password: 2792\");\n\n\t\tlabel5.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel5.setText(\"import java.util.Scanner;\\n\");\n\n\t\tlabel6.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel6.setText(\"public class ATM{\");\n\n\t\tlabel7.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel7.setText(\"public static void main(String[] args){\");\n\n\t\tlabel8.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel8.setText(\"System.out.print(\");\n\n\t\tlabel9.setFont(new java.awt.Font(\"Dialog\", 0, 14)); // NOI18N\n\t\tlabel9.setText(\" -\");\n\n\t\tlabel10.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel10.setText(\");\");\n\n\t\ttextField1.addActionListener(new java.awt.event.ActionListener() {\n\t\t\tpublic void actionPerformed(java.awt.event.ActionEvent evt) {\n\t\t\t\ttextField1ActionPerformed(evt);\n\t\t\t}\n\t\t});\n\n\t\tlabel14.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel14.setText(\"System.out.print( (\");\n\n\t\tlabel15.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel15.setText(\"System.out.print(\");\n\n\t\tlabel16.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel16.setText(\"System.out.print( ( (\");\n\n\t\tlabel17.setFont(new java.awt.Font(\"Dialog\", 0, 14)); // NOI18N\n\t\tlabel17.setText(\")\");\n\n\t\tlabel18.setFont(new java.awt.Font(\"Dialog\", 0, 14)); // NOI18N\n\t\tlabel18.setText(\" +\");\n\n\t\tlabel19.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel19.setText(\");\");\n\n\t\tlabel20.setFont(new java.awt.Font(\"Dialog\", 0, 14)); // NOI18N\n\t\tlabel20.setText(\" /\");\n\n\t\tlabel21.setFont(new java.awt.Font(\"Dialog\", 0, 14)); // NOI18N\n\t\tlabel21.setText(\" %\");\n\n\t\tlabel22.setFont(new java.awt.Font(\"Dialog\", 0, 14)); // NOI18N\n\t\tlabel22.setText(\" +\");\n\n\t\tlabel23.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel23.setText(\");\");\n\n\t\tlabel24.setFont(new java.awt.Font(\"Dialog\", 0, 14)); // NOI18N\n\t\tlabel24.setText(\" +\");\n\n\t\tlabel25.setFont(new java.awt.Font(\"Dialog\", 0, 14)); // NOI18N\n\t\tlabel25.setText(\" /\");\n\n\t\tlabel26.setFont(new java.awt.Font(\"Dialog\", 0, 14)); // NOI18N\n\t\tlabel26.setText(\" *\");\n\n\t\tlabel27.setCursor(new java.awt.Cursor(java.awt.Cursor.DEFAULT_CURSOR));\n\t\tlabel27.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel27.setText(\")\");\n\n\t\tlabel28.setFont(new java.awt.Font(\"Dialog\", 0, 14)); // NOI18N\n\t\tlabel28.setText(\")\");\n\n\t\tlabel30.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel30.setText(\"}\");\n\n\t\tlabel31.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel31.setText(\"}\");\n\n\t\tlabel32.setFont(new java.awt.Font(\"Consolas\", 0, 14)); // NOI18N\n\t\tlabel32.setText(\");\");\n\n\t\tjButton1.setFont(new java.awt.Font(\"Segoe UI Semibold\", 0, 14)); // NOI18N\n\t\tjButton1.setText(\"Check\");\n\t\tjButton1.addActionListener(new java.awt.event.ActionListener() {\n\t\t\tpublic void actionPerformed(java.awt.event.ActionEvent evt) {\n\t\t\t\tjButton1ActionPerformed(evt);\n\t\t\t}\n\t\t});\n\n\t\tjavax.swing.GroupLayout layout = new javax.swing.GroupLayout(this);\n\t\tlayout.setHorizontalGroup(layout.createParallelGroup(Alignment.LEADING)\n\t\t\t\t.addGroup(layout.createSequentialGroup().addGap(28).addGroup(layout\n\t\t\t\t\t\t.createParallelGroup(Alignment.LEADING).addComponent(getDoneButton()).addComponent(jButton1)\n\t\t\t\t\t\t.addComponent(label7, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addComponent(label6, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addComponent(label5, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addComponent(label4, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addComponent(label3, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t.addComponent(label1, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t.addGap(1)\n\t\t\t\t\t\t\t\t.addComponent(label2, GroupLayout.PREFERRED_SIZE, 774, GroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t.addGap(92).addGroup(layout.createParallelGroup(Alignment.LEADING).addGroup(layout\n\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.LEADING, false)\n\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label15, GroupLayout.PREFERRED_SIZE, 145,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField8, GroupLayout.PREFERRED_SIZE, 20,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGap(2)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label21, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField7, GroupLayout.PREFERRED_SIZE, 20,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label8, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField1, GroupLayout.PREFERRED_SIZE, 20,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label9, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED).addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\ttextField2, GroupLayout.PREFERRED_SIZE, 20,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label31, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup().addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label14, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGap(37))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup().addGap(174)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField5, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t20, GroupLayout.PREFERRED_SIZE)))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label18, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGap(7)))\n\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.LEADING).addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(Alignment.TRAILING, false).addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField4, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t20, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label17, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label22, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField9, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t20, GroupLayout.PREFERRED_SIZE)))\n\t\t\t\t\t\t\t\t\t\t\t\t.addGap(20)\n\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.TRAILING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label23, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label20, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField3, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t20, GroupLayout.PREFERRED_SIZE)))\n\t\t\t\t\t\t\t\t\t\t\t\t.addGap(20).addComponent(label19, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup().addGap(23).addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tlabel10, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))))\n\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label16, GroupLayout.PREFERRED_SIZE, 177,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField12, GroupLayout.PREFERRED_SIZE, 20,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label24, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField6, GroupLayout.PREFERRED_SIZE, 20,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label27, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label25, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField11, GroupLayout.PREFERRED_SIZE, 20,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label28, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addGap(1)\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label26, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField10, GroupLayout.PREFERRED_SIZE, 20,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED).addComponent(label32,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))))\n\t\t\t\t\t\t.addComponent(label30, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t.addContainerGap(GroupLayout.DEFAULT_SIZE, Short.MAX_VALUE)));\n\t\tlayout.setVerticalGroup(\n\t\t\t\tlayout.createParallelGroup(Alignment.LEADING).addGroup(layout.createSequentialGroup().addContainerGap()\n\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.TRAILING)\n\t\t\t\t\t\t\t\t.addComponent(label1, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t.addComponent(label2, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t.addGap(1)\n\t\t\t\t\t\t.addComponent(label3, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t.addComponent(label4, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t.addComponent(label5, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t.addComponent(label6, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t.addComponent(label7, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\tAlignment.TRAILING)\n\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\tlayout.createSequentialGroup().addGroup(layout.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\tAlignment.TRAILING)\n\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createSequentialGroup().addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(Alignment.TRAILING).addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label9,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(Alignment.TRAILING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label8,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField1,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\ttextField2, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label10,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGap(3)))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGap(19)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.TRAILING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField5,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label14,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup().addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label18,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(Alignment.TRAILING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label17,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField4,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGap(1))))\n\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label20, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label19, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField3, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE, GroupLayout.PREFERRED_SIZE)))\n\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup().addGap(78)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label27, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup().addGap(76)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField11, GroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup().addGap(75)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.TRAILING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label32,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField10,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addPreferredGap(ComponentPlacement.RELATED, 20,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tShort.MAX_VALUE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(Alignment.TRAILING, false)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.TRAILING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label15,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField8,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label21,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField7,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGap(27))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.TRAILING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField9,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label22,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tlayout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGap(3)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tlabel23,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGap(29)))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.TRAILING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label16,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField12,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout.createSequentialGroup()\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGroup(layout\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.createParallelGroup(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tAlignment.TRAILING)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(label24,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addComponent(textField6,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE))\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t.addGap(1))))))\n\t\t\t\t\t\t\t\t.addGroup(layout.createParallelGroup(Alignment.LEADING)\n\t\t\t\t\t\t\t\t\t\t.addComponent(label25, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t.addComponent(label28, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t\t\t\t\t.addComponent(label26, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)))\n\t\t\t\t\t\t.addGap(30)\n\t\t\t\t\t\t.addComponent(label31, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addGap(25)\n\t\t\t\t\t\t.addComponent(label30, GroupLayout.PREFERRED_SIZE, GroupLayout.DEFAULT_SIZE,\n\t\t\t\t\t\t\t\tGroupLayout.PREFERRED_SIZE)\n\t\t\t\t\t\t.addGap(26).addComponent(jButton1).addPreferredGap(ComponentPlacement.RELATED)\n\t\t\t\t\t\t.addComponent(getDoneButton()).addContainerGap(23, Short.MAX_VALUE)));\n\t\tthis.setLayout(layout);\n\n\t\tlabel16.getAccessibleContext().setAccessibleName(\"System.out.print( ( (\");\n\t\tlabel17.getAccessibleContext().setAccessibleName(\"\");\n\t\tlabel18.getAccessibleContext().setAccessibleName(\" +\");\n\t}",
"public Pregunta23() {\n initComponents();\n }",
"public FormMenuUser() {\n super(\"Form Menu User\");\n initComponents();\n }",
"public AvtekOkno() {\n initComponents();\n }",
"public busdet() {\n initComponents();\n }",
"public ViewPrescriptionForm() {\n initComponents();\n }",
"public Ventaform() {\n initComponents();\n }",
"public Kuis2() {\n initComponents();\n }",
"public CreateAccount_GUI() {\n initComponents();\n }",
"public POS1() {\n initComponents();\n }",
"public Carrera() {\n initComponents();\n }",
"public EqGUI() {\n initComponents();\n }",
"public JFriau() {\n initComponents();\n this.setLocationRelativeTo(null);\n this.setTitle(\"BuNus - Budaya Nusantara\");\n }",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents() {\n\n setBackground(new java.awt.Color(204, 204, 204));\n setMinimumSize(new java.awt.Dimension(1, 1));\n setPreferredSize(new java.awt.Dimension(760, 402));\n\n javax.swing.GroupLayout layout = new javax.swing.GroupLayout(this);\n this.setLayout(layout);\n layout.setHorizontalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGap(0, 750, Short.MAX_VALUE)\n );\n layout.setVerticalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGap(0, 400, Short.MAX_VALUE)\n );\n }",
"public nokno() {\n initComponents();\n }",
"public dokter() {\n initComponents();\n }",
"public ConverterGUI() {\n initComponents();\n }",
"public hitungan() {\n initComponents();\n }",
"public Modify() {\n initComponents();\n }",
"public frmAddIncidencias() {\n initComponents();\n }",
"public CovidGUI(){\n initComponents();\n }"
]
| [
"0.73206544",
"0.7291311",
"0.7291311",
"0.7291311",
"0.7286492",
"0.7249181",
"0.7213362",
"0.72085494",
"0.71965617",
"0.7190475",
"0.7184897",
"0.7159234",
"0.71483016",
"0.7094075",
"0.7081491",
"0.70579433",
"0.6987627",
"0.69776064",
"0.69552463",
"0.69549114",
"0.69453007",
"0.69439274",
"0.69369227",
"0.6932056",
"0.6927733",
"0.6925948",
"0.69254535",
"0.69121534",
"0.6911907",
"0.6894101",
"0.6892413",
"0.68919593",
"0.6891924",
"0.6889863",
"0.6884052",
"0.6883223",
"0.688166",
"0.68787736",
"0.68764126",
"0.68745583",
"0.68721986",
"0.68595314",
"0.685675",
"0.68565613",
"0.6855288",
"0.6854687",
"0.6854457",
"0.685303",
"0.685303",
"0.68448347",
"0.6837389",
"0.6837193",
"0.6829965",
"0.6829964",
"0.68275386",
"0.68249714",
"0.6823691",
"0.6818224",
"0.68173605",
"0.6811417",
"0.6809674",
"0.680964",
"0.6809329",
"0.68085754",
"0.6802194",
"0.67955625",
"0.67938477",
"0.6793322",
"0.679176",
"0.67900634",
"0.6789749",
"0.67888486",
"0.6781942",
"0.6767308",
"0.6766431",
"0.6765252",
"0.67573947",
"0.6756327",
"0.6753509",
"0.67520833",
"0.6741834",
"0.6740361",
"0.6737793",
"0.67370224",
"0.6734898",
"0.6727867",
"0.6727453",
"0.67214817",
"0.6716735",
"0.67162156",
"0.6715855",
"0.6709997",
"0.6707508",
"0.67042965",
"0.6702483",
"0.67014945",
"0.67007315",
"0.6699097",
"0.669545",
"0.6692102",
"0.6690473"
]
| 0.0 | -1 |
Gets the associated view | public View getView() {
return view;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public ViewIdentificator getView() {\r\n return view;\r\n }",
"public View getView() {\n return view;\n }",
"public String getView();",
"public String getView();",
"View getActiveView();",
"public View getView() { return view; }",
"protected View getCompartmentView() {\n\t\tView view = (View) getDecoratorTarget().getAdapter(View.class);\r\n\t\tIterator it = view.getPersistedChildren().iterator();\r\n\t\twhile (it.hasNext()) {\r\n\t\t\tView child = (View) it.next();\r\n\t\t\tif (child.getType().equals(DeployCoreConstants.HYBRIDLIST_SEMANTICHINT)) {\r\n\t\t\t\treturn child;\r\n\t\t\t}\r\n\t\t}\r\n\t\treturn null;\r\n\t}",
"private View getView() {\n try {\n return (View) this.webView.getClass().getMethod(\"getView\", new Class[0]).invoke(this.webView, new Object[0]);\n } catch (Exception unused) {\n return (View) this.webView;\n }\n }",
"com.google.ads.googleads.v6.resources.ClickView getClickView();",
"public java.lang.String getView() {\n return view;\n }",
"public java.lang.String getView() {\n return view;\n }",
"public java.lang.String getView() {\n return view;\n }",
"Views getViews();",
"@Override\r\n\tpublic View getView() {\n\t\treturn this.view;\r\n\t}",
"public GraphView getVisibleView() {\r\n\t\treturn graphModel.getVisibleView();\r\n\t}",
"ViewElement getViewElement();",
"Object getViewDetails();",
"public AddressSetView getCurrentView();",
"com.google.ads.googleads.v6.resources.TopicView getTopicView();",
"@Override\r\n\tpublic String getViewIdentifier() {\n\t\treturn ClassUtils.getUrl(this);\r\n\t}",
"@Override\n\tpublic String getViewIdentifier() {\n\t\treturn ClassUtils.getUrl(this);\n\t}",
"@Override\n\tpublic String getViewIdentifier() {\n\t\treturn ClassUtils.getUrl(this);\n\t}",
"@Override\n\tpublic View getView(String viewName) {\n\n\t\tint resourceID = context.getResources().getIdentifier(viewName, \"id\",\n\t\t\t\tcontext.getPackageName());\n\t\tviewObject = activity.findViewById(resourceID);\n\n\t\treturn viewObject;\n\t}",
"public ViewObjectImpl getDcmRoleTemplateView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmRoleTemplateView\");\r\n }",
"ViewMap<IBranchMapping> getView();",
"String getViewClass();",
"public String getViewName() {\n return viewName;\n }",
"public ViewObjectImpl getDcmTemplateView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmTemplateView\");\r\n }",
"@NonNull\n public final AutoRef<View> getView() throws IllegalStateException, ReferenceNullException {\n return AutoRef.of(getBinding().get().getRoot());\n }",
"public String getViewName() {\n return viewName;\n }",
"public ViewObjectImpl getEventInterviewerDetails1() {\n return (ViewObjectImpl) findViewObject(\"EventInterviewerDetails1\");\n }",
"public ViewObjectImpl getEventDetails1() {\n return (ViewObjectImpl) findViewObject(\"EventDetails1\");\n }",
"public DialogView getView() {\n // Create view lazily only once it's needed\n if (this.home3DAttributesView == null) {\n this.home3DAttributesView = this.viewFactory.createHome3DAttributesView(\n this.preferences, this); \n }\n return this.home3DAttributesView;\n }",
"int getViewId();",
"public String getViewPath() {\n return mviewPath;\n }",
"public View getView() {\n // Create view lazily only once it's needed\n if (this.furnitureView == null) {\n this.furnitureView = this.viewFactory.createFurnitureView(this.home, this.preferences, this);\n }\n return this.furnitureView;\n }",
"public IJoinGameView getJoinGameView() {\n\t\t\n\t\treturn (IJoinGameView)super.getView();\n\t}",
"public View findViewById(int viewId){\r\n return AppContext.getCurrent().getActivity().getCurrentView().findViewById(viewId);\r\n }",
"public ViewObjectImpl getDcmJobView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmJobView\");\r\n }",
"@Override\n public Activity getViewActivity() {\n return this;\n }",
"public ViewObjectImpl getDcmUserTemplateView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmUserTemplateView\");\r\n }",
"String getViewName() {\n\t\treturn this.viewName;\n\t}",
"public ViewLinkImpl getinterviewetforadding() {\n return (ViewLinkImpl) findViewLink(\"interviewetforadding\");\n }",
"public DrawingView view() {\n return fView;\n }",
"public CalendarEventView getCalendarEventView()\r\n {\n CalendarEventView cView = new CalendarEventView(\"appointmentView\");;\r\n\r\n cView.setEventId(getEventId());\r\n return cView;\r\n }",
"public final String getViewName() {\n\t\treturn viewName;\n\t}",
"public abstract String getView();",
"public java.lang.Boolean getView() {\n return view;\n }",
"public java.lang.String getViewName() {\r\n return viewName;\r\n }",
"private View getCachedView()\n\t{\n\t\tif (_cachedItemViews.size() != 0)\n\t\t{\n\t\t\treturn _cachedItemViews.removeFirst();\n\t\t}\n\t\treturn null;\n\t}",
"@CheckForNull\n View getView(String viewName);",
"public ViewObjectImpl getEventInterviewerDetailsVO1() {\n return (ViewObjectImpl) findViewObject(\"EventInterviewerDetailsVO1\");\n }",
"private View getCachedView() {\n if (mCachedItemViews.size() != 0) {\n return mCachedItemViews.removeFirst();\n }\n return null;\n }",
"String getViewType();",
"public BwView getView() {\n if (view == null) {\n view = new BwView();\n }\n\n return view;\n }",
"public ViewLinkImpl geteventinterviewer_interviewer() {\n return (ViewLinkImpl) findViewLink(\"eventinterviewer_interviewer\");\n }",
"ImageView getView() {\n return view;\n }",
"public AddSingleStatsView getView(){\r\n\t\treturn view;\r\n\t}",
"public Parent getView() {\r\n Parent view = null;\r\n try {\r\n FXMLLoader loader = new FXMLLoader(\r\n ListProjectsViewController.class.getResource(\"/views/collaborator/Collaborator.fxml\"));\r\n loader.load();\r\n viewController = loader.getController();\r\n viewController.setListener(this);\r\n initializeCollaboratorCheckComboBox();\r\n setProjectTitleText();\r\n setCollaboratorsInCheckComboBox();\r\n view = loader.getRoot();\r\n\r\n } catch (IOException e) {\r\n HomeController.displayErrorAlert(e.getMessage(),\r\n ErrorMessagesUtils.ERROR_LOADING_VIEW);\r\n } catch (DatabaseException e) {\r\n HomeController.displayErrorAlert(e.getMessage(),\r\n ErrorMessagesUtils.ERROR_MESSAGE);\r\n } catch (ConnectionFailedException e) {\r\n HomeController.displayErrorAlert(e.getMessage(), ErrorMessagesUtils.CONNECTION_MSG_ERROR);\r\n }\r\n return view;\r\n }",
"View getShowReportGraphView();",
"public ViewObjectImpl getEmployeesView1() {\n return (ViewObjectImpl)findViewObject(\"EmployeesView1\");\n }",
"public ViewObjectImpl getDcmCombinationView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmCombinationView\");\r\n }",
"public View findViewById(int id) {\r\n\t\tView _view;\r\n\r\n\t\t// get parent view\r\n\t\tView _presentView = getPresentView();\r\n\r\n\t\t// check present view\r\n\t\tif (null == _presentView) {\r\n\t\t\t_view = null;\r\n\r\n\t\t\tLog.e(LOG_TAG, \"Simple imeeting base view present view is null.\");\r\n\t\t} else {\r\n\t\t\t_view = _presentView.findViewById(id);\r\n\t\t}\r\n\r\n\t\treturn _view;\r\n\t}",
"public ImageView getImageView() {\n return (ImageView) getView().findViewById(imageViewId);\n }",
"protected InteractionDrawingEditor getViewEditor()\n {\n return view.getEditor();\n }",
"public ViewObjectImpl getDcmTemplateCombinationView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmTemplateCombinationView\");\r\n }",
"@Override\n public View getView() {\n return mView;\n }",
"public ViewObjectImpl getDcmComVsView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmComVsView\");\r\n }",
"public ViewObjectImpl getDcmValidationView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmValidationView\");\r\n }",
"public TransportView getTransportView(String id) {\n if (id == null)\n return null;\n for (TransportView t: _transportViews) {\n if (t.getId().equals(id))\n return t;\n }\n return null;\n }",
"public ViewConfiguration invoke() {\n return ViewConfiguration.get(this.f64333a);\n }",
"@Override\r\n\tpublic View getView() {\n\t\treturn super.getView();\r\n\t}",
"public ViewObjectImpl getDcmComVsQueryView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmComVsQueryView\");\r\n }",
"public ViewTaskOption getViewTaskOption() {\n return (ViewTaskOption) commandData.get(CommandProperties.TASKS_VIEW_OPTION);\n }",
"public GraphView getGraphView() {\n return this.graphView;\n }",
"@Override\r\n public View getView() {\r\n return mBaseView;\r\n }",
"public View getPresentView() {\r\n\t\tView _presentView;\r\n\r\n\t\t// check present view\r\n\t\tif (null == _mView) {\r\n\t\t\t// get layout inflater\r\n\t\t\tLayoutInflater _layoutInflater = (LayoutInflater) getContext()\r\n\t\t\t\t\t.getSystemService(Context.LAYOUT_INFLATER_SERVICE);\r\n\r\n\t\t\t// inflater present view, save it and return\r\n\t\t\t_presentView = _mView = _layoutInflater.inflate(\r\n\t\t\t\t\tpresentViewLayout(), null);\r\n\t\t} else {\r\n\t\t\t// return immediately\r\n\t\t\t_presentView = _mView;\r\n\t\t}\r\n\r\n\t\treturn _presentView;\r\n\t}",
"public View emitAsView() {\n return view;\n }",
"@Override\n\tpublic View GetDynamicView() {\n\t\treturn null;\n\t}",
"public RoomView getRoomView() {\n\t\treturn roomView;\n\t}",
"public ViewObjectImpl getEventInterviewerDetailsVO2() {\n return (ViewObjectImpl) findViewObject(\"EventInterviewerDetailsVO2\");\n }",
"@Override\n\tpublic View getView() {\n\t\treturn super.getView();\n\t}",
"public AbstractView getView(String viewName)\n {\n if (viewName == null)\n return null;\n\n return m_NameMap.getView(viewName);\n }",
"public ViewProcessor getViewProcessor() {\n return _viewProcessor;\n }",
"private ViewFrame getViewFrame() {\n\t\treturn this.viewFrame;\n\t}",
"@Override\n public View getView()\n {\n return view;\n }",
"@SuppressWarnings(\"unchecked\")\n\tpublic View getView(int id) {\n\t\t\n\t\tt = (T) activity.findViewById(id);\n\t\treturn (View)t;\n\t}",
"public ViewObjectImpl getComplainsSuggestionsView1() {\n return (ViewObjectImpl)findViewObject(\"ComplainsSuggestionsView1\");\n }",
"protected View getCachedView(){\n\t\tif (mCachedItemViews.size() != 0) {\n\t\t\tView v;\n\t\t\tdo{\n\t v = mCachedItemViews.removeFirst().get();\n\t\t\t}\n while(v == null && mCachedItemViews.size() != 0);\n\t\t\treturn v;\n }\n return null;\n\t}",
"public ViewObjectImpl getDcmCatTemplateQueryView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmCatTemplateQueryView\");\r\n }",
"public View invoke() {\n return this.f64322a.findViewById(R.id.am2);\n }",
"public View e() {\n this.i = this.h.findViewById(c.e.popup_window_view);\n return this.i;\n }",
"public int getCurrentDetailView() {\n return currentDetailView;\n }",
"public View getTopView() {\n\t\tint topViewIndex = getChildCount() - 1;\n\t\treturn getChildAt(topViewIndex);\n\t}",
"private String determineViewTag() {\r\n\t\tif (viewTag == null) {\r\n\t\t\tviewTag = ClearCaseUtils.getViewTag(getViewPath(), getProject());\r\n\t\t}\r\n\t\treturn viewTag;\r\n\t}",
"public ViewObjectImpl getFindYourOilVO1() {\n return (ViewObjectImpl) findViewObject(\"FindYourOilVO1\");\n }",
"public int getViewType()\n {\n return this.viewType;\n }",
"public View invoke() {\n return this.f64321a.findViewById(R.id.am1);\n }",
"public View getView(int n) {\n return view;\n }",
"public AbstractView getPrimeView()\n {\n return m_MainWindow.getPrimeView();\n }"
]
| [
"0.74299246",
"0.6532015",
"0.650972",
"0.650972",
"0.64365155",
"0.64124",
"0.6268603",
"0.62677777",
"0.62620145",
"0.623145",
"0.623145",
"0.623145",
"0.62043774",
"0.6158793",
"0.61265147",
"0.61237234",
"0.60936564",
"0.6093014",
"0.60862184",
"0.6081529",
"0.60690194",
"0.60690194",
"0.6066045",
"0.60560715",
"0.6047067",
"0.6039945",
"0.6014688",
"0.59541416",
"0.5937868",
"0.5932086",
"0.5931555",
"0.59147364",
"0.5882884",
"0.5868704",
"0.5864501",
"0.58378583",
"0.58289915",
"0.5828247",
"0.5807361",
"0.579649",
"0.57705617",
"0.57698107",
"0.5762506",
"0.5753232",
"0.57497305",
"0.5742496",
"0.5740913",
"0.5732269",
"0.5721778",
"0.5675645",
"0.56670034",
"0.5654515",
"0.56406313",
"0.56332076",
"0.5623861",
"0.561073",
"0.56026787",
"0.55987644",
"0.55927294",
"0.5585471",
"0.5566589",
"0.554146",
"0.5525266",
"0.5524631",
"0.5521652",
"0.55060184",
"0.55033845",
"0.54999256",
"0.54961604",
"0.5492566",
"0.5492394",
"0.5475416",
"0.5461653",
"0.545938",
"0.5449673",
"0.54359883",
"0.5428617",
"0.5428572",
"0.5414012",
"0.54134744",
"0.5396608",
"0.5391782",
"0.539014",
"0.5388188",
"0.53860027",
"0.5384412",
"0.53765637",
"0.537207",
"0.53699404",
"0.5366719",
"0.5365951",
"0.5364377",
"0.5363681",
"0.53596807",
"0.5355163",
"0.5347574",
"0.53468966",
"0.5346815",
"0.5346406",
"0.5344967"
]
| 0.67675996 | 1 |
Sets the view this action must run in. | public void setView(View view) {
this.view = view;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"protected void setView(@NonNull T view) {\n mView = view;\n }",
"public void setView(View view);",
"public void setView(final String view) \n {\n\tthis.view = view;\n }",
"public void setView(int view)\r\n\t{\n\t\tswitch(view)\r\n\t\t{\r\n\t\t\tcase Settings.ANONYMOUS_VIEW:\r\n\t\t\t\tbreak;\r\n\t\t\tcase Settings.WELCOME_VIEW:\r\n\t\t\t\tbreak;\r\n\t\t\tcase Settings.ACCOUNT_VIEW:\r\n\t\t\t\tbreak;\r\n\t\t}\r\n\t\t\t\r\n\t}",
"public void setView(CMView _view) {\n mView = _view;\n }",
"@Override\n\tpublic void setView(View view) {\n\n\t}",
"public Get setView(java.lang.String view) {\n this.view = view;\n return this;\n }",
"public void setView(java.lang.Boolean view) {\n this.view = view;\n }",
"public BatchGet setView(java.lang.String view) {\n this.view = view;\n return this;\n }",
"void setView(View v);",
"public void setView(IHUDView view) {\n\n this.view = view;\n stateChange(uiStateManager.getState());\n playerAttributeChange();\n }",
"protected void setCurrentView( final View view )\n {\n updater.setCurrentView( view );\n }",
"public void setView(View v)\n {\n\tthis.view = v;\n\tif (this.view != null)\n\t{\n\t addActionListeners();\n\t}\n }",
"public void setView(View view) {\n mView = view;\n mViewSpacingSpecified = false;\n }",
"public void setView(View view) {\n this.view = view;\n this.model = view.getModel();\n initControl();\n }",
"private void setContentView(View view) {\n mContentView = view;\n }",
"void assignToView(View view) {\n int pass = mPass - 1;\n // prepare the view for display while rendering\n prepare(view, mParam, pass);\n // update the view with whatever work we have already done\n if (pass >= 0)\n update(view, mRender, pass);\n // check if we have work left to do\n if (mPass < mPasses) {\n // add the view to our set\n mViews.add(view);\n // tag the view so that we can cancel the task later if we need\n // to\n setTask(view, this);\n // all set, queue us up\n enqueue();\n }\n }",
"@Override\n\tpublic void setView(Resultado resultado, HttpServletRequest request, HttpServletResponse response) {\n\n\t}",
"@Override\n public void setView(@NonNull final View view) {\n mNextView = view;\n }",
"private void maySetCurrentView(ProductSceneView view) {\n final String viewProductType = view.getProduct().getProductType();\n if (view != currentView &&\n !view.isRGB() &&\n viewProductType.equals(AbstractTimeSeries.TIME_SERIES_PRODUCT_TYPE) &&\n TimeSeriesMapper.getInstance().getTimeSeries(view.getProduct()) != null) {\n setCurrentView(view);\n }\n }",
"@Override\r\n\tpublic void setView(ViewProduct v) {\n\t\tthis.view = v;\r\n\t}",
"private void setViews() {\n\n }",
"public void setAssessSetview(String assessSetview) {\r\n this.assessSetview = assessSetview == null ? null : assessSetview.trim();\r\n }",
"void setView(PopupView<T> view);",
"@Override\n\tpublic void setCustomView(View view) {\n\t\t\n\t}",
"@Override\n\tpublic FileSelectDialog setView(View view) {\n\t\tthrow new Error(\"You cannot customize the view of a FileSelectDialog, \" +\n\t\t\t\t\"this feature would override the actual list\");\n\t}",
"protected ReliedOnView() {}",
"public List setView(java.lang.String view) {\n this.view = view;\n return this;\n }",
"public void setView(Component view){\n int n=getComponentCount();\n for(int i=n-1;i>=0;i--){\n remove(getComponent(i));\n }\n isViewSizeSet=false;\n if(view!=null){\n super.addImpl(view,null,-1);\n viewListener=createViewListener();\n view.addComponentListener(viewListener);\n }\n if(hasHadValidView){\n // Only fire a change if a view has been installed.\n fireStateChanged();\n }else if(view!=null){\n hasHadValidView=true;\n }\n viewChanged=true;\n revalidate();\n repaint();\n }",
"public void setView(AddSegmentDialog view) {\n View = view;\n }",
"public void setView(final BwView val) {\n view = val;\n }",
"public final void setViewName(String viewName) {\n\t\tthis.viewName = viewName;\n\t}",
"public void setView(FruitView newView){\n\t\tthis.view = newView;\n\t}",
"public TournamentSetting_View(RiskStart_View start_view, boolean modality)\r\n\t{\r\n\t\tsetTitle(\"Setting Tournament Mode\");\r\n setPreferredSize(new Dimension(200, 200));\r\n setDefaultCloseOperation(JFrame.HIDE_ON_CLOSE);\r\n setResizable(false);\r\n add(tournamentSettingPanel());\r\n setLocationRelativeTo(null);\r\n pack();\r\n\t}",
"@Override\n\tprotected void setView() {\n\t\tsetContentView(R.layout.activity_main);\n\t}",
"public void setView(SimulationManagerView newView) throws SimulationException {\n try {\n theSimManagerView = newView;\n \n theSimManagerView.tick(theCoorInt.getCurrentSimulationTime()); \n theSimManagerView.setScriptStatus(theCoorInt.getScriptStatus());\n theSimManagerView.setParamicsStatus(theCoorInt.getParamicsStatus());\n \n initialize();\n }\n catch (RemoteException re) {\n simManagerLogger.logp(Level.SEVERE, \"SimulationManagerModel\", \n \"startSimulation\", \"Unable to communicate with the \" +\n \"CAD Simulator.\", re);\n \n throw new SimulationException(SimulationException.CAD_SIM_COMM, re);\n } \n \n }",
"public void switchView(View view) {\r\n\t\tthis.currentView = view;\r\n\t\trenderView();\r\n\t}",
"public void configure(T aView) { }",
"public void setViewName(java.lang.String viewName) {\r\n this.viewName = viewName;\r\n }",
"protected abstract void setupMvpView();",
"@Override\n public void init(View view) {\n this.view = (BackstoryView) view;\n }",
"public void setViewProcessor(ViewProcessor viewProcessor) {\n JodaBeanUtils.notNull(viewProcessor, \"viewProcessor\");\n this._viewProcessor = viewProcessor;\n }",
"public abstract void setRenderRedirectViewId(String viewId);",
"public void setIsView(Byte isView) {\n this.isView = isView;\n }",
"protected void viewSetup() {\n\t\t// TODO Auto-generated method stub\n\n\t}",
"public Installer on(@NonNull View view) {\n rootView = (ViewGroup) view.getRootView();\n return this;\n }",
"public abstract void setViewManager(IViewManager viewManager, ITurnManager turnManager);",
"public String getAssessSetview() {\r\n return assessSetview;\r\n }",
"@FXML\n private void viewSelected() {\n if (selectedAccount == null) {\n // Warn user if no account was selected.\n noAccountSelectedAlert(\"View DonorReceiver\");\n } else {\n ViewProfilePaneController.setAccount(selectedAccount);\n PageNav.loadNewPage(PageNav.VIEW);\n }\n }",
"public void setInViews(String value) {\n setValue(IN_VIEWS, value);\n }",
"void setActiveView(ViewFrame activeView);",
"public Builder setContentView(View v) {\r\n this.contentView = v;\r\n return this;\r\n }",
"public void setLocation(ParentView view) {\r\n\t\tif (view instanceof BuildingView) {\r\n\t\t\tlocation = Location.BUILDING;\r\n\t\t} else if (view instanceof TownView) {\r\n\t\t\tlocation = Location.TOWN;\r\n\t\t} else if (view instanceof SafariView) {\r\n\t\t\tlocation = Location.SAFARI;\r\n\t\t} else if (view instanceof CaveView) {\r\n\t\t\tlocation = Location.CAVE;\r\n\t\t}\r\n\t}",
"@Override\r\n\tpublic void setContentView(View view) {\r\n\t\tsuper.setContentView(view);\r\n\t\tapplyCustomTitle();\r\n\t}",
"void setPlayerView(View v);",
"public void setViewType(int viewType)\n {\n this.viewType = viewType;\n }",
"private void setViewFrame(final ViewFrame viewFrame) {\n\t\tthis.viewFrame = viewFrame;\n\t}",
"public final void setViewPath(String viewPath) {\n mviewPath = viewPath;\n }",
"private void setViewFrame(final ViewFrame viewFrame) {\r\n\t\tthis.viewFrame = viewFrame;\r\n\t}",
"public void goTo(View view) {\n if (stage != null) {\n try {\n Parent root = FXMLLoader.load(getClass().getResource(\"../ui/\" + view.toString() + \".fxml\"));\n stage.setTitle(APP_NAME);\n stage.setScene(new Scene(root, APP_WIDTH, APP_HEIGHT));\n stage.show();\n } catch (IOException e) {\n System.err.println(\"The view \" + \"../ui/\" + view.toString() + \".fxml\" + \" doesn't exist.\");\n e.printStackTrace();\n }\n }\n }",
"public T setPoint(@NonNull View view) {\n int[] location = new int[2];\n view.getLocationInWindow(location);\n int x = location[0] + view.getWidth() / 2;\n int y = location[1] + view.getHeight() / 2;\n return setPoint(x, y);\n }",
"public void updateView(ClientView view);",
"@SuppressWarnings(\"deprecation\")\n public void setDate(View view) {\n showDialog(999);\n }",
"@Override\n protected void initViewSetup() {\n }",
"@Required\n\tpublic void setInputFormView(String inputFormView) {\n\t\tthis.inputFormView = inputFormView;\n\t}",
"public SchemaViewController( SchemaView view )\n {\n this.view = view;\n viewer = view.getViewer();\n \n initActions();\n initToolbar();\n initMenu();\n initContextMenu();\n initProjectsHandlerListener();\n initDoubleClickListener();\n initAuthorizedPrefs();\n initPreferencesListener();\n }",
"public Builder setContentView(View v) {\n this.contentView = v;\n return this;\n }",
"public Builder setContentView(View v) {\n this.contentView = v;\n return this;\n }",
"public void changeScene(final View view) {\n try {\n Parent viewHierarchy = loadHierarchy(view.getFXMLPath());\n Scene scene = new Scene(viewHierarchy);\n currStage.setScene(scene);\n currStage.show();\n\n } catch (Exception e) {\n System.err.print(\"\");\n }\n }",
"protected void setNotificationView(View notificationView) {\n mNotificationView = notificationView;\n }",
"public void configure(T aView) { aView.setText(\"Button\"); }",
"public final void zza(View view) {\n this.zznj = view;\n }",
"@Override\n public void onCreate(MVP.RequiredBuildWorkoutViewOps view) {\n super.onCreate(view);\n }",
"@Override\n\tprotected void initViews(View view) {\n\t\tsuper.initViews(view);\n//\t\tsendRequestData();\n\t}",
"@Override\n\tpublic void setCustomView(int resId) {\n\t\t\n\t}",
"public void configure(T aView) { aView.setText(\"Label\"); }",
"public void setStatusView(String statusView) {\r\n this.statusView = statusView;\r\n }",
"private void changeView(){\r\n\t\t\tm.changeView(Views.GAME, gameType, game);\r\n\t}",
"public void setConfig(View view) {\n startActivityForResult(new Intent(this, SettingsActivity.class), StaticConfig.REQUEST_CODE_SETTINGS);\n }",
"@Override\n\tpublic void setCustomView(View view, LayoutParams layoutParams) {\n\t\t\n\t}",
"public MyProgress setCustomView(View view) {\n if (view != null) {\n mProgressDialog.setView(view);\n } else {\n throw new RuntimeException(\"Custom view must not be null!\");\n }\n return this;\n }",
"public ActivityMenuEditController(final Model model, final View view) {\n\t\tsuper(model, view);\n\t}",
"public static void setNotificationsView(NotificationsView view) {\n\t\t\n\t\tnotificationsView = view;\n\t\t\n\t}",
"@Override\n\tpublic void view() {\n\t\t\n\t}",
"protected final void setView(View v) {\n rootView.setView(v);\n painted = false;\n editor.revalidate();\n editor.repaint();\n }",
"View mo73990a(View view);",
"@Override\r\n\t\tpublic void setViewBinder(ViewBinder viewBinder) {\n\t\t\tsuper.setViewBinder(viewBinder);\r\n\t\t}",
"public ViewAction( View view, SgFrame parent, Session session )\r\n {\r\n super( view.getName(), getIconFromView( view ) );\r\n this.view = view;\r\n this.parent = parent;\r\n buttons = new ArrayList<AbstractButton>();\r\n this.session = session;\r\n notYetAddedViListener = true;\r\n session.addObjectSelectionChangeListener( this );\r\n putValue( \"toolTipText\", view.getShortDescription() );\r\n\r\n createdVIs = new HashMap<ViewInstance,SessionElementDescriptor>();\r\n\r\n setEnabled( view.isAutostartView() || view.canHandle( null ) );\r\n }",
"public void setARView(int viewSetting) {\n // rerender the view without recreate the object\n if(currentDisplayMode==DISPLAY_PLACE_DETAIL)\n generateWorld(mWorld, mPlaceDetail,viewSetting, false);\n else\n generateWorld(mWorld, mPlaceListMain,viewSetting, false);\n\n }",
"public GUIController(GUI view) {\n this();\n this.view = view;\n }",
"@Override\r\n\tpublic void setViewCallback(ViewCallback callback) {\r\n\t\tthis.callback = callback;\r\n\t}",
"public void testSetViews() {\n }",
"public interface View{\n void setupViews();\n void onClickSubmitReview();\n void showSuccessfullReviewSubmit();\n void showErrorSubmitReview();\n }",
"@Override\n\tpublic void InitView() {\n\t\t\n\t}",
"private void setupView() {\n view.setName(advertisement.getTitle());\n view.setPrice(advertisement.getPrice());\n view.setDescription(advertisement.getDescription());\n view.setDate(advertisement.getDatePublished());\n view.setTags(advertisement.getTags());\n setCondition();\n if (advertisement.getImageUrl() != null) { //the url here is null right after upload\n view.setImageUrl(advertisement.getImageUrl());\n }\n }",
"void viewButton_actionPerformed(ActionEvent e) {\n doView();\n }",
"public Controller(ViewIF view) {\n\t\tthis.view = view;\n\t\tthis.dao = new DAO();\n\t\tthis.stats = new Statistics(this.dao);\n\t\tthis.gameStarted = false;\n\t}",
"public abstract void viewRun();",
"public void setView(AddressSetView view) {\n\t\tAddressSetView adjustedView = view;\n\n\t\tif (multiModel != null) {\n\t\t\tif ((program != null) && view.contains(new AddressSet(program.getMemory()))) {\n\t\t\t\tProgram otherProgram = otherPanel.getProgram();\n\t\t\t\tadjustedView = ProgramMemoryComparator.getCombinedAddresses(program, otherProgram);\n\t\t\t}\n\t\t\tmultiModel.setAddressSet(adjustedView);\n\t\t}\n\n\t\tlistingPanel.setView(adjustedView);\n\t\tif (otherPanel != null) {\n\t\t\t// Convert the view addresses to ones compatible with the otherPanel's model.\n\t\t\tAddressSet compatibleAddressSet =\n\t\t\t\tDiffUtility.getCompatibleAddressSet(adjustedView, otherPanel.getProgram());\n\t\t\totherPanel.setView(compatibleAddressSet);\n\t\t}\n\t}",
"public void setView(View view, int viewSpacingLeft, int viewSpacingTop, int viewSpacingRight,\n int viewSpacingBottom) {\n mView = view;\n mViewSpacingSpecified = true;\n mViewSpacingLeft = viewSpacingLeft;\n mViewSpacingTop = viewSpacingTop;\n mViewSpacingRight = viewSpacingRight;\n mViewSpacingBottom = viewSpacingBottom;\n }"
]
| [
"0.7156484",
"0.7115476",
"0.69812775",
"0.6890761",
"0.6829798",
"0.6825188",
"0.6768195",
"0.6713528",
"0.66807383",
"0.6565187",
"0.65270895",
"0.6478179",
"0.64055616",
"0.63708323",
"0.6350114",
"0.6249755",
"0.6204418",
"0.6203546",
"0.61732006",
"0.6113065",
"0.6094152",
"0.6087742",
"0.60450965",
"0.6042354",
"0.6026819",
"0.60247564",
"0.6013887",
"0.59104216",
"0.5891709",
"0.5864926",
"0.58640635",
"0.58584803",
"0.5814296",
"0.5797963",
"0.5736096",
"0.57335705",
"0.5714919",
"0.57098055",
"0.5681404",
"0.56761146",
"0.5666367",
"0.56627667",
"0.56403685",
"0.5629366",
"0.5616823",
"0.5613208",
"0.56124634",
"0.559983",
"0.5592",
"0.55879515",
"0.5574603",
"0.55668366",
"0.5562782",
"0.5559621",
"0.554246",
"0.55386317",
"0.55340797",
"0.55274606",
"0.5515109",
"0.5504279",
"0.55034065",
"0.55018276",
"0.55010915",
"0.54931897",
"0.5487527",
"0.5485861",
"0.5479191",
"0.5479191",
"0.5463305",
"0.5443778",
"0.54419565",
"0.54390055",
"0.54361403",
"0.5424875",
"0.5424446",
"0.54230756",
"0.54206306",
"0.54203105",
"0.54120266",
"0.5407315",
"0.54009235",
"0.54001683",
"0.5398678",
"0.5395988",
"0.53862005",
"0.53852487",
"0.5380334",
"0.5377874",
"0.5364669",
"0.5341332",
"0.5340817",
"0.5336325",
"0.53248066",
"0.53134257",
"0.53117156",
"0.5309019",
"0.52967626",
"0.5289822",
"0.5284723",
"0.528337"
]
| 0.72012126 | 0 |
Sets the key for the action name | public void setName(String name) {
this.name = name;
fireChange();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\n @NonNull\n public SliceActionImpl setKey(@NonNull String key) {\n mActionKey = key;\n return this;\n }",
"BaseAction(int key, String name) {\n this.key = key;\n this.name = name;\n }",
"public void setKeyName(String newName){\n\n //assigns the value newName to the keyName field\n this.keyName = newName;\n }",
"public void setAction(NameIdAction action) {\n\t\tif (nameidRequest != null) {nameidRequest.execute(action);}\n\t}",
"void setKey(java.lang.String key);",
"private void setKey(String key) {\n this.key = key;\n }",
"private void setAction(String action)\r\n/* 46: */ {\r\n/* 47: 48 */ this.action = action;\r\n/* 48: */ }",
"public void setKey(String key) {\n this.key = key;\n }",
"public void setKey(String key) {\r\n this.key = key;\r\n }",
"public void addActionKey(String name, InputKey key) {\n synchronized(actions) {\n InputAction action = actions.get(name);\n if(action == null)\n actions.put(name, action = new InputAction());\n action.addKey(key);\n }\n }",
"void setKey(final String key);",
"void setKey(String key);",
"private void setKey(String key){\n\t\tthis.key=key;\n\t}",
"public void setKey(String key) {\n this.key = key;\n }",
"public void setKey(String key) {\n this.key = key;\n }",
"public void setKey(String key) {\n this.key = key;\n }",
"public void setKey(String key) {\n\n this.key = key;\n }",
"public void setKey(final String key);",
"public void setKey(final String key);",
"protected void setKey(String key) {\r\n this.key = key;\r\n }",
"public void setKey(String key) {\r\n\t\tthis.key = key;\r\n\t}",
"public final void setKey(String key) {\n this.key = key;\n }",
"public void setKey(final String key) {\n this.key = key;\n }",
"public void setKey(java.lang.String key) {\n\t\tthis.key = key;\n\t}",
"public void setKey(String key) {\n\t\tthis.key = key;\n\t}",
"public void setKey(String key) {\n\t\tthis.key = key;\n\t}",
"public void setKey(String key) {\n\t\tthis.key = key;\n\t}",
"public void setAction(String action);",
"public void setKey(String aKey) {\n\t\tthis.key = aKey;\n\t}",
"public void setKey(String key)\r\n {\r\n m_key = key;\r\n }",
"public void setKey(Key key) {\n this.key = key;\n }",
"@Override\n\tpublic ManagedFunctionObjectTypeBuilder<M> setKey(M key) {\n\t\tthis.key = key;\n\t\tthis.index = key.ordinal();\n\t\treturn this;\n\t}",
"public com.opentext.bn.converters.avro.entity.ContentKey.Builder setKeyName(java.lang.String value) {\n validate(fields()[0], value);\n this.keyName = value;\n fieldSetFlags()[0] = true;\n return this;\n }",
"public void _setKey(String e)\n {\n _key = e;\n }",
"public void setKey(int key){\r\n this.key = key; \r\n }",
"private void setKey() {\n\t\t \n\t}",
"public Action(String name) {\n this.name = name;\n }",
"KeycloakEmailActions(String propKey){\n this.propKey = propKey;\n }",
"public void setKey (K k) {\n key = k;\n }",
"public void setActionInfo(String actionInfo);",
"public void setAction(String action) { this.action = action; }",
"void setKey(K key);",
"public void setKey(java.lang.String param){\n localKeyTracker = true;\n \n this.localKey=param;\n \n\n }",
"public void setKey(int key);",
"public void setKey(int key);",
"public void setKey(String e)\n {\n ScControlRegistry r;\n r = getRegistry();\n r.unregister(this);\n\n _key = e;\n r.register(this);\n }",
"public void set(String newKey)\n\t{\n\t\tthis.Key = newKey;\n\t}",
"public void setAction(String str) {\n\t\taction = str;\n\t}",
"public void setKey(char key){ this.key = key;}",
"public Builder setActionClassName(\n java.lang.String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n bitField0_ |= 0x00000001;\n actionClassName_ = value;\n onChanged();\n return this;\n }",
"public void setActionName(String actionName) {\n this.actionName = actionName;\n }",
"String setKey(String newKey);",
"public void setPermissionKey(String key){\r\n\t\tFactoryUtil.setPermissionKey(key);\r\n\t}",
"protected void declareGlobalActionKeys() {\n\r\n }",
"public void setKey(MessageKey key) {\n\tthis.key = key;\n }",
"public void setName(final String strname) {\n this.action.setValue(this.textBoxname, strname);\n }",
"public void setAction (String action) {\n this.action = action;\n }",
"public void setName(String name) {\n if (name == null || name.trim().length() == 0) {\n throw new IllegalArgumentException(\n \"Trigger name cannot be null or empty.\");\n }\n\n this.name = name;\n this.key = null;\n }",
"public ModelMessage addName(String key, String value) {\n super.addName(key, value);\n return this;\n }",
"void setKey(int key);",
"public void setKey(String key) {\n this.key = key == null ? null : key.trim();\n }",
"public void setKey(String key) {\n this.key = key == null ? null : key.trim();\n }",
"public void setAction(String action) {\n\t\tthis.action.set(action);\n\t}",
"public Builder setAction(\n String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n action_ = value;\n onChanged();\n return this;\n }",
"public void setAction(A action) {\r\n\t\tthis.action = action;\r\n\t}",
"public void setKey(String key) {\n if (element != null) {\n element.setKey(key);\n }\n }",
"private void setTranslationKey(String name) {\n\t\t\r\n\t}",
"public void setKey(K newKey) {\n this.key = newKey;\n }",
"public void setAction(String action)\n {\n // Check property\n if (action == null) \n { \n action = \"\"; \n }\n \n // If the specified context path already contains\n // a query string, append an ampersand character\n // for further parameter concatenation\n if (action.indexOf(\"=\") != -1)\n {\n action = action + \"&\";\n }\n else\n {\n action = action + \"?\";\n }\n \n // Set property\n this.action = action;\n }",
"public void setTargetString(String key) {\n/* 108 */ this.m_targetString = key;\n/* */ }",
"public void setKey(K newKey) {\r\n\t\tkey = newKey;\r\n\t}",
"String getActionName();",
"public void setAction(String action) {\n this.action = action;\n }",
"public void setAction(String action) {\n this.action = action;\n }",
"public void setAction(Action action) {\n this.action = action;\n }",
"public void setKey(TableKey key) {\n\tthis.key = key;\n }",
"public RenameAction(String name, Questionaire app) {\n\t\tsuper(name, app);\n\t}",
"public Action newAction(Object key) {\n\t\tif (key == null)\n\t\t\tthrow new IllegalArgumentException(\"No legal key passed!\");\n\t\tif (super.containsKey(key))\n\t\t\tthrow new IllegalArgumentException(\n\t\t\t\t\t\"Allready kontains a mapping for that key!\");\n\t\tAction action = new ActionForward();\n\t\tsuper.put(key, action);\n\t\tactionList.add(action);\n\t\treturn action;\n\t}",
"public void setItskey(String newItskey) {\n keyTextField.setText(newItskey);\n itskey = newItskey;\n }",
"@Override public void setKey(IndexKey key) {\n listOfKeys.add(key);\n\n }",
"public void setKey(SelectionKey key) {\n this._key = key;\n }",
"public void setIndex (int i){\n putValue(Action.NAME, i + \" \" + mDisplayName);\n putValue(Action.MNEMONIC_KEY, new Integer(Integer.toString(i).charAt(0)));\n }",
"public void setKey(String nkey) {\r\n setAttribute(\"id\", nkey);\r\n }",
"public void setAction(int value) {\n this.action = value;\n }",
"public void setKey(com.coda.www.efinance.schemas.elementmaster.ElmFullKey key) {\r\n this.key = key;\r\n }",
"@Override\n\tpublic void setMessageKey(String key) {\n\t\tsuper.setMessageKey(key);\n\t}",
"String getActionName(Closure action);",
"public void setKey(byte[] argKey) {\n this.key = argKey;\n }",
"private native void switchKey(String newKey);",
"void setObjectKey(String objectKey);",
"public K setKey(K key);",
"public void setUserAction(String newUserAction) {\n userAction = newUserAction;\n }",
"public void setInitialKey(java.lang.String value) {\r\n\t\tBase.set(this.model, this.getResource(), INITIALKEY, value);\r\n\t}",
"public void setCaseAction(java.lang.String newCaseAction) {\n\tcaseAction = newCaseAction;\n}",
"public void setSrcKey(String value) {\n\t\tsrcKey = value;\r\n }",
"public void setCommandKey(String commandKey)\n\t{\n\t\tthis.commandKey = Toolbox.trim(commandKey, 1);\n\t}",
"static InitKey toKey(final String key) throws ManagementException {\n\t\t\ttry {\n\t\t\t\treturn valueOf(key.toUpperCase());\n\t\t\t} catch (final IllegalArgumentException e) {\n\t\t\t\tthrow new ManagementException(key + \" is not a valid key for the Tic-Tac-Toe environment\", e);\n\t\t\t}\n\t\t}",
"private final void setAction(Action a){\n\t\tthis.a = a;\n\t}",
"public CayenneAction getAction(String key) {\n return (CayenneAction) actionMap.get(key);\n }",
"public Builder setNameKeySpace(\n String value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n nameKeySpace_ = value;\n onChanged();\n return this;\n }",
"public void setAction(String action) {\n\t\tthis.action = action;\n\t}"
]
| [
"0.7099871",
"0.69528157",
"0.674016",
"0.6712145",
"0.66627026",
"0.6609381",
"0.6557214",
"0.65454596",
"0.65346843",
"0.6501448",
"0.64960825",
"0.6493685",
"0.647045",
"0.6463265",
"0.6463265",
"0.6463265",
"0.64527214",
"0.6450896",
"0.6450896",
"0.6446056",
"0.64095134",
"0.6408513",
"0.6381312",
"0.63531816",
"0.63492715",
"0.63492715",
"0.6296653",
"0.62919",
"0.62817323",
"0.6165082",
"0.6156719",
"0.6030968",
"0.6019722",
"0.60072845",
"0.59982127",
"0.5994287",
"0.59397894",
"0.5937831",
"0.59356076",
"0.59142625",
"0.59021837",
"0.5896971",
"0.58737016",
"0.58655494",
"0.58655494",
"0.5827567",
"0.5817945",
"0.5791164",
"0.5783111",
"0.57743603",
"0.5773234",
"0.57527333",
"0.5744449",
"0.5736994",
"0.57355607",
"0.57337147",
"0.5720905",
"0.57054096",
"0.56999207",
"0.5694151",
"0.5693712",
"0.5693712",
"0.568163",
"0.56812686",
"0.55924445",
"0.55916166",
"0.55849093",
"0.55646944",
"0.5563777",
"0.5551316",
"0.55373317",
"0.5531946",
"0.5531859",
"0.5531859",
"0.55157214",
"0.5472173",
"0.5466383",
"0.5456572",
"0.54524106",
"0.5451481",
"0.5451417",
"0.54397005",
"0.54300296",
"0.5421898",
"0.54217774",
"0.54216665",
"0.5418434",
"0.54162675",
"0.54155487",
"0.54142076",
"0.5399008",
"0.53963256",
"0.53842163",
"0.5381239",
"0.5376625",
"0.5371341",
"0.53687036",
"0.536705",
"0.53645545",
"0.53566855",
"0.5354846"
]
| 0.0 | -1 |
Utility method to get the data associated to the view | protected Object getViewData() {
return view.getViewData();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"Object getViewDetails();",
"public StudioFinalFixDTO getViewData() {\n return this.viewData;\n }",
"private void getDataFromView() throws EmptyTextFieldException, EmptyChoiceBoxException, NumberSmallerOneException {\n\n date = _view.getDate().getValue();\n title = _view.getTitle().getText();\n function = _view.getFunction().getText();\n protagonist = _view.getProtagonist().getText();\n source = _view.getSource().getText();\n references = _view.getReferences().getText();\n description = _view.getDescription().getText();\n checkForEmptyFields();\n\n priority = _view.getPriorityMap().get(_view.getPriority().getValue());\n classification = _view.getClassificationMap().get(_view.getClassification().getValue());\n checkForEmptyChoiceBox();\n\n id = Integer.parseInt(_view.getId().getText());\n ftr = Integer.parseInt(_view.getFtr().getText());\n det = Integer.parseInt(_view.getDet().getText());\n checkForNumbersSmallerOne();\n }",
"public String getViewContent() {\r\n\t\treturn viewContent;\r\n\t}",
"public DataModel getData() {\r\n state = PersistentFacesState.getInstance();\r\n if (onePageDataModel == null) {\r\n onePageDataModel = new LocalDataModel(pageSize);\r\n }\r\n return onePageDataModel;\r\n }",
"Object getSingleResult(View view, Settings settings);",
"Views getViews();",
"public Object[] getData() {\n\t\treturn new Object[] { this.textoHtml };\n\t}",
"public Object getData() {\n if (this.mInvitation != null) return this.mInvitation;\n else if (this.mChatMessageFragment != null) return this.mChatMessageFragment;\n else return null;\n }",
"private void getAttributes(View view) {\n firstName = view.findViewById(R.id.user_first_name);\n vibez = view.findViewById(R.id.vibePointsNum);\n vibezString = view.findViewById(R.id.myVibe);\n myBooksRecyclerView = view.findViewById(R.id.my_books_recycler_view);\n booksIReadRecyclerView = view.findViewById(R.id.books_i_read_recycler_view);\n ownerImg = (CircleImageView) view.findViewById(R.id.circ_image);\n }",
"Map<String, String> getPropsViews();",
"private InsuranceContainerViewData getInsuranceContainerViewData()\r\n {\r\n return (InsuranceContainerViewData) sessionService.getAttribute(\"insuranceContainerViewData\");\r\n }",
"public ViewObjectImpl getEventDetails1() {\n return (ViewObjectImpl) findViewObject(\"EventDetails1\");\n }",
"public ViewObjectImpl getInterviewerDataVO1() {\n return (ViewObjectImpl) findViewObject(\"InterviewerDataVO1\");\n }",
"DataModel getDataModel ();",
"public String getView();",
"public String getView();",
"@Override\r\n\t\tpublic Meta_data getData() {\n\t\t\treturn this.data;\r\n\t\t}",
"public final RelationType<List<RelationType<?>>> getViewContentParam()\n\t{\n\t\treturn aViewContentParam;\n\t}",
"public void LoadSingleItemData(View view) {\n loadSingleItem(friendsDatabase);\n }",
"Object getCurrentData();",
"public void displayData(View view) {\n\n }",
"public Object getData();",
"public JSONObject ownGetView()\n {\n JSONObject jsonObject = new JSONObject();\n try\n {\n jsonObject.put(\"task\", currentTask.getTask());\n jsonObject.put(\"location\", currentTask.getLocation());\n jsonObject.put(\"starttime\", currentTask.getStartTime());\n currentTask.setStopStime(currentTask.getCurrentTime());\n jsonObject.put(\"stoptime\", currentTask.getStopStime());\n currentTask.recalculateTime();\n jsonObject.put(\"time\",currentTask.getTime());\n jsonObject.put(\"timeinseconds\",currentTask.getTimeInSeconds());\n jsonObject.put(\"gps\", currentTask.getGps());\n jsonObject.put(\"notes\", currentTask.getNotes());\n jsonObject.put(\"inmotion\", currentTask.isInMotion());\n jsonObject.put(\"edited\", currentTask.isEdited());\n }\n\n catch (JSONException e)\n {\n e.printStackTrace();\n }\n return jsonObject;\n }",
"public Object getData(){\n\t\treturn this.data;\n\t}",
"public Object data() {\n return this.data;\n }",
"@Override\n\t\t\tpublic View getInfoContents(Marker arg0) {\n\t\t\t\treturn null;\n\t\t\t}",
"T getData() {\n\t\treturn data;\n\t}",
"private void getData() {\n\t\tSharedPreferences preferences = getActivity().getSharedPreferences(\"the_username_and_password\", LoginActivity.MODE_PRIVATE);\n\t\tmToken = preferences.getString(\"accessToken\", \"\");\n//\t\tmap.put(\"access_token\", mToken);\n\n\t\tIPresenter presenter = new IPresenter(new IView<FeaturesBean>() {\n\n\t\t\t@Override\n\t\t\tpublic void success(FeaturesBean bean) {\n\t\t\t\tif (swipe != null) {\n\t\t\t\t\tswipe.setRefreshing(false);\n\t\t\t\t\tswipe.setEnabled(true);\n\t\t\t\t}\n\t\t\t\tonSuccess(bean);\n\t\t\t}\n\n\t\t\t@Override\n\t\t\tpublic void defeat(String s) {\n\t\t\t\tswipe.setRefreshing(false);\n\t\t\t\tswipe.setEnabled(true);\n\t\t\t}\n\t\t});\n\n\t\tpresenter.DoGet(UrlUtils.ROUTE_URL + mToken);\n\t}",
"public interface WaterAndSandDetailsView extends BaseView {\n void successData(Map<String, String> data);\n\n}",
"public ViewIdentificator getView() {\r\n return view;\r\n }",
"Object getData();",
"Object getData();",
"public ViewObjectImpl getEventInterviewerDetails1() {\n return (ViewObjectImpl) findViewObject(\"EventInterviewerDetails1\");\n }",
"public interface HomePageView extends BaseView{\n Context getContext();\n\n void getSummary(SummaryBean.Data repest);\n\n void getUserinfo(UserInfoBean.Data userInfo);\n\n}",
"public String getDataInternal() {\n\t\treturn this.appTda_.getPassedInParameters();\n\t}",
"public abstract Object getCustomData();",
"Object getData() { /* package access */\n\t\treturn data;\n\t}",
"public void toViewData(View view) {\n final Controller aController = (Controller) getApplicationContext();\n TextView sportName = (TextView) findViewById(R.id.SportName);\n String name = sportName.getText().toString();\n Log.i(\"EllieNull\", name);\n int sport = aController.getSport(name).getStyle();\n if (sport == 1) {\n Intent intent = new Intent(SportHome.this, ViewData.class);\n intent.putExtra(\"sportName\", sportName.getText());\n startActivity(intent);\n } else if (sport == 2) {\n Intent intent = new Intent(SportHome.this, Timevstime.class);\n intent.putExtra(\"sportName\", sportName.getText());\n startActivity(intent);\n } else if (sport == 3) {\n Intent intent = new Intent(SportHome.this, DistanceGraph.class);\n intent.putExtra(\"sportName\", sportName.getText());\n startActivity(intent);\n } else if (sport == 4) {\n Intent intent = new Intent(SportHome.this, Accuracyvstime.class);\n intent.putExtra(\"sportName\", sportName.getText());\n startActivity(intent);\n } else if (sport == 5) {\n Intent intent = new Intent(SportHome.this, Pointsvstime.class);\n intent.putExtra(\"sportName\", sportName.getText());\n startActivity(intent);\n }\n }",
"public ViewConfiguration invoke() {\n return ViewConfiguration.get(this.f64333a);\n }",
"public interface DataView extends View\n{\n //Returns the status of the response\n //True: successful\n //False: failed\n public boolean getResponseStatus();\n \n //Returns the response message\n public String getResponseMessage();\n \n //Returns the data from the controller\n public Message getResponseData();\n \n //Returns a json representation of the data\n public String getJson();\n \n}",
"@Override\n\tpublic View GetDynamicView() {\n\t\treturn null;\n\t}",
"public String getViewParam() {\r\n\t\treturn viewParam;\r\n\t}",
"public void loadData() {\n if (this.model != null) {\n\n this.dataLayout.setVisibility(View.VISIBLE);\n this.emptyText.setVisibility(View.GONE);\n\n\n if (this.model.getSolution() != null) {\n this.solutionView.setText(this.model.getSolution());\n }\n if (this.model.getArguments() != null) {\n this.argumentsView.setText(this.model.getArguments());\n }\n if (this.model.getQuestion() != null) {\n this.questionView.setText(\n String.valueOf(this.model.getQuestion().getId()));\n }\n } else {\n this.dataLayout.setVisibility(View.GONE);\n this.emptyText.setVisibility(View.VISIBLE);\n }\n }",
"public Object getUserData();",
"ControllerState getViewState();",
"public Object getData() \n {\n return data;\n }",
"protected void findAndCacheViews(View view) {\n\t SpeakerItemViews views = new SpeakerItemViews();\n\t views.headerView = view.findViewById(R.id.header);\n\t views.headerTextView = (TextView) view.findViewById(R.id.header_text);\n\t views.dividerView = view.findViewById(R.id.session_divider);\n\t views.nameView = (TextView) view.findViewById(R.id.speaker_name);\n\t views.companyView = (TextView) view.findViewById(R.id.speaker_company);\n\t views.starButton = (CheckBox) view.findViewById(R.id.star_button);\n\t view.setTag(views);\n\t }",
"public Map<String, Object> getDataModel() {\n return this.dataModel;\n }",
"public View getView() {\n\t\treturn view;\n\t}",
"public Object getData()\r\n\t\t{\r\n\t\t\treturn data;\r\n\t\t}",
"public String getData() {\n\t\treturn this.appTda_.getAssignedData();\n\t}",
"ViewElement getViewElement();",
"public abstract String getView();",
"private void getViews(View view) {\n listView = (com.baoyz.swipemenulistview.SwipeMenuListView)view.findViewById(R.id.detail_listview);\n accept = (Button)view.findViewById(R.id.change_quantity_button);\n totalPriceTextView = (TextView)view.findViewById(R.id.total_price_text_view);\n searchET = (EditText)view.findViewById(R.id.search_edit_text);\n clearTextButton = (Button)view.findViewById(R.id.clear_text_button);\n }",
"protected ScServletData getData()\n {\n return ScServletData.getLocal();\n }",
"protected abstract void populateView(View v, T model);",
"PersistentDataHolder getDataHolder();",
"public JavaScriptObject getData() {\n\t return getDataImpl(getUrl(), getRealHeight(), getRealWidth());\n }",
"private void readViews() {\n mNameString = mNameEditText.getText().toString().trim();\n mQuantityString = Integer.parseInt(mQuantityTextView.getText().toString().trim());\n mPriceString = Double.parseDouble(mPriceEditText.getText().toString().trim());\n mPhoneString = Integer.parseInt(mPhoneEditText.getText().toString().trim());\n }",
"@Override\n protected Map<String, String> getParams() {\n Map<String, String> params = new HashMap<>();\n params.put(\"user_id\", globalClass.getId());\n params.put(\"view\", \"getMyTaskRewardsByUser\");\n\n Log.d(TAG, \"getParams: \"+params);\n return params;\n }",
"public View getView() { return view; }",
"public View getView() {\n return view;\n }",
"@Override\r\n\tpublic View getView() {\n\t\treturn this.view;\r\n\t}",
"public interface IViewGetter<T,V extends View> {\n V createView(Context context);\n void initView(V view, T bean);\n}",
"@Override\n\tpublic HashMap<String, String> getData() {\n\t\treturn dataSourceApi.getData();\n\t}",
"public T getData()\n\t{\n\t\treturn this.data;\n\t}",
"ViewMap<IBranchMapping> getView();",
"private void displayData() {\n ChildStatement childStmt = app.getChildStatement();\n\n //---Child\n childModelViewSynchronizer = new ModelViewSynchronizer<Child>(CHILD_CLASS,\n getChildMetadata(), rootView, AppConstants.EMPTY_STRING);\n childModelViewSynchronizer.setLabels();\n childModelViewSynchronizer.setHeaderTitle(R.id.section_child_particulars,\n R.string.label_child);\n childModelViewSynchronizer.displayDataObject(childStmt.getChildItem().getChild());\n\n //---CDA Trustee\n cdaTrusteeModelViewSynchronizer = new ModelViewSynchronizer<Adult>(ADULT_CLASS,\n getCdaTrusteeMetaData(), rootView, AppConstants.EMPTY_STRING);\n cdaTrusteeModelViewSynchronizer.setLabels();\n cdaTrusteeModelViewSynchronizer.setHeaderTitle(R.id.section_cdat_particulars,\n R.string.label_adult_type_cdat);\n cdaTrusteeModelViewSynchronizer.displayDataObject(childStmt.getChildDevAccountTrustee());\n\n //---Child Development Bank Account\n cdaBankModelViewSynchronizer = new ModelViewSynchronizer<CdaBankAccount>(CDA_BANK_ACCOUNT_CLASS,\n getChildDevAccountMetaData(), rootView, AppConstants.EMPTY_STRING);\n cdaBankModelViewSynchronizer.setLabels();\n cdaBankModelViewSynchronizer.setHeaderTitle(R.id.section_cda_details,\n R.string.label_child_dev_acc_detail);\n cdaBankModelViewSynchronizer.displayDataObject(childStmt.getCdaBankAccount());\n\n //--- To From Date\n displayFromToDates();\n\n //Screen - Title and Instructions\n fragmentContainer.setFragmentTitle(rootView,\n R.string.title_activity_family_view_cda_details);\n fragmentContainer.setInstructions(rootView.findViewById(R.id.screen_instructions),\n CURRENT_POSITION, 0, false);\n }",
"@RequestMapping(value=\"getEvaluateData\",method = RequestMethod.GET)\n @ResponseBody\n public EvaluateData getEvaluateData(){\n EvaluateData evaluateType = evaluateService.getEvaluateType();\n return evaluateType;\n }",
"private View getView() {\n try {\n return (View) this.webView.getClass().getMethod(\"getView\", new Class[0]).invoke(this.webView, new Object[0]);\n } catch (Exception unused) {\n return (View) this.webView;\n }\n }",
"public Object getData() {\r\n\t\t\treturn data;\r\n\t\t}",
"Collection getData();",
"public void getSceneDetails() {\n Intent sceneIntent = getIntent();\n //TODO: set member strings = intent extras\n storyId = sceneIntent.getStringExtra(\"storyId\");\n chapterId = sceneIntent.getStringExtra(\"chapterId\");\n sceneId = sceneIntent.getStringExtra(\"selectedSceneId\");\n\n getAllFormFields();\n\n setSceneFormFields();\n }",
"public Object getData() {\r\n if (data != null) {\r\n return data;\r\n }\r\n ValueBinding vb = getValueBinding(\"data\");\r\n if (vb != null) {\r\n return vb.getValue(getFacesContext());\r\n } else {\r\n \r\n if(!Beans.isDesignTime()){\r\n setChartTitle(getChartTitle() + \" with default data\");\r\n }\r\n return DEFAULT_DATA;\r\n }\r\n }",
"public Map<String, Object> getData() {\n\t\treturn this.data;\n\t}",
"public Object getData() {\n\t\treturn data;\n\t}",
"T getData() {\n return this.data;\n }",
"public abstract VT getItemViewModel(ViewDataBinding viewDataBinding);",
"public T getData(){\n return this.data;\n }",
"public interface InformationView extends BaseView {\n String getPage();\n String getPagecount();\n void getDoctorNoticeList(ResultModel<List<InfoUserNoticeListBean>> model);\n\n String getUserUuid();\n void getInformationList(ResultModel<InformationBean> model);\n\n\n}",
"public ViewObjectImpl getUserDetailsVO() {\n return (ViewObjectImpl)findViewObject(\"UserDetailsVO\");\n }",
"@Override\n\t\tpublic View getInfoContents(Marker marker) {\n\t\t\treturn null;\n\t\t}",
"protected List<View> getItems() {\n return items;\n }",
"public PropertySet getViewProperties() {\r\n return prefs;\r\n }",
"public T getData() {\r\n\t\t\treturn t;\r\n\t\t}",
"@Override\r\n\tpublic View getContentView() {\n\t\treturn contentView;\r\n\t}",
"public T getData() {\r\n return data;\r\n }",
"public LiveData<DataEntry> getData() {\n return data;\n }",
"@Override\r\n\tpublic Meta_data get_Meta_data() {\n\t\treturn projectdata;\r\n\t}",
"public T getData() {\n return this.data;\n }",
"String getViewName() {\n\t\treturn this.viewName;\n\t}",
"public T getViewDataBinding() {\n return mViewDataBinding;\n }",
"com.google.protobuf.ByteString\n getViewBytes();",
"@Override\r\n\tpublic String detail() {\n\t\tSystem.out.println(\"detailView.\");\r\n\t\t//javax.servlet.http.HttpSession session=request.getSession();\r\n\t\t//javax.servlet.ServletContext application=request.getServletContext();\r\n\t\t\r\n\t\t//String vId=request.getParameter(\"id\");\r\n\t\tif(!SysFun.isNullOrEmpty(id)) {\r\n\t\t\tLong iId=SysFun.parseLong(id);\r\n\t\t\tHeadLine bean=headLineService.load(iId);\r\n\t\t\tif(bean!=null) {\r\n\t\t\t\trequest.put(\"bean\", bean);\r\n\t\t\t\treturn \"detail\";\r\n\t\t\t\t\r\n\t\t\t}\r\n\t\t}\r\n\t\treturn \"detail\";\r\n\t}",
"public java.lang.String getView() {\n return view;\n }",
"public java.lang.String getView() {\n return view;\n }",
"public java.lang.String getView() {\n return view;\n }",
"private Views getViews() throws IOException, ProcessingException {\n\t\tJsonReader reader = new JsonReader(new FileReader(viewsFilePath));\n\t\treturn GSON.fromJson(reader, Views.class);\n\t}",
"public ViewObjectImpl getEventInterviewerDetailsVO1() {\n return (ViewObjectImpl) findViewObject(\"EventInterviewerDetailsVO1\");\n }"
]
| [
"0.72120655",
"0.65043473",
"0.62794983",
"0.6074431",
"0.5990717",
"0.59905994",
"0.59795386",
"0.59559864",
"0.58783966",
"0.58681333",
"0.5850952",
"0.5831869",
"0.5784812",
"0.57212967",
"0.57057875",
"0.5689399",
"0.5689399",
"0.5684308",
"0.56833476",
"0.56693757",
"0.5661124",
"0.5652022",
"0.56461406",
"0.56310433",
"0.562436",
"0.5609429",
"0.55951893",
"0.5589819",
"0.5581077",
"0.5578213",
"0.55750847",
"0.55745685",
"0.55745685",
"0.55684793",
"0.5555493",
"0.5535677",
"0.55237865",
"0.552058",
"0.5515391",
"0.5512672",
"0.55042887",
"0.5492638",
"0.5492055",
"0.5481703",
"0.54710233",
"0.5458141",
"0.5453707",
"0.545273",
"0.5447406",
"0.543943",
"0.5434537",
"0.54289293",
"0.54279524",
"0.542591",
"0.54157776",
"0.54136354",
"0.5411839",
"0.540668",
"0.5399506",
"0.5398117",
"0.5397848",
"0.53938264",
"0.53931653",
"0.53912693",
"0.53896904",
"0.53853214",
"0.53800255",
"0.53768814",
"0.53708583",
"0.5369467",
"0.53616804",
"0.53595215",
"0.53540987",
"0.5353833",
"0.53536415",
"0.5352455",
"0.535203",
"0.53474855",
"0.5344069",
"0.53344494",
"0.53312075",
"0.5319393",
"0.53167623",
"0.5316089",
"0.53149694",
"0.53138965",
"0.5313394",
"0.5312112",
"0.5309285",
"0.53066623",
"0.5305344",
"0.53040713",
"0.53039986",
"0.5300946",
"0.52963823",
"0.52912587",
"0.52912587",
"0.52912587",
"0.52826",
"0.52754503"
]
| 0.7991718 | 0 |
Utility method to validate the view content. In case of validation errors, they are displayed. | protected boolean validateView() {
ValidationReport report = new ValidationReport();
view.validate(report);
// Displays the validation report result
view.display(report);
// Result
return report.isOk();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\n public View checkContentValidation() {\n return null;\n }",
"@Override\n public View checkContentValidation() {\n return null;\n }",
"@Override\n\tpublic boolean validateContent()\n\t{\n\t\treturn true;\n\t}",
"public interface IValidatingView {\r\n\r\n\t/**\r\n\t * Sets the validator to the view\r\n\t * \r\n\t * @param validator\r\n\t * - validator to be set\r\n\t * @param fieldDisplayName\r\n\t * - a name of the field to be displayed in the error message\r\n\t */\r\n\tpublic void setValidator(IViewValidator validator, String fieldDisplayName);\r\n\r\n\t/**\r\n\t * Checks whether the value of the view is valid or not\r\n\t * \r\n\t * @return <b>true</b> - valid, <b>false</b> - not valid\r\n\t */\r\n\tpublic boolean isValid();\r\n\r\n\t/**\r\n\t * Shows a validation error sign if the view is not valid\r\n\t */\r\n\tpublic void flagOrUnflagValidationError(boolean validationMode);\r\n\r\n}",
"public boolean validate() {\n boolean validate = true;\n String titleStr = etTitle.getText().toString();\n String contentStr = etContent.getText().toString();\n if (titleStr.isEmpty() || titleStr.matches(\"\")) {\n etTitle.setError(\"Please Fill Title\");\n validate = false;\n }\n if (contentStr.isEmpty() || contentStr.matches(\"\")) {\n etContent.setError(\"Please Fill Content\");\n validate = false;\n }\n\n return validate;\n }",
"boolean isValid(View view);",
"private void validatePage() {\n String error = null;\n String warning = null;\n\n // -- validate project\n if (getProject() == null) {\n error = \"Please select an Android project.\";\n }\n\n // -- validate filename\n if (error == null) {\n String fileName = getFileName();\n if (fileName == null || fileName.length() == 0) {\n error = \"A destination file name is required.\";\n } else if (!fileName.endsWith(AndroidConstants.DOT_XML)) {\n error = String.format(\"The filename must end with %1$s.\", AndroidConstants.DOT_XML);\n }\n }\n\n // -- validate type\n if (error == null) {\n TypeInfo type = getSelectedType();\n\n if (type == null) {\n error = \"One of the types must be selected (e.g. layout, values, etc.)\";\n }\n }\n\n // -- validate type API level\n if (error == null) {\n IAndroidTarget target = Sdk.getCurrent().getTarget(mProject);\n int currentApiLevel = 1;\n if (target != null) {\n currentApiLevel = target.getVersion().getApiLevel();\n }\n\n TypeInfo type = getSelectedType();\n\n if (type.getTargetApiLevel() > currentApiLevel) {\n error = \"The API level of the selected type (e.g. AppWidget, etc.) is not \" +\n \"compatible with the API level of the project.\";\n }\n }\n\n // -- validate folder configuration\n if (error == null) {\n ConfigurationState state = mConfigSelector.getState();\n if (state == ConfigurationState.INVALID_CONFIG) {\n ResourceQualifier qual = mConfigSelector.getInvalidQualifier();\n if (qual != null) {\n error = String.format(\"The qualifier '%1$s' is invalid in the folder configuration.\",\n qual.getName());\n }\n } else if (state == ConfigurationState.REGION_WITHOUT_LANGUAGE) {\n error = \"The Region qualifier requires the Language qualifier.\";\n }\n }\n\n // -- validate generated path\n if (error == null) {\n String wsFolderPath = getWsFolderPath();\n if (!wsFolderPath.startsWith(RES_FOLDER_ABS)) {\n error = String.format(\"Target folder must start with %1$s.\", RES_FOLDER_ABS);\n }\n }\n\n // -- validate destination file doesn't exist\n if (error == null) {\n IFile file = getDestinationFile();\n if (file != null && file.exists()) {\n warning = \"The destination file already exists\";\n }\n }\n\n // -- update UI & enable finish if there's no error\n setPageComplete(error == null);\n if (error != null) {\n setMessage(error, WizardPage.ERROR);\n } else if (warning != null) {\n setMessage(warning, WizardPage.WARNING);\n } else {\n setErrorMessage(null);\n setMessage(null);\n }\n }",
"public void checkComponent() {\r\n Component component = ViewToEntityConverter.view2Model(view);\r\n validate(component);\r\n }",
"private void displayValidationError() {\n\n\t\tif (null != validationErrorTitle) {\n\t\t\tvalidationErrorParent.toFront();\n\t\t\tAppController.showMessage(validationErrorParent, validationErrorMessage, validationErrorTitle,\n\t\t\t\tvalidationErrorType);\n\t\t}\n\n\t\tclearValidationError();\n\t}",
"private void check_displaysError() {\n onView(withId(R.id.title))\n .check(matches(withText(R.string.input_title_error)));\n onView(withId(R.id.subtitle))\n .check(matches(withText(R.string.input_subtitle_error)));\n\n // And the button to be labeled try again\n onView(withId(R.id.hint))\n .check(matches(isDisplayed()))\n .check(matches(withText(R.string.input_hint_error)));\n }",
"private boolean validate() {\n if (activityAddTodoBinding.etTitle.getText().toString().trim().isEmpty())\n {\n activityAddTodoBinding.etTitle.setError(getString(R.string.enter_title));\n return false;\n }\n else if (activityAddTodoBinding.etDesc.getText().toString().trim().isEmpty())\n {\n activityAddTodoBinding.etDesc.setError(getString(R.string.enter_desc));\n return false;\n }\n return true;\n }",
"private boolean Validate() {\n EditText titleText = findViewById(R.id.register_movie_title_txt);\n EditText yearText = findViewById(R.id.register_movie_year_txt);\n EditText ratingText = findViewById(R.id.register_movie_rating_txt);\n\n\n boolean is_filled_required_fields = false;\n is_filled_required_fields = titleText.getText().toString().length() > 0\n && yearText.getText().toString().length() > 0\n && ratingText.getText().toString().length() > 0;\n\n if (!is_filled_required_fields) {\n Snackbar mySnackbar = Snackbar.make(findViewById(R.id.activity_register_base_layout), \"Please fill required fields\", BaseTransientBottomBar.LENGTH_SHORT);\n mySnackbar.show();\n }\n return is_filled_required_fields;\n }",
"@Override\r\n\tpublic void validate() {\n\t\t\r\n\t}",
"@Override\r\n\tprotected void validate() {\n\t}",
"private boolean validateUserInputs() {\n ArrayList<String> errors = new ArrayList();\n \n if (this.view.getContent().equals(\"\")) {\n errors.add(\"\\t - Enter a comment\");\n }\n \n if (errors.size() > 0) {\n String errorMsg = \"Unable to save new Asset.\\nDetails:\";\n for (String error : errors) {\n errorMsg += \"\\n\" + error;\n }\n JOptionPane.showMessageDialog(this.view, errorMsg, \"Unable to Save\", JOptionPane.INFORMATION_MESSAGE);\n return false;\n }\n return true;\n }",
"@Override\n public boolean validate() throws SmogException {\n\n // List of validation messages\n ArrayList<XmlError> validationMessages = new ArrayList<>();\n\n // Validate the missive document\n boolean isValid = this.missiveDocument.validate(new XmlOptions().setErrorListener(validationMessages));\n\n // Check if the missive document is valid\n if (isValid) {\n return true;\n } else {\n\n // Validation message\n String validationMessage = \"\";\n\n // Iterator for validation messages\n Iterator<XmlError> iterator = validationMessages.iterator();\n\n // Build the complete error message\n while(iterator.hasNext()) {\n\n // Add validation message separtor\n if (!validationMessage.equals(\"\")) {\n validationMessage += \"\\n\";\n }\n\n // Concatenate validation messages\n validationMessage += iterator.next().getMessage();\n }\n\n throw new SmogException(validationMessage);\n }\n }",
"ValidationResponse validate();",
"@Override\n\tpublic void validate()\n\t{\n\n\t}",
"@Override\r\n public void validate() {\r\n }",
"@Override\n\tpublic void validate() {\n\t}",
"@Override\n\tpublic void validate() {\n\t\tsuper.validate();\n\t}",
"public void validate() {}",
"public boolean validate() {\n return true;\n }",
"public boolean validate() {\n return true;\n }",
"@Override\r\n public boolean validate() {\n return true;\r\n }",
"@After\n public static void renderValidationErrors() {\n if (validation.hasErrors()) {\n response.status = 400;\n Map<String, String> errorsMap = new HashMap();\n for (Error error : validation.errors()) {\n errorsMap.put(error.getKey(), Messages.get(error.message()));\n }\n renderJSON(errorsMap);\n }\n }",
"private void validate() {\n\n etCardNumber.validate();\n\n etCardExpiryDate.validate();\n\n etCardCvv.validate();\n\n etCardHolderName.validate();\n\n etPhoneNumber.validate();\n\n etCustomerName.validate();\n }",
"private boolean validateData() {\n if (!mCommon.validateData()) return false;\n\n Core core = new Core(this);\n\n // Due Date is required\n if (TextUtils.isEmpty(getRecurringTransaction().getDueDateString())) {\n core.alert(R.string.due_date_required);\n return false;\n }\n\n if (TextUtils.isEmpty(mCommon.viewHolder.dateTextView.getText().toString())) {\n core.alert(R.string.error_next_occurrence_not_populate);\n\n return false;\n }\n\n // Payments Left must have a value\n if (getRecurringTransaction().getPaymentsLeft() == null) {\n core.alert(R.string.payments_left_required);\n return false;\n }\n return true;\n }",
"protected void validate() {\n // no op\n }",
"@Override\r\n\tpublic boolean validate() {\n\t\treturn true;\r\n\t}",
"@Override\r\n\tpublic boolean validate() {\n\t\treturn true;\r\n\t}",
"@Override\n\tpublic void validation() throws EditorException\n\t{\n\t}",
"@Override\n\tprotected void validate(Controller c) {\n\n\t}",
"public boolean validateModel(){\r\n System.out.println(\"Validated!\");\r\n return true;\r\n }",
"@Override\n protected void postValidate() throws Exception\n {\n final HtmlPage page = getHtmlPage();\n\n // Basic checks - see action 'Homepage' for some more details how and when to use these validators.\n HttpResponseCodeValidator.getInstance().validate(page);\n ContentLengthValidator.getInstance().validate(page);\n HtmlEndTagValidator.getInstance().validate(page);\n\n HeaderValidator.getInstance().validate(page);\n\n // Check that it's the cart overview page.\n Assert.assertTrue(\"Title not found\", HtmlPageUtils.isElementPresent(page, \"id('titleCart')\"));\n Assert.assertTrue(\"Total price not found\", HtmlPageUtils.isElementPresent(page, \"id('orderSubTotalValue')\"));\n Assert.assertTrue(\"Checkout button not found\", HtmlPageUtils.isElementPresent(page, \"id('btnStartCheckout')\"));\n }",
"@Then(\"^validation error message should be displayed$\")\n public void verifyThatValidationErrorMessageIsDiplayed() {\n assertion.assertTrue(StoryBoard.validationError());\n }",
"@Override\r\n \t\tprotected boolean validatePage() {\r\n \t\t\tif (super.validatePage()) {\r\n \t\t\t\tString extension = new Path(getFileName()).getFileExtension();\r\n \t\t\t\tif (extension == null || !FILE_EXTENSIONS.contains(extension)) {\r\n \t\t\t\t\tString key = FILE_EXTENSIONS.size() > 1 ? \"_WARN_FilenameExtensions\" : \"_WARN_FilenameExtension\";\r\n \t\t\t\t\tsetErrorMessage(Reqif10EditorPlugin.INSTANCE.getString(key, new Object [] { FORMATTED_FILE_EXTENSIONS }));\r\n \t\t\t\t\treturn false;\r\n \t\t\t\t}\r\n \t\t\t\treturn true;\r\n \t\t\t}\r\n \t\t\treturn false;\r\n \t\t}",
"private void validation() {\n this.validate();\n this.repaint();\n }",
"private boolean formValidated() {\n boolean flag = true;\n name_error.setVisibility(View.GONE);\n family_error.setVisibility(View.GONE);\n address_region_error.setVisibility(View.GONE);\n address_city_error.setVisibility(View.GONE);\n address_error.setVisibility(View.GONE);\n gender_error.setVisibility(View.GONE);\n cellphone_error.setVisibility(View.GONE);\n address_postal_code_error.setVisibility(View.GONE);\n if (address_spinner.getSelectedItem() == null || address_spinner.getSelectedItem().equals(getString(R.string.address_province_placeholder))) {\n address_region_error.setVisibility(View.VISIBLE);\n address_region_error.setText(R.string.error_isrequired);\n flag = false;\n }\n if (city_spinner.getVisibility() == View.VISIBLE && (city_spinner.getSelectedItem() == null || city_spinner.getSelectedItem().equals(getString(R.string.address_city_placeholder)))) {\n address_city_error.setVisibility(View.VISIBLE);\n address_city_error.setText(R.string.error_isrequired);\n flag = false;\n }\n if (postal_spinner.getVisibility() == View.VISIBLE && (postal_spinner.getSelectedItem() == null || postal_spinner.getSelectedItem().equals(getString(R.string.delivery_neighbourhood)))) {\n address_postal_region_error.setVisibility(View.VISIBLE);\n address_postal_region_error.setText(R.string.error_isrequired);\n flag = true;\n }\n if (BamiloApplication.CUSTOMER.getGender().isEmpty()) {\n if (gender_spinner.getSelectedItem() == null || gender_spinner.getSelectedItem().equals(getString(R.string.gender))) {\n gender_error.setVisibility(View.VISIBLE);\n gender_error.setText(R.string.error_isrequired);\n flag = false;\n }\n }\n if (name.getText().length() >= 0) {\n /* */\n if (name.getText().length() < 2) {\n name_error.setVisibility(View.VISIBLE);\n name_error.setText(R.string.error_isrequired);\n flag = false;\n }\n\n }\n if (family.getText().length() >= 0) {\n /* */\n if (family.getText().length() < 2) {\n family_error.setVisibility(View.VISIBLE);\n family_error.setText(R.string.error_isrequired);\n flag = false;\n }\n\n }\n if (address.getText().length() >= 0) {\n /* */\n if (address.getText().length() < 2) {\n address_error.setVisibility(View.VISIBLE);\n address_error.setText(R.string.error_isrequired);\n flag = false;\n }\n\n }\n Pattern pattern = Pattern.compile(getString(R.string.cellphone_regex), Pattern.CASE_INSENSITIVE);\n\n Matcher matcher = pattern.matcher(cellphone.getText());\n boolean result = matcher.matches();\n if (!result) {\n cellphone.setVisibility(View.VISIBLE);\n cellphone_error.setVisibility(View.VISIBLE);\n cellphone_error.setText(R.string.address_phone_number_invalidity_error);\n flag = false;\n }\n if (cellphone.getText().length() == 0) {\n cellphone.setVisibility(View.VISIBLE);\n cellphone_error.setVisibility(View.VISIBLE);\n cellphone_error.setText(R.string.error_isrequired);\n flag = false;\n }\n\n\n if (postal_code.getText().length() != 0 && postal_code.getText().length() != 10) {\n address_postal_code_error.setVisibility(View.VISIBLE);\n flag = false;\n }\n\n if (gender_lable.length() == 0) {\n gender_error.setVisibility(View.VISIBLE);\n flag = false;\n }\n return flag;\n }",
"public Resolution handleValidationErrors(ValidationErrors errors) throws Exception\n {\n setDisplayForm(true);\n return context.getSourcePageResolution();\n }",
"public boolean validation(){\n String Venuename= venuename.getText().toString();\n String Address= address.getText().toString();\n String Details= details.getText().toString();\n String Venueimage= venueimage.getText().toString();\n if(Venuename.isEmpty()){\n venuename.setError(\"Please enter the item name\");\n venuename.requestFocus();\n return false;\n }\n if(Address.isEmpty()){\n address.setError(\"Please enter the item name\");\n address.requestFocus();\n return false;\n }\n if(Details.isEmpty()){\n details.setError(\"Please enter the item name\");\n details.requestFocus();\n return false;\n }\n if(Venueimage.isEmpty()){\n venueimage.setError(\"Please Select the image first\");\n return false;\n }\n\n\n return true;\n }",
"private void showErrorView() {\n Log.d(\"lodd\", \"showSuccessView: hjfj91919515\");\n\n }",
"@Override\r\n\tpublic void Validate() {\n\r\n\t}",
"public void onValidateState() {\n // Case first time\n if (mNewslettersForm == null) {\n triggerGetNewslettersForm();\n }\n // Case rotate restore the form\n else if(mNewsletterScroll.getChildCount() == 0){\n showDynamicForm(mNewslettersForm);\n }\n // Default, show current form\n else {\n showFragmentContentContainer();\n }\n }",
"private void displayValidity() {\n if (allValid) spnValid.setText(\"All fields are valid!\");\n else spnValid.setText(\"There are invalid fields. Please go back and check these.\");\n }",
"protected void validate() {\n // no implementation.\n }",
"public static void validation() {\n\t\tif ((!textFieldName.getText().isEmpty()) && (!textField_FirstName.getText().isEmpty())\n\t\t\t\t&& (!textField_Town.getText().isEmpty()) && (!textField_Town.getText().isEmpty())) {\n\n\t\t\tif ((isValidEmailAddress(textField_Email.getText()) == true)) {\n\t\t\t\ttextField_Email.setBackground(Color.white);\n\t\t\t\tif ((force(textField_Mtp.getText()) > 82)) {\n\t\t\t\t\ttextField_Mtp.setBackground(Color.white);\n\t\t\t\t\tactionGiveServeur();\n\n\t\t\t\t} else {\n\t\t\t\t\tshowMessageDialog(null, \"Votre mot de passe est trop faible\");\n\t\t\t\t\ttextField_Mtp.setText(\"Mot de passe trop simple : changer le \");\n\t\t\t\t\ttextField_Mtp.setBackground(Color.RED);\n\t\t\t\t}\n\t\t\t} else {\n\t\t\t\ttextField_Email.setText(\"Email invalide\");\n\t\t\t\ttextField_Email.setBackground(Color.RED);\n\t\t\t\tshowMessageDialog(null, \"Email est invalide\");\n\t\t\t}\n\t\t} else {\n\n\t\t\tshowMessageDialog(null, \"Certain champs sont vide !\");\n\t\t}\n\t}",
"private boolean validate(){\n return EditorUtils.editTextValidator(generalnformation,etGeneralnformation,\"Type in information\") &&\n EditorUtils.editTextValidator(symptoms,etSymptoms, \"Type in symptoms\") &&\n EditorUtils.editTextValidator(management,etManagement, \"Type in management\");\n }",
"public boolean validate(){\n return true;\n }",
"private void showErrorMessage() {\n // hide the view for the list of movies\n mMoviesRecyclerView.setVisibility(View.INVISIBLE);\n // show the error message\n mErrorMessageDisplay.setVisibility(View.VISIBLE);\n }",
"void validate();",
"void validate();",
"public boolean canDisplay(){\n if(title.isEmpty() && body.isEmpty()){\n return false;\n }\n\n return true;\n }",
"@Test(groups ={Slingshot,Regression})\n\tpublic void EditViewLessthan15AcctsErrorValidation() {\n\t\tReport.createTestLogHeader(\"MuMv\", \"Verify whether proper error message is displayed in view when continuing with out enabling the accounts check box\");\n\n\t\tUserProfile userProfile = new TestDataHelper().getUserProfile(\"MuMvManageView\");\n\t\tnew LoginAction()\n\t\t.BgbnavigateToLogin()\n\t\t.BgbloginDetails(userProfile);\n\t\tnew MultiUserMultiViewAction()\n\t\t\t.clicktestacct();\n\t\t/*.ClickManageUserLink()\n\t\t.ManageViews()\n\t\t.VerifyEditviewname(userProfile)\n\t\t.EditViewNameErrorValidation(userProfile); \t \t\t\t\t\t\t \t \t\t\n\t}*/\n\t}",
"protected void validateInput()\r\n\t{\r\n\t\tString errorMessage = null;\r\n\t\tif ( validator != null ) {\r\n\t\t\terrorMessage = validator.isValid(text.getText());\r\n\t\t}\r\n\t\t// Bug 16256: important not to treat \"\" (blank error) the same as null\r\n\t\t// (no error)\r\n\t\tsetErrorMessage(errorMessage);\r\n\t}",
"public static void validate() {\r\n\t\tfrmMfhEmailer.validate();\r\n\t}",
"private boolean validateInputs() {\n if (Constants.NULL.equals(review)) {\n reviewET.setError(\"Must type a review!\");\n reviewET.requestFocus();\n return false;\n }\n if (Constants.NULL.equals(heading)) {\n headingET.setError(\"Heading cannot be empty\");\n headingET.requestFocus();\n return false;\n }\n return true;\n }",
"protected String validateContents (Component component, Object o) \r\n { \r\n if (advancedBox.isSelected())\r\n {\r\n if (getWizardData(\"blacksaved\") == \"false\")\r\n {\r\n return \"You must save the black list before continuing... \";\r\n }\r\n }\r\n return null;\r\n }",
"@Override\n\tpublic void validate() {\n\t\tFormFieldValidator.validateStudent(this, student);\n\t\tFormFieldValidator.validateCourseList(this, courseID);\n\t}",
"@Override\n public void validateModel() {\n }",
"@Test(priority = 5)\n\tpublic void validateContents() {\n\t\tlog = Logger.getLogger(HeroImageProducttestscripts.class);\n\t\tLogReport.getlogger();\n\t\tlogger = extent.startTest(\"Validating the content of the product\");\n\t\tHeroImageProductPageFlow.clickHeroImage(locator);\n\t\theroImg.validateDescriptionContent(locator, validate);\n\t\t;\n\t\tlog.info(\"Content validation is correct\");\n\t\tHeroImageProductPageFlow.clickProductSpecification(locator);\n\t\theroImg.validateSpecificationContent(locator, validate);\n\t\tlog.info(\"Content is present\");\n\t\tlog.info(\"Starting Sorting functionality testing\");\n\t}",
"private boolean validate() {\n if (category.equals(\"n/a\")) {\n AppUtils.displayToast(mContext, \"Please select category!!!\");\n return false;\n } else if (category.equals(AppUtils.CREATE_CATEGORY) && mCustomCategory.getText().toString().length() == 0) {\n AppUtils.displayToast(mContext, \"Please enter custom category name!!!\");\n return false;\n } else if (mTaskTile.getText().toString().length() == 0) {\n AppUtils.displayToast(mContext, \"Please enter task Title!!!\");\n return false;\n } else if (dueDate == 0) {\n AppUtils.displayToast(mContext, \"Please enter due date!!\");\n return false;\n } else if (mTaskContent.getText().toString().length() == 0) {\n AppUtils.displayToast(mContext, \"Please enter task content!!!\");\n return false;\n } else\n return true;\n\n\n }",
"private void validateData() {\n }",
"private boolean checkValidations() {\n if (TextUtils.isEmpty(etFirstName.getText().toString().trim())) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.empty_name_war));\n return false;\n } else if (etPhoneNo.getText().length() > 0 && etPhoneNo.getText().toString().trim().length() < 7) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.valid_mo_no_war));\n return false;\n }\n /*else if (TextUtils.isEmpty(etAdress.getText().toString().trim())) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.empty_address_war));\n return false;\n } else if (countryId==null || countryId.equals(\"\")) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.country_war));\n return false;\n } else if (stateId==null || stateId.equals(\"\")) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.state_war));\n return false;\n }*/ /*else if (cityId==null || cityId.equals(\"\")) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.city_war));\n return false;\n }*/\n else\n return true;\n }",
"private boolean checkEditContent()\n {\n if (etUrl.hasContent() && etFilePath.hasContent())\n {\n return true;\n }\n return false;\n }",
"@Test\n public void shouldBeAValidCustomerView() {\n Assert.assertTrue(customerService.isValid(view));\n }",
"interface View {\n\n void displayError(String error);\n\n String getBarcode();\n \n String getDescription();\n \n BigDecimal getPrice();\n \n \n }",
"private void displayTextView() {\n wellnessEntryErrorTextView.setText(\"This is an error message e.g no data\");\n wellnessEntryErrorTextView.setVisibility(View.VISIBLE);\n recyclerView.setVisibility(View.GONE);\n }",
"private boolean validateForm() {\n\n String email = mEditTextViewEmail.getText().toString();\n if (TextUtils.isEmpty(email)) {\n mTextInputLayoutEmail.setError(\"Emaill Id Required\");\n Toast.makeText(MainActivity.this, \"Email field required\", Toast.LENGTH_SHORT).show();\n return false;\n } else if (!isEmailValid(email)) {\n mTextInputLayoutEmail.setError(\"A valid Email id is required\");\n return false;\n } else {\n mTextInputLayoutEmail.setError(null);\n }\n\n String password = mEditTextViewPassword.getText().toString();\n if (TextUtils.isEmpty(password)) {\n mTextInputLayoutPassword.setError(\"Password required\");\n Toast.makeText(MainActivity.this, \"Password field required\", Toast.LENGTH_SHORT).show();\n return false;\n } else if (!isPasswordValid(password)) {\n mTextInputLayoutPassword.setError(\"Password must be at least 6 characters\");\n return false;\n } else {\n mTextInputLayoutPassword.setError(null);\n }\n\n return true;\n }",
"@Override\n public void validate() {\n boolean b = false;\n\n //retrieving the contact us form details from request object\n String firstName = objContactUsForm.getName().trim();\n String email = objContactUsForm.getEmail().trim();\n String message = objContactUsForm.getMessage().trim();\n\n //now validating each of the field\n if (firstName.isEmpty()) {\n addFieldError(\"name\", getText(\"name.required\"));\n b = true;\n }\n\n if (email.isEmpty()) {\n addFieldError(\"email\", getText(\"email.required\"));\n b = true;\n }\n if (!b) {\n Pattern p = Pattern.compile(\".+@.+\\\\.[a-z]+\");\n Matcher m = p.matcher(email);\n boolean matchFound = m.matches();\n if (!matchFound) {\n addFieldError(\"email\", \"Please Provide Valid Email ID\");\n }\n }\n\n if (message.isEmpty()) {\n addFieldError(\"message\", getText(\"message.required\"));\n b = true;\n }\n\n if (!b) {\n boolean matches = message.matches(\"[<>!~@$%^&\\\"|!\\\\[#$]\");\n if (matches) {\n addFieldError(\"message\", \"Please Provide Valid Message Name\");\n b = true;\n }\n }\n }",
"private void showErrorMessage() {\n /* First, hide the currently visible data */\n mRecyclerView.setVisibility(View.INVISIBLE);\n /* Then, show the error */\n mErrorMessageDisplay.setVisibility(View.VISIBLE);\n mLayout.setVisibility(View.INVISIBLE);\n }",
"@Override\n protected Result validate() {\n return successful(this);\n }",
"protected boolean validatePage(PDPage page, DocumentHandler handler,\n List<ValidationError> result) throws ValidationException {\n boolean isValid = validateActions(page, handler, result);\n isValid = isValid && validateAnnotation(page, handler, result);\n isValid = isValid && validateTransparency(page, handler, result);\n isValid = isValid && validateContent(page, handler, result);\n isValid = isValid && validateShadingPattern(page, handler, result);\n return isValid;\n }",
"private boolean validatorForm() {\n\t\tboolean validazione = true;\n\t\tif (!Validator.validaDataInizio(viewInserimento.getTxtFieldDataI().getText())) {\n\t\t\tviewInserimento.getTxtFieldDataI().setBackground(Color.red);\n\t\t\tvalidazione = false;\n\t\t} else {\n\t\t\tif (viewInserimento.getTxtFieldDataI().getBackground() == Color.red)\n\t\t\t\tviewInserimento.getTxtFieldDataI().setBackground(Color.white);\n\t\t}\n\t\tif (!Validator.validaImporto(viewInserimento.getTxtFieldValore().getText())) {\n\t\t\tviewInserimento.getTxtFieldValore().setBackground(Color.red);\n\t\t\tvalidazione = false;\n\t\t} else {\n\t\t\tif (viewInserimento.getTxtFieldValore().getBackground() == Color.red)\n\t\t\t\tviewInserimento.getTxtFieldValore().setBackground(Color.white);\n\t\t}\n\n\t\tif (!viewInserimento.getTxtFieldDataI().getText().equals(\"\")\n\t\t\t\t&& !viewInserimento.getTxtFieldDataIPre().getText().equals(\"\")) {\n\t\t\tif (!Date.valueOf(viewInserimento.getTxtFieldDataIPre().getText()).before(Date.valueOf(viewInserimento.getTxtFieldDataI().getText() + \"-01\"))\n\t\t\t\t\t) {\n\t\t\t\tviewInserimento.getTxtFieldDataI().setBackground(Color.red);\n\t\t\t\tvalidazione = false;\n\t\t\t} else {\n\t\t\t\tif (viewInserimento.getTxtFieldDataI().getBackground() == Color.red)\n\t\t\t\t\tviewInserimento.getTxtFieldDataI().setBackground(Color.white);\n\t\t\t}\n\t\t}\n\t\treturn validazione;\n\t}",
"@Override\n\t@FXML\n\tpublic boolean validate() {\n\t\t\n\t\tboolean isDataEntered = true;\n\t\tLocalDate startDate = Database.getInstance().getStartingDate();\n\t\tSystem.out.println();\n\t\tif(amountField.getText() == null || amountField.getText().trim().isEmpty())\n\t\t\tisDataEntered = setErrorTxt(\"You left the amount field empty.\");\n\t\telse if(!(Validation.validateAmount(amountField.getText())))\n\t\t\tisDataEntered = setErrorTxt(\"Please enter a valid amount\");\n\t\telse if(creditTextField.getText() == null || creditTextField.getText().trim().isEmpty())\n\t\t\tisDataEntered = setErrorTxt(\"You left the credit text field empty.\");\n\t\telse if(!(Validation.validateChars(creditTextField.getText())))\n\t\t\tisDataEntered = setErrorTxt(\"Please only enter valid characters\");\n\t\telse if(dateField.getValue() == null) {\n\t\t\tisDataEntered = setErrorTxt(\"You left the date field empty.\");\t\t\t\n\t\t}\n\t\telse if(dateField.getValue().isBefore(startDate))\n\t\t\tisDataEntered = setErrorTxt(\"Sorry, the date you entered is before the starting date.\");\n\t\treturn isDataEntered;\n\t}",
"public boolean canEdit() {\r\n\t\treturn !dslView.isContainsErrors();\r\n\t}",
"@Override\r\n public void validate() {\n\r\n }",
"private boolean isValidate() {\n name = edt_name.getText().toString();\n phone = edt_phone.getText().toString();\n landMark = edt_landmark.getText().toString();\n address = edt_address.getText().toString();\n city = edt_city.getText().toString();\n state = edt_state.getText().toString();\n if (name.length() == 0) {\n edt_name.setError(\"Please Enter Name \");\n requestFocus(edt_name);\n return false;\n } else if (phone.isEmpty()) {\n edt_phone.setError(\"Please Enter Phone Number \");\n requestFocus(edt_phone);\n return false;\n } else if (phone.length() != 10) {\n edt_phone.setError(\"Please Enter Valid Phone Number \");\n requestFocus(edt_phone);\n return false;\n } else if (address.length() == 0) {\n edt_address.setError(\"Please Enter Address\");\n requestFocus(edt_address);\n return false;\n } else if (city.length() == 0) {\n edt_city.setError(\"Please Enter City Name\");\n requestFocus(edt_city);\n return false;\n } else if (state.length() == 0) {\n edt_state.setError(\"Please Enter State Name\");\n requestFocus(edt_state);\n return false;\n }\n return true;\n }",
"public boolean validate() {\n String sDayCheck = sDayView.getText().toString();\n String eDayCheck = eDayView.getText().toString();\n String sTimeCheck = sTimeView.getText().toString();\n String eTimeCheck = eTimeView.getText().toString();\n\n if ((titleView.getText().toString().matches(\"\")) || (roomView.getText().toString().matches(\"\"))) {\n Toast.makeText(getApplicationContext(),\"Please fill in all fields.\",Toast.LENGTH_SHORT).show();\n return false;\n }\n\n if ((sDayCheck.length() != 10) ||\n (eDayCheck.length() != 10) ||\n (sTimeCheck.length() != 5) ||\n (eTimeCheck.length() != 5)) {\n Toast.makeText(getApplicationContext(),\"Please check your Date and Time fields.\",Toast.LENGTH_SHORT).show();\n return false;\n } else if ((sDayCheck.charAt(2) != '/') || (sDayCheck.charAt(5) != '/') ||\n (eDayCheck.charAt(2) != '/') || (eDayCheck.charAt(5) != '/')) {\n Toast.makeText(getApplicationContext(), \"Please check your Date fields.\", Toast.LENGTH_SHORT).show();\n return false;\n } else if ((sTimeCheck.charAt(2) != ':') || (eTimeCheck.charAt(2) != ':')) {\n Toast.makeText(getApplicationContext(), \"Please check your Time fields.\", Toast.LENGTH_SHORT).show();\n return false;\n }\n if (!endDateAfter(sDayCheck, eDayCheck)) {\n Toast.makeText(getApplicationContext(), \"End date must be on or after the Start date.\", Toast.LENGTH_SHORT).show();\n return false;\n }\n if (!endTimeAfter(sTimeCheck, eTimeCheck)) {\n Toast.makeText(getApplicationContext(), \"End time must be on or after the Start time.\", Toast.LENGTH_SHORT).show();\n return false;\n }\n if (isOutOfDate(eDayCheck)) {\n Toast.makeText(getApplicationContext(), \"End date must be on or after Today's Date.\", Toast.LENGTH_SHORT).show();\n return false;\n }\n return true;\n }",
"public abstract boolean validate();",
"private void showErrorMessage() {\n gridview.setVisibility(View.INVISIBLE);\n // Then, show the error\n errorTextView.setVisibility(View.VISIBLE);\n }",
"public ViewObjectImpl getDcmValidationView() {\r\n return (ViewObjectImpl)findViewObject(\"DcmValidationView\");\r\n }",
"public void validation() {\n ValidationData();\n if (Validation == null) {\n Toast.makeText(this, \"No Data Found\", Toast.LENGTH_SHORT).show();\n } else {\n getHistory();\n }\n }",
"public void validate()\n throws org.exolab.castor.xml.ValidationException {\n org.exolab.castor.xml.Validator validator = new org.exolab.castor.xml.Validator();\n validator.validate(this);\n }",
"public boolean validate() throws edu.mit.coeus.exception.CoeusUIException \r\n {\r\n return false;\r\n }",
"public boolean validations() {\n boolean result = false;\n String nameString = mItemNameEditText.getText().toString().trim();\n String locationString = mItemLocationEditText.getText().toString().trim();\n\n if (nameString.isEmpty() || nameString == null || locationString.isEmpty() || locationString == null || isImageNotPresent()) {\n displayToastMessage(getString(R.string.fields_mandatory_msg));\n return result;\n } else {\n result = true;\n return result;\n }\n }",
"public boolean validateInputFields(){\n if(titleText.getText().isEmpty() || descriptionText.getText().isEmpty()){\n showError(true, \"All fields are required. Please complete.\");\n return false;\n }\n if(locationCombo.getSelectionModel().isEmpty()){\n showError(true, \"Please select a location.\");\n return false;\n }\n if(contactCombo.getSelectionModel().isEmpty()){\n showError(true, \"Please select a contact.\");\n return false;\n }\n if(typeCombo.getSelectionModel().isEmpty()){\n showError(true, \"Please select the type.\");\n return false;\n }\n if(customerCombo.getSelectionModel().isEmpty()){\n showError(true, \"Please select a customer.\");\n return false;\n }\n if(userCombo.getSelectionModel().isEmpty()){\n showError(true, \"Please select a user.\");\n return false;\n }\n return true;\n }",
"public abstract void validate () throws ModelValidationException;",
"public void validate()\n throws org.exolab.castor.xml.ValidationException\n {\n org.exolab.castor.xml.Validator validator = new org.exolab.castor.xml.Validator();\n validator.validate(this);\n }",
"public void validate()\n throws org.exolab.castor.xml.ValidationException\n {\n org.exolab.castor.xml.Validator validator = new org.exolab.castor.xml.Validator();\n validator.validate(this);\n }",
"public boolean validatePageElements() {\n boolean nameCheck = name.isDisplayed() && name.isEnabled();\n boolean emailCheck = email.isDisplayed() && email.isEnabled();\n boolean passwordCheck = password.isDisplayed() && password.isEnabled();\n boolean signupGoogleCheck = signupGoogle.isDisplayed() && signupGoogle.isEnabled();\n boolean signupSlackCheck = signupSlack.isDisplayed() && signupSlack.isEnabled();\n boolean signupOutlookCheck = signupOutlook.isDisplayed() && signupOutlook.isEnabled();\n boolean signupAppleCheck = signupApple.isDisplayed() && signupApple.isEnabled();\n boolean signupFacebookCheck = signupFacebook.isDisplayed() && signupFacebook.isEnabled();\n boolean logoCheck = miroLogo.isDisplayed();\n\n return nameCheck && emailCheck && passwordCheck && signupGoogleCheck && signupSlackCheck && signupOutlookCheck && signupAppleCheck && signupFacebookCheck && logoCheck;\n\n }",
"@Override\n\tpublic boolean validate() {\n\t\treturn false;\n\t}",
"@Override\n\tpublic boolean validate() {\n\t\treturn false;\n\t}",
"public void validate()\r\n throws org.exolab.castor.xml.ValidationException\r\n {\r\n org.exolab.castor.xml.Validator validator = new org.exolab.castor.xml.Validator();\r\n validator.validate(this);\r\n }",
"public void validate()\r\n throws org.exolab.castor.xml.ValidationException\r\n {\r\n org.exolab.castor.xml.Validator validator = new org.exolab.castor.xml.Validator();\r\n validator.validate(this);\r\n }",
"public void validate() throws org.exolab.castor.xml.ValidationException {\r\n\t\torg.exolab.castor.xml.Validator validator = new org.exolab.castor.xml.Validator();\r\n\t\tvalidator.validate(this);\r\n\t}",
"@Override\n public boolean validate(Batch batch,\n InputStream contents,\n ResultCollector resultCollector) {\n Document document = DOM.streamToDOM(contents);\n return validate(batch,document,resultCollector);\n }",
"private boolean validate(ActionRequest request) {\n\t\t// Variable à mettre à false quand une erreur est détectée\n\t\tboolean isValid = true;\n\t\t// Défini le format de date à utiliser pour les champs temporels \n\t\tDateFormat dateFormat = new SimpleDateFormat(\"dd/MM/yyyy\");\n\n\t\t// Titre\n\t\tif (Validator.isNull(ParamUtil.getString(request, \"title\"))) {\n\t\t\tSessionErrors.add(request, \"title-error\");\n\t\t\tisValid = false;\n\t\t}\n\n\t\t// Description\n\t\tif (Validator.isNull(ParamUtil.getString(request, \"descriptionEditor\"))) {\n\t\t\tSessionErrors.add(request, \"description-error\");\n\t\t\tisValid = false;\n\t\t}\n\n\t\t// Adresse\n\t\tif (Validator.isNull(ParamUtil.getString(request, \"address\"))) {\n\t\t\tSessionErrors.add(request, \"address-error\");\n\t\t\tisValid = false;\n\t\t}\n\n\t\t// Ville\n\t\tif (Validator.isNull(ParamUtil.getString(request, \"city\"))) {\n\t\t\tSessionErrors.add(request, \"city-error\");\n\t\t\tisValid = false;\n\t\t}\n\n\t\t// Code postal\n\t\tif (Validator.isNull(ParamUtil.getString(request, \"postalCode\"))) {\n\t\t\tSessionErrors.add(request, \"postal-code-error\");\n\t\t\tisValid = false;\n\t\t}\n\n\t\t// Téléphone\n\t\tif (Validator.isNull(ParamUtil.getString(request, \"phoneNumber\"))) {\n\t\t\tSessionErrors.add(request, \"phone-number-error\");\n\t\t\tisValid = false;\n\t\t}\n\n\t\t// Au nom de\n\t\tif (Validator.isNull(ParamUtil.getString(request, \"inTheNameOf\"))) {\n\t\t\tSessionErrors.add(request, \"in-the-name-of-error\");\n\t\t\tisValid = false;\n\t\t}\n\n\t\treturn isValid;\n\t}",
"private void showErrorMessage() {\n // First, hide the currently visible data\n mRecyclerView.setVisibility(View.INVISIBLE);\n\n // Then, show the error\n mErrorMessageDisplay.setVisibility(View.VISIBLE);\n }",
"public void validate()\n\t{\t\t\n\t\t// calculate the corner position\n\t\tsetCorner(\n\t\t\t\tcalculateCornerPosition(\n\t\t\t\t\t\tgetCentrePosition(),\n\t\t\t\t\t\tgetHorizontalSpanVector(),\n\t\t\t\t\t\tgetVerticalSpanVector()\n\t\t\t\t\t)\n\t\t\t);\n\t}"
]
| [
"0.74903625",
"0.74903625",
"0.7205004",
"0.6181878",
"0.61666536",
"0.61568785",
"0.6147448",
"0.6092104",
"0.6055259",
"0.602797",
"0.59384245",
"0.5891738",
"0.5857381",
"0.58129746",
"0.58103704",
"0.58027625",
"0.57862395",
"0.57790136",
"0.57585794",
"0.5741152",
"0.57406753",
"0.57391274",
"0.5719066",
"0.5719066",
"0.5708019",
"0.56855",
"0.56804574",
"0.5679263",
"0.5659669",
"0.56541336",
"0.56541336",
"0.5641142",
"0.56318635",
"0.5618854",
"0.5614827",
"0.559313",
"0.5566219",
"0.5550342",
"0.55352277",
"0.5520373",
"0.5512592",
"0.55094236",
"0.5487649",
"0.54832006",
"0.5482986",
"0.5473899",
"0.54695743",
"0.54527074",
"0.5448087",
"0.54331845",
"0.54259896",
"0.54259896",
"0.54249144",
"0.5424064",
"0.54124004",
"0.53944385",
"0.53909713",
"0.538018",
"0.53776866",
"0.5363102",
"0.5353389",
"0.5348325",
"0.5344464",
"0.5329964",
"0.5321933",
"0.531664",
"0.53039616",
"0.5302794",
"0.52985054",
"0.52890736",
"0.5286899",
"0.5284375",
"0.52760464",
"0.52614284",
"0.5255761",
"0.52551013",
"0.52535534",
"0.52510107",
"0.5250943",
"0.52497864",
"0.52486664",
"0.52419883",
"0.52355075",
"0.5224334",
"0.5222106",
"0.5221803",
"0.5221116",
"0.5206585",
"0.52061623",
"0.52061623",
"0.51963025",
"0.51888573",
"0.51888573",
"0.5185966",
"0.5185966",
"0.5179226",
"0.5174759",
"0.51731706",
"0.51694524",
"0.5168426"
]
| 0.74647975 | 2 |
Initial state of the action. | public void setEnabled(boolean enabled) {
this.enabled = enabled;
fireChange();
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void doInitialAction(){}",
"public void initialState() {\n\t\t//empty\n\t}",
"public InitialState() {\r\n\t\t}",
"public State getInitialState() {\r\n \t\treturn initialState;\r\n \t}",
"public State getInitialState() {\n\t\treturn initialState;\n\t}",
"public void initiateAction() {\r\n\t\t// TODO Auto-generated method stub\t\r\n\t}",
"public State getinitialState(){\n\t\t\treturn initialState;\n\t\t}",
"public static void initial(){\n\t}",
"@Override\r\n\tpublic void initActions() {\n\t\t\r\n\t}",
"@Override\r\n public MachineState getInitialState() {\r\n \tclearpropnet();\r\n \tpropNet.getInitProposition().setValue(true);\r\n\t\tMachineState initial = getStateFromBase();\r\n\t\treturn initial;\r\n }",
"@Override\r\n public void initAction() {\n \r\n }",
"@Override\n\tpublic void initial() {\n\t\t\n\t}",
"public State getInitialState(){\n\t\treturn new AggregateState(gs);\n\t}",
"private StateActions(){}",
"private CalculateInitialAttritionEffect(Action action) {\n super(action);\n }",
"public void initialise() throws ActionLifecycleException;",
"State getInitialState( int nIdWorkflow );",
"public abstract void init_actions() throws Exception;",
"@Override\r\n\tpublic final void beginAction() {\r\n\t\tframesPassed = 0;\r\n\t\trecentFrame = -1;\r\n\t\ttarget = getEntity().getAttackTarget();\r\n\t\tMinecraftForge.EVENT_BUS.post(new ActionSelectionEvent(this, getEntity()));\r\n\t\tresetAction();\r\n\t\tinitializeExecutionRandomness();\r\n\t\tbeginExecution();\r\n\t}",
"public void initialState() {\r\n\t\tfor (int i = 0; i < checkBoxes.length; i++) {\r\n\t\t\tamountBoxes[i].setSelectedIndex(0);\r\n\t\t\tcheckBoxes[i].setSelected(false);\r\n\t\t}\r\n\t}",
"public void setInitialState(State initial) {\n model.setInitialState(initial);\n model.setDeterministic(false);\n model.restoreInvariant();\n }",
"public void initialize() {\r\n\t\tsetValue(initialValue);\r\n\t}",
"public ActionState createActionState();",
"private void initBeginOfTurn()\n\t{\n\t\tfor(Action action : this.getCurrentPlayer().getPersonalityCard().getActions())\n\t\t{\n\t\t\taction.execute(this);\n\t\t}\n\t\t\n\t\tcanPlayPlayerCard = true;\n\t\tthis.getCurrentPlayer().getDataInput().printMessage(this.getEntireGameStatus());\n\t\tthis.getCurrentPlayer().getDataInput().printMessage(this.getCurrentPlayerGameStatus());\n\t\tthis.showSaveGame = true;\n\t\t\n\t\tfor(Card card : this.getCurrentPlayer().getCityAreaCardDeck())\n\t\t{\n\t\t\tcard.setActiveState(true);\n\t\t}\n\t}",
"@Override\n public void initState() {\n \n\t//TODO: Complete Method\n\n }",
"public void beginTurn() {\n \t\t// clear the action log\n \t\tactionLog = \"\";\n \t}",
"public static State startState() {\n return new State(StateTypes.q0);\n }",
"private void init() {\n StateManager.setState(new MenuState());\n }",
"public synchronized void reset() {\n state = State.WAITING_TO_START;\n }",
"public void resetAction()\r\n {\r\n this.action = null;\r\n }",
"public ResetAction() {\n width = height = mines = 0;\n }",
"SpacecraftState getInitialState() throws OrekitException;",
"protected void resetState()\n {\n // Nothing to do by default.\n }",
"@Override\n\tpublic int doInit() throws RadowException {\n\t\tthis.setNextEventName(\"initX\");\n\t\treturn EventRtnType.NORMAL_SUCCESS;\n\t}",
"private static State generateInitialState(double initialHeuristic) {\n ArrayList<List<Job>> jobList = new ArrayList<>(RecursionStore.getNumberOfProcessors());\n for (int i = 0; i < RecursionStore.getNumberOfProcessors(); i++) {\n jobList.add(new ArrayList<>());\n }\n int[] procDur = new int[RecursionStore.getNumberOfProcessors()];\n java.util.Arrays.fill(procDur, 0);\n return new State(jobList, procDur, initialHeuristic, 0);\n }",
"public SetStartPageAction() {\n this(TYPE_NONE, null); // Fake action -> The context aware is real one, drawback of the NB design?\n }",
"public void setFirstAction(boolean firstAction) {\n _firstAction = firstAction;\n }",
"@Override\n\tprotected void initial() throws SiDCException, Exception {\n\t\tLogAction.getInstance().initial(logger, this.getClass().getCanonicalName());\n\t}",
"public EmptyAction() {\n\t\tsetActionName(\"Empty Action\");\n\t}",
"@Override\n public void doInit() {\n action = (String) getRequestAttributes().get(\"action\");\n }",
"public State setInitialState(final State initialState) {\n\t\tfinal State oldInitialState = this.initialState;\n\t\tthis.initialState = initialState;\n\t\tdistributeStateEvent(new AutomataStateEvent(this, initialState, false, false, true));\n\t\treturn oldInitialState;\n\t}",
"public void setInitialState(String state) {\r\n \t\tinitialState = addState(state);\r\n \t}",
"public String initialAction() throws Exception {\n\t\tSystem.out.println(\" *** initialAction **** \");\t\n\t return \"login\";\n\t }",
"public void performInitialisation() {\n \t\t// subclasses can override the behaviour for this method\n \t}",
"void resetInitialState(SpacecraftState state)\n throws OrekitException;",
"public void setInitialStatus(InstanceStatus initialStatus)\n {\n this.initialStatus = initialStatus;\n }",
"public abstract MachineState getInitialState();",
"S getInitialState();",
"@Override\n\tpublic State getSingleInitialState()\n\t{\n\t\tassert (initialState != null);\n\t\treturn initialState;\n\t}",
"public void initOperation() {\n\t\tinitialized = true;\r\n\t}",
"public void begin(GameState init_state) {\n rand = new Random();\n }",
"@Override\n\tpublic void initializeState(){\n\t\tSystem.out.println(\"Entered instructionState\");\n\t}",
"@Override\n\tprotected String initial() {\n\t\treturn INITIAL;\n\t}",
"protected void init_actions()\r\n {\r\n action_obj = new CUP$CircuitCup$actions(this);\r\n }",
"@Override\n protected void initialize() {\n System.out.println(\"initializing claw state machine\");\n }",
"public State() {\n resetTransitions();\n id = next_id++;\n }",
"public final void initialize() {\n initialize(0);\n }",
"@RequiresApi(api = Build.VERSION_CODES.N)\n public void StartInitial() {\n model.StartInitial();\n\n // Add any code required\n\n }",
"void createInitialBeliefState( )\n throws BelievabilityException\n {\n if ( _asset_dim_model == null )\n throw new BelievabilityException\n ( \"POMDPAssetDimensionModel.createInitialBeliefState()\",\n \"Asset model is NULL\" );\n \n if ( _logger.isDetailEnabled() )\n _logger.detail( \"\\tCreating POMDP iinitial belief for dimension: \" \n + _asset_dim_model.getStateDimensionName( ) );\n\n int num_vals = _asset_dim_model.getNumStateDimValues( );\n \n if ( num_vals < 0 )\n throw new BelievabilityException\n ( \"POMDPAssetDimensionModel.createInitialBeliefState()\",\n \"Asset model returning zero values: \"\n + _asset_dim_model.getStateDimensionName( ) );\n \n double[] belief_prob = new double[num_vals];\n \n int default_idx = _asset_dim_model.getDefaultStateIndex( );\n \n if ( default_idx < 0 )\n throw new BelievabilityException\n ( \"POMDPAssetDimensionModel.createInitialBeliefState()\",\n \"Asset model returning invalid default value: \"\n + _asset_dim_model.getStateDimensionName( ) );\n\n // We assume that each asset state dimension starts off\n // deterministically in a single possible state value.\n //\n belief_prob[default_idx] = 1.0;\n \n _initial_belief = new BeliefStateDimension( _asset_dim_model,\n belief_prob,\n null );\n\n }",
"public void setInitialState(String type, String state) {\r\n\r\n\t\tTaskType tt = getType(type);\r\n\t\tif (tt != null)\r\n\t\t\ttt.initialState = state;\r\n\r\n\t}",
"public void reset() {\n\t\tinit(0, 0, 1, false);\n\t}",
"protected void init_actions()\n {\n action_obj = new CUP$FractalParser$actions(this);\n }",
"public void createStartState(){\n\t\tState startState = new State();\n\t\tstartState.setName(\"qStart\");\n\t\taddState(startState);\n\t\tthis.startState = startState;\n\t}",
"public void\ninit(SoState state)\n//\n////////////////////////////////////////////////////////////////////////\n{\n data = getDefault().getValue();\n}",
"public State(){}",
"public void reset() {\n actionFlag = true;\n messageFlag = false;\n self.getInputBuffer().clear();\n self.getOutputBuffer().clear();\n self.setCurrentProduct(null);\n self.resetCounters();\n self.getServiceManager().init(getRandom(), template);\n syncUpdate();\n }",
"private void enterSequence_mainRegion_State1_default() {\n\t\tnextStateIndex = 0;\n\t\tstateVector[0] = State.mainRegion_State1;\n\t}",
"public CreateIndividualPreAction() {\n }",
"public void reset() {\n this.state = null;\n }",
"T initialState();",
"protected PMBaseAction() {\r\n super();\r\n }",
"private Action(){\r\n\t\tthis(-1);\r\n\t}",
"protected void init_actions()\r\n {\r\n action_obj = new CUP$SintaxAnalysis$actions(this);\r\n }",
"@Override\n\tprotected Object entryInitialFlow() {\n\t\treturn null;\n\t}",
"public void startup() {\n neutral();\n }",
"@Override\n public void initComponent() {\n ActionManager am = ActionManager.getInstance();\n }",
"protected void initialize() {\n\t\televator.zeroEncoder();\n\t}",
"public boolean isFirstAction() {\n return _firstAction;\n }",
"@Override\n\tpublic void reset(){\n\t\tstate.reset();\n\t\toldState.reset();\n\t\treturnAction = new boolean[Environment.numberOfButtons]; \n\t\trewardSoFar = 0;\n\t\tcurrentReward = 0;\n\t}",
"private void startButtonAction(){\n scoreboard.setStartAction(event->initControl());\n }",
"@Override\n public AbstractState getInitialState(CFANode pNode) {\n return null;\n }",
"@Override\n\tpublic int getState() {\n\t\treturn 0;\n\t}",
"public static Stage initial( int count )\n\t\t{ return new InitialStage( count ); }",
"protected void init_actions()\n {\n action_obj = new CUP$Parser$actions(this);\n }",
"protected void init_actions()\n {\n action_obj = new CUP$Parser$actions(this);\n }",
"protected void init_actions()\n {\n action_obj = new CUP$Parser$actions(this);\n }",
"protected void init_actions()\n {\n action_obj = new CUP$Parser$actions(this);\n }",
"protected void init_actions()\n {\n action_obj = new CUP$Parser$actions(this);\n }",
"private void initializeResetButton()\r\n {\r\n resetButton = new JButton(\"RESET\");\r\n resetButton.addActionListener(new ActionListener()\r\n {\r\n @Override\r\n public void actionPerformed(ActionEvent e)\r\n {\r\n numMoves = 0;\r\n // implementation of multi-problem choices\r\n ProblemChooser pc = null;\r\n if (problem.isMultiProblem())\r\n {\r\n if (problem.hasCanvas())\r\n {\r\n pc = new ProblemChooser(problem.getInitialStatesList(),\r\n problem.getFinalStatesList(),\r\n problem.getMoveCounts(),\r\n problem.getInitialCanvasList(),\r\n problem.getFinalCanvasList()\r\n );\r\n } else\r\n {\r\n pc = new ProblemChooser(problem.getInitialStatesList(),\r\n problem.getFinalStatesList(), problem.getMoveCounts());\r\n }\r\n\r\n initialState = pc.getStart();\r\n }\r\n problem.setCurrentState(initialState);\r\n if (pc != null) {\r\n problem.setFinalState(pc.getFinal());}\r\n problemState.setText(initialState.toString());\r\n if (canvas != null)\r\n {\r\n canvas.setCurrentState(initialState);\r\n if (problem.isMultiProblem() && pc != null)\r\n {\r\n finalStateCanvas.setCurrentState(pc.getFinal());\r\n } else\r\n {\r\n finalStateCanvas.setCurrentState(problem.getFinalState());\r\n }\r\n canvas.render();\r\n finalStateCanvas.render();\r\n }\r\n problem.resetCounters();\r\n setStats();\r\n toggleButtons(true);\r\n }\r\n });\r\n }",
"private SyncState() {}",
"private void initialize() {\r\n\r\n // add default buttons\r\n addButton(getToggleButton(),\"toggle\");\r\n addButton(getFinishButton(),\"finish\");\r\n addButton(getCancelButton(),\"cancel\");\r\n addActionListener(new ActionListener() {\r\n\r\n public void actionPerformed(ActionEvent e) {\r\n String cmd = e.getActionCommand();\r\n if(\"toggle\".equalsIgnoreCase(cmd)) change();\r\n else if(\"finish\".equalsIgnoreCase(cmd)) finish();\r\n else if(\"cancel\".equalsIgnoreCase(cmd)) cancel();\r\n }\r\n\r\n });\r\n\r\n }",
"protected void init_actions()\r\n {\r\n action_obj = new CUP$Parser$actions(this);\r\n }",
"protected void reset(){\n inited = false;\n }",
"public ActionManager() {\n\t\tsuper();\n\t}",
"protected void init_actions()\n {\n action_obj = new CUP$analisis_sintactico_re$actions(this);\n }",
"protected void init( CommonDockAction action ){\n if( this.action != null )\n throw new IllegalStateException( \"already initialized\" );\n \n if( action == null )\n throw new NullPointerException( \"action is null\" );\n \n this.action = action;\n }",
"@Override\n\tpublic void onActionStart(int action) {\n\t\t\n\t}",
"public SimpleSateMachine(final @NotNull S initialState)\n {\n super(initialState);\n }",
"public ExecuteAction()\n {\n this(null);\n }",
"public void reset()\n {\n m_source_.setToStart();\n updateInternalState();\n }",
"protected void init_actions()\r\n {\r\n action_obj = new CUP$MJParser$actions(this);\r\n }"
]
| [
"0.7692392",
"0.7638914",
"0.72594416",
"0.72048694",
"0.7091551",
"0.706266",
"0.6868899",
"0.68302333",
"0.68118393",
"0.67923594",
"0.6785418",
"0.67644185",
"0.65731376",
"0.6553342",
"0.64903027",
"0.6445867",
"0.6405534",
"0.63818866",
"0.63602483",
"0.6323042",
"0.63223094",
"0.6299789",
"0.6294242",
"0.6265591",
"0.6260068",
"0.6259528",
"0.62454516",
"0.62415594",
"0.6236083",
"0.6234226",
"0.6225734",
"0.6214016",
"0.6208121",
"0.620357",
"0.62023205",
"0.6191286",
"0.61761737",
"0.616741",
"0.6127688",
"0.6093637",
"0.60854983",
"0.6079086",
"0.6024658",
"0.6019138",
"0.60166025",
"0.60127735",
"0.59981376",
"0.599638",
"0.5980371",
"0.5978551",
"0.59773254",
"0.5957851",
"0.59495485",
"0.5941443",
"0.5938833",
"0.5935927",
"0.59288675",
"0.5922873",
"0.5904294",
"0.59027463",
"0.58980995",
"0.589419",
"0.5886431",
"0.5884113",
"0.5870563",
"0.5862393",
"0.5858427",
"0.5856551",
"0.58499944",
"0.58495075",
"0.58471304",
"0.5842007",
"0.5831185",
"0.5813673",
"0.5804881",
"0.5799465",
"0.5799439",
"0.57959396",
"0.57764506",
"0.57755715",
"0.5773201",
"0.57723933",
"0.57631505",
"0.57578915",
"0.57578915",
"0.57578915",
"0.57578915",
"0.57578915",
"0.57574654",
"0.575643",
"0.5755968",
"0.5755665",
"0.57555145",
"0.57527107",
"0.574917",
"0.5747121",
"0.57442564",
"0.5741586",
"0.5740099",
"0.5730081",
"0.57295555"
]
| 0.0 | -1 |
Fires a change in the action. | protected void fireChange() {
ActionListener[] actionListenerArray = actionListeners.toArray(new ActionListener[0]);
for (int i = 0; i < actionListenerArray.length; i++) {
ActionListener listener = actionListenerArray[i];
listener.onActionChanged(this);
}
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\n public void actionPerformed (ActionEvent e) {\n fireChanged();\n }",
"@Override\r\n\tprotected void firePropertyChange(int action) {\r\n\t\tsuper.firePropertyChange(action);\r\n\t}",
"public void fireChange() {\n fireChange(new ChangeEvent(source));\n }",
"protected void fireChangeEvent() {\n\t\tfireEvent(new DebugEvent(this, DebugEvent.CHANGE));\n\t}",
"public void fireChangeEvent(ChangeEvent event);",
"void actionChanged( final ActionAdapter action );",
"protected void fireActionChanged()\n {\n for( final ActionAdapterListener listener : this.listeners )\n {\n listener.actionChanged( this );\n }\n }",
"public void setChangeAction(String changeAction)\r\n\t{\r\n\t\tthis.changeAction = changeAction;\r\n\t}",
"@Override\n\t\t\tpublic void changed(ChangeEvent event, Actor actor) {\n\t\t\t}",
"@Override\n\t\t\tpublic void changed(ChangeEvent event, Actor actor) {\n\t\t\t}",
"@Override\n\t\t\tpublic void changed(ChangeEvent event, Actor actor) {\n\t\t\t}",
"@Override\n\t\t\tpublic void changed(ChangeEvent event, Actor actor) {\n\t\t\t}",
"protected final void fireChangeEvent() {\n\t\tIterator<ChangeListener> it;\n\t\tsynchronized (listeners) {\n\t\t\tit = new HashSet<ChangeListener>(listeners).iterator();\n\t\t}\n\t\tChangeEvent ev = new ChangeEvent(this);\n\t\twhile (it.hasNext()) {\n\t\t\tit.next().changed(ev);\n\t\t}\n\t}",
"private void change() {\n\t\tsetChanged();\n\t\t//NotifyObservers calls on the update-method in the GUI\n\t\tnotifyObservers();\n\t}",
"public void actionPerformed(prisms.arch.event.PrismsEvent toFire,\n\t\tjava.awt.event.ActionEvent actionEvent)\n\t{\n\t\ttheSession.fireEvent(toFire);\n\t}",
"protected void fireChangeEvent(Action action) {\n for (SelectionListener listener : selectionListeners) {\n listener.selectionChanged(action);\n }\n }",
"public void triggerEvent() {\n\t\ts.changeOpenState();\n\t\ts.setChangedAndNotify();\n\t\t\n\t}",
"void onChange( T newValue );",
"public void firePropertyChange(String propertyName, Object oldValue, Object newValue);",
"public void notifyNewAction(Action action){\n\t\tnotifyObservers(action);\n\t}",
"@Override\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\n\t\t\t\tupdate();\n\t\t\t}",
"@Override\n\tpublic void action() {\n\t\tSystem.out.println(\"action now!\");\n\t}",
"public void selectionChanged(IAction action, ISelection selection) {\n\t\t\r\n\t}",
"public final void change() {\n\t\tBSUIWindow.change_do(this);\n\t}",
"protected void fireChangeEvent (ModelProperties prop)\n {\n\tJsimEvent evt;\n\tString\t SLASH = System.getProperty (\"file.separator\");\n\tString fname = System.getProperty (\"user.home\");\n\tString xmlStr;\n\n\tif (use_xml) {\n try {\n Vector data = new Vector (); data.add (prop);\n if (generate_xml_files) {\n\t\t fname += SLASH + \"JSIM\" + SLASH + \"jsim\" + SLASH +\n\t\t\t\t\"jmessage\" + SLASH + \"change.xml\";\n\t\t xmlStr = XMLSerializer.serialize (data, fname);\n\t\t} else {\n\t\t xmlStr = XMLSerializer.serialize (data);\n\t\t}; // if\n } catch (Exception e) {\n trc.tell (\"fireChangeEvent\", e.getMessage ());\n e.printStackTrace ();\n return;\n }\n\t evt = new JsimEvent (this, EventMap.CHANGE_EVT, xmlStr);\n\t} else {\n\t evt = new JsimEvent (this, EventMap.CHANGE_EVT, prop);\n\t}; // if\n\n propCache = prop;\n\tfireJsimEvent (evt);\n \n }",
"public String getChangeAction()\r\n\t{\r\n\t\treturn changeAction;\r\n\t}",
"protected void fireActionEvent() {\n if (actionListener != null) {\n ActionEvent ae = new ActionEvent(this, ActionEvent.ACTION_PERFORMED, command);\n actionListener.actionPerformed(ae);\n }\n }",
"void trigger(Entity e);",
"public void chg() {\n currentChangeStep = 3;\n }",
"public void changePerformed(final ProjectDiagramChange change);",
"@Override\n\t\tpublic void actionPerformed(ActionEvent arg0) {\n\t\t\ttry {\n\t\t\t\tupdate();\n\t\t\t} catch (MyException e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t}",
"public void setAction(int value) {\n this.action = value;\n }",
"public void setChangeStateAction(int c)\r\n \t{\r\n \t\tm_iChangeStateBy = c;\r\n \t}",
"public void action() {\n action.action();\n }",
"public void selectionChanged(IAction action, ISelection selection) {\n\r\n\t}",
"public void selectionChanged(IAction action, ISelection selection) {\n\r\n\t}",
"public void trigger(Fact fact) {\n\t\t\n\t}",
"@Override\n\tpublic void setAction() {\n\t}",
"public void selectionChanged(IAction action, ISelection selection) {\n\t}",
"@Override\n\tpublic void updateAction(Client input) {\n\t\t\n\t}",
"public void setAction(String action);",
"@Property(\"triggerAction\")\n void setTriggerAction(String triggerAction);",
"public void setChangeListener();",
"public void actionPerformed(ActionEvent e) {\r\n\t\t\tmode = InputMode.CHANGE_VALUE;\r\n\t\t\tinstr.setText(\"Click an array element to change its value.\");\r\n\t\t\tdefaultVar(canvas);\t\t\t\r\n\t\t}",
"@Override\n\tpublic void update(VPAction arg0) {\n\n\t}",
"public void changed (ChangeEvent event, Actor actor) {\n\t \t\t\t\tfloat percent = (float)theCasing.maintenance/(float)ST.getJarMaintenance( theCasing.strain.temp_required, Assets.player.inc_temp );\n\t \t\t\t\tif ( theCasing.location==ST.FC )\n\t \t\t\t\t\t percent = (float)theCasing.maintenance/(float)ST.getJarMaintenance( theCasing.strain.temp_required, Assets.player.fc_temp );\n\t \t\t\t\tAssets.player.increaseXP( (int)(ST.MAINTENANCE_XP*ST.logisticSpread( percent ) ) );\n\t \t\t\t\t\n\t \t\t\t\tST.focus( pane, maintenanceBar );\n\t \t\t\t\t\n\t \t\t\t\t// reduce the jar's maintenance to 0\n\t \t\t\t\ttheCasing.maintenance = 0;\n\t \t\t\t}",
"private void fireValueChange(boolean b) {\n \t\n\t\t\n\t}",
"public void notifyChange()\r\n {\r\n setChanged();\r\n notifyObservers();\r\n }",
"public void fire() {\n \tintakeTalon1.set(1);\n \tintakeTalon2.set(1);\n }",
"public void actionPerformed(ActionEvent e){\n\t\t\topenUpdate();\n\t\t}",
"void trigger();",
"public void selectionChanged(IAction action, ISelection selection) {\n }",
"@Override\r\n\tpublic void action() {\n\t\t\r\n\t}",
"void onPropertyChange(String name, String newValue);",
"@Override\n public void action() {\n }",
"@Override\n public void action() {\n }",
"@Override\n public void action() {\n }",
"public void testFirePropertyChangeEvent() {\n ModelElementChangeListenerMock listener = new ModelElementChangeListenerMock();\n instance.addModelElementChangeListener(listener);\n instance.firePropertyChangeEvent(new GuardImpl(), PropertyKind.ACTIVE, PropertyOperation.MODIFY, \"accuracy\");\n assertTrue(\"Failed to fire the event.\", listener.IsCalled());\n }",
"public abstract void setTriggerOrAction();",
"protected void fireUpdateEvent(UpdateResult evt) {\n \t\tif (periodModel != null) {\n \t\t\ttry {\n \t\t\t\tperiodModel.update();\n \t\t\t} catch (RaplaException e) {\n \t\t\t\tgetLogger().error(\"Can't update Period Model\", e);\n \t\t\t}\n \t\t}\n \t\t{\n \t\t\tCollection<ModificationListener> modificationListeners = directListenerList;\n \t\t\tif (modificationListeners.size() > 0 ) {\n \t\t\t\tnew UpdateCommandModification(modificationListeners,evt).execute(); \n \t\t\t}\n \t\t}\n \t\t{\n \t\t\tCollection<ModificationListener> modificationListeners = getModificationListeners();\n \t\t\tif (modificationListeners.size() > 0 ) {\n \t\t\t\tnotifyQueue.schedule(new UpdateCommandModification(modificationListeners, evt),0);\n \t\t\t}\n \t\t\tCollection<AllocationChangeListener> allocationChangeListeners = getAllocationChangeListeners();\n \t\t\tif (allocationChangeListeners.size() > 0) {\n \t\t\t\tnotifyQueue.schedule(new UpdateCommandAllocation(allocationChangeListeners, evt),0);\n \t\t\t}\n \t\t}\n \t}",
"public void actionSuccessful() {\n System.out.println(\"Action performed successfully!\");\n }",
"@Override\n\tpublic void doAction(String action) {\n\t\tthis.action = action;\n\t\t\n\t\tthis.gameController.pause();\n\t}",
"public void performAction() {\n\t\t// TODO Auto-generated method stub\n\t\t\n\t}",
"@Override\r\n\t\tpublic void actionPerformed(ActionEvent arg0) {\n\t\t\tSaveAction();\r\n\t\t\t\r\n\t\t}",
"public void trigger(Event event);",
"protected void fireAttributeChanged(VAttribute attr)\n\t{\n\t\tResourceEvent event=ResourceEvent.createAttributesChangedEvent(getVRL(),\n\t\t\t\tnew VAttribute[]{attr}); \n\t\tthis.vrsContext.getResourceEventNotifier().fire(event); \n\t}",
"@Override\n\tpublic void propertyChange() {\n\t\tthis.apply();\n\t}",
"public void run() {\n long startTime = 0;\n if (action.getClass().getName().contains(\"TooAction\")) {\n startTime = System.currentTimeMillis();\n LOG.log(Level.WARNING, \"Sending a ToO alert...\");\n }\n\n action.doTriggerAction(change, handback);\n\n // Record the end time and warn if it took too long.\n if (startTime != 0) {\n long curTime = System.currentTimeMillis();\n LOG.log(Level.WARNING, \"Sent ToO alert\");\n\n long elapsed = curTime - startTime;\n if (elapsed > 5000) {\n LOG.log(Level.WARNING, \"Long delay sending ToO alert: \" + elapsed);\n }\n }\n\n }",
"public void executeAction()\n\t{\t\t\n\t\tthis.getUser().setHealth(this.getUser().getHealth()+HEALTH);\n\t}",
"public void setAction(String action) { this.action = action; }",
"@Override\n\tpublic void selectionChanged(IAction arg0, ISelection arg1) {\n\n\t}",
"public void firePropertyChange(java.lang.String propertyName, java.lang.Object oldValue, java.lang.Object newValue) {\r\n\tgetPropertyChange().firePropertyChange(propertyName, oldValue, newValue);\r\n}",
"public void performChange() {\n newAttrValue = oldAttrValue.replaceAll(\"\\\\.\" + method + \"$\", \".\" + rename.getNewName());\n doAttributeValueChange(newAttrValue, valueType);\n }",
"@Override\n\t\t\tpublic void changed(ChangeEvent event, Actor actor) {\n\t\t\t\tbuttonSound.play((game.setting.sfxVol()*(game.setting.masterVol()/100))/100);\n\t\t\t\t//screen.getActions().makeArt(typeSelBox.getSelectedIndex(), subjectSelBox.getSelectedIndex());\n\t\t\t\t\n\t\t\t\t// Call player actor to make art\n\t\t\t\tGameScreen screen = (GameScreen)game.getScreen();\n\t\t\t\t\n\t\t\t\t// If you can make art, make art\n\t\t\t\tif(screen.getActions().canMakeArt(typeSelBox.getSelectedIndex()))\t\n\t\t\t\t\tscreen.getPlayer().makeArt(typeSelBox.getSelectedIndex(), subjectSelBox.getSelectedIndex());\n\n\t\t\t\tclosePopups();\n\t\t\t}",
"public void setAction(Action action) {\n this.action = action;\n }",
"private void fireChangeInternal(ChangeEvent event) {\n assert event != null;\n for (ChangeListener listener : listeners) {\n try {\n listener.stateChanged(event);\n } catch (RuntimeException x) {\n Exceptions.printStackTrace(x);\n }\n }\n }",
"void willDisplayUpdate(String change) throws RemoteException;",
"public void actionPerformed(ActionEvent e) {\n action.actionPerformed(e);\n }",
"public void actionPerformed(ActionEvent evt) {\r\n super.actionPerformed(evt);\r\n runRefactoring();\r\n }",
"public final void fire(Object event) {\n manager.fire(event);\n }",
"@Override\r\n\t\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\t\tsaveChanges();\r\n\t\t\t\t\t\r\n\t\t\t\t}",
"public void actionPerformed(ActionEvent e) {\n\t\t\t\tamountChange(mainLabel, amountInput, buttons2, assets[0], $, labels, changeStart, assets, changes);\n\t\t\t}",
"public abstract void setValueAction(Object value);",
"public void actionPerformed(ActionEvent e) {\n\t\t\t\t\tchangeSettings();\n\t\t\t\t}",
"@Override\n\tpublic void update(VPAction arg0, VPContext arg1) {\n\t\t\n\t}",
"@Override\n\tpublic void HandleEvent(int action) {\n\t\tsetActiveAction(action);\n\t\tSystem.out.println(\"action is :\" + action);\n\t\t\n\t}",
"public void \n actionPerformed\n (\n ActionEvent e\n ) \n {\n String cmd = e.getActionCommand();\n if(cmd.equals(\"mode-changed\")) \n doModeChanged();\n else if(cmd.equals(\"method-changed\")) \n doMethodChanged();\n else if(cmd.equals(\"version-changed\")) {\n if(e.getSource() instanceof JCollectionField)\n\tdoVersionChanged((JCollectionField) e.getSource());\n }\n else\n super.actionPerformed(e);\n }",
"void\n notifyChange() {\n this.notifyChange = true;\n synchronized (this.changeMonitor) {\n this.changeMonitor.notifyAll();\n }\n }",
"@Override\n\tpublic void action() {\n\n\t}",
"protected void firePropertyChange( java.beans.PropertyChangeEvent evt ) {\n propertyChangeSupport.firePropertyChange( evt );\n }",
"void fireMyEvent(ChangeEvent evt) {\n Object[] listeners = listenerList.getListenerList();\n // Each listener occupies two elements - the first is the listener class\n // and the second is the listener instance\n for (int i = 0; i < listeners.length; i += 2) {\n if (listeners[i] == ChangeListener.class) {\n ((ChangeListener) listeners[i + 1]).stateChanged(evt);\n }\n }\n }",
"void entityValueChange(String name, String value);",
"@Override\n\t\tpublic void onChange(boolean selfChange) {\n\t\t\tsuper.onChange(selfChange);\n\t\t}",
"@Override\n public void onChange(boolean selfChange) {\n onChange(selfChange, null);\n }",
"protected void fireStateChanged() {\n\t\tChangeEvent changeEvent = new ChangeEvent(this);\n\n\t\tfor (ChangeListener changeListener : changeListeners) {\n\t\t\tchangeListener.stateChanged(changeEvent);\n\t\t}\n\t}",
"protected final void firePropertyChange(String propertyName, int oldValue, int newValue) {\n PropertyChangeSupport aChangeSupport = this.changeSupport;\n if (aChangeSupport == null) {\n return;\n }\n aChangeSupport.firePropertyChange(\n propertyName, Integer.valueOf(oldValue), Integer.valueOf(newValue));\n }",
"@FXML\r\n\tprivate void updateStatus(ActionEvent event) {\r\n\t\tupdateAsset(AssetOperation.STATUS);\r\n\t}",
"public void firePropertyChange(String p, Object a, Object b) {\n\n\t}",
"public void descriptionTypeRefsetMemberChanged(\n DescriptionType member, Action action) throws Exception;",
"public void postActionEvent() {\n fireActionPerformed();\n }"
]
| [
"0.7426401",
"0.74019474",
"0.73549974",
"0.68464166",
"0.6708779",
"0.668759",
"0.66139144",
"0.64577615",
"0.64563364",
"0.64563364",
"0.64563364",
"0.64563364",
"0.6416002",
"0.64013016",
"0.639562",
"0.63848776",
"0.62691355",
"0.62227684",
"0.62164605",
"0.62112844",
"0.6196263",
"0.6135354",
"0.6135176",
"0.61350137",
"0.61328375",
"0.61260784",
"0.6122141",
"0.61079943",
"0.6075044",
"0.60479146",
"0.6024465",
"0.6024388",
"0.6008646",
"0.59938765",
"0.59834605",
"0.59834605",
"0.5982789",
"0.59627",
"0.5959163",
"0.5943722",
"0.5942722",
"0.5921336",
"0.59166235",
"0.5914559",
"0.5909289",
"0.5903078",
"0.5902417",
"0.58999366",
"0.5897718",
"0.58921224",
"0.58875895",
"0.5884172",
"0.5874032",
"0.58675987",
"0.5862075",
"0.5862075",
"0.5862075",
"0.58581746",
"0.5853897",
"0.5846013",
"0.5841677",
"0.5832049",
"0.5824734",
"0.58165926",
"0.5816528",
"0.58116204",
"0.5805627",
"0.58049375",
"0.5803441",
"0.5799635",
"0.57973075",
"0.5795134",
"0.5785791",
"0.57821995",
"0.57796067",
"0.57772607",
"0.57757974",
"0.577441",
"0.5772397",
"0.5768951",
"0.5763227",
"0.57596517",
"0.5758567",
"0.574602",
"0.57439965",
"0.5739699",
"0.57362896",
"0.5732249",
"0.57320344",
"0.5730084",
"0.5721958",
"0.5711942",
"0.57110536",
"0.5704867",
"0.5700341",
"0.56960535",
"0.5692606",
"0.5691932",
"0.56919026",
"0.56847334"
]
| 0.7476343 | 0 |
Might be null if Google Play services APK is not available. This method is performed by android at the creation of the Activity. It will be tasked to initializing its presenter. | @Override
protected void onCreate(Bundle savedInstanceState) {
super.onCreate(savedInstanceState);
setContentView(R.layout.activity_map_chart);
setUpMapIfNeeded();
presenter= PresenterImpl.create(PresenterImpl.ChartType.MAPCHART_TYPE,this);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void acquireGooglePlayServices() {\r\n GoogleApiAvailability apiAvailability = GoogleApiAvailability.getInstance();\r\n final int connectionStatusCode = apiAvailability.isGooglePlayServicesAvailable(getActivity());\r\n if (apiAvailability.isUserResolvableError(connectionStatusCode)) {\r\n showGooglePlayServicesAvailabilityErrorDialog(connectionStatusCode);\r\n }\r\n }",
"private void acquireGooglePlayServices() {\n GoogleApiAvailability apiAvailability =\n GoogleApiAvailability.getInstance();\n final int connectionStatusCode =\n apiAvailability.isGooglePlayServicesAvailable(getActivity());\n if (apiAvailability.isUserResolvableError(connectionStatusCode)) {\n showGooglePlayServicesAvailabilityErrorDialog(connectionStatusCode);\n }\n }",
"private void acquireGooglePlayServices() {\n GoogleApiAvailability apiAvailability =\n GoogleApiAvailability.getInstance();\n final int connectionStatusCode =\n apiAvailability.isGooglePlayServicesAvailable(this);\n if (apiAvailability.isUserResolvableError(connectionStatusCode)) {\n showGooglePlayServicesAvailabilityErrorDialog(connectionStatusCode);\n }\n }",
"private void acquireGooglePlayServices() {\n GoogleApiAvailability apiAvailability =\n GoogleApiAvailability.getInstance();\n final int connectionStatusCode =\n apiAvailability.isGooglePlayServicesAvailable(this);\n if (apiAvailability.isUserResolvableError(connectionStatusCode)) {\n showGooglePlayServicesAvailabilityErrorDialog(connectionStatusCode);\n }\n }",
"private void acquireGooglePlayServices() {\n GoogleApiAvailability apiAvailability =\n GoogleApiAvailability.getInstance();\n final int connectionStatusCode =\n apiAvailability.isGooglePlayServicesAvailable(this);\n if (apiAvailability.isUserResolvableError(connectionStatusCode)) {\n showGooglePlayServicesAvailabilityErrorDialog(connectionStatusCode);\n }\n }",
"private void acquireGooglePlayServices() {\n GoogleApiAvailability apiAvailability =\n GoogleApiAvailability.getInstance();\n final int connectionStatusCode =\n apiAvailability.isGooglePlayServicesAvailable(mActivity);\n if (apiAvailability.isUserResolvableError(connectionStatusCode)) {\n Log.d(Util.TAG_GOOGLE, \"\" + connectionStatusCode);\n // showGooglePlayServicesAvailabilityErrorDialog(connectionStatusCode);\n }\n }",
"@Override\n protected void onStart() {\n super.onStart();\n\n\n GoogleApiAvailability GMS_Availability = GoogleApiAvailability.getInstance();\n int GMS_CheckResult = GMS_Availability.isGooglePlayServicesAvailable(this);\n\n if (GMS_CheckResult != ConnectionResult.SUCCESS) {\n\n // Would show a dialog to suggest user download GMS through Google Play\n GMS_Availability.getErrorDialog(this, GMS_CheckResult, 1).show();\n }else{\n mGoogleApiClient.connect();\n }\n }",
"@Override\n public void onCreate() {\n super.onCreate();\n\n Integer response = GooglePlayServicesUtil.isGooglePlayServicesAvailable(this);\n\n if (response != ConnectionResult.SUCCESS) {\n Log.d(\"LocationUpdateService\", \"Google Play services unavailable\");\n stopSelf();\n return;\n }\n\n locationClient = new LocationClient(this, this, this);\n }",
"@Override\n protected void onPreExecute() {\n super.onPreExecute();\n\n /** Getting Google Play availability status **/\n int status = GooglePlayServicesUtil.isGooglePlayServicesAvailable(getBaseContext());\n if(status!= ConnectionResult.SUCCESS){ // Google Play Services are not available\n\n int requestCode = 10;\n Dialog dialog = GooglePlayServicesUtil.getErrorDialog(status, MainActivity.this, requestCode);\n dialog.show();\n\n }\n else { /** Google Play Services are available **/\n\n pb = (ProgressBar)findViewById(R.id.progressBar);\n progress_status = 0;\n\n // show the ProgressBar\n pb.setVisibility(View.VISIBLE);\n\n // update progress\n pb.setProgress(progress_status);\n tvResult.setText(\"downloading 0%\");\n }\n }",
"@Override\n public void onCreate() {\n super.onCreate();\n // Check if Google Map API Services is Available\n if (servicesOK()) {\n Log.d(Constants.SERVICE_STARTED, Constants.GOOGLE_MAP_ONLINE);\n // build google map client and connect\n buildGoogleApiClient();\n mGoogleApiClient.connect();\n }\n }",
"@Override\n protected void onStart() {\n super.onStart();\n idsession = MyModel.getInstance().getIdsession();\n\n //Check if GooglePlayServices are available\n GoogleApiAvailability googleApiAvailability = GoogleApiAvailability.getInstance();\n int status = googleApiAvailability.isGooglePlayServicesAvailable(this);\n if(status == ConnectionResult.SUCCESS) {\n Log.d(\"GeoPost Location\", \"GooglePlayServices available\");\n } else {\n Log.d(\"GeoPost Location\", \"GooglePlayServices UNAVAILABLE\");\n if(googleApiAvailability.isUserResolvableError(status)) {\n Log.d(\"GeoPost Location\", \"Ask the user to fix the problem\");\n //If the user accepts to install the google play services,\n //a new app will open. When the user gets back to this activity,\n //the onStart method is invoked again.\n googleApiAvailability.getErrorDialog(this, status, 2404).show();\n } else {\n Log.d(\"GeoPost Location\", \"The problem cannot be fixed\");\n }\n }\n\n // Instantiate and connect GoogleAPIClient.\n if (mGoogleApiClient == null) {\n mGoogleApiClient = new GoogleApiClient.Builder(this)\n .addConnectionCallbacks(this)\n .addOnConnectionFailedListener(this)\n .addApi(LocationServices.API)\n .build();\n }\n mGoogleApiClient.connect();\n }",
"protected void SetupGoogleServices()\n {\n if (mGoogleApiClient == null)\n {\n mGoogleApiClient = new GoogleApiClient.Builder(this)\n .addConnectionCallbacks(this)\n .addOnConnectionFailedListener(this)\n .addApi(LocationServices.API)\n .build();\n }\n }",
"@Override\n public void onCreate(){\n super.onCreate();\n createGoogleAPIClient();\n Log.i(TAG, \"On Create\");\n }",
"@Override\n\tprotected void onResume()\n\t{\n\t\tsuper.onResume();\n\n\t\tint resCode = GooglePlayServicesUtil.isGooglePlayServicesAvailable(getApplicationContext());\n\t\tif (resCode != ConnectionResult.SUCCESS)\n\t\t{\n\t\t\tGooglePlayServicesUtil.getErrorDialog(resCode, this, 1);\n\t\t}\n\t}",
"@Override\n public void onStart() {\n super.onStart();\n googleApiClient.connect();\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.activity_main);\n if (isServicesOK()) {\n init();\n }\n }",
"@Override\n public void onStart() {\n super.onStart();\n try {\n if (mGoogleApiClient != null) {\n mGoogleApiClient.connect();\n }\n } catch (Exception e) {\n e.printStackTrace();\n }\n }",
"@Override\n\tprotected void onStart() {\n\t\tsuper.onStart();\n\t\t// Connect the client.\n\t\tif (isGooglePlayServicesAvailable()) {\n\t\t\tmLocationClient.connect();\n\t\t}\n\n\t}",
"@Override\r\n protected void onStart() {\n super.onStart();\r\n mGoogleApiClient.connect();\r\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n try {\n ChromeBrowserInitializer.getInstance(this).handleSynchronousStartup();\n } catch (ProcessInitException e) {\n Log.e(TAG, \"Failed to start browser process.\", e);\n // Since the library failed to initialize nothing in the application\n // can work, so kill the whole application not just the activity\n System.exit(-1);\n }\n\n // We don't trust android to restore the saved state correctly, so pass null.\n super.onCreate(null);\n setContentView(R.layout.account_signin_view_cheetah);\n\n mGoogleSign = new GoogleSignin(this, this);\n\n ButtonCompat positiveButton = (ButtonCompat) findViewById(R.id.positive_button);\n positiveButton.setOnClickListener(view -> mGoogleSign.signIn());\n\n Button negativeButton = (Button) findViewById(R.id.negative_button);\n negativeButton.setOnClickListener(view -> finish());\n\n String google = \"Google\";\n ((TextView) findViewById(R.id.account_name)).setText(google);\n }",
"@Override\n\tpublic void onCreate() {\n\t\tLog.i(TAG, \"PlayerService.onCreate() called\");\n\t\tsuper.onCreate();\n\t}",
"private void setUpMapIfNeeded() {\n if (mMap == null) {\n // Try to obtain the map from the SupportMapFragment.\n mMap = mMapFragment.getMap();\n // Check if we were successful in obtaining the map.\n if (mMap != null) {\n Log.i(TAG, \"Yes, we have a google map...\");\n setUpMap();\n } else {\n // means that Google Service is not available\n form.dispatchErrorOccurredEvent(this, \"setUpMapIfNeeded\",\n ErrorMessages.ERROR_GOOGLE_PLAY_NOT_INSTALLED);\n }\n\n }\n }",
"@Override\n protected void onStart() {\n super.onStart();\n if (!mGoogleApiClient.isConnected()) {\n mGoogleApiClient.connect();\n }\n }",
"@Override\n protected void onStart() {\n super.onStart();\n Log.i(TAG, \"In onStart() - connecting...\");\n googleApiClient.connect();\n }",
"private void init(Bundle savedInstanceState) {\n googleApiClient = new GoogleApiClient.Builder(getContext())\n .addApi(LocationServices.API)\n .addConnectionCallbacks(this)\n .addOnConnectionFailedListener(this)\n .build();\n geocoder = new Geocoder(getContext(), Locale.getDefault());\n }",
"@Override\n public void onStart() {\n mGoogleApiClient.connect();\n super.onStart();\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n initViews(savedInstanceState);\n mPresenter = onLoadPresenter(savedInstanceState);\n if (mPresenter != null) {\n mPresenter.attachView(this);\n mPresenter.subscribe();\n }\n initEventAndData();\n }",
"private boolean isGooglePlayServicesAvailable() {\r\n GoogleApiAvailability apiAvailability = GoogleApiAvailability.getInstance();\r\n final int connectionStatusCode = apiAvailability.isGooglePlayServicesAvailable(getActivity());\r\n return connectionStatusCode == ConnectionResult.SUCCESS;\r\n }",
"@Override\n public void onCreate() {\n super.onCreate();\n setUSDK();\n }",
"private void initService() {\n connection = new AppServiceConnection();\n Intent i = new Intent(this, AppService.class);\n boolean ret = bindService(i, connection, Context.BIND_AUTO_CREATE);\n Log.d(TAG, \"initService() bound with \" + ret);\n }",
"private void checkGooglePlayServiceSDK() {\n //To change body of created methods use File | Settings | File Templates.\n final int googlePlayServicesAvailable = GooglePlayServicesUtil.isGooglePlayServicesAvailable(context);\n Log.i(TAG, \"googlePlayServicesAvailable:\" + googlePlayServicesAvailable);\n\n switch (googlePlayServicesAvailable) {\n case ConnectionResult.SERVICE_MISSING:\n form.dispatchErrorOccurredEvent(this, \"checkGooglePlayServiceSDK\",\n ErrorMessages.ERROR_GOOGLE_PLAY_NOT_INSTALLED);\n break;\n case ConnectionResult.SERVICE_VERSION_UPDATE_REQUIRED:\n form.dispatchErrorOccurredEvent(this, \"checkGooglePlayServiceSDK\",\n ErrorMessages.ERROR_GOOGLE_PLAY_SERVICE_UPDATE_REQUIRED);\n break;\n case ConnectionResult.SERVICE_DISABLED:\n form.dispatchErrorOccurredEvent(this, \"checkGooglePlayServiceSDK\",\n ErrorMessages.ERROR_GOOGLE_PLAY_DISABLED);\n break;\n case ConnectionResult.SERVICE_INVALID:\n form.dispatchErrorOccurredEvent(this, \"checkGooglePlayServiceSDK\",\n ErrorMessages.ERROR_GOOGLE_PLAY_INVALID);\n break;\n }\n }",
"private boolean isGooglePlayServicesAvailable() {\n GoogleApiAvailability apiAvailability =\n GoogleApiAvailability.getInstance();\n final int connectionStatusCode =\n apiAvailability.isGooglePlayServicesAvailable(getActivity());\n return connectionStatusCode == ConnectionResult.SUCCESS;\n }",
"private boolean isGooglePlayServicesAvailable() {\n GoogleApiAvailability apiAvailability =\n GoogleApiAvailability.getInstance();\n final int connectionStatusCode =\n apiAvailability.isGooglePlayServicesAvailable(mActivity);\n return connectionStatusCode == ConnectionResult.SUCCESS;\n }",
"@Override\r\n public void onCreate() {\r\n Log.d(TAG, \"on service create\");\r\n }",
"private boolean isGooglePlayServicesAvailable() {\n GoogleApiAvailability apiAvailability =\n GoogleApiAvailability.getInstance();\n final int connectionStatusCode =\n apiAvailability.isGooglePlayServicesAvailable(this);\n\n return connectionStatusCode == ConnectionResult.SUCCESS;\n\n }",
"@Override\n\tpublic void onCreate() {\n\t\tsuper.onCreate();\n\t\t/* BINDER LAB: Create a new instance of the Binder service */\n\t}",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.activity_main);\n ButterKnife.bind(this);\n Prefs prefs = new Prefs(this);\n if (prefs.getUrl()!=null)\n textUrl.setText(prefs.getUrl());\n checkCallPermission();\n }",
"@Override\n protected void onStart(){\n GoogleSignInOptions gso = new GoogleSignInOptions.Builder(GoogleSignInOptions.DEFAULT_SIGN_IN)\n .requestEmail()\n .build();\n\n // Build a GoogleSignInClient with the options specified by gso.\n mGoogleSignInClient = GoogleSignIn.getClient(this, gso);\n super.onStart();\n }",
"void onActivityReady();",
"private boolean isGooglePlayServicesAvailable() {\n GoogleApiAvailability apiAvailability =\n GoogleApiAvailability.getInstance();\n final int connectionStatusCode =\n apiAvailability.isGooglePlayServicesAvailable(this);\n return connectionStatusCode == ConnectionResult.SUCCESS;\n }",
"private boolean isGooglePlayServicesAvailable() {\n GoogleApiAvailability apiAvailability =\n GoogleApiAvailability.getInstance();\n final int connectionStatusCode =\n apiAvailability.isGooglePlayServicesAvailable(this);\n return connectionStatusCode == ConnectionResult.SUCCESS;\n }",
"@Override\n public void onMapReady(GoogleMap googleMap) {\n mMap = googleMap;\n if (mPresenter.isReady()) {\n mPresenter.displayMarkers();\n }\n }",
"private void init() {\n //set view to presenter\n presenter.setView(this, service);\n\n setupView();\n }",
"private IActivityResultObserver init(Context application){\n gpsUtil = new GpsUtil(application);\n return gpsUtil.getObserver();\n }",
"@Override\n public void onCreate() {\n googleApiClient = new GoogleApiClient.Builder(this)\n .addConnectionCallbacks(this)\n .addOnConnectionFailedListener(this)\n .addApi(LocationServices.API)\n .build();\n\n /*conectar al servicio*/\n Log.w(TAG, \"onCreate: Conectando el google client\");\n googleApiClient.connect();\n\n\n //NOTIFICACION\n mNotificationManager = (NotificationManager) getSystemService(NOTIFICATION_SERVICE);\n stateService = Constants.STATE_SERVICE.NOT_CONNECTED;\n\n }",
"@Override\n public void onMapReady(GoogleMap googleMap) {\n initGoogleApi(googleMap);\n initWindow();\n }",
"@Override\n protected void onPostCreate(Bundle savedInstanceState){\n super.onPostCreate(savedInstanceState);\n new LoadMeetsAsync().execute();\n }",
"private void startStep1() {\n\n //Check whether this user has installed Google play service which is being used by Location updates.\n if (isGooglePlayServicesAvailable()) {\n\n //Passing null to indicate that it is executing for the first time.\n startStep2(null);\n\n } else {\n Toast.makeText(getApplicationContext(), R.string.no_google_playservice_available, Toast.LENGTH_LONG).show();\n }\n }",
"private void setupMap() {\n int status = GooglePlayServicesUtil.isGooglePlayServicesAvailable(getBaseContext());\n \t\tif ( status != ConnectionResult.SUCCESS ) {\n \t\t\t// Google Play Services are not available.\n \t\t\tint requestCode = 10;\n \t\t\tGooglePlayServicesUtil.getErrorDialog( status, this, requestCode ).show();\n \t\t} else {\n \t\t\t// Google Play Services are available.\n \t\t\tif ( this.googleMap == null ) {\n \t\t\t\tFragmentManager fragManager = this.getSupportFragmentManager();\n \t\t\t\tSupportMapFragment mapFrag = (SupportMapFragment) fragManager.findFragmentById( R.id.edit_gpsfilter_area_google_map );\n \t\t\t\tthis.googleMap = mapFrag.getMap();\n \n \t\t\t\tif ( this.googleMap != null ) {\n \t\t\t\t\t// The Map is verified. It is now safe to manipulate the map.\n \t\t\t\t\tthis.configMap();\n \t\t\t\t}\n \t\t\t}\n \t\t}\n \t}",
"@Override\n protected void onResume() {\n super.onResume();\n Log.d(TAG, \"onResume: Registering for broadcasts\");\n placesBroadcastReceiver = new PlacesBroadcastReceiver(this, this); //we are a place broadcast listener\n AppEventsLogger.activateApp(this);\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.activity_maps);\n\n// mGeoDataClient = Places.getGeoDataClient(this, null);\n//\n// mPlaceDetectionClient = Places.getPlaceDetectionClient(this, null);\n//\n// mFusedLocationProviderClient = LocationServices.getFusedLocationProviderClient(this);\n\n setUpMap();\n }",
"@Override\n\tpublic void onCreate() {\n\t\tsuper.onCreate();\n\t\tmContext = this;\n\t\tLogUtils.i(\"tr069Service onCreate is in >>>>>\");\n\t\tLogUtils.writeSystemLog(\"tr069Service\", \"onCreate\", \"tr069\");\n\t\tinitService();\n\t\tinitData();\n\t\tregisterReceiver();\n\t\t\t\t\n\t\tif(JNILOAD){\n\t\t\tTr069ServiceInit();\n\t\t}\n\t}",
"@Override\n\tprotected void onCreate (Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\n\t\tAndroidApplicationConfiguration config = new AndroidApplicationConfiguration();\n\t\tinitialize(new MainClass(), config);\n\t\tstartService(new Intent(getBaseContext(),MyServices.class));\n\t}",
"private void initService() {\n\t\tavCommentService = new AvCommentService(getApplicationContext());\n\t}",
"private boolean isGooglePlayServicesAvailable() {\n int status = GooglePlayServicesUtil.isGooglePlayServicesAvailable(this);\n if (ConnectionResult.SUCCESS == status) {\n return true;\n } else {\n GooglePlayServicesUtil.getErrorDialog(status, this, 0).show();\n return false;\n }\n }",
"@RequiresApi(api = Build.VERSION_CODES.JELLY_BEAN)\n @Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n\n setContentView(R.layout.activity_login);\n loginPresenter=new LoginPresenter(this);\n loginPresenter.initConfig();\n }",
"public TripleSolitaireActivity() {\n // request that superclass initialize and manage the Google Play Services for us\n super(BaseGameActivity.CLIENT_ALL);\n enableDebugLog(BuildConfig.DEBUG, TripleSolitaireActivity.TAG);\n }",
"private void initializeGoogleApiClient() {\n\n if (mGoogleApiClient == null) {\n mGoogleApiClient = new GoogleApiClient.Builder(getContext())\n .addConnectionCallbacks(this)\n .addOnConnectionFailedListener(this)\n .addApi(LocationServices.API)\n .build();\n }\n\n }",
"private void setupApp() {\n Log.d(TAG, \"setupApp()\");\n\n // Initialize the BluetoothService to perform bluetooth connections\n mBTService = new BTService(getActivity(), mHandler);\n\n // Initialize the buffer for outgoing messages\n mOutStringBuffer = new StringBuffer(\"\");\n }",
"@Override\n protected void onCreate(@Nullable Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(getLayoutViewId());\n// presenter = getPresenter(typePresenter);\n init();\n }",
"public boolean isGooglePlayAvailable() {\n GoogleApiAvailability api= GoogleApiAvailability.getInstance();\n int isAvailable= api.isGooglePlayServicesAvailable(this);\n\n if (isAvailable == ConnectionResult.SUCCESS) {\n return true;\n }else if (api.isUserResolvableError(isAvailable)){\n Dialog dialog= api.getErrorDialog(this, isAvailable, 0);\n dialog.show();\n }else {\n Toast.makeText(this,\"Can't connect to Play Services\",Toast.LENGTH_LONG).show();\n }\n return false;\n }",
"@Override\n protected void notifyUserOnPlayServicesUnavailable() {\n final View rootView = findViewById(R.id.root_layout);\n if (rootView == null) return;\n Snackbar.make(rootView, R.string.google_play_services_error, Snackbar.LENGTH_LONG)\n .show();\n }",
"@Override\r\n\tpublic void onCreate() {\n\t\tsuper.onCreate();\r\n\t\tdoBindService();\r\n\t\tinitImageLoaderConfig();\r\n\t}",
"private void checkGooglePlayServices() {\n\t\tint status = GooglePlayServicesUtil\n\t\t\t\t.isGooglePlayServicesAvailable(getApplicationContext());\n\t\tif (D) {\n\t\t\tif (status == ConnectionResult.SUCCESS) {\n\t\t\t\t// Success! Do what you want\n\t\t\t\tLog.i(TAG, \"Google Play Services all good\");\n\t\t\t} else if (status == ConnectionResult.SERVICE_MISSING) {\n\t\t\t\tLog.e(TAG, \"Google Play Services not in place\");\n\t\t\t} else if (status == ConnectionResult.SERVICE_VERSION_UPDATE_REQUIRED) {\n\t\t\t\tLog.e(TAG, \"Google Play Serivices outdated\");\n\t\t\t} else if (status == ConnectionResult.SERVICE_DISABLED) {\n\t\t\t\tLog.e(TAG, \"Google Plauy Services disabled\");\n\t\t\t} else if (status == ConnectionResult.SERVICE_INVALID) {\n\t\t\t\tLog.e(TAG,\n\t\t\t\t\t\t\"Google Play Serivices invalid but wtf does that mean?\");\n\t\t\t} else {\n\t\t\t\tLog.e(TAG, \"No way this is gonna happen\");\n\t\t\t}\n\t\t}\n\t}",
"@Override\n public void onStart() {\n super.onStart();\n if (Util.SDK_INT > 23) {\n initializePlayer(this.getContext());\n }\n }",
"@Override\r\n protected void onCreate(Bundle savedInstanceState) {\r\n super.onCreate(savedInstanceState);\r\n setContentView(R.layout.ac_main);\r\n mResultReveiver = new AddressResultReceiver(new Handler());\r\n mTextView = (TextView) findViewById(R.id.my_text);\r\n if (savedInstanceState != null) {\r\n mIsInResolution = savedInstanceState.getBoolean(KEY_IN_RESOLUTION, false);\r\n }\r\n mGoogleApiClient = new GoogleApiClient.Builder(this)\r\n .addApi(LocationServices.API)\r\n .addConnectionCallbacks(this)\r\n .addOnConnectionFailedListener(this)\r\n .build();\r\n mLocationRequest = LocationRequest.create();\r\n mLocationRequest.setInterval(5000);\r\n mLocationRequest.setFastestInterval(1000);\r\n\r\n }",
"private void initializeAndConnectGoogleApi() {\n if (googleApiClient != null) {\n googleApiClient.stopAutoManage(this);\n googleApiClient.disconnect();\n }\n googleApiClient = new GoogleApiClient\n .Builder(this)\n .enableAutoManage(this, 0, this)\n .addApi(Places.GEO_DATA_API)\n .addApi(Places.PLACE_DETECTION_API)\n .addConnectionCallbacks(this)\n .addOnConnectionFailedListener(this)\n .build();\n // Connect if it's not\n if (!googleApiClient.isConnected()) {\n googleApiClient.connect();\n }\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.activity_main);\n\n btnStart = findViewById(R.id.GetStarted);\n\n // check if user already accept permission or not\n if (checkPermissions()) {\n startService();\n }\n\n btnStart.setOnClickListener(view -> GraphActivity.startActivity(MainActivity.this));\n }",
"@Override\n public void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.login); \n//\tYouTubeService service = new YouTubeService(clientId, developer_key);\n\n \n \n \n }",
"private boolean supportsGooglePlayServices() {\n return GooglePlayServicesUtil.isGooglePlayServicesAvailable(this) ==\n ConnectionResult.SUCCESS;\n }",
"private boolean supportsGooglePlayServices() {\n return GooglePlayServicesUtil.isGooglePlayServicesAvailable(this) ==\n ConnectionResult.SUCCESS;\n }",
"@Override\n protected void onCreate(final Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n mAsyncQueryHandler = new AsyncQueryHandler(getContentResolver()) {\n };\n setContentView(R.layout.main);\n googlePlayGamesViewFlipper = (ViewFlipper) findViewById(R.id.google_play_games);\n final Button newGameBtn = (Button) findViewById(R.id.new_game);\n newGameBtn.setOnClickListener(new OnClickListener() {\n @Override\n public void onClick(final View v) {\n newGame();\n }\n });\n final Button statsBtn = (Button) findViewById(R.id.stats);\n statsBtn.setOnClickListener(new OnClickListener() {\n @Override\n public void onClick(final View v) {\n StatsDialogFragment.createInstance(stats).show(getFragmentManager(), \"stats\");\n }\n });\n // Set up sign in button\n final SignInButton signInBtn = (SignInButton) findViewById(R.id.sign_in);\n signInBtn.setOnClickListener(new OnClickListener() {\n @SuppressWarnings(\"synthetic-access\")\n @Override\n public void onClick(final View v) {\n beginUserInitiatedSignIn();\n }\n });\n // Set up Google Play Games buttons\n final Button achievementsBtn = (Button) findViewById(R.id.achievements);\n achievementsBtn.setOnClickListener(new OnClickListener() {\n @Override\n public void onClick(final View v) {\n startActivityForResult(getGamesClient().getAchievementsIntent(), REQUEST_ACHIEVEMENTS);\n }\n });\n final Button leaderboardsBtn = (Button) findViewById(R.id.leaderboards);\n leaderboardsBtn.setOnClickListener(new OnClickListener() {\n @Override\n public void onClick(final View v) {\n startActivityForResult(getGamesClient().getAllLeaderboardsIntent(), REQUEST_LEADERBOARDS);\n }\n });\n getLoaderManager().initLoader(0, null, this);\n }",
"private void initPresenter() {\n\n RequestQueue requestQueue = App.getInstance().getRequestQueue();\n CatsHttp catsHttp = new VolleyCatsHttp(requestQueue);\n\n CatsRepository catsRepository = new CatsRepository(catsHttp);\n\n presenter = new MainPresenter(catsRepository);\n presenter.bindView(this);\n }",
"@Override\n public void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n\n Intent googlePicker = AccountPicker.newChooseAccountIntent(selectedAccount, null,\n new String[]{GoogleAuthUtil.GOOGLE_ACCOUNT_TYPE}, true, null, null, null, null) ;\n intent = googlePicker;\n startActivityForResult(googlePicker,PICK_ACCOUNT_REQUEST);\n }",
"public void setUpGoogleApiClient() {\n mGoogleApiClient = new GoogleApiClient\n .Builder(this)\n .addApi(Places.GEO_DATA_API)\n .addApi(Places.PLACE_DETECTION_API)\n .addApi(LocationServices.API)\n .enableAutoManage(this, this)\n .build();\n }",
"@Override\n public void onCreate() {\n mAuthenticator = new F1ResultsAuthenticator(this);\n }",
"@Override\n\t\tprotected void onPreExecute() {\n\n\t\t\tmProgressHUD = ProgressHUD.show(MakeMyPaymentsTopUp.this, getString(R.string.app_please_wait_label), true, true, this);\n\t\t\t\n\t\t\tPackageInfo pInfo = null ;\n\t\t\t\n\t\t\ttry {\n\t\t\t\tpInfo = getPackageManager().getPackageInfo(getPackageName(), 0);\n\t\t\t\tAppVersion = pInfo.versionName;\n\t\t\t} catch (NameNotFoundException e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t\t\n\t\t}",
"public void launchReceiver() {\n try {\n mCastClientListener = new Cast.Listener() {\n\n @Override\n public void onApplicationDisconnected(int errorCode) {\n Log.d(context.getString(R.string.LOGTAG), \"application has stopped\");\n teardown();\n }\n\n };\n // Connect to Google Play services\n mConnectionCallbacks = new ConnectionCallbacks();\n mConnectionFailedListener = new ConnectionFailedListener();\n Cast.CastOptions.Builder apiOptionsBuilder = Cast.CastOptions\n .builder(mSelectedDevice, mCastClientListener);\n mApiClient = new GoogleApiClient.Builder(this.context)\n .addApi(Cast.API, apiOptionsBuilder.build())\n .addConnectionCallbacks(mConnectionCallbacks)\n .addOnConnectionFailedListener(mConnectionFailedListener)\n .build();\n\n mApiClient.connect();\n } catch (Exception e) {\n Log.e(context.getString(R.string.LOGTAG), \"Failed launchReceiver\", e);\n }\n }",
"@Override\n public void onActivityPreCreated(@NonNull Activity activity, @Nullable Bundle savedInstanceState) {/**/}",
"@Override\n protected void onResume() {\n Log.d(TAG, \"MyTracks.onResume\");\n serviceConnection.bindIfRunning();\n super.onResume();\n }",
"public boolean isGooglePlayServicesAvailable() {\n GoogleApiAvailability googleApiAvailability = GoogleApiAvailability.getInstance();\n int status = googleApiAvailability.isGooglePlayServicesAvailable(this);\n if (status != ConnectionResult.SUCCESS) {\n if (googleApiAvailability.isUserResolvableError(status)) {\n googleApiAvailability.getErrorDialog(this, status, 2404).show();\n }\n return false;\n }\n return true;\n }",
"protected synchronized void createGoogleAPIClient() {\n googleApiClient = new GoogleApiClient.Builder(this)\n .addConnectionCallbacks(this)\n .addOnConnectionFailedListener(this)\n .addApi(LocationServices.API)\n .build();\n }",
"@Override\n public void onCreate() {\n super.onCreate();\n //是不是第一次打开此app\n// initSplashed();\n //缓存文件\n// initCache();\n\n// initUser();\n\n// initAccessToken();\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.activity_main);\n\n playerView = (PlayerView) findViewById(R.id.ExoPlayerVIew);\n initPlayer();\n }",
"@Override\r\n public void onMapReady(GoogleMap googleMap) {\r\n mMap = googleMap;\r\n mMap.setMapType(GoogleMap.MAP_TYPE_NORMAL);\r\n\r\n //Initialize Google Play Services\r\n if (Build.VERSION.SDK_INT >= Build.VERSION_CODES.M) {\r\n if (ContextCompat.checkSelfPermission(this,\r\n Manifest.permission.ACCESS_FINE_LOCATION)\r\n == PackageManager.PERMISSION_GRANTED) {\r\n buildGoogleApiClient();\r\n mMap.setMyLocationEnabled(true);\r\n }\r\n }\r\n else {\r\n buildGoogleApiClient();\r\n mMap.setMyLocationEnabled(true);\r\n }\r\n }",
"public boolean isGooglePlayServicesAvailable() {\n final int connectionStatusCode =\n GooglePlayServicesUtil.isGooglePlayServicesAvailable(context);\n if (GooglePlayServicesUtil.isUserRecoverableError(connectionStatusCode)) {\n showGooglePlayServicesAvailabilityErrorDialog(connectionStatusCode);\n return false;\n } else if (connectionStatusCode != ConnectionResult.SUCCESS ) {\n return false;\n }\n return true;\n }",
"public void onCreate() {\n super.onCreate();\n // An Android handler thread internally operates on a looper.\n mHandlerThread = new HandlerThread(\"HandlerThreadService.HandlerThread\", Process.THREAD_PRIORITY_BACKGROUND);\n mHandlerThread.start();\n // An Android service handler is a handler running on a specific background thread.\n mServiceHandler = new ServiceHandler(mHandlerThread.getLooper());\n\n // Get access to local broadcast manager\n mLocalBroadcastManager = LocalBroadcastManager.getInstance(this);\n }",
"@Override\n\tprotected void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\n\t\tString infoStr = GameConfig\n\t\t\t\t.nativeReadGamePlatformInfo(PlatformAndGameInfo.enPlatform_Jinli);\n\t\ttry {\n\t\t\tJSONObject dataJsonObj = new JSONObject(infoStr);\n\t\t\tAPI_KEY = dataJsonObj.getString(\"appkey\");\n\t\t\tSecretKey = dataJsonObj.getString(\"app_secret\");\n\t\t\tLOGIN_URL = dataJsonObj.getString(\"loginurl\");\n\t\t} catch (JSONException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t\tmActivity = this;\n\t\t\n\t\t//微信分享初始化\n\t\tif(doInitWeChat==false)\n\t\t{\n\t\t\tApplicationInfo appInfo = null;\n\t\t\ttry {\n\t\t\t\tappInfo = this.getPackageManager().getApplicationInfo(this.getPackageName(),PackageManager.GET_META_DATA);\n\t\t\t} catch (NameNotFoundException e) {\n\t\t\n\t\t\t}\n\t\t\n\t\t\tif(appInfo!=null && appInfo.metaData != null)\n\t\t\t{\n\t\t\t\tString WX_APP_ID = appInfo.metaData.getString(\"WX_APP_ID\");\n\t\t\t\tif(WX_APP_ID!=null)\n\t\t\t\t{\n\t\t\t\tConfig.WX_APP_ID = WX_APP_ID;\n\t\t\t\t}\n\t\t\t}\n\t\t\t\n\t\t\tdoInitWeChat = true;\n\t\t}\n\t\tif(null!=Config.WX_APP_ID && !Config.WX_APP_ID.equals(\"\")){\n\t\t\tapi = WXAPIFactory.createWXAPI(this, Config.WX_APP_ID, false);\n\t\t\tapi.registerApp(Config.WX_APP_ID);// 将该app注册到微信\n\t\t}\n\t\t\n\t\t//Amigo组件初始化\n\t\tmGnCommplatform = GnCommplatform.getInstance(mActivity);\n\t\tmGnCommplatform.setFloatingBoxOriginPosition(GnEFloatingBoxPositionModel.LEFT_TOP);\n\t\tmGnCommplatform.init(mActivity, GnEType.GAME, API_KEY);\n \n mAmigoPayer = new AmigoPayer(mActivity);\n mMyPayCallback = mAmigoPayer.new MyPayCallback() {\n\n /* 支付结束\n * @params stateCode 支付结果的返回码,代码成功还是失败\n * 返回码定义,请见文档说明\n */\n @Override\n public void payEnd(String stateCode) {\n // 这句话必须,否则不会自动调起收银台\n super.payEnd(stateCode);\n Log.d(TAG, \" mSubmitButton.setOnClickListener: payEnd,stateCode=\" + stateCode);\n // 如果是升级的场景,升级会在MyPayCallback自动处理,开发者可以不用处理。\n if (isAppUpdate(stateCode)) {\n return;\n }\n \n if(pd != null && pd.isShowing()){\n \tpd.dismiss();\n }\n \n isPay = false;\n // 可以在这里处理自己的业务,下面这几句,实际接入时去掉。\n //Message message = mHandler.obtainMessage(3);\n //message.getData().putString(AmigoPayer.STATE_CODE, stateCode);\n //mHandler.sendMessage(message);\n\n }\n\n private boolean isAppUpdate(String stateCode) {\n return AmigoPayer.RESULT_CODE_UPDATE.equals(stateCode)\n || AmigoPayer.RESULT_CODE_UPDATE_IS_NOT_GIONEE.equals(stateCode);\n }\n };\n\t}",
"@Override\n\tpublic void onCreate() {\n\t\tLog.i(TAG, \"service on create\");\n\t\tsuper.onCreate();\n\t}",
"@Override\n\tprotected void onCreate(Bundle savedInstanceState) {\n\t\tsuper.onCreate(savedInstanceState);\t\t\n\t\tappManager = AppManager.getAppManager();\n\t\tappManager.addActivity(this);\n\t}",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n setContentView(R.layout.activity_gmaps_view);\n\n // Get Channel Name\n Intent intent = getIntent();\n channelName = intent.getExtras().getString(\"channel\");\n Log.d(TAG, \"Passed Channel Name: \" + channelName);\n\n // Set up View: Map & Action Bar\n MapFragment mapFragment = (MapFragment) getFragmentManager()\n .findFragmentById(R.id.map);\n mapFragment.getMapAsync(this);\n ActionBar actionBar = getSupportActionBar();\n actionBar.setDisplayShowHomeEnabled(false);\n actionBar.setDisplayShowTitleEnabled(false);\n }",
"@Override\r\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\r\n Bundle savedInstanceState) {\n View view = inflater.inflate(R.layout.fragment_setup, container, false);\r\n ButterKnife.bind(this, view);\r\n initView(view);\r\n/* toolbar.setNavigationOnClickListener(new View.OnClickListener() {\r\n @Override\r\n public void onClick(View view) {\r\n parentActivity.finish();\r\n }\r\n });*/\r\n getActivity().bindService(PlayService.newIntent(getActivity()), connection, Context.BIND_AUTO_CREATE);\r\n return view;\r\n }",
"@Override\r\n public void onMapReady(GoogleMap googleMap) {\r\n mMap = googleMap;\r\n mMap.setMapType(GoogleMap.MAP_TYPE_HYBRID);\r\n\r\n //Initialize Google Play Services\r\n if (android.os.Build.VERSION.SDK_INT >= Build.VERSION_CODES.M) {\r\n if (ContextCompat.checkSelfPermission(this,\r\n Manifest.permission.ACCESS_FINE_LOCATION)\r\n == PackageManager.PERMISSION_GRANTED) {\r\n buildGoogleApiClient();\r\n mMap.setMyLocationEnabled(true);\r\n }\r\n }\r\n else {\r\n buildGoogleApiClient();\r\n mMap.setMyLocationEnabled(true);\r\n }\r\n\r\n\r\n }",
"@Override\n protected void onCreate(Bundle savedInstanceState) {\n super.onCreate(savedInstanceState);\n\n if (mGameHelper == null) {\n getGameHelper();\n }\n mGameHelper.setup(this);\n\n }",
"protected synchronized void buildGoogleApiClient() {\n //Confirms no instance of GoogleApiClient has been instantiated\n if (mGoogleApiClient == null) {\n mGoogleApiClient = new GoogleApiClient.Builder(this)\n .addConnectionCallbacks(this)\n .addOnConnectionFailedListener(this)\n .addApi(LocationServices.API)\n .build();\n }\n }",
"private boolean isGooglePlayServicesAvailable() {\n int resultCode = GooglePlayServicesUtil.isGooglePlayServicesAvailable(this);\r\n // If Google Play services is available\r\n if (ConnectionResult.SUCCESS == resultCode) {\r\n // In debug mode, log the status\r\n Log.d(\"Location Updates\", \"Google Play services is available.\");\r\n return true;\r\n } else {\r\n // Get the error dialog from Google Play services\r\n Dialog errorDialog = GooglePlayServicesUtil.getErrorDialog( resultCode,\r\n this,\r\n CONNECTION_FAILURE_RESOLUTION_REQUEST);\r\n\r\n // If Google Play services can provide an error dialog\r\n if (errorDialog != null) {\r\n // Create a new DialogFragment for the error dialog\r\n ErrorDialogFragment errorFragment = new ErrorDialogFragment();\r\n errorFragment.setDialog(errorDialog);\r\n errorFragment.show(getFragmentManager(), \"Location Updates\");\r\n }\r\n\r\n return false;\r\n }\r\n }",
"private void setupGoogleSignin() {\n GoogleSignInOptions gso = new GoogleSignInOptions.Builder(GoogleSignInOptions.DEFAULT_SIGN_IN)\n .requestIdToken(getString(R.string.default_web_client_id))\n .requestEmail()\n .build();\n\n // Build a GoogleApiClient with access to the Google Sign-In API and the\n // options specified by gso.\n mGoogleApiClient = new GoogleApiClient.Builder(this)\n .enableAutoManage(this /* FragmentActivity */, this /* OnConnectionFailedListener */)\n .addApi(Auth.GOOGLE_SIGN_IN_API, gso)\n .build();\n }",
"@Override\n public void onCreate() {\n super.onCreate();\n\n\n\n try {\n MultiDex.install(this);\n mContext = getApplicationContext();\n sharePrefrences = new SharePrefrences(App.this);\n\n\n getFont_Regular();\n getFont_Bold();\n createAppFolder();\n\n\n Realm.init(this);\n Fabric.with(this, new Crashlytics());\n realmConfiguration = getRealmConfiguration();\n\n\n\n //startService(new Intent(this, LoginSessionService.class));\n SendBird.init(APP_ID_SENDBIRD, mContext);\n\n\n } catch (Exception e) {\n e.printStackTrace();\n }\n }",
"protected synchronized void buildGoogleApiClient() {\n mGoogleApiClient = new GoogleApiClient.Builder(this)\n .addConnectionCallbacks(this)\n .addOnConnectionFailedListener(this)\n .addApi(LocationServices.API).build();\n if (mGoogleApiClient != null) {\n mGoogleApiClient.connect();\n customProgressDialog = CustomProgressDialog.show(LocationChooser.this);\n }\n }",
"@java.lang.Override\n public boolean hasGoogleService() {\n return stepInfoCase_ == 24;\n }"
]
| [
"0.7277459",
"0.72615445",
"0.72174466",
"0.72174466",
"0.72174466",
"0.711065",
"0.67224103",
"0.6596314",
"0.6488966",
"0.645785",
"0.63720703",
"0.6350369",
"0.62998617",
"0.6265403",
"0.6159358",
"0.6132073",
"0.6109351",
"0.6107967",
"0.60702914",
"0.60504305",
"0.60339856",
"0.6027937",
"0.5995596",
"0.59572566",
"0.5952043",
"0.5939881",
"0.5920571",
"0.5917417",
"0.5882865",
"0.5881777",
"0.58806306",
"0.5842702",
"0.5839097",
"0.5815583",
"0.5812647",
"0.580565",
"0.5801513",
"0.57832706",
"0.5779279",
"0.57768273",
"0.57768273",
"0.5775303",
"0.57552993",
"0.57552874",
"0.574362",
"0.57287997",
"0.57235587",
"0.5723547",
"0.57216996",
"0.5702449",
"0.5688736",
"0.5680599",
"0.567307",
"0.5670831",
"0.5668002",
"0.5658268",
"0.5648922",
"0.56371504",
"0.5631479",
"0.56184",
"0.5610299",
"0.5603083",
"0.56022286",
"0.5597241",
"0.5597225",
"0.5579268",
"0.5575214",
"0.5572996",
"0.5548893",
"0.5538715",
"0.5538715",
"0.553502",
"0.55272824",
"0.5526425",
"0.55217206",
"0.5520817",
"0.55176985",
"0.5513366",
"0.55116326",
"0.5507081",
"0.55059284",
"0.5505857",
"0.55039805",
"0.5496699",
"0.54959",
"0.5482401",
"0.54793084",
"0.5477543",
"0.54749167",
"0.5467923",
"0.5467589",
"0.5467069",
"0.54631937",
"0.54585564",
"0.5458303",
"0.54577756",
"0.54562885",
"0.5456015",
"0.54526556",
"0.54508984"
]
| 0.5673237 | 52 |
This method will display correctly the chart passed as a parameter. | @Override
public void renderChart(ChartData data) {
markers.clear();
mMap.clear();
ArrayList<MapSet> sets= ((MapChartDataImpl)data).getData();
for(int i=0;i<sets.size();i++){
BitmapDescriptor setmarkerico=null;
ArrayList<MapPoint> set=sets.get(i).getData();
if(sets.get(i).getMarker().equals("")||sets.get(i).getMarker().equals("standard"))
setmarkerico=BitmapDescriptorFactory.fromResource(R.drawable.standard);
else if(sets.get(i).getMarker().equals("custom"))
setmarkerico=BitmapDescriptorFactory.fromResource(R.drawable.custom);
else if(sets.get(i).getMarker().equals("plane"))
setmarkerico=BitmapDescriptorFactory.fromResource(R.drawable.plane);
else if(sets.get(i).getMarker().equals("flag"))
setmarkerico=BitmapDescriptorFactory.fromResource(R.drawable.flag);
else if(sets.get(i).getMarker().equals("bus"))
setmarkerico=BitmapDescriptorFactory.fromResource(R.drawable.bus);
//TODO more...
for(int j = 0;j<set.size();j++){
LatLng coord = new LatLng(set.get(j).getLatitude(),set.get(j).getLongitude());
MarkerOptions mo=new MarkerOptions()
.position(coord)
.snippet("" + coord.toString())
.icon(setmarkerico);
if(set.get(j).getId()!=null)
mo.title("" + j + "/" + sets.get(i).getName()+ " (id: "+ set.get(j).getId()+")");
else
mo.title("" + j + "/" + sets.get(i).getName());
markers.add(mMap.addMarker(mo));
/*if(j!=0)
mMap.addPolyline(new PolylineOptions()
.color(Color.parseColor(sets.get(i).getColor()))
.add(new LatLng(set.get(j - 1).getLatitude(), set.get(j - 1).getLongitude()))
.add(coord));*/
}
}
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void View()\n\t{\n\t\tDefaultPieDataset pieDataset = new DefaultPieDataset();\n\t\t\n\t\tfor(String key : result.keySet())\n\t\t{\n\t\t\tpieDataset.setValue(key, Double.parseDouble(result.get(key).toString()));\n\t\t}\n\t\t\n\t\tJFreeChart chart = ChartFactory.createPieChart(title, pieDataset, true, true, true);\n\t\t\n\t\tChartFrame frame = new ChartFrame(\"Pie Chart\", chart);\n\t\t\n\t\tframe.setVisible(true);\n\t\tframe.setSize(450,500);\n\t}",
"public JFreeChart render();",
"public JFrame displayChart() {\n final JFrame frame = new JFrame(\"dds\");\n\n // Schedule a job for the event-dispatching thread:\n // creating and showing this application's GUI.\n try {\n javax.swing.SwingUtilities.invokeAndWait(new Runnable() {\n\n @Override\n public void run() {\n\n frame.setDefaultCloseOperation(WindowConstants.EXIT_ON_CLOSE);\n // XChartPanel<XYChart> chartPanel = new XChartPanel<XYChart>(charts.get(0));\n //() chartPanels.add(chartPanel);\n // frame.add(chartPanel);\n\n // Display the window.\n frame.setName(\"Динаміка системи\");\n frame.pack();\n frame.setVisible(true);\n }\n });\n } catch (InterruptedException e) {\n e.printStackTrace();\n } catch (InvocationTargetException e) {\n e.printStackTrace();\n }\n\n return frame;\n }",
"public void showBarChart() {\r\n\r\n // Count classes\r\n int neutralCountPred = 0;\r\n int negativeCountPred = 0;\r\n int positiveCountPred = 0;\r\n\r\n int neutralCountAnsw = 0;\r\n int negativeCountAnsw = 0;\r\n int positiveCountAnsw = 0;\r\n\r\n for(Integer pred : predictions.values()) {\r\n switch (pred.intValue()) {\r\n case 0:\r\n negativeCountPred++;\r\n break;\r\n case 1:\r\n neutralCountPred++;\r\n break;\r\n case 2:\r\n positiveCountPred++;\r\n break;\r\n default:\r\n System.err.println(\"Illegal class index\");\r\n break;\r\n }\r\n }\r\n System.out.printf(\"PREDICTED \\nnegativeCountPred = %d, neutralCountPred = %d, positiveCountPred = %d\", negativeCountPred,\r\n neutralCountPred, positiveCountPred);\r\n\r\n for(Integer answer : rightAnswers.values()) {\r\n switch (answer.intValue()) {\r\n case 0:\r\n negativeCountAnsw++;\r\n break;\r\n case 1:\r\n neutralCountAnsw++;\r\n break;\r\n case 2:\r\n positiveCountAnsw++;\r\n break;\r\n default:\r\n System.err.println(\"Illegal class index\");\r\n break;\r\n }\r\n }\r\n System.out.printf(\"\\nRIGHT ANSWERS \\nnegativeCountAnsw = %d, neutralCountAnsw = %d, positiveCountAnsw = %d\", negativeCountAnsw,\r\n neutralCountAnsw, positiveCountAnsw);\r\n\r\n // Predicted classes\r\n XYChart.Series<String, Number> dataSeries1 = new XYChart.Series();\r\n dataSeries1.setName(\"Predicted\");\r\n dataSeries1.getData().add(new XYChart.Data(\"Neutral\", neutralCountPred));\r\n dataSeries1.getData().add(new XYChart.Data(\"Positive\", positiveCountPred));\r\n dataSeries1.getData().add(new XYChart.Data(\"Negative\", negativeCountPred));\r\n resultChart.getData().add(dataSeries1);\r\n\r\n // Predicted classes\r\n XYChart.Series<String, Number> dataSeries2 = new XYChart.Series();\r\n dataSeries2.setName(\"Right answers\");\r\n dataSeries2.getData().add(new XYChart.Data(\"Neutral\", neutralCountAnsw));\r\n dataSeries2.getData().add(new XYChart.Data(\"Positive\", positiveCountAnsw));\r\n dataSeries2.getData().add(new XYChart.Data(\"Negative\", negativeCountAnsw));\r\n resultChart.getData().add(dataSeries2);\r\n\r\n }",
"public void chart() {\r\n setLayout(new FlowLayout());\r\n String[] testNumbers = {\"LINEAR SEARCH\", \"TEST 1\", \"TEST 2\", \"TEST 3\", \"TEST 4\", \"TEST 5\", \"TEST 6\", \"TEST 7\", \"TEST 8\", \"TEST 9\", \"TEST 10\", \"AVERAGE\", \"STANDARD DEV.\"};\r\n Object[][] testResult = {{\"500\", lin[0][0], lin[0][1], lin[0][2], lin[0][3], lin[0][4], lin[0][5], lin[0][6], lin[0][7], lin[0][8], lin[0][0], linAvAndDev[0][0], linAvAndDev[0][1]},\r\n {\"10,000\", lin[1][0], lin[1][1], lin[1][2], lin[1][3], lin[1][4], lin[1][5], lin[1][6], lin[1][7], lin[1][8], lin[1][9], linAvAndDev[1][0], linAvAndDev[1][1]},\r\n {\"100,000\", lin[2][0], lin[2][1], lin[2][2], lin[2][3], lin[2][4], lin[2][5], lin[2][6], lin[2][7], lin[2][8], lin[2][9], linAvAndDev[2][0], linAvAndDev[2][1]},\r\n {\"1,000,000\", lin[3][0], lin[3][1], lin[3][2], lin[3][3], lin[3][4], lin[3][5], lin[3][6], lin[3][7], lin[3][8], lin[3][9], linAvAndDev[3][0], linAvAndDev[3][1]},\r\n {\"5,000,000\", lin[4][0], lin[4][1], lin[4][2], lin[4][3], lin[4][4], lin[4][5], lin[4][6], lin[4][7], lin[4][8], lin[4][9], linAvAndDev[4][0], linAvAndDev[4][1]},\r\n {\"7,000,000\", lin[5][0], lin[5][1], lin[5][2], lin[5][3], lin[5][4], lin[5][5], lin[5][6], lin[5][7], lin[5][8], lin[5][9], linAvAndDev[5][0], linAvAndDev[5][1]},\r\n {\"10,000,000\", lin[6][0], lin[6][1], lin[6][2], lin[6][3], lin[6][4], lin[6][5], lin[6][6], lin[6][7], lin[6][8], lin[6][9], linAvAndDev[6][0], linAvAndDev[6][1]},\r\n {\"BINARY SEARCH\", \"TEST 1\", \"TEST 2\", \"TEST 3\", \"TEST 4\", \"TEST 5\", \"TEST 6\", \"TEST 7\", \"TEST 8\", \"TEST 9\", \"TEST 10\", \"AVERAGE\", \"STANDARD DEV.\"},\r\n {\"500\", bin[0][0], bin[0][1], bin[0][2], bin[0][3], bin[0][4], bin[0][5], bin[0][6], bin[0][7], bin[0][8], bin[0][9], linAvAndDev[7][0], linAvAndDev[7][1]},\r\n {\"10,000\", bin[1][0], bin[1][1], bin[1][2], bin[1][3], bin[1][4], bin[1][5], bin[1][6], bin[1][7], bin[1][8], bin[1][9], linAvAndDev[8][0], linAvAndDev[8][1]},\r\n {\"100,000\", bin[2][0], bin[2][1], bin[2][2], bin[2][3], bin[2][4], bin[2][5], bin[2][6], bin[2][7], bin[2][8], bin[2][9], linAvAndDev[9][0], linAvAndDev[9][1]},\r\n {\"1,000,000\", bin[3][0], bin[3][1], bin[3][2], bin[3][3], bin[3][4], bin[3][5], bin[3][6], bin[3][7], bin[3][8], bin[3][9], linAvAndDev[10][0], linAvAndDev[10][1]},\r\n {\"5,000,000\", bin[4][0], bin[4][1], bin[4][2], bin[4][3], bin[4][4], bin[4][5], bin[4][6], bin[4][7], bin[4][8], bin[4][9], linAvAndDev[11][0], linAvAndDev[11][1]},\r\n {\"7,000,000\", bin[5][0], bin[5][1], bin[5][2], bin[5][3], bin[5][4], bin[5][5], bin[5][6], bin[5][7], bin[5][8], bin[5][9], linAvAndDev[12][0], linAvAndDev[12][1]},\r\n {\"10,000,000\", bin[6][0], bin[6][1], bin[6][2], bin[6][3], bin[6][4], bin[6][5], bin[6][6], bin[6][7], bin[6][8], bin[6][9], linAvAndDev[13][0], linAvAndDev[13][1]}};\r\n chart = new JTable(testResult, testNumbers);\r\n chart.setPreferredScrollableViewportSize(new Dimension(1500, 500)); // SETS SIZE OF CHART.\r\n chart.setFillsViewportHeight(true);\r\n JScrollPane scrollPane = new JScrollPane(chart);\r\n add(scrollPane);\r\n }",
"private void helperDisplayChart (boolean isFrequency)\r\n\t{\r\n\t\ttry\r\n\t\t{\r\n\t\t\tint tableSize = DataController.getTable().getTableSize();\r\n\r\n\t\t\tif (tableSize != 0)\r\n\t\t\t{\r\n\t\t\t\t/*!*/DebugLogger.logMessage(\"Displaying the frequency chart\", LOG_MESSAGE_TYPE.INFO);\r\n\r\n\t\t\t\tint indexImage = mainFormLink.getComponentPanelLeft().getComponentComboboxFileName().getSelectedIndex();\r\n\r\n\t\t\t\tif (indexImage >= 0 && indexImage < tableSize)\r\n\t\t\t\t{\r\n\t\t\t\t\tmainFormLink.getComponentPanelRight().getComponentPanelChart().resetChartData();\r\n\r\n\t\t\t\t\tint sampleCount = DataController.getTable().getElement(indexImage).getChannelCount();\r\n\r\n\t\t\t\t\tfor (int i = 0; i < sampleCount; i++)\r\n\t\t\t\t\t{\r\n\r\n\t\t\t\t\t\t/*!*/DebugLogger.logMessage(\"Converting data to display in the chart\", LOG_MESSAGE_TYPE.INFO);\r\n\r\n\t\t\t\t\t\t//---- Prepare data for displaying in the chart box\r\n\t\t\t\t\t\tint chartStartX = DataController.getTable().getElement(indexImage).getDataDevice().getChannel(i).getFeatureVector().getAbsoluteCellLengthIntervalMin();\r\n\t\t\t\t\t\tint chartOffsetX = DataController.getTable().getElement(indexImage).getDataDevice().getChannel(i).getFeatureVector().getAbsoluteCellLengthFrequencyHistogramOffset();\r\n\r\n\t\t\t\t\t\tdouble[] chartDataY = DataController.getTable().getElement(indexImage).getDataDevice().getChannel(i).getFeatureVector().getAbsoluteCellLengthFrequencyHistogram();\r\n\r\n\t\t\t\t\t\t//---- if features has not been extracted return\r\n\t\t\t\t\t\tif (chartDataY == null) \r\n\t\t\t\t\t\t{\r\n\t\t\t\t\t\t\t/*!*/DebugLogger.logMessage(\"Chart data is NULL\", LOG_MESSAGE_TYPE.INFO);\r\n\t\t\t\t\t\t\treturn; \r\n\t\t\t\t\t\t}\r\n\r\n\t\t\t\t\t\tdouble[] chartDataX = new double[chartDataY.length];\r\n\r\n\t\t\t\t\t\tint cellCount = DataController.getTable().getElement(indexImage).getDataDevice().getChannel(i).getFeatureVector().getAbsoluteCellCount();\r\n\r\n\t\t\t\t\t\t/*!*/DebugLogger.logMessage(\"Chart data size is: \" + chartDataY.length, LOG_MESSAGE_TYPE.INFO);\r\n\r\n\t\t\t\t\t\tfor (int k = 0; k < chartDataY.length; k++)\r\n\t\t\t\t\t\t{\r\n\t\t\t\t\t\t\tchartDataX[k] = chartStartX + k * chartOffsetX;\r\n\t\t\t\t\t\t}\r\n\r\n\t\t\t\t\t\tif (isFrequency)\r\n\t\t\t\t\t\t{\r\n\t\t\t\t\t\t\tfor (int k = 0; k < chartDataY.length; k++)\r\n\t\t\t\t\t\t\t{\r\n\t\t\t\t\t\t\t\tchartDataY[k] = chartDataY[k] / cellCount;\r\n\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t}\r\n\r\n\t\t\t\t\t\tString chartDataName = \"\";\r\n\r\n\t\t\t\t\t\tif (i == DataController.getTable().getElement(indexImage).getDataDevice().getControlChannelIndex())\r\n\t\t\t\t\t\t{ chartDataName = \"control \" + (i+1); }\r\n\t\t\t\t\t\telse\r\n\t\t\t\t\t\t{ chartDataName = \"sample\" + (i+1); }\r\n\r\n\t\t\t\t\t\t/*!*/DebugLogger.logMessage(\"Loading data to the chart panel\", LOG_MESSAGE_TYPE.INFO);\r\n\r\n\t\t\t\t\t\tmainFormLink.getComponentPanelRight().getComponentPanelChart().addChartData(chartDataX, chartDataY, chartDataName, isFrequency);\r\n\t\t\t\t\t}\r\n\r\n\t\t\t\t\tmainFormLink.getComponentPanelRight().getComponentPanelChart().displayChartData();\r\n\t\t\t\t}\r\n\r\n\t\t\t}\r\n\r\n\t\t}\r\n\t\tcatch (ExceptionMessage exception)\r\n\t\t{\r\n\t\t\tExceptionHandler.processException(exception);\r\n\t\t}\r\n\t}",
"public void showChart(boolean enable) {\n mainChartPanel.remove(chartPanel);\n\n if (showChartPanel) {\n\n JFreeChart chart = createChart();\n chartPanel = new ChartPanel(chart);\n setDefaultChartOptions();\n mainChartPanel.add(chartPanel, BorderLayout.CENTER);\n\n //chartTableModel = new ChartTableModel(xySeriesCollection.getSeriesCount());\n chartTableModel = new ChartTableModel(dataSets.size());\n\n for (int row = 0; row < dataSets.size(); row++) {\n DataSet data_set = dataSets.get(row);\n chartTableModel.setValueAt(data_set.getDataCollection().getSeries(0).getDescription(), row, 0);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 1);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 2);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 3);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 4);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 5);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 6);\n }\n }\n /*\n for (int row = 0; row < xySeriesCollection.getSeriesCount(); row++) {\n XYPlot plot = (XYPlot) chart.getPlot();\n XYSeries series = xySeriesCollection.getSeries(row);\n chartTableModel.setValueAt(series.getDescription(), row, 0);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 1);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 2);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 3);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 4);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 5);\n chartTableModel.setValueAt(new Double(\"0.00\"), row, 6);\n }\n */\n\n jScrollPane1.getViewport().removeAll();\n if (showTablePanel) {\n JTable table = new JTable(chartTableModel);\n TableCellRenderer renderer2 = new NumberCellRenderer();\n table.getColumnModel().getColumn(1).setCellRenderer(renderer2);\n table.getColumnModel().getColumn(2).setCellRenderer(renderer2);\n table.getColumnModel().getColumn(3).setCellRenderer(renderer2);\n table.getColumnModel().getColumn(4).setCellRenderer(renderer2);\n table.getColumnModel().getColumn(5).setCellRenderer(renderer2);\n table.getColumnModel().getColumn(6).setCellRenderer(renderer2);\n jScrollPane1.getViewport().add(table);\n }\n\n //jSplitPane.add(tablePanel, JSplitPane.BOTTOM);\n\n chartSlider.setEnabled(false);\n chartSlider.setValue(0);\n chartSlider.setEnabled(true);\n\n this.validate();\n }",
"public void displayChart(int choice) {\n\n\t\tif (choice == 1) {\n\t\t\tSystem.out.println(\"---CURRENT TRAVELLING CHART\");\n\t\t\tSystem.out\n\t\t\t\t\t.println(\"TRAIN No\tSTARTINGPOINT\tENDPOINT\tPRICE\t\tDURATION\tSEATSAVAILABLE\");\n\t\t\tIterator<PassengerTrain> itr3 = TrainDetails.passengerList\n\t\t\t\t\t.iterator();\n\t\t\twhile (itr3.hasNext()) {\n\t\t\t\tPassengerTrain object5 = itr3.next();\n\t\t\t\tSystem.out.println(object5.trainId + \"\t\t\" + object5.fromPlace\n\t\t\t\t\t\t+ \"\t\t\" + object5.toPlace + \"\t\t\" + object5.price + \"\t\t\"\n\t\t\t\t\t\t+ object5.duration + \"\t\t\" + object5.seats);\n\n\t\t\t}\n\n\t\t} else if (choice == 2) {\n\t\t\tSystem.out.println(\"---CURRENT TRAVELLING CHART\");\n\t\t\tSystem.out\n\t\t\t\t\t.println(\"TRAIN No\tSTARTINGPOINT\t ENDPOINT\tPRICE\t DURATION\tWEIGHTAVAILABLE\");\n\t\t\tIterator<GoodsTrain> itr4 = TrainDetails.goodsList.iterator();\n\t\t\twhile (itr4.hasNext()) {\n\t\t\t\tGoodsTrain object5 = itr4.next();\n\t\t\t\tSystem.out.println(object5.trainId + \"\t\t\" + object5.fromPlace\n\t\t\t\t\t\t+ \"\t\t \" + object5.toPlace + \"\t\" + object5.price\n\t\t\t\t\t\t+ \" \" + object5.duration + \"\t\t\" + object5.weight);\n\n\t\t\t}\n\n\t\t} else {\n\t\t\tSystem.out.println(\"enter right values\");\n\n\t\t}\n\n\t}",
"protected void setOutputPanelChart(ChartPanel chart) {\n\t\toutputPanel.removeAll();\n\t\toutputPanel.setLayout(new BorderLayout());\n\t\toutputPanel.add(chart, BorderLayout.CENTER);\n\t\toutputPanel.validate();\n\t\toutputPanel.setVisible(true);\n\t\t//frame.setVisible(true);\n\t\t//outputPanel.setLayout(new BorderLayout());\n\t\t//outputPanel.validate();\n\t}",
"public void generateChart(){\n String[][] contents = retrieveFields();\n\n// String msg = \"test - \";\n// printCells(contents);\n\n String[] houseDisplay = new String[12];\n houseDisplay = new String[]{\"6\",\"4\",\"2\",\"1\",\"4\",\"6\",\"3\",\"5\",\"7/8\",\"\",\"5\",\"3\"};\n display(houseDisplay);\n }",
"@Override\r\n\tpublic void render(Canvas canvas) {\n\t\tsuper.render(canvas);\r\n\r\n\t\ttry {\r\n\t\t\tchart.render(canvas);\r\n\t\t} catch (Exception e) {\r\n\t\t\tLog.e(TAG, e.toString());\r\n\t\t}\r\n\t}",
"public void createChart(StatisticPreviewChartViewModel statistic, Chart chart){\n\t chart.getTitle().setText(mainUser.getUsername());\r\n\t chart.getAxisSet().getXAxis(0).getTitle().setText(\"Dzień\");\r\n\t chart.getAxisSet().getYAxis(0).getTitle().setText(\"Kwoty\");\r\n\t // create scatter series\r\n\t ILineSeries series = (ILineSeries) chart.getSeriesSet().createSeries(SeriesType.LINE, \"Wartość\");\r\n\t series.setLineStyle(LineStyle.SOLID);\r\n\r\n\t Date[] days = statistic.getDays().stream().toArray(Date[]::new);\r\n\t series.setYSeries(statistic.getPrices());\r\n\t series.setXDateSeries(days); // xSeries is an array of java.util.Date\r\n\t IAxisTick xTick = chart.getAxisSet().getXAxis(0).getTick();\r\n\t \r\n\t IAxis yAxis = chart.getAxisSet().getYAxis(0);\r\n\t yAxis.adjustRange();\r\n\t \r\n\t yAxis.scrollUp();\r\n\t yAxis.scrollDown();\r\n\t Color color = new Color(Display.getDefault(), 255, 0, 0);\r\n\t series.setSymbolColor(color);\r\n\t \r\n\r\n\t DateFormat format = new SimpleDateFormat(\"dd-MM-yyyy\");\r\n\t xTick.setFormat(format);\r\n\t \r\n\t \r\n\t // adjust the axis range\r\n\t chart.getAxisSet().adjustRange();\r\n\t \r\n\t chart.getParent().layout();\r\n\t comp.getParent().layout();\r\n\t \r\n\r\n\t comp.getParent().layout();\r\n\t chart.setVisible(true);\r\n\t}",
"private void showChart(LineChart mChart, LineData mLineData, int rgb) {\n\t\tmChart.setDrawBorders(false); // 是否在折线图上添加边框\n\t\tmChart.fitScreen();\n\t\t// no description text\n\t\tmChart.setDescription(\"\");// 数据描述\n\t\t// 如果没有数据的时候,会显示这个,类似listview的emtpyview\n\t\tmChart.setNoDataTextDescription(\"You need to provide data for the chart.\");\n\n\t\t// enable / disable grid background\n\t\tmChart.setDrawGridBackground(false); // 是否显示表格颜色\n\n\t\tmChart.getAxisLeft().setEnabled(false);\n\t\tmChart.getAxisRight().setEnabled(false);\n\t\tmChart.getAxisRight().setDrawGridLines(false);\n\t\tmChart.getAxisRight().setTextColor(R.color.transparent_background);\n\t\t\n\t\tmChart.getXAxis().setPosition(XAxisPosition.BOTTOM); // 让x轴在下面\n\t\tmChart.getXAxis().setTextColor(Color.WHITE);\n\t\tmChart.getXAxis().setDrawAxisLine(false);\n\t\tmChart.getXAxis().setDrawGridLines(false);\n\t\t\n\n\t\t\n\t\tmChart.animateX(2500, Easing.EasingOption.EaseInOutQuart);\n\n\t \n\t\tmChart.getLegend().setEnabled(false);\n\t\t\n\t\tmChart.setData(mLineData);\n\n\t}",
"public void onDisplay(Bundle savedInstanceState, Number[] stockValues)\r\n {\n plot = (XYPlot) findViewById(R.id.mySimpleXYPlot);\r\n \r\n // Turn the above arrays into XYSeries':\r\n XYSeries series1 = new SimpleXYSeries(\r\n Arrays.asList(stockValues), // SimpleXYSeries takes a List so turn our array into a List\r\n SimpleXYSeries.ArrayFormat.Y_VALS_ONLY, // Y_VALS_ONLY means use the element index as the x value\r\n \"Series1\"); // Set the display title of the series\r\n\r\n // Create a formatter to use for drawing a series using LineAndPointRenderer\r\n // and configure it from xml:\r\n //LineAndPointFormatter series1Format = new LineAndPointFormatter();\r\n //series1Format.setPointLabelFormatter(new PointLabelFormatter());\r\n //series1Format.configure(getApplicationContext(),\r\n //R.xml.line_point_formatter_with_plf1);\r\n\r\n LineAndPointFormatter series1Format = new LineAndPointFormatter(\r\n \t\tColor.rgb(0, 200, 0),\r\n \t\tColor.rgb(0, 100, 0),\r\n \t\tnull,\r\n \t\tnew PointLabelFormatter(Color.WHITE));\r\n \r\n // add a new series' to the xyplot:\r\n plot.addSeries(series1, series1Format);\r\n\r\n\r\n // reduce the number of range labels\r\n plot.setTicksPerRangeLabel(3);\r\n plot.getGraphWidget().setDomainLabelOrientation(-45);\r\n\r\n }",
"@Override\r\n\tprotected void generateChart() throws Exception {\n\t\t\r\n\t}",
"private void drawChart() throws ParseException {\n Calendar cal = new GregorianCalendar();\n cal.setTime(new Date());\n cal.set(Calendar.DAY_OF_MONTH, -7);\n cal.set(Calendar.HOUR_OF_DAY, 0);\n cal.set(Calendar.MINUTE, 0);\n cal.set(Calendar.SECOND, 0);\n cal.set(Calendar.MILLISECOND, 0);\n Date startTime = cal.getTime();\n Date dayEnd = new Date();\n\n historyChart.setBackgroundColor(Color.WHITE);\n historyChart.setDrawBorders(true);\n\n\n ArrayList<String> xAxis = new ArrayList<>();\n ArrayList<Float> calories = new ArrayList<>();\n ArrayList<Float> calcium = new ArrayList<>();\n ArrayList<Float> sodium = new ArrayList<>();\n ArrayList<Float> carbs = new ArrayList<>();\n ArrayList<Float> cholestrol = new ArrayList<>();\n ArrayList<Float> iron = new ArrayList<>();\n ArrayList<Float> protien = new ArrayList<>();\n ArrayList<Float> sugar = new ArrayList<>();\n ArrayList<Float> totalfat = new ArrayList<>();\n\n NutritionHistory instance = NutritionHistory.getInstance();\n NutritionHistory.getInstance().getNutritionInformation(startTime, dayEnd, nutritionInformation -> {\n DatabaseReference mDatabase = FirebaseDatabase.getInstance().getReference();\n FirebaseUser mCurrentUser = FirebaseAuth.getInstance().getCurrentUser();\n mDatabase.child(\"account\").child(mCurrentUser.getUid()).addListenerForSingleValueEvent(new ValueEventListener() {\n @Override\n public void onDataChange(@NonNull DataSnapshot dataSnapshot) {\n\n double caloriesNeeded = 2000L;\n for (DataSnapshot data : dataSnapshot.getChildren()) {\n switch (data.getKey()) {\n case \"calories\":\n caloriesNeeded = Double.parseDouble(String.valueOf(data.getValue()));\n }\n }\n\n NutrientConverter converter = new NutrientConverter(caloriesNeeded);\n\n NutritionInformation.NutritionInformationBuilder builder = new NutritionInformation.NutritionInformationBuilder();\n NutritionInformation current = builder.build();\n\n Long[] days = nutritionInformation.keySet().stream().toArray(Long[]::new);\n Arrays.sort(days);\n\n for(Long day: days) {\n xAxis.add(sdf2.format(new Date(day)).toString());\n calories.add(converter.convert(\"Calories\", (float) nutritionInformation.get(day).getCalories()));\n calcium.add(converter.convert(\"Calcium\", (float) nutritionInformation.get(day).getCalcium()));\n sodium.add(converter.convert(\"Sodium\", (float)nutritionInformation.get(day).getSodium()));\n carbs.add(converter.convert(\"Carbohydrates\", (float) nutritionInformation.get(day).getCarbohydrates()));\n cholestrol.add(converter.convert(\"Cholesterol\", (float)nutritionInformation.get(day).getCholesterol()));\n iron.add(converter.convert(\"Iron\", (float)nutritionInformation.get(day).getIron()));\n protien.add(converter.convert(\"Protein\", (float)nutritionInformation.get(day).getProtein()));\n sugar.add(converter.convert(\"Sugar\", (float)nutritionInformation.get(day).getSugar()));\n totalfat.add(converter.convert(\"Total Fat\", (float)nutritionInformation.get(day).getTotalFat()));\n }\n Log.i(\"HERE\", xAxis.toString());\n LineDataSet dataCalories = addValues(\"Calories\", calories);\n dataCalories.setColor(Color.RED);\n dataCalories.setLineWidth(2f);\n\n LineDataSet dataCalcium = addValues(\"Calcium\",calcium);\n dataCalcium.setColor(Color.rgb(181, 126\t, 220));\n dataCalcium.setLineWidth(2f);\n\n LineDataSet dataSodium = addValues(\"Sodium\", sodium);\n dataSodium.setColor(Color.BLUE);\n dataSodium.setLineWidth(2f);\n\n LineDataSet dataCarbs = addValues(\"Carbohydrates\",carbs);\n dataCarbs.setColor(Color.GREEN);\n dataCarbs.setLineWidth(2f);\n\n LineDataSet dataCholesterol = addValues(\"Cholesterol\", cholestrol);\n dataCholesterol.setColor(Color.YELLOW);\n dataCholesterol.setLineWidth(2f);\n\n LineDataSet dataIron = addValues(\"Iron\",iron);\n dataIron.setColor(Color.BLACK);\n dataIron.setLineWidth(2f);\n\n LineDataSet dataProtein = addValues(\"Protein\", protien);\n dataProtein.setColor(Color.CYAN);\n dataProtein.setLineWidth(2f);\n\n LineDataSet dataSugar = addValues(\"Sugar\",sugar);\n dataSugar.setColor(Color.MAGENTA);\n dataSugar.setLineWidth(2f);\n\n LineDataSet dataTotalFat = addValues(\"Total Fat\", totalfat);\n dataTotalFat.setColor(Color.rgb(248\t,131, 121));\n dataTotalFat.setLineWidth(2f);\n\n LineData lineData = new LineData(dataCalories, dataCalcium ,dataSodium, dataCarbs, dataIron, dataSugar, dataProtein, dataTotalFat, dataCholesterol);\n historyChart.setData(lineData);\n historyChart.getXAxis().setDrawAxisLine(true);\n historyChart.setVisibleXRange(0, xAxis.size() - 1);\n historyChart.getXAxis().setValueFormatter(new MyXAxisValueFormatter(xAxis));\n historyChart.getXAxis().setPosition(XAxis.XAxisPosition.BOTTOM);\n historyChart.enableScroll();\n historyChart.getDescription().setEnabled(false);\n historyChart.getXAxis().setLabelCount(7, true);\n historyChart.setExtraBottomOffset(20f);\n }\n\n @Override\n public void onCancelled(@NonNull DatabaseError databaseError) {\n\n }\n });\n });\n\n designChart(xAxis);\n historyChart.invalidate();\n }",
"protected void setChartShow() {\n\t\tbackIV.setVisibility(View.GONE);\r\n\t\tbarLayout.setVisibility(View.GONE);\r\n\t\tif (chartShowFrag == null) {\r\n\t\t\tfTransaction.add(R.id.content, new ChartShowFrag(),\r\n\t\t\t\t\tChartShowFrag.TAG);\r\n\t\t} else {\r\n\t\t\tfTransaction.attach(chartShowFrag);\r\n\t\t}\r\n\t\ttitleTV.setText(R.string.chart_show);\r\n\t}",
"private void createchart() {\n int successcount = 0;\n int failedcount = 0;\n \n DefaultPieDataset barchartdata = new DefaultPieDataset();\n \n if(system == null && enterprise == null){\n for(Enterprise ent: network.getEnterpriseDirectory().getEnterpriseList()){\n for(WorkRequest request: ent.getWorkQueue().getWorkQueue()){\n if(request.getStatus() == WorkRequest.Status.ENTERPRISE2ADMINAPPROVED || request.getStatus() == WorkRequest.Status.ORGANIZATION3ADMINAPPROVED)\n successcount++;\n else if(request.getStatus() == WorkRequest.Status.TESTFAILED)\n failedcount++;\n }\n }\n }\n else if(network == null && enterprise == null){\n for(Network net: system.getNetworkList()){\n for(Enterprise ent: net.getEnterpriseDirectory().getEnterpriseList()){\n for(WorkRequest request: ent.getWorkQueue().getWorkQueue()){\n if(request.getStatus() == WorkRequest.Status.ENTERPRISE2ADMINAPPROVED || request.getStatus() == WorkRequest.Status.ORGANIZATION3ADMINAPPROVED)\n successcount++;\n else if(request.getStatus() == WorkRequest.Status.TESTFAILED)\n failedcount++;\n }\n }\n }\n }\n else{\n for(WorkRequest request: enterprise.getWorkQueue().getWorkQueue()){\n if(request.getStatus() == WorkRequest.Status.ENTERPRISE2ADMINAPPROVED || request.getStatus() == WorkRequest.Status.ORGANIZATION3ADMINAPPROVED)\n successcount++;\n else if(request.getStatus() == WorkRequest.Status.TESTFAILED)\n failedcount++;\n }\n }\n \n barchartdata.setValue( \"Successful Trials\",new Double(successcount));\n barchartdata.setValue(\"Failed trials\",new Double(failedcount));\n\n JFreeChart pieChart = ChartFactory.createPieChart(\"Successful versus failed trials\",barchartdata, false, true, false);\n final PiePlot plot=(PiePlot) pieChart.getPlot();\n ChartPanel barPanel = new ChartPanel(pieChart);\n\n dashboardpanel.removeAll();\n dashboardpanel.setLayout(new java.awt.BorderLayout());\n dashboardpanel.add(barPanel, BorderLayout.CENTER);\n dashboardpanel.validate();\n \n }",
"private void createChart() {\n // Preparing...\n String selectedDate = periodComboBox.getSelectedItem().toString();\n String selectedPeriod = periodComboBox.getSelectedItem().toString();\n String periodType = periodTypeComboBox.getSelectedItem().toString();\n periodList = new ArrayList<>();\n PieChart chart;\n\n switch (periodType) {\n case \"Monthly\":\n // Configuring panel\n chartPanel.removeAll();\n chartPanel.revalidate();\n\n // Gathering data\n periodList = new ArrayList<>();\n monthlyTotals.stream().filter((w) -> (w.getDate().equals(selectedDate))).forEach((w) -> {\n periodList.add(w);\n });\n\n // Creating chart\n if (pieChartRadioButton.isSelected()) {\n chart = new PieChart(selectedPeriod + \" Totals\", periodList);\n chartPanel.add(chart.getContentPane());\n chart.pack();\n } else if (barGraphRadioButton.isSelected()) {\n BarGraph bg = new BarGraph(\"\", selectedPeriod + \" Totals\", periodList);\n chartPanel.add(bg.getContentPane());\n bg.pack();\n }\n\n // Displaying\n chartPanel.repaint();\n break;\n case \"Yearly\":\n // Configuring panel\n chartPanel.removeAll();\n chartPanel.revalidate();\n\n // Gathering data\n periodList = new ArrayList<>();\n yearlyTotals.stream().filter((w) -> (w.getDate().equals(selectedDate))).forEach((w) -> {\n periodList.add(w);\n });\n\n // Creating chart\n if (pieChartRadioButton.isSelected()) {\n chart = new PieChart(selectedPeriod + \" Totals\", periodList);\n chartPanel.add(chart.getContentPane());\n chart.pack();\n } else if (barGraphRadioButton.isSelected()) {\n BarGraph bg = new BarGraph(\"\", selectedPeriod + \" Totals\", periodList);\n chartPanel.add(bg.getContentPane());\n bg.pack();\n }\n\n // Displaying\n chartPanel.repaint();\n break;\n case \"Historical\":\n // Configuring panel\n chartPanel.removeAll();\n chartPanel.revalidate();\n\n // Creating chart\n if (pieChartRadioButton.isSelected()) {\n chart = new PieChart(\"Historical Totals\", historicalTotals);\n chartPanel.add(chart.getContentPane());\n chart.pack();\n } else if (barGraphRadioButton.isSelected()) {\n BarGraph bg = new BarGraph(\"\", \"Historical Totals\", historicalTotals);\n chartPanel.add(bg.getContentPane());\n bg.pack();\n }\n\n // Displaying\n chartPanel.repaint();\n }\n }",
"private void displayNonSedData(JSONObject[] jsonObjects) {\r\n final SharedPreferences sharedPref = getSharedPreferences(getString(R.string.pref_file_key),\r\n Context.MODE_PRIVATE);\r\n\r\n int[] stepsPerHour = new int[24];\r\n try {\r\n // Calculate steps per hour\r\n JSONArray jsonArray = jsonObjects[0].getJSONObject(\"activities-steps-intraday\")\r\n .getJSONArray(\"dataset\");\r\n\r\n int steps = 0, interval = 0, hour = 0;\r\n for(int i = 0; i < jsonArray.length(); i++) {\r\n // Step data is requested in 15 minute intervals so we add up the steps\r\n // in every four values to get the total for each hour\r\n steps += Integer.parseInt(jsonArray.getJSONObject(i).getString(\"value\"));\r\n interval++;\r\n if(interval == 4) {// we have reached the end of the hour\r\n stepsPerHour[hour] = steps;\r\n\r\n interval = 0;\r\n steps = 0;\r\n hour++;\r\n }\r\n }\r\n } catch(JSONException | NullPointerException e) {\r\n fitbitRequestError();\r\n return;\r\n }\r\n\r\n BarChart chart = findViewById(R.id.chart);\r\n\r\n ArrayList<BarEntry> entries = new ArrayList<>();\r\n int[] barColours = new int[24];\r\n\r\n // Get non-sedentary hours goal and step threshold for an hour to be non-sedentary\r\n int stepThreshold;\r\n int nonSedHoursGoal = sharedPref.getInt(getString(R.string.non_sed_goal_key), 0);\r\n if(nonSedHoursGoal == 0) {\r\n stepThreshold = 0;\r\n } else {\r\n stepThreshold = getResources().getInteger(R.integer.steps_threshold);\r\n }\r\n\r\n // For each hour in the day create a bar showing the data\r\n // If there is no data create a bar with value 0 so the hour is still shown on the graph\r\n for (int i = 0; i < 24; i++) {\r\n float yValue = (float) stepsPerHour[i];\r\n\r\n entries.add(new BarEntry((float) i, yValue));\r\n\r\n barColours[i] = getResources().getColor(getProgressColour((int) yValue, stepThreshold));\r\n }\r\n\r\n // Show data on chart\r\n BarDataSet dataSet = new BarDataSet(entries, \"\");\r\n dataSet.setColors(barColours);\r\n dataSet.setDrawValues(false);\r\n BarData barData = new BarData(dataSet);\r\n\r\n chart.setData(barData);\r\n chart.invalidate();\r\n\r\n // Show non-sedentary goal\r\n TextView textViewSummary = findViewById(R.id.tv_goal_summary);\r\n if(nonSedHoursGoal > 0) {\r\n textViewSummary.setText(getResources().getString(R.string.goal_hours_steps,\r\n nonSedHoursGoal, stepThreshold));\r\n } else {\r\n textViewSummary.setText(getResources().getString(R.string.no_goal_set));\r\n }\r\n }",
"private void displayCalorieData(JSONObject[] jsonObjects) {\r\n int[] caloriesOut = {};\r\n boolean displayGoal = false;\r\n\r\n try {\r\n // Get calories burned for each day\r\n JSONArray caloriesArray = jsonObjects[0].getJSONArray(\"activities-calories\");\r\n caloriesOut = new int[caloriesArray.length()];\r\n\r\n for(int i = 0; i < caloriesArray.length(); i++) {\r\n int calsOut = Integer.parseInt(caloriesArray.getJSONObject(i)\r\n .getString(\"value\"));\r\n caloriesOut[i] = calsOut;\r\n }\r\n\r\n // Get calorie burn goal, if it was requested\r\n if(jsonObjects.length > 1) {\r\n displayGoal = true;\r\n JSONObject jsonObject = jsonObjects[1];\r\n caloriesOutGoal = Integer.parseInt(jsonObject.getJSONObject(\"goals\")\r\n .getString(\"caloriesOut\"));\r\n }\r\n\r\n } catch(JSONException | NullPointerException e) {\r\n fitbitRequestError();\r\n return;\r\n }\r\n\r\n BarChart chart = findViewById(R.id.chart);\r\n\r\n ArrayList<BarEntry> entries = new ArrayList<>();\r\n int[] barColours = new int[7];\r\n\r\n // For each day in the week create a bar showing the data\r\n // If there is no data create a bar with value 0 so the day is still shown on the graph\r\n for (int i = 0; i < 7; i++) {\r\n float yValue = 0f;\r\n if (i < caloriesOut.length) {\r\n yValue = (float) caloriesOut[i];\r\n }\r\n\r\n entries.add(new BarEntry((float) i, yValue));\r\n\r\n barColours[i] = getResources().getColor(getProgressColour((int) yValue,\r\n caloriesOutGoal));\r\n }\r\n\r\n // Show data on chart\r\n BarDataSet dataSet = new BarDataSet(entries, \"\");\r\n dataSet.setColors(barColours);\r\n dataSet.setDrawValues(false);\r\n BarData barData = new BarData(dataSet);\r\n\r\n chart.setData(barData);\r\n chart.getLegend().setEnabled(false);\r\n\r\n chart.invalidate();\r\n\r\n if(displayGoal) {\r\n // Show calorie burn goal\r\n String unit = getResources().getString(R.string.cal_burn_unit);\r\n TextView textViewSummary = findViewById(R.id.tv_goal_summary);\r\n if(caloriesOutGoal > 0) {\r\n textViewSummary.setText(getResources().getString(R.string.goal_value_unit,\r\n caloriesOutGoal, unit));\r\n } else {\r\n textViewSummary.setText(getResources().getString(R.string.no_goal_set));\r\n }\r\n }\r\n }",
"public static void main(String[] args) {\r\n\r\n // create a chart\r\n double[][] data = new double[][] {\r\n {56.0, -12.0, 34.0, 76.0, 56.0, 100.0, 67.0, 45.0},\r\n {37.0, 45.0, 67.0, 25.0, 34.0, 34.0, 100.0, 53.0},\r\n {43.0, 54.0, 34.0, 34.0, 87.0, 64.0, 73.0, 12.0}};\r\n CategoryDataset dataset = DatasetUtilities.createCategoryDataset(\r\n \"Series \", \"Type \", data);\r\n\r\n JFreeChart chart = null;\r\n boolean drilldown = true;\r\n\r\n if (drilldown) {\r\n CategoryAxis categoryAxis = new CategoryAxis(\"Category\");\r\n ValueAxis valueAxis = new NumberAxis(\"Value\");\r\n BarRenderer renderer = new BarRenderer();\r\n renderer.setBaseToolTipGenerator(\r\n new StandardCategoryToolTipGenerator());\r\n renderer.setBaseItemURLGenerator(new StandardCategoryURLGenerator(\r\n \"bar_chart_detail.jsp\"));\r\n \r\n // add URLs to the series names in the legend...\r\n renderer.setLegendItemURLGenerator(new CategorySeriesLabelGenerator() \r\n {\r\n public String generateLabel(CategoryDataset dataset, int series) {\r\n return \"series.html?series=\" + (series + 1);\r\n }\r\n \r\n });\r\n \r\n // add tool tips to the series names in the legend...\r\n renderer.setLegendItemToolTipGenerator(new CategorySeriesLabelGenerator() \r\n {\r\n public String generateLabel(CategoryDataset dataset, int series) {\r\n return \"Tool tip for series \" + (series + 1);\r\n }\r\n \r\n });\r\n CategoryPlot plot = new CategoryPlot(dataset, categoryAxis, \r\n valueAxis, renderer);\r\n plot.setOrientation(PlotOrientation.VERTICAL);\r\n chart = new JFreeChart(\"Bar Chart\", JFreeChart.DEFAULT_TITLE_FONT,\r\n plot, true);\r\n }\r\n else {\r\n chart = ChartFactory.createBarChart(\r\n \"Vertical Bar Chart\", // chart title\r\n \"Category\", // domain axis label\r\n \"Value\", // range axis label\r\n dataset, // data\r\n PlotOrientation.VERTICAL,\r\n true, // include legend\r\n true,\r\n false\r\n );\r\n }\r\n chart.setBackgroundPaint(java.awt.Color.white);\r\n \r\n // save it to an image\r\n try {\r\n ChartRenderingInfo info = new ChartRenderingInfo(\r\n new StandardEntityCollection());\r\n File file1 = new File(\"barchart100.png\");\r\n ChartUtilities.saveChartAsPNG(file1, chart, 600, 400, info);\r\n\r\n // write an HTML page incorporating the image with an image map\r\n File file2 = new File(\"barchart100.html\");\r\n OutputStream out = new BufferedOutputStream(\r\n new FileOutputStream(file2));\r\n PrintWriter writer = new PrintWriter(out);\r\n writer.println(\"<!DOCTYPE html PUBLIC \\\"-//W3C//DTD XHTML 1.0 Strict//EN\\\"\");\r\n writer.println(\"\\\"http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd\\\">\");\r\n writer.println(\"<html xmlns=\\\"http://www.w3.org/1999/xhtml\\\" lang=\\\"en\\\" xml:lang=\\\"en\\\">\");\r\n writer.println(\"<head><title>JFreeChart Image Map Demo</title></head>\");\r\n writer.println(\"<body><p>\");\r\n ImageMapUtilities.writeImageMap(writer, \"chart\", info);\r\n writer.println(\"<img src=\\\"barchart100.png\\\" \"\r\n + \"width=\\\"600\\\" height=\\\"400\\\" usemap=\\\"#chart\\\" alt=\\\"barchart100.png\\\"/>\");\r\n writer.println(\"</p></body>\");\r\n writer.println(\"</html>\");\r\n writer.close();\r\n\r\n }\r\n catch (IOException e) {\r\n System.out.println(e.toString());\r\n }\r\n\r\n }",
"private void drawChart(Canvas canvas) {\n\t\tfor (int i = 0; i < chart.length; i++) {\n\t\t\tfor (int j = 0; j < chart[i].length; j++) {\n\t\t\t\tif (chart[i][j] != null) {\n\t\t\t\t\tBitmap bitmap = BitmapFactory.decodeResource(\n\t\t\t\t\t\t\tthis.getResources(), chart[i][j].getColour());\n\n\t\t\t\t\tcanvas.drawBitmap(bitmap, j * xRatio - bitmap.getWidth()\n\t\t\t\t\t\t\t/ 2, i * yRatio - bitmap.getHeight() / 2, null);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t}",
"protected void replaceChart() {\n ChartPanel jChart = null;\n jChart = DataGrapher.makeOverlaidMap(m_oDataset,\n m_oTreeDataset, \"East->\", \"\", m_iPlotLengthX,\n m_iPlotLengthY, m_oRenderer, m_oTreeRenderer,\n new java.awt.Dimension(Math.min(600,\n m_iPlotLengthX * 3),\n Math.min(600, m_iPlotLengthY * 3)));\n m_jChartPanel.add(jChart);\n m_jChartPanel.validate();\n m_jChartPanel.repaint();\n }",
"public GraphicalView execute(Context context) {\r\n double[] minValues = new double[] { 4300, 3500, 5300, 4900, 3800, 2900, };\r\n double[] maxValues = new double[] { 8000,7000, 9700, 8600, 7000, 6500};\r\n\r\n XYMultipleSeriesDataset dataset = new XYMultipleSeriesDataset();\r\n RangeCategorySeries series = new RangeCategorySeries(\"波动情况\");\r\n int length = minValues.length;\r\n for (int k = 0; k < length; k++) {\r\n series.add(minValues[k], maxValues[k]);\r\n }\r\n dataset.addSeries(series.toXYSeries());\r\n int[] colors = new int[] { Color.CYAN };\r\n XYMultipleSeriesRenderer renderer = buildBarRenderer(colors);\r\n setChartSettings(renderer, \"好友们最近一周的能量波动范围\", \"用户\", \"能量值\", 0.5, 6.5,\r\n 2000, 12000, Color.GRAY, Color.LTGRAY);\r\n renderer.setBarSpacing(1);\r\n renderer.setXLabels(0);\r\n renderer.setYLabels(10);\r\n renderer.addXTextLabel(1, \"任东卫\");\r\n renderer.addXTextLabel(2, \"罗智宜\");\r\n renderer.addXTextLabel(3, \"郭子涵\");\r\n renderer.addXTextLabel(4, \"谢以荷\");\r\n renderer.addXTextLabel(5, \"赵一援\");\r\n renderer.addXTextLabel(6, \"萧之雁\");\r\n renderer.addYTextLabel(3000, \"心情差\");\r\n renderer.addYTextLabel(4500, \"心情有点差\");\r\n renderer.addYTextLabel(6000, \"心情一般\");\r\n renderer.addYTextLabel(8500, \"心情棒\");\r\n renderer.setMargins(new int[] {30, 70, 30, 70});\r\n renderer.setYLabelsAlign(Align.RIGHT);\r\n SimpleSeriesRenderer r = renderer.getSeriesRendererAt(0);\r\n r.setDisplayChartValues(true);\r\n r.setChartValuesTextSize(12);\r\n r.setChartValuesSpacing(3);\r\n r.setGradientEnabled(true);\r\n r.setGradientStart(4000, Color.parseColor(\"#B0C4DE\"));\r\n r.setGradientStop(8000, Color.parseColor(\"#00AAAA\"));\r\n return ChartFactory.getRangeBarChartView(context, dataset, renderer, Type.DEFAULT);\r\n }",
"private void setupBarChart() {\n mBarChart.setOnChartValueSelectedListener(this);\n mBarChart.getDescription().setEnabled(false);\n mBarChart.setDrawBorders(true);\n mBarChart.setBorderWidth(1.f);\n mBarChart.setBorderColor(Color.parseColor(\"#616161\"));\n mBarChart.setPinchZoom(true);\n mBarChart.setDrawBarShadow(false);\n mBarChart.setDrawGridBackground(false);\n mBarChart.setTouchEnabled(true);\n mBarChart.setDoubleTapToZoomEnabled(false);\n\n Legend l = mBarChart.getLegend();\n l.setVerticalAlignment(Legend.LegendVerticalAlignment.TOP);\n l.setHorizontalAlignment(Legend.LegendHorizontalAlignment.RIGHT);\n l.setOrientation(Legend.LegendOrientation.VERTICAL);\n l.setDrawInside(true);\n l.setYOffset(0f);\n l.setXOffset(10f);\n l.setYEntrySpace(0f);\n l.setTextSize(8f);\n\n// List<String> list = new ArrayList<String>();\n// for(Report report: mReportList){\n// list.add(report.monthYear);\n// }\n// final String[] stringMonthYear = list.toArray(new String[0]);\n\n XAxis xAxis = mBarChart.getXAxis();\n xAxis.setGranularity(1f);\n xAxis.setPosition(XAxis.XAxisPosition.TOP);\n xAxis.setCenterAxisLabels(true);\n xAxis.setValueFormatter(new IAxisValueFormatter() {\n @Override\n public String getFormattedValue(float value, AxisBase axis) {\n int n = (int) value;\n switch (n) {\n case 0:\n if(mReportList.size()<1){\n break;\n }\n return mReportList.get(0).monthYear;\n case 1:\n if(mReportList.size()<2){\n break;\n }\n return mReportList.get(1).monthYear;\n case 2:\n if(mReportList.size()<3){\n break;\n }\n return mReportList.get(2).monthYear;\n case 3:\n if(mReportList.size()<4){\n break;\n }\n return mReportList.get(3).monthYear;\n }\n if (n < 0) {\n return \"Tháng\";\n } else{\n return \"Tháng\";\n }\n }\n });\n\n YAxis leftAxis = mBarChart.getAxisLeft();\n leftAxis.setValueFormatter(new LargeValueFormatter());\n leftAxis.setDrawGridLines(false);\n leftAxis.setSpaceTop(35f);\n leftAxis.setAxisMinimum(0f); // this replaces setStartAtZero(true)\n\n mBarChart.getAxisRight().setEnabled(false);\n\n float groupSpace = 0.04f;\n float barSpace = 0.03f; // x2 dataset\n float barWidth = 0.45f; // x2 dataset\n // (0.45 + 0.03) * 2 + 0.04 = 1.00 -> interval per \"group\"\n\n int startMonth = 0;\n\n ArrayList<BarEntry> yValsThu = new ArrayList<BarEntry>();\n ArrayList<BarEntry> yValsChi = new ArrayList<BarEntry>();\n\n int i = 0;\n for (Report report : mReportList) {\n yValsThu.add(new BarEntry(i, (float) report.incomeTotal));\n yValsChi.add(new BarEntry(i, (float) report.expenseTotal));\n i++;\n }\n\n BarDataSet setThu, setChi;\n\n if (mBarChart.getData() != null && mBarChart.getData().getDataSetCount() > 0) {\n\n setThu = (BarDataSet) mBarChart.getData().getDataSetByIndex(0);\n setChi = (BarDataSet) mBarChart.getData().getDataSetByIndex(1);\n setThu.setValues(yValsThu);\n setChi.setValues(yValsChi);\n mBarChart.getData().notifyDataChanged();\n mBarChart.notifyDataSetChanged();\n\n } else {\n // create 4 DataSets\n setThu = new BarDataSet(yValsThu, \"Thu\");\n setThu.setColor(Color.parseColor(\"#64dd17\"));\n setChi = new BarDataSet(yValsChi, \"Chi\");\n setChi.setColor(Color.parseColor(\"#2196f3\"));\n\n BarData data = new BarData(setThu, setChi);\n data.setValueFormatter(new LargeValueFormatter());\n\n mBarChart.setData(data);\n }\n\n // specify the width each bar should have\n mBarChart.getBarData().setBarWidth(barWidth);\n\n // restrict the x-axis range\n mBarChart.getXAxis().setAxisMinimum(startMonth);\n\n // barData.getGroupWith(...) is a helper that calculates the width each group needs based on the provided parameters\n mBarChart.getXAxis().setAxisMaximum(startMonth + mBarChart.getBarData().getGroupWidth(groupSpace, barSpace) * mReportList.size());\n mBarChart.groupBars(startMonth, groupSpace, barSpace);\n for (IBarDataSet set : mBarChart.getData().getDataSets()) {\n ((BarDataSet) set).setBarBorderWidth(1.f);\n ((BarDataSet) set).setBarBorderColor(Color.parseColor(\"#616161\"));\n }\n mBarChart.invalidate();\n mBarChart.animateY(800);\n\n //[END Setup Bar Char]\n }",
"public void actionPerformed(ActionEvent ae)\n\t{\n\t\tif(ae.getSource()==ok)//ae.getActionCommand().equals(\" OK \")) // pie chart\n\t\t{\n\t\t\tif(!processTitles())\n\t\t\t\treturn;\n\t\t\tif(type==0)\n\t\t\t{\n\t\t\t\tvalues=ws.buildBarChart();\n\t\t\t\tif(values.length>15)\n\t\t\t\t{\n\t\t\t\t\t\twordBundle = map.getWordBundle();\n\t\t\t\t\t\tObject[] options = {wordBundle.getString(\"ok\")};\n\t\t\t\t\t\tString checkRange1 = wordBundle.getString(\"checkRange1\");\n\t\t\t\t\t\tString messageTitle = wordBundle.getString(\"messageTitle\");\n\t\t\t\t\t\tint select = map.showDialog(map,\"checkRange1\",JOptionPane.OK_OPTION, JOptionPane.WARNING_MESSAGE, null,options, 0);\n\t\t\t\t }\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tws.buildPieChart(titles,xvalues,map);\n\t\t\t\t}\n\t\t\t}\n\t\t\telse if(type==1) // vertical bar chart\n\t\t\t{\n\t\t\t\tvalues=ws.buildBarChart();\n\t\t\t\tif(checkDataValidity(values))\n\t\t\t\t{\n\t\t\t\t\tif(values.length>10)\n\t\t\t\t\t{\n\t\t\t\t\t\twordBundle = map.getWordBundle();\n\t\t\t\t\t\tObject[] options = {wordBundle.getString(\"ok\")};\n\t\t\t\t\t\tString checkRange = wordBundle.getString(\"checkRange\");\n\t\t\t\t\t\tString messageTitle = wordBundle.getString(\"messageTitle\");\n\t\t\t\t\t\tint select = map.showDialog(map,\"checkRange\",JOptionPane.OK_OPTION, JOptionPane.WARNING_MESSAGE, null,options, 0);\n\t\t\t\t\t}\n\t\t\t\t\telse\n\t\t\t\t\t{\n\t\t\t\t\t\tJFrame bcV =new barChartV(map,values,titles,xvalues);\n\t\t\t\t\t\tbcV.repaint();\n\t\t\t\t\t\tbcV.validate();\n\t\t\t\t\t\tbcV.show();\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\t//System.out.println(\"Chart can not be drawn\");\n\t\t\t\t\twordBundle = map.getWordBundle();\n\t\t\t\t\tObject[] options = {wordBundle.getString(\"ok\")};\n\t\t\t\t\tString DataCheck = wordBundle.getString(\"DataCheck\");\n\t\t\t\t\tString messageTitle = wordBundle.getString(\"messageTitle\");\n\t\t\t\t\tint select = map.showDialog(map,\"DataCheck\",JOptionPane.OK_OPTION, JOptionPane.WARNING_MESSAGE, null,options, 0);\n\t\t\t\t}\n\t\t\t}\n\t\t\telse if(type==2)//horizontal bar chart\n\t\t\t{\n\t\t\t\tvalues=ws.buildBarChart();\n\t\t\t\t//arrValue av=new arrValue();\n\t\t\t\t//av.selValues=values;\n\t\t\t\tif(checkDataValidity(values))\n\t\t\t\t{\n\t\t\t\t\tif(values.length>10)\n\t\t\t\t\t{\n\t\t\t\t\t\t\twordBundle = map.getWordBundle();\n\t\t\t\t\t\t\tObject[] options = {wordBundle.getString(\"ok\")};\n\t\t\t\t\t\t\tString checkRange = wordBundle.getString(\"checkRange\");\n\t\t\t\t\t\t\tString messageTitle = wordBundle.getString(\"messageTitle\");\n\t\t\t\t\t\t\tint select = map.showDialog(map,\"checkRange\",JOptionPane.OK_OPTION, JOptionPane.WARNING_MESSAGE, null,options, 0);\n\t\t\t\t\t}\n\t\t\t\t\telse\n\t\t\t\t\t{\n\t\t\t\t\t\tJFrame bcH =new barChartH(map,values,titles,xvalues);\n\t\t\t\t\t\tbcH.repaint();\n\t\t\t\t\t\tbcH.validate();\n\t\t\t\t\t\tbcH.show();\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\twordBundle = map.getWordBundle();\n\t\t\t\t\tObject[] options = {wordBundle.getString(\"ok\")};\n\t\t\t\t\tString DataCheck = wordBundle.getString(\"DataCheck\");\n\t\t\t\t\tString messageTitle = wordBundle.getString(\"messageTitle\");\n\t\t\t\t\tint select = map.showDialog(map,\"DataCheck\",JOptionPane.OK_OPTION, JOptionPane.WARNING_MESSAGE, null,options, 0);\n\t\t\t\t}\n\n\t\t\t}\n\t\t\tsetVisible(false);\n\t\t}\n\t\telse if(ae.getSource()==cancel)//getActionCommand().equals(\"CANCEL\"))\n\t\t\tsetVisible(false);\n\n\t}",
"private void drawHighPrices(Graphics g , int contentHeight) {\n // declare local variables:\n int buffer;\n int actualBars;\n int dataMinimum;\n int heightDifference;\n int highPrices[];\n int dataArray[];\n double scale;\n // end of local variables declaration\n\n\n // check fro logical error\n if(data == null) {\n // exit from method\n return;\n } // end of if statement\n\n // check for logical error\n if(data.getHighPrices() == null || data.getHighPrices().length < 2) {\n // exit from method\n return;\n } // end of if statement\n\n\n // find the data minimum\n dataMinimum = ChartData.getMinimum(data.getHighPrices(bars));\n\n // resolve the data array\n highPrices = data.getHighPrices(bars);\n dataArray = new int[highPrices.length];\n System.arraycopy(highPrices, 0, dataArray, 0, highPrices.length);\n\n // resolve the actual bars\n actualBars = dataArray.length;\n\n // find the heightDifference\n heightDifference = ChartData.getMaximum(data.getHighPrices(bars)) - dataMinimum;\n\n // check if the heightDifference is too big and reduce it\n buffer = heightDifference / 50;\n if( buffer > 0) {\n heightDifference = heightDifference / buffer;\n } // end of if statement\n\n //\n for(int c = 0; c < actualBars; c++) {\n //\n dataArray[c] = dataArray[c] - dataMinimum;\n } // end of for loop;\n\n //\n if(buffer > 0) {\n //\n for(int c=0; c < actualBars; c++) {\n //\n dataArray[c] = dataArray[c] / buffer;\n } // end of for loop\n\n } // end of if statement\n\n\n // resolve the scale\n scale = contentHeight / heightDifference;\n\n // select color\n g.setColor(format.getHighPricesColor());\n\n // main drawing loop\n for(int c = 0; c < actualBars -1 ; c++) {\n //\n g.drawLine(getWidth()-textAreaLenght-c*barLenght,\n getHeight()- 30 - (int) Math.round(dataArray[c]*scale),\n getWidth()-textAreaLenght- ( (c+1)*barLenght ),\n getHeight()- 30 - (int) Math.round(dataArray[c+1]*scale));\n } // end of for loop\n\n }",
"public void drawChart() {\n ArrayList<Entry> confuse = new ArrayList<>();\n ArrayList<Entry> attention = new ArrayList<>();\n ArrayList<Entry> engagement = new ArrayList<>();\n ArrayList<Entry> joy = new ArrayList<>();\n ArrayList<Entry> valence = new ArrayList<>();\n // point = \"Brow Furrow: \\n\";\n String dum = null, dum2 = null;\n for (int i = 0; i < size; i++) {\n //point += (\"\" + Emotion.getBrowFurrow(i).getL() + \" seconds reading of \" + Emotion.getBrowFurrow(i).getR() + \"\\n\");\n dum2 = Emotion.getBrowFurrow(i).getL().toString();\n dum = Emotion.getBrowFurrow(i).getR().toString();\n confuse.add(new Entry((float)Double.parseDouble(dum2), Float.parseFloat(dum)));\n dum2 = Emotion.getAttention(i).getL().toString();\n dum = Emotion.getAttention(i).getR().toString();\n attention.add(new Entry((float)Double.parseDouble(dum2), Float.parseFloat(dum)));\n dum2 = Emotion.getEngagement(i).getL().toString();\n dum = Emotion.getEngagement(i).getR().toString();\n engagement.add(new Entry((float)Double.parseDouble(dum2), Float.parseFloat(dum)));\n dum2 = Emotion.getJoy(i).getL().toString();\n dum = Emotion.getJoy(i).getR().toString();\n joy.add(new Entry((float)Double.parseDouble(dum2), Float.parseFloat(dum)));\n dum2 = Emotion.getValence(i).getL().toString();\n dum = Emotion.getValence(i).getR().toString();\n valence.add(new Entry((float)Double.parseDouble(dum2), Float.parseFloat(dum)));\n }\n\n LineDataSet data1 = new LineDataSet(confuse,\"Confuse\");\n LineDataSet data2 = new LineDataSet(attention,\"Attention\");\n LineDataSet data3 = new LineDataSet(engagement,\"Engagement\");\n LineDataSet data4 = new LineDataSet(joy,\"Engagement\");\n LineDataSet data5 = new LineDataSet(valence,\"Valence\");\n data1.setColor(Color.BLUE);\n data1.setDrawCircles(false);\n data2.setColor(Color.YELLOW);\n data2.setDrawCircles(false);\n data3.setColor(Color.GRAY);\n data3.setDrawCircles(false);\n data4.setColor(Color.MAGENTA);\n data4.setDrawCircles(false);\n data5.setColor(Color.GREEN);\n data5.setDrawCircles(false);\n\n\n dataSets.add(data1);\n dataSets.add(data2);\n dataSets.add(data3);\n dataSets.add(data4);\n dataSets.add(data5);\n }",
"public void updateChart() {\n\t\tdouble val_min = Double.MAX_VALUE;\n\t\tdouble val_max = -Double.MAX_VALUE;\n\t\tVector<CurveData> cdV = new Vector<CurveData>();\n\n\t\tint maxMarkLength = 1;\n\t\tint nClmns = barColumns.size();\n\t\tint nMaxLines = 0;\n\t\tfor ( final BarColumn bc : barColumns ) {\n\t\t\tif (bc.show()) {\n\t\t\t\tfor (int j = 0; j < bc.size(); j++) {\n\t\t\t\t\tif (val_min > bc.value(j)) {\n\t\t\t\t\t\tval_min = bc.value(j);\n\t\t\t\t\t}\n\t\t\t\t\tif (val_max < bc.value(j)) {\n\t\t\t\t\t\tval_max = bc.value(j);\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t\tif (nMaxLines < bc.size()) {\n\t\t\t\tnMaxLines = bc.size();\n\t\t\t}\n\t\t\tif (maxMarkLength < bc.marker().length()) {\n\t\t\t\tmaxMarkLength = bc.marker().length();\n\t\t\t}\n\t\t}\n\n\t\tString tmp_str = \"\";\n\t\tfor (int i = 0; i < maxMarkLength; i++) {\n\t\t\ttmp_str = tmp_str + \" \";\n\t\t}\n\t\temptyStr = tmp_str;\n\n\t\t//System.out.println(\"debug =========== val_min=\" + val_min + \" val_max=\" + val_max);\n\n\t\tif (val_min * val_max > 0.) {\n\t\t\tif (val_min > 0.) {\n\t\t\t\tval_min = 0.;\n\t\t\t} else {\n\t\t\t\tval_max = 0.;\n\t\t\t}\n\t\t}\n\n\t\tint iMin = GP.getScreenX(GP.getCurrentMinX());\n\t\tint iMax = GP.getScreenX(GP.getCurrentMaxX());\n\t\t//System.out.println(\"debug iMin=\" + iMin + \" iMax=\" + iMax);\n\t\twidth = (int) ((iMax - iMin) / (1.9 * nMaxLines * nClmns));\n\t\t//System.out.println(\"debug width=\" + width);\n\t\tif (width < 1) {\n\t\t\twidth = 1;\n\t\t}\n\n\t\t//make line from\n\t\tCurveData cd = cvV.get(0);\n\t\tif (nClmns > 0) {\n\t\t\tcd.clear();\n\t\t\tcd.addPoint(0., 0.);\n\t\t\tcd.addPoint(1.0 * (nClmns + 1), 0.);\n\t\t\tcd.setColor(Color.black);\n\t\t\tcd.setLineWidth(1);\n\t\t\tcd.findMinMax();\n\t\t\tcdV.add(cd);\n\t\t}\n\n\t\tint cvCount = 1;\n\t\tfor (int i = 1; i <= nClmns; i++) {\n\t\t\tBarColumn bc = barColumns.get(i - 1);\n\t\t\tif (bc.show()) {\n\t\t\t\tdouble d_min = i - 0.35;\n\t\t\t\tdouble d_max = i + 0.35;\n\t\t\t\tint nL = bc.size();\n\t\t\t\tdouble st = (d_max - d_min) / nL;\n\t\t\t\tfor (int j = 0; j < nL; j++) {\n\t\t\t\t\tif (bc.show(j)) {\n\t\t\t\t\t\tif(cvCount < cvV.size()){\n\t\t\t\t\t\t\tcd = cvV.get(cvCount);\n\t\t\t\t\t\t}\n\t\t\t\t\t\telse{\n\t\t\t\t\t\t\tcd = new CurveData();\n\t\t\t\t\t\t\tcvV.add(cd);\n\t\t\t\t\t\t}\n\t\t\t\t\t\tcd.clear();\n\t\t\t\t\t\tcd.addPoint(d_min + (j + 0.5) * st, 0.);\n\t\t\t\t\t\tcd.addPoint(d_min + (j + 0.5) * st, bc.value(j));\n\t\t\t\t\t\tcd.setLineWidth(width);\n\t\t\t\t\t\tif (bc.getColor(j) == null) {\n\t\t\t\t\t\t\tcd.setColor(bcColor.getColor(j));\n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\tcd.setColor(bc.getColor(j));\n\t\t\t\t\t\t}\n\t\t\t\t\t\tcd.findMinMax();\n\t\t\t\t\t\tcdV.add(cd);\n\t\t\t\t\t\tcvCount++;\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\n\t\t//System.out.println(\"debug ===========start plotting=============== nClmns= \" + nClmns);\n\t\tif (val_min < val_max) {\n\t\t\tformatter.makeAnalysis(val_min, val_max);\n\t\t\tGP.setNumberFormatY(formatter.getFormat());\n\t\t\tGP.setLimitsAndTicksY(formatter.getMin(), formatter.getMax(), formatter.getStep());\n\t\t}\n\n\t\tif (barColumns.size() >= 10) {\n\t\t\tGP.getCurrentGL().setXminOn(false);\n\t\t\tGP.getCurrentGL().setXmaxOn(false);\n\t\t}\n\n\t\tif (cdV.size() > 0) {\n\t\t\tGP.setCurveData(cdV);\n\t\t} else {\n\t\t\tGP.removeAllCurveData();\n\t\t}\n\t}",
"@Override\r\n\tpublic void refreshChart2() {\n\t\tString[] s = new String[categoryStrings.size()];\r\n\t\ts= categoryStrings.toArray(s);\r\n\t\tif(getChartType().equals(\"StepLineChart\")) {\r\n\t\t\tDateAxis xAxis = new DateAxis(\"time\");\r\n\t\t\tValueAxis yAxis = new SymbolAxis(\"status\", s);\r\n\t\t\tXYStepRenderer renderer = new XYStepRenderer();\r\n\t\t\tXYPlot plot = new XYPlot(chartDataset, xAxis, yAxis, renderer);\r\n\t\t\tsetChart(new JFreeChart(null, new Font(\"Tahoma\", 0, 18), plot, true));\r\n\t\t}\r\n\t\t((GridBagLayout)getMonitoringPanel().getLayout()).rowHeights[2] = getMinimumHeight();\r\n\t\tgetMonitoringPanel().setPreferredSize(new Dimension(getMinimumWhidth(), (int) Math.round(getMonitoringPanel().getPreferredSize().getHeight())));\r\n\t\tsetVisible(isVisible());\r\n\t\tgetMonitoringPanel().setVisible(isVisible());\r\n\t\tif (chartPanel != null) \r\n\t\t\tgetMonitoringPanel().remove(chartPanel);\r\n\t\tsetChartPanel(new ChartPanel(chart));\r\n\t\tgetMonitoringPanel().add(chartPanel, new GridBagConstraints(0, 2, 6, 1, 0.0, 0.0,\r\n\t\t\t\tGridBagConstraints.CENTER, GridBagConstraints.BOTH,\r\n\t\t\t\tnew Insets(0, 0, 5, 5), 0, 0));\r\n\t}",
"@Override\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\n Bundle savedInstanceState) {\n View rootView = inflater.inflate(R.layout.fragment_graph, container, false);\n mChart = (LineChart) rootView.findViewById(R.id.historical_chart);\n Paint p = mChart.getPaint(Chart.PAINT_INFO);\n p.setColor(getResources().getColor(android.support.v7.appcompat.R.color.material_grey_300));\n p.setTextSize(getResources().getDimensionPixelSize(R.dimen.graph_error_text_size));\n if(mStockDetail != null && mStockDetail.getHistoryStr() != null) {\n TextView stockName = (TextView) rootView.findViewById(R.id.stock_name);\n stockName.setText(mStockDetail.getName() + StockAdapter.OPEN_BRACE + mStockDetail.getSymbol() + StockAdapter.CLOSE_BRACE);\n stockName.setContentDescription(mStockDetail.getName() + StockAdapter.OPEN_BRACE + mStockDetail.getSymbol() + StockAdapter.CLOSE_BRACE);\n //mChart = (LineChart) rootView.findViewById(R.id.historical_chart);\n // no description text\n mChart.getDescription().setEnabled(false);\n\n // enable touch gestures\n mChart.setTouchEnabled(true);\n\n // enable scaling and dragging\n mChart.setDragEnabled(true);\n mChart.setScaleEnabled(true);\n mChart.setDrawGridBackground(false);\n mChart.setHighlightPerDragEnabled(true);\n // set an alternative background color\n\n //mChart.setBackgroundColor(Color.WHITE);\n\n // get the legend (only possible after setting data)\n Legend l = mChart.getLegend();\n l.setEnabled(false);\n\n XAxis xAxis = mChart.getXAxis();\n //xAxis.setPosition(XAxis.XAxisPosition.TOP_INSIDE);\n //xAxis.setTextSize(10f);\n xAxis.setTextColor(Color.WHITE);\n xAxis.setDrawAxisLine(false);\n xAxis.setDrawGridLines(false);\n xAxis.setCenterAxisLabels(true);\n //xAxis.setGranularity(1f); // one hour\n xAxis.setValueFormatter(new IAxisValueFormatter() {\n\n //private SimpleDateFormat mFormat = new SimpleDateFormat(\"dd MMM yy\");\n private SimpleDateFormat mFormat = new SimpleDateFormat(\"dd MMM yy\");\n\n @Override\n public String getFormattedValue(float value, AxisBase axis) {\n\n //long millis = TimeUnit.HOURS.toMillis((long) value);\n return mFormat.format(new Date((long) value));\n }\n });\n\n YAxis leftAxis = mChart.getAxisLeft();\n leftAxis.setPosition(YAxis.YAxisLabelPosition.INSIDE_CHART);\n leftAxis.setTextColor(Color.WHITE);\n leftAxis.setDrawGridLines(false);\n leftAxis.setGranularityEnabled(true);\n leftAxis.setDrawLabels(true);\n final DecimalFormat dollarFormat = (DecimalFormat) NumberFormat.getCurrencyInstance(Locale.US);\n leftAxis.setValueFormatter(new IAxisValueFormatter() {\n @Override\n public String getFormattedValue(float value, AxisBase axis) {\n return dollarFormat.format(value);\n }\n });\n YAxis rightAxis = mChart.getAxisRight();\n rightAxis.setEnabled(false);\n\n\n LineDataSet dataSet = new LineDataSet(mStockDetail.getDataEntries(), \"Label\"); // add entries to dataset\n dataSet.setColor(Color.WHITE);\n //dataSet.setCircleColor(Color.BLUE);\n dataSet.setDrawCircles(false);\n dataSet.setDrawFilled(true);\n //dataSet.setFillColor(R.color.colorPrimary);\n LineData lineData = new LineData(dataSet);\n //lineData.setDrawValues(false);\n //lineData.setValueTextSize(10f);\n lineData.setValueTextColor(Color.WHITE);\n mChart.setData(lineData);\n mChart.notifyDataSetChanged();\n mChart.invalidate(); // refresh\n mChart.setContentDescription(getString(R.string.a11y_history_graph,\n Float.toString(mChart.getYMin()), Float.toString(mChart.getYMax())));\n }\n return rootView;\n }",
"public void plotData(boolean appendingData, boolean mean) {\n\n // Add data to existing plaot if appending.\n if (appendingData && chartpanel != null) {\n appendData();\n } else {\n String xaxisname = \"Plane\";\n // Create an chart empty.\n if (mean) {\n xaxisname = \"Length\";\n }\n final JFreeChart chart = createChart(xaxisname);\n chart.setBackgroundPaint(Color.WHITE); //DJ: 09/22/2014\n\n // Get the data.\n if (mean) {\n data = getLineDataset();\n } else {\n data = getDataset();\n }\n\n // Apply data to the plot\n MimsXYPlot xyplot = (MimsXYPlot) chart.getPlot();\n\n xyplot.setBackgroundPaint(Color.WHITE); //DJ: 09/22/2014\n\n xyplot.setDataset(data);\n xyplot.setRois(rois);\n xyplot.setParent(this);\n\n //DJ 09/22/2014\n final int numberOfSeries = xyplot.getSeriesCount();\n //System.out.println(\"number-of-series = \" + numberOfSeries);\n\n /*\n System.out.println(\"range up limit = \" + xyplot.getRangeAxis().getRange().getUpperBound());\n System.out.println(\"range down limit = \" + xyplot.getRangeAxis().getRange().getLowerBound());\n System.out.println(\"domain up limit = \" + xyplot.getDomainAxis().getRange().getUpperBound());\n System.out.println(\"domain down limit = \" + xyplot.getDomainAxis().getRange().getLowerBound());\n */\n // Generate the layout.\n //chartpanel = new MimsChartPanel(chart);\n chartpanel = new MimsChartPanel(chart);\n chartpanel.addMouseListener(this);\n chartpanel.setPreferredSize(new java.awt.Dimension(600, 400));\n String lastFolder = ui.getLastFolder();\n if (lastFolder != null) {\n if (new File(lastFolder).exists()) {\n chartpanel.setDefaultDirectoryForSaveAs(new File(lastFolder));\n }\n }\n this.add(chartpanel);\n\n chartpanel.setNumberOfSeries(numberOfSeries);\n\n // DJ: 09/22/2014\n // Add menu item for thikining or the plot lines\n // increase lines thikness\n JMenuItem incresaseLinesThikness = new JMenuItem(\"Increase Lines Thickness\");\n incresaseLinesThikness.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n //DJ\n\n lineThikness = chartpanel.getLineThikness();\n\n if (chartpanel.setLineThikness(lineThikness + 0.5f)) {\n lineThikness = chartpanel.getLineThikness();\n //if (lineThikness + 1.0f <= maxThikness) {\n // lineThikness += 1.0f;\n\n BasicStroke stroke = new BasicStroke(lineThikness);\n Plot plot = chart.getXYPlot();\n\n if (plot instanceof CategoryPlot) {\n CategoryPlot categoryPlot = chart.getCategoryPlot();\n CategoryItemRenderer cir = categoryPlot.getRenderer();\n try {\n for (int i = 0; i < numberOfSeries; i++) {\n cir.setSeriesStroke(i, stroke); //series line style\n }\n } catch (Exception ex) {\n System.err.println(ex);\n }\n } else if (plot instanceof XYPlot) {\n\n XYPlot xyPlot = chart.getXYPlot();\n XYItemRenderer xyir = xyPlot.getRenderer();\n try {\n for (int i = 0; i < numberOfSeries; i++) {\n xyir.setSeriesStroke(i, stroke); //series line style\n }\n } catch (Exception ex) {\n System.err.println(ex);\n }\n }\n }\n }\n });\n\n // increase lines thikness\n JMenuItem decreaseLinesThikness = new JMenuItem(\"Decrease Lines Thickness\");\n decreaseLinesThikness.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n //DJ\n lineThikness = chartpanel.getLineThikness();\n\n if (chartpanel.setLineThikness(lineThikness - 0.5f)) {\n lineThikness = chartpanel.getLineThikness();\n //if (lineThikness - 1.0f >= minThikness) {\n // lineThikness -= 1.0f;\n\n BasicStroke stroke = new BasicStroke(lineThikness);\n Plot plot = chart.getXYPlot();\n\n if (plot instanceof CategoryPlot) {\n CategoryPlot categoryPlot = chart.getCategoryPlot();\n CategoryItemRenderer cir = categoryPlot.getRenderer();\n try {\n for (int i = 0; i < numberOfSeries; i++) {\n cir.setSeriesStroke(i, stroke); //series line style\n }\n } catch (Exception ex) {\n System.err.println(ex);\n }\n } else if (plot instanceof XYPlot) {\n\n XYPlot xyPlot = chart.getXYPlot();\n XYItemRenderer xyir = xyPlot.getRenderer();\n try {\n for (int i = 0; i < numberOfSeries; i++) {\n xyir.setSeriesStroke(i, stroke); //series line style\n }\n } catch (Exception ex) {\n System.err.println(ex);\n }\n }\n }\n }\n });\n\n chartpanel.getPopupMenu().addSeparator();\n chartpanel.getPopupMenu().add(incresaseLinesThikness);\n chartpanel.getPopupMenu().add(decreaseLinesThikness);\n\n JMenu changePlotColor = new JMenu(\"Change Plot Color\");\n final JMenuItem black = new JMenuItem(\"BLACK\");\n final JMenuItem blue = new JMenuItem(\"BLUE\");\n final JMenuItem grey = new JMenuItem(\"GRAY\");\n final JMenuItem green = new JMenuItem(\"GREEN\");\n final JMenuItem red = new JMenuItem(\"RED\");\n final JMenuItem yellow = new JMenuItem(\"YELLOW\");\n final JMenuItem purple = new JMenuItem(\"PURPLE\");\n final JMenuItem brown = new JMenuItem(\"BROWN\");\n final JMenuItem orange = new JMenuItem(\"ORANGE\");\n final JMenuItem darkGreen = new JMenuItem(\"DARK GREEN\");\n final JMenuItem lightBlue = new JMenuItem(\"LIGHT BLUE\");\n\n black.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(black.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 97, 'a');\n chartpanel.keyPressed(ev);\n }\n });\n blue.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(blue.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 98, 'b');\n chartpanel.keyPressed(ev);\n }\n });\n grey.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(grey.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 101, 'e');\n chartpanel.keyPressed(ev);\n }\n });\n green.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(green.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 103, 'g');\n chartpanel.keyPressed(ev);\n }\n });\n red.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(red.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 114, 'r');\n chartpanel.keyPressed(ev);\n }\n });\n yellow.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(yellow.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 121, 'y');\n chartpanel.keyPressed(ev);\n }\n });\n purple.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(purple.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 112, 'p');\n chartpanel.keyPressed(ev);\n }\n });\n brown.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(brown.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 119, 'w');\n chartpanel.keyPressed(ev);\n }\n });\n orange.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(orange.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 111, 'o');\n chartpanel.keyPressed(ev);\n }\n });\n darkGreen.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(darkGreen.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 100, 'd');\n chartpanel.keyPressed(ev);\n }\n });\n lightBlue.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n KeyEvent ev = new KeyEvent(lightBlue.getComponent(), e.getID(), e.getWhen(), e.getModifiers(), 108, 'l');\n chartpanel.keyPressed(ev);\n }\n });\n\n changePlotColor.add(black);\n changePlotColor.add(blue);\n changePlotColor.add(grey);\n changePlotColor.add(green);\n changePlotColor.add(red);\n changePlotColor.add(yellow);\n changePlotColor.add(purple);\n changePlotColor.add(brown);\n changePlotColor.add(orange);\n changePlotColor.add(darkGreen);\n changePlotColor.add(lightBlue);\n\n chartpanel.getPopupMenu().add(changePlotColor);\n\n // Add menu item for showing/hiding crosshairs.\n JMenuItem xhairs = new JMenuItem(\"Show/Hide Crosshairs\");\n xhairs.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n showHideCrossHairs(chartpanel);\n }\n });\n chartpanel.getPopupMenu().addSeparator();\n chartpanel.getPopupMenu().add(xhairs);\n // Add menu item for showing/hiding crosshairs.\n JMenuItem pointhairs = new JMenuItem(\"Add point roi at crosshairs\");\n pointhairs.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n if (pointX > 0 && pointY > 0) {\n ui.getRoiManager().add(new PointRoi(pointX, pointY));\n ui.updateAllImages();\n }\n }\n });\n chartpanel.getPopupMenu().add(pointhairs);\n // Add menu item for toggling between linear and log scales.\n JMenuItem logscale = new JMenuItem(\"Log/Linear scale\");\n logscale.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n MimsJFreeChart.logLinScale(chartpanel);\n }\n });\n chartpanel.getPopupMenu().add(logscale);\n\n // Add menu item for exporting plot to report.\n /*JMenuItem genreport = new JMenuItem(\"Generate Report\");\n genreport.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n generateReport();\n }\n });\n chartpanel.getPopupMenu().add(genreport);*/\n JMenuItem libreoffice = new JMenuItem(\"Add to Libreoffice\");\n libreoffice.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n mimsUno.insertGraph(getImage(), \"test\", \"test\", \"test\");\n }\n });\n chartpanel.getPopupMenu().add(libreoffice);\n\n // Replace Save As... menu item.\n chartpanel.getPopupMenu().remove(3);\n JMenuItem saveas = new JMenuItem(\"Save as...\");\n saveas.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n saveAs();\n }\n });\n chartpanel.getPopupMenu().add(saveas, 3);\n\n // Add an option for getting the underlying data\n JMenuItem asTextMenuItem = new javax.swing.JMenuItem(\"Display text\");\n asTextMenuItem.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n displayProfileData();\n }\n });\n chartpanel.getPopupMenu().add(asTextMenuItem, 2);\n\n // Add key listener.\n KeyboardFocusManager.getCurrentKeyboardFocusManager().addKeyEventDispatcher(new KeyEventDispatcher() {\n public boolean dispatchKeyEvent(KeyEvent e) {\n if (e.getID() == KeyEvent.KEY_PRESSED && thisHasFocus()) {\n chartpanel.keyPressed(e);\n }\n return false;\n }\n });\n\n pack();\n setVisible(true);\n\n }\n }",
"public void getPaedCommodSTKA(final String mUid,final String mYear, final String mWeekNo){\n mCombComdtySTKC = new CombComdtySTKC() {\n @Override\n protected void onPostExecute(String results) {\n // dialog.dismiss();\n if (!results.equalsIgnoreCase(\"error\")) {\n try {\n JSONObject objAdults = new JSONObject(results);\n if(objAdults.getString(\"status\").equalsIgnoreCase(\"ok\")) {\n Log.e(\"here CombData\", \"\"+results);\n JSONArray mRes = objAdults.getJSONArray(\"results\");\n\n String[] weeks = new String[mRes.length()];\n\n for(int i= 0; i< mRes.length();i++){\n JSONArray array = mRes.getJSONArray(i);\n ClientRisk.add(new BarEntry(i+1, array.getInt(2)));\n StockoutRates.add(new Entry(i+1,(float) array.getDouble(1)));\n ReportingRates.add(new Entry(i+1, (float) array.getDouble(3)));\n weeks[i] = array.getString(0);\n\n }\n Collections.sort(ClientRisk, new EntryXComparator());\n Collections.sort(StockoutRates, new EntryXComparator());\n Collections.sort(ReportingRates, new EntryXComparator());\n mChart.setDrawGridBackground(true);\n mChart.setDrawBarShadow(false);\n mChart.setClickable(false);\n mChart.setHighlightFullBarEnabled(false);\n // draw bars behind lines\n mChart.setDrawOrder(new CombinedChart.DrawOrder[]{\n CombinedChart.DrawOrder.BAR, CombinedChart.DrawOrder.LINE\n });\n\n mChart.setOnTouchListener(new View.OnTouchListener(){\n @Override\n public boolean onTouch(View view, MotionEvent motionEvent) {\n return false;\n }\n });\n //Set the Legends Orientation\n Legend l = mChart.getLegend();\n l.setWordWrapEnabled(true);\n l.setVerticalAlignment(Legend.LegendVerticalAlignment.BOTTOM);\n l.setHorizontalAlignment(Legend.LegendHorizontalAlignment.CENTER);\n l.setOrientation(Legend.LegendOrientation.HORIZONTAL);\n\n //Set Right And Left Axis\n YAxis rightAxis = mChart.getAxisRight();\n rightAxis.setDrawGridLines(false);\n rightAxis.setAxisMinimum(0f); // this replaces setStartAtZero(true)\n //rightAxis.setAxisMaximum(80000f);\n\n YAxis leftAxis = mChart.getAxisLeft();\n leftAxis.setDrawGridLines(false);\n leftAxis.setAxisMinimum(0f); // this replaces setStartAtZero(true)\n leftAxis.setAxisMaximum(80f);\n\n //Set X-Axis Lables\n XAxis xAxis = mChart.getXAxis();\n xAxis.setAxisMinimum(0f);\n xAxis.setGranularity(1f);\n xAxis.setValueFormatter(new IndexAxisValueFormatter(weeks));\n xAxis.setLabelRotationAngle(45);\n xAxis.setPosition(XAxis.XAxisPosition.BOTTOM);\n xAxis.setGranularityEnabled(true);\n xAxis.setLabelCount(12);\n\n\n\n CombinedData combdata = new CombinedData();\n combdata.setData(generateLineData());\n combdata.setData(generateLineData2());\n combdata.setData(generateBarData());\n xAxis.setAxisMaximum(combdata.getXMax() + 0.25f);\n mChart.setData(combdata);\n mChart.invalidate();\n\n\n\n }else{\n Toast.makeText(getActivity(), \"message failed!\", Toast.LENGTH_SHORT).show();\n if(dialog.isShowing()){\n dialog.dismiss();\n }\n }\n } catch (JSONException localJSONException) {\n Log.e(\"gettingjson\", localJSONException.toString());\n localJSONException.printStackTrace();\n if(dialog.isShowing()){\n dialog.dismiss();\n }\n }\n }\n }\n @Override\n protected void onPreExecute()\n {\n //dialog = ProgressDialog.show(getActivity(), \"\", \"Loading Data...\", true);\n //dialog.setCancelable(true);\n }\n\n };\n mCombComdtySTKC.execute(mUid,mYear,mWeekNo);\n\n }",
"@Override\n\tpublic Pane getchart(int width, int height, boolean withdate) {\n\t\treturn fanChart.getchart(width, height, withdate);\n\t}",
"public MoeHistoryChart(SimulationTab tab) {\n\t\tthis.tab = tab;\n\t\t\n\t\tchartPanel = new SNChartPanel();\n\t\tchartPanel.setPreferredSize(new Dimension(600,400));\n\t\tsetLeftComponent(chartPanel);\n\t\t\n\t\tJPanel controlPanel = new JPanel();\n\t\tcontrolPanel.setLayout(new GridBagLayout());\n\t\tcontrolPanel.setBorder(BorderFactory.createTitledBorder(\"Chart Options\"));\n\t\tGridBagConstraints c = new GridBagConstraints();\n\t\tc.insets = new Insets(2,2,2,2);\n\t\tc.gridx = 0;\n\t\tc.gridy = 0;\n\t\tc.weightx = 1;\n\t\tc.weighty = 0;\n\t\tc.gridwidth = 2;\n\t\tc.gridy = 0;\n\t\tc.anchor = GridBagConstraints.LINE_START;\n\t\tc.fill = GridBagConstraints.BOTH;\n\t\tmoeCombo = new JComboBox();\n\t\tfor(MoeType t : MoeType.values()) {\n\t\t\tmoeCombo.addItem(t);\n\t\t}\n\t\tmoeCombo.addItemListener(new ItemListener() {\n\t\t\tpublic void itemStateChanged(ItemEvent e) {\n\t\t\t\tif(e.getStateChange()==ItemEvent.SELECTED) {\n\t\t\t\t\tupdateView();\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\t\tcontrolPanel.add(moeCombo, c);\n\t\tc.gridx--;\n\t\tc.gridy++;\n\t\tc.gridwidth = 1;\n\t\tc.weighty = 0;\n\t\tc.weightx = 0;\n\t\tc.gridx = 0;\n\t\tc.anchor = GridBagConstraints.LINE_END;\n\t\tc.fill = GridBagConstraints.NONE;\n\t\tJLabel totalMetricLabel = new JLabel(\"Total: \");\n\t\tcontrolPanel.add(totalMetricLabel, c);\n\t\tc.gridy++;\n\t\tJLabel metricLabel = new JLabel(\"Filtered: \");\n\t\tcontrolPanel.add(metricLabel, c);\n\t\tc.gridx++;\n\t\tc.gridy--;\n\t\tc.weightx = 1;\n\t\tc.anchor = GridBagConstraints.LINE_START;\n\t\tc.fill = GridBagConstraints.BOTH;\n\t\ttotalValueLabel = new JLabel(\"\");\n\t\tcontrolPanel.add(totalValueLabel, c);\n\t\tc.gridy++;\n\t\tvalueLabel = new JLabel(\"\");\n\t\tcontrolPanel.add(valueLabel, c);\n\t\tc.gridx--;\n\t\tc.gridy++;\n\t\tc.gridwidth = 2;\n\t\tc.weightx = 1;\n\t\tc.weighty = 1;\n\t\tlocationsModel = new CheckBoxTableModel<Location>();\n\t\tlocationsModel.addTableModelListener(new TableModelListener() {\n\t\t\tpublic void tableChanged(TableModelEvent e) {\n\t\t\t\tupdateChart();\n\t\t\t}\n\t\t});\n\t\tJTable locationsTable = new JTable(locationsModel);\n\t\tlocationsTable.getTableHeader().setReorderingAllowed(false);\n\t\tlocationsTable.getColumnModel().getColumn(0).setHeaderValue(\"\");\n\t\tlocationsTable.getColumnModel().getColumn(0).setMaxWidth(25);\n\t\tlocationsTable.getColumnModel().getColumn(1).setHeaderValue(\"Filter Locations\");\n\t\tlocationsTable.getColumnModel().getColumn(0).setHeaderRenderer(new VisibilityTableCellHeaderRenderer());\n\t\tlocationsTable.setShowGrid(false);\n\t\tJScrollPane locationsScroll = new JScrollPane(locationsTable);\n\t\tlocationsScroll.setPreferredSize(new Dimension(150,200));\n\t\tcontrolPanel.add(locationsScroll, c);\n\t\tc.gridy++;\n\t\tc.weighty = 0;\n\t\tc.fill = GridBagConstraints.NONE;\n\t\tJPanel buttonPanel = new JPanel();\n\t\tbuttonPanel.setLayout(new FlowLayout(FlowLayout.LEFT, 5, 0));\n\t\tJButton selectAllButton = new JButton(\"Select All\");\n\t\tselectAllButton.setToolTipText(\"Select All Locations\");\n\t\tselectAllButton.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tlocationsModel.selectAll();\n\t\t\t}\n\t\t});\n\t\tbuttonPanel.add(selectAllButton);\n\t\tJButton deselectAllButton = new JButton(\"Deselect All\");\n\t\tdeselectAllButton.setToolTipText(\"Deselect All Locations\");\n\t\tdeselectAllButton.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tlocationsModel.deselectAll();\n\t\t\t}\n\t\t});\n\t\tbuttonPanel.add(deselectAllButton);\n\t\tcontrolPanel.add(buttonPanel, c);\n\t\tc.gridy++;\n\t\tJPanel prop = new JPanel();\n\t\tprop.setPreferredSize(new Dimension(1,15));\n\t\tcontrolPanel.add(prop, c);\n\n\t\tc.gridy++;\n\t\tc.anchor = GridBagConstraints.LINE_START;\n\t\tlinearizeDataCheck = new JCheckBox(\"Linearize Data\", true);\n\t\tlinearizeDataCheck.addItemListener(new ItemListener() {\n\t\t\tpublic void itemStateChanged(ItemEvent e) {\n\t\t\t\tupdateChart();\n\t\t\t}\n\t\t});\n\t\tcontrolPanel.add(linearizeDataCheck, c);\n\t\t\n\t\tcontrolPanel.setMinimumSize(new Dimension(150,50));\n\t\tsetRightComponent(controlPanel);\n\n\t\tsetName(\"Measures History\");\n\t\tsetOneTouchExpandable(true);\n\t\tsetDividerSize(10);\n\t\tsetBorder(BorderFactory.createEmptyBorder());\n\t\tsetResizeWeight(1);\n\t\tsetDividerLocation(700);\n\t}",
"private void initChart() {\n Cartesian cartesian = AnyChart.line();\n\n cartesian.animation(true);\n\n cartesian.padding(10d, 20d, 5d, 20d);\n\n cartesian.crosshair().enabled(true);\n cartesian.crosshair()\n .yLabel(true)\n // TODO ystroke\n .yStroke((Stroke) null, null, null, (String) null, (String) null);\n\n cartesian.tooltip().positionMode(TooltipPositionMode.POINT);\n\n cartesian.title(\"Steps taken in this week and last week\");\n\n cartesian.yAxis(0).title(\"Steps\");\n cartesian.xAxis(0).labels().padding(5d, 5d, 5d, 5d);\n\n List<DataEntry> seriesData = new ArrayList<>();\n Log.d(\"Size This Week\",stepsTakenModelsThisWeek.size()+\"\");\n for(int i = 0 ; i<7 ; i++){\n CustomDataEntry c = new CustomDataEntry(days[i],stepsTakenModelsLastWeek.get(i).getSteps());\n if(i<stepsTakenModelsThisWeek.size()){\n c.setValue(\"value2\",stepsTakenModelsThisWeek.get(i).getSteps());\n }else{\n if(DateUtilities.getDayInAbbBySelectedDate(stepsTakenModelsLastWeek.get(i).getDate()).equals(\n DateUtilities.getCurrentDayInAbb()))\n {\n c.setValue(\"value2\",stepsToday);\n }else{\n c.setValue(\"value2\",0);\n }\n }\n seriesData.add(c);\n }\n\n Set set = Set.instantiate();\n set.data(seriesData);\n Mapping series1Mapping = set.mapAs(\"{ x: 'x', value: 'value' }\");\n Mapping series2Mapping = set.mapAs(\"{ x: 'x', value: 'value2' }\");\n\n Line series1 = cartesian.line(series1Mapping);\n series1.name(\"Last Week\");\n series1.hovered().markers().enabled(true);\n series1.hovered().markers()\n .type(MarkerType.CIRCLE)\n .size(4d);\n series1.tooltip()\n .position(\"right\")\n .anchor(Anchor.LEFT_CENTER)\n .offsetX(5d)\n .offsetY(5d);\n\n Line series2 = cartesian.line(series2Mapping);\n series2.name(\"This Week\");\n series2.hovered().markers().enabled(true);\n series2.hovered().markers()\n .type(MarkerType.CIRCLE)\n .size(4d);\n series2.tooltip()\n .position(\"right\")\n .anchor(Anchor.LEFT_CENTER)\n .offsetX(5d)\n .offsetY(5d);\n\n\n cartesian.legend().enabled(true);\n cartesian.legend().fontSize(13d);\n cartesian.legend().padding(0d, 0d, 10d, 0d);\n\n chart.setChart(cartesian);\n }",
"@Override\r\n \t\t\t\tpublic void onClick(View v) {\n \t\t\t\t\t\r\n \t\t\t\t\tmRenderer.setZoomButtonsVisible(false);\r\n \t\t\t\t\t\r\n \t\t\t\t\t/*Bitmap bmp = Bitmap.createBitmap( 800, 600, Bitmap.Config.ARGB_8888 );\r\n \t\t\t\t\t\r\n \t\t\t\t\t//Bitmap bmp =Bitmap.createBitmap( mChart.getMeasuredWidth(),mChart.getMeasuredHeight(), Bitmap.Config.ARGB_8888 );\r\n \t\t\t\t\t\r\n \t\t\t\t\tCanvas canvas = new Canvas(bmp);\r\n \t\t\t\t\tmChart.draw( canvas );\r\n \t\t\t\t\t\r\n \t\t\t\t\tFile myDir = new File(Environment.getExternalStorageDirectory() + File.separator + \"SpeakingTime Graphs\"); //pour créer le repertoire dans lequel on va mettre notre fichier\r\n \t\t if (!myDir.exists()) {\r\n \t\t \tmyDir.mkdir(); //On crée le répertoire (s'il n'existe pas!!)\r\n \t\t }\r\n \t\t\t\t\t\r\n \t\t\t\t\tFileOutputStream out = null;\r\n\t\t\t\t\t\ttry {\r\n\t\t\t\t\t\t\tout = new FileOutputStream(Environment.getExternalStorageDirectory() + File.separator + \"SpeakingTime Graphs\" + File.separator + name.substring(0, name.length() - 4) + \"_bargraph.jpg\");\r\n\t\t\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\t\t\te.printStackTrace();\r\n\t\t\t\t\t\t}\r\n \t\t\t\t\tbmp.compress( Bitmap.CompressFormat.JPEG, 97, out );\r\n \t\t\t\t\ttry {\r\n\t\t\t\t\t\t\tout.close();\r\n\t\t\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\t\t\te.printStackTrace();\r\n\t\t\t\t\t\t}*/\r\n \t\t\t\t\t\r\n \t\t\t\t\tModalDialog modalDialog = new ModalDialog();\r\n\t\t\t\t\t\tString boxplots_name = modalDialog.showModalDialogReunionName(BarGraphActivity.this, \"Give a name to this graph\"); \t\t\t\t\t\r\n\t\t\t\t\t\t\r\n\t\t\t\t\t\tif (boxplots_name != \"Cancel\"){\r\n\t\t\t\t\t\t\tif (boxplots_name.equalsIgnoreCase(\"\")){\r\n\t\t\t\t\t\t\t\t\r\n\t\t\t\t\t\t\t\tAlertDialog.Builder alertDialog = new AlertDialog.Builder(BarGraphActivity.this);\r\n\t\t\t\t\t\t\t\talertDialog.setTitle(\"Warning\");\r\n\t\t\t\t\t\t\t\talertDialog.setMessage(\"GIVE A VALID NAME !\");\r\n\t\t\t\t\t\t\t\talertDialog.show();\r\n\t\t\t\t\t\t\t\t\t\t\t\t\t\r\n\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\telse {\r\n\t\t\t\t\t\t\t\t\r\n\t\t\t\t\t\t\t\tif (SaveGraphOnDisk(boxplots_name) == \"error\") {\r\n\t\t \t\t\t\t\t\tAlertDialog.Builder alertDialog = new AlertDialog.Builder(BarGraphActivity.this);\r\n\t\t\t\t\t\t\t\t\talertDialog.setTitle(\"Warning\");\r\n\t\t\t\t\t\t\t\t\talertDialog.setMessage(\"The graph can't be saved !\");\r\n\t\t\t\t\t\t\t\t\talertDialog.show();\r\n\t\t \t\t\t\t\t}\r\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\r\n\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t}\r\n \t\t\t\t\t\r\n \t\t\t\t\t\r\n \t\t\t\t\t\r\n \t\t\t\t\tmRenderer.setZoomButtonsVisible(true);\r\n \t\t\t\t}",
"public void BarChartForViolationFines() {\n\t\t\n\t\t// Dataset Generation\t\t\n\n\t\tDefaultCategoryDataset dataset = new DefaultCategoryDataset();\t\t\t\n\t\tfor (int i = 0; i < 10; i++) {\n\t\t\tString key = sortedKeysByVioDesc.get(i);\n\t\t\tdataset.addValue(ticketByVioFine.get(key), \"Violation Fine\", key);\n\t\t}\t\t\t\n\t\tCategoryDataset plotDataset = dataset;\n\n\t\t// JFreeChart Call for BarChart and passing formats\n\t\tJFreeChart barChart2 = ChartFactory.createBarChart(\n\t\t\t\t\"Parking Tickets by Violation Fee\", \n\t\t\t\t\"Ticket Description\", \n\t\t\t\t\"Ticket Fee ($)\", \n\t\t\t\tplotDataset, \n\t\t\t\tPlotOrientation.VERTICAL, \n\t\t\t\tfalse, //legend\n\t\t\t\ttrue, //tool tip\n\t\t\t\tfalse // use to generate URL\n\t\t\t\t);\t\n\n\t\t// Turing label by 45 degree to show full label\n\t\tCategoryPlot cplot2 = barChart2.getCategoryPlot();\n\t\tCategoryAxis xAxis = (CategoryAxis)cplot2.getDomainAxis();\n\t\txAxis.setCategoryLabelPositions(CategoryLabelPositions.UP_45);\n\t\t\n\t\t//Chart panel generation\n ChartPanel chartPanel2 = new ChartPanel(barChart2);\n chartPanel2.setBorder(BorderFactory.createEmptyBorder(15, 15, 15, 15));\n chartPanel2.setBackground(Color.white);\n add(chartPanel2);\n pack();\n setLocationRelativeTo(null);\n setDefaultCloseOperation(JFrame.EXIT_ON_CLOSE);\n setVisible(true);\n try {\n \tfinal ChartRenderingInfo chartInfo2 = new ChartRenderingInfo(new StandardEntityCollection());\n \tfinal File file4 = new File(\"BarChartForViolationFee.png\");\n ChartUtilities.saveChartAsPNG(file4, barChart2, 800, 800, chartInfo2);\n }\n catch (Exception e) {\n }\n\t}",
"@Override\n @Transactional\n public void getTheSpecial() {\n log.info(\"Running \\\"The Special\\\"...\");\n\n log.info(\"Creating plot...\");\n Chart plot = new Chart();\n plot.setName(\"My_Plot_\" + RandomUtils.nextInt());\n Map<String, Object> map = new HashMap<>();\n map.put(\"key1\", \"value1\");\n map.put(\"key2\", 2);\n plot.setOptions(map);\n plot.setTopic(topicDao.findOne(\"test\"));\n\n List<Map<String, Object>> mainPlotData = new ArrayList<Map<String, Object>>();\n\n for (Integer i = 0; i < 1; i++) {\n Map<String, Object> itemData = new HashMap<String, Object>();\n\n // Generate data set\n List<List<Double>> data = new ArrayList<>();\n for (Double j = 0D; j < 20; j++) {\n List<Double> bar = new ArrayList<>();\n bar.add(j);\n bar.add(Math.sin(j));\n data.add(bar);\n }\n\n itemData.put(\"data\", data);\n itemData.put(\"label\", \"Sin\");\n itemData.put(\"color\", \"#000000\");\n\n mainPlotData.add(itemData);\n }\n //plot.setData(mainPlotData);\n\n Map<String, Object> mainOptions = new HashMap<>();\n\n Map<String, Object> bars = new HashMap<>();\n bars.put(\"show\", true);\n bars.put(\"barWidth\", 0.5);\n bars.put(\"fill\", 0.9);\n mainOptions.put(\"bars\", bars);\n\n Map<String, Object> xaxis = new HashMap<>();\n bars.put(\"ticks\", new ArrayList<String>());\n bars.put(\"autoscaleMargin\", 0.02);\n mainOptions.put(\"xaxis\", xaxis);\n\n Map<String, Object> yaxis = new HashMap<>();\n bars.put(\"min\", -2);\n bars.put(\"max\", 2);\n mainOptions.put(\"yaxis\", yaxis);\n \n Map<String, Object> grid = new HashMap<>();\n List<Map<String, Object>> markings = new ArrayList<>();\n Map<String, Object> markingItem;\n Map<String, Object> axisItem;\n\n markingItem = new HashMap<>();\n markingItem.put(\"color\", \"#F6F6F6\");\n axisItem = new HashMap<>();\n axisItem.put(\"from\", 1);\n markingItem.put(\"yaxis\", axisItem);\n markings.add(markingItem);\n\n markingItem = new HashMap<>();\n markingItem.put(\"color\", \"#F6F6F6\");\n axisItem = new HashMap<>();\n axisItem.put(\"to\", -1);\n markingItem.put(\"yaxis\", axisItem);\n markings.add(markingItem);\n\n markingItem = new HashMap<>();\n markingItem.put(\"color\", \"#F6F6F6\");\n markingItem.put(\"lineWidth\", 1);\n axisItem = new HashMap<>();\n axisItem.put(\"from\", 2);\n axisItem.put(\"to\", 2);\n markingItem.put(\"xaxis\", axisItem);\n markings.add(markingItem);\n\n markingItem = new HashMap<>();\n markingItem.put(\"color\", \"#F6F6F6\");\n markingItem.put(\"lineWidth\", 1);\n axisItem = new HashMap<>();\n axisItem.put(\"from\", 8);\n axisItem.put(\"to\", 8);\n markingItem.put(\"xaxis\", axisItem);\n markings.add(markingItem);\n\n grid.put(\"markings\", markings);\n mainOptions.put(\"grid\", grid);\n\n plot.setOptions(mainOptions);\n\n try {\n plotService.save(plot);\n } catch (InvalidChartException e) {\n log.error(\"Couldn't create the plot.\");\n }\n\n List<Post> posts = datastoreService.findByTopicId(\"test\", Post.class);\n log.info(\"Posts count is <\" + posts.size() + \">\");\n\n log.info(\"That's it. Have fun!\");\n\n return;\n }",
"private void initChart() {\r\n /*mCurrentSeries = new XYSeries(\"Sample Data\");\r\n mDataset.addSeries(mCurrentSeries);\r\n mCurrentRenderer = new XYSeriesRenderer();\r\n mRenderer.addSeriesRenderer(mCurrentRenderer);*/\r\n \t\r\n \tList<Integer> MyListValue = new ArrayList<Integer>();\r\n\t\t/*for (int i = 0; i < SpeakingTimeList.size(); i++){\r\n\t\t\tMyListValue.add(SpeakingTimeList.get(i));\r\n\t\t}*/\r\n\t\tfor (int i = 0; i < participantAndSpeakingTimeList.size(); i++){\r\n\t\t\tMyListValue.add(participantAndSpeakingTimeList.get(i).getValue());\r\n\t\t}\r\n\t\t\r\n\t\t/*MyList.add(25);\r\n\t\tMyList.add(10);\r\n\t\tMyList.add(15);\r\n\t\tMyList.add(20);*/\r\n\t\t\t\t\r\n\t\tint[] y = new int[MyListValue.size()];\r\n\t\tfor (int i = 0; i < MyListValue.size(); i++) \r\n\t\t\ty[i] = MyListValue.get(i);\r\n\t\t\r\n\t\t//int y[] = {25,10,15,20};\r\n\t \r\n CategorySeries series = new CategorySeries(\"Speaking time in secondes\");\r\n for(int i=0; i < y.length; i++){\r\n series.add(\"Bar\"+(i+1),y[i]);\r\n }\r\n \r\n dataSet = new XYMultipleSeriesDataset(); // collection of series under one object.,there could any\r\n dataSet.addSeries(series.toXYSeries()); // number of series\r\n \r\n //customization of the chart\r\n \r\n XYSeriesRenderer renderer = new XYSeriesRenderer(); // one renderer for one series\r\n renderer.setColor(Color.parseColor(\"#0099FF\"));\r\n renderer.setDisplayChartValues(true);\r\n renderer.setChartValuesSpacing((float) 5.5d);\r\n renderer.setLineWidth((float) 10.5d);\r\n \r\n \r\n mRenderer = new XYMultipleSeriesRenderer(); // collection multiple values for one renderer or series\r\n mRenderer.addSeriesRenderer(renderer);\r\n mRenderer.setChartTitle(\"Speaking time per participant\");\r\n// mRenderer.setXTitle(\"xValues\");\r\n mRenderer.setYTitle(\"Time in secondes\");\r\n mRenderer.setZoomButtonsVisible(true); mRenderer.setShowLegend(true);\r\n mRenderer.setShowGridX(true); // this will show the grid in graph\r\n mRenderer.setShowGridY(true); \r\n// mRenderer.setAntialiasing(true);\r\n mRenderer.setBarSpacing(.5); // adding spacing between the line or stacks\r\n mRenderer.setApplyBackgroundColor(true);\r\n mRenderer.setBackgroundColor(Color.BLACK);\r\n mRenderer.setXAxisMin(0);\r\n mRenderer.setYAxisMin(0);\r\n //mRenderer.setXAxisMax(5);\r\n /*mRenderer.setXAxisMax(ParticipantsList.size()+1);*/\r\n mRenderer.setXAxisMax(participantAndSpeakingTimeList.size()+1);\r\n //mRenderer.setYAxisMax(100);\r\n mRenderer.setYAxisMax(Math.round(getMaxValue()/10)*10+10);\r\n// \r\n \r\n mRenderer.setXLabels(0);\r\n \r\n mRenderer.setXLabelsAngle(90);\r\n mRenderer.setXLabelsAlign(Align.LEFT);\r\n \r\n /*for (int i = 0; i < ParticipantsList.size(); i++){\r\n\t\t\tmRenderer.addXTextLabel(i+1, ParticipantsList.get(i));\r\n\t\t}*/\r\n for (int i = 0; i < participantAndSpeakingTimeList.size(); i++){\r\n\t\t\tmRenderer.addXTextLabel(i+1, participantAndSpeakingTimeList.get(i).getName());\r\n\t\t}\r\n \r\n /*mRenderer.addXTextLabel(1,\"Income\");\r\n mRenderer.addXTextLabel(2,\"Saving\");\r\n mRenderer.addXTextLabel(3,\"Expenditure\");\r\n mRenderer.addXTextLabel(4,\"NetIncome\");*/\r\n \r\n mRenderer.setPanEnabled(true, true); // will fix the chart position\r\n //Intent intent = ChartFactory.getBarChartIntent(context, dataSet, mRenderer,Type.DEFAULT);\r\n \r\n //return intent;\r\n\r\n\t\r\n\t}",
"private void showBars() {\n graph.removeAllSeries();\n Log.d(\"ShowGraph \", \"started\");\n Log.d(\"Tuples length \", tuples.size() + \"\");\n ArrayList<Double> vkupno = new ArrayList<Double>();\n //vo vkupno, sekoj element, e vkupnata vrednost za nutrientot pod toj broj\n int brNutrienti = values.size();\n Log.d(\"Values length\", brNutrienti + \"\");\n for (int i = 0; i < brNutrienti; i++) {\n vkupno.add(i, 0.0);\n }\n Iterator<String> it = values.iterator();\n String currentNutrient = null;\n double dodadi = 0;\n for (int j = 0; j < brNutrienti; j++) {\n currentNutrient = it.next();\n for (int i = 0; i < tuples.size(); i++) {\n Tuple currentTuple = tuples.get(i);\n if (currentNutrient.equals(\"Protein\")) {\n dodadi = (currentTuple.getProtein()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Total lipid (fat)\")) {\n dodadi = (currentTuple.getLipid()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Carbohydrate\")) {\n dodadi = (currentTuple.getCarbohydrate()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Glucose\")) {\n dodadi = (currentTuple.getGlucose()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Calcium\")) {\n dodadi = (currentTuple.getCalcium()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Iron\")) {\n dodadi = (currentTuple.getIron()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Magnesium\")) {\n dodadi = (currentTuple.getMagnesium()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Zinc\")) {\n dodadi = (currentTuple.getZinc()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Vitamin C\")) {\n dodadi = (currentTuple.getVitaminC()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Thiamin\")) {\n dodadi = (currentTuple.getThiamin()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Riboflavin\")) {\n dodadi = (currentTuple.getRibofavin()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Niacin\")) {\n dodadi = (currentTuple.getNiacin()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Vitamin B6\")) {\n dodadi = (currentTuple.getVitaminB6()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Vitamin B12\")) {\n dodadi = (currentTuple.getVitaminB12()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"VitaminA\")) {\n dodadi = (currentTuple.getVitaminA()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Vitamin D\")) {\n dodadi = (currentTuple.getVitaminD()) * currentTuple.getQuantity() / 100;\n } else if (currentNutrient.equals(\"Vitamin E\")) {\n dodadi = (currentTuple.getVitaminE()) * currentTuple.getQuantity() / 100;\n }\n dodadi = dodadi + vkupno.get(j);\n vkupno.set(j, dodadi);\n dodadi = 0;\n }\n }\n Log.d(\"Posle polenje na vkupno\", \"sfsfsdf\");\n //posle ova vo vkupno se sodrzhat y vrednostite za grafikot\n DataPoint[] dpArray = new DataPoint[vkupno.size()];\n for (int i = 0; i < vkupno.size(); i++) {\n dpArray[i] = new DataPoint(i + 1, vkupno.get(i));\n intake.add(vkupno.get(i));\n Log.d(\"y(\" + i + \")=\", vkupno.get(i) + \"\");\n }\n BarGraphSeries<DataPoint> series = new BarGraphSeries<DataPoint>(dpArray);\n graph.addSeries(series);\n // styling\n series.setValueDependentColor(new ValueDependentColor<DataPoint>() {\n @Override\n public int get(DataPoint data) {\n return Color.rgb((int) data.getX() * 255 / 4, (int) Math.abs(data.getY() * 255 / 6), 100);\n }\n });\n series.setSpacing(1);\n series.setDataWidth(0.2);\n // draw values on top\n series.setDrawValuesOnTop(true);\n series.setValuesOnTopColor(Color.BLACK);\n /* StaticLabelsFormatter staticLabelsFormatter = new StaticLabelsFormatter(graph);\n staticLabelsFormatter.setHorizontalLabels(new String[] {\"CH\", \"F\", \"Pr\",\"Mi\"});\n graph.getGridLabelRenderer().setLabelFormatter(staticLabelsFormatter);\n */\n //graph.getLegendRenderer().setVisible(true);\n graph.getLegendRenderer().setAlign(LegendRenderer.LegendAlign.TOP);\n }",
"@Override\r\n public void run() {\n chart = new PieChart();\r\n chart.setWidth(\"100px\");\r\n chart.setHeight(\"100px\");\r\n fp.add(chart);\r\n draw();\r\n }",
"@Override\n public void onClick(View view) {\n\n ft2 = getFragmentManager().beginTransaction();\n chartFragment = ChartFragment.newInstance(\"chart-fragment\");\n chartFragment.setArguments(bundleHourlyArr);\n ft2.add(R.id.main_holder, chartFragment, \"chart-fragment-tag\");\n ft2.show(chartFragment);\n ft2.commit();\n }",
"private static JFreeChart createChart(CategoryDataset dataset) {\n\t\t//the title of the chart depending of the attributes chosen by the user\n\t\tif (queryNumber==0) {domainLabel=\"Per day\";}\n\t\telse if (queryNumber==1) {domainLabel=\"Per hour\";}\n\t\telse if (queryNumber==2) {domainLabel=\"Per minute\";}\n\t\t\n\t\t// setting the title \n\t\tString rangeLabel=\"Average (ms)\";\n\t\t// create the chart...\n\t\tJFreeChart chart = ChartFactory.createBarChart(\n\t\t\t\t\"Static\", // chart title\n\t\t\t\tdomainLabel, // domain axis label\n\t\t\t\trangeLabel, // range axis label\n\t\t\t\tdataset, // data\n\t\t\t\tPlotOrientation.VERTICAL, // orientation\n\t\t\t\tfalse, // include legend\n\t\t\t\ttrue, // tooltips\n\t\t\t\tfalse // URLs\n\t\t\t\t);\n\t\t\n\t\t//setting the title preferences and format\n\t\tchart.getTitle().setFont(fontStatic);\n\t\tchart.getTitle().setPaint(Color.red);\n\t\tchart.setBackgroundPaint(Color.white);\n\t\tCategoryPlot plot = chart.getCategoryPlot();\n\t\tplot.setBackgroundPaint(Color.lightGray);\n\t\tplot.setDomainGridlinePaint(Color.white);\n\t\tplot.setDomainGridlinesVisible(true);\n\t\tplot.setRangeGridlinePaint(Color.white);\n\t\tfinal NumberAxis rangeAxis = (NumberAxis) plot.getRangeAxis();\n\t\tchart.getCategoryPlot().getRangeAxis().setLabelPaint(Color.RED);\n\t\tchart.getCategoryPlot().getDomainAxis().setLabelPaint(Color.RED);\n\t\trangeAxis.setStandardTickUnits(NumberAxis.createIntegerTickUnits());\n\t\tBarRenderer renderer = (BarRenderer) plot.getRenderer();\n\t\trenderer.setDrawBarOutline(false);\n\t\tfor (int i =0;i<25;i++) renderer.setSeriesPaint(i, Color.BLUE);\n\t\treturn chart;\n\t}",
"public static String exampleBarChart() {\n BarChartPlot team1 = Plots.newBarChartPlot(Data.newData(25, 43, 12, 30), Color.BLUEVIOLET, \"Team A\");\n BarChartPlot team2 = Plots.newBarChartPlot(Data.newData(8, 35, 11, 5), Color.ORANGERED, \"Team B\");\n BarChartPlot team3 = Plots.newBarChartPlot(Data.newData(10, 20, 30, 30), Color.LIMEGREEN, \"Team C\");\n\n // Instantiating chart.\n BarChart chart = GCharts.newBarChart(team1, team2, team3);\n\n // Defining axis info and styles\n AxisStyle axisStyle = AxisStyle.newAxisStyle(Color.BLACK, 13, AxisTextAlignment.CENTER);\n AxisLabels score = AxisLabelsFactory.newAxisLabels(\"Score\", 50.0);\n score.setAxisStyle(axisStyle);\n AxisLabels year = AxisLabelsFactory.newAxisLabels(\"Year\", 50.0);\n year.setAxisStyle(axisStyle);\n\n // Adding axis info to chart.\n chart.addXAxisLabels(AxisLabelsFactory.newAxisLabels(\"2002\", \"2003\", \"2004\", \"2005\"));\n chart.addYAxisLabels(AxisLabelsFactory.newNumericRangeAxisLabels(0, 100));\n chart.addYAxisLabels(score);\n chart.addXAxisLabels(year);\n\n chart.setSize(600, 450);\n chart.setBarWidth(100);\n chart.setSpaceWithinGroupsOfBars(20);\n chart.setDataStacked(true);\n chart.setTitle(\"Team Scores\", Color.BLACK, 16);\n chart.setGrid(100, 10, 3, 2);\n chart.setBackgroundFill(Fills.newSolidFill(Color.ALICEBLUE));\n LinearGradientFill fill = Fills.newLinearGradientFill(0, Color.LAVENDER, 100);\n fill.addColorAndOffset(Color.WHITE, 0);\n chart.setAreaFill(fill);\n String url = chart.toURLString();\n return url;\n }",
"public static void graph(){\n\t\t double[][] valuepairs = new double[2][];\n\t\t valuepairs[0] = mutTotal; //x values\n\t\t valuepairs[1] = frequency; //y values\n\t\t DefaultXYDataset set = new DefaultXYDataset();\n\t\t set.addSeries(\"Occurances\",valuepairs); \n\t\t XYBarDataset barset = new XYBarDataset(set, .8);\n\t\t JFreeChart chart = ChartFactory.createXYBarChart(\n\t\t \"Mutation Analysis\",\"Number of Mutations\",false,\"Frequency\",\n\t\t barset,PlotOrientation.VERTICAL,true, true, false);\n\t\t JFrame frame = new JFrame(\"Mutation Analysis\");\n\t\t frame.setContentPane(new ChartPanel(chart));\n\t\t frame.setDefaultCloseOperation(JFrame.EXIT_ON_CLOSE);\n\t\t frame.pack();\n\t\t frame.setVisible(true);\n\t\t }",
"private void constructChartPanel() {\n chartPanel = new JPanel();\n chartPanel.setBorder(BorderFactory.createTitledBorder(\"Price Chart\"));\n chartPanel.setPreferredSize(relativeSize(0.4f, 0.35f));\n \n displayChartButton = new JButton(\"Click to Display Price Chart\");\n displayChartButton.setEnabled(false);\n displayChartButton.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent e) {\n JPanel cPanel = chart.getChartPanel();\n chartPanel.removeAll();\n chartPanel.add(cPanel);\n cPanel.setPreferredSize(relativeSize(0.4f, 0.35f));\n \n pack();\n repaint();\n }\n });\n \n chartPanel.add(displayChartButton);\n }",
"public void render(Chart chart, Map<String, Obs> latestObservations,\n List<Obs> observations, List<Order> orders,\n LocalDate admissionDate, LocalDate firstSymptomsDate,\n GridJsInterface controllerInterface) {\n if (chart == null) {\n mView.loadUrl(\"file:///android_asset/no_chart.html\");\n return;\n }\n if (mLastChartName.equals(chart.name) &&\n mLastRenderedZoomIndex == mSettings.getChartZoomIndex() &&\n observations.equals(mLastRenderedObs) &&\n orders.equals(mLastRenderedOrders)) {\n return; // nothing has changed; no need to render again\n }\n\n // setDefaultFontSize is supposed to take a size in sp, but in practice\n // the fonts don't change size when the user font size preference changes.\n // So, we apply the scaling factor explicitly, defining 1 em to be 10 sp.\n DisplayMetrics metrics = mResources.getDisplayMetrics();\n float defaultFontSize = 10*metrics.scaledDensity/metrics.density;\n mView.getSettings().setDefaultFontSize((int) defaultFontSize);\n\n mView.getSettings().setJavaScriptEnabled(true);\n mView.addJavascriptInterface(controllerInterface, \"controller\");\n mView.setWebChromeClient(new WebChromeClient());\n String html = new GridHtmlGenerator(\n chart, latestObservations, observations, orders,\n admissionDate, firstSymptomsDate).getHtml();\n mView.loadDataWithBaseURL(\n \"file:///android_asset/\", html, \"text/html; charset=utf-8\", \"utf-8\", null);\n mView.setWebContentsDebuggingEnabled(true);\n\n mLastChartName = chart.name;\n mLastRenderedZoomIndex = mSettings.getChartZoomIndex();\n mLastRenderedObs = observations;\n mLastRenderedOrders = orders;\n }",
"public Chart(double[][] result, double[][] observed){\n //Create a new Frame object\n final Frame f1 = new Frame(\"Model Fit\");\n\t//Set the Frame object size\t\n\tf1.setSize(600,400);\n //Add a window listener to the Frame to close it\n\tf1.addWindowListener(new WindowAdapter() {\n @Override\n\t\tpublic void windowClosing(WindowEvent we) {\n\t\t\tf1.dispose();\n\t\t}\n\t});\n \n //add in the code to create the chart\n //create a data object to hold the XY data\n DefaultXYDataset data = new DefaultXYDataset();\n //cycle through the origins\n for (int i = 0; i < observed.length; i++) {\n //create a two dimensional array to hold the observed and result\n double dataArray[][] = new double[2][observed[i].length];\n //put the observed data in element 0\n dataArray[0]=observed[i];\n //put the result data in element 1\n dataArray[1]=result[i];\n //add the data series with a unique name\n data.addSeries(\"Origin \"+i, dataArray);\n }\n\t//Create the chart with the correct title and axis names and data etc.\n\tJFreeChart chart = ChartFactory.createScatterPlot(\"Observed vs. Results\", \n\t\t\"Observed\", // x axis label\n\t\t\"Results\", // y axis label\n\t\tdata, // data\n\t\tPlotOrientation.VERTICAL, // orientation\n\t\ttrue, // legend\n\t\ttrue, // tooltips\n\t\tfalse // URLs\n\t);\n\t//get the plot area and format it to the desired colours\n\tXYPlot plot = (XYPlot) chart.getPlot();\n\tplot.setBackgroundPaint(Color.white);\n\tplot.setDomainGridlinePaint(Color.darkGray);\n\tplot.setDomainGridlinesVisible(true);\n\tplot.setRangeGridlinePaint(Color.black);\n\t\n\t// We're going to add some regression stuff here shortly.\n double[] coeffs = Regression.getOLSRegression(createTwoDArray(result, observed));\n\tLineFunction2D linefunction2d = new LineFunction2D(coeffs[0], coeffs[1]);\n\tXYDataset series2 = DatasetUtilities.sampleFunction2D(linefunction2d, 10, 50, 5, \"Linear Regression Line\");\n\tplot.setDataset(2, series2); \n\tXYLineAndShapeRenderer lineDrawer = new XYLineAndShapeRenderer(true, false);\n\tlineDrawer.setSeriesPaint(0, Color.BLACK);\n\tplot.setRenderer(2, lineDrawer);\n\t\n //create a chart panel to render to the screnn\n\tChartPanel chartPanel = new ChartPanel(chart);\n //add the chart panel to the frame\n\tf1.add(chartPanel);\n //set the frame to be visible\n\tf1.setVisible(true);\n }",
"public testChart() {\n initComponents();\n }",
"private Chart(){}",
"public interface ChartRenderer {\n\t\n\t/**\n\t * Renders this object's data as a chart.\n\t */\n\tpublic JFreeChart render();\n\n\t\n}",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents() {\n\n jButton1 = new javax.swing.JButton();\n panelChart = new javax.swing.JPanel();\n\n setDefaultCloseOperation(javax.swing.WindowConstants.EXIT_ON_CLOSE);\n\n jButton1.setText(\"Balansas\");\n jButton1.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n jButton1ActionPerformed(evt);\n }\n });\n\n panelChart.setBackground(new java.awt.Color(255, 255, 255));\n panelChart.setLayout(new java.awt.BorderLayout());\n\n javax.swing.GroupLayout layout = new javax.swing.GroupLayout(getContentPane());\n getContentPane().setLayout(layout);\n layout.setHorizontalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addContainerGap()\n .addGroup(layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addComponent(panelChart, javax.swing.GroupLayout.DEFAULT_SIZE, 686, Short.MAX_VALUE)\n .addGroup(layout.createSequentialGroup()\n .addGap(306, 306, 306)\n .addComponent(jButton1)\n .addGap(0, 0, Short.MAX_VALUE)))\n .addContainerGap())\n );\n layout.setVerticalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addContainerGap()\n .addComponent(panelChart, javax.swing.GroupLayout.PREFERRED_SIZE, 440, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addPreferredGap(javax.swing.LayoutStyle.ComponentPlacement.RELATED, 11, Short.MAX_VALUE)\n .addComponent(jButton1)\n .addContainerGap())\n );\n\n pack();\n }",
"public void updateChart(){\n for(Pair<Number,Number> p : sss.getPopulationQueue()){\n this.population.getData().add(new XYChart.Data<>(p.getKey(),p.getValue()));\n }\n for(Pair<Number,Number> p : sss.getDeathsQueue()){\n this.deaths.getData().add(new XYChart.Data<>(p.getKey(),p.getValue()));\n }\n for(Pair<Number,Number> p : sss.getInfectionsQueue()){\n this.infections.getData().add(new XYChart.Data<>(p.getKey(),p.getValue()));\n }\n for(Pair<Number,Number> p : sss.getHealsQueue()){\n this.heals.getData().add(new XYChart.Data<>(p.getKey(),p.getValue()));\n }\n sss.clearPopulationQueue();\n sss.clearDeathsQueue();\n sss.clearInfectionsQueue();\n sss.clearHealsQueue();\n }",
"private void drawLowPrices(Graphics g , int contentHeight) {\n // declare local variables:\n int buffer;\n int actualBars;\n int dataMinimum;\n int heightDifference;\n int lowPrices[];\n int dataArray[];\n double scale;\n // end of local variables declaration\n\n\n // check fro logical error\n if(data == null) {\n // exit from method\n return;\n } // end of if statement\n\n // check for logical error\n if(data.getLowPrices() == null || data.getLowPrices().length < 2) {\n // exit from method\n return;\n } // end of if statement\n\n // find the data minimum\n dataMinimum = ChartData.getMinimum(data.getLowPrices(bars));\n\n // resolve the data array\n lowPrices = data.getLowPrices(bars);\n dataArray = new int[lowPrices.length];\n System.arraycopy(lowPrices, 0, dataArray, 0, lowPrices.length);\n\n // resolve the actual bars\n actualBars = dataArray.length;\n\n // find the heightDifference\n heightDifference = ChartData.getMaximum(data.getLowPrices(bars)) - dataMinimum;\n\n // check if the heightDifference is too big and reduce it\n buffer = heightDifference / 50;\n if( buffer > 0) {\n heightDifference = heightDifference / buffer;\n } // end of if statement\n\n //\n for(int c = 0; c < actualBars; c++) {\n //\n dataArray[c] = dataArray[c] - dataMinimum;\n } // end of for loop;\n\n //\n if(buffer > 0) {\n //\n for(int c=0; c < actualBars; c++) {\n //\n dataArray[c] = dataArray[c] / buffer;\n } // end of for loop\n\n } // end of if statement\n\n\n // resolve the scale\n scale = contentHeight / heightDifference;\n\n // select color\n g.setColor(format.getLowPricesColor());\n\n // main drawing loop\n for(int c = 0; c < actualBars -1 ; c++) {\n //\n g.drawLine(getWidth()-textAreaLenght-c*barLenght,\n getHeight()- 30 - (int) Math.round(dataArray[c]*scale),\n getWidth()-textAreaLenght- ( (c+1)*barLenght ),\n getHeight()- 30 - (int) Math.round(dataArray[c+1]*scale));\n } // end of for loop\n\n }",
"private void initializeChartPanel() {\n\n Rectangle region = new Rectangle(0, 0, clip.getFrameCount(), clip.getFrameFreqSamples());\n\n //toClipCoords(region);\n region.y = clip.getFrameFreqSamples() - (region.y + region.height);\n\n final int endCol = region.x + region.width;\n final int endRow = region.y + region.height;\n\n //System.out.println(\"endCol = \" + endCol + \" endRow = \" + endRow);\n\n XYSeries xy = new XYSeries(\"data\");\n XYSeries xySpline = new XYSeries(\"spline\");\n\n // Displays the single MAX or STRONGEST Frequency for each column\n // captures every x'th element for fitting spline\n int maxItensity = 0;\n int[] rows = new int[endCol];\n int[] intensities = new int[endCol];\n\n// int SPLINEPRECISION = chartPrefJSlider2.getValue(); // 1 is highest precision; default = 40\n int SPLINEPRECISION = 40; // 1 is highest precision; default = 40\n int splineCounter = 0;\n\n for (int col = region.x; col < endCol; col++) {\n Frame fr = clip.getFrame(col);\n int strongestFreq = 0;\n int strongestFreqStrength = 0;\n for (int row = region.y; row < endRow; row++) {\n // the following is a MUCH faster equivalent to: img.setRGB(col, row, greyVal);\n //int greyVal = (int) (brightness + (contrast * Math.log1p(Math.abs(preMult * val))));\n int greyVal = (int) (0 + (625.0 * Math.log1p(Math.abs(11.2 * fr.getReal(row)))));\n greyVal = Math.min(255, Math.max(0, greyVal));\n int thisFreqStrength = (greyVal << 16) | (greyVal << 8) | (greyVal);\n\n if (thisFreqStrength > strongestFreqStrength) {\n strongestFreqStrength = thisFreqStrength;\n strongestFreq = row;\n }\n if (thisFreqStrength > maxItensity) {\n maxItensity = thisFreqStrength;\n }\n }\n rows[col] = strongestFreq;\n intensities[col] = strongestFreqStrength;\n }\n System.out.println(\"maxItensity = \" + maxItensity);\n\n // Average neighboring data values\n // Use minIntensity amoung neighbors for averaged row\n // Use threshold to exclude weak signals\n //int NUMPOINTSAVERAGED = 20;\n int NUMPOINTSAVERAGED = jSlider1.getValue(); // default = 20\n double INTENSITYTHRESHOLD = 0.95;\n int[] data = new int[endCol - NUMPOINTSAVERAGED];\n int[] dataAveraged = new int[endCol - NUMPOINTSAVERAGED];\n int[] minIntensities = new int[endCol - NUMPOINTSAVERAGED];\n for (int col = region.x; col < endCol - NUMPOINTSAVERAGED; col++) {\n int sumRows = 0;\n int minIntensity = maxItensity;\n for (int i = col; i < col + NUMPOINTSAVERAGED; i++) {\n sumRows += rows[i];\n minIntensity = java.lang.Math.min(minIntensity, intensities[i]);\n }\n data[col] = rows[col];\n dataAveraged[col] = java.lang.Math.round(sumRows / NUMPOINTSAVERAGED);\n minIntensities[col] = minIntensity;\n }\n\n for (int col = region.x; col < endCol - 2 * NUMPOINTSAVERAGED; col++) {\n splineCounter++;\n for (int row = region.y; row < endRow; row++) {\n if (row == data[col] && minIntensities[col] > INTENSITYTHRESHOLD * maxItensity) {\n // adds actual data\n xy.add((double) col, (double) convertYCoordToFreq(row));\n //System.out.println(\"adding data point (\" + col + \",\" + row + \")\");\n }\n\n if (row == dataAveraged[col] && minIntensities[col] > INTENSITYTHRESHOLD * maxItensity) {\n // adds averaged data\n //xy.add((double) col, (double) convertYCoordToFreq(row));\n //System.out.println(\"adding data point (\" + col + \",\" + row + \")\");\n if (splineCounter % SPLINEPRECISION == 0) {\n xySpline.add((double) (col + NUMPOINTSAVERAGED / 2), (double) convertYCoordToFreq(row));\n }\n }\n }\n }\n\n dataset.removeAllSeries();\n dataset.addSeries(xy);\n\n //XYSeriesCollection splineDataset = new XYSeriesCollection();\n dataset.addSeries(xySpline);\n\n JFreeChart chart = ChartFactory.createXYLineChart(\n //JFreeChart chart = ChartFactory.createScatterPlot(\n clip.getFileName(), \"Time (ms)\", \"Frequency (Hz)\", dataset, PlotOrientation.VERTICAL, true, true, false);\n XYPlot xyplot = (XYPlot) chart.getPlot();\n xyplot.setRenderer(new XYSplineRenderer());\n XYLineAndShapeRenderer xylineandshaperenderer = (XYLineAndShapeRenderer) xyplot.getRenderer();\n xylineandshaperenderer.setSeriesShape(0, new java.awt.Rectangle(1, 1, 1, 1));\n xylineandshaperenderer.setSeriesLinesVisible(0, false);\n xylineandshaperenderer.setSeriesShapesVisible(0, true);\n xylineandshaperenderer.setSeriesLinesVisible(1, false);\n xylineandshaperenderer.setSeriesShapesVisible(1, false);\n\n// ChartFrame frame = new ChartFrame(\"First\", chart);\n// frame.pack();\n// frame.setVisible(true);\n\n\n jCheckBox1.setEnabled(true);\n jCheckBox1.setSelected(true);\n\n jCheckBox2.setEnabled(true);\n jCheckBox2.setSelected(false);\n\n jSlider1.setEnabled(true);\n jSlider2.setEnabled(true);\n\n jTextField9.setText(clip.getFileName());\n\n chartPanel = new ChartPanel(chart);\n }",
"public void setChart(Chart chart) {\r\n \tgetAbstractChart().setChart(chart);\r\n }",
"@Override\n public void draw(WinPlotterFX plotter) {\n super.draw(plotter);\n plotter.printAt(x + (base / 3.2), y + (height / 3), name);\n }",
"private void setupDailyBarChart() {\r\n BarChart chart = findViewById(R.id.chart);\r\n chart.getDescription().setEnabled(false);\r\n chart.setExtraOffsets(0, 0, 0, 10);\r\n chart.setNoDataText(getResources().getString(R.string.loading_graph));\r\n chart.getPaint(Chart.PAINT_INFO).setTextSize(Utils.convertDpToPixel(16f));\r\n chart.getLegend().setEnabled(false);\r\n\r\n // Show time on x-axis at three hour intervals\r\n XAxis xAxis = chart.getXAxis();\r\n xAxis.setValueFormatter(new IAxisValueFormatter() {\r\n @Override\r\n public String getFormattedValue(float value, AxisBase axis) {\r\n int valueInt = (int) value;\r\n if(valueInt == 0) {\r\n return \"12am\";\r\n } else if(valueInt > 0 && valueInt < 12) {\r\n return valueInt + \"am\";\r\n } else if(valueInt == 12) {\r\n return \"12pm\";\r\n } else {\r\n return (valueInt - 12) + \"pm\";\r\n }\r\n }\r\n });\r\n\r\n xAxis.setPosition(XAxis.XAxisPosition.BOTTOM);\r\n xAxis.setDrawGridLines(false);\r\n xAxis.setTextSize(14f);\r\n // show label for every three hours\r\n xAxis.setGranularity(3.0f);\r\n xAxis.setLabelCount(8);\r\n xAxis.setGranularityEnabled(true);\r\n\r\n // Show non-sedentary hours on left y-axis\r\n YAxis yAxisLeft = chart.getAxisLeft();\r\n yAxisLeft.setAxisMinimum(0f);\r\n yAxisLeft.setTextSize(14f);\r\n yAxisLeft.setGranularity(1.0f); // show integer values on y axis\r\n yAxisLeft.setGranularityEnabled(true);\r\n\r\n YAxis yAxisRight = chart.getAxisRight();\r\n yAxisRight.setEnabled(false);\r\n }",
"private String generateChart() {\r\n\t\tint passedTestCount = data.getNumberofTestPassed();\r\n\t\tint skippedTestCount = data.getNumberofTestSkipped();\r\n\t\tint failedTestCount = data.getNumberofTestFailed();\r\n\r\n\t\tString script = \"<script>var svg = d3.select('svg'),\"\r\n\t\t\t\t+ \"margin = {top: 30, right: 20, bottom: 20, left: 50},\"\r\n\t\t\t\t+ \"width = +svg.attr('width') - margin.left - margin.right,\"\r\n\t\t\t\t+ \"height = +svg.attr('height') - margin.top - margin.bottom;\"\r\n\t\t\t\t+ \"var x = d3.scaleBand().range([0, 450]),\"\r\n\t\t\t\t+ \"y = d3.scaleLinear().rangeRound([230, 0]);\"\r\n\t\t\t\t+ \"var g = svg.append('g').attr('transform', 'translate(' + margin.left + ',' + margin.top + ')');\"\r\n\t\t\t\t+\r\n\r\n\t\t\t\t\"var data = [{'name':'Pass','value':\"\r\n\t\t\t\t+ passedTestCount\r\n\t\t\t\t+ \"},{'name':'FaiL','value':\"\r\n\t\t\t\t+ failedTestCount\r\n\t\t\t\t+ \"},{'name':'Skip','value':\"\r\n\t\t\t\t+ skippedTestCount\r\n\t\t\t\t+ \"}];\"\r\n\t\t\t\t+\r\n\r\n\t\t\t\t\"var max = 0;\"\r\n\t\t\t\t+ \"var index = 0;\"\r\n\t\t\t\t+ \"for(index=0;index<data.length;index++) {\"\r\n\t\t\t\t+ \"if(max<data[index]['value']) {\"\r\n\t\t\t\t+ \"max = data[index]['value']; } }\"\r\n\t\t\t\t+ \"max = max%2 ==0? max : max +1;\"\r\n\t\t\t\t+ \"x.domain(data.map(function(d) { return d.name; }));\"\r\n\t\t\t\t+ \"y.domain([0, max]);\"\r\n\t\t\t\t+ \"g.append('g').attr('class', 'axis axis--x')\"\r\n\t\t\t\t+ \".attr('transform', 'translate(0,' + height + ')')\"\r\n\t\t\t\t+ \".call(d3.axisBottom(x)).attr('stroke', '#000000');\"\r\n\t\t\t\t+ \"g.append('g').attr('class', 'axis axis--y')\"\r\n\t\t\t\t+ \".call(d3.axisLeft(y).ticks(3)).attr('stroke', '#000000')\"\r\n\t\t\t\t+ \".append('text').attr('transform', 'rotate(-90)').attr('y', 6)\"\r\n\t\t\t\t+ \".attr('dy', '0.71em').attr('text-anchor', 'end');\"\r\n\t\t\t\t+ \"d3.selectAll('line').attr('stroke', '#000000');\"\r\n\t\t\t\t+ \"d3.selectAll('path').attr('stroke', '#000000');\"\r\n\t\t\t\t+ \"var temp=0;\"\r\n\t\t\t\t+ \"g.selectAll('.bar').data(data).enter().append('rect').attr('class', 'bar')\"\r\n\t\t\t\t+ \".attr('x', function(d) {return x(d.name)+50; })\"\r\n\t\t\t\t+ \".attr('y', function(d) { return y(d.value); })\"\r\n\t\t\t\t+ \".attr('width', 50)\"\r\n\t\t\t\t+ \".attr('height', function(d) { return height - y(d.value); }).attr('fill','#ff9900')\"\r\n\t\t\t\t+ \".attr('data-name',function(d){return d.name})\"\r\n\t\t\t\t+ \".attr('data-value',function(d){return d.value}).attr('height', 0).transition().duration(1000).delay(200).attr('height', function (d, i) {return height - y(d.value);});;</script>\";\r\n\t\treturn script;\r\n\t}",
"public Chart initializeChart();",
"String generateChartString(int type) { //format the hourly exposure data into a format that can be sent to quickchart.. Type 1=hour, type 2=day, type 3 = week\n\n //chart fomratting data\n String BASE_REQUEST_HOUR = \"https://quickchart.io/chart?c={type:%27line%27,%20options:%20{legend:%20{display:%20false}},data:{labels:[%2712%20AM%27,%271%20AM%27,%272%20AM%27,%273%20AM%27,%274%20AM%27,%275%20AM%27,%276%20AM%27,%277%20AM%27,%278%20AM%27,%279%20AM%27,%2710%20AM%27,%2711%20AM%27,%2712%20PM%27,%20%271%20PM%27,%272%20PM%27,%273%20PM%27,%274%20PM%27,%275%20PM%27,%276%20PM%27,%277%20PM%27,%278%20PM%27,%279%20PM%27,%2710%20PM%27,%2711%20PM%27],%20datasets:[{label:%27%27,%20data:%20[#CHARTDATA#],%20fill:false,borderColor:%27blue%27}]}}\";\n String BASE_REQUEST_MINUTE = \"https://quickchart.io/chart?c={type:%27line%27,%20options:%20{legend:%20{display:%20false}},data:{labels:[#LABELDATA#],%20datasets:[{label:%27%27,%20data:%20[#CHARTDATA#],%20fill:false,borderColor:%27blue%27}]}}\";\n String BASE_REQUEST_DAILY = \"https://quickchart.io/chart?c={type:'line', options: {legend: {display: false}},data:{labels:[#LABELDATA#], datasets:[{label:'', data: [#CHARTDATA#], fill:false,borderColor:'blue'}]}}\";\n\n //Strings for obtained data\n String hourlyData = \"\";\n String dailyData = \"\";\n String minuteData = \"\";\n\n //formats and keys\n SimpleDateFormat todayFormat = new SimpleDateFormat(\"dd-MMM-yyyy\");\n String todayKey = todayFormat.format(Calendar.getInstance(TimeZone.getDefault(), Locale.getDefault()).getTime());\n\n SimpleDateFormat minuteFormat = new SimpleDateFormat(\"-H-dd-MMM-yyyy\");\n String minuteKey = minuteFormat.format(Calendar.getInstance(TimeZone.getDefault(), Locale.getDefault()).getTime());\n SimpleDateFormat hourFormat = new SimpleDateFormat(\"H\");\n final SharedPreferences prefs = getSharedPreferences(\"com\", MODE_PRIVATE);\n\n int thisHour = Integer.parseInt(hourFormat.format(Calendar.getInstance(TimeZone.getDefault(), Locale.getDefault()).getTime())); //todo: clearer way of getting current hour\n\n // /go through each hour of the day and append teh number of contacts to hourlydata.\n // We want to plot points for all the hours that have actually happened. Some might be missing data (if the app wasn't running), so show these as 0\n for (int time = 0; time <= thisHour; time++) {\n int contactNum = prefs.getInt(time + \"-\" + todayKey, -1);\n if (contactNum > -1) { //we actually have data for this slot\n hourlyData = hourlyData + contactNum + \",\";\n } else {\n hourlyData = hourlyData + \"0,\";\n }\n }\n //now do the same thing for minute\n for (int min = 0; min <= 59; min++) {\n int contactNum = prefs.getInt(\"min-\" + min + minuteKey, -1);\n\n\n if (contactNum > -1) { //we actually have data for this slot\n minuteData = minuteData + contactNum + \",\";\n } else {\n minuteData = minuteData + \"0,\";\n }\n }\n\n\n //for this one we use a custom label since it is getting data for the last 7 days and we don't know up front which weekdays\n //Therefore, we find the day of the week for each data point and plug it in\n SimpleDateFormat weekdayFormat = new SimpleDateFormat(\"E\");\n String WEEK_LABELS = \"\";\n //and for the day of the week\n for (int daysBehind = 6; daysBehind >= 0; daysBehind--) {\n Calendar thisDate = Calendar.getInstance(TimeZone.getDefault(), Locale.getDefault());\n thisDate.add(Calendar.DATE, 0 - daysBehind);\n String thisDayKey = todayFormat.format(thisDate.getTime());\n String thisDayLabel = weekdayFormat.format(thisDate.getTime());\n WEEK_LABELS = WEEK_LABELS + \"'\" + thisDayLabel + \"'\" + \",\";\n\n\n int contactNum = prefs.getInt(thisDayKey, -1);\n if (contactNum > -1) { //we actually have data for this slot\n dailyData = dailyData + contactNum + \",\";\n } else {\n dailyData = dailyData + \"0,\";\n }\n }\n\n //return the URL for the request chart. 1=current hour, 2=current day, 3=current week\n if (type == 1) {\n String minLabel = \"\";\n for (int i = 0; i < 60; i++) { //create labels from 1 to 60 minutes\n minLabel = minLabel + i + \",\";\n }\n BASE_REQUEST_MINUTE = BASE_REQUEST_MINUTE.replace(\"#LABELDATA#\", minLabel).replace(\"#CHARTDATA#\", minuteData);\n return BASE_REQUEST_MINUTE;\n } else if (type == 2) {\n BASE_REQUEST_HOUR = BASE_REQUEST_HOUR.replace(\"#CHARTDATA#\", hourlyData); //plug the data into the URL\n return BASE_REQUEST_HOUR;\n } else {\n BASE_REQUEST_DAILY = BASE_REQUEST_DAILY.replace(\"#CHARTDATA#\", dailyData).replace(\"#LABELDATA#\", WEEK_LABELS); //plug the data into the URL\n return BASE_REQUEST_DAILY;\n }\n }",
"private void drawGraph() {\n // you can show warning messages now\n imrGuiBean.showWarningMessages(true);\n addGraphPanel();\n setButtonsEnable(true);\n }",
"private void last30DaysReport() {\n\t\tListSeries dollarEarning = new ListSeries();\n//\t\tString[] dates = controler.getLast30DaysTransactionsDates();\n\t\tString[] dates = getLast30Dates();\n\t\t\n\t\tvReportDisplayLayout.removeAllComponents();\n\t\t\n\t\tdollarEarning = getLast30DaysData();\n\t\tdisplayChart chart = new displayChart();\n\t\t\n\t\tdReportPanel.setContent(chart.getDisplayChart(dates, dollarEarning));\n\t\tvReportDisplayLayout.addComponent(dReportPanel);\n\t}",
"public void displayGraph() {\r\n\t\tgraph.display();\r\n\t}",
"private void setContentEstadisticas(View root){\n spinnerMeasure = root.findViewById(R.id.spinnerMeasure);\n ArrayAdapter<CharSequence> measureAdapter = ArrayAdapter.createFromResource(getContext(),\n R.array.measure_array, android.R.layout.simple_spinner_item);\n measureAdapter.setDropDownViewResource(android.R.layout.simple_spinner_dropdown_item);\n spinnerMeasure.setAdapter(measureAdapter);\n spinnerMeasure.setOnItemSelectedListener(this);\n\n // Setting options for spinnerPeriod\n spinnerPeriod = root.findViewById(R.id.spinnerPeriod);\n ArrayAdapter<CharSequence> periodAdapter = ArrayAdapter.createFromResource(getContext(),\n R.array.period_array, android.R.layout.simple_spinner_item);\n periodAdapter.setDropDownViewResource(android.R.layout.simple_spinner_dropdown_item);\n spinnerPeriod.setAdapter(periodAdapter);\n spinnerPeriod.setOnItemSelectedListener(this);\n\n // Setting options for graph, default = km/week\n lineChart = root.findViewById(R.id.lineChart);\n date = new Date();\n Calendar calendar = Calendar.getInstance();\n calendar.setTime(date);\n\n String day = Integer.toString(calendar.get(Calendar.DAY_OF_MONTH));\n String month = Integer.toString(calendar.get(Calendar.MONTH) + 1) ;\n day = day.length() == 1 ? \"0\" + day : day;\n month = month.length() == 1 ? \"0\" + month : month;\n\n TextView periodGraph = root.findViewById(R.id.periodGraph);\n periodGraph.setText( day + \"/\" + month + \"/\" + calendar.get(Calendar.YEAR));\n\n // Styling description\n Description description = lineChart.getDescription();\n description.setEnabled(false);\n // Styling legend\n Legend legend = lineChart.getLegend();\n legend.setEnabled(false);\n // Styling xAxis\n XAxis xAxis = lineChart.getXAxis();\n xAxis.setPosition(XAxis.XAxisPosition.BOTTOM);\n xAxis.setGranularity(1f);\n xAxis.setDrawAxisLine(true);\n xAxis.setAxisLineColor(getResources().getColor(R.color.colorPrimaryExtraDark));\n xAxis.setAxisLineWidth(1f);\n xAxis.setGridColor(getResources().getColor(R.color.colorPrimaryLigth2));\n xAxis.setTextColor(getResources().getColor(R.color.colorPrimary));\n // Other styling\n lineChart.setNoDataText(getResources().getString(R.string.noChartData));\n\n // Refreshing chart\n lineChart.invalidate();\n\n\n // Setting buttons for graph\n Button btnSelectDate = root.findViewById(R.id.buttonSelectDate);\n btnSelectDate.setOnClickListener(this);\n }",
"String getHtml() {\n Map<String, Object> context = new HashMap<>();\n context.put(\"tileRows\", mTileRows);\n context.put(\"rows\", mRows);\n context.put(\"columns\", Lists.newArrayList(mColumnsByStartMillis.values()));\n context.put(\"numColumnsPerDay\", getSegmentStartTimes().length);\n context.put(\"nowColumnStart\", mNowColumn.start);\n context.put(\"nowDate\", mNow.toLocalDate());\n context.put(\"orders\", mOrders);\n context.put(\"dataCellsByConceptId\", getJsonDataDump());\n return renderTemplate(\"assets/chart.html\", context);\n }",
"public static void main(String[] args) throws Exception {\n\t\tBarcharPhone chart = new BarcharPhone(null);\r\n\t\tchart.renderBarChart();\r\n\t\tchart.pack( ); \r\n\t RefineryUtilities.centerFrameOnScreen( chart ); \r\n\t chart.setVisible( true ); \r\n\t}",
"@Override\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\n Bundle savedInstanceState) {\n View view = inflater.inflate(R.layout.fragment_piechart, container, false);\n view.setBackgroundColor(getResources().getColor(R.color.background));\n\n Log.d(TAG, \"onCreate: starting to create chart\");\n\n //Reference piechart in xml layout\n pieChart = (PieChart)view.findViewById(R.id.pieChart1);\n\n //Generate inner circle\n pieChart.setRotationEnabled(true);\n pieChart.setHoleRadius(25f);\n pieChart.setHoleColor(Color.BLACK);\n pieChart.setTransparentCircleAlpha(0);\n\n pieChart.setCenterText(\"Revenue(%)\");\n pieChart.setCenterTextColor(Color.WHITE);\n pieChart.setCenterTextSize(16);\n pieChart.setDescription(null);\n\n //Handles the population of chart data\n addDataSet();\n\n /*Handles the touch event for the chart slices (Displaying message info)*/\n pieChart.setOnChartValueSelectedListener(new OnChartValueSelectedListener() {\n @Override\n public void onValueSelected(Entry e, Highlight h) {\n\n Log.d(TAG,\"onValueSelected: Value select from chart\");\n Log.d(TAG,\"onValueSelected: \" + e.toString());\n Log.d(TAG,\"onValueSelected: \" + h.toString());\n\n int pos1=e.toString().indexOf(\"(sum): \");\n String sales = e.toString().substring(pos1 + 18);\n\n\n for(int i=0; i<yData.length; i++){\n\n if(yData[i] == Float.parseFloat(sales)){\n pos1 = i;\n break;\n }\n }\n\n String company = xData[pos1];\n Toast.makeText(getContext(), \"Store: \" + company + \"\\n\" +\"$\"\n +yValues[pos1]+ \" Billion\", Toast\n .LENGTH_SHORT)\n .show();\n\n\n }\n\n @Override\n public void onNothingSelected() {\n\n }\n });\n\n return view;\n\n }",
"public void generateBarChart(float[] act, float[] act1)\n {\n\n HorizontalBarChart barChart= (HorizontalBarChart) findViewById(R.id.chart);\n /*\n ArrayList<BarEntry> entries = new ArrayList<>();\n entries.add(new BarEntry(4f, 0));\n entries.add(new BarEntry(8f, 1));\n entries.add(new BarEntry(6f, 2));\n entries.add(new BarEntry(12f, 3));\n entries.add(new BarEntry(18f, 4));\n entries.add(new BarEntry(10f, 6));\n entries.add(new BarEntry(14f, 7));\n entries.add(new BarEntry(2f, 5));\n\n BarDataSet dataset1 = new BarDataSet(entries, \"# of Calls\");\n */\n\n ArrayList<String> labels = new ArrayList<String>();\n labels.add(\"Food\");\n labels.add(\"Cloth\");\n labels.add(\"Travelling\");\n labels.add(\"Stationary\");\n labels.add(\"Furniture\");\n labels.add(\"Medicine\");\n labels.add(\"Bill\");\n labels.add(\"Utensils\");\n\n\n /* for create Grouped Bar chart*/\n ArrayList<BarEntry> group1 = new ArrayList<>();\n group1.add(new BarEntry(act1[0], 0));\n group1.add(new BarEntry(act1[1], 1));\n group1.add(new BarEntry(act1[2], 2));\n group1.add(new BarEntry(act1[3], 3));\n group1.add(new BarEntry(act1[4], 4));\n group1.add(new BarEntry(act1[5], 5));\n group1.add(new BarEntry(act1[6], 6));\n group1.add(new BarEntry(act1[7], 7));\n\n ArrayList<BarEntry> group2 = new ArrayList<>();\n group2.add(new BarEntry(act[0], 0));\n group2.add(new BarEntry(act[1], 1));\n group2.add(new BarEntry(act[2], 2));\n group2.add(new BarEntry(act[3], 3));\n group2.add(new BarEntry(act[4], 4));\n group2.add(new BarEntry(act[5], 5));\n group2.add(new BarEntry(act[6], 6));\n group2.add(new BarEntry(act[7], 7));\n\n BarDataSet barDataSet1 = new BarDataSet(group1, \"Planned Amount\");\n //barDataSet1.setColor(Color.rgb(0, 155, 0));\n barDataSet1.setColor(getResources().getColor(R.color.darkgreen));\n\n BarDataSet barDataSet2 = new BarDataSet(group2, \"Actual Amount\");\n barDataSet2.setColor(getResources().getColor(R.color.purered));\n\n\n ArrayList<IBarDataSet> dataset = new ArrayList<>();\n dataset.add(barDataSet1);\n dataset.add(barDataSet2);\n /**/\n\n BarData data = new BarData(labels,dataset);\n// // dataset.setColors(ColorTemplate.COLORFUL_COLORS); //\n barChart.setData(data);\n barChart.animateY(5000);\n barChart.setDescription(\"Expense Graph\");\n barChart.setDescriptionPosition(2f, 2f);\n\n }",
"public void draw() {\n\t\tp.pushStyle();\n\t\t{\n\t\t\tp.rectMode(PConstants.CORNER);\n\t\t\tp.fill(360, 0, 70, 180);\n\t\t\tp.rect(60f, 50f, p.width - 110f, p.height * 2f * 0.33f - 50f);\n\t\t\tp.rect(60f, p.height * 2f * 0.33f + 50f, p.width - 110f, p.height * 0.33f - 130f);\n\t\t}\n\t\tp.popStyle();\n\n\t\tlineChart.draw(40f, 40f, p.width - 80f, p.height * 2f * 0.33f - 30f);\n\t\tlineChart2.draw(40f, p.height * 2f * 0.33f + 45f, p.width - 80f, p.height * 0.33f - 110f);\n\t\t//p.line(x1, y1, x2, y2);\n\n\t}",
"private void setCustomGraph(){\n\n // Set Touch, Drag and Scale to enable\n chart.setTouchEnabled(false);\n chart.setDragEnabled(false);\n chart.setScaleEnabled(false);\n\n // Controlling right side of y axis\n YAxis yAxisRight = chart.getAxisRight();\n yAxisRight.setEnabled(false);\n\n // Controlling left side of y axis\n YAxis yAxisLeft = chart.getAxisLeft();\n yAxisLeft.setGranularity(1f);\n\n yAxisLeft.setAxisLineColor(Color.TRANSPARENT);\n yAxisLeft.setDrawLabels(false);\n\n chart.getDescription().setEnabled(false);\n\n chart.getAxisLeft().setDrawGridLines(false);\n chart.getXAxis().setDrawGridLines(false);\n\n\n //Controlling X axis\n xAxis = chart.getXAxis();\n //Set the xAxis position to bottom\n xAxis.setPosition(XAxis.XAxisPosition.BOTTOM);\n\n IAxisValueFormatter formatter = new IAxisValueFormatter() {\n @Override\n public String getFormattedValue(float value, AxisBase axis) {\n return weeks[(int) value];\n }\n };\n\n // minimum axis-step interval is 1\n xAxis.setGranularity(1f);\n xAxis.setValueFormatter(formatter);\n\n }",
"protected void reloadText() {\n this.chart.getPlot().setNoDataMessage(translator.translate(\"noDataAvailable\"));\n //this.chart.setTitle(translator.translate(key));\n //TODO extend method for x and y title exchange\n }",
"@SuppressWarnings(\"unchecked\")\n // <editor-fold defaultstate=\"collapsed\" desc=\"Generated Code\">//GEN-BEGIN:initComponents\n private void initComponents() {\n\n pnlChart = new javax.swing.JPanel();\n jButton2 = new javax.swing.JButton();\n\n setDefaultCloseOperation(javax.swing.WindowConstants.EXIT_ON_CLOSE);\n\n pnlChart.setBackground(new java.awt.Color(0, 0, 0));\n pnlChart.setBorder(javax.swing.BorderFactory.createLineBorder(new java.awt.Color(0, 0, 0)));\n pnlChart.setForeground(new java.awt.Color(255, 255, 255));\n pnlChart.setAlignmentX(1.5F);\n pnlChart.setAlignmentY(0.35F);\n pnlChart.setMaximumSize(new java.awt.Dimension(1000, 1000));\n pnlChart.setMinimumSize(new java.awt.Dimension(1, 1));\n pnlChart.setPreferredSize(new java.awt.Dimension(1, 1));\n pnlChart.setLayout(new java.awt.BorderLayout());\n\n jButton2.setText(\"jButton2\");\n jButton2.addActionListener(new java.awt.event.ActionListener() {\n public void actionPerformed(java.awt.event.ActionEvent evt) {\n jButton2ActionPerformed(evt);\n }\n });\n pnlChart.add(jButton2, java.awt.BorderLayout.PAGE_START);\n\n javax.swing.GroupLayout layout = new javax.swing.GroupLayout(getContentPane());\n getContentPane().setLayout(layout);\n layout.setHorizontalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addComponent(pnlChart, javax.swing.GroupLayout.PREFERRED_SIZE, 631, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addGap(0, 993, Short.MAX_VALUE))\n );\n layout.setVerticalGroup(\n layout.createParallelGroup(javax.swing.GroupLayout.Alignment.LEADING)\n .addGroup(layout.createSequentialGroup()\n .addComponent(pnlChart, javax.swing.GroupLayout.PREFERRED_SIZE, 595, javax.swing.GroupLayout.PREFERRED_SIZE)\n .addGap(0, 801, Short.MAX_VALUE))\n );\n\n pack();\n }",
"private void btnRenderActionPerformed(java.awt.event.ActionEvent evt) {\n \r\n String x = jcbX_Axis.getSelectedItem().toString();\r\n String y = jcbY_Axis.getSelectedItem().toString();\r\n \r\n if(y.equals(\"Depth\")){\r\n //log plot\r\n \r\n WitsmlLogCurve ydata = currentCurves.get(0);\r\n WitsmlLogCurve xdata = null;\r\n // the selected value by looping through the curve object\r\n \r\n for(int i = 1; i < currentCurves.size(); i ++){\r\n if(x.equals(currentCurves.get(i).getDescription())){\r\n xdata = currentCurves.get(i);\r\n // System.out.println(\"got \"+currentCurves.get(i).getDescription());\r\n break;\r\n }\r\n }\r\n \r\n \r\n List<Object> yvalues = ydata.getValues();\r\n List<Object> xvalues = xdata.getValues();\r\n \r\n \r\n String title = \"Depth against \"+xdata.getDescription();\r\n XYSeries series = new XYSeries(title);\r\n for(int i = 0; i<yvalues.size(); i++){\r\n Object vx = xvalues.get(i);\r\n Object vy = yvalues.get(i);\r\n double dx = Double.parseDouble(vx.toString());\r\n double dy = Double.parseDouble(vy.toString());\r\n // System.out.println(\"depth : \"+dy +\" : \"+title+\" : \"+dx);\r\n series.add(dx, dy);\r\n }\r\n XYSeriesCollection data = new XYSeriesCollection();\r\n data.addSeries(series);\r\n \r\n // create a chart using the createYLineChart method...\r\n JFreeChart chart = ChartFactory.createXYLineChart(title, // chart title\r\n xdata.getDescription(), \"Depth\", // x and y axis labels\r\n data); // data\r\n \r\n XYPlot plot = (XYPlot) chart.getPlot();\r\n XYLineAndShapeRenderer renderer = new XYLineAndShapeRenderer();\r\n renderer.setSeriesLinesVisible(0, true);\r\n renderer.setSeriesShapesVisible(0, false);\r\n renderer.setSeriesLinesVisible(1, false);\r\n renderer.setSeriesShapesVisible(1, true); \r\n plot.setRenderer(renderer);\r\n ChartPanel cp = new ChartPanel(chart);\r\n setDisplayArea(cp);\r\n \r\n }else{\r\n // trajectory\r\n \r\n ArrayList<Double> ax = getValues(x);\r\n ArrayList<Double> ay = getValues(y);\r\n \r\n XYSeries series = new XYSeries(trajName);\r\n for(int i = 0; i < ax.size(); i++){\r\n series.add(ax.get(i), ay.get(i));\r\n }\r\n XYSeriesCollection data = new XYSeriesCollection();\r\n data.addSeries(series);\r\n JFreeChart chart = ChartFactory.createXYLineChart(trajName, // chart title\r\n x, y, // x and y axis labels\r\n data);\r\n ChartPanel cp = new ChartPanel(chart);\r\n setDisplayArea(cp);\r\n// call a method to select the method here \r\n }\r\n }",
"public ChartFrame(Chart chart) {\r\n\t\tthis.chart = chart;\r\n\t\t\r\n\t\tfor(int r = 0; r < seatGrid.length; r++) {\r\n\t\t\tfor(int c = 0; c < seatGrid[r].length; c++) {\r\n\t\t\t\tJLabel label = new JLabel();\r\n\t\t\t\tlabel.setBorder(BorderFactory.createLineBorder(Color.BLACK, 1));\r\n\t\t\t\tseatGrid[r][c] = label;\r\n\t\t\t}\r\n\t\t}\r\n\t\t\r\n\t\tremoveBtn = new JButton(\"Remove\");\r\n\t\tremoveBtn.addActionListener(new ActionListener() {\r\n\t\t\t@Override\r\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\r\n\t\t\t\tonRemoveClicked();\r\n\t\t\t}\r\n\t\t});\r\n\t\t\r\n\t\taddBtn = new JButton(\"Add\");\r\n\t\taddBtn.addActionListener(new ActionListener() {\r\n\t\t\t@Override\r\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\r\n\t\t\t\tonAddClicked();\r\n\t\t\t}\r\n\t\t});\r\n\t\t\r\n\t\tswapBtn = new JButton(\"Swap\");\r\n\t\tswapBtn.addActionListener(new ActionListener() {\r\n\t\t\t@Override\r\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\r\n\t\t\t\tonSwapClicked();\r\n\t\t\t}\r\n\t\t});\r\n\t\t\r\n\t\tloadBtn = new JButton(\"Load\");\r\n\t\tloadBtn.addActionListener(new ActionListener() {\r\n\t\t\t@Override\r\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\r\n\t\t\t\tonLoadClicked();\r\n\t\t\t}\r\n\t\t});\r\n\t\t\r\n\t\tmoveBtn = new JButton(\"Move\");\r\n\t\tmoveBtn.addActionListener(new ActionListener() {\r\n\t\t\t@Override\r\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\r\n\t\t\t\tonMoveClicked();\r\n\t\t\t}\r\n\t\t});\r\n\t\t\r\n\t\tJPanel panel = new JPanel();\r\n\t\tpanel.setBorder(BorderFactory.createEmptyBorder(20, 20, 20, 20));\r\n\t\tpanel.setLayout(new GridLayout(7, 5));\r\n\t\t\r\n\t\tfor(int r = 0; r < seatGrid.length; r++) {\r\n\t\t\tfor(int c = 0; c < seatGrid[r].length; c++) {\r\n\t\t\t\tpanel.add(seatGrid[r][c]);\r\n\t\t\t}\r\n\t\t}\r\n\t\t\r\n\t\t\r\n\t\tfor(int i = 0; i < seatGrid[0].length; i++) {\r\n\t\t\tpanel.add(Box.createHorizontalGlue());\r\n\t\t}\r\n\r\n\t\tpanel.add(removeBtn);\r\n\t\tpanel.add(addBtn);\r\n\t\tpanel.add(loadBtn);\r\n\t\tpanel.add(swapBtn);\r\n\t\tpanel.add(moveBtn);\r\n\r\n\t\tadd(panel);\r\n\t\tsetSize(500, 400);\r\n\t\tsetVisible(true);\r\n\t\tsetTitle(\"Seating Chart\");\r\n\t\tupdate();\r\n\r\n\t}",
"private void initialize() {\n\t\tfrmcCharts = new JFrame();\n\t\tfrmcCharts.setTitle(\"8C Charts\");\n\t\tfrmcCharts.setBounds(100, 100, 775, 487);\n\t\tfrmcCharts.setDefaultCloseOperation(JFrame.EXIT_ON_CLOSE);\n\t\t\n\t\tJPanel panel = new JPanel();\n\t\tpanel.setBackground(SystemColor.activeCaption);\n\t\tfrmcCharts.getContentPane().add(panel, BorderLayout.CENTER);\n\t\tpanel.setLayout(null);\n\t\t\n\t\tJLabel lblWelcomeToc = new JLabel(\"Welcome to 8C Charts\");\n\t\tlblWelcomeToc.setFont(new Font(\"Tahoma\", Font.BOLD, 20));\n\t\tlblWelcomeToc.setBounds(239, 42, 242, 35);\n\t\tpanel.add(lblWelcomeToc);\n\t\t\n\t\tJButton btnWorkBreakdownTree = new JButton(\"Work Breakdown Tree\");\n\t\tbtnWorkBreakdownTree.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\n\t\t\t\t\n//\t\t\t\tWBT.main(null);\n\t\t\t\tchartType = \"WBT\";\n//\t\t\t\tframe.dispose();\n\t\t fileLoader.main(null);\n\t\t\t\t\n\t\t\t}\n\t\t});\n\t\tbtnWorkBreakdownTree.setBounds(26, 119, 187, 45);\n\t\tpanel.add(btnWorkBreakdownTree);\n\t\t\n\t\tJButton btnNewButton = new JButton(\"PERT Chart\");\n\t\tbtnNewButton.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\t\n\t\t\t\tchartType = \"PERT\";\n//\t\t\t\tframe.dispose();\n\t\t fileLoader.main(null);\n\t\t\t\t\n\t\t\t}\n\t\t});\n\t\tbtnNewButton.setBounds(26, 188, 187, 45);\n\t\tpanel.add(btnNewButton);\n\t\t\n\t\tJButton btnGanttChart = new JButton(\"GANTT Chart\");\n\t\tbtnGanttChart.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\t\n\t\t\t\tchartType = \"GANTT\";\n\t\t fileLoader.main(null);\n\t\t\t\t\n\t\t\t}\n\t\t});\n\t\tbtnGanttChart.setBounds(26, 259, 187, 45);\n\t\tpanel.add(btnGanttChart);\n\t\t\n\t\tTextArea textArea = new TextArea();\n\t\ttextArea.setEditable(false);\n\t\ttextArea.setBounds(239, 88, 510, 309);\n\t\tpanel.add(textArea);\n\t\ttextArea.setText(\"Welcome to 8C Charts\\r\\n\\r\\n8C Charts can create the perfect charts for all you project planning or schedueling \\r\\nneeds.\\r\\n\\r\\nThis application will allow you to create the following charts:\\r\\n\\r\\nWork Breakdown Tree (WBT):\\r\\n\\t\\r\\nThis diagram is to shows the main tasks that needs to be done and the sub task of \\r\\neach of the main tasks. It will order the tasks in priority of what needs to be done \\r\\nbefore another.\\r\\n\\r\\nPERT Chart:\\r\\n\\r\\nThis chart will have a diagram with all the different task that needs to be done. \\r\\nNext to the task it will also have the start and end dates for which the task \\r\\nneeds to be completed. It will also show you what tasks can be done at the same\\r\\ntime as other tasks and what has to be done before certain task can be started.\\r\\n\\r\\nGANTT Chart:\\r\\n\\r\\nThis chart shows a time line length for different tasks and how long each task will\\r\\ntake. It will also have all the information that the PERT Chart has but includes lines\\r\\nshowing the lastest start and finish time of each task.\\r\\n\\r\\n\");\n\t\t\n\t\tJButton btnDonate = new JButton(\"Donate\");\n\t\tbtnDonate.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\n\t\t donate.main(null);\n\t\t\t\t\n\t\t\t}\n\t\t});\n\t\t\n\t\tbtnDonate.setBounds(660, 414, 89, 23);\n\t\tpanel.add(btnDonate);\n\t\t\n\t\tJMenuBar menuBar = new JMenuBar();\n\t\tmenuBar.setToolTipText(\"\");\n\t\tmenuBar.setBounds(0, 0, 759, 21);\n\t\tpanel.add(menuBar);\n\t\t\n\t\tJMenu mnFile = new JMenu(\"File\");\n\t\tmenuBar.add(mnFile);\n\t\t\n\t\tJMenu mnWbt = new JMenu(\"WBT\");\n\t\tmenuBar.add(mnWbt);\n\t\t\n\t\tJMenu mnCreateNewFile = new JMenu(\"Create New File\");\n\t\tmnWbt.add(mnCreateNewFile);\n\t\t\n\t\tJMenu mnLoadExistingFile = new JMenu(\"Load Existing File\");\n\t\tmnWbt.add(mnLoadExistingFile);\n\t\t\n\t\tJMenu mnPert = new JMenu(\"PERT\");\n\t\tmenuBar.add(mnPert);\n\t\t\n\t\tJMenu mnCreateNewFile_1 = new JMenu(\"Create New File\");\n\t\tmnPert.add(mnCreateNewFile_1);\n\t\t\n\t\tJMenu mnLoadExistingFile_1 = new JMenu(\"Load Existing File\");\n\t\tmnPert.add(mnLoadExistingFile_1);\n\t\t\n\t\tJMenu mnGantt = new JMenu(\"GANTT\");\n\t\tmenuBar.add(mnGantt);\n\t\t\n\t\tJMenu mnCreateNewFile_2 = new JMenu(\"Create New File\");\n\t\tmnGantt.add(mnCreateNewFile_2);\n\t\t\n\t\tJMenu mnLoadExistingFile_2 = new JMenu(\"Load Existing File\");\n\t\tmnGantt.add(mnLoadExistingFile_2);\n\t\t\n\t\tJMenu mnHelp = new JMenu(\"Help\");\n\t\tmenuBar.add(mnHelp);\n\t\t\n\t\tJMenu mnDonate = new JMenu(\"Donate\");\n\t\tmnHelp.add(mnDonate);\n\t\t\n\t\tJMenu mnUserGuide = new JMenu(\"User Guide\");\n\t\tmnHelp.add(mnUserGuide);\n\t}",
"public JFreeChart createChart(IntervalXYDataset paramIntervalXYDataset) {\n\n\n JFreeChart jfreechart = ChartFactory.createXYBarChart(\n \"Spread Example\", //title\n \"Resource\", //xAxisLabel\n false, //dateAxis\n \"Timing\", //yAxisLabel\n paramIntervalXYDataset, //dataset\n PlotOrientation.VERTICAL, //orientation\n true, //legend\n true, //tooltips\n false); //urls\n\n\n\n XYPlot xyplot = (XYPlot) jfreechart.getPlot();\n\n xyplot.setBackgroundPaint(Color.white);\n xyplot.setRangeGridlinePaint(Color.darkGray);//vertical\n xyplot.setDomainGridlinePaint(Color.LIGHT_GRAY);//horizontal\n\n// xyplot.setDomainAxis(createTimeAxis());\n xyplot.setDomainAxis(createSymbolAxis());\n\n xyplot.setFixedLegendItems(createLegend());\n\n MyXYBarRenderer xyBarRenderer = new MyXYBarRenderer();\n xyBarRenderer.setUseYInterval(true);\n\n xyBarRenderer.setShadowVisible(false);\n\n xyBarRenderer.setDrawBarOutline(true);\n xyBarRenderer.setBaseOutlinePaint(Color.DARK_GRAY);\n\n xyBarRenderer.setBaseItemLabelFont(new Font(\"Arial\", Font.PLAIN, 10));\n\n xyBarRenderer.setMargin(0.2);\n xyplot.setRenderer(0, xyBarRenderer, true);\n\n//xyBarRenderer.\n\n\n MyXYBarPainter barPainter = new MyXYBarPainter((XYTaskDataset) paramIntervalXYDataset);\n barPainter.setPainterType(MyXYBarPainter.PainterType.GRADIENT);\n xyBarRenderer.setBarPainter(barPainter);\n\n\n\n //Item-Label:\n xyBarRenderer.setBaseItemLabelsVisible(true);\n xyBarRenderer.setBaseItemLabelGenerator(createItemLabelGenerator());\n xyBarRenderer.setBasePositiveItemLabelPosition(createItemLabelPosition());\n\n\n\n xyBarRenderer.setBaseToolTipGenerator(createTooltipGenerator());\n\n\n\n//PeriodAxis xaxis= new PeriodAxis(\"kk\");\n\n xyplot.setRangeAxis(createTimeAxis());\n// xyplot.setRangeAxis(createSymbolAxis());\n\n\n\n// DateAxis xaxis = new DateAxis();\n// xaxis.setVerticalTickLabels(true);\n// xyplot.setRangeAxis(xaxis);\n xyplot.setRangeAxisLocation(AxisLocation.TOP_OR_LEFT);\n\n// ChartUtilities.applyCurrentTheme(jfreechart);\n\n return jfreechart;\n }",
"@Override\n public void initialize(URL url, ResourceBundle rb) { \n \n XYChart.Series series = new XYChart.Series<>();\n \n \n series.setName(\"Gagnant\");\n series.getData().add(new XYChart.Data(\"Jan\", 100));\n series.getData().add(new XYChart.Data(\"Fev\", 170));\n series.getData().add(new XYChart.Data(\"Mars\", 197));\n series.getData().add(new XYChart.Data(\"Avr\", 160));\n series.getData().add(new XYChart.Data(\"Mai\", 165));\n series.getData().add(new XYChart.Data(\"Juin\", 179));\n series.getData().add(new XYChart.Data(\"Juil\", 195));\n series.getData().add(new XYChart.Data(\"Aout\", 140));\n series.getData().add(new XYChart.Data(\"Sept\", 121));\n series.getData().add(new XYChart.Data(\"Oct\", 173));\n series.getData().add(new XYChart.Data(\"Nov\", 185));\n series.getData().add(new XYChart.Data(\"Dec\", 150));\n \n XYChart.Series perdant = new XYChart.Series<>();\n perdant.setName(\"Perdant\");\n \n perdant.getData().add(new XYChart.Data(\"Jan\", 80));\n perdant.getData().add(new XYChart.Data(\"Fev\", 60));\n perdant.getData().add(new XYChart.Data(\"Mars\", 80));\n perdant.getData().add(new XYChart.Data(\"Avr\", 70));\n perdant.getData().add(new XYChart.Data(\"Mai\", 70));\n perdant.getData().add(new XYChart.Data(\"Juin\", 60));\n perdant.getData().add(new XYChart.Data(\"Juil\", 100));\n perdant.getData().add(new XYChart.Data(\"Aout\", 80));\n perdant.getData().add(new XYChart.Data(\"Sept\", 50));\n perdant.getData().add(new XYChart.Data(\"Oct\", 79));\n perdant.getData().add(new XYChart.Data(\"Nov\", 70));\n perdant.getData().add(new XYChart.Data(\"Dec\", 12));\n \n\n Tooltip tooltip = new Tooltip(\"Le nombre de gagnants ou cours des mois augmentent souvent.\");\n areaChart.getStylesheets().add(\"-fx-color:green;\");\n areaChart.getData().addAll(series, perdant);\n BarChart.getStylesheets().add(\"chart-bar series<1> bar-legend-symbol default-color<red>\");\n BarChart.getData().addAll(perdant);\n\n\n }",
"public void onModuleLoad() {\n\n Chart chart = new Chart()\n .setType(Series.Type.SPLINE)\n .setChartTitleText(\"Temperaturen\")\n .setMarginRight(10);\n\t\n\tSeries series = chart.createSeries()\n\t.setName(\"°C in Palma\")\n\t.setPoints(new Number[] { 22.4, 25.6, 20.5, 19.0, 17.0, 18.0, 19.0, 18.3 });\n\tchart.addSeries(series);\n\n\tSeries series2 = chart.createSeries()\n\t.setName(\"°C in Leipzig\")\n\t.setPoints(new Number[] { 13.5, 14.3, 16.4, 9.9, 12.5, 13.0, 15.9, 20.0} );\n\tchart.addSeries(series2);\n\t\n\tRootPanel.get().add(chart);\n\t\n\t}",
"public BarChart() {\n\n\t\t//set the initial size of the store for curve data\n\t\tfor (int i = 0; i < 5; i++) {\n\t\t\tcvV.add(new CurveData());\n\t\t}\n\n\t\tbarChartPanel.add(GP, BorderLayout.CENTER);\n\n\t\tBorder etchedBorder = BorderFactory.createEtchedBorder();\n\t\tborder = BorderFactory.createTitledBorder(etchedBorder, \"Title\");\n\t\tborder.setTitleColor(Color.blue);\n\t\tbarChartPanel.setBorder(border);\n\n\t\tMarkerFormat = new MarkerFormat(barColumns);\n\n\t\tGP.setSmartGL(false);\n\t\tGP.setNumberFormatX(MarkerFormat);\n\n\t\tGP.addHorLimitsListener(\n\t\t\t\t\t\t\t\tnew ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\n\t\t\t\tint nClmns = barColumns.size();\n\t\t\t\tint nMaxLines = 0;\n\t\t\t\tjava.util.Iterator<BarColumn> itr = barColumns.iterator();\n\t\t\t\twhile (itr.hasNext()) {\n\t\t\t\t\tBarColumn bc = itr.next();\n\t\t\t\t\tif (nMaxLines < bc.size()) {\n\t\t\t\t\t\tnMaxLines = bc.size();\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t\tif (nClmns > 0 && nMaxLines > 0) {\n\t\t\t\t\t//int iMin = GP.getScreenX(GP.getCurrentMinX());\n\t\t\t\t\t//int iMax = GP.getScreenX(GP.getCurrentMaxX());\n\t\t\t\t\tint iMin = GP.getScreenX(GP.getInnerMinX());\n\t\t\t\t\tint iMax = GP.getScreenX(GP.getInnerMaxX());\n\n\t\t\t\t\twidth = (int) ((iMax - iMin) / (1.9 * nMaxLines * nClmns));\n\t\t\t\t\tif (width < 1) {\n\t\t\t\t\t\twidth = 1;\n\t\t\t\t\t}\n\n\t\t\t\t\tfor (int i = 1, n = Math.min(nClmns * nMaxLines + 1, cvV.size()); i < n; i++) {\n\t\t\t\t\t\tCurveData cd = cvV.get(i);\n\t\t\t\t\t\tcd.setLineWidth(width);\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t\tRunnable runRefresh =\n\t\t\t\tnew Runnable() {\n\t\t\t\t\tpublic void run() {\n\t\t\t\t\t\tGP.refreshGraphJPanel();\n\t\t\t\t\t}\n\t\t\t\t};\n\t\t\t\tThread mThread = new Thread(runRefresh);\n\t\t\t\tmThread.start();\n\t\t\t}\n\t\t});\n\n\t\t//operations with clicked point object\n\t\tJLabel infoLabel = new JLabel(\" Clicked Point Info: \", JLabel.CENTER);\n\n\t\tFunctionGraphsJPanel.ClickedPoint cpObj = GP.getClickedPointObject();\n\t\tcpObj.xValueLabel = new JLabel(\"X-Marker=\", JLabel.RIGHT);\n\t\tcpObj.xValueFormat = MarkerFormat;\n\t\tcpObj.xValueText = new JTextField(10);\n\t\tcpObj.xValueText.setHorizontalAlignment(JTextField.CENTER);\n\t\tcpObj.xValueText.setForeground(Color.blue);\n\n\t\tcpObj.yValueLabel = new JLabel(\" Value=\", JLabel.RIGHT);\n\t\tcpObj.yValueFormat = fortranFrmt;\n\t\tcpObj.yValueText = new JTextField(12);\n\t\tcpObj.yValueText.setHorizontalAlignment(JTextField.CENTER);\n\t\tcpObj.yValueText.setForeground(Color.blue);\n\n\t\tJPanel infoPanel = new JPanel(new FlowLayout(FlowLayout.LEFT, 4, 0));\n\t\tinfoPanel.add(infoLabel);\n\t\tinfoPanel.add(cpObj.xValueLabel);\n\t\tinfoPanel.add(cpObj.xValueText);\n\t\tinfoPanel.add(cpObj.yValueLabel);\n\t\tinfoPanel.add(cpObj.yValueText);\n\n\t\tbarChartPanel.add(infoPanel, BorderLayout.SOUTH);\n\t}",
"public ChartPanel createChartPanel(QueryResult myResult) throws Exception {\n\n myChart = makeChart(myResult);\n\n // create the chart frame and display it \n ChartPanel myChartPanel = new ChartPanel(myChart);\n\n return myChartPanel;\n }",
"public void buttonDisplayClick(View v){\n paused = true;\n passObject();\n Intent chartIntent = new Intent(this, SingleChartActivity.class);\n chartIntent.putExtra(\"chartType\", CURRENT_TOKEN);\n startActivity(chartIntent);\n }",
"@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\tint month;\n\t\tdouble maxtempereture,monthlytempereture,mintempereture;\n\t\tResultSet rs;\n\t\tlib.MySQL mysql = new lib.MySQL();\n\t\trs = mysql.selectAll();\n\t\tDefaultCategoryDataset data = new DefaultCategoryDataset();\n\t\ttry{\n\t\t\twhile(rs.next()){\n\t\t\t\tmonth = rs.getInt(\"Month\");\n\t\t\t\tmaxtempereture = rs.getDouble(\"MaxTempereture\");\n\t\t\t\tmonthlytempereture = rs.getDouble(\"MonthkyTempereture\");\n\t\t\t\tmintempereture = rs.getDouble(\"MinTempereture\");\n System.out.println(\"月:\" + month);\n System.out.println(\"最高気温:\" + maxtempereture);\n System.out.println(\"月間平均気温:\" + monthlytempereture);\n System.out.println(\"最低気温:\" + mintempereture);\n data.addValue(maxtempereture,\"MaxTempereture\",month+\"\");\n data.addValue(monthlytempereture,\"MonthlyTempereture\",month+\"\");\n data.addValue(mintempereture,\"MinTempereture\",month+\"\");\n\t\t }\n\t\t}catch(SQLException et){}\n\t\t JFreeChart chart = \n\t\t\t ChartFactory.createLineChart(\"TOKYO TEMPERETURE\",\n\t\t\t \"month\",\n\t\t\t \"tempereture\",\n\t\t\t data,\n\t\t\t PlotOrientation.VERTICAL,\n\t\t\t true,\n\t\t\t false,\n\t\t\t false);\n \n\n ChartPanel cpanel = new ChartPanel(chart);\n panel1.add(cpanel);\n cardlayout.next(this);\n\t}",
"void toChartData(XYChart<Number, Number> chart) {\n minX=0;\n maxX=0;\n Set<String> labels = new HashSet<>(dataLabels.values());\n for (String label : labels) {\n XYChart.Series<Number, Number> series = new XYChart.Series<Number, Number>();\n series.setName(label);\n dataLabels.entrySet().stream().filter(entry -> entry.getValue().equals(label)).forEach(entry -> {\n Point2D point = dataPoints.get(entry.getKey());\n series.getData().add(new XYChart.Data<>(point.getX(), point.getY()));\n if (minX == 0 || minX > point.getX()) {\n minX = point.getX();\n }\n if (maxX < point.getX()) {\n maxX = point.getX();\n }\n });\n\n series.setData(series.getData().sorted());\n chart.getData().add(series);\n }\n\n String[] lines = data.split(\"[\\n\\t]\");\n\n int i = 0;\n\n for (final Series<Number, Number> series : chart.getData()) {\n for (final Data<Number, Number> data : series.getData()) {\n Tooltip tooltip = new Tooltip();\n tooltip.setText(lines[3 * i] + \"\");\n Tooltip.install(data.getNode(), tooltip);\n i++;\n }\n }\n\n\n for (int k = 0; k < chart.getData().size(); k++) {\n chart.getData().get(k).getNode().setStyle(\"-fx-stroke: transparent;\");\n }\n\n }",
"public interface IChartGenerator {\n void show();\n}",
"@Override\n\tprotected final JFreeChart createChart() {\n\t\tJFreeChart jFreeChart=null;\n\t\tIntervalXYDataset dataset=createDataset();\n\t\t\n\t\tjFreeChart=ChartFactory.createXYBarChart(title,xalabel, dateAxis, yalabel,dataset, por, legend, tooltips, urls);\n\t\t\n\t\tXYPlot plot=(XYPlot)jFreeChart.getPlot();\n\t\tpreRender(plot);\n\t\treturn jFreeChart; \n\t}",
"public static void main(String[] args) {\n\t\texpNum = Integer.parseInt(args[0]);\n\n\t\tLineChart chart = new LineChart(\n\t\t\t\t\"Line Graph of Agent Pay-Off vrs Tournament\");\n\t\t/** Title Modified from original code **/\n\t\tchart.pack(); // resize the window to fit the graph\n\t\tRefineryUtilities.centerFrameOnScreen(chart); // display chart on screen\t\t\t\t\t\t\t\t\t\t\t\n\t\tchart.setVisible(true); // show the chart\n\t}",
"private void createChart() {\n\t\tchartSpace = CTChartSpace.Factory.newInstance();\n\t\tchart = chartSpace.addNewChart();\n\t\tCTPlotArea plotArea = chart.addNewPlotArea();\n\n\t\tplotArea.addNewLayout();\n\t\tchart.addNewPlotVisOnly().setVal(true);\n\n\t\tCTPrintSettings printSettings = chartSpace.addNewPrintSettings();\n\t\tprintSettings.addNewHeaderFooter();\n\n\t\tCTPageMargins pageMargins = printSettings.addNewPageMargins();\n\t\tpageMargins.setB(0.75);\n\t\tpageMargins.setL(0.70);\n\t\tpageMargins.setR(0.70);\n\t\tpageMargins.setT(0.75);\n\t\tpageMargins.setHeader(0.30);\n\t\tpageMargins.setFooter(0.30);\n\t\tprintSettings.addNewPageSetup();\n\t}",
"private void plotGPS(LineChart lineChart, GPS gps)\n {\n Description desc = new Description();\n\n if(gps.getTime() != null && gps.getElevation() != null)\n {\n final long refTimestamp = gps.getTime().get(0).toDate().getTime();\n\n // X-Axis //\n XAxis xAxis = lineChart.getXAxis();\n xAxis.setValueFormatter(new IAxisValueFormatter()\n {\n @Override\n public String getFormattedValue(float value, AxisBase axis)\n {\n SimpleDateFormat sdf_mmss = new SimpleDateFormat(getString(R.string.sdf_hhmmss));\n sdf_mmss.setTimeZone(TimeZone.getTimeZone(\"GMT\"));\n return sdf_mmss.format(new Date((long) (value + refTimestamp)));\n }\n });\n\n lineChart.getXAxis().setPosition(XAxis.XAxisPosition.BOTTOM);\n\n desc.setText(getString(R.string.axisTime));\n\n // Y-Axis //\n lineChart.getAxisLeft().setEnabled(true);\n lineChart.getAxisRight().setEnabled(true);\n\n // Data //\n // Elevation //\n ArrayList<Entry> xy1Vals = new ArrayList<Entry>();\n for (int i = 0; i < gps.getElevation().size(); i++)\n {\n xy1Vals.add(new Entry(new Long(gps.getTime().get(i).toDate().getTime()-refTimestamp).floatValue(), new Double(gps.getElevation().get(i)).floatValue()));\n }\n\n LineDataSet dataSet1 = new LineDataSet(xy1Vals, getString(R.string.axisElevation));\n dataSet1.setLineWidth(2f);\n dataSet1.setDrawCircleHole(false);\n dataSet1.setCircleRadius(3f);\n dataSet1.setColor(Color.BLUE);\n dataSet1.setCircleColor(Color.BLUE);\n dataSet1.setDrawVerticalHighlightIndicator(true);\n dataSet1.setAxisDependency(lineChart.getAxisLeft().getAxisDependency());\n\n // HeartRate //\n ArrayList<Entry> xy2Vals = new ArrayList<Entry>();\n for (int i = 0; i < gps.getHeartRate().size(); i++)\n {\n xy2Vals.add(new Entry(new Long(gps.getTime().get(i).toDate().getTime()-refTimestamp).floatValue(), new Double(gps.getHeartRate().get(i)).floatValue()));\n }\n\n LineDataSet dataSet2 = new LineDataSet(xy2Vals, getString(R.string.axisHeartRate));\n dataSet2.setLineWidth(2f);\n dataSet2.setDrawCircleHole(false);\n dataSet2.setCircleRadius(3f);\n dataSet2.setColor(Color.GREEN);\n dataSet2.setCircleColor(Color.GREEN);\n dataSet2.setDrawVerticalHighlightIndicator(true);\n dataSet2.setAxisDependency(lineChart.getAxisRight().getAxisDependency());\n\n ArrayList<ILineDataSet> dataSets = new ArrayList<ILineDataSet>();\n dataSets.add(dataSet1);\n dataSets.add(dataSet2);\n\n LineData data = new LineData(dataSets);\n\n // Loading of data //\n lineChart.setData(data);\n lineChart.invalidate();\n }\n else\n {\n lineChart.setNoDataText(getString(R.string.noDataGPS));\n desc.setText(\"\");\n }\n\n lineChart.setDescription(desc);\n }",
"private static JFreeChart createChart(CategoryDataset dataset) {\n JFreeChart chart = ChartFactory.createLineChart(\n \"Line Chart\", null /* x-axis label*/, \n \"Range\" /* y-axis label */, dataset);\n chart.addSubtitle(new TextTitle(\" Its is generated to show patient History \" \n ));\n chart.setBackgroundPaint(Color.white);\n CategoryPlot plot = (CategoryPlot) chart.getPlot();\n\tNumberAxis rangeAxis = (NumberAxis) plot.getRangeAxis();\n rangeAxis.setStandardTickUnits(NumberAxis.createIntegerTickUnits());\n // Line renderer = (BarRenderer) plot.getRenderer();\n // renderer.setDrawBarOutline(false);\n // LineAndShapeRenderer renderer = (LineAndShapeRenderer) plot.getRenderer(); \n//renderer.setItemMargin(3); \n//renderer.setItemLabelsVisible(true);\n chart.getLegend().setFrame(BlockBorder.NONE);\n return chart;\n }",
"public ChartPanel getChartPanel();",
"public void generateChart(int[] dataValues) {\n\t\t/*\n\t\t * The XYSeriesCollection object is a set XYSeries series (dataset) that\n\t\t * can be visualized in the same chart\n\t\t */\n\t\tXYSeriesCollection dataset = new XYSeriesCollection();\n\t\t/*\n\t\t * The XYSeries that are loaded in the dataset. There might be many\n\t\t * series in one dataset.\n\t\t */\n\t\tXYSeries data = new XYSeries(\"random values\");\n\n\t\t/*\n\t\t * Populating the XYSeries data object from the input Integer array\n\t\t * values.\n\t\t */\n\t\tfor (int i = 0; i < dataValues.length; i++) {\n\t\t\tdata.add(i, dataValues[i]);\n\t\t}\n\n\t\t// add the series to the dataset\n\t\tdataset.addSeries(data);\n\n\t\tboolean legend = false; // do not visualize a legend\n\t\tboolean tooltips = false; // do not visualize tooltips\n\t\tboolean urls = false; // do not visualize urls\n\n\t\t// Declare and initialize a createXYLineChart JFreeChart\n\t\tJFreeChart chart = ChartFactory.createXYLineChart(\"Grades Histogram\", \"Grades\", \"Frequency\", dataset,\n\t\t\t\tPlotOrientation.VERTICAL, legend, tooltips, urls);\n\n\t\t/*\n\t\t * Initialize a frame for visualizing the chart and attach the\n\t\t * previously created chart.\n\t\t */\n\t\tChartFrame frame = new ChartFrame(\"First\", chart);\n\t\tframe.pack();\n\t\t// makes the previously created frame visible\n\t\tframe.setVisible(true);\n\t}",
"public GUIVerbrauchsdiagramm(String title, EnergyData energyData) {\n super(title);\n this.energyData = energyData;\n setExtendedState(JFrame.MAXIMIZED_BOTH);\n ChartPanel chartPanel = (ChartPanel) createPanel(energyData);\n\n buttonGroup.add(verbrauchDiagramm);\n buttonGroup.add(zaehlerDiagramm);\n pRadiobuttons.add(verbrauchDiagramm);\n pRadiobuttons.add(zaehlerDiagramm);\n pRadiobuttons.setBorder(new EmptyBorder(0, 20, 0, 0));\n verbrauchDiagramm.setSelected(true);\n tDate.setForeground(Color.gray);\n\n pSkipDay.setLayout(new GridLayout(1, 7, 5, 0));\n pSkipDay.add(bBackwardsM);\n pSkipDay.add(bBackwardsW);\n pSkipDay.add(bBackwards);\n pSkipDay.add(tDate);\n pSkipDay.add(bForwards);\n pSkipDay.add(bForwardsW);\n pSkipDay.add(bForwardsM);\n\n pDate.add(lCurrentDate);\n pDate.add(lEmpty2);\n pDate.add(pSkipDay);\n\n\n pCsv.add(bExportCSV);\n pCsv.add(lEmpty);\n pCsv.add(bExportJSON);\n\n\n pHeader.add(pRadiobuttons);\n pHeader.add(pDate);\n pHeader.add(pCsv);\n\n this.add(chartPanel, BorderLayout.CENTER);\n this.add(pHeader, BorderLayout.NORTH);\n\n //Actionlistener\n ActionListener actionListenerDiagramm = new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n if (verbrauchDiagramm.isSelected()) {\n System.out.println(\"Verbrauchsdiagramm selected\");\n dataset.removeAllSeries();\n createDatasetVerbrauchsdiagramm(energyData);\n chart.setTitle(\"Stromzählerübersicht\");\n }\n if (zaehlerDiagramm.isSelected()) {\n System.out.println(\"Zählerdiagramm selected\");\n dataset.removeAllSeries();\n createDatasetZaehlerdiagramm(energyData);\n chart.setTitle(\"Zählerstand\");\n }\n }\n };\n\n bExportCSV.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n TreeMap<Long, csvData> map = FileHandler.getFileHandler().getCSVData();\n try {\n JFileChooser fileChooser = new JFileChooser(\"./CSV\");\n fileChooser.setDialogTitle(\"CSV-Datei speichern\");\n fileChooser.setFileFilter(new FileNameExtensionFilter(\"*.csv\",\"csv\"));\n\n int userSelection = fileChooser.showSaveDialog(getFrame());\n\n if (userSelection == JFileChooser.APPROVE_OPTION) {\n File fileToSave = fileChooser.getSelectedFile();\n String path = fileToSave.getPath();\n if (!path.contains(\".csv\")){\n path = path +\".csv\";\n }\n FileHandler.writeCSV(map,path);\n System.out.println(\"Save as file: \" + fileToSave.getAbsolutePath());\n }\n\n\n } catch (IOException ioException) {\n ioException.printStackTrace();\n }\n lEmpty.setText(\"Daten wurden in ein CSV-File exportiert\");\n }\n });\n\n bExportJSON.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n TreeMap<Long, csvData> map = FileHandler.getFileHandler().getCSVData();\n FileHandler.saveJSON(map);\n\n try {\n JFileChooser fileChooser = new JFileChooser(\"./JSON\");\n fileChooser.setDialogTitle(\"JSON-Datei speichern\");\n fileChooser.setFileFilter(new FileNameExtensionFilter(\"*.json\",\"json\"));\n\n int userSelection = fileChooser.showSaveDialog(getFrame());\n\n if (userSelection == JFileChooser.APPROVE_OPTION) {\n File fileToSave = fileChooser.getSelectedFile();\n String path = fileToSave.getPath();\n if (!path.contains(\".json\")){\n path = path +\".json\";\n }\n FileWriter fileWriter = new FileWriter(path);\n fileWriter.write(FileHandler.saveJSON(map));\n fileWriter.flush();\n fileWriter.close();\n System.out.println(\"Save as file: \" + fileToSave.getAbsolutePath());\n }\n\n\n } catch (IOException ioException) {\n ioException.printStackTrace();\n }\n lEmpty.setText(\"Daten wurden zum JSON exportiert \\n\" + \"https://api.npoint.io/0dc854da1619aca3be45\");\n }\n });\n\n bForwards.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n changeDate(86400000, true);\n }\n });\n\n bBackwards.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n changeDate(86400000, false);\n }\n });\n bBackwardsW.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n changeDate(604800000, false);\n }\n });\n bForwardsW.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n changeDate(604800000, true);\n }\n });\n bBackwardsM.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n changeDate(2629800000L, false);\n }\n });\n bForwardsM.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent e) {\n changeDate(2629800000L, true);\n }\n });\n\n /*chart.getXYPlot().addChangeListener(new PlotChangeListener() {\n @Override\n public void plotChanged(PlotChangeEvent plotChangeEvent) {\n XYPlot plot = plotChangeEvent.getPlot().getChart().getXYPlot();\n PlotChangeListener plotChangeListener = this;\n\n plot.removeChangeListener(plotChangeListener);\n long upperBound = (long) plot.getDomainAxis().getUpperBound();\n long lowerBound = (long) plot.getDomainAxis().getLowerBound();\n\n Calendar calendar = Calendar.getInstance();\n calendar.setTimeInMillis(upperBound / 900000 * 900000);\n upperBound = calendar.getTimeInMillis();\n\n calendar.setTimeInMillis(lowerBound / 900000 * 900000);\n lowerBound = calendar.getTimeInMillis();\n System.out.println(new SimpleDateFormat(\"dd-MM-yyyy HH:mm:ss\").format(new Date(lowerBound)));\n\n System.out.println(getEnergyData().getSdatData().containsKey(lowerBound));\n\n double highestValue = 0;\n if (getEnergyData().getSdatData().containsKey(lowerBound)) {\n for (long i = lowerBound; i < upperBound; i = i + 86400000) {\n if (getEnergyData().getSdatData().get(i).getRelativBezug() > highestValue) {\n highestValue = getEnergyData().getSdatData().get(i).getRelativBezug();\n\n }\n if (getEnergyData().getSdatData().get(i).getRelativeEinspeisung() > highestValue) {\n highestValue = getEnergyData().getSdatData().get(i).getZaehlerstandEinspeisung();\n }\n }\n\n System.out.println(highestValue);\n System.out.println(highestValue + 1);\n\n plot.getRangeAxis().setLowerBound(0);\n plot.getRangeAxis().setUpperBound(highestValue + 1);\n }else {\n plot.getRangeAxis().setLowerBound(0);\n plot.getRangeAxis().setUpperBound(plot.getRangeAxis().getUpperBound());\n }\n plot.addChangeListener(plotChangeListener);\n\n }\n\n });\n */\n\n tDate.addKeyListener(new KeyListener() {\n @Override\n public void keyTyped(KeyEvent e) {\n checkDate(e);\n }\n\n @Override\n public void keyPressed(KeyEvent e) {\n\n }\n\n @Override\n public void keyReleased(KeyEvent e) {\n\n }\n });\n\n tDate.addFocusListener(new FocusListener() {\n @Override\n public void focusGained(FocusEvent e) {\n if (tDate.getText().equals(\"Datum:\")) {\n tDate.setText(\"\");\n tDate.setForeground(Color.BLACK);\n }\n }\n\n @Override\n public void focusLost(FocusEvent e) {\n if (tDate.getText().isEmpty()) {\n tDate.setForeground(Color.GRAY);\n tDate.setText(\"Datum:\");\n }\n }\n });\n\n\n verbrauchDiagramm.addActionListener(actionListenerDiagramm);\n zaehlerDiagramm.addActionListener(actionListenerDiagramm);\n }",
"private void invokeHistoricChart(StockData sd)\r\n {\r\n\r\n debug(\"invokeHistoricChart(\" + sd.getName().toString() + \") - preparing to change\");\r\n\r\n String fileName = getString(\"WatchListTableModule.edit.historic_details_basic_name\") + sd.getSymbol().getDataSz();\r\n java.io.File theFile = new java.io.File(fileName);\r\n\r\n // First signal the chart if we are demo mode, we really do not want a problem\r\n // Then create a new instance of our chart.\r\n com.stockmarket.chart.ohlc.HighLowStockChart.DEMO_MODE = this.DEMO_MODE;\r\n com.stockmarket.chart.ohlc.HighLowStockChart chart = new com.stockmarket.chart.ohlc.HighLowStockChart();\r\n // If we have historic data send it through\r\n if (theFile.exists())\r\n {\r\n debug(\"invokeHistoricChart() - \" + fileName + \" exists preparing the Historic Chart\");\r\n chart.displayHighLowChart(fileName);\r\n }\r\n else if (this.DEMO_MODE)\r\n {\r\n // If we are demo mode display the Chart. With its default data\r\n javax.swing.JOptionPane.showMessageDialog(\r\n null,\r\n \"Application is in DEMO Mode\\n\"\r\n + \"No historic data for \"\r\n + sd.getName().toString()\r\n + \" exists, displaying default graph.\");\r\n chart.displayHighLowChart(null);\r\n }\r\n else\r\n {\r\n // If we are live mode and no historic data - tell the user to try later.\r\n // This is the case where the user reached a item to display as a chart\r\n // before the program has finished downloading.\r\n javax.swing.JOptionPane.showMessageDialog(\r\n null,\r\n \"Application has no historic data for \" + sd.getName().toString() + \"\\nTry again later!\");\r\n }\r\n\r\n debug(\"invokeHistoricChart() - Processing completed\");\r\n }",
"public void initializeChart(String subtitle) {\n JFreeChart jfreechart = ChartFactory.createXYLineChart(\n subtitle, \"X\", \"Y\", this.dataset.getXYDataset(),\n PlotOrientation.VERTICAL, true, true, false);\n XYPlot xyplot = (XYPlot) jfreechart.getPlot();\n XYLineAndShapeRenderer xylineandshaperenderer = new XYLineAndShapeRenderer();\n xylineandshaperenderer.setBaseLinesVisible(true);\n\n // System.out.println(\"date set series count: \" + xydataset.getSeriesCount());\n // set visible or not shapes of series\n// System.out.printf(\"sets in the dataset: \"); // TODO delete this \"print\" if necessary\n for (int i = 0; i < this.dataset.seriesCount(); i++) {\n// System.out.printf(this.dataset.getSeries(i).getKey() + \" \");\n xylineandshaperenderer.setSeriesLinesVisible(i, false);\n xylineandshaperenderer.setSeriesShapesVisible(i, this.dataset.shapeVisible(i));\n }\n xylineandshaperenderer.setBaseToolTipGenerator(new StandardXYToolTipGenerator());\n xyplot.setRenderer(xylineandshaperenderer);\n NumberAxis numberaxis = (NumberAxis) xyplot.getRangeAxis();\n numberaxis.setStandardTickUnits(NumberAxis.createIntegerTickUnits());\n this.jPanel = new ChartPanel(jfreechart);\n }",
"@Override\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\n Bundle savedInstanceState) {\n View view= inflater.inflate(R.layout.layout3, container, false);\n\n //对View中控件的操作方法\n mLineChart = (LineChart) view.findViewById(R.id.spread_line_chart);\n zhaiyao = (TextView) view.findViewById(R.id.zhaiyao);\n mPieChart = (PieChart) view.findViewById(R.id.consume_pie_chart);\n btn_1 = (Button) view.findViewById(R.id.btn_1);\n btn_2 = (Button) view.findViewById(R.id.btn_2);\n btn_3 = (Button) view.findViewById(R.id.btn_3);\n btn_1.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n mLineChart.setVisibility(View.VISIBLE);\n zhaiyao.setVisibility(View.GONE);\n mPieChart.setVisibility(View.GONE);\n LineData mLineData = getLineData();\n showChart(mLineChart, mLineData, Color.rgb(114, 188, 223));\n }\n });\n btn_2.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n mLineChart.setVisibility(View.GONE);\n zhaiyao.setVisibility(View.VISIBLE);\n mPieChart.setVisibility(View.GONE);\n zhaiyao.setText(\"1.必须坚持中国特色社会主义政治发展道路\\n\" +\n \"2.要坚持中国特色社会主义文化发展道路\\n\" +\n \"3.这就是必须从理论和实践结合上系统回答新时代坚持和发展什么样的中国特色社会主义、怎样坚持和发展中国特色社会主义\\n\" +\n \"4.明确全面深化改革总目标是完善和发展中国特色社会主义制度、推进国家治理体系和治理能力现代化\\n\" +\n \"5.必须坚持和完善中国特色社会主义制度\\n\" +\n \"6.明确全面推进依法治国总目标是建设中国特色社会主义法治体系、建设社会主义法治国家\\n\" +\n \"7.始终坚持和发展中国特色社会主义\\n\" +\n \"8.明确坚持和发展中国特色社会主义\\n\" +\n \"9.完善和发展中国特色社会主义军事制度\\n\" +\n \"10.发展中国特色社会主义文化\");\n zhaiyao.setTextSize(17);\n //zhaiyao.setTextColor(0xffffff);\n }\n });\n btn_3.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n mPieChart.setVisibility(View.VISIBLE);\n mLineChart.setVisibility(View.GONE);\n zhaiyao.setVisibility(View.GONE);\n PieData mPieData = getPieData();\n showChart(mPieChart, mPieData);\n }\n });\n return view;\n }",
"private PanelTester()\n {\n /**/\n //f.add(new CardSelector(0, 0, width, height, \"TEST\"));\n\n // 73 Total\n// Slice[] slices2 = { new Slice(5, Color.BLACK,\"BLACK\"),\n// new Slice(33, Color.GREEN,\"GREEN\"),\n// new Slice(20, Color.YELLOW,\"YELLOW\"), new Slice(15, Color.RED,\"RED\") };\n//\n// Slice[] slices = { new Slice(0.64, Color.GREEN, \"Organic\"),\n// new Slice(52.6590008, Color.BLUE, \"Conventional\" ),\n// new Slice(46.7009992, Color.RED, \"GMO\" ) };\n//\n// ArrayList<Slice> sliceArray = new ArrayList<>();\n// for( int i = 0; i < slices.length ; i++)\n// {\n// sliceArray.add( slices[i] );\n// }\n// f.add(new PieChart( f.getBounds(), sliceArray ) );\n// Rectangle temp = new Rectangle(0,0,100,100);\n //f.add(new ChartKey(temp, sliceArray ));\n /**/\n\n\n\n f.add(new AvailableCropsBar(\"test\", new Color(134,255, 109,255),100,60,20,300,50));\n\n\n\n\n\n //f.pack();\n }",
"@Test\n public void test71() throws Throwable {\n DefaultCategoryDataset defaultCategoryDataset0 = new DefaultCategoryDataset();\n SubCategoryAxis subCategoryAxis0 = new SubCategoryAxis(\"\");\n NumberAxis3D numberAxis3D0 = new NumberAxis3D();\n DefaultPolarItemRenderer defaultPolarItemRenderer0 = new DefaultPolarItemRenderer();\n Color color0 = (Color)defaultPolarItemRenderer0.getBaseFillPaint();\n CategoryLabelPositions categoryLabelPositions0 = CategoryLabelPositions.UP_45;\n subCategoryAxis0.setCategoryLabelPositions(categoryLabelPositions0);\n WaterfallBarRenderer waterfallBarRenderer0 = new WaterfallBarRenderer((Paint) color0, (Paint) color0, (Paint) color0, (Paint) color0);\n Boolean boolean0 = Boolean.valueOf(\"\");\n defaultPolarItemRenderer0.setSeriesVisible(2989, boolean0);\n CategoryPlot categoryPlot0 = new CategoryPlot((CategoryDataset) defaultCategoryDataset0, (CategoryAxis) subCategoryAxis0, (ValueAxis) numberAxis3D0, (CategoryItemRenderer) waterfallBarRenderer0);\n Font font0 = SpiderWebPlot.DEFAULT_LABEL_FONT;\n subCategoryAxis0.setTickLabelFont(font0);\n DefaultCategoryDataset defaultCategoryDataset1 = (DefaultCategoryDataset)categoryPlot0.getDataset();\n DatasetChangeEvent datasetChangeEvent0 = new DatasetChangeEvent((Object) defaultCategoryDataset1, (Dataset) defaultCategoryDataset0);\n categoryPlot0.datasetChanged(datasetChangeEvent0);\n CombinedDomainXYPlot combinedDomainXYPlot0 = new CombinedDomainXYPlot();\n PlotRenderingInfo plotRenderingInfo0 = new PlotRenderingInfo((ChartRenderingInfo) null);\n Point2D.Double point2D_Double0 = new Point2D.Double();\n XYPlot xYPlot0 = combinedDomainXYPlot0.findSubplot(plotRenderingInfo0, point2D_Double0);\n }",
"@Override\n public View onCreateView(LayoutInflater inflater, ViewGroup container,\n Bundle savedInstanceState) {\n View view = inflater.inflate(R.layout.fragment_analysis,container,false);\n\n cases_bar = view.findViewById(R.id.cases_bar);\n //Appearance of Bar chart\n cases_bar.getDescription().setEnabled(false);\n cases_bar.setDrawValueAboveBar(false);\n cases_bar.animateY(5000);\n cases_bar.animateX(5000);\n\n XAxis xAxis = cases_bar.getXAxis();\n xAxis.setValueFormatter(new ValueFormatter() {\n @Override\n public String getFormattedValue(float value) {\n return YEARS[(int) value];\n }\n });\n\n YAxis axisLeft = cases_bar.getAxisLeft();\n axisLeft.setGranularity(100f);\n axisLeft.setAxisMinimum(0);\n\n YAxis axisRight = cases_bar.getAxisRight();\n axisLeft.setGranularity(100f);\n axisLeft.setAxisMinimum(0);\n\n\n ArrayList <BarEntry> cases = new ArrayList<>();\n cases.add(new BarEntry(0,2144));\n cases.add(new BarEntry(1,2230));\n cases.add(new BarEntry(2,1480));\n cases.add(new BarEntry(3,1131));\n cases.add(new BarEntry(4,1089));\n\n\n\n BarDataSet bardataset = new BarDataSet(cases, \"Cases\");\n\n ArrayList<IBarDataSet> labels = new ArrayList<>();\n labels.add(bardataset);\n\n BarData data = new BarData( labels);\n cases_bar.setData(data); // set the data and list of labels\n data.setValueTextSize(12f);\n bardataset.setColors(ColorTemplate.COLORFUL_COLORS);\n\n return view;\n }"
]
| [
"0.68051994",
"0.67708015",
"0.6770363",
"0.66598433",
"0.66585004",
"0.6615324",
"0.6579938",
"0.6465659",
"0.64376056",
"0.6432189",
"0.63617486",
"0.6307608",
"0.630291",
"0.62948996",
"0.6261786",
"0.61147064",
"0.59905505",
"0.5974524",
"0.5959943",
"0.593203",
"0.592003",
"0.5917151",
"0.59067196",
"0.589365",
"0.5880264",
"0.5871619",
"0.5857984",
"0.5830079",
"0.5815792",
"0.58024865",
"0.5793173",
"0.57885236",
"0.57699925",
"0.57677215",
"0.57585573",
"0.5743037",
"0.57332456",
"0.5721828",
"0.5710773",
"0.5709805",
"0.570222",
"0.5698503",
"0.56863165",
"0.5679537",
"0.56674045",
"0.5666966",
"0.56608003",
"0.563392",
"0.56221247",
"0.5606759",
"0.5602083",
"0.56018096",
"0.55929595",
"0.55917126",
"0.5590921",
"0.5577661",
"0.556017",
"0.5557872",
"0.5557663",
"0.55453247",
"0.5544862",
"0.5543012",
"0.5540681",
"0.55372447",
"0.55369174",
"0.55333287",
"0.55329686",
"0.5532541",
"0.5527202",
"0.55197024",
"0.5514911",
"0.55146116",
"0.55101895",
"0.55028147",
"0.54951876",
"0.5493199",
"0.5491086",
"0.5481098",
"0.5470494",
"0.54687667",
"0.5464328",
"0.5463005",
"0.5454372",
"0.54416406",
"0.5439896",
"0.5433807",
"0.543166",
"0.5430995",
"0.54266256",
"0.5423353",
"0.5421634",
"0.5419143",
"0.5417188",
"0.5415936",
"0.53916854",
"0.53914696",
"0.53856945",
"0.53801155",
"0.5377228",
"0.53635013",
"0.5360716"
]
| 0.0 | -1 |
This method provides the ability to change the display position of the map chart, or the coordinates of the central point. | @Override
public void setCameraCoordinate(double latitude, double longitude) {
mMap.moveCamera(CameraUpdateFactory.newLatLng(new LatLng(latitude, longitude)));
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"void reconfigure() {\n computePosition(_primaryPlot.getScreenCoords(findCurrentCenterPoint()), false);\n }",
"public void setMapPosition() {\n\t\txmap = levelState.getx();\n\t\tymap = levelState.gety();\n\t}",
"private void panMap(int x, int y){\r\n Point p = map.getMapCenter();\r\n p.x += x;\r\n p.y += y;\r\n map.setMapCenter(p);\r\n mapPane.render();\r\n }",
"public void setOrigin(){\n // draw X-axis\n graphics2D.draw(new Line2D.Double(leftMiddle, rightMiddle));\n\n // draw string \"+X\" and \"-X\"\n graphics2D.drawString(\"+X\", (int) rightMiddle.getX() - 10, (int) rightMiddle.getY() - 5);\n graphics2D.drawString(\"-X\", (int) leftMiddle.getX() + 10, (int) leftMiddle.getY() + 10);\n\n // draw Y-axis\n graphics2D.draw(new Line2D.Double(topMiddle, bottomMiddle));\n\n // draw string \"+Y\" and \"-Y\"\n graphics2D.drawString(\"+Y\", (int) topMiddle.getX() + 5, (int) topMiddle.getY() + 10);\n graphics2D.drawString(\"-Y\", (int) bottomMiddle.getX() - 15, (int) bottomMiddle.getY());\n\n }",
"public void setPosicao() {\n Dimension d = this.getDesktopPane().getSize();\n this.setLocation((d.width - this.getSize().width) / 2, (d.height - this.getSize().height) / 2);\n }",
"private void setMapPos()\r\n {\r\n try\r\n {\r\n Thread.sleep(1000);//so that you can see players move\r\n }\r\n catch(Exception e){}\r\n int currentPlayer = worldPanel.getCurrentPlayer();\r\n int currentUnit = worldPanel.getCurrentUnit();\r\n int unitPos = 0;\r\n int firstX = 0;\r\n int firstY = 0;\r\n if (currentPlayer == 1)\r\n {\r\n unitPos = worldPanel.player1.units[currentUnit - 1].getPosition();\r\n }\r\n if (currentPlayer == 2)\r\n {\r\n unitPos = worldPanel.player2.units[currentUnit - 1].getPosition();\r\n }\r\n int tempX = unitPos % mapWidth;\r\n int tempY = unitPos - tempX;\r\n if (tempY == 0) {}\r\n else\r\n tempY = tempY / mapHeight;\r\n tempX = tempX - 11;\r\n tempY = tempY - 7;\r\n if (tempX >= 0)\r\n firstX = tempX;\r\n else\r\n firstX = tempX + mapWidth;\r\n if (tempY >= 0)\r\n firstY = tempY;\r\n else\r\n firstY = tempY + mapWidth;\r\n\r\n int drawWidth = worldPanel.getDrawWidth();\r\n int drawHeight = worldPanel.getDrawHeight();\r\n worldPanel.setNewXYPos(firstX, firstY);\r\n miniMap.setNewXY(firstX, firstY, drawWidth, drawHeight);\r\n }",
"public void setPositionOnMap(Point positionOnMap)\n {\n this.positionOnMap = positionOnMap;\n }",
"@Override\n public Location getDisplayedLocation() {\n this.displayedLocation = new Location((int)pane.getHvalue(), (int)pane.getVvalue(), curFloor, \"Unknown\");\n return displayedLocation;\n }",
"public void setCenter() {\n\t\tthis.isCenter = true;\n\t}",
"@Override\n public void setDisplayedLocation(Location loc) {\n pane.setVvalue(loc.getyCoord());\n pane.setHvalue(loc.getxCoord());\n setCurrentFloor(loc.getLevel());\n displayedLocation = getDisplayedLocation();\n }",
"public void panCenterTo(float x, float y) {\n \t\tLocation location = mapDisplay.pointLocation(x, y);\n \t\tpanCenterTo(location);\n \t}",
"@Override\n public void onPositionChanged(GeoCoordinate geoCoordinate) {\n m_mapTransformCenter = m_map.projectToPixel\n (geoCoordinate).getResult();\n }",
"public void moveTheMap() {\n \t if(streetLevelFragment != null && map != null){\n \t\t map.setCenter(streetLevelFragment.getStreetLevelModel().getPosition(), MapAnimation.LINEAR, map.getZoomLevel(), streetLevelFragment.getStreetLevelModel().getHeading(), 0);\n \t }\n }",
"protected void zoomToPresent(){\n if(xpCursor1 >=0){\n ixDataCursor1 = ixDataShown[xpCursor1];\n }\n if(xpCursor2 >=0){\n ixDataCursor2 = ixDataShown[xpCursor2];\n }\n xpCursor1New = xpCursor2New = cmdSetCursor; \n if(widgg.timeorg.timeSpread > 100) { widgg.timeorg.timeSpread /=2; }\n else { widgg.timeorg.timeSpread = 100; }\n bPaintAllCmd = true;\n widgg.redraw(100, 200);\n }",
"private void updatePopupPosition() {\n // get the annotation's screen coordinates\n SKScreenPoint screenPoint = mapView.coordinateToPoint(selectedAnnotation.getLocation());\n // change the popup's (screen) position\n mapPopup.changePosition(screenPoint.getX(), screenPoint.getY(), 65);\n }",
"private void center(Display display) {\n\t Monitor primary = display.getPrimaryMonitor();\n\t Rectangle bounds = primary.getBounds();\n\t Rectangle rect = shell.getBounds();\n\t int x = bounds.x + (bounds.width - rect.width) / 2;\n\t int y = bounds.y + (bounds.height - rect.height) / 2;\n\t shell.setLocation(x, y);\n\t}",
"public void mapViewLayedOut() {\n if (mPointToGoTo != null) {\n setCenter(mPointToGoTo);\n mPointToGoTo = null;\n }\n if (mZoomToZoomTo != -1) {\n setZoom(mZoomToZoomTo);\n mZoomToZoomTo = -1;\n }\n\n }",
"private void displayWorldCoordinates() {\n int n = trackerPanel == null ? 0 : trackerPanel.getFrameNumber();\n OffsetOriginStep step = (OffsetOriginStep) getStep(n);\n if (step == null) {\n xField.setText(null);\n yField.setText(null);\n } else {\n xField.setValue(step.worldX);\n yField.setValue(step.worldY);\n }\n }",
"void setPosition(double xPos, double yPos);",
"public void setCenter(Point newPoint) {\n this.center = newPoint;\n }",
"public void setPosicao() {\n Dimension d = this.getDesktopPane().getSize();\n this.setLocation((d.width - this.getSize().width) / 2, (d.height - this.getSize().height) / 2); \n}",
"void updatePosition() {\n if (gameScreen.cursorIsOnLeft()) \n {\n // set the panel's rightmost edge to be 1/12th from the edge\n // set the panel's bottommost edge to be 1/6th from the edge\n setLocation(\n gameScreen.getScreenWidth() * 11/12 - getWidth(), \n gameScreen.getScreenHeight() * 5/6 - getHeight());\n }\n else // Otherwise the cursor must be on the right half of the screen\n {\n // set the panel's leftmost edge to be 1/12th from the edge\n // set the panel's bottommost edge to be 1/6th from the edge\n setLocation(\n gameScreen.getScreenWidth() * 1/12, \n gameScreen.getScreenHeight() * 5/6 - getHeight());\n }\n }",
"public void smartCenter() {\n WebPlot p = getPrimaryPlot();\n if (p==null) return;\n\n if (isWcsSync()) {\n wcsSyncCenter(computeWcsSyncCenter());\n }\n else if (p.containsAttributeKey(WebPlot.FIXED_TARGET)) {\n Object o = p.getAttribute(WebPlot.FIXED_TARGET);\n if (o instanceof ActiveTarget.PosEntry) {\n ActiveTarget.PosEntry entry = (ActiveTarget.PosEntry) o;\n ImageWorkSpacePt ipt = p.getImageWorkSpaceCoords(entry.getPt());\n if (ipt!=null && p.pointInPlot(entry.getPt())) centerOnPoint(ipt);\n else simpleImageCenter();\n }\n } else {\n simpleImageCenter();\n }\n }",
"public void setCenterPosition(ViewPosition p) {\n\n\t}",
"private void updatePosition(){\n updateXPosition(true);\n updateYPosition(true);\n }",
"public void displayMap() {\n MapMenuView mapMenu = new MapMenuView();\r\n mapMenu.display();\r\n \r\n }",
"private void centerOnLatLon(Point2D newCenter){\n Point2D currentCenter = getCenterLatLon();\n double dx = currentCenter.getX() - newCenter.getX();\n double dy = currentCenter.getY() - newCenter.getY();\n panMapCoords(dx, dy);\n }",
"@SuppressWarnings(\"unchecked\")\n public void centralizarComponente() {\n Dimension ds = Toolkit.getDefaultToolkit().getScreenSize();\n Dimension dw = getSize();\n setLocation((ds.width - dw.width) / 2, (ds.height - dw.height) / 2);\n }",
"private void previewXY() {\n Viewport tempViewport = new Viewport(chart.getMaximumViewport());\n // Make temp viewport smaller.\n float dx = tempViewport.width() / 4;\n float dy = tempViewport.height() / 4;\n tempViewport.inset(dx, dy);\n previewChart.setCurrentViewportWithAnimation(tempViewport);\n }",
"protected final void windowLocationControl(){\n\t\tthis.setLocation(0, 0);\n\t}",
"public void onMapCenterChange(NMapView arg0, NGeoPoint arg1) {\n\n }",
"@Override\n\tpublic void onLocationChanged(Location location) {\n\t\t if (location != null) {\n\t\t //punto = location;\n\t\t GeoPoint puntoCap = new GeoPoint(location);\n\t\t this.posicionActualOverlay.setLocation(puntoCap);\n\t\t mapView.getController().animateTo(puntoCap);\n\t\t mapView.getController().setCenter(puntoCap);\n\t\t }\n\t\t\n\t}",
"public void setPosition(Point newPosition);",
"@Override\n\tpublic void onCenterChanged(GeoPoint center) {\n\t}",
"public void setCenter(Point center) {\r\n this.center = center;\r\n }",
"protected void replaceChart() {\n ChartPanel jChart = null;\n jChart = DataGrapher.makeOverlaidMap(m_oDataset,\n m_oTreeDataset, \"East->\", \"\", m_iPlotLengthX,\n m_iPlotLengthY, m_oRenderer, m_oTreeRenderer,\n new java.awt.Dimension(Math.min(600,\n m_iPlotLengthX * 3),\n Math.min(600, m_iPlotLengthY * 3)));\n m_jChartPanel.add(jChart);\n m_jChartPanel.validate();\n m_jChartPanel.repaint();\n }",
"public void setCenterOverCoords(boolean doCenter)\n\t{\n\t\tcenterOverCoords = doCenter;\n\t}",
"public void setNodePositionXY (Point2D position) { n.setXYPositionMap(position); }",
"void setCenter() {\n\t\tLine line02 = new Line(myParent, new PVector(), new PVector());\n\t\tLine line13 = new Line(myParent, new PVector(), new PVector());\n\t\tline02.set(point[0].position, point[2].position);\n\t\tline13.set(point[1].position, point[3].position);\n\t\tif (line02.intersects_at(line13) != null) // if two points are on each\n\t\t\t\t\t\t\t\t\t\t\t\t\t// other\n\t\t\tcenter.set(line02.intersects_at(line13));\n\t}",
"public void setLocation(Point p) {\n // Not supported for MenuComponents\n }",
"private void center() {\r\n\t\tDimension dim = Toolkit.getDefaultToolkit().getScreenSize();\r\n\r\n\t\tint x = (dim.width - getSize().width) / 2;\r\n\t\tint y = (dim.height - getSize().height) / 2;\r\n\r\n\t\tsetLocation(x, y);\r\n\t}",
"public void placeInCenter( JFrame f ){\n f.setLocation(widthScreen / 2 - f.getWidth()/2 , heightScreen / 2 - f.getHeight()/2);\n }",
"public void setPosicionMapa() {\n\t\txmapa = mapaTile.getx();\n\t\tymapa = mapaTile.gety();\n\t}",
"public void updateXLoc();",
"public void update() {\n\t\tgetLocation().offsetX(getDirection().getXOffset());\n\t\tgetLocation().offsetY(getDirection().getYOffset());\n\t\t\n\t\tChunk center = World.getMap().getCenterChunk();\n\t\t\n\t\tint localX = (int) (getLocation().getX() - center.getData().getRealX());\n\t\tint localY = (int) (getLocation().getY() - center.getData().getRealY());\n\t\t\n\t\tif(localX < 0 ||localY< 0\n\t\t\t|| localX > 256 || localY > 256) {\n\t\t\t\tWorld.getMap().load(getLocation());\n\t\t}\n\t}",
"@Override\n public void setCoord(PuertoPosition pp, Point2D newCoord) {\n layout.setLocation(pp, newCoord);\n }",
"@Override\n public void setPosition(float x, float y) {\n }",
"public void setCenter(Point center) {\r\n\t\tthis.center = center;\r\n\t}",
"public void centerMapOnPoint(int targetX, int targetY) {\n\n int scaledWidth = (int) (TileDataRegister.TILE_WIDTH * scale);\n int scaledHeight = (int) (TileDataRegister.TILE_HEIGHT * scale);\n int baseX = (int) (map.getWidth() * TileDataRegister.TILE_WIDTH * scale) / 2;\n\n int x = baseX + (targetY - targetX) * scaledWidth / 2;\n x -= viewPortWidth * 0.5;\n int y = (targetY + targetX) * scaledHeight / 2;\n y -= viewPortHeight * 0.5;\n\n currentXOffset = -x;\n currentYOffset = -y;\n\n gameChanged = true;\n }",
"public void setLocation(float x, float y);",
"public void getCoord(MouseEvent me){\n if(mapImage.getImage()!=null) {\n double xPos = me.getX();\n double yPos = me.getY();\n Main.ps.setTitle(xPos + \" \" + yPos);\n }\n }",
"private void centerMap(final GoogleMap map) {\n // Bounds of campustown and some surroundings\n final double swLatitude = 40.098331;\n final double swLongitude = -88.246065;\n final double neLatitude = 40.116601;\n final double neLongitude = -88.213077;\n\n // Get the window dimensions (for the width)\n Point windowSize = new Point();\n getWindowManager().getDefaultDisplay().getSize(windowSize);\n\n // Convert 300dp (height of map control) to pixels\n final int mapHeightDp = 300;\n float heightPx = TypedValue.applyDimension(TypedValue.COMPLEX_UNIT_DIP, mapHeightDp,\n getResources().getDisplayMetrics());\n\n // Submit the camera update\n final int paddingPx = 10;\n map.moveCamera(CameraUpdateFactory.newLatLngBounds(new LatLngBounds(\n new LatLng(swLatitude, swLongitude),\n new LatLng(neLatitude, neLongitude)), windowSize.x, (int) heightPx, paddingPx));\n }",
"public void centre(){\n //Skip if not windowed\n if(type != Type.WINDOWED){\n return;\n }\n\n //Retrieve the handle of the primary monitor\n long primaryMonitor = glfwGetPrimaryMonitor();\n\n //Retrieve the top left corner of the primary monitor\n IntBuffer posX;\n IntBuffer posY;\n try(MemoryStack stack = MemoryStack.stackPush()){\n posX = stack.mallocInt(1);\n posY = stack.mallocInt(1);\n glfwGetMonitorPos(primaryMonitor, posX, posY);\n }\n\n //Centre the window on that monitor\n GLFWVidMode mode = glfwGetVideoMode(primaryMonitor);\n int newX = posX.get(0) + (mode.width() / 2) - (int) (size.x / 2);\n int newY = posY.get(0) + (mode.height() / 2) - (int) (size.y / 2);\n\n //Move the window and change the field\n glfwSetWindowPos(handle, newX, newY);\n position.set(newX, newY);\n }",
"public void showMyLocation() {\n if (myLocationoverlay.getLastFix() == null) return;\n\n boolean r = isMyLocationVisible(); // whether the current location is visible\n if (!r) {\n GeoPoint cl = new GeoPoint(myLocationoverlay.getLastFix());\n showLocation(cl.getLatitude(), cl.getLongitude());\n }\n }",
"public void setPosition(Point position);",
"public void setCenter(Point centerPoint) {\n this.center = centerPoint;\n }",
"public void setPosition(float x, float y);",
"@Override\n public void updateCenter(int newX, int newY) {\n Point oldCenter = wrappedPolygon.getCenterPoint();\n wrappedPolygon.translate(newX - oldCenter.x, newY - oldCenter.y);\n }",
"public void onMapCenterChangeFine(NMapView arg0) {\n\n }",
"public void setZeroPosition(int center) {\n centerPos = center;\n }",
"protected void positionCenter() {\n\t\tlog(\"Positioning on center of line.\");\n\t\tdouble offset = -lineWidth / 2;\n\t\tbindTransition(getPilot().travelComplete(offset), LineFinderState.FINISH);\n\t}",
"public void setLabelPosition(int x, int y);",
"@Override\n\tpublic void setPosition(int left)\n\t{\n\t\t_mainPanel.getElement().getStyle().setLeft(left, Style.Unit.PX) ;\n\t}",
"public void setDisplayLocReplace() {\r\n displayLoc = REPLACE;\r\n }",
"public void SetDisplayArea(float x1, float x2, float y1, float y2) {\n\tmBoundary[0] = x1; \n\tmBoundary[1] = x2; \n\tmBoundary[2] = y1; \n\tmBoundary[3] = y2; \n\t\n\n\t//mVPMatrix = pMatrix;\t\t\n}",
"public void setCenter(Point newCenter) {\n\t\tPoint oldCenter = getCenter();\n\t\tmove(newCenter.x - oldCenter.x, newCenter.y - oldCenter.y);\n\t}",
"public void setPostion(int newXPosition, int newYPosition) {\n xPosition = newXPosition;\n yPosition = newYPosition;\n }",
"public void setDisplayLocNew() {\r\n displayLoc = NEW;\r\n }",
"private void setLocation() {\n switch (getKey()) {\n case UP:\n this.y_location = -136.8 - 6;\n this.y_tile = -1;\n this.positive = false;\n break;\n case DOWN:\n this.y_location = 136.8 + 6;\n this.y_tile = 1;\n break;\n case LEFT:\n this.x_location = -140.6 - 6;\n this.x_tile = -1;\n this.positive = false;\n break;\n case RIGHT:\n this.x_location = 140.6 + 6;\n this.x_tile = 1;\n break;\n default:\n break;\n }\n }",
"public void setPosition(int diagramID) {\n if(diagramID == sourceId) {\n startX = base.getCenterX();\n startY = base.getCenterY();\n }\n else {\n headLayoutX = head.getLayoutX();\n headLayoutY = head.getLayoutY();\n }\n }",
"public void display() {\r\n \tsetLocation((int)parent.getLocationOnScreen().getX() + (parent.getWidth()/2) - (getWidth()/2), (int)parent.getLocationOnScreen().getY() + (parent.getHeight()/2) - (getHeight()/2));\r\n \tsetVisible(true);\r\n }",
"public void setLocation(int popupX, int popupY) {\n displayWindow.setLocation(popupX, popupY);\n }",
"private void m12811c(Map<String, String> map) {\n Rect rect = new Rect();\n this.f10118e.getGlobalVisibleRect(rect);\n map.put(\"pt\", String.valueOf(rect.top));\n map.put(\"pl\", String.valueOf(rect.left));\n map.put(\"ph\", String.valueOf(this.f10118e.getMeasuredHeight()));\n map.put(\"pw\", String.valueOf(this.f10118e.getMeasuredWidth()));\n WindowManager windowManager = (WindowManager) this.f10116c.getSystemService(\"window\");\n DisplayMetrics displayMetrics = new DisplayMetrics();\n windowManager.getDefaultDisplay().getMetrics(displayMetrics);\n map.put(\"vph\", String.valueOf(displayMetrics.heightPixels));\n map.put(\"vpw\", String.valueOf(displayMetrics.widthPixels));\n }",
"public void updateYLoc();",
"protected abstract void setMarkers();",
"public void setOrigin(int x, int y) {\n ic.setOrigin(x, y);\n notifyViewportListeners(x, y, panelWidth, panelHeight);\n }",
"public void setWhereToGo() {\n\t\tfloat diffZ=mApplications.get(CurIndex).getZ() - Constants.displayedPlace;\r\n\t\tif( Math.abs(diffZ) < Constants.threshold)\r\n\t\t{\r\n\t\t\tif(diffZ >=0)\r\n\t\t\t\tgoTo(Constants.TO_BACKWARD_CENTER);\r\n\t\t\telse\r\n\t\t\t\tgoTo(Constants.TO_FORWARD_CENTER);\r\n\t\t}\r\n\t\telse if( diffZ >= 0) // go to disappeared place\r\n\t\t{\r\n\t\t\tgoTo(Constants.TO_FRONT);\r\n\t\t}\r\n\t\telse if( diffZ < 0) // go to origin place\r\n\t\t{\r\n\t\t\tgoTo(Constants.TO_BACK);\r\n\t\t}\r\n\t}",
"public void setPosition(ScreenPoint p) {\n setX(p.x);\n setY(p.y);\n }",
"@SuppressWarnings(\"unused\")\n private void setCenter(JSONArray args, CallbackContext callbackContext) throws JSONException {\n double lat, lng;\n\n lat = args.getDouble(1);\n lng = args.getDouble(2);\n\n LatLng latLng = new LatLng(lat, lng);\n CameraUpdate cameraUpdate = CameraUpdateFactory.newLatLng(latLng);\n this.myMoveCamera(cameraUpdate, callbackContext);\n }",
"public void setCenter(PointF center) {\n this.center = center;\n }",
"@Override\n\tpublic void changeMapPointer(ImageView posView) {\n\t\tif (room.equals(properties.getRoomFromProperties().get(1))) {\n\t\t\tposView.relocate(789, 272);\n\n\t\t} else if (room.equals(properties.getRoomFromProperties().get(2))) {\n\t\t\tposView.relocate(788, 185);\n\n\t\t} else if (room.equals(properties.getRoomFromProperties().get(3))) {\n\t\t\tposView.relocate(880.0, 281);\n\n\t\t} else if (room.equals(properties.getRoomFromProperties().get(4))) {\n\t\t\tposView.relocate(867.0, 200);\n\n\t\t} else if (room.equals(properties.getRoomFromProperties().get(5))) {\n\t\t\tposView.relocate(880.0, 64.0);\n\n\t\t} else {\n\t\t\tposView.relocate(788.0, 60.0);\n\t\t}\n\t}",
"public void showLocation(double lat, double lon) {\n IMapController mapController = mapView.getController();\n GeoPoint cl = new GeoPoint(lat, lon);\n mapController.animateTo(cl);\n settings.setZoomLevel(settings.getZoomLevel(), cl.getLatitude(), cl.getLongitude());\n }",
"private void setUpMap() {\n if (points.size()>2) {\n drawCircle();\n }\n\n\n }",
"double getMapPositionX();",
"public void setLocation(int loacation) {\n\t\tsuper.setLocation(loacation);\n\t}",
"@Override\n\tpublic void setCenterView() {\n\n\t}",
"void setPosition(Point point);",
"private void centerRegion() {\r\n\t\tthis.addComponent(BorderLayout.CENTER, mp);\r\n\t}",
"void setPosition(Unit unit, MapLocation position);",
"public void centerOnScreen()\n {\n \t// Get the size of the screen\n Dimension dim = Toolkit.getDefaultToolkit().getScreenSize();\n \n // Determine the new location of the window\n int w = frame.getSize().width;\n int h = frame.getSize().height;\n int xloc = (dim.width-w)/2;\n int yloc = (dim.height-h)/2;\n\n // Move the window\n frame.setLocation(xloc, yloc);\n }",
"public void setLoc(int x, int y)\n {\n powerUp.setBounds(x,y,65,29);\n text.setBounds(x,y,65,29);\n }",
"@Override\n protected void positionChanged () {\n\n\n valueLabel.setPosition( this.getX() + ((this.getScaleX() * this.getWidth() - valueLabel.getScaleX() * valueLabel.getWidth()) / 2),\n this.getY() + ((this.getScaleY() * this.getHeight() - valueLabel.getScaleY() * valueLabel.getHeight()) / 2) );\n }",
"private void updateUserPosition()\n {\n LatLng current = new LatLng(mCurrentLocation.getLatitude(), mCurrentLocation.getLongitude());\n circle.setCenter(current);\n Log.i(\"ZOOM:\", \" \" + mMap.getCameraPosition().zoom);\n mMap.moveCamera(CameraUpdateFactory.newLatLng(current));//move map to the user's position\n updateMap();\n }",
"@Override\n public void onMapViewCenterPointMoved(MapView arg0, MapPoint arg1) {\n\n }",
"public void showProximityDependencyNode() {\n\n\n mapTab.getTabSet().selectTab(mapTab);\n\t\tif (location == null) location = MapWidget.getMapInstance().getCenter();\n\t\tif (latTextItem.getValue()!= null && !\"\".equals(latTextItem.getValue())) {\n\t\t\tdouble lat = Double.parseDouble(latTextItem.getValueAsString());\n\t\t\tlocation = LatLng.create(lat, location.lng());\n\t\t}\n\t\tif (lngTextItem.getValue()!= null && !\"\".equals(lngTextItem.getValue())) {\n\t\t\tdouble lng = Double.parseDouble(lngTextItem.getValueAsString());\n\t\t\tlocation = LatLng.create(location.lat(), lng);\n\t\t}\n\t\tdrawMarker(MapWidget.getMapInstance());\n if (radiusTextItem.getValue()!= null && !\"\".equals(radiusTextItem.getValue())) {\n double radius = Double.parseDouble(radiusTextItem.getValueAsString());\n circle.setRadius(radius);\n }\n\t\tProximityDependencyEditor.this.setVisibility(Visibility.INHERIT);\n\n\t}",
"public void centerScreen(int x, int y)\r\n {\r\n // Scaled parameters\r\n int width = View.WIDTH;\r\n int height = View.HEIGHT;\r\n int mapWidth = gameData.getMap().getWidth();\r\n int mapHeight = gameData.getMap().getHeight();\r\n\r\n xScreenOffset = x - width / 2;\r\n yScreenOffset = y - height / 2;\r\n\r\n // Limit Offset, so that the view never leaves the map\r\n if (xScreenOffset < 0)\r\n {\r\n xScreenOffset = 0;\r\n }\r\n if (xScreenOffset > mapWidth - width)\r\n {\r\n xScreenOffset = mapWidth - width;\r\n }\r\n if (yScreenOffset < 0)\r\n {\r\n yScreenOffset = 0;\r\n }\r\n if (yScreenOffset > mapHeight - height)\r\n {\r\n yScreenOffset = mapHeight - height;\r\n }\r\n }",
"@Override\n protected void onLayout(boolean changed, int left, int top, int right, int bottom) {\n super.onLayout(changed, left, top, right, bottom);\n\n horizon = (getHeight() - 100) / density;\n\n // set city coordinates\n float loc[] = new float[3];\n loc[0] = getWidth() / (density * 4);\n loc[1] = getWidth() / (density * 2);\n loc[2] = (getWidth() * 3) / (density * 4);\n\n for (int i = 0; i < cityCount; ++i) {\n cityLocations[i] = new PointF(loc[i], horizon);\n }\n }",
"public static void prikaziEastPanel() {\r\n\t\tteretanaGui.getEastPanel().setVisible(true);\r\n\t}",
"@Override\n public void setLocation(ITileGrid grid, int x, int y) {\n var tile = grid.getTile(x, y);\n pos = tile.getPixelCenterLocation(grid.getTileSize());\n }",
"private void resetBalloonPosition(View balloon){\n int viewId = balloon.getId();\n if(globalViewMap != null && globalViewMap.containsKey(viewId+\"_x\") && globalViewMap.containsKey(viewId+\"_y\")) {\n balloon.setX(globalViewMap.get(balloon.getId() + \"_x\"));\n balloon.setY(globalViewMap.get(balloon.getId() + \"_y\"));\n balloon.setVisibility(View.VISIBLE);\n }\n \n }",
"@Override\n public void onCameraMove() {\n zoom = GMap.getCameraPosition().zoom;\n if(zoom >= 17.2f){\n map_label.setVisible(true);\n mapOverlay.setVisible(false);\n }\n else{\n map_label.setVisible(false);\n mapOverlay.setVisible(true);\n }\n\n }"
]
| [
"0.70611787",
"0.6402091",
"0.63788456",
"0.6268012",
"0.6182953",
"0.6154789",
"0.61147994",
"0.6012174",
"0.5995493",
"0.59884834",
"0.59615684",
"0.59334147",
"0.59323853",
"0.5926745",
"0.59239113",
"0.59119517",
"0.5911848",
"0.5890431",
"0.5885507",
"0.587968",
"0.5860624",
"0.5851693",
"0.58329374",
"0.5821621",
"0.579938",
"0.57984877",
"0.57772684",
"0.5747713",
"0.57470757",
"0.5747047",
"0.5743932",
"0.57395685",
"0.57316136",
"0.5723233",
"0.5715386",
"0.5715088",
"0.5700213",
"0.5697537",
"0.5694523",
"0.5679214",
"0.5661727",
"0.56419396",
"0.5630956",
"0.56213623",
"0.5621083",
"0.5616006",
"0.5596702",
"0.55963975",
"0.5592479",
"0.5588248",
"0.55592376",
"0.5558365",
"0.55444205",
"0.5526037",
"0.5520127",
"0.5516046",
"0.55123496",
"0.55109775",
"0.5510143",
"0.55094546",
"0.55085266",
"0.55019045",
"0.5494769",
"0.5492351",
"0.54807913",
"0.5479083",
"0.54788715",
"0.5475542",
"0.54672164",
"0.54668665",
"0.5456431",
"0.5455477",
"0.5454777",
"0.54436153",
"0.54429775",
"0.5441634",
"0.543602",
"0.54357743",
"0.5433578",
"0.54327583",
"0.5431322",
"0.54207236",
"0.5420337",
"0.54167014",
"0.54106504",
"0.541014",
"0.5394641",
"0.5382425",
"0.53796864",
"0.53760487",
"0.53728026",
"0.53689533",
"0.5354178",
"0.53525084",
"0.53516763",
"0.5349824",
"0.53449434",
"0.53367245",
"0.53332925",
"0.53304005",
"0.53300303"
]
| 0.0 | -1 |
This method provides the ability to change the display height of the map chart. The permitted heights are available in static constants of class (X_ZOOM_LEVEL) or intermediate values to them. | @Override
public void setCameraZoom(int zoomLevel) {
mMap.moveCamera(CameraUpdateFactory.zoomTo(zoomLevel));
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void updateMapViewHeight() {\n\t\tint screenHeight = getActivity().getWindowManager().getDefaultDisplay()\n\t\t\t\t.getHeight();\n\n\t\tint coordinatesContainerHeight = 0;\n\t\tif (mEditMode) {\n\t\t\tmDiveSiteCoordinatesEditContainer.measure(MeasureSpec.UNSPECIFIED,\n\t\t\t\t\tMeasureSpec.UNSPECIFIED);\n\t\t\tcoordinatesContainerHeight = mDiveSiteCoordinatesEditContainer\n\t\t\t\t\t.getMeasuredHeight();\n\t\t}\n\n\t\tmMapView.getLayoutParams().height = screenHeight - getTitleBarHeight()\n\t\t\t\t- getStatusBarHeight() - coordinatesContainerHeight\n\t\t\t\t- MAPVIEW_HEIGHT_BUFFER;\n\t}",
"public void setHeight(int height);",
"public void setHeight(int height);",
"public void setHeight(Integer height) {\n this.height = height;\n control.draw();\n }",
"public void setHeight(int value) {\n this.height = value;\n }",
"public void setHeight(double value) {\n this.height = value;\n }",
"@Override\n\tpublic void setHeight(float height) {\n\n\t}",
"public static int getMapHeight() {\r\n\t\treturn 7;\r\n\t}",
"void setHeight(int height);",
"void setHeight(int height);",
"public void setHeight(double height) {\n this.height = height;\n }",
"public void updateHeight() {\n Rectangle repaintBounds = getBounds();\n parent.getScene().paintImmediately(repaintBounds);\n\n // set new height compute while repainting.\n setBounds(new Rectangle(bounds));\n\n parent.getScene().repaint(repaintBounds);\n setChanged();\n notifyObservers();\n }",
"public void setHeight(double height) {\r\n this.height = height;\r\n }",
"public void setHeight(int newValue)\n {\n height = newValue;\n }",
"@Override\r\n\tpublic void setHeight(int height) {\n\t\t\r\n\t}",
"public void setHeight(int height) {\n this.height = height;\n }",
"public void setHeight(double height) {\n this.height = height;\n }",
"public void setHeight(int height) {\r\n this.height = height;\r\n }",
"@Override\n\tpublic void setHeight(short arg0) {\n\t\t\n\t}",
"void setHeight(VariableAmount height);",
"private void setHeight(float height){\n this.height = height;\n }",
"@Override\r\n public void setHeight(String height) {\n }",
"public final native void setHeight(double height) /*-{\n this.setHeight(height);\n }-*/;",
"public void setHeight(int l){\n \theight = l;\n }",
"public void setHeight(double height){\n h=height;\r\n }",
"public void setHeight(int height) {\n this.height = height;\n }",
"public void setHeight(int height) {\n this.height = height;\n }",
"public void setHeight(int h) {\n this.H = h;\n }",
"default void setHeight(int height) {\n setHeight(VariableAmount.fixed(height));\n }",
"public void setHeight(int arg) throws ReadWriteException\n\t{\n\t\tsetValue(_Prefix + HardZone.HEIGHT.toString(), arg);\n\t}",
"public void setHeight(int newValue) {\n seatHeight = newValue;\n }",
"@Override\n public double getMaxY() {\n return curMap.getMap().getHeight();\n }",
"private void setWindowHeight(int height) {\n this.height = height;\n }",
"public void setHeight(int height) {\r\n\t\tthis.height = height;\r\n\t}",
"public void setHeight(int newValue)\r\n {\r\n seatHeight = newValue;\r\n }",
"public void setHeight(int h)\n {\n height = h;\n }",
"public void setHeight(int height) {\n int oldValue = mHeight;\n mHeight = height;\n pcs.firePropertyChange(PROP_HEIGHT, oldValue, mHeight);\n }",
"public void setHeight(double height) {\n\t\tthis.height = height;\n\t}",
"public void setHeight(double height) {\n\t\tthis.height = height;\n\t}",
"public void setHeight(double height) {\n\t\tthis.height = height;\n\t}",
"public abstract int getDisplayHeight();",
"public void setHeight(int newHeight) {\n roomHeight = newHeight;\n }",
"public static Integer getMapHeight() {\n\t\treturn MAPHEIGHT;\n\t}",
"private void updateSize() {\n double width = pane.getWidth();\n double height = pane.getHeight();\n\n if(oldWidth == 0) {\n oldWidth = width;\n }\n if(oldHeight == 0) {\n oldHeight = height;\n }\n\n double oldHvalue = pane.getHvalue();\n double oldVvalue = pane.getVvalue();\n if(Double.isNaN(oldVvalue)) {\n oldVvalue = 0;\n }\n if(Double.isNaN(oldHvalue)) {\n oldHvalue = 0;\n }\n\n pane.setVmax(height);\n pane.setHmax(width);\n\n if(grow) {\n renderMapGrow(width, height, curZoom);\n } else {\n renderMap(width, height, curZoom);\n }\n\n pane.setVvalue((height/oldHeight)*oldVvalue);\n pane.setHvalue((width/oldWidth)*oldHvalue);\n\n oldWidth = width;\n oldHeight = height;\n }",
"public void setHeight(Integer height)\n {\n getStateHelper().put(PropertyKeys.height, height);\n }",
"public void setHeight(Short height) {\r\n this.height = height;\r\n }",
"public void setHeight( int height ) {\n\t\t_height = height;\n\t}",
"public void setHeight(final String value)\n {\n height = value;\n }",
"private void setHeight(long value) {\n bitField0_ |= 0x00000008;\n height_ = value;\n }",
"@Override\n public int getHeight() {\n return graphicsEnvironmentImpl.getHeight(canvas);\n }",
"public void setHeight(int height) {\n\t\tthis.height = height;\n\t}",
"public void setHeight(int height) {\n\t\tthis.height = height;\n\t}",
"public void setHeight(double height) {\n\t\t this.height = height;\n\t }",
"@Override\n\tpublic double getRenderHeight() {\n\t\treturn height;\n\t}",
"public void setHeight(int height) {\n\t\th = height;\n\t}",
"public void setBestHeight() { setHeight(getBestHeight()); }",
"@Override\n public int getHeight() {\n return height;\n }",
"@Override\n public int getHeight() {\n return height;\n }",
"public void setHeight(int inches) {\n if (inches >= 24 && inches <= 84)\n this.height = inches;\n }",
"public void setHeight(int height) {\n if (height > 0) {\n this.height = height;\n }\n }",
"void setFitHeight(short height);",
"@Override\n\tpublic void height() {\n\t\t\n\t}",
"public void setHeight(int height) {\n\tthis.height = height;\n\tcalculateHeightRatio();\n }",
"@Override\r\n public void changeSocialWindowHeight(int newHeight) {\r\n\r\n ViewGroup.LayoutParams layoutParams = unifiedSocialWindowView.getLayoutParams();\r\n layoutParams.height = newHeight;\r\n unifiedSocialWindowView.setLayoutParams(layoutParams);\r\n }",
"public void setHeight(float height) {\n this.yRadius = 0.5f * height;\n }",
"@Override\n\tpublic void setHeightInPoints(float arg0) {\n\t\t\n\t}",
"@Override\r\n\tprotected void onSizeChanged(int w, int h, int oldw, int oldh) {\n\t\tsuper.onSizeChanged(w, h, oldw, oldh);\r\n\t\t// 图所占范围大小\r\n\t\tchart.setChartRange(w, h);\r\n\t}",
"public int getHeight() {return height;}",
"public int getHeight() { return height; }",
"public void setHeight(String height) {\r\n this.height = height;\r\n }",
"public void setWindowHeight(double windowHeight) {\n this.windowHeight = windowHeight;\n }",
"public void changeHeight(double y)\r\n {\n }",
"public void setHeight(int arg, String compcode) throws ReadWriteException\n\t{\n\t\tsetValue(_Prefix + HardZone.HEIGHT.toString(), arg, compcode);\n\t}",
"public int levelHeight() {\r\n\t\treturn map[0].getProperties().get(\"height\", Integer.class);\r\n\t}",
"public void setDisplaySize(int width, int height)\r\n\t{\r\n\t\tint xDiff = (int) Math.abs(height - height*ASPECT);\r\n\t\tint yDiff = (int) Math.abs(width - width/ASPECT);\r\n\t\tif (xDiff < yDiff)\r\n\t\t{\r\n\t\t\tmMaxWidth = (int) (height*ASPECT);\r\n\t\t\tmMaxHeight = height;\r\n\t\t}\r\n\t\telse\r\n\t\t{\r\n\t\t\tmMaxWidth = width;\r\n\t\t\tmMaxHeight = (int)(width/ASPECT);\r\n\t\t}\r\n\t}",
"public void setHeight(String height) {\n this.height = height;\n }",
"public void onWindowResized(int width, int height) {\n this.setHeight(\"\" + (height - TopPanel.HEIGHT));\n }",
"public int getHeight() {\r\n return Display.getHeight();\r\n }",
"public void setHeight (int height) {\n if (height < 10) {\n Log.warning(\"Attempted to set a checkbox height of less than 10 pixels.\");\n return;\n }\n\n synchronized (this) {\n this.height = height;\n }\n }",
"public void setCurrentHeight(final int currentHeight);",
"public double getHeight() {\n return location.height();\n }",
"@Override\n\tpublic int getHeight() {\n\t\treturn windowHeight;\n\t}",
"public int getDisplayHeight() {\n\t\treturn displayHeight;\n\t}",
"public int getDisplayHeight()\n {\n if ( amiga.isPAL() ) {\n return isInterlaced() ? 512 : 256;\n }\n return isInterlaced() ? 400 : 200;\n }",
"@java.lang.Override\n public long getHeight() {\n return height_;\n }",
"public final int getHeight() {\r\n return config.height;\r\n }",
"public double getHeight();",
"public double getHeight();",
"public void setTabHeight( final int height ) {\n checkWidget();\n if( height < -1 ) {\n SWT.error( SWT.ERROR_INVALID_ARGUMENT );\n }\n fixedTabHeight = height;\n updateTabHeight( false );\n }",
"public void setYHeight(float yHeight) {\n\t\tthis.yHeight = yHeight;\n\t}",
"@Override\n\tpublic float getHeight() {\n\t\treturn 26;\n\t}",
"public int getHeight() {\n return height;\n }",
"public int getHeight() {\n return height;\n }",
"public int getHeight() {\n return height;\n }",
"public float getHeight();",
"public abstract Builder setOutputHeight(int value);",
"public int getHeight() {\n return height;\n }",
"@Override\n public int getHeight() {\n return this.height;\n }",
"@Override\n\tpublic void setHeight(int y) {\n\t\tdelegate.setHeight(y);\n\t}",
"@Override\n protected void setHeight(Context context, Integer heightInDp) {\n }",
"public float getHeight() {\r\n\t\treturn height;\r\n\t}"
]
| [
"0.70661247",
"0.65448505",
"0.65448505",
"0.651352",
"0.648073",
"0.64734995",
"0.6438781",
"0.6390741",
"0.63856643",
"0.63856643",
"0.6365522",
"0.63205093",
"0.6300341",
"0.6297921",
"0.6272116",
"0.6246726",
"0.6243689",
"0.6199641",
"0.619859",
"0.6193157",
"0.6178397",
"0.6176159",
"0.6170486",
"0.6166103",
"0.6154324",
"0.61409104",
"0.61409104",
"0.6121185",
"0.61116534",
"0.60921293",
"0.6091738",
"0.60711807",
"0.6068946",
"0.60633594",
"0.6061481",
"0.60586935",
"0.604285",
"0.60405695",
"0.60405695",
"0.60405695",
"0.6034989",
"0.6032387",
"0.6028727",
"0.6019762",
"0.6000686",
"0.5992738",
"0.5955911",
"0.5953748",
"0.5944335",
"0.5926804",
"0.59145236",
"0.59145236",
"0.5909063",
"0.59081805",
"0.59057796",
"0.58955914",
"0.58649015",
"0.58649015",
"0.5862119",
"0.5846346",
"0.5846",
"0.58255464",
"0.5822312",
"0.58058584",
"0.58040905",
"0.58037",
"0.57970566",
"0.5777753",
"0.5775348",
"0.5768755",
"0.57574415",
"0.5738201",
"0.5733403",
"0.57317656",
"0.57269543",
"0.57055295",
"0.5704946",
"0.56957823",
"0.5688772",
"0.56722003",
"0.5669678",
"0.5660227",
"0.5649993",
"0.56430364",
"0.5606958",
"0.56050634",
"0.55996567",
"0.55996567",
"0.5587241",
"0.5581454",
"0.55732256",
"0.5565378",
"0.5565378",
"0.5565378",
"0.5564559",
"0.5560538",
"0.5555038",
"0.5552752",
"0.5542439",
"0.55418354",
"0.5540093"
]
| 0.0 | -1 |
Returns a single listener. Asserts that the number configured is <= 1, and returns a noop listener if 0 or the only one in the list if 1. | public static ClusterListener singleClusterListener(final ClusterSettings clusterSettings) {
assertTrue(clusterSettings.getClusterListeners().size() <= 1);
return clusterSettings.getClusterListeners().isEmpty()
? NO_OP_CLUSTER_LISTENER
: clusterSettings.getClusterListeners().get(0);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public static ServerListener singleServerListener(final ServerSettings serverSettings) {\n assertTrue(serverSettings.getServerListeners().size() <= 1);\n return serverSettings.getServerListeners().isEmpty()\n ? NO_OP_SERVER_LISTENER\n : serverSettings.getServerListeners().get(0);\n }",
"public static ServerMonitorListener singleServerMonitorListener(final ServerSettings serverSettings) {\n assertTrue(serverSettings.getServerMonitorListeners().size() <= 1);\n return serverSettings.getServerMonitorListeners().isEmpty()\n ? NO_OP_SERVER_MONITOR_LISTENER\n : serverSettings.getServerMonitorListeners().get(0);\n }",
"@Nullable\n public P getListener() {\n return mListener;\n }",
"@Override\n public Listener<T> getListener() {\n List<ProcessorNode> nodes = getProcessorChain();\n if(nodes != null && !nodes.isEmpty()){\n return nodes.get(0).getListener();\n }else if(getConsumer() != null){\n return getConsumer().getListener();\n }\n return null;\n }",
"public ConnectionListener getListener(String listenerID);",
"protected String getDefaultListener()\n {\n return DEFAULT_LISTENER;\n }",
"public Listener getListener() {\n return listener;\n }",
"@Override\n\tpublic String getListenerID() {\n\t\treturn null;\n\t}",
"public synchronized EndpointListener getListener(String str) {\r\n return (EndpointListener) propListeners.get(str);\r\n }",
"public String getListener(int i)\r\n { return this.history.get(i).listener;\r\n }",
"long getListenerCount();",
"private String getNotifierListener(int notifierType) {\n\t\tString listener = null;\n\t\ttry {\n\t\t\tswitch (notifierType) {\n\t\t\tcase NotifierConstants.PUSH_MESSAGE_NOTIFIER:\n\t\t\t\tlistener = appConfigInformation.getString(SmartConstants.APPEZ_CONF_PROP_PUSH_NOTIFIER_LISTENER);\n\t\t\t\tbreak;\n\n\t\t\tcase NotifierConstants.NETWORK_STATE_NOTIFIER:\n\t\t\t\tlistener = appConfigInformation.getString(SmartConstants.APPEZ_CONF_PROP_NWSTATE_NOTIFIER_LISTENER);\n\t\t\t\tbreak;\n\t\t\t}\n\t\t} catch (JSONException je) {\n\t\t\t// TODO handle this exception\n\t\t}\n\t\treturn listener;\n\t}",
"@Required\n @Updatable\n public Set<Listener> getListener() {\n if (listener == null) {\n listener = new HashSet<>();\n }\n\n return listener;\n }",
"@Override\n\tpublic String getListenerId()\n\t{\n\t\treturn ID;\n\t}",
"private static StatusListener getListener() {\n StatusListener statusListener = new StatusListener () {\n @Override\n public void onException(Exception e) {\n }\n\n public void onStatus(Status status) {\n reply(status);\n }\n\n @Override\n public void onDeletionNotice(StatusDeletionNotice statusDeletionNotice) {\n }\n\n @Override\n public void onTrackLimitationNotice(int i) {\n }\n\n @Override\n public void onScrubGeo(long l, long l1) {\n }\n\n @Override\n public void onStallWarning(StallWarning stallWarning) {\n }\n\n };\n return statusListener;\n }",
"@SuppressWarnings(\"deprecation\")\n\torg.ogema.core.resourcemanager.ResourceListener getListener();",
"Move listen(IListener ll);",
"public TCPListener getMyTCPListener()\n {\n return fMyListener;\n }",
"public int listen() {\n\t\tcommlock.acquire();\n\n\t\tlistenersWaiting++;\n\t\tLib.debug(dbgCommunicator, \"Waiting Listeners \" + listenersWaiting);\n\t\tspeaker.wake();\n\t\tlistener.sleep();\n\n\t\tint word = sharedWord;\n\t\tsharedWordInUse = false;\n\t\tlistenersWaiting--;\n\t\tLib.debug(dbgCommunicator, \"Waiting Listeners \" + listenersWaiting);\n\n\t\tcommlock.release();\n\n\n\treturn word;\n }",
"public NumberCellGeneratorListener getListener() {\n return mListener;\n }",
"public boolean isListenerAvailable() {\n return mListener != null;\n }",
"public boolean isListenerAvailable() {\n return mListener != null;\n }",
"public boolean hasListener(int type) {\n assert type > 0 : \"Invalid event type: \" + type;\n\n Listeners listeners = lsnrs.get(type);\n\n return (listeners != null) && (!F.isEmpty(listeners.highPriorityLsnrs) || !F.isEmpty(listeners.lsnrs));\n }",
"static synchronized AbstractMMXListener getGlobalListener() {\n return sInstance.mGlobalListener;\n }",
"private ContactListener getListener(short categoryA, short categoryB)\n\t{\n\t\tObjectMap<Short, ContactListener> listenerCollection = listeners.get(categoryA);\n\t\tif (listenerCollection == null)\n\t\t{\n\t\t return null;\n\t\t}\n\t\treturn listenerCollection.get(categoryB);\n\t}",
"public ActivityListener getListener() {\n\t\treturn logger.getConfiguration().getActivityListener();\n\t}",
"public Optional<D> getNetworkEventListener();",
"public static ServerSocket getServerSocket(){\n if (listener == null) {\n listener = createServerSocket();\n }\n return listener;\n }",
"@Test\n public void testLogErrorListener()\n {\n assertEquals(\"No default error listener registered\", 1,\n new DefaultConfigurationBuilder().getErrorListeners().size());\n }",
"public ListenerRegistar getMiListener() {\n return miListenerReg;\n }",
"public int listen() {\n \tlock.acquire();\n \tif (status!= s_waitL) {\n \t\twaitingL++;\n \t\t//System.out.println(KThread.currentThread() + \" Listener slept, state = \" + status);\n \t\tcondListen.sleep();\n \t\t//System.out.println(KThread.currentThread() + \" Listener arrives\");\n \t\twaitingL--;\n \t}\n \telse ;//System.out.println(KThread.currentThread() + \" Listener arrives without sleep\");\n \t\n \t\n \t\n \tLib.assertTrue(status == s_waitL || status == s_waitLq);\n \t\n \t//System.out.println(KThread.currentThread() + \" Wake up a returner\");\n \t\n \tint ret = msg;\n \tcondRet.wake();\n \tstatus = s_waitR;\n \tlock.release();\n \treturn ret;\n }",
"ListenerMethod getListenerMethod();",
"private DefaultListener() {\n }",
"@Test\n public void testListen_int() throws Exception {\n System.out.println(\"listen\");\n int p = 4000;\n instance.listen(p);\n }",
"public int listen() {\n\t \n\t \n\tconditionLock.acquire();\n\t\t\n\t\tint aux=0;\n\t \n\t\twhile(listenerReady == true){\n\t\t\tcondLock.sleep();\n\t\t}\n\t\t//~ else{\n\t\t\tlistenerReady = true;\n\t\t\tcondLock.wakeAll();\n\t\t\t\n\t\t\taux = data;\n\t\t\n\t\twhile(speakerReady == false){\n\t\t\t\n\t\t\tcondLock.sleep();\n\t\t}\t\n\t\t\n\t\taux = data;\n\t\tspeakerReady = false;\n\t\tcondLock.wakeAll();\n\t\t\n\t\t//~ if(speakerReady){\n\t\t\t\t\n\t\t\t\t//~ aux = data;\n\t\t\t\t//~ speakerReady = false;\n\t\t\t\t\n\t\t\t\t//~ condLock.wakeAll();\n\t\t\t//~ }\n\t\t\t//~ else{\n\t\t\t\t//~ condLock.sleep();\n\t\t\t\t\n\t\t\t\t//~ aux = data;\n\t\t\t\t//~ speakerReady = false;\n\t\t\t\t//~ condLock.wakeAll();\n\t\t\t\t\n\t\t\t//~ }\n\t\t//~ }\n\t\n\t\n\tlistenerReady = false; \n\tconditionLock.release();\n\t \n\treturn aux;\n }",
"public static GuidoLocationListener getReference(){\r\n\t\tif(instance == null)\r\n\t\t\tinstance = new GuidoLocationListener();\r\n\t\treturn instance;\r\n\t}",
"public interface Listener {}",
"public int listen() {\n\t\tmutex.acquire();\n\t\twhile(message == null ) {\n\t\t\tspeakers.wake();\n\t\t\tlisteners.sleep();\n\t\t}\n\t\tint receivedWord = message.intValue();\n\t\tmessage = null;\n\t\tacknowledge.wake();\n\t\tmutex.release();\n\t\treturn receivedWord;\n\t}",
"public static boolean GetClientListenerStatus (){\n return ClientListenerAlive;\n }",
"protected static Listener testListenerClassValidity(Class<?> listenerClass) {\n Listener l = ReflectionUtil.getAnnotation(listenerClass, Listener.class);\n if (l == null)\n throw new IncorrectListenerException(String.format(\"Cache listener class %s must be annotated with org.infinispan.notifications.annotation.Listener\", listenerClass.getName()));\n return l;\n }",
"public synchronized boolean isEnabled() {\n \t\t\treturn listenerEnabled;\n \t\t}",
"public int getSize(){\r\n\t\treturn listeners.size();\r\n\t}",
"public CellListener getListener() {\n return listener;\n }",
"protected String getDefaultListenerMethod() {\n\t\treturn this.defaultListenerMethod;\n\t}",
"Integer listeningPort();",
"protected Integer getSourcePort(LoadBalancerListenerInfo listener) {\n return listener.getPrivatePort() != null ? listener.getPrivatePort() : listener.getSourcePort();\n }",
"@Override\n public BrokerMessageListener fetchByName(long companyId, String name)\n throws SystemException {\n return fetchByName(companyId, name, true);\n }",
"public interface GetPointsListener extends Listener {\n\n public void onGetPointsSucc(PointsInfo info);\n}",
"public E pollFirst();",
"public T pollFirst() {\n if (!isEmpty()) {\n T polled = (T) list[startIndex];\n startIndex++;\n if (isEmpty()) {\n startIndex = 0;\n nextindex = 0;\n }\n return polled;\n }\n return null;\n }",
"void setListener(Listener listener);",
"@Test\n public void testShouldNotDuplicateListeners() {\n manager.register(listener);\n manager.publishConnect(\"sessionId\");\n\n verify(listener, only()).onConnect(stringCaptor.capture());\n String id = stringCaptor.getValue();\n assertThat(id, is(equalTo(\"sessionId\")));\n }",
"public GameEvent getFirst();",
"IProductSelectorListener getM_pslListener();",
"public interface Listener {\n}",
"public interface Listener {\n}",
"public List<String> listeners();",
"@Override\n\tpublic void getListener(){\n\t}",
"@NonNull\n public HubEvent<?> awaitFirst() {\n // If the event list is empty, then wait.\n if (events.isEmpty()) {\n Latch.await(latch);\n }\n return events.isEmpty() ? null : events.get(0);\n }",
"public final int getPortListened() {\n return portListened;\n }",
"public QuadricRobustEstimatorListener getListener() {\n return mListener;\n }",
"public interface CallListener {\r\n void onCallTapListener(int position);\r\n}",
"LateListenerNotifier()\r\n/* :17: */ {\r\n/* :18:858 */ this.l = l;\r\n/* :19: */ }",
"public JmsRequestorListener getListener() {\n return listener;\n }",
"public ONDEXListener[] getONDEXListeners() {\n return listeners.toArray(new ONDEXListener[0]);\n }",
"public Call getCallById(Integer num) {\n return this.mCallMapById.get(num);\n }",
"public Listener(int max) {\r\n count = 0;\r\n maxCount = max;\r\n tweets = new LinkedList<Status>();\r\n }",
"private <T> ListenerList<T> getOrCreateListenerList(Class<T> target) {\n final ListenerList<T> existing = this.activeListeners.get(target);\n if (existing != null) {\n return existing;\n }\n synchronized (this.activeListenersWriteLock) {\n // Fetch the list again, as it could've been initialized since the lock was released.\n final ListenerList<T> list = this.activeListeners.get(target);\n if (list == null) {\n // Validate the event type, throwing an IllegalArgumentException if it is invalid\n Util.catchAndRethrow(() -> Events.validateEventType(target), IllegalArgumentException::new);\n\n final ListenerList<T> newList = this.listenerListFactory.create(target);\n\n // If insertion of a new key will require a rehash, then clone the map and reassign the field.\n if (this.activeListeners.needsRehash()) {\n final Event2ListenersMap newMap = this.activeListeners.clone();\n newMap.put(target, newList);\n this.activeListeners = newMap;\n } else {\n this.activeListeners.put(target, newList);\n }\n\n return newList;\n } else {\n return list;\n }\n }\n }",
"void removeListener(RosZeroconfListener listener);",
"@Test\n public void testLogErrorListener() throws ConfigurationException {\n final DatabaseConfiguration config = helper.setUpConfig();\n assertEquals(1, config.getEventListeners(ConfigurationErrorEvent.ANY).size());\n }",
"public void addEventListener(OneToOneChatListener listener) throws RcsServiceException {\n\t\tif (api != null) {\n\t\t\ttry {\n\t\t\t\tapi.addEventListener2(listener);\n\t\t\t} catch (Exception e) {\n\t\t\t\tthrow new RcsServiceException(e.getMessage());\n\t\t\t}\n\t\t} else {\n\t\t\tthrow new RcsServiceNotAvailableException();\n\t\t}\n\t}",
"public static ILateralCacheListener getInstance( ILateralCacheAttributes ilca )\n {\n //throws IOException, NotBoundException\n ILateralCacheListener ins = ( ILateralCacheListener ) instances.get( ilca.getUdpMulticastAddr() + \":\" + ilca.getUdpMulticastPort() );\n if ( ins == null )\n {\n synchronized ( LateralGroupCacheUDPListener.class )\n {\n if ( ins == null )\n {\n ins = new LateralGroupCacheUDPListener( ilca );\n }\n if ( log.isDebugEnabled() )\n {\n log.debug( \"created new listener \" + ilca.getUdpMulticastAddr() + \":\" + ilca.getUdpMulticastPort() );\n }\n instances.put( ilca.getUdpMulticastAddr() + \":\" + ilca.getUdpMulticastPort(), ins );\n }\n }\n return ins;\n }",
"public int addListener(Value listener) {\n\n IApplication adapter = new IApplication() {\n private boolean execute(Value jsObject, String memberName, Object... args) {\n if (jsObject == null)\n return true;\n Value member = jsObject.getMember(memberName);\n if (member == null) {\n return true;\n }\n Value result = plugin.executeInContext(member, app);\n return result != null && result.isBoolean() ? result.asBoolean() : true;\n }\n\n @Override\n public boolean appStart(IScope app) {\n return execute(listener, \"appStart\", app);\n }\n\n @Override\n public boolean appConnect(IConnection conn, Object[] params) {\n return execute(listener, \"appConnect\", conn, params);\n }\n\n @Override\n public boolean appJoin(IClient client, IScope app) {\n return execute(listener, \"appJoin\", client, app);\n }\n\n @Override\n public void appDisconnect(IConnection conn) {\n execute(listener, \"appDisconnect\", conn);\n }\n\n @Override\n public void appLeave(IClient client, IScope app) {\n execute(listener, \"appLeave\", client, app);\n }\n\n @Override\n public void appStop(IScope app) {\n execute(listener, \"appStop\", app);\n }\n\n @Override\n public boolean roomStart(IScope room) {\n return execute(listener, \"roomStart\", room);\n }\n\n @Override\n public boolean roomConnect(IConnection conn, Object[] params) {\n return execute(listener, \"roomConnect\", conn, params);\n }\n\n @Override\n public boolean roomJoin(IClient client, IScope room) {\n return execute(listener, \"roomJoin\", client, room);\n }\n\n @Override\n public void roomDisconnect(IConnection conn) {\n execute(listener, \"roomDisconnect\", conn);\n }\n\n @Override\n public void roomLeave(IClient client, IScope room) {\n execute(listener, \"roomLeave\", client, room);\n }\n\n @Override\n public void roomStop(IScope room) {\n execute(listener, \"roomStop\", room);\n }\n };\n this.app.addListener(adapter);\n this.listeners.add(adapter);\n return this.listeners.indexOf(adapter);\n }",
"public boolean contains(L listener) {\r\n synchronized (this) {\r\n return listeners.containsKey(listener) || weak.containsKey(listener);\r\n }\r\n }",
"@Override\r\n\tnative long createListenerProxy(EventSink eventSink);",
"void addListener(RosZeroconfListener listener);",
"public Conservable[] getListener() throws SQLException{\n return listener;\n }",
"@Override\n public BrokerMessageListener findByCompany_First(long companyId,\n OrderByComparator orderByComparator)\n throws NoSuchBrokerMessageListenerException, SystemException {\n BrokerMessageListener brokerMessageListener = fetchByCompany_First(companyId,\n orderByComparator);\n\n if (brokerMessageListener != null) {\n return brokerMessageListener;\n }\n\n StringBundler msg = new StringBundler(4);\n\n msg.append(_NO_SUCH_ENTITY_WITH_KEY);\n\n msg.append(\"companyId=\");\n msg.append(companyId);\n\n msg.append(StringPool.CLOSE_CURLY_BRACE);\n\n throw new NoSuchBrokerMessageListenerException(msg.toString());\n }",
"@Test\n public void testListenerIsNotified () {\n DelayedPrompter.Listener mockListener = mock(DelayedPrompter.Listener.class);\n Message mockMessage = mock(Message.class);\n Bundle mockBundle = mock(Bundle.class);\n when(mockMessage.getData()).thenReturn(mockBundle);\n when(mockBundle.getInt(DelayedPrompter.NUM_OF_ROWS_IN_LIST)).thenReturn(13);\n\n DelayedPrompter promptHandler = new DelayedPrompter(mockListener);\n\n promptHandler.handleMessage(mockMessage);\n\n verify(mockListener).listUpdated(13);\n }",
"public boolean hasListeners() {\n return !listeners.isEmpty();\n }",
"public boolean hasListeners() {\n return !listeners.isEmpty();\n }",
"public DefaultDeviceDiscovererListener()\r\n {\r\n }",
"public static Sensor getFirstSensor() {\n\t\tSensor retVal = null;\n\t\tfor (int x = 0; x < mSensors.size(); x++) {\n\t\t\tif (mSensors.get(x).mEnabled) {\n\t\t\t\tretVal = mSensors.get(x);\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\n\t\treturn retVal;\n\t}",
"public MyListener() {\r\n }",
"void removeListener(\n ReaderSettingsListenerType l);",
"public String addListener(ServiceListener listener) {\n return (orgConfigImpl.addListener(listener));\n }",
"@Async.Schedule\n public void listen(IgniteRunnable lsnr);",
"public void addListener(int userID, int epoch, int listenerPort, String listenerType, int listenerid) {\n\t\tListener e = new Listener(userID, epoch, listenerPort, listenerType, listenerid);\n\t\tlisteners.add(e);\n\t}",
"static //@Override\n\tpublic void addListener(final Listener listener) {\n\t\tif (null == stListeners) {\n\t\t\tstListeners = new LinkedList<>();\n\t\t}\n\t\tstListeners.add(listener);\n\t}",
"private void removeListener(int n) {\n Object object = this.mMapLock;\n synchronized (object) {\n this.mListenerMap.remove(n);\n this.mServiceMap.remove(n);\n return;\n }\n }",
"public static int choosePort() {\n try (ServerSocket s = new ServerSocket(0)) {\n return s.getLocalPort();\n } catch (IOException ex) {\n throw new DeltaException(\"Failed to find a port\");\n }\n }",
"boolean addConnectionListener(LWSConnectionListener lis);",
"public void addListener(Listener l) {\n if (!listeners.contains(l)) {\n listeners.add(l);\n }\n }",
"public boolean removeListener(ChipListener l) {\n return listeners.remove(l);\n }",
"public void maybeAdd(Object listener) {\n if (type.isInstance(listener)) {\n add(type.cast(listener));\n }\n }",
"public Builder listeningPort(final Optional<Integer> maybeListeningPort) {\n this.listeningPort = maybeListeningPort.filter(port -> port != 0);\n return this;\n }",
"@Override\r\n\t\tpublic ApplicationListener createApplicationListener() {\n\t\t\treturn new FishchickenGame();\r\n\t\t}",
"private ChangeListener createMaxListener()\r\n\t\t{\r\n\t\treturn new ChangeListener()\r\n\t\t\t{\r\n\r\n\t\t\t//called when the max spinner value is changed\r\n\t\t\t@Override\r\n\t\t\tpublic void stateChanged(ChangeEvent e)\r\n\t\t\t\t{\r\n\t\t\t\tint spinMinValue = (int)spinMin.getValue();\r\n\t\t\t\tint spinMaxValue = (int)spinMax.getValue();\r\n\r\n\t\t\t\tif (spinMaxValue <= spinMinValue) { // verify if the max spin goes under the min limit and adjust the value if necessary\r\n\t\t\t\t\tif (--spinMinValue < min)\r\n\t\t\t\t\t\t{\r\n\t\t\t\t\t\t\tspinMax.setValue(spinMaxValue = (spinMinValue=min)+1);\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\tspinMin.setValue(spinMinValue);\r\n\t\t\t\t}\r\n\r\n\t\t\t\tif (spinMaxValue > spinMinValue) // verify intervals are correct\r\n\t\t\t\t\t{\r\n\t\t\t\t\tdiceBuilder.setInterval(spinMinValue, spinMaxValue);\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\r\n\t\t\t};\r\n\r\n\t\t}",
"void removeListener(BotListener l);",
"private InterstitialViewListener getInterstitialViewListener() {\n return (InterstitialViewListener) WhiteBox.getInternalState(mInterstitialController, \"mInterstitialViewListener\");\n }"
]
| [
"0.6223965",
"0.57466096",
"0.55924916",
"0.5585998",
"0.5552002",
"0.54347086",
"0.54001075",
"0.5384879",
"0.5338852",
"0.5231237",
"0.504645",
"0.500792",
"0.5000315",
"0.49573186",
"0.49510753",
"0.49292958",
"0.4872886",
"0.48387346",
"0.482676",
"0.4817139",
"0.47272733",
"0.47272733",
"0.47225425",
"0.46922663",
"0.46747684",
"0.4628904",
"0.45998305",
"0.45956293",
"0.459141",
"0.45779246",
"0.4574645",
"0.45740283",
"0.45534065",
"0.45429814",
"0.45246252",
"0.44844165",
"0.4483305",
"0.44816527",
"0.44747633",
"0.44670254",
"0.44594043",
"0.44276825",
"0.4427606",
"0.44193158",
"0.438376",
"0.43730813",
"0.43487793",
"0.43476018",
"0.43470564",
"0.43428642",
"0.4340997",
"0.433238",
"0.43226817",
"0.43221173",
"0.4313831",
"0.4313831",
"0.429811",
"0.4295428",
"0.42903492",
"0.42808163",
"0.42771095",
"0.42751455",
"0.4274516",
"0.42720854",
"0.4267302",
"0.42666918",
"0.42653507",
"0.42572805",
"0.42512614",
"0.42430252",
"0.42259648",
"0.42252737",
"0.42196134",
"0.4215038",
"0.42098382",
"0.41944134",
"0.4190018",
"0.41784596",
"0.41714627",
"0.41705143",
"0.41705143",
"0.41657123",
"0.41382727",
"0.41376075",
"0.41264912",
"0.41189972",
"0.41140172",
"0.41135475",
"0.41099834",
"0.4106585",
"0.41046482",
"0.41011786",
"0.40991545",
"0.40976438",
"0.409522",
"0.40934235",
"0.409201",
"0.40915635",
"0.4091337",
"0.4077777"
]
| 0.55467165 | 5 |
Returns a single listener. Asserts that the number configured is <= 1, and returns a noop listener if 0 or the only one in the list if 1. | public static ServerListener singleServerListener(final ServerSettings serverSettings) {
assertTrue(serverSettings.getServerListeners().size() <= 1);
return serverSettings.getServerListeners().isEmpty()
? NO_OP_SERVER_LISTENER
: serverSettings.getServerListeners().get(0);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public static ServerMonitorListener singleServerMonitorListener(final ServerSettings serverSettings) {\n assertTrue(serverSettings.getServerMonitorListeners().size() <= 1);\n return serverSettings.getServerMonitorListeners().isEmpty()\n ? NO_OP_SERVER_MONITOR_LISTENER\n : serverSettings.getServerMonitorListeners().get(0);\n }",
"@Nullable\n public P getListener() {\n return mListener;\n }",
"@Override\n public Listener<T> getListener() {\n List<ProcessorNode> nodes = getProcessorChain();\n if(nodes != null && !nodes.isEmpty()){\n return nodes.get(0).getListener();\n }else if(getConsumer() != null){\n return getConsumer().getListener();\n }\n return null;\n }",
"public ConnectionListener getListener(String listenerID);",
"public static ClusterListener singleClusterListener(final ClusterSettings clusterSettings) {\n assertTrue(clusterSettings.getClusterListeners().size() <= 1);\n return clusterSettings.getClusterListeners().isEmpty()\n ? NO_OP_CLUSTER_LISTENER\n : clusterSettings.getClusterListeners().get(0);\n }",
"protected String getDefaultListener()\n {\n return DEFAULT_LISTENER;\n }",
"public Listener getListener() {\n return listener;\n }",
"@Override\n\tpublic String getListenerID() {\n\t\treturn null;\n\t}",
"public synchronized EndpointListener getListener(String str) {\r\n return (EndpointListener) propListeners.get(str);\r\n }",
"public String getListener(int i)\r\n { return this.history.get(i).listener;\r\n }",
"long getListenerCount();",
"private String getNotifierListener(int notifierType) {\n\t\tString listener = null;\n\t\ttry {\n\t\t\tswitch (notifierType) {\n\t\t\tcase NotifierConstants.PUSH_MESSAGE_NOTIFIER:\n\t\t\t\tlistener = appConfigInformation.getString(SmartConstants.APPEZ_CONF_PROP_PUSH_NOTIFIER_LISTENER);\n\t\t\t\tbreak;\n\n\t\t\tcase NotifierConstants.NETWORK_STATE_NOTIFIER:\n\t\t\t\tlistener = appConfigInformation.getString(SmartConstants.APPEZ_CONF_PROP_NWSTATE_NOTIFIER_LISTENER);\n\t\t\t\tbreak;\n\t\t\t}\n\t\t} catch (JSONException je) {\n\t\t\t// TODO handle this exception\n\t\t}\n\t\treturn listener;\n\t}",
"@Required\n @Updatable\n public Set<Listener> getListener() {\n if (listener == null) {\n listener = new HashSet<>();\n }\n\n return listener;\n }",
"@Override\n\tpublic String getListenerId()\n\t{\n\t\treturn ID;\n\t}",
"private static StatusListener getListener() {\n StatusListener statusListener = new StatusListener () {\n @Override\n public void onException(Exception e) {\n }\n\n public void onStatus(Status status) {\n reply(status);\n }\n\n @Override\n public void onDeletionNotice(StatusDeletionNotice statusDeletionNotice) {\n }\n\n @Override\n public void onTrackLimitationNotice(int i) {\n }\n\n @Override\n public void onScrubGeo(long l, long l1) {\n }\n\n @Override\n public void onStallWarning(StallWarning stallWarning) {\n }\n\n };\n return statusListener;\n }",
"@SuppressWarnings(\"deprecation\")\n\torg.ogema.core.resourcemanager.ResourceListener getListener();",
"Move listen(IListener ll);",
"public TCPListener getMyTCPListener()\n {\n return fMyListener;\n }",
"public int listen() {\n\t\tcommlock.acquire();\n\n\t\tlistenersWaiting++;\n\t\tLib.debug(dbgCommunicator, \"Waiting Listeners \" + listenersWaiting);\n\t\tspeaker.wake();\n\t\tlistener.sleep();\n\n\t\tint word = sharedWord;\n\t\tsharedWordInUse = false;\n\t\tlistenersWaiting--;\n\t\tLib.debug(dbgCommunicator, \"Waiting Listeners \" + listenersWaiting);\n\n\t\tcommlock.release();\n\n\n\treturn word;\n }",
"public NumberCellGeneratorListener getListener() {\n return mListener;\n }",
"public boolean isListenerAvailable() {\n return mListener != null;\n }",
"public boolean isListenerAvailable() {\n return mListener != null;\n }",
"public boolean hasListener(int type) {\n assert type > 0 : \"Invalid event type: \" + type;\n\n Listeners listeners = lsnrs.get(type);\n\n return (listeners != null) && (!F.isEmpty(listeners.highPriorityLsnrs) || !F.isEmpty(listeners.lsnrs));\n }",
"static synchronized AbstractMMXListener getGlobalListener() {\n return sInstance.mGlobalListener;\n }",
"private ContactListener getListener(short categoryA, short categoryB)\n\t{\n\t\tObjectMap<Short, ContactListener> listenerCollection = listeners.get(categoryA);\n\t\tif (listenerCollection == null)\n\t\t{\n\t\t return null;\n\t\t}\n\t\treturn listenerCollection.get(categoryB);\n\t}",
"public ActivityListener getListener() {\n\t\treturn logger.getConfiguration().getActivityListener();\n\t}",
"public Optional<D> getNetworkEventListener();",
"public static ServerSocket getServerSocket(){\n if (listener == null) {\n listener = createServerSocket();\n }\n return listener;\n }",
"@Test\n public void testLogErrorListener()\n {\n assertEquals(\"No default error listener registered\", 1,\n new DefaultConfigurationBuilder().getErrorListeners().size());\n }",
"public ListenerRegistar getMiListener() {\n return miListenerReg;\n }",
"ListenerMethod getListenerMethod();",
"public int listen() {\n \tlock.acquire();\n \tif (status!= s_waitL) {\n \t\twaitingL++;\n \t\t//System.out.println(KThread.currentThread() + \" Listener slept, state = \" + status);\n \t\tcondListen.sleep();\n \t\t//System.out.println(KThread.currentThread() + \" Listener arrives\");\n \t\twaitingL--;\n \t}\n \telse ;//System.out.println(KThread.currentThread() + \" Listener arrives without sleep\");\n \t\n \t\n \t\n \tLib.assertTrue(status == s_waitL || status == s_waitLq);\n \t\n \t//System.out.println(KThread.currentThread() + \" Wake up a returner\");\n \t\n \tint ret = msg;\n \tcondRet.wake();\n \tstatus = s_waitR;\n \tlock.release();\n \treturn ret;\n }",
"private DefaultListener() {\n }",
"@Test\n public void testListen_int() throws Exception {\n System.out.println(\"listen\");\n int p = 4000;\n instance.listen(p);\n }",
"public int listen() {\n\t \n\t \n\tconditionLock.acquire();\n\t\t\n\t\tint aux=0;\n\t \n\t\twhile(listenerReady == true){\n\t\t\tcondLock.sleep();\n\t\t}\n\t\t//~ else{\n\t\t\tlistenerReady = true;\n\t\t\tcondLock.wakeAll();\n\t\t\t\n\t\t\taux = data;\n\t\t\n\t\twhile(speakerReady == false){\n\t\t\t\n\t\t\tcondLock.sleep();\n\t\t}\t\n\t\t\n\t\taux = data;\n\t\tspeakerReady = false;\n\t\tcondLock.wakeAll();\n\t\t\n\t\t//~ if(speakerReady){\n\t\t\t\t\n\t\t\t\t//~ aux = data;\n\t\t\t\t//~ speakerReady = false;\n\t\t\t\t\n\t\t\t\t//~ condLock.wakeAll();\n\t\t\t//~ }\n\t\t\t//~ else{\n\t\t\t\t//~ condLock.sleep();\n\t\t\t\t\n\t\t\t\t//~ aux = data;\n\t\t\t\t//~ speakerReady = false;\n\t\t\t\t//~ condLock.wakeAll();\n\t\t\t\t\n\t\t\t//~ }\n\t\t//~ }\n\t\n\t\n\tlistenerReady = false; \n\tconditionLock.release();\n\t \n\treturn aux;\n }",
"public interface Listener {}",
"public static GuidoLocationListener getReference(){\r\n\t\tif(instance == null)\r\n\t\t\tinstance = new GuidoLocationListener();\r\n\t\treturn instance;\r\n\t}",
"public int listen() {\n\t\tmutex.acquire();\n\t\twhile(message == null ) {\n\t\t\tspeakers.wake();\n\t\t\tlisteners.sleep();\n\t\t}\n\t\tint receivedWord = message.intValue();\n\t\tmessage = null;\n\t\tacknowledge.wake();\n\t\tmutex.release();\n\t\treturn receivedWord;\n\t}",
"public static boolean GetClientListenerStatus (){\n return ClientListenerAlive;\n }",
"protected static Listener testListenerClassValidity(Class<?> listenerClass) {\n Listener l = ReflectionUtil.getAnnotation(listenerClass, Listener.class);\n if (l == null)\n throw new IncorrectListenerException(String.format(\"Cache listener class %s must be annotated with org.infinispan.notifications.annotation.Listener\", listenerClass.getName()));\n return l;\n }",
"public synchronized boolean isEnabled() {\n \t\t\treturn listenerEnabled;\n \t\t}",
"public CellListener getListener() {\n return listener;\n }",
"public int getSize(){\r\n\t\treturn listeners.size();\r\n\t}",
"protected String getDefaultListenerMethod() {\n\t\treturn this.defaultListenerMethod;\n\t}",
"Integer listeningPort();",
"protected Integer getSourcePort(LoadBalancerListenerInfo listener) {\n return listener.getPrivatePort() != null ? listener.getPrivatePort() : listener.getSourcePort();\n }",
"@Override\n public BrokerMessageListener fetchByName(long companyId, String name)\n throws SystemException {\n return fetchByName(companyId, name, true);\n }",
"public interface GetPointsListener extends Listener {\n\n public void onGetPointsSucc(PointsInfo info);\n}",
"public E pollFirst();",
"public T pollFirst() {\n if (!isEmpty()) {\n T polled = (T) list[startIndex];\n startIndex++;\n if (isEmpty()) {\n startIndex = 0;\n nextindex = 0;\n }\n return polled;\n }\n return null;\n }",
"void setListener(Listener listener);",
"@Test\n public void testShouldNotDuplicateListeners() {\n manager.register(listener);\n manager.publishConnect(\"sessionId\");\n\n verify(listener, only()).onConnect(stringCaptor.capture());\n String id = stringCaptor.getValue();\n assertThat(id, is(equalTo(\"sessionId\")));\n }",
"public GameEvent getFirst();",
"IProductSelectorListener getM_pslListener();",
"public interface Listener {\n}",
"public interface Listener {\n}",
"public List<String> listeners();",
"@Override\n\tpublic void getListener(){\n\t}",
"@NonNull\n public HubEvent<?> awaitFirst() {\n // If the event list is empty, then wait.\n if (events.isEmpty()) {\n Latch.await(latch);\n }\n return events.isEmpty() ? null : events.get(0);\n }",
"public final int getPortListened() {\n return portListened;\n }",
"public QuadricRobustEstimatorListener getListener() {\n return mListener;\n }",
"public interface CallListener {\r\n void onCallTapListener(int position);\r\n}",
"LateListenerNotifier()\r\n/* :17: */ {\r\n/* :18:858 */ this.l = l;\r\n/* :19: */ }",
"public JmsRequestorListener getListener() {\n return listener;\n }",
"public ONDEXListener[] getONDEXListeners() {\n return listeners.toArray(new ONDEXListener[0]);\n }",
"public Call getCallById(Integer num) {\n return this.mCallMapById.get(num);\n }",
"public Listener(int max) {\r\n count = 0;\r\n maxCount = max;\r\n tweets = new LinkedList<Status>();\r\n }",
"private <T> ListenerList<T> getOrCreateListenerList(Class<T> target) {\n final ListenerList<T> existing = this.activeListeners.get(target);\n if (existing != null) {\n return existing;\n }\n synchronized (this.activeListenersWriteLock) {\n // Fetch the list again, as it could've been initialized since the lock was released.\n final ListenerList<T> list = this.activeListeners.get(target);\n if (list == null) {\n // Validate the event type, throwing an IllegalArgumentException if it is invalid\n Util.catchAndRethrow(() -> Events.validateEventType(target), IllegalArgumentException::new);\n\n final ListenerList<T> newList = this.listenerListFactory.create(target);\n\n // If insertion of a new key will require a rehash, then clone the map and reassign the field.\n if (this.activeListeners.needsRehash()) {\n final Event2ListenersMap newMap = this.activeListeners.clone();\n newMap.put(target, newList);\n this.activeListeners = newMap;\n } else {\n this.activeListeners.put(target, newList);\n }\n\n return newList;\n } else {\n return list;\n }\n }\n }",
"void removeListener(RosZeroconfListener listener);",
"@Test\n public void testLogErrorListener() throws ConfigurationException {\n final DatabaseConfiguration config = helper.setUpConfig();\n assertEquals(1, config.getEventListeners(ConfigurationErrorEvent.ANY).size());\n }",
"public void addEventListener(OneToOneChatListener listener) throws RcsServiceException {\n\t\tif (api != null) {\n\t\t\ttry {\n\t\t\t\tapi.addEventListener2(listener);\n\t\t\t} catch (Exception e) {\n\t\t\t\tthrow new RcsServiceException(e.getMessage());\n\t\t\t}\n\t\t} else {\n\t\t\tthrow new RcsServiceNotAvailableException();\n\t\t}\n\t}",
"public static ILateralCacheListener getInstance( ILateralCacheAttributes ilca )\n {\n //throws IOException, NotBoundException\n ILateralCacheListener ins = ( ILateralCacheListener ) instances.get( ilca.getUdpMulticastAddr() + \":\" + ilca.getUdpMulticastPort() );\n if ( ins == null )\n {\n synchronized ( LateralGroupCacheUDPListener.class )\n {\n if ( ins == null )\n {\n ins = new LateralGroupCacheUDPListener( ilca );\n }\n if ( log.isDebugEnabled() )\n {\n log.debug( \"created new listener \" + ilca.getUdpMulticastAddr() + \":\" + ilca.getUdpMulticastPort() );\n }\n instances.put( ilca.getUdpMulticastAddr() + \":\" + ilca.getUdpMulticastPort(), ins );\n }\n }\n return ins;\n }",
"public int addListener(Value listener) {\n\n IApplication adapter = new IApplication() {\n private boolean execute(Value jsObject, String memberName, Object... args) {\n if (jsObject == null)\n return true;\n Value member = jsObject.getMember(memberName);\n if (member == null) {\n return true;\n }\n Value result = plugin.executeInContext(member, app);\n return result != null && result.isBoolean() ? result.asBoolean() : true;\n }\n\n @Override\n public boolean appStart(IScope app) {\n return execute(listener, \"appStart\", app);\n }\n\n @Override\n public boolean appConnect(IConnection conn, Object[] params) {\n return execute(listener, \"appConnect\", conn, params);\n }\n\n @Override\n public boolean appJoin(IClient client, IScope app) {\n return execute(listener, \"appJoin\", client, app);\n }\n\n @Override\n public void appDisconnect(IConnection conn) {\n execute(listener, \"appDisconnect\", conn);\n }\n\n @Override\n public void appLeave(IClient client, IScope app) {\n execute(listener, \"appLeave\", client, app);\n }\n\n @Override\n public void appStop(IScope app) {\n execute(listener, \"appStop\", app);\n }\n\n @Override\n public boolean roomStart(IScope room) {\n return execute(listener, \"roomStart\", room);\n }\n\n @Override\n public boolean roomConnect(IConnection conn, Object[] params) {\n return execute(listener, \"roomConnect\", conn, params);\n }\n\n @Override\n public boolean roomJoin(IClient client, IScope room) {\n return execute(listener, \"roomJoin\", client, room);\n }\n\n @Override\n public void roomDisconnect(IConnection conn) {\n execute(listener, \"roomDisconnect\", conn);\n }\n\n @Override\n public void roomLeave(IClient client, IScope room) {\n execute(listener, \"roomLeave\", client, room);\n }\n\n @Override\n public void roomStop(IScope room) {\n execute(listener, \"roomStop\", room);\n }\n };\n this.app.addListener(adapter);\n this.listeners.add(adapter);\n return this.listeners.indexOf(adapter);\n }",
"public boolean contains(L listener) {\r\n synchronized (this) {\r\n return listeners.containsKey(listener) || weak.containsKey(listener);\r\n }\r\n }",
"@Override\r\n\tnative long createListenerProxy(EventSink eventSink);",
"void addListener(RosZeroconfListener listener);",
"public Conservable[] getListener() throws SQLException{\n return listener;\n }",
"@Override\n public BrokerMessageListener findByCompany_First(long companyId,\n OrderByComparator orderByComparator)\n throws NoSuchBrokerMessageListenerException, SystemException {\n BrokerMessageListener brokerMessageListener = fetchByCompany_First(companyId,\n orderByComparator);\n\n if (brokerMessageListener != null) {\n return brokerMessageListener;\n }\n\n StringBundler msg = new StringBundler(4);\n\n msg.append(_NO_SUCH_ENTITY_WITH_KEY);\n\n msg.append(\"companyId=\");\n msg.append(companyId);\n\n msg.append(StringPool.CLOSE_CURLY_BRACE);\n\n throw new NoSuchBrokerMessageListenerException(msg.toString());\n }",
"@Test\n public void testListenerIsNotified () {\n DelayedPrompter.Listener mockListener = mock(DelayedPrompter.Listener.class);\n Message mockMessage = mock(Message.class);\n Bundle mockBundle = mock(Bundle.class);\n when(mockMessage.getData()).thenReturn(mockBundle);\n when(mockBundle.getInt(DelayedPrompter.NUM_OF_ROWS_IN_LIST)).thenReturn(13);\n\n DelayedPrompter promptHandler = new DelayedPrompter(mockListener);\n\n promptHandler.handleMessage(mockMessage);\n\n verify(mockListener).listUpdated(13);\n }",
"public boolean hasListeners() {\n return !listeners.isEmpty();\n }",
"public boolean hasListeners() {\n return !listeners.isEmpty();\n }",
"public DefaultDeviceDiscovererListener()\r\n {\r\n }",
"public MyListener() {\r\n }",
"public static Sensor getFirstSensor() {\n\t\tSensor retVal = null;\n\t\tfor (int x = 0; x < mSensors.size(); x++) {\n\t\t\tif (mSensors.get(x).mEnabled) {\n\t\t\t\tretVal = mSensors.get(x);\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\n\t\treturn retVal;\n\t}",
"void removeListener(\n ReaderSettingsListenerType l);",
"public String addListener(ServiceListener listener) {\n return (orgConfigImpl.addListener(listener));\n }",
"@Async.Schedule\n public void listen(IgniteRunnable lsnr);",
"public void addListener(int userID, int epoch, int listenerPort, String listenerType, int listenerid) {\n\t\tListener e = new Listener(userID, epoch, listenerPort, listenerType, listenerid);\n\t\tlisteners.add(e);\n\t}",
"static //@Override\n\tpublic void addListener(final Listener listener) {\n\t\tif (null == stListeners) {\n\t\t\tstListeners = new LinkedList<>();\n\t\t}\n\t\tstListeners.add(listener);\n\t}",
"private void removeListener(int n) {\n Object object = this.mMapLock;\n synchronized (object) {\n this.mListenerMap.remove(n);\n this.mServiceMap.remove(n);\n return;\n }\n }",
"boolean addConnectionListener(LWSConnectionListener lis);",
"public static int choosePort() {\n try (ServerSocket s = new ServerSocket(0)) {\n return s.getLocalPort();\n } catch (IOException ex) {\n throw new DeltaException(\"Failed to find a port\");\n }\n }",
"public void addListener(Listener l) {\n if (!listeners.contains(l)) {\n listeners.add(l);\n }\n }",
"public boolean removeListener(ChipListener l) {\n return listeners.remove(l);\n }",
"public void maybeAdd(Object listener) {\n if (type.isInstance(listener)) {\n add(type.cast(listener));\n }\n }",
"public Builder listeningPort(final Optional<Integer> maybeListeningPort) {\n this.listeningPort = maybeListeningPort.filter(port -> port != 0);\n return this;\n }",
"@Override\r\n\t\tpublic ApplicationListener createApplicationListener() {\n\t\t\treturn new FishchickenGame();\r\n\t\t}",
"void removeListener(BotListener l);",
"private ChangeListener createMaxListener()\r\n\t\t{\r\n\t\treturn new ChangeListener()\r\n\t\t\t{\r\n\r\n\t\t\t//called when the max spinner value is changed\r\n\t\t\t@Override\r\n\t\t\tpublic void stateChanged(ChangeEvent e)\r\n\t\t\t\t{\r\n\t\t\t\tint spinMinValue = (int)spinMin.getValue();\r\n\t\t\t\tint spinMaxValue = (int)spinMax.getValue();\r\n\r\n\t\t\t\tif (spinMaxValue <= spinMinValue) { // verify if the max spin goes under the min limit and adjust the value if necessary\r\n\t\t\t\t\tif (--spinMinValue < min)\r\n\t\t\t\t\t\t{\r\n\t\t\t\t\t\t\tspinMax.setValue(spinMaxValue = (spinMinValue=min)+1);\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\tspinMin.setValue(spinMinValue);\r\n\t\t\t\t}\r\n\r\n\t\t\t\tif (spinMaxValue > spinMinValue) // verify intervals are correct\r\n\t\t\t\t\t{\r\n\t\t\t\t\tdiceBuilder.setInterval(spinMinValue, spinMaxValue);\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\r\n\t\t\t};\r\n\r\n\t\t}",
"private InterstitialViewListener getInterstitialViewListener() {\n return (InterstitialViewListener) WhiteBox.getInternalState(mInterstitialController, \"mInterstitialViewListener\");\n }"
]
| [
"0.57468635",
"0.5592603",
"0.5586251",
"0.5552324",
"0.55473",
"0.5435362",
"0.5399837",
"0.53849614",
"0.53392136",
"0.52315897",
"0.50466186",
"0.5007862",
"0.5000775",
"0.4956263",
"0.49518213",
"0.49293324",
"0.4873376",
"0.48398277",
"0.48252115",
"0.48160207",
"0.4728047",
"0.4728047",
"0.4722843",
"0.4691601",
"0.46751055",
"0.46293432",
"0.46010768",
"0.45954654",
"0.4591443",
"0.45771584",
"0.45747665",
"0.45747548",
"0.4554182",
"0.4542917",
"0.45246932",
"0.44842252",
"0.4484221",
"0.44807956",
"0.4475785",
"0.44671884",
"0.4459438",
"0.44275412",
"0.44274756",
"0.4420296",
"0.43834674",
"0.43717048",
"0.4349582",
"0.43481383",
"0.43468222",
"0.4342181",
"0.434141",
"0.43325266",
"0.43224052",
"0.4322335",
"0.43149817",
"0.43149817",
"0.42999706",
"0.42961848",
"0.42901063",
"0.427943",
"0.4275914",
"0.427582",
"0.42754352",
"0.4271887",
"0.42678112",
"0.42662936",
"0.42653513",
"0.4256526",
"0.425161",
"0.42434683",
"0.42258662",
"0.42255947",
"0.4219931",
"0.42144498",
"0.42102325",
"0.4194924",
"0.4191601",
"0.41794783",
"0.41718036",
"0.41715616",
"0.41715616",
"0.41663596",
"0.41392636",
"0.4136615",
"0.41261607",
"0.41173884",
"0.41145644",
"0.41120902",
"0.41092876",
"0.41061625",
"0.41031",
"0.4103072",
"0.409925",
"0.40977848",
"0.40938818",
"0.40934867",
"0.40926647",
"0.40916312",
"0.40911168",
"0.40778047"
]
| 0.6224255 | 0 |
Returns a single listener. Asserts that the number configured is <= 1, and returns a noop listener if 0 or the only one in the list if 1. | public static ServerMonitorListener singleServerMonitorListener(final ServerSettings serverSettings) {
assertTrue(serverSettings.getServerMonitorListeners().size() <= 1);
return serverSettings.getServerMonitorListeners().isEmpty()
? NO_OP_SERVER_MONITOR_LISTENER
: serverSettings.getServerMonitorListeners().get(0);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public static ServerListener singleServerListener(final ServerSettings serverSettings) {\n assertTrue(serverSettings.getServerListeners().size() <= 1);\n return serverSettings.getServerListeners().isEmpty()\n ? NO_OP_SERVER_LISTENER\n : serverSettings.getServerListeners().get(0);\n }",
"@Nullable\n public P getListener() {\n return mListener;\n }",
"@Override\n public Listener<T> getListener() {\n List<ProcessorNode> nodes = getProcessorChain();\n if(nodes != null && !nodes.isEmpty()){\n return nodes.get(0).getListener();\n }else if(getConsumer() != null){\n return getConsumer().getListener();\n }\n return null;\n }",
"public ConnectionListener getListener(String listenerID);",
"public static ClusterListener singleClusterListener(final ClusterSettings clusterSettings) {\n assertTrue(clusterSettings.getClusterListeners().size() <= 1);\n return clusterSettings.getClusterListeners().isEmpty()\n ? NO_OP_CLUSTER_LISTENER\n : clusterSettings.getClusterListeners().get(0);\n }",
"protected String getDefaultListener()\n {\n return DEFAULT_LISTENER;\n }",
"public Listener getListener() {\n return listener;\n }",
"@Override\n\tpublic String getListenerID() {\n\t\treturn null;\n\t}",
"public synchronized EndpointListener getListener(String str) {\r\n return (EndpointListener) propListeners.get(str);\r\n }",
"public String getListener(int i)\r\n { return this.history.get(i).listener;\r\n }",
"long getListenerCount();",
"private String getNotifierListener(int notifierType) {\n\t\tString listener = null;\n\t\ttry {\n\t\t\tswitch (notifierType) {\n\t\t\tcase NotifierConstants.PUSH_MESSAGE_NOTIFIER:\n\t\t\t\tlistener = appConfigInformation.getString(SmartConstants.APPEZ_CONF_PROP_PUSH_NOTIFIER_LISTENER);\n\t\t\t\tbreak;\n\n\t\t\tcase NotifierConstants.NETWORK_STATE_NOTIFIER:\n\t\t\t\tlistener = appConfigInformation.getString(SmartConstants.APPEZ_CONF_PROP_NWSTATE_NOTIFIER_LISTENER);\n\t\t\t\tbreak;\n\t\t\t}\n\t\t} catch (JSONException je) {\n\t\t\t// TODO handle this exception\n\t\t}\n\t\treturn listener;\n\t}",
"@Required\n @Updatable\n public Set<Listener> getListener() {\n if (listener == null) {\n listener = new HashSet<>();\n }\n\n return listener;\n }",
"@Override\n\tpublic String getListenerId()\n\t{\n\t\treturn ID;\n\t}",
"private static StatusListener getListener() {\n StatusListener statusListener = new StatusListener () {\n @Override\n public void onException(Exception e) {\n }\n\n public void onStatus(Status status) {\n reply(status);\n }\n\n @Override\n public void onDeletionNotice(StatusDeletionNotice statusDeletionNotice) {\n }\n\n @Override\n public void onTrackLimitationNotice(int i) {\n }\n\n @Override\n public void onScrubGeo(long l, long l1) {\n }\n\n @Override\n public void onStallWarning(StallWarning stallWarning) {\n }\n\n };\n return statusListener;\n }",
"@SuppressWarnings(\"deprecation\")\n\torg.ogema.core.resourcemanager.ResourceListener getListener();",
"Move listen(IListener ll);",
"public TCPListener getMyTCPListener()\n {\n return fMyListener;\n }",
"public int listen() {\n\t\tcommlock.acquire();\n\n\t\tlistenersWaiting++;\n\t\tLib.debug(dbgCommunicator, \"Waiting Listeners \" + listenersWaiting);\n\t\tspeaker.wake();\n\t\tlistener.sleep();\n\n\t\tint word = sharedWord;\n\t\tsharedWordInUse = false;\n\t\tlistenersWaiting--;\n\t\tLib.debug(dbgCommunicator, \"Waiting Listeners \" + listenersWaiting);\n\n\t\tcommlock.release();\n\n\n\treturn word;\n }",
"public NumberCellGeneratorListener getListener() {\n return mListener;\n }",
"public boolean isListenerAvailable() {\n return mListener != null;\n }",
"public boolean isListenerAvailable() {\n return mListener != null;\n }",
"public boolean hasListener(int type) {\n assert type > 0 : \"Invalid event type: \" + type;\n\n Listeners listeners = lsnrs.get(type);\n\n return (listeners != null) && (!F.isEmpty(listeners.highPriorityLsnrs) || !F.isEmpty(listeners.lsnrs));\n }",
"static synchronized AbstractMMXListener getGlobalListener() {\n return sInstance.mGlobalListener;\n }",
"private ContactListener getListener(short categoryA, short categoryB)\n\t{\n\t\tObjectMap<Short, ContactListener> listenerCollection = listeners.get(categoryA);\n\t\tif (listenerCollection == null)\n\t\t{\n\t\t return null;\n\t\t}\n\t\treturn listenerCollection.get(categoryB);\n\t}",
"public ActivityListener getListener() {\n\t\treturn logger.getConfiguration().getActivityListener();\n\t}",
"public Optional<D> getNetworkEventListener();",
"public static ServerSocket getServerSocket(){\n if (listener == null) {\n listener = createServerSocket();\n }\n return listener;\n }",
"@Test\n public void testLogErrorListener()\n {\n assertEquals(\"No default error listener registered\", 1,\n new DefaultConfigurationBuilder().getErrorListeners().size());\n }",
"public ListenerRegistar getMiListener() {\n return miListenerReg;\n }",
"ListenerMethod getListenerMethod();",
"public int listen() {\n \tlock.acquire();\n \tif (status!= s_waitL) {\n \t\twaitingL++;\n \t\t//System.out.println(KThread.currentThread() + \" Listener slept, state = \" + status);\n \t\tcondListen.sleep();\n \t\t//System.out.println(KThread.currentThread() + \" Listener arrives\");\n \t\twaitingL--;\n \t}\n \telse ;//System.out.println(KThread.currentThread() + \" Listener arrives without sleep\");\n \t\n \t\n \t\n \tLib.assertTrue(status == s_waitL || status == s_waitLq);\n \t\n \t//System.out.println(KThread.currentThread() + \" Wake up a returner\");\n \t\n \tint ret = msg;\n \tcondRet.wake();\n \tstatus = s_waitR;\n \tlock.release();\n \treturn ret;\n }",
"private DefaultListener() {\n }",
"@Test\n public void testListen_int() throws Exception {\n System.out.println(\"listen\");\n int p = 4000;\n instance.listen(p);\n }",
"public int listen() {\n\t \n\t \n\tconditionLock.acquire();\n\t\t\n\t\tint aux=0;\n\t \n\t\twhile(listenerReady == true){\n\t\t\tcondLock.sleep();\n\t\t}\n\t\t//~ else{\n\t\t\tlistenerReady = true;\n\t\t\tcondLock.wakeAll();\n\t\t\t\n\t\t\taux = data;\n\t\t\n\t\twhile(speakerReady == false){\n\t\t\t\n\t\t\tcondLock.sleep();\n\t\t}\t\n\t\t\n\t\taux = data;\n\t\tspeakerReady = false;\n\t\tcondLock.wakeAll();\n\t\t\n\t\t//~ if(speakerReady){\n\t\t\t\t\n\t\t\t\t//~ aux = data;\n\t\t\t\t//~ speakerReady = false;\n\t\t\t\t\n\t\t\t\t//~ condLock.wakeAll();\n\t\t\t//~ }\n\t\t\t//~ else{\n\t\t\t\t//~ condLock.sleep();\n\t\t\t\t\n\t\t\t\t//~ aux = data;\n\t\t\t\t//~ speakerReady = false;\n\t\t\t\t//~ condLock.wakeAll();\n\t\t\t\t\n\t\t\t//~ }\n\t\t//~ }\n\t\n\t\n\tlistenerReady = false; \n\tconditionLock.release();\n\t \n\treturn aux;\n }",
"public interface Listener {}",
"public static GuidoLocationListener getReference(){\r\n\t\tif(instance == null)\r\n\t\t\tinstance = new GuidoLocationListener();\r\n\t\treturn instance;\r\n\t}",
"public int listen() {\n\t\tmutex.acquire();\n\t\twhile(message == null ) {\n\t\t\tspeakers.wake();\n\t\t\tlisteners.sleep();\n\t\t}\n\t\tint receivedWord = message.intValue();\n\t\tmessage = null;\n\t\tacknowledge.wake();\n\t\tmutex.release();\n\t\treturn receivedWord;\n\t}",
"public static boolean GetClientListenerStatus (){\n return ClientListenerAlive;\n }",
"protected static Listener testListenerClassValidity(Class<?> listenerClass) {\n Listener l = ReflectionUtil.getAnnotation(listenerClass, Listener.class);\n if (l == null)\n throw new IncorrectListenerException(String.format(\"Cache listener class %s must be annotated with org.infinispan.notifications.annotation.Listener\", listenerClass.getName()));\n return l;\n }",
"public synchronized boolean isEnabled() {\n \t\t\treturn listenerEnabled;\n \t\t}",
"public int getSize(){\r\n\t\treturn listeners.size();\r\n\t}",
"public CellListener getListener() {\n return listener;\n }",
"protected String getDefaultListenerMethod() {\n\t\treturn this.defaultListenerMethod;\n\t}",
"Integer listeningPort();",
"protected Integer getSourcePort(LoadBalancerListenerInfo listener) {\n return listener.getPrivatePort() != null ? listener.getPrivatePort() : listener.getSourcePort();\n }",
"@Override\n public BrokerMessageListener fetchByName(long companyId, String name)\n throws SystemException {\n return fetchByName(companyId, name, true);\n }",
"public interface GetPointsListener extends Listener {\n\n public void onGetPointsSucc(PointsInfo info);\n}",
"public E pollFirst();",
"public T pollFirst() {\n if (!isEmpty()) {\n T polled = (T) list[startIndex];\n startIndex++;\n if (isEmpty()) {\n startIndex = 0;\n nextindex = 0;\n }\n return polled;\n }\n return null;\n }",
"void setListener(Listener listener);",
"@Test\n public void testShouldNotDuplicateListeners() {\n manager.register(listener);\n manager.publishConnect(\"sessionId\");\n\n verify(listener, only()).onConnect(stringCaptor.capture());\n String id = stringCaptor.getValue();\n assertThat(id, is(equalTo(\"sessionId\")));\n }",
"IProductSelectorListener getM_pslListener();",
"public GameEvent getFirst();",
"public interface Listener {\n}",
"public interface Listener {\n}",
"public List<String> listeners();",
"@Override\n\tpublic void getListener(){\n\t}",
"@NonNull\n public HubEvent<?> awaitFirst() {\n // If the event list is empty, then wait.\n if (events.isEmpty()) {\n Latch.await(latch);\n }\n return events.isEmpty() ? null : events.get(0);\n }",
"public final int getPortListened() {\n return portListened;\n }",
"LateListenerNotifier()\r\n/* :17: */ {\r\n/* :18:858 */ this.l = l;\r\n/* :19: */ }",
"public QuadricRobustEstimatorListener getListener() {\n return mListener;\n }",
"public interface CallListener {\r\n void onCallTapListener(int position);\r\n}",
"public JmsRequestorListener getListener() {\n return listener;\n }",
"public ONDEXListener[] getONDEXListeners() {\n return listeners.toArray(new ONDEXListener[0]);\n }",
"public Listener(int max) {\r\n count = 0;\r\n maxCount = max;\r\n tweets = new LinkedList<Status>();\r\n }",
"public Call getCallById(Integer num) {\n return this.mCallMapById.get(num);\n }",
"private <T> ListenerList<T> getOrCreateListenerList(Class<T> target) {\n final ListenerList<T> existing = this.activeListeners.get(target);\n if (existing != null) {\n return existing;\n }\n synchronized (this.activeListenersWriteLock) {\n // Fetch the list again, as it could've been initialized since the lock was released.\n final ListenerList<T> list = this.activeListeners.get(target);\n if (list == null) {\n // Validate the event type, throwing an IllegalArgumentException if it is invalid\n Util.catchAndRethrow(() -> Events.validateEventType(target), IllegalArgumentException::new);\n\n final ListenerList<T> newList = this.listenerListFactory.create(target);\n\n // If insertion of a new key will require a rehash, then clone the map and reassign the field.\n if (this.activeListeners.needsRehash()) {\n final Event2ListenersMap newMap = this.activeListeners.clone();\n newMap.put(target, newList);\n this.activeListeners = newMap;\n } else {\n this.activeListeners.put(target, newList);\n }\n\n return newList;\n } else {\n return list;\n }\n }\n }",
"void removeListener(RosZeroconfListener listener);",
"@Test\n public void testLogErrorListener() throws ConfigurationException {\n final DatabaseConfiguration config = helper.setUpConfig();\n assertEquals(1, config.getEventListeners(ConfigurationErrorEvent.ANY).size());\n }",
"public static ILateralCacheListener getInstance( ILateralCacheAttributes ilca )\n {\n //throws IOException, NotBoundException\n ILateralCacheListener ins = ( ILateralCacheListener ) instances.get( ilca.getUdpMulticastAddr() + \":\" + ilca.getUdpMulticastPort() );\n if ( ins == null )\n {\n synchronized ( LateralGroupCacheUDPListener.class )\n {\n if ( ins == null )\n {\n ins = new LateralGroupCacheUDPListener( ilca );\n }\n if ( log.isDebugEnabled() )\n {\n log.debug( \"created new listener \" + ilca.getUdpMulticastAddr() + \":\" + ilca.getUdpMulticastPort() );\n }\n instances.put( ilca.getUdpMulticastAddr() + \":\" + ilca.getUdpMulticastPort(), ins );\n }\n }\n return ins;\n }",
"public void addEventListener(OneToOneChatListener listener) throws RcsServiceException {\n\t\tif (api != null) {\n\t\t\ttry {\n\t\t\t\tapi.addEventListener2(listener);\n\t\t\t} catch (Exception e) {\n\t\t\t\tthrow new RcsServiceException(e.getMessage());\n\t\t\t}\n\t\t} else {\n\t\t\tthrow new RcsServiceNotAvailableException();\n\t\t}\n\t}",
"public int addListener(Value listener) {\n\n IApplication adapter = new IApplication() {\n private boolean execute(Value jsObject, String memberName, Object... args) {\n if (jsObject == null)\n return true;\n Value member = jsObject.getMember(memberName);\n if (member == null) {\n return true;\n }\n Value result = plugin.executeInContext(member, app);\n return result != null && result.isBoolean() ? result.asBoolean() : true;\n }\n\n @Override\n public boolean appStart(IScope app) {\n return execute(listener, \"appStart\", app);\n }\n\n @Override\n public boolean appConnect(IConnection conn, Object[] params) {\n return execute(listener, \"appConnect\", conn, params);\n }\n\n @Override\n public boolean appJoin(IClient client, IScope app) {\n return execute(listener, \"appJoin\", client, app);\n }\n\n @Override\n public void appDisconnect(IConnection conn) {\n execute(listener, \"appDisconnect\", conn);\n }\n\n @Override\n public void appLeave(IClient client, IScope app) {\n execute(listener, \"appLeave\", client, app);\n }\n\n @Override\n public void appStop(IScope app) {\n execute(listener, \"appStop\", app);\n }\n\n @Override\n public boolean roomStart(IScope room) {\n return execute(listener, \"roomStart\", room);\n }\n\n @Override\n public boolean roomConnect(IConnection conn, Object[] params) {\n return execute(listener, \"roomConnect\", conn, params);\n }\n\n @Override\n public boolean roomJoin(IClient client, IScope room) {\n return execute(listener, \"roomJoin\", client, room);\n }\n\n @Override\n public void roomDisconnect(IConnection conn) {\n execute(listener, \"roomDisconnect\", conn);\n }\n\n @Override\n public void roomLeave(IClient client, IScope room) {\n execute(listener, \"roomLeave\", client, room);\n }\n\n @Override\n public void roomStop(IScope room) {\n execute(listener, \"roomStop\", room);\n }\n };\n this.app.addListener(adapter);\n this.listeners.add(adapter);\n return this.listeners.indexOf(adapter);\n }",
"public boolean contains(L listener) {\r\n synchronized (this) {\r\n return listeners.containsKey(listener) || weak.containsKey(listener);\r\n }\r\n }",
"@Override\r\n\tnative long createListenerProxy(EventSink eventSink);",
"void addListener(RosZeroconfListener listener);",
"public Conservable[] getListener() throws SQLException{\n return listener;\n }",
"@Override\n public BrokerMessageListener findByCompany_First(long companyId,\n OrderByComparator orderByComparator)\n throws NoSuchBrokerMessageListenerException, SystemException {\n BrokerMessageListener brokerMessageListener = fetchByCompany_First(companyId,\n orderByComparator);\n\n if (brokerMessageListener != null) {\n return brokerMessageListener;\n }\n\n StringBundler msg = new StringBundler(4);\n\n msg.append(_NO_SUCH_ENTITY_WITH_KEY);\n\n msg.append(\"companyId=\");\n msg.append(companyId);\n\n msg.append(StringPool.CLOSE_CURLY_BRACE);\n\n throw new NoSuchBrokerMessageListenerException(msg.toString());\n }",
"@Test\n public void testListenerIsNotified () {\n DelayedPrompter.Listener mockListener = mock(DelayedPrompter.Listener.class);\n Message mockMessage = mock(Message.class);\n Bundle mockBundle = mock(Bundle.class);\n when(mockMessage.getData()).thenReturn(mockBundle);\n when(mockBundle.getInt(DelayedPrompter.NUM_OF_ROWS_IN_LIST)).thenReturn(13);\n\n DelayedPrompter promptHandler = new DelayedPrompter(mockListener);\n\n promptHandler.handleMessage(mockMessage);\n\n verify(mockListener).listUpdated(13);\n }",
"public boolean hasListeners() {\n return !listeners.isEmpty();\n }",
"public boolean hasListeners() {\n return !listeners.isEmpty();\n }",
"public DefaultDeviceDiscovererListener()\r\n {\r\n }",
"public MyListener() {\r\n }",
"public static Sensor getFirstSensor() {\n\t\tSensor retVal = null;\n\t\tfor (int x = 0; x < mSensors.size(); x++) {\n\t\t\tif (mSensors.get(x).mEnabled) {\n\t\t\t\tretVal = mSensors.get(x);\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\n\t\treturn retVal;\n\t}",
"void removeListener(\n ReaderSettingsListenerType l);",
"public String addListener(ServiceListener listener) {\n return (orgConfigImpl.addListener(listener));\n }",
"@Async.Schedule\n public void listen(IgniteRunnable lsnr);",
"public void addListener(int userID, int epoch, int listenerPort, String listenerType, int listenerid) {\n\t\tListener e = new Listener(userID, epoch, listenerPort, listenerType, listenerid);\n\t\tlisteners.add(e);\n\t}",
"static //@Override\n\tpublic void addListener(final Listener listener) {\n\t\tif (null == stListeners) {\n\t\t\tstListeners = new LinkedList<>();\n\t\t}\n\t\tstListeners.add(listener);\n\t}",
"private void removeListener(int n) {\n Object object = this.mMapLock;\n synchronized (object) {\n this.mListenerMap.remove(n);\n this.mServiceMap.remove(n);\n return;\n }\n }",
"public static int choosePort() {\n try (ServerSocket s = new ServerSocket(0)) {\n return s.getLocalPort();\n } catch (IOException ex) {\n throw new DeltaException(\"Failed to find a port\");\n }\n }",
"boolean addConnectionListener(LWSConnectionListener lis);",
"public void addListener(Listener l) {\n if (!listeners.contains(l)) {\n listeners.add(l);\n }\n }",
"public boolean removeListener(ChipListener l) {\n return listeners.remove(l);\n }",
"public void maybeAdd(Object listener) {\n if (type.isInstance(listener)) {\n add(type.cast(listener));\n }\n }",
"public Builder listeningPort(final Optional<Integer> maybeListeningPort) {\n this.listeningPort = maybeListeningPort.filter(port -> port != 0);\n return this;\n }",
"@Override\r\n\t\tpublic ApplicationListener createApplicationListener() {\n\t\t\treturn new FishchickenGame();\r\n\t\t}",
"void removeListener(BotListener l);",
"private ChangeListener createMaxListener()\r\n\t\t{\r\n\t\treturn new ChangeListener()\r\n\t\t\t{\r\n\r\n\t\t\t//called when the max spinner value is changed\r\n\t\t\t@Override\r\n\t\t\tpublic void stateChanged(ChangeEvent e)\r\n\t\t\t\t{\r\n\t\t\t\tint spinMinValue = (int)spinMin.getValue();\r\n\t\t\t\tint spinMaxValue = (int)spinMax.getValue();\r\n\r\n\t\t\t\tif (spinMaxValue <= spinMinValue) { // verify if the max spin goes under the min limit and adjust the value if necessary\r\n\t\t\t\t\tif (--spinMinValue < min)\r\n\t\t\t\t\t\t{\r\n\t\t\t\t\t\t\tspinMax.setValue(spinMaxValue = (spinMinValue=min)+1);\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\tspinMin.setValue(spinMinValue);\r\n\t\t\t\t}\r\n\r\n\t\t\t\tif (spinMaxValue > spinMinValue) // verify intervals are correct\r\n\t\t\t\t\t{\r\n\t\t\t\t\tdiceBuilder.setInterval(spinMinValue, spinMaxValue);\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\r\n\t\t\t};\r\n\r\n\t\t}",
"private InterstitialViewListener getInterstitialViewListener() {\n return (InterstitialViewListener) WhiteBox.getInternalState(mInterstitialController, \"mInterstitialViewListener\");\n }"
]
| [
"0.62239",
"0.559228",
"0.5585708",
"0.5552114",
"0.5547311",
"0.54356056",
"0.5399513",
"0.53853977",
"0.5339",
"0.52325225",
"0.5047711",
"0.5008053",
"0.50008154",
"0.49564886",
"0.49514368",
"0.49290577",
"0.48733437",
"0.48400414",
"0.48249707",
"0.48168603",
"0.4727098",
"0.4727098",
"0.47221765",
"0.4692125",
"0.4674415",
"0.4628741",
"0.46002606",
"0.4595998",
"0.45923194",
"0.45779204",
"0.45739445",
"0.4573832",
"0.45543808",
"0.4542919",
"0.45235178",
"0.44837534",
"0.44834805",
"0.44802207",
"0.44740605",
"0.44674963",
"0.4458802",
"0.44289008",
"0.4427385",
"0.44201732",
"0.43835944",
"0.43723333",
"0.4349317",
"0.43479535",
"0.43463215",
"0.43424347",
"0.4341531",
"0.43326986",
"0.43222883",
"0.43214798",
"0.43144688",
"0.43144688",
"0.4300022",
"0.42958868",
"0.42883155",
"0.42802882",
"0.4276467",
"0.42760754",
"0.42756385",
"0.42714646",
"0.4268137",
"0.42662513",
"0.42661253",
"0.42571038",
"0.42527962",
"0.4243856",
"0.422713",
"0.4224556",
"0.4219235",
"0.42152035",
"0.42105138",
"0.4195328",
"0.41913128",
"0.41792673",
"0.41730747",
"0.4171363",
"0.4171363",
"0.4166303",
"0.41388994",
"0.41364464",
"0.41274747",
"0.4118071",
"0.41151044",
"0.4112558",
"0.41107157",
"0.41083026",
"0.41036102",
"0.4102552",
"0.4099813",
"0.40985537",
"0.40947965",
"0.4094014",
"0.4092758",
"0.40924898",
"0.40916693",
"0.40777808"
]
| 0.5746396 | 1 |
TODO Autogenerated method stub | public List<Entity> getListByPage(Integer pageNo, Integer pageSize) {
return entityDao.getListByPage(pageNo, pageSize);
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"@Override\r\n\tpublic void comer() \r\n\t{\n\t\t\r\n\t}",
"@Override\n\tpublic void comer() {\n\t\t\n\t}",
"@Override\n public void perish() {\n \n }",
"@Override\r\n\t\t\tpublic void annadir() {\n\r\n\t\t\t}",
"@Override\n\tpublic void anular() {\n\n\t}",
"@Override\n\tprotected void getExras() {\n\n\t}",
"@Override\r\n\tpublic void anularFact() {\n\t\t\r\n\t}",
"@Override\n\tpublic void entrenar() {\n\t\t\n\t}",
"@Override\n\tpublic void nadar() {\n\t\t\n\t}",
"@Override\r\n\tpublic void tires() {\n\t\t\r\n\t}",
"@Override\r\n\t\t\tpublic void ayuda() {\n\r\n\t\t\t}",
"@Override\n\tprotected void interr() {\n\t}",
"@Override\n\tpublic void emprestimo() {\n\n\t}",
"@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}",
"@Override\n\tpublic void grabar() {\n\t\t\n\t}",
"@Override\n\tpublic void gravarBd() {\n\t\t\n\t}",
"@Override\r\n\tpublic void rozmnozovat() {\n\t}",
"@Override\r\n\tpublic void dormir() {\n\t\t\r\n\t}",
"@Override\n protected void getExras() {\n }",
"@Override\r\n\tpublic void publierEnchere() {\n\t\t\r\n\t}",
"@Override\n\tpublic void nefesAl() {\n\n\t}",
"@Override\n\tpublic void ligar() {\n\t\t\n\t}",
"@Override\n public void func_104112_b() {\n \n }",
"@Override\n\tprotected void initdata() {\n\n\t}",
"@Override\n\tpublic void nghe() {\n\n\t}",
"@Override\n public void function()\n {\n }",
"@Override\n public void function()\n {\n }",
"public final void mo51373a() {\n }",
"@Override\r\n\tpublic void stehReagieren() {\r\n\t\t//\r\n\t}",
"@Override\n public void inizializza() {\n\n super.inizializza();\n }",
"@Override\n\tprotected void initData() {\n\t\t\n\t}",
"@Override\r\n\t\tpublic void init() {\n\t\t\t\r\n\t\t}",
"@Override\n\tpublic void sacrifier() {\n\t\t\n\t}",
"@Override\r\n\tprotected void InitData() {\n\t\t\r\n\t}",
"public void designBasement() {\n\t\t\r\n\t}",
"@Override\r\n\tprotected void initialize() {\r\n\t\t\r\n\t\t\r\n\t}",
"public void gored() {\n\t\t\n\t}",
"@Override\r\n\tprotected void initData() {\n\r\n\t}",
"@Override\n\tpublic void einkaufen() {\n\t}",
"@Override\n protected void initialize() {\n\n \n }",
"public void mo38117a() {\n }",
"@Override\n\tprotected void getData() {\n\t\t\n\t}",
"Constructor() {\r\n\t\t \r\n\t }",
"@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}",
"@Override\n\tpublic void one() {\n\t\t\n\t}",
"@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}",
"@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}",
"@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}",
"@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}",
"@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}",
"@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}",
"private stendhal() {\n\t}",
"@Override\n\tprotected void update() {\n\t\t\n\t}",
"@Override\n\t\t\tpublic void ic() {\n\t\t\t\t\n\t\t\t}",
"@Override\n\tprotected void initData() {\n\n\t}",
"@Override\n\tprotected void initData() {\n\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\t\t\n\t}",
"@Override\n public void init() {\n\n }",
"@Override\n\tprotected void initialize() {\n\t\t\n\t}",
"@Override\n\tprotected void initialize() {\n\t\t\n\t}",
"@Override\r\n\tpublic void init() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void init() {\n\t\t\r\n\t}",
"@Override\r\n\tpublic void init() {\n\t\t\r\n\t}",
"@Override\n\tpublic void debite() {\n\t\t\n\t}",
"@Override\r\n\tpublic void init() {\n\r\n\t}",
"@Override\r\n\tpublic void init() {\n\r\n\t}",
"@Override\r\n\tpublic void init() {\n\r\n\t}",
"public contrustor(){\r\n\t}",
"@Override\n\tprotected void initialize() {\n\n\t}",
"@Override\r\n\tpublic void dispase() {\n\r\n\t}",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"public void mo55254a() {\n }",
"@Override\n\tpublic void dtd() {\n\t\t\n\t}",
"@Override\n\tprotected void logic() {\n\n\t}",
"@Override\n\tprotected void lazyLoad() {\n\t\t\n\t}",
"public void mo4359a() {\n }",
"@Override\r\n\tprotected void initialize() {\n\r\n\t}",
"@Override\n public void memoria() {\n \n }",
"@Override\n\t\tpublic void method() {\n\t\t\t\n\t\t}",
"private RepositorioAtendimentoPublicoHBM() {\r\t}",
"@Override\n protected void initialize() \n {\n \n }",
"@Override\r\n\tpublic void getProposition() {\n\r\n\t}",
"@Override\n\tpublic void particular1() {\n\t\t\n\t}",
"@Override\n\tpublic void init() {\n\n\t}",
"@Override\n\tpublic void init() {\n\n\t}",
"@Override\n\tpublic void init() {\n\n\t}",
"@Override\n protected void prot() {\n }",
"@Override\r\n\tpublic void init()\r\n\t{\n\t}",
"@Override\n\tprotected void initValue()\n\t{\n\n\t}",
"public void mo55254a() {\n }"
]
| [
"0.6671074",
"0.6567672",
"0.6523024",
"0.6481211",
"0.6477082",
"0.64591026",
"0.64127725",
"0.63762105",
"0.6276059",
"0.6254286",
"0.623686",
"0.6223679",
"0.6201336",
"0.61950207",
"0.61950207",
"0.61922914",
"0.6186996",
"0.6173591",
"0.61327106",
"0.61285484",
"0.6080161",
"0.6077022",
"0.6041561",
"0.6024072",
"0.6020252",
"0.59984857",
"0.59672105",
"0.59672105",
"0.5965777",
"0.59485507",
"0.5940904",
"0.59239364",
"0.5910017",
"0.5902906",
"0.58946234",
"0.5886006",
"0.58839184",
"0.58691067",
"0.5857751",
"0.58503544",
"0.5847024",
"0.58239377",
"0.5810564",
"0.5810089",
"0.5806823",
"0.5806823",
"0.5800025",
"0.5792378",
"0.5792378",
"0.5792378",
"0.5792378",
"0.5792378",
"0.5792378",
"0.5790187",
"0.5789414",
"0.5787092",
"0.57844025",
"0.57844025",
"0.5774479",
"0.5774479",
"0.5774479",
"0.5774479",
"0.5774479",
"0.5761362",
"0.57596046",
"0.57596046",
"0.575025",
"0.575025",
"0.575025",
"0.5747959",
"0.57337177",
"0.57337177",
"0.57337177",
"0.5721452",
"0.5715831",
"0.57142824",
"0.57140535",
"0.57140535",
"0.57140535",
"0.57140535",
"0.57140535",
"0.57140535",
"0.57140535",
"0.5711723",
"0.57041645",
"0.56991017",
"0.5696783",
"0.56881124",
"0.56774884",
"0.56734604",
"0.56728",
"0.56696945",
"0.5661323",
"0.5657007",
"0.5655942",
"0.5655942",
"0.5655942",
"0.56549734",
"0.5654792",
"0.5652974",
"0.5650185"
]
| 0.0 | -1 |
creates the file if it doesn't exist | public static void CreateFile(){
try{
new File("wipimages").mkdir();
logscommissions.createNewFile();
}catch(Exception e){
e.printStackTrace();
System.out.println("CreateFile Failed\n");
}
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"void createFile()\n {\n //Check if file already exists\n try {\n File myObj = new File(\"src/main/java/ex45/exercise45_output.txt\");\n if (myObj.createNewFile()) {\n System.out.println(\"File created: \" + myObj.getName());// created\n } else {\n System.out.println(\"File already exists.\"); //exists\n }\n //Error check\n } catch (IOException e) {\n System.out.println(\"An error occurred.\");\n e.printStackTrace();\n }\n }",
"@SuppressWarnings(\"unused\")\r\n\tprivate static File createFile(String path) {\r\n\t\t\r\n\t\t// open the file\r\n\t\tFile currentFile = new File(path);\r\n\t\t\r\n\t\t\r\n\t\t// check if it is a valid file\r\n\t\tif (currentFile == null) {\r\n\t\t\tSystem.out.println(\"Could not create the file\");\r\n\t\t\tthrow new NullPointerException();\r\n\t\t}\r\n\r\n\t\t// hopefully things went perfect\r\n\t\treturn currentFile;\r\n\r\n\t}",
"public void createFile(File file) {\n\t\tif (file.exists())\n\t\t\treturn;\n\t\ttry {\n\t\t\tfile.createNewFile();\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public boolean create()\n\t{\n\t\ttry\n\t\t{\n\t\t\treturn file.createNewFile() ;\n\t\t}\n\t\tcatch( IOException ex )\n\t\t{\n\t\t\tex.printStackTrace() ;\n\t\t\treturn false ;\n\t\t}\n\t}",
"public void createFile(File file) throws IOException {\n if (!file.exists()) {\n file.createNewFile();\n }\n }",
"@Test\n public void CreateFile() throws Exception {\n createFile(\"src\\\\TestSuite\\\\SampleFiles\\\\supervisor.xlsx\",\n readTemplateXLSX(\"src\\\\TestSuite\\\\SampleFiles\\\\template_supervisor.xlsx\"));\n File file = new File(\"src\\\\TestSuite\\\\SampleFiles\\\\supervisor.xlsx\");\n Assert.assertTrue(file.exists());\n }",
"@Override\n public File createFile(String path) throws IOException {\n String pathStr=path+fileSeparator+\"Mail.json\";\n File file = new File(pathStr);\n file.createNewFile();\n return file;\n }",
"public boolean create() {\n boolean operation = false;\n try {\n File file = new File( fileName );\n file.createNewFile();\n\n if ( this.open() == false ) {\n throw new Exception(\"File created but still has issues opening the file\");\n } else {\n writeFirstLine(\"\");\n }\n\n operation = true;\n } catch( Exception error ) {\n System.out.println(error.toString());\n operation = false;\n }\n\n return operation;\n }",
"@SuppressWarnings(\"ResultOfMethodCallIgnored\")\r\n private static void fileExists(String filepath) throws IOException {\r\n File file = new File(filepath + filePath);\r\n if (!file.exists()) {\r\n file.createNewFile();\r\n }\r\n }",
"public static boolean createFile() throws IOException {\n String bytes = \"\";\n byte[] write = bytes.getBytes(); //Salva i bytes della stringa nel byte array\n if(!fileName.exists()){\n Path filePath = Paths.get(fileName.toString()); //Converte il percorso in stringa\n Files.write(filePath, write); // Creare il File\n Main.log(\"File \\\"parametri\\\" creato con successo in \" + fileName.toString());\n return true;\n }\n return false;\n }",
"private void createCatalogFileIfNoneExists(){\n\t\t\n\t\tinOut = new IOUtility();\n\t\t\n\t\tif (inOut.checkLocalCache()) {\n\t\t\tcatalog = inOut.readCatalogFromFile();\n\t\t}\n\n\t\telse {\n\n\t\t\ttry {\n\t\t\t\tinOut.createCatalogFile();\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(e.getMessage());\n\t\t\t} \n\t\t}\n\t\t\n\t}",
"public void createFile(String fname) {\n\t\tprintMsg(\"running createFiles() in \\\"\" + this.getClass().getName() + \"\\\" class.\");\n\t\t\n\t\t// Check if the scratch directory exists, create it if it doesn't\n\t\tPath rootpath = Paths.get(theRootPath);\n\t\tcreateScratchDirectory(rootpath);\n\n\t\t// Check if the file name is null or empty, if it is, use default name\n\t\tPath filepath = null;\n\t\tif(fname == null || fname.isEmpty()) {\n\t\t\tfilepath = Paths.get(rootpath + System.getProperty(\"file.separator\") + theFilename);\n\t\t} else {\n\t\t\tfilepath = Paths.get(rootpath + System.getProperty(\"file.separator\") + fname);\n\t\t}\n\t\t\n\t\t// Create file\n\t\ttry {\n\t\t\t// If file exists already, don't override it.\n\t\t\tif(!Files.exists(filepath)) {\n\t\t\t\tFiles.createFile(filepath);\n\t\t\t}\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public static void existeFichero(){\n File fichero = new File(\"config.ser\");\n\n try{\n\n if (fichero.exists()) {\n recuperarFecha();\n }\n else {\n fichero.createNewFile();\n }\n }catch(IOException ex){\n System.out.println(\"Excepcion al crear el fichero: \" + ex);\n }\n\n }",
"public static void CreateFile (String filename) {\r\n\t\t try {\r\n\t\t File myObj = new File(filename + \".txt\");\r\n\t\t if (myObj.createNewFile()) {\r\n\t\t System.out.println(\"File created: \" + myObj.getName());\r\n\t\t } else {\r\n\t\t System.out.println(\"File already exists.\");\r\n\t\t }\r\n\t\t } catch (IOException e) {\r\n\t\t System.out.println(\"An error occurred.\");\r\n\t\t e.printStackTrace();\r\n\t\t }\r\n\t\t }",
"private static void createSaveDirIfNotExisting() {\n\t\tFile dir = new File(\"save\");\n\t\tif (!dir.exists()) {\n\t\t\t// directory does not exist => create!\n\t\t\tdir.mkdir();\n\t\t}\n\t}",
"public static void main(String[] args) {\n\t\tFile file = new File(\"test/a.txt\");\r\n\t\tFileUtil.createFile(file);\r\n\t\t/*if(! file.exists()){\r\n\t\t\ttry {\r\n\t\t\t\tSystem.out.println(file.getAbsolutePath());\r\n\t\t\t\tfile.createNewFile();\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t\te.printStackTrace();\r\n\t\t\t}\r\n\t\t}\r\n\t\t*/\r\n\t}",
"public boolean createFile() {\n String filename = name + \".ics\";\n String directory = \"Calendar-Files\";\n String userHome = System.getProperty(\"user.home\") + \"/Desktop/\";\n System.out.println(\"Generating Event File...\");\n \n try {\n File folder = new File(userHome, directory);\n\n // if no folder exists, create it\n if (!folder.exists()) {\n folder.mkdir();\n }\n\n // change file location\n File file = new File(userHome + \"/\" + directory, filename);\n\n // if no file exists, create it\n if (!file.exists()) {\n file.createNewFile();\n }\n\n // write the content string to the event file\n FileWriter fw = new FileWriter(file.getAbsoluteFile());\n BufferedWriter bw = new BufferedWriter(fw);\n bw.write(createContent());\n bw.close();\n }\n catch (IOException e) {\n return false;\n }\n return true;\n }",
"public static void createFile(File source) {\n try {\n if (!source.createNewFile()) {\n throw new IOException();\n }\n } catch (IOException e) {\n throw new RuntimeException(\"Failed to create file: \" + source.getAbsolutePath(), e);\n }\n }",
"private void createFile() {\n if (mDriveServiceHelper != null) {\n Log.d(\"error\", \"Creating a file.\");\n\n mDriveServiceHelper.createFile()\n .addOnSuccessListener(fileId -> readFile(fileId))\n .addOnFailureListener(exception ->\n Log.e(\"error\", \"Couldn't create file.\", exception));\n }\n }",
"public void createFile (String filePath){\n try{\n File newFile = new File(filePath);\n if(newFile.createNewFile()){\n System.out.println(\"File created: \"+newFile.getName());\n } else {\n System.out.println(\"File already exists.\");\n }\n } catch (IOException e) {\n System.out.println(\"An error occurred.\");\n e.printStackTrace();\n }\n }",
"private static void checkHistoryDirectory()\n throws FileNotFoundException {\n Path path = Paths.get(HISTORY_FILE_PATH); //creates Path instance\n try {\n Files.createDirectories(Paths.get(DIRECTORY));\n Files.createFile(path); //creates file at specified location\n } catch (IOException e) {\n readHistoryData();\n }\n }",
"private void createFile(PonsFileFactory ponsFileFactory, Profile profile){\n moveX(profile);\n ponsFileFactory.setProfile(profile);\n String text = ponsFileFactory.createPonsFile();\n String profileName = profile.getName();\n WriteFile.write(text,pathTextField.getText() + \"/\" + profileName.substring(0,profileName.indexOf(\".\")));\n }",
"private static void checkFilePath(String filePath) {\n File file = new File(filePath);\n try {\n if (!file.getParentFile().exists()) {\n file.getParentFile().mkdirs();\n }\n if (!file.exists()) {\n file.createNewFile();\n }\n file.createNewFile();\n } catch (IOException e) {\n System.err.println(e.getMessage());\n }\n }",
"private static void isFileExistOrCreatIt(String fileName) {\n if (!fileName.endsWith(\".json\")){\n throw new IllegalArgumentException(\"Invalid file name\");\n }\n File file = new File(\"src//main//resources\"+\"//\"+fileName);\n if(!file.exists()){\n try{\n file.createNewFile();\n }catch (IOException e){\n e.printStackTrace();\n }\n\n }\n }",
"@Override\n public synchronized boolean create(Path file)\n {\n File f = file.toFile(root);\n if (file.isRoot()) {\n return false;\n }\n File parent = file.parent().toFile(root);\n parent.mkdirs();\n\n try {\n return f.createNewFile();\n } catch (IOException e) {\n \te.printStackTrace();\n return false;\n }\n }",
"public boolean createNewFile(File file) throws IOException {\n if (\"/probes/.ready\".equals(file.getPath())) {\n return true;\n }\n return file.createNewFile();\n }",
"int createFile(String pFileNamePath, String pContent, String pPath, String pRoot, boolean pOverride) throws RemoteException;",
"@SuppressWarnings(\"TailRecursion\")\n // As long as the specified path does not contain files with names matching a random UUID value,\n // recursive calls should not happen.\n private static File createFileUnderPath(Path path) {\n var fileName = UUID.randomUUID().toString();\n var result = new File(path.toFile(), fileName);\n if (result.exists()) {\n return createFileUnderPath(path);\n }\n try {\n result.createNewFile();\n return result;\n } catch (IOException e) {\n throw Exceptions.newIllegalStateException(e,\n \"Could not create a temporary file in %s.\",\n path.toAbsolutePath());\n }\n }",
"private void createFile(String fileName, String content) throws IOException {\n File file = new File(fileName);\n if (!file.exists()) {\n file.createNewFile();\n }\n FileWriter fileWriter = new FileWriter(fileName, false);\n fileWriter.append(content);\n fileWriter.close();\n }",
"private static void createTestFile(String path) throws IOException {\n\t\tFile file = new File(path);\n\t\tFileWriter writer = new FileWriter(file);\n\t\twriter.write(\"Jenkins Test : \"+new Date() + \" ==> Writing : \" + Math.random());\n\t\twriter.flush();\n\t\twriter.close();\n\t}",
"public void testCreateFileSuccess() throws Exception {\r\n assertNotNull(\"setup fails\", filePersistence);\r\n String fileCreationId = filePersistence.createFile(VALID_FILELOCATION, FILENAME);\r\n assertTrue(\"fileCreationId shouldn't be null or empty\", fileCreationId != null\r\n && fileCreationId.trim().length() != 0);\r\n filePersistence.closeFile(fileCreationId);\r\n filePersistence.deleteFile(VALID_FILELOCATION, FILENAME);\r\n }",
"public static File createPlayerFile(){\n try {\n playerFile = new File(System.getProperty(\"user.dir\") + \"/PlayerFiles/\" + \".txt\"); //creates player file, can it run on android?\n playerFile.createNewFile();\n }catch (IOException e){\n e.printStackTrace();\n }\n finally {\n return playerFile;\n }\n }",
"private File loadFile() throws IOException {\r\n File file = new File(filePath);\r\n if (!file.exists()) {\r\n File dir = new File(fileDirectory);\r\n dir.mkdir();\r\n File newFile = new File(filePath);\r\n newFile.createNewFile();\r\n return newFile;\r\n } else {\r\n return file;\r\n }\r\n }",
"private File createDestinationFile() {\n\t\tSystem.out.print(\"Please enter the name of the output file that will be created to hold the modified/correct inventory: \");\n\t\tString fileName = sc.nextLine();\n\t\tFile file = new File(fileName);\n\t\twhile (file.exists()) {\n\t\t\tSystem.out.println(\"----->A file with the name of \\\"\" + fileName + \"\\\" [size = \" + file.length() + \" bytes; path = \" + file.getAbsolutePath() + \"] already exists.<-----\");\n\t\t\tSystem.out.print(\"Please input a new file name: \");\n\t\t\tfileName = sc.nextLine();\n\t\t\tfile = new File(fileName);\n\t\t}\n\t\treturn file;\n\t}",
"public String createFile(String name) {\t\t\n\t\tString filename = this.path + name;\n\t\tFile file = new File(filename);\n\t\t\n\t\ttry {\n\t\t\tif (file.createNewFile()) {\n\t\t System.out.println(\"Created file '\" + filename + \"'.\");\n\t\t \n\t\t // Add file to files list\n\t\t\t\tthis.files.add(name);\t\n\t\t\t\t\n\t\t } else {\n\t\t \t// Null filename to report it was NOT created\n\t\t\t\tfilename = null;\n\t\t System.out.println(\"ERROR - File name already exists!\");\n\t\t }\n\t\t} catch(IOException e) {\n\t\t\t// Null filename to report it was NOT created\n\t\t\tfilename = null;\n\t\t e.printStackTrace();\n\t\t}\t\t\n\t\t\n\t\treturn filename;\n\t}",
"private void createFile(String outputData, File file) {\n try {\n FileWriter writer = new FileWriter(file);\n writer.write(outputData);\n writer.close();\n } catch (IOException e) {\n e.getSuppressed();\n }\n }",
"@Override\n protected void createFile(String directoryName, String fileNamePrefix) {\n }",
"@Override\n public String createFile(String date, String todaysDate) throws FlooringMasteryPersistenceException{\n \n return \"You are in Training mode, cannot create file\";\n }",
"@Test\n public void createFile(){\n try\n {\n URI uri = new URI(\"http://www.yu.edu/documents/doc390\");//given the complete uri\n String path = uri.getAuthority() + this.disectURI(uri);//get the Path which is www.yu.edu\\documents\n File file = new File(baseDir.getAbsolutePath() + File.separator + path);//make a File with the full class path and with the \"URI Path\"\n Files.createDirectories(file.toPath());//create the directories we didn't have before, ie not apart of the baseDir\n\n File theFile = new File(file.getAbsolutePath() + File.separator + \"doc390.txt\");//create a new File with the document as the last piece\n //wrap in a try because if the file is already there than we don't need to create a file\n if(!theFile.exists())Files.createFile(theFile.toPath());//create this file in the computer\n\n //write to the file -- in the real application this is the writing of the json\n FileWriter fileWriter = new FileWriter(theFile);\n fileWriter.write(\"HaYom sishi BShabbos\");\n fileWriter.flush();\n fileWriter.close();\n\n }\n catch(Exception e){\n e.printStackTrace();\n }\n }",
"public static void createNewFile(File file) {\n\t\ttry {\n\t\t\tfile.createNewFile();\n\t\t} catch (Exception exp) {\n\t\t\tthrow new RuntimeException(exp);\n\t\t}\n\t}",
"private File createDirectoryIfNotExisting( String dirName ) throws HarvesterIOException\n {\n \tFile path = FileHandler.getFile( dirName );\n \tif ( !path.exists() )\n \t{\n \t log.info( String.format( \"Creating directory: %s\", dirName ) );\n \t // create path:\n \t if ( !path.mkdir() )\n \t {\n \t\tString errMsg = String.format( \"Could not create necessary directory: %s\", dirName );\n \t\tlog.error( errMsg );\n \t\tthrow new HarvesterIOException( errMsg );\n \t }\n \t}\n \t\n \treturn path;\n }",
"public static void createFile(String name)\n {\n file = new File(name);\n try\n {\n if(file.exists())\n {\n file.delete();\n file.createNewFile();\n }else file.createNewFile();\n \n fileWriter = new FileWriter(file);\n fileWriter.append(\"Generation, \");\n fileWriter.append(\"Fitness, \");\n fileWriter.append(\"Average\\n\");\n \n }catch (IOException e) \n {\n System.out.println(e);\n }\n \n }",
"public static void insurePathToFileExists(File f) {\r\n File p = f.getParentFile();\r\n //System.out.println(\"uu.iPE: parent of \"+filename+\" is \"+parent);\r\n\r\n if (!p.exists()) {\r\n // parent doesn't exist, create it:\r\n if (!p.mkdirs()) {\r\n throw new IllegalStateException(\"Unable to make directory \" + p.getPath());\r\n } // endif -- second mkdir unsuc\r\n } // endif -- parent exists\r\n }",
"public File createFile(final String path) {\n return new com.good.gd.file.File(path);\n }",
"public static boolean createFile(String filePath)\n\t{\n\t\tFile file = new File(filePath);\n\t\tfile.mkdirs();\n\t\ttry\n\t\t{\n\t\t\treturn file.createNewFile();\n\t\t} catch (IOException e)\n\t\t{\n\t\t}\n\t\treturn false;\n\t}",
"public static void main(String[] args) {\n\n\t\tFile fi = new File(\"C:/test_io\");\n\t\tif(fi.exists()) {\n\t\t\t\n\t\t\tSystem.out.println(\"exists!\");\n\t\t}else {\n\t\t\tSystem.out.println(\"new\");\n\t\t\tfi.mkdir();\n\t\t}\n\t\t\n\t\tFile fic1 = new File(fi, \"AA\");\n\t\tfic1.mkdir();\n\t\t\n\t\tFile fic2 = new File(\"C:/test_io\", \"BB\");\n\t\tfic2.mkdir();\n\t\t\n\t\tFile fitxt = new File(fic1,\"a.txt\");\n\t\t\n\t\ttry {//checked exception\n\t\t\tfitxt.createNewFile();\n\t\t} catch (IOException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public void createDir(File file) {\n if (!file.exists()) {\n file.mkdir();\n }\n }",
"private static void prepareSaveFile(String filename) {\n\t\tFile f = new File(filename);\n\t\tif(!f.exists()) {\n\t\t\ttry {\n\t\t\t\tf.createNewFile();\n\t\t\t} catch (IOException e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t}\n\t}",
"private void createScheduleFile() {\n try {\n File scheduleFile = new File(filePath, \"schedule.txt\");\n// FileWriter fw = new FileWriter(scheduleFile);\n\n OutputStreamWriter osw = new OutputStreamWriter(new FileOutputStream(scheduleFile), StandardCharsets.UTF_8);\n osw.write(\"SCHEDULE:\\n\" + schedule);\n osw.close();\n\n System.out.println(\"schedule.txt successfully created.\");\n\n } catch (IOException e) {\n e.printStackTrace();\n }\n }",
"public void createDir(File file){\n\t\tif (!file.exists()) {\n\t\t\tif (file.mkdir()) {\n\t\t\t\tlogger.debug(\"Directory is created!\");\n\t\t\t} else {\n\t\t\t\tlogger.debug(\"Failed to create directory!\");\n\t\t\t}\n\t\t}\n\t}",
"static void initContacts(){\n String directory = \"contacts\";\n String filename = \"contacts.txt\";\n Path contactsDirectory= Paths.get(directory);\n Path contactsFile = Paths.get(directory, filename);\n try {\n if (Files.notExists(contactsDirectory)) {\n Files.createDirectories((contactsDirectory));\n System.out.println(\"Created directory\");\n }\n if (!Files.exists(contactsFile)) {\n Files.createFile(contactsFile);\n System.out.println(\"Created file\");\n }\n } catch(IOException ioe){\n ioe.printStackTrace();\n }\n }",
"public static boolean createFileIfNotExists(String path, SourceType sourceType) throws IOException {\n return getFileSystemBySourceType(sourceType).createNewFile(new Path(path));\n }",
"public void crearPrimerFichero(){\n File f=new File(getApplicationContext().getFilesDir(),\"datos.json\");\n // si no existe lo creo\n if(!f.exists()) {\n String filename = \"datos.json\";\n String fileContents = \"[]\";\n FileOutputStream outputStream;\n\n try {\n outputStream = openFileOutput(filename, Context.MODE_PRIVATE);\n outputStream.write(fileContents.getBytes());\n outputStream.close();\n } catch (Exception e) {\n e.printStackTrace();\n }\n }\n\n }",
"public void ifFileExistsAndCreate() {\n DbHelper dbHelper = new DbHelper(context);\n File file = new File(directory_path);\n if (!file.exists()) {\n file.mkdirs();\n }\n SQLiteToExcel sqliteToExcel2 = new SQLiteToExcel(context, dbHelper.getDatabaseName(), directory_path);\n sqliteToExcel2.exportAllTables(fileName, new SQLiteToExcel.ExportListener() {\n\n @Override\n public void onStart() {\n Log.d(\"start\", \"Started Exported\");\n\n }\n\n @Override\n public void onCompleted(String filePath) {\n Log.d(\"succesfully\", \"Successfully Exported\");\n }\n\n @Override\n public void onError(Exception e) {\n Log.d(\"error\", e.getMessage());\n\n }\n });\n }",
"private void createFileHierarchie() throws IOException {\r\n\t\tlog.debug(\"START: SBIWebServer.createFileHierarchie\");\r\n\t\t// Create logs directory if not exist\r\n\t\tPath logPath = Paths.get(DEFAULT_LOG_LOCATION);\r\n\t\tif (!Files.exists(logPath)) {\r\n\t\t\tFiles.createDirectory(Paths.get(DEFAULT_LOG_LOCATION));\r\n\t\t\tlog.debug(\"Directory \"+DEFAULT_LOG_LOCATION+\" created\");\r\n\t\t}else {\r\n\t\t\tlog.debug(\"Directory \"+DEFAULT_LOG_LOCATION+\" already exists\");\r\n\t\t}\r\n\t\t\r\n\t\t// Create default server.xml\r\n\t\tPath serverConfigPath = Paths.get(CONFIG_SERVER_LOCATION);\r\n\t\tif (!Files.exists(serverConfigPath)) {\r\n\t\t\tXmlServerConfig xml = ConfigurationFactory.createDefaultXmlServerConfig();\r\n\t\t\ttry {\r\n\t\t\t\tXmlHelper.storeXml(xml, new File(CONFIG_SERVER_LOCATION));\r\n\t\t\t\tlog.debug(\"File \"+CONFIG_SERVER_LOCATION+\" created\");\r\n\t\t\t} catch (JAXBException e) {\r\n\t\t\t\tlog.error(\"Cannot store \"+CONFIG_SERVER_LOCATION,e);\r\n\t\t\t}\r\n\t\t}else {\r\n\t\t\tlog.debug(\"File \"+CONFIG_SERVER_LOCATION+\" already exists\");\r\n\t\t}\r\n\t\tlog.debug(\"END: SBIWebServer.createFileHierarchie\");\r\n\t}",
"static void createNewFile(String path) \n\t\t{\n\t\tLinkedList<String> defaultData = new LinkedList<String>();\n\t\tdefaultData.add(\"1,Frank,West,98,95,87,78,77,80\");\n\t\tdefaultData.add(\"2,Dianne,Greene,78,94,88,87,95,92\");\n\t\tdefaultData.add(\"3,Doug,Lei,78,94,88,87,95,92\");\n\t\tdefaultData.add(\"4,James,Hewlett,69,92,74,77,89,91\");\n\t\tdefaultData.add(\"5,Aroha,Wright,97,92,87,83,82,92\");\n\t\t\n\t\ttry \n\t\t{\n\t\t\tPrintWriter newFile = new PrintWriter(path, \"UTF-8\"); // Create .txt file in given path\n\t\t\t\n\t\t\tfor (String s : defaultData) \n\t\t\t{\n\t\t\t\tnewFile.println(s); // Write To file\n\t\t\t}\n\t\t\t\n\t\t\tnewFile.close(); // Close File\n\t\t\t\n\t\t} catch (FileNotFoundException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (UnsupportedEncodingException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t\tSystem.out.println(\"studentData.txt Created Successfully!\");\n\t\t\n\t}",
"public void createFiles() {\r\n try {\r\n FileWriter file = new FileWriter(registerNumber + \".txt\");\r\n file.write(\"Name : \" + name + \"\\n\");\r\n file.write(\"Surname : \" + surname + \"\\n\");\r\n file.write(\"Registration Number : \" + registerNumber + \"\\n\");\r\n file.write(\"Position : \" + position + \"\\n\");\r\n file.write(\"Year of Start : \" + yearOfStart + \"\\n\");\r\n file.write(\"Total Salary : \" + Math.round(totalSalary) + \".00 TL\" +\"\\n\");\r\n file.close();\r\n }\r\n catch(IOException e) {\r\n e.printStackTrace();\r\n }\r\n }",
"private FSDataOutputStream createNewFile() throws Exception {\n\t\tlogger.traceEntry();\n\t\tPath newFile = new Path(rootDirectory, \"dim_\" + System.currentTimeMillis() + \".json\");\n\t\tlogger.debug(\"Creating file \" + newFile.getName());\n\t\tFSDataOutputStream dataOutputStream = null;\n\n\t\tif (!hadoopFileSystem.exists(newFile)) {\n\t\t\tdataOutputStream = hadoopFileSystem.create(newFile);\n\t\t} else {\n\t\t\tdataOutputStream = hadoopFileSystem.append(newFile);\n\t\t}\n\n\t\tdataOutputStreams.clear();\n\t\tdataOutputStreams.add(dataOutputStream);\n\t\tlogger.traceExit();\n\t\treturn dataOutputStream;\n\t}",
"public static void main(String[] args) {\n\t\ttry {\n\t\t\tFile f = new File(\"data/testfile.dat\");\n\t\t\tboolean b = f.createNewFile();\n\t\t\t\n\t\t\tif (b){\n\t\t\t\tSystem.out.println(\"File created!\");\n\t\t\t}\n\t\t\telse {\n\t\t\t\tSystem.out.println(\"Already exists\");\n\t\t\t}\n\t\t\n\t\t}\n\t\tcatch (IOException e){\n\t\t\tSystem.out.println(\"Exception occured\");\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t}",
"public static void createSaveFile( )\n {\n try\n {\n new File( \"data\" ).mkdirs( );\n PrintWriter writer = new PrintWriter( \"data/\" + Game.instance.getCurrentSaveFile( ).SAVEFILENAME + \".txt\", \"UTF-8\" );\n writer.println( \"dkeys: \" + Game.START_DIAMOND_KEY_COUNT );\n writer.close( );\n }\n catch ( IOException e )\n {\n e.printStackTrace( );\n System.exit( 1 );\n }\n }",
"private static void createFile(String fileType) throws Exception {\n DateTimeFormatter dtf = DateTimeFormatter.ofPattern(\"yyyy-MM-dd-HH-mm-ss\");\n LocalDateTime now = LocalDateTime.now();\n File xmlFile = new File(System.getProperty(\"user.dir\")+\"/data/saved/\"+dtf.format(now) + fileType + \".xml\");\n OutputFormat out = new OutputFormat();\n out.setIndent(5);\n FileOutputStream fos = new FileOutputStream(xmlFile);\n XML11Serializer serializer = new XML11Serializer(fos, out);\n serializer.serialize(xmlDoc);\n\n }",
"public static void makeNewFile(File root, String name) {\n File directory = new File(root, name);\n try {\n if (!directory.createNewFile()) {\n throw new IOException(\"Could not create \" + name + \", file already exists\");\n }\n } catch (IOException e) {\n throw new UncheckedIOException(\"Failed to create file: \" + name, e);\n }\n }",
"public File generateFile()\r\n {\r\n return generateFile(null);\r\n }",
"public final static void createNullFile(String nFile) {\r\n File file = new File(nFile);\r\n try {\r\n if (!file.exists())\r\n file.createNewFile();\r\n }\r\n catch (IOException ex) {\r\n }\r\n }",
"private void ensureFile(File destFile) {\n\t\tif (destFile.exists()) {\n\t\t\tLog.i(\"[\" + destFile.getName() + \"]\"\n\t\t\t\t\t+ \" has already exsited, previous content cleared\");\n\t\t}\n\n\t\ttry {\n\t\t\tdestFile.createNewFile();\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public static void checkTextFile(String dir){\n java.nio.file.Path checkFilePath = java.nio.file.Paths.get(dir+\"/data/duke.txt\");\n boolean fileExists = java.nio.file.Files.exists(checkFilePath);\n //text file not exists, create one\n if(!fileExists) {\n try {\n File dukeFile = new File(dir+\"/data/duke.txt\");\n dukeFile.createNewFile();\n } catch (IOException e) {\n System.out.println(\"An error occurred while creating file.\");\n e.printStackTrace();\n }\n }\n }",
"public void createFile() throws IOException {\n String newName = input.getText();\n File user = new File(\"SaveData\\\\UserData\\\\\" + newName + \".txt\");\n\n if (user.exists() && !user.isDirectory()) {\n input.setStyle(\"-fx-border-color: red\");\n }\n if (user.exists() && !user.isDirectory() || newName.isEmpty()) {\n input.setStyle(\"-fx-border-color: red\");\n ERROR_AUDIO.play(Double.parseDouble(getInitData().get(\"SFXVol\")));\n\n }\n else {\n input.setStyle(\"-fx-border-color: default\");\n playerList.getItems().addAll(newName);\n PrintWriter newUser = new PrintWriter(new FileWriter(\"SaveData\\\\UserData\\\\\" + newName + \".txt\"));\n newUser.write(\"0 0 0 0 icon0 car\");\n newUser.close();\n MAIN_MENU_AUDIO.play(Double.parseDouble(getInitData().get(\"SFXVol\")));\n }\n }",
"public static File fileFromPathOrCreate(String path) throws IOException {\n File propFile = new File(path);\n if (!propFile.exists()) {\n propFile.createNewFile();\n }\n return propFile;\n }",
"public void createStorageFile() throws IoDukeException {\n PrintWriter writer = null;\n try {\n writer = getStorageFile();\n } catch (IOException e) {\n throw new IoDukeException(\"Error opening task file for reading\");\n } finally {\n if (writer != null) {\n writer.close();\n }\n }\n }",
"public void createDirectory() {\r\n\t\tpath = env.getProperty(\"resources\") + \"/\" + Year.now().getValue() + \"/\";\r\n\t\tFile file = new File(path);\r\n\t\tif (!file.exists())\r\n\t\t\tfile.mkdirs();\r\n\t}",
"public static void createOrOpenUsersFile() {\n try {\r\n File usersFile = new File(\"users.txt\");\r\n if (usersFile.createNewFile()) {\r\n System.out.println(\"\\nFile \" + usersFile.getName() + \" has been created.\");\r\n } else {\r\n System.out.println(\"\\nFile \" + usersFile.getName() + \" is ready.\");\r\n }\r\n } catch (IOException e) {\r\n System.out.println(\"An error occurred.\");\r\n e.printStackTrace();\r\n }\r\n }",
"File createFile(String name) throws IOException {\n File storageFile = File.createTempFile(FILE_PREFIX + name + \"_\", null, this.subDirectories[fileCounter.getAndIncrement()&(this.subDirectories.length-1)]); //$NON-NLS-1$\n if (LogManager.isMessageToBeRecorded(org.teiid.logging.LogConstants.CTX_BUFFER_MGR, MessageLevel.DETAIL)) {\n LogManager.logDetail(org.teiid.logging.LogConstants.CTX_BUFFER_MGR, \"Created temporary storage area file \" + storageFile.getAbsoluteFile()); //$NON-NLS-1$\n }\n return storageFile;\n }",
"public static void createFile(String path) {\n try {\n Scanner scanner = new Scanner(System.in);\n System.out.println(\"Enter the file name :\");\n String filepath = path+\"/\"+scanner.next();\n File newFile = new File(filepath);\n newFile.createNewFile();\n System.out.println(\"File is Created Successfully\");\n\n } catch (Exception ex) {\n System.out.println(ex.getMessage());\n }\n }",
"public void createNoteBookFile(NoteBook myNoteBook) throws DaoException {\n\t\tFile notebookFile = new File(FILE_NAME);\n\t\tif (notebookFile.exists()) {\n\t\t\tnotebookFile.delete();\n\t\t}\n\t\ttry {\n\t\t\tnotebookFile.createNewFile();\n\t\t} catch (IOException e) {\n\t\t\tthrow new DaoException(\"Create NoteBook file error\", e);\n\t\t}\n\t}",
"@Nullable\n private static File generateFile(Context context, @NonNull String fileName) {\n File file = null;\n if (isExternalStorageAvailable()) {\n// String path = Environment.getExternalStorageDirectory().getAbsolutePath()+\"/showlog\";\n\n String path = context.getExternalFilesDir(Environment.DIRECTORY_DOCUMENTS).getAbsolutePath()+\"/showlog\";\n Log.d(\"ZINGLOGSHOW\", path);\n File root = new File(path);\n\n boolean dirExists = true;\n\n if (!root.exists()) {\n dirExists = root.mkdirs();\n }\n\n if (dirExists) {\n file = new File(root, fileName);\n }\n }\n return file;\n }",
"private static File safeOpenFile() throws IOException {\n\t\tPath path = Paths.get(PropertyUtil.getConfigPath() + \"/config\");\n\n\t\tif (!Files.exists(path)) {\n\t\t\tFiles.createDirectories(path.getParent());\n\t\t\tFiles.createFile(path);\n\t\t\tlogger.debug(\"Creating {}\", path.toAbsolutePath());\n\t\t}\n\n\t\treturn path.toFile();\n\t}",
"private void createConfig() {\n try {\n if (!getDataFolder().exists()) {\n getDataFolder().mkdirs();\n }\n File file = new File(getDataFolder(), \"config.yml\");\n if (!file.exists()) {\n getLogger().info(\"config.yml not found :( Creating one with default values...\");\n saveDefaultConfig();\n } else {\n getLogger().info(\"config.yml found :) Loading...\");\n }\n } catch (Exception e) {\n e.printStackTrace();\n\n }\n\n }",
"private void createDirectory(String path) throws IOException {\n\t\tfinal Path p = Paths.get(path);\n\t\tif (!fileExists(p)) {\n\t\t\tFiles.createDirectory(p);\n\t\t}\n\t}",
"public static void createFile(String file) throws FileNotFoundException {\n\t\tif(!file.contains(\".txt\")) {\n\t\t\tthrow new IllegalArgumentException(\"Wrong format\"); \n\t\t}\n\t\tPrintWriter pw = new PrintWriter(file);\n\t\tpw.close();\n\n\t}",
"@Override\n public StorageOutputStream create(File file) throws IOException {\n\treturn null;\n }",
"private File createNewFile(String prefix){\n if(prefix==null || \"\".equalsIgnoreCase(prefix)){\n prefix=\"IMG_\";\n }\n File newDirectory = new File(Environment.getExternalStorageDirectory()+\"/mypics/\");\n if(!newDirectory.exists()){\n if(newDirectory.mkdir()){\n Log.d(mContex.getClass().getName(), newDirectory.getAbsolutePath()+\" directory created\");\n }\n }\n File file = new File(newDirectory,(prefix+ System.currentTimeMillis()+\".jpg\"));\n if(file.exists()){\n //this wont be executed\n file.delete();\n try {\n file.createNewFile();\n } catch (IOException e) {\n e.printStackTrace();\n }\n }\n\n return file;\n }",
"public void createPatient() throws IOException\n {\n addPatientToList();\n \n //creates the patient's empty folders and files\n File userFolder = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB); \n File patientEvaluation = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm\");\n File patientProgressReports = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/ProgressNotes\"); \n \n try\n \t{\n \tuserFolder.mkdir();\n patientEvaluation.mkdir();\n patientProgressReports.mkdir();\n \t//result = true;\n \t} \n \tcatch(SecurityException se)\n \t{\n \t//handle it\n \t} \n \t\n File listOfProgressReports = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/ProgressReports.txt\");\n FileWriter writer = new FileWriter(listOfProgressReports, true);\t \n BufferedWriter bufferedreader = new BufferedWriter(writer);\n writer.append(\"\");\n bufferedreader.close();\n writer.close();\n \n \n /*if(result) \n \t{ \n \t\tSystem.out.println(\"DIR created\"); \n \t}*/\n \n //creates the patient's empty evaluation form files\n File signedStatus = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/signed.txt\");\n FileWriter w = new FileWriter(signedStatus, true);\t \n BufferedWriter b = new BufferedWriter(w);\n w.append(\"false\");\n b.close();\n w.close();\n \n File firstName = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/first.txt\");\n FileWriter writ = new FileWriter(firstName, true);\t \n BufferedWriter bw = new BufferedWriter(writ);\n writ.append(currentPatientFirstName);\n bw.close();\n writ.close();\n \n File lastName = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/last.txt\");\n FileWriter writ1 = new FileWriter(lastName, true);\t \n BufferedWriter bw1 = new BufferedWriter(writ1);\n writ1.append(currentPatientLastName);\n bw1.close();\n writ1.close();\n \n File age = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/age.txt\");\n FileWriter writ2 = new FileWriter(age, true);\t \n BufferedWriter bw2 = new BufferedWriter(writ2);\n writ2.append(\"\");\n bw2.close();\n writ2.close();\n \n File dob = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/dateofbirth.txt\");\n FileWriter writ3 = new FileWriter(dob, true);\t \n BufferedWriter bw3 = new BufferedWriter(writ3);\n writ3.append(\"\");\n bw3.close();\n writ3.close();\n \n File maritalstatus = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/maritalstatus.txt\");\n FileWriter writ4 = new FileWriter(maritalstatus, true);\t \n BufferedWriter bw4 = new BufferedWriter(writ4);\n writ4.append(\"\");\n bw4.close();\n writ4.close();\n \n File ethnicity = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/ethnicity.txt\");\n FileWriter writ5 = new FileWriter(ethnicity, true);\t \n BufferedWriter bw5 = new BufferedWriter(writ5);\n writ5.append(\"\");\n bw5.close();\n writ5.close();\n\n File ethnicityother = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/ethnicity-other.txt\");\n FileWriter writt = new FileWriter(ethnicityother, true);\t \n BufferedWriter bww = new BufferedWriter(writt);\n writt.append(\"\");\n bww.close();\n writt.close();\n \n File sex = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/sex.txt\");\n FileWriter writ6 = new FileWriter(sex, true);\t \n BufferedWriter bw6 = new BufferedWriter(writ6);\n writ6.append(\"\");\n bw6.close();\n writ6.close();\n \n File referredBy = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/referredby.txt\");\n FileWriter writ7 = new FileWriter(referredBy, true);\t \n BufferedWriter bw7 = new BufferedWriter(writ7);\n writ7.append(\"\");\n bw7.close();\n writ7.close();\n \n File referredByTherapist = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/referredby-therapist.txt\");\n FileWriter writ8 = new FileWriter(referredByTherapist, true);\t \n BufferedWriter bw8 = new BufferedWriter(writ8);\n writ8.append(\"\");\n bw8.close();\n writ8.close();\n \n File referredByOther = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/referredby-other.txt\");\n FileWriter writ9 = new FileWriter(referredByOther, true);\t \n BufferedWriter bw9 = new BufferedWriter(writ9);\n writ9.append(\"\");\n bw9.close();\n writ9.close();\n \n //dr. prince\n File reasonForReferral = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/reasonforreferral.txt\");\n FileWriter writ10 = new FileWriter(reasonForReferral, true);\t \n BufferedWriter bw10 = new BufferedWriter(writ10);\n writ10.append(\"\");\n bw10.close();\n writ10.close();\n \n File sourceOfInformation = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/sourceofinformation.txt\");\n FileWriter writ11 = new FileWriter(sourceOfInformation, true);\t \n BufferedWriter bw11 = new BufferedWriter(writ11);\n writ11.append(\"\");\n bw11.close();\n writ11.close();\n \n File sourceOfInformationOther = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/sourceofinformation-other.txt\");\n FileWriter writ12 = new FileWriter(sourceOfInformationOther, true);\t \n BufferedWriter bw12 = new BufferedWriter(writ12);\n writ12.append(\"\");\n bw12.close();\n writ12.close();\n \n File reliabilityOfInformation = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/reliabilityofinformation.txt\");\n FileWriter writ13 = new FileWriter(reliabilityOfInformation, true);\t \n BufferedWriter bw13 = new BufferedWriter(writ13);\n writ13.append(\"\");\n bw13.close();\n writ13.close();\n \n File reliabilityOfInformationOther = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/reliabilityofinformation-other.txt\");\n FileWriter writ14 = new FileWriter(reliabilityOfInformationOther, true);\t \n BufferedWriter bw14 = new BufferedWriter(writ14);\n writ14.append(\"\");\n bw14.close();\n writ14.close();\n \n File historyOfPresentIllness = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/historyofpresentillness.txt\");\n FileWriter writ15 = new FileWriter(historyOfPresentIllness, true);\t \n BufferedWriter bw15 = new BufferedWriter(writ15);\n writ15.append(\"\");\n bw15.close();\n writ15.close();\n \n File signsSymptoms = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/signsandsymptoms.txt\");\n FileWriter writ16 = new FileWriter(signsSymptoms, true);\t \n BufferedWriter bw16 = new BufferedWriter(writ16);\n writ16.append(\"\");\n bw16.close();\n writ16.close();\n \n File currentMedications = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/currentmedications.txt\");\n FileWriter writ17 = new FileWriter(currentMedications, true);\t \n BufferedWriter bw17 = new BufferedWriter(writ17);\n writ17.append(\"\");\n bw17.close();\n writ17.close();\n \n File pastHistoryOf = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/pasthistoryof.txt\");\n FileWriter writ18 = new FileWriter(pastHistoryOf, true);\t \n BufferedWriter bw18 = new BufferedWriter(writ18);\n writ18.append(\"\");\n bw18.close();\n writ18.close();\n \n File pastHistoryOfText = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/pasthistoryoftext.txt\");\n FileWriter writ19 = new FileWriter(pastHistoryOfText, true);\t \n BufferedWriter bw19 = new BufferedWriter(writ19);\n writ19.append(\"\");\n bw19.close();\n writ19.close();\n \n File medicationTrialsTable = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/medicationtrialstable.txt\");\n FileWriter writ20 = new FileWriter(medicationTrialsTable, true);\t \n BufferedWriter bw20 = new BufferedWriter(writ20);\n writ20.append(\"\");\n bw20.close();\n writ20.close();\n \n File medicationTrialsComments = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/medicationtrialscomments.txt\");\n FileWriter writ21 = new FileWriter(medicationTrialsComments, true);\t \n BufferedWriter bw21 = new BufferedWriter(writ21);\n writ21.append(\"\");\n bw21.close();\n writ21.close();\n \n File substanceUseHistory = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/substanceusehistory.txt\");\n FileWriter writ22 = new FileWriter(substanceUseHistory, true);\t \n BufferedWriter bw22 = new BufferedWriter(writ22);\n writ22.append(\"\");\n bw22.close();\n writ22.close();\n \n File deniesHistoryOf = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/denieshistoryof.txt\");\n FileWriter writ23 = new FileWriter(deniesHistoryOf, true);\t \n BufferedWriter bw23 = new BufferedWriter(writ23);\n writ23.append(\"\");\n bw23.close();\n writ23.close();\n \n File deniesHistoryOfText = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/denieshistoryoftext.txt\");\n FileWriter writ24 = new FileWriter(deniesHistoryOfText, true);\t \n BufferedWriter bw24 = new BufferedWriter(writ24);\n writ24.append(\"\");\n bw24.close();\n writ24.close();\n \n File socialHistoryText = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/socialhistorytext.txt\");\n FileWriter writ25 = new FileWriter(socialHistoryText, true);\t \n BufferedWriter bw25 = new BufferedWriter(writ25);\n writ25.append(\"\");\n bw25.close();\n writ25.close();\n \n File socialHistoryParents = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/socialhistoryparents.txt\");\n FileWriter writ26 = new FileWriter(socialHistoryParents, true);\t \n BufferedWriter bw26 = new BufferedWriter(writ26);\n writ26.append(\"\");\n bw26.close();\n writ26.close();\n \n File socialHistorySiblings = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/socialhistorysiblings.txt\");\n FileWriter writ27 = new FileWriter(socialHistorySiblings, true);\t \n BufferedWriter bw27 = new BufferedWriter(writ27);\n writ27.append(\"\");\n bw27.close();\n writ27.close();\n \n File socialHistoryChildren = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/socialhistorychildren.txt\");\n FileWriter writ28 = new FileWriter(socialHistoryChildren, true);\t \n BufferedWriter bw28 = new BufferedWriter(writ28);\n writ28.append(\"\");\n bw28.close();\n writ28.close();\n \n File familyHistoryOfMentalIllness = new File(installationPath + \"/userdata/\" + currentPatientFirstName + currentPatientLastName + currentPatientDOB + \"/EvaluationForm/familyhistoryofmentalillness.txt\");\n FileWriter writ29 = new FileWriter(familyHistoryOfMentalIllness, true);\t \n BufferedWriter bw29 = new BufferedWriter(writ29);\n writ29.append(\"\");\n bw29.close();\n writ29.close();\n \n }",
"private File createEmptyDirectory() throws IOException {\n File emptyDirectory = findNonExistentDirectory();\n if (emptyDirectory.mkdir() == false) {\n throw new IOException(\"Can't create \" + emptyDirectory);\n }\n\n return emptyDirectory;\n }",
"public boolean createFiles(String filename) {\n\t\t\t// Create files in SD card for location recording\n\t\t\tFile sdDir = new File(\"/sdcard/\");\n\t\t\tif(sdDir.exists() && sdDir.canWrite()) {\n\t\t\t\tFile sensiDir = new File(sdDir.getAbsolutePath()+\"/sensiloc/\");\n\t\t\t\tif(sensiDir.isDirectory()) {\n\t\t\t\t\t// Delete old files if exist\n\t\t\t\t\t/*for(File f:sensiDir.listFiles()) {\n\t\t\t\t\t\tf.delete();\n\t\t\t\t\t}*/\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t\telse sensiDir.mkdir();\n\t\t\t\t// Create files and assign corresponding file handler\n\t\t\t\tif(sensiDir.exists() && sensiDir.canWrite()) {\n\t\t\t\t\t\n\t\t\t\t/*\tfp = new File(sensiDir.getAbsoluteFile()+((curMethod == LocateMethod.LOCATE_GPS) ? \"/GPS_Record.txt\" :\n\t\t\t\t\t\t(curMethod == LocateMethod.LOCATE_NETWORK) ? \"/Network_Record.txt\" : \"/Adapt_Record.txt\") );*/\n\t\t\t\t\tfp = new File(sensiDir.getAbsoluteFile() + \"/\" + filename);\n\t\t\t\t\tif(fp.exists()) {\n\t\t\t\t\t\t// Delete existing file\n\t\t\t\t\t\tfp.delete();\n\t\t\t\t\t}\n\t\t\t\t\ttry {\n\t\t\t\t\t\tfp.createNewFile();\n\t\t\t\t\t\t// Record start battery level\n\t\t\t\t\t\tIntentFilter ifilter = new IntentFilter(Intent.ACTION_BATTERY_CHANGED);\n\t\t\t\t\t\tIntent battery = getApplicationContext().registerReceiver(null, ifilter);\n\t\t\t\t\t\tint startLevel = battery.getIntExtra(BatteryManager.EXTRA_LEVEL, -1);\n\t\t\t\t\t\tint scale = battery.getIntExtra(BatteryManager.EXTRA_SCALE, -1);\n\t\t\t\t\t\tfw = new FileWriter(fp, true);\n\t\t\t\t\t\tfw.append(String.format(\"Battery Level: %d: %d\\n\", startLevel, scale));\n\t\t\t\t\t\tfw.flush();\n\t\t\t\t\t\t\n\t\t\t\t\t}catch(IOException e) {\n\t\t\t\t\t\tLog.e(LOG_TAG, \"Error creating files under \"+sensiDir.getPath(), e);\n\t\t\t\t\t\treturn false;\n\t\t\t\t\t} \n\n\t\t\t\t} else { // sensiDir.exists()\n\t\t\t\t\tLog.e(LOG_TAG, \"unable to write to /sdcard/sensiloc/\");\n\t\t\t\t\treturn false;\n\t\t\t\t}\n\t\t\t} else { // sdDir.exists\n\t\t\t\tLog.e(LOG_TAG, \"/sdcard not available\");\n\t\t\t\treturn false;\n\t\t\t}\n\t\t\treturn true;\n\t\t}",
"public void checkIfXslCreated() {\n final File extStore = Environment.getExternalStorageDirectory();\n File myFile = new File(extStore.getAbsolutePath() + \"/backup/\" + fileName);\n\n if (myFile.exists()) {\n Log.d(\"YES\", \"YES\");\n } else {\n Log.d(\"NO\", \"NO\");\n }\n }",
"private static boolean isValidCreate(String pFilePath) {\n\t\tassert pFilePath != null;\n\t\tFile f = new File(pFilePath);\n\t\treturn f.exists();\n\t}",
"public static void createFile(String fileString) {\n\t\tPath filePath = Paths.get(fileString);\n\t\t// this will only happen if the file is not there\n\t\tif (Files.notExists(filePath)) {\n\t\t\ttry {\n\t\t\t\tFiles.createFile(filePath);\n\t\t\t\tSystem.out.println(\"Your file was cerated successfully\");\n\t\t\t} catch (IOException e) {\n\t\t\t\tSystem.out.println(\"Something went wrong with file creation \");\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t}\n\t}",
"private static void addFile(File filedir) throws Exception {\n String fileName = getFileNameInput();\n File newFile = new File(filedir.toString() + \"\\\\\" + fileName);\n boolean fileAlreadyExists = newFile.exists();\n if (fileAlreadyExists) {\n throw new FileAlreadyExistsException(\"File already exists in current directory.\");\n } else {\n try {\n if (newFile.createNewFile()) {\n System.out.println(\"File created successfully\");\n } else {\n System.out.println(\"Something went wrong, please try again.\");\n }\n } catch (IOException e) {\n throw new IOException(e.getMessage());\n }\n }\n }",
"public static File createFile(String filename){\n try {\n File outputFile = new File(filename + \".csv\");\n\n //Prevent File Overwrite\n int tmp = 1;\n while (outputFile.exists()){\n outputFile = new File(filename + \".csv\" + \".\" + tmp);\n tmp++;\n }\n\n //Creates File\n outputFile.createNewFile();\n\n return outputFile;\n\n } catch (IOException ex) {\n Logger.getLogger(CSVWriter.class.getName()).log(Level.SEVERE, null, ex);\n return null;\n }\n }",
"private void createFile() {\n if (mDriveServiceHelper != null) {\n Log.d(TAG, \"Creating a file.\");\n\n mDriveServiceHelper.createFile()\n .addOnSuccessListener(new OnSuccessListener<Void>() {\n @Override\n public void onSuccess(Void aVoid) {\n //progressDialog.setProgress(100);\n progressDialog.dismiss();\n Toast.makeText(MainActivity.this, \"Download Successful\", Toast.LENGTH_SHORT).show();\n }\n })\n .addOnFailureListener(exception ->\n Log.e(TAG, \"Couldn't Create file.\", exception));}\n }",
"private void checkIfLocationExists() {\n try {\n File file = new File(saveLocation);\n if(!file.exists()) file.mkdirs();\n } catch (Exception e) {\n log.error(e.getMessage(), e);\n }\n }",
"public abstract T create(T file, boolean doPersist) throws IOException;",
"@TaskAction\n public void create() {\n dir.mkdirs();\n getChmod().chmod(dir, dirMode);\n }",
"public static File createFile(String fileName) {\n\t\tif (fileName == null || fileName.matches(\"\") { System.out.println(\"Utils|createFile|fileName is null or empty\"); return null; }\n\t\tFile file = new File(fileName);\n\t\tfile.mkdirs();\n\t\treturn file;\n\t}",
"private void CreateNewFile() {\n\tcheckState();\n\t\n\tif (CanR=CanW=true)\n\t{\n\t\t\n\t\ttry {\n\t\t root = Environment.getExternalStorageDirectory();\n\t\t \n\t\t if (root.canWrite()){\n\t\t gpxfile = new File(root, \"Speed_SD.csv\");\n\t\t gpxwriter = new FileWriter(gpxfile,true);\n\t\t out = new BufferedWriter(gpxwriter);\nout.append(\"\"+\",\"+\"\"+\",\"+\"\");\n\t\t out.newLine();\n\t\t }\n\t\t} catch (IOException e) {\n\t\t //Log.e(, \"Could not write file \" + e.getMessage());\ne.printStackTrace();\n\t\t\n\t}\n\t\t\n}\n\t\t}",
"public static void createOrOpenTasksFile() {\n try {\r\n File tasksFile = new File(\"tasks.txt\");\r\n if (tasksFile.createNewFile()) {\r\n System.out.println(\"\\nFiles \" + tasksFile.getName() + \" has been created.\");\r\n } else {\r\n System.out.println(\"\\nFile \" + tasksFile.getName() + \" is ready.\");\r\n }\r\n } catch (IOException e) {\r\n System.out.println(\"An error occurred.\");\r\n e.printStackTrace();\r\n }\r\n }",
"protected void createHMetisInFilePath() {\n\t\tString file = \"\";\n\t\tfile += this.getRuntimeEnv().getOptionValue(PTArgString.OUTPUTDIR);\n\t\tfile += Utils.getFileSeparator();\n\t\tfile += \"TEMP_GRAPH_FILE.hgr\";\n\t\tthis.setHMetisInFile(file);\n\t}",
"public GridFSInputFile createFile(File f) throws IOException {\n\treturn createFile(new FileInputStream(f), f.getName(), true);\n }",
"private File createNewRotationFile(String clearName, String extension, Path parent){\n\n Path newPath = getPathRotationFile(clearName, lastCountRotation+1, extension, parent);\n try{\n File ret = Files.createFile(newPath).toFile();\n return ret;\n } catch (IOException ex){\n System.out.println(\"Ошибка в создании файла: \"+ex.getMessage());\n }\n System.out.println(\"Ошибка в создании файла: \"+newPath);\n return file;\n }",
"static void createNew() \r\n\t {\n boolean flag = false;\r\n Scanner file = new Scanner(System.in);\r\n System.out.println(\"Enter a new file name\");\r\n String newfilename = file.next();\r\n File createfile = new File(\"D:\\\\java_project\\\\\"+newfilename+\".txt\");\r\n try\r\n\t\t {\r\n\t\t flag = createfile.createNewFile();\r\n\t\t System.out.println(\"flag value\" + flag);\r\n\t\t if(!flag)\r\n\t\t {\r\n\t\t \t System.out.println(\"Same file name already exisy\" + createfile.getPath());\r\n\t\t } \r\n\t\t else \r\n\t\t {\r\n\t\t \t System.out.println(\"file is created sucessfully\" + createfile.getPath() + \" created \");\r\n\t\t }\r\n\t\t } \r\n\t\t catch (IOException ioe) \r\n\t\t {\r\n\t\t System.out.println(\"Error while Creating File in Java\" + ioe);\r\n\t\t }\r\n\t\t \r\n\t\t \t }"
]
| [
"0.76564926",
"0.7128559",
"0.69889045",
"0.69790363",
"0.6956708",
"0.6933596",
"0.68425816",
"0.68113685",
"0.67658925",
"0.6763985",
"0.6689998",
"0.6623557",
"0.6616276",
"0.6586332",
"0.65784615",
"0.6572005",
"0.656463",
"0.654466",
"0.65237004",
"0.6483298",
"0.64315",
"0.64243335",
"0.64234585",
"0.6408115",
"0.6392021",
"0.63291675",
"0.6328155",
"0.6324254",
"0.6286011",
"0.62723416",
"0.6236848",
"0.6235211",
"0.623178",
"0.62120277",
"0.62057924",
"0.62056",
"0.6199893",
"0.6180432",
"0.6164038",
"0.61617893",
"0.615466",
"0.6120548",
"0.61126286",
"0.6112141",
"0.61092645",
"0.6093961",
"0.6083815",
"0.60808283",
"0.60762846",
"0.6070763",
"0.6060709",
"0.60431087",
"0.6027998",
"0.60126865",
"0.60047024",
"0.6003008",
"0.59984744",
"0.5995392",
"0.59935683",
"0.59882903",
"0.5988004",
"0.59862804",
"0.59765655",
"0.5969018",
"0.5968696",
"0.5960532",
"0.5950705",
"0.59410954",
"0.5933587",
"0.5913571",
"0.59054303",
"0.59039783",
"0.5890255",
"0.5888093",
"0.588527",
"0.5878045",
"0.5874711",
"0.5871713",
"0.58688515",
"0.58686846",
"0.58682096",
"0.58674663",
"0.5857524",
"0.5855159",
"0.5855121",
"0.58519864",
"0.5850275",
"0.58396745",
"0.5835213",
"0.58327025",
"0.5832146",
"0.5821384",
"0.5807989",
"0.5796667",
"0.5772691",
"0.5756685",
"0.573323",
"0.5722434",
"0.5716155",
"0.5712523"
]
| 0.68405724 | 7 |
writes the last entry in ManageCommissionerList.comms to the file | public static void WriteFile(){
String[] linha;
FileWriter writer;
try{
writer = new FileWriter(logscommissions, true);
PrintWriter printer = new PrintWriter(writer);
linha = ManageCommissionerList.ReturnsCommissionerListInString(ManageCommissionerList.comms.size()-1);
for(int i=0;i<19;i++){
printer.append(linha[i]+ "\n");
}
printer.close();
}catch(Exception e){
e.printStackTrace();
System.out.println("Unable to read file\n");
}
try{
Commissions temp = ManageCommissionerList.comms.get(ManageCommissionerList.comms.size()-1);
BufferedImage img = temp.GetWipImage();
File fl = new File("wipimages/wip" + temp.GetCommissionTitle() + temp.GetUniqueID() + ".jpg");
ImageIO.write(img, "jpg", fl);
}catch (Exception e){
e.printStackTrace();
System.out.printf("Failure to write image file");
}
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"static void writeFile(){\n try{\n Path contactsListPath = Paths.get(\"contacts\",\"contacts.txt\");\n Files.write(contactsListPath, contactList);\n } catch(IOException ioe){\n ioe.printStackTrace();\n }\n //refreshes list of Contact objs\n fileToContactObjs();\n }",
"public void write_adm_file()\n \t{\n \t\ttry \n \t\t{\n \t\t\tFile f1 = new File(\"adm1.txt\");\n \t\t\tFileOutputStream fileOut = new FileOutputStream(f1); \n \t\t\tAppendingObjectOutputStream objectOut = new AppendingObjectOutputStream(new ObjectOutputStream(fileOut));//used to append in the output stream\n Node<Admin> pos=adm_list.getFirst();\n while(pos!=null)\n {\n \tobjectOut.writeObject(pos.getData());//traversing the whole linked list data and writing into the stream\n \tpos=pos.getNext();\n }\n objectOut.flush();//flushing the stream\n objectOut.close();//closing streams\n fileOut.close();\n \t\t} \n \t\tcatch (IOException ex) \n \t\t{\n \n \t\t}\n }",
"public void saveComm() throws Exception {\n JFileChooser chooser = new JFileChooser();\n chooser.setFileFilter(new FileNameExtensionFilter(\"Log-Datei (*.log)\", \"log\"));\n\n File comfile = null;\n File home;\n File folder;\n Date date = Calendar.getInstance().getTime();\n DateFormat df = new SimpleDateFormat(\"yy.MM.dd-HH.mm.ss.SSS\");\n\n try {\n home = new File(System.getProperty(\"user.home\"));\n } catch (Exception e) {\n home = null;\n }\n\n if (home != null && home.exists()) {\n folder = new File(home + File.separator + \"Bike-Files\" + File.separator + \"Service_Files\");\n if (!folder.exists()) {\n if (!folder.mkdir()) {\n throw new Exception(\"Internal Error\");\n }\n }\n comfile = new File(folder + File.separator + \"CommLog_\" + df.format(date) + \".log\");\n }\n\n chooser.setSelectedFile(comfile);\n\n int rv = chooser.showSaveDialog(this);\n if (rv == JFileChooser.APPROVE_OPTION) {\n comfile = chooser.getSelectedFile();\n\n try (BufferedWriter w = new BufferedWriter(new FileWriter(comfile))) {\n CommunicationLogger.getInstance().writeFile(w);\n } catch (Exception ex) {\n LOG.severe(ex);\n }\n }\n }",
"private void saveInFile() {\n\t\tthis.deleteFile();\n\t\tfor (CounterModel obj : counterListModel.getCounterList()) {\n\t\t\ttry {\n\t\t\t\tGson gson = new Gson();\n\t\t\t\tif (obj.getCounterName().equals(counterModel.getCounterName())) {\n\t\t\t\t\tobj = counterModel;\n\t\t\t\t}\n\t\t\t\tString json = gson.toJson(obj) +'\\n';\n\t\t\t\tFileOutputStream fos = openFileOutput(FILENAME,\n\t\t\t\t\t\tContext.MODE_APPEND);\n\t\t\t\tfos.write(json.getBytes());\n\t\t\t\tfos.close();\n\t\t\t} catch (FileNotFoundException e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t} catch (IOException e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t}\n\t}",
"public void writeToServiceFile()\r\n {\r\n\ttry(ObjectOutputStream toServiceFile = \r\n new ObjectOutputStream(new FileOutputStream(\"listfiles/servicelist.dta\")))\r\n\t{\r\n toServiceFile.writeObject(serviceList);\r\n\t}\r\n\tcatch(NotSerializableException nse)\r\n\t{\r\n JOptionPane.showMessageDialog(null, \"Service objektene er ikke \"\r\n + \"serialiserbare.\\nIngen registrering på fil!\"\r\n + nse.getMessage(), \"Feilmelding\", \r\n JOptionPane.ERROR_MESSAGE);\r\n\t}\r\n\tcatch(IOException ioe)\r\n\t{\r\n JOptionPane.showMessageDialog(null, \"Det oppsto en feil ved skriving \"\r\n + \"til fil.\\n\" + ioe.getMessage());\r\n\t}\r\n }",
"public static void writeNewCSV(Calendar cal) {\n\n try {\n\n BufferedWriter bw = null;\n\n String fileString = \"P5Calendar.csv\";\n String fileLine = \"\";\n\n FileWriter fw = new FileWriter(fileString, true);\n bw = new BufferedWriter(fw);\n\n ArrayList<Activity> activities = cal.getActivities();\n\n int lastElement = activities.size();\n Activity activity = activities.get(lastElement - 1);\n bw.write(activity.Year + \",\" + activity.Month + \",\" + activity.Name + \",\" + activity.Roles.name + \" \" + \"(\"\n + activity.Roles.subRole + \")\" + \"\\n\");\n\n bw.close();\n\n } catch (IOException e) {\n\n e.printStackTrace();\n\n }\n }",
"public void closeFile()\n {\n ArrayList<String> jobs = new ArrayList<String>();\n ArrayList<String> jobRecruiters = new ArrayList<String>();\n ArrayList<String> jobSeekers = new ArrayList<String>();\n ArrayList<String> notifications = new ArrayList<String>();\n for (Job job : jobList)\n {\n String jobinfo = job.getJobRecruiterUsername() + \"///\" + job.getTitle() + \"///\" + job.getDescription() + \"/// \" + job.getSalary();\n jobinfo = jobinfo + \"///\" + job.getLocation() + \"///\";\n for (String cate: job.getCategory())\n {\n jobinfo = jobinfo + cate + \",\";\n }\n jobinfo = jobinfo.substring(0,jobinfo.length()-1) + \"///\";\n for (String seek : job.getJobSeekerUsername())\n {\n jobinfo = jobinfo + seek + \",\";\n }\n jobinfo = jobinfo.substring(0,jobinfo.length()-1);\n jobs.add(jobinfo);\n }\n writeFile(\"Job.txt\", jobs);\n for (JobRecruiter recruiter : jobRecruiterList)\n {\n String recinfo = recruiter.getName() + \",\" + recruiter.getUserName() + \",\" + recruiter.getRole() + \",\" + recruiter.getGender() + \",\";\n recinfo = recinfo + recruiter.getEmail() + \",\" + recruiter.getPassword() + \",\" + recruiter.getCompanyName() + \",\" + recruiter.getLocation();\n jobRecruiters.add(recinfo);\n }\n writeFile(\"JobRecruiter.txt\", jobRecruiters);\n for (JobSeeker seeker : jobSeekerList)\n {\n String seekinfo = seeker.getName() + \",\" + seeker.getUserName() + \",\" + seeker.getRole() + \",\" + seeker.getGender() + \",\";\n seekinfo = seekinfo + seeker.getEmail() + \",\" + seeker.getPassword() + \",\";\n for(String skill : seeker.getSkillsets())\n {\n seekinfo = seekinfo + skill + \",\";\n }\n seekinfo = seekinfo.substring(0,seekinfo.length()-1);\n String notinfo = seeker.getUserName() + \"///\";\n for (String noti : seeker.getNotification())\n {\n notinfo = notinfo + noti + \",\";\n }\n notinfo = notinfo.substring(0,notinfo.length()-1);\n jobSeekers.add(seekinfo);\n notifications.add(notinfo);\n }\n writeFile(\"JobSeeker.txt\", jobSeekers);\n writeFile(\"Notification.txt\", notifications);\n }",
"static void recordProcess() {\n try {\n PrintWriter output = new PrintWriter(new FileWriter(file, true));\n output.print(huLuWaList.size() + \" \");\n lock.lock();\n for (Creature creature : huLuWaList) {\n output.print(creature.getCreatureName() + \" \" + creature.getX() + \" \" + creature.getY()+\" \");\n }\n output.print(enemyList.size() + \" \");\n for (Creature creature : enemyList) {\n output.print(creature.getCreatureName() + \" \" + creature.getX() + \" \" + creature.getY()+\" \");\n }\n output.println();\n output.close();\n lock.unlock();\n }catch (Exception ex){\n System.out.println(ex);\n }\n }",
"public void writeToConferenceRoomListFile()\r\n {\r\n\ttry(ObjectOutputStream toConferenceRoomListFile = \r\n new ObjectOutputStream(new FileOutputStream(\"listfiles/conferenceroomlist.dta\")))\r\n\t{\r\n toConferenceRoomListFile.writeObject(conferenceRoomList);\r\n conferenceRoomList.saveStaticPrice(toConferenceRoomListFile);\r\n\t}\r\n\tcatch(NotSerializableException nse)\r\n\t{\r\n JOptionPane.showMessageDialog(null, \"Konferanserom objektene er ikke \"\r\n + \"serialiserbare.\\nIngen registrering på fil!\"\r\n + nse.getMessage(), \"Feilmelding\", \r\n JOptionPane.ERROR_MESSAGE);\r\n\t}\r\n\tcatch(IOException ioe)\r\n\t{\r\n JOptionPane.showMessageDialog(null, \"Det oppsto en feil ved skriving \"\r\n + \"til fil.\\n\" + ioe.getMessage());\r\n\t}\r\n }",
"public void writeToEmployeeListFile()\r\n {\r\n\ttry(ObjectOutputStream toEmployeeListFile = \r\n new ObjectOutputStream(new FileOutputStream(\"listfiles/employeelist.dta\")))\r\n\t{\r\n toEmployeeListFile.writeObject(employeeList);\r\n employeeList.saveStaticEmpRunNr(toEmployeeListFile);\r\n\t}\r\n\tcatch(NotSerializableException nse)\r\n\t{\r\n JOptionPane.showMessageDialog(null, \"Ansatt objektene er ikke \"\r\n + \"serialiserbare.\\nIngen registrering på fil!\"\r\n + nse.getMessage(), \"Feilmelding\", \r\n JOptionPane.ERROR_MESSAGE);\r\n\t}\r\n\tcatch(IOException ioe)\r\n\t{\r\n JOptionPane.showMessageDialog(null, \"Det oppsto en feil ved skriving \"\r\n + \"til fil.\\n\" + ioe.getMessage());\r\n\t}\r\n }",
"public static void save() {\r\n\t\ttry {\r\n\t\t\tFile csv = new File(\"src/transaction.csv\");\r\n\t\t\tBufferedWriter bw = new BufferedWriter(new FileWriter(csv, false));\r\n\t\t\tbw.write(\"type,account number,amount,year,month,date,cleared\");\r\n\t\t\tbw.newLine();\r\n\t\t\tfor (int i = 0; i < transList.size(); i++) {\r\n\t\t\t\tbw.write(transList.get(i).toFile());\r\n\t\t\t\tbw.newLine();\r\n\t\t\t}\r\n\t\t\tbw.close();\r\n\t\t} catch (FileNotFoundException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}",
"private void writeToFile(File contactsFile) {\n\n try (BufferedWriter out = new BufferedWriter(new FileWriter(contactsFile))) {\n List<String> lines = new ArrayList<>();\n\n for (User user : contacts) {\n String line = user.getUserId() + \"|\" + user.getFirstName() + \"|\" + user.getLastName() + \"|\" + user.getEmail() + \"|\" +\n user.getAge() + \"|home_\" + user.getPhoneNumbers().get(\"home\").getCountryCode() + \"_\" +\n user.getPhoneNumbers().get(\"home\").getNumber() + \",mobile_\" +\n user.getPhoneNumbers().get(\"mobile\").getCountryCode() + \"_\" +\n user.getPhoneNumbers().get(\"mobile\").getNumber() + \",work_\" +\n user.getPhoneNumbers().get(\"work\").getCountryCode() + \"_\" +\n user.getPhoneNumbers().get(\"work\").getNumber() + \"|\" + user.getAddress().getStreetName() + \",\" +\n user.getAddress().getStreetNumber() + \",\" + user.getAddress().getApartmentNumber() + \",\" +\n user.getAddress().getFloor() + \",\" + user.getAddress().getZipCode() + \",\" +\n user.getAddress().getCity() + \",\" + user.getAddress().getCountry() + \"|\" +\n user.getJobTitle() + \"|\" + user.getCompany().getName() + \"_\" +\n user.getCompany().getAddress().getStreetName() + \",\" +\n user.getCompany().getAddress().getStreetNumber() + \",\" +\n user.getCompany().getAddress().getApartmentNumber() + \",\" +\n user.getCompany().getAddress().getFloor() + \",\" +\n user.getCompany().getAddress().getZipCode() + \",\" +\n user.getCompany().getAddress().getCity() + \",\" +\n user.getCompany().getAddress().getCountry() + \"|\" +\n user.isFavorite();\n\n lines.add(line);\n\n }\n\n for (String line : lines) {\n out.write(line);\n out.newLine();\n }\n\n } catch (FileNotFoundException ex) {\n System.out.println(\"File not found \" + contactsFile + \"\\n\" + ex);\n } catch (IOException ex) {\n System.out.println(\"Failed to write content to file \" + contactsFile + \"\\n\" + ex);\n }\n\n\n }",
"public void exportFile() {\n\t\ttry {\n\t\t\tFileWriter file_write = new FileWriter(\"accounts/CarerAccounts.txt\", false);\n\t\t\tString s = System.getProperty(\"line.separator\");\n\t\t\tfor (int i=0; i < CarerAccounts.size();i++) {\n\t\t\t\tString Users = new String();\n\t\t\t\tfor (int user: CarerAccounts.get(i).getUsers()) {\n\t\t\t\t\tUsers += Integer.toString(user) + \"-\";\n\t\t\t\t}\n\t\t\t\tString individual_user = CarerAccounts.get(i).getID() + \",\" + CarerAccounts.get(i).getUsername() + \",\" + CarerAccounts.get(i).getPassword() + \",\" + CarerAccounts.get(i).getFirstName() + \",\" + CarerAccounts.get(i).getLastName() + \",\" + CarerAccounts.get(i).getEmailAddress() + \",\" + Users;\n\t\t\t\tfile_write.write(individual_user + s);\n\t\t\t}\n\t\t\tfile_write.close();\n\n\t\t} catch (IOException e) {\n\t\t\tSystem.out.println(\"Unable to export file.\");\n\t\t}\n\t}",
"public void writeBuyingHistory(ArrayList<String> boughtBooks)throws IOException\n {\n String toWrite = new String();\n int i =0;\n if(hisMap.get(Customer.getInstance().getUsername())==null)\n {\n hisMap.put(Customer.getInstance().getUsername(),new ArrayList<String>());\n }\n else\n {\n i=0;\n while (i<boughtBooks.size())\n {\n hisMap.get(Customer.getInstance().getUsername()).add(boughtBooks.get(i));\n i++;\n }\n }\n\n\n i=0;\n\n toWrite+=Customer.getInstance().getUsername()+\",\";\n while (i<hisMap.get(Customer.getInstance().getUsername()).size()-boughtBooks.size())\n {\n toWrite+=hisMap.get(Customer.getInstance().getUsername()).get(i)+\"%\";\n i++;\n }\n ;\n i=0;\n while (i<boughtBooks.size())\n {\n toWrite+=boughtBooks.get(i);\n if(i!=boughtBooks.size()-1)\n toWrite+=\"%\";\n i++;\n }\n\n\n\n\n List<String> lines = Files.readAllLines(Paths.get(\"history.txt\"));\n if(specificLine>lines.size()-1)\n {\n lines.add(toWrite);\n }\n else {\n lines.set(specificLine, toWrite);\n }\n /*write part*/\n BufferedWriter bw = null;\n FileWriter fw = null;\n try {\n int j=0;\n String content = \"\";\n while (j<lines.size())\n {\n content+= lines.get(j)+\"\\n\";\n j++;\n }\n\n fw = new FileWriter(\"history.txt\");\n bw = new BufferedWriter(fw);\n bw.write(content);\n\n } catch (IOException e) {\n\n e.printStackTrace();\n\n } finally {\n\n try {\n\n if (bw != null)\n bw.close();\n\n if (fw != null)\n fw.close();\n\n } catch (IOException ex) {\n\n ex.printStackTrace();\n\n }\n\n }\n\n }",
"static void writeOperations(){\n \ttry{\n \t\t\n\t\t\t// Create file \n\t\t\tFileWriter fstream = new FileWriter(FILE_FILEOP);\n\t\t\tBufferedWriter out = new BufferedWriter(fstream);\n\t \tfor (int i=0; i < operations.size(); i++){\n\t \t\tout.write(operations.get(i).getDetails() );\n\t \t}\n\t\t\t\n\t\t\t//Close the output stream\n\t\t\tout.close();\n\t\t}\n \tcatch (Exception e){//Catch exception if any\n\t\t\tSystem.err.println(\"Error: \" + e.getMessage());\n\t\t}\n\t\tSystem.out.print(\"Operations file written.\\n\");\n\n \t\n }",
"public void writeToBookingListFile()\r\n {\r\n\ttry(ObjectOutputStream toBookingListFile = \r\n new ObjectOutputStream(new FileOutputStream(\"listfiles/bookinglist.dta\")))\r\n\t{\r\n toBookingListFile.writeObject(bookingList);\r\n bookingList.saveStaticBookingRunNr(toBookingListFile);\r\n\t}\r\n\tcatch(NotSerializableException nse)\r\n\t{\r\n JOptionPane.showMessageDialog(null, \"Booking objektene er ikke \"\r\n + \"serialiserbare.\\nIngen registrering på fil!\"\r\n + nse.getMessage(), \"Feilmelding\", \r\n JOptionPane.ERROR_MESSAGE);\r\n\t}\r\n\tcatch(IOException ioe)\r\n\t{\r\n JOptionPane.showMessageDialog(null, \"Det oppsto en feil ved skriving \"\r\n + \"til fil.\\n\" + ioe.getMessage());\r\n\t}\r\n }",
"public void writeAdmin(String fileName)\n {\n String message = \"\";\n String output = \"\";\n try\n {\n PrintWriter outputFile = new PrintWriter(fileName);\n for(int index = 0; index < getAllAdmin().length; index++)\n {\n if(getAdmin(index).getAdminEmail().equals(\"????\"))\n break;\n message = getAdmin(index).getAdminEmail() + \",\" + getAdmin(index).getAdminPassword()+\";\";\n output = output + message;\n }\n outputFile.println(output);\n outputFile.close();\n }\n catch(FileNotFoundException exception)\n {\n System.out.println(fileName + \" not found\");\n }\n catch(IOException exception)\n {\n System.out.println(\"Unexpected I/O error occured\");\n }\n }",
"private void miSalvareActionPerformed(java.awt.event.ActionEvent evt) { \n if (!model.isEmpty()) {\n int response = JOptionPane.showConfirmDialog(this, \"Doriti sa salvati lista de contacte?\", \"Salvare\", JOptionPane.YES_NO_OPTION, JOptionPane.QUESTION_MESSAGE);\n if (response == JOptionPane.YES_OPTION) {\n try {\n JFileChooser chooser = new JFileChooser();\n chooser.showSaveDialog(this);\n File list = new File(chooser.getSelectedFile().getAbsolutePath() + \".csv\");\n PrintWriter writer = new PrintWriter(list);\n StringBuilder sb = new StringBuilder();\n\n sb.append(\"Nume\");\n sb.append(\",\");\n sb.append(\"Prenume\");\n sb.append(\",\");\n sb.append(\"Data nasterii\");\n sb.append(\",\");\n sb.append(\"Numar Telefon\");\n sb.append(\",\");\n sb.append(\"\\r\\n\");\n\n listaContacte.stream().map((c) -> {\n sb.append(c.getNume());\n return c;\n }).map((c) -> {\n sb.append(\",\");\n sb.append(c.getPrenume());\n return c;\n }).map((c) -> {\n sb.append(\",\");\n String dataNasterii[] = c.getDataNasterii().toString().split(\"-\");\n String a = dataNasterii[0];\n String l = dataNasterii[1];\n String z = dataNasterii[2];\n String dt = z + \".\" + l + \".\" + a;\n sb.append(dt);\n sb.append(\",\");\n sb.append(c.getNrTel().toString());\n return c;\n }).forEachOrdered((_item) -> {\n sb.append(\"\\r\\n\");\n });\n\n writer.write(sb.toString());\n writer.close();\n\n } catch (FileNotFoundException ex) {\n Logger.getLogger(MainForm.class.getName()).log(Level.SEVERE, null, ex);\n }\n }\n }\n }",
"private void writeMessageInDataFile(String message){\n try {\n String messageToWrite = \"\\n\" + this + message;\n messagesManager.add(messageToWrite); // adds last message to last 15 messages queue\n Files.write(Paths.get(\"messages.txt\"), messageToWrite.getBytes(), StandardOpenOption.APPEND); // writes last message in messages database\n }catch (IOException e) {\n System.err.println(\"*** ERROR ***\\nCouldn't write in data file.\");\n }\n }",
"private void writeFile(List<ClubPointsDTO> clubs) {\n\t\tFileWriter file = null;\n\t\ttry {\n\n\t\t\tfile = new FileWriter(\"clubs.txt\");\n\n\t\t\t// Escribimos linea a linea en el fichero\n\t\t\tfile.write(\"CLUB\\tPUNTOS\\r\\n\");\n\t\t\tfor(ClubPointsDTO c : clubs)\n\t\t\t\tfile.write(c.getName()+\"\\t\"+c.getPoints()+\"\\r\\n\");\n\n\t\t\tfile.close();\n\n\t\t} catch (Exception ex) {\n\t\t\tthrow new FileException();\n\t\t}\n\t}",
"public void writeEvent(){\n for (int i = 0; i<eventlist.size();i++){\n try {\n FileWriter fw = new FileWriter(eventFile, true);\n BufferedWriter bw = new BufferedWriter(fw);\n bw.write(eventlist.get(i).getConfirm()); //this is the username of whoever is writing the event, which will be used as a confirmation later\n bw.newLine();\n bw.write(eventlist.get(i).getEventName());\n bw.newLine();\n bw.write(eventlist.get(i).getEventType());\n bw.newLine();\n bw.write(eventlist.get(i).getDescription());\n bw.newLine();\n bw.write(eventlist.get(i).getPriority());\n bw.newLine();\n bw.write(eventlist.get(i).getDate());\n bw.newLine();\n eventlist.clear(); //clears the ArrayList to prevent duplicate events showing up\n bw.close();\n //each event will take up 6 lines in the file\n }\n catch(IOException ex){\n ex.printStackTrace();\n System.out.println(\"Error writing to files\");\n }\n } \n \n }",
"private void transferContactList() throws IOException {\n dbh.open();\n try {\n String[][] contacts = dbh.getContactsArray(user.toString());\n System.out.println(Arrays.toString(contacts));\n int nbrOfContacts = contacts.length;\n oos.writeObject(\"ContactList\");\n oos.writeObject(contacts);\n oos.flush();\n logListener.logInfo(\"Transfered \" + nbrOfContacts + \" contacts to: \" + user.toString());\n } catch (SQLException e) {\n e.printStackTrace();\n }\n }",
"private void saveChatMessagesInFile() {\n\n if (chatMessages.isEmpty()) {\n return;\n }\n chatMessageFileName = utils.getUserName() + chatPartner + \"TutorscoutChatMessages\";\n\n StringBuilder messagesString = new StringBuilder();\n\n\n for (ChatMessage message : chatMessages) {\n messagesString.append(message.toString());\n }\n\n\n try {\n\n FileOutputStream fos = getContext().openFileOutput(chatMessageFileName, Context.MODE_PRIVATE);\n fos.write(messagesString.toString().getBytes());\n fos.close();\n } catch (IOException e) {\n e.printStackTrace();\n } catch (Exception e) {\n e.printStackTrace();\n }\n\n }",
"public static void writeFile ( LinkedList contactsList ) {\n\t\ttry {\n PrintWriter writer = new PrintWriter ( \"contacts.txt\" );\n for ( int row = 0; row < contactsList.size ( ); row++ ) {\n \t// this is basically a toString right here, adapted to the original contacts.txt\n \tString line = contactsList.get ( row ).getFirst ( ) + \",\" + contactsList.get ( row ).getLast ( ) + \",\" + contactsList.get ( row ).getPhone ( ) \n \t\t\t+ \",\" + contactsList.get ( row ).getAddress ( ) + \",\" + contactsList.get ( row ).getCity ( ) + \",\" + contactsList.get ( row ).getZip ( );\n writer.println ( line );\n }\n writer.close();\n } catch ( FileNotFoundException fnf ) {\n System.out.println(\"File was not found.\");\n }\n\t}",
"private static void saveIntoFile() throws IOException {\n\n\t\tDateFormat format = new SimpleDateFormat(\"yyyy.MM.dd.HH.mm.ss\");\n\t\tString fileName = \"./ipmi.\" + format.format(new Date()) + \".log\";\n\n\t\tBasicConsumptionList file = new BasicConsumptionList();\n\t\tlogger.debug(\"file:\" + fileName);\n\t\tfile.setWriter(new FileWriter(fileName));\n\n\t\tSystem.err.println(ipmi.execute(Command.IPMI_SENSOR_LIST));\n\n\t\twhile (true) {\n\t\t\tDouble watts = ipmi.getWatt();\n\t\t\tfile.addData(System.currentTimeMillis(), watts);\n\t\t\tfile.commit();\n\t\t\ttry {\n\t\t\t\tThread.sleep(1000);\n\t\t\t} catch (InterruptedException e) {\n\t\t\t\tlogger.trace(\"\", e);\n\t\t\t}\n\t\t}\n\t}",
"public void FileWrite(Nimsys nimSys,ArrayList<Player> list)throws IOException{\r\n\t\tOutputStream out = new FileOutputStream(\"players.dat\");\r\n\t\tIterator<Player> aa = list.iterator();\r\n\t\twhile(aa.hasNext()){ //each line includes the information below related to the players\r\n\t\t\tPlayer in = aa.next();\r\n\t\t\tout.write(in.getUserName().getBytes());\r\n\t\t\tout.write(' ');\r\n\t\t\tout.write(in.getSurName().getBytes());\r\n\t\t\tout.write(' ');\r\n\t\t\tout.write(in.getGivenName().getBytes());\r\n\t\t\tout.write(' ');\r\n\t\t\tout.write(String.valueOf(in.getGamePlay()).getBytes());\r\n\t\t\tout.write(' ');\r\n\t\t\tout.write(String.valueOf(in.getWinGame()).getBytes());\r\n\t\t\tout.write(' ');\r\n\t\t\tout.write(String.valueOf(in.getID()).getBytes());\r\n\t\t\tout.write('\\r');\r\n\t\t}\r\n\t}",
"private void writeInfoToFile() {\n createInfoFile(\"infoList.txt\", fwExMessage);\n outFile.println(\"منشی\");\n outFile.println(username);\n outFile.println(password);\n outFile.println(\" \");\n outFile.close();\n }",
"private void chatSave() {\n try{\n //create a text file to write the chatList to\n PrintStream print =\n new PrintStream(new FileOutputStream(\"log.txt\", true));\n //write each line of the array to the file \n for (String str:chatList)\n print.println(str);\n //once each record has been written to the file, close it.\n print.close();\n } catch (IOException e) {\n // exception handling\n }\n }",
"public void toAddWrite(ArrayList<Client> clients, String nameFileWriter) throws Exception{\n \n FileWriter fout = null;\n PrintWriter pw = null;\n \n try{\n fout = new FileWriter(nameFileWriter, true);\n pw = new PrintWriter(fout);\n \n String line = \"Client Name,Save Set Name,Group Start Time,Save Type,Level,Status\";\n pw.println(line);\n \n int size = clients.size();\n \n for(int i=0;i<size;++i){\n for(int j=0;j<clients.get(i).getSizeErrors();++j){\n pw.println(clients.get(i).getName() + \",\" + clients.get(i).getReport(j).toString()); \n }\n } \n }catch(Exception e){\n throw new Exception(\"Error de escritura\");\n }finally{\n if(null != fout){\n fout.close();\n }\n }\n \n }",
"public void writeTo(File file) throws IOException, ClassNotFoundException, CollectionManagerNotExist {\n /**\n if(file.exists()){\n throw new CollectionManagerNotExist();\n }\n **/\n ObjectOutputStream out = new ObjectOutputStream(new FileOutputStream(file));\n out.writeInt(collections.size());\n collections.entrySet().stream().forEachOrdered(entry->{\n String key = entry.getKey();\n Collection collection = entry.getValue();\n try {\n out.writeUTF(key);\n out.writeObject(collection);\n } catch (IOException e) {\n e.printStackTrace();\n }\n\n });\n out.flush();\n out.close();\n }",
"private void writeObject (java.io.ObjectOutputStream out) throws IOException {\n message(AX_PROGRESS,\"Serialize activeX control\");\n if (clientSite != AX_NO_CLIENT_SITE) {\n String componentFileName = generateComponentFileName(\"x0p\");\n message(AX_PROGRESS,componentFileName); \n OleThreadRequest saveRequest = new OleThreadRequest(SAVE,\n componentFileName);\n messagesWaiting.add(saveRequest);\n \n // busy wait - there must be a better way\n while (!saveRequest.finished) {\n synchronized(saveRequest) {\n try {\n saveRequest.wait(POLL_FOR_RESULT_HEARTBEAT);\n }\n catch (InterruptedException e) {\n\n }\n }\n } \n \n componentFileName = saveRequest.name;\n out.defaultWriteObject();\n if (componentFileName.equals(\"\")) {\n message(AX_PROGRESS,\n \"Cannot serialize activeX control, continuing anyway\");\n out.writeLong(0);\n } else {\n File f = new File(componentFileName);\n FileInputStream fi = new FileInputStream(f);\n long sofar = 0;\n int num = -1;\n int filelen = (int)f.length();\n out.writeLong(filelen);\n message(AX_PROGRESS, \"Writing the size of COM storage: \" + filelen);\n byte[] buffer = new byte[1024];\n\n /* The storage file could be many Megs so work in 1K chunks */\n do {\n num = fi.read(buffer,0,1024);\n if (num >= 0) {\n out.write(buffer,0,num);\n sofar += num;\n }\n }\n while (num == 1024);\n\n message(AX_PROGRESS, \"Read \" + sofar + \" bytes from a storage file\");\n\n fi.close();\n if (! f.delete())\n message(AX_ERROR,\"Failed to delete temporary file: \" + \n componentFileName);\n }\n }\n }",
"void writeToFile () throws IOException{\n FileWriter deleteFile = new FileWriter(\"Resolved Ticket of \" + this.resovedDate + \".txt\");\n BufferedWriter FileDeleted = new BufferedWriter(deleteFile);\n\n FileDeleted.write(\"Resolution: \" + this.Resolution + \" ; Date: \" + this.resovedDate);\n FileDeleted.close();\n }",
"public void saveCustomerToFile() throws IOException {\n\t\tString desktopPath = System.getProperty(\"user.home\") + \"\\\\Desktop\\\\customer\";\n\t\t\n\t\tFileOutputStream fos = new FileOutputStream(desktopPath);\n\t\tObjectOutputStream oos = new ObjectOutputStream(fos);\n\t\t\n\t\tCustomer[] customersArr = customers.toArray(new Customer[customers.size()]) ;\n\t\t\n\t\toos.writeObject(customersArr);\n\t\toos.close();\n\t}",
"private void saveResourceFile()\r\n\t{\t\r\n\t\tFile file = null;\r\n\t\tFileWriter fw = null;\r\n\t\t//File complete = null;//New file for the completed list\r\n\t\t//FileWriter fw2 = null;//Can't use the same filewriter to do both the end task and the complted products.\r\n\t\ttry{\r\n\t\t\tfile = new File(outFileName);\r\n\t\t\tfile.createNewFile();\r\n\t\t\tfw = new FileWriter(outFileName,true);\r\n\t\t\tfor(FactoryObject object : mFObjects)\r\n\t\t\t{\r\n\t\t\t\tif(object instanceof FactoryReporter) {\r\n\t\t\t\t\t((FactoryReporter)object).report(fw);\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (IOException ioe) {\r\n\t\t\tSystem.out.println(ioe.getMessage());\r\n\t\t\tif(file != null) {\r\n\t\t\t\tfile.delete();\r\n\t\t\t}\r\n\t\t} finally {\r\n\t\t\tif(fw != null) {\r\n\t\t\t\ttry{\r\n\t\t\t\t\tfw.close();\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t\tSystem.out.println(\"Failed to close the filewriter!\");\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"public void save() {\n CSVWriter csvWriter = new CSVWriter();\n csvWriter.writeToTalks(\"phase1/src/Resources/Talks.csv\", this.getTalkManager()); //Not implemented yet\n }",
"@SuppressWarnings({ \"unchecked\" })\n\tpublic static void writeMerchants(ArrayList<Merchant> list) {\n\t\tJSONArray array = new JSONArray();\n\t\tJSONObject jsonM;\n\t\tfor (Merchant m : list) {\n\t\t\tjsonM = new JSONObject();\n\t\t\tjsonM.put(\"name\", m.getName());\n\t\t\tjsonM.put(\"apiKey\", m.getApiKey());\n\t\t\tjsonM.put(\"description\", m.getDescription());\n\t\t\tjsonM.put(\"realm\", m.getRealm());\n\t\t\tarray.add(jsonM);\n\t\t}\n\t\tArrayList<String> al = new ArrayList<String>();\n\t\tal.add(array.toJSONString());\n\t\ttry {\n\t\t\tFiles.write(new File(Call.class.getResource(MERCHANT_FILE).getPath()).toPath(), al,\n\t\t\t\t\tCharset.forName(\"UTF-8\"));\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public void writeFile() {\n\t\ttry {\n\t\t\tFile dir = Environment.getExternalStorageDirectory();\n\t\t\tFile myFile = new File(dir.toString() + File.separator + FILENAME);\n\t\t\tLog.i(\"MyMovies\", \"SeSus write : \" + myFile.toString());\n\t\t\tmyFile.createNewFile();\n\t\t\tFileOutputStream fOut = new FileOutputStream(myFile);\n\t\t\tOutputStreamWriter myOutWriter = \n\t\t\t\t\tnew OutputStreamWriter(fOut);\n\t\t\tfor (Map.Entry<String, ValueElement> me : hm.entrySet()) {\n\t\t\t\tString refs = (me.getValue().cRefMovies>0? \"MOVIE\" : \"\");\n\t\t\t\trefs += (me.getValue().cRefBooks>0? \"BOOK\" : \"\");\n\t\t\t\tString line = me.getKey() + DELIMITER + me.getValue().zweiteZeile \n\t\t\t\t\t\t //+ DELIMITER\n\t\t\t\t\t\t //+ me.getValue().count\n\t\t\t\t\t \t+ DELIMITER\n\t\t\t\t\t \t+ refs\n\t\t\t\t\t \t + System.getProperty(\"line.separator\");\n\t\t\t\t//Log.i(\"MyMovies\", \"SeSus extracted : \" + line);\n\t\t\t\tmyOutWriter.write(line);\n\t\t\t}\n\t\t\tmyOutWriter.close();\n\t\t\tfOut.close();\n\t\t} catch (IOException e) {\n\t\t\t//\n\t\t\tLog.i(\"MyMovies\", \"SeSus write Exception : \");\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"private void saveCompletedItemsFile()\r\n\t{\r\n\t\tFile complete = null;//New file for the completed list\r\n\t\tFileWriter fw2 = null;//Can't use the same filewriter to do both the end task and the complted products.\r\n\t\ttry{\r\n\t\t\tString completeFileName = \"reports/\" + \"CompletedItems.txt\";\r\n\t\t\tcomplete = new File(completeFileName); //Create a new text file called CompletedItems.txt\r\n\t\t\tcomplete.createNewFile(); // Make the file\r\n\t\t\tfw2 = new FileWriter(completeFileName, true); //Initialize the second filewriter\r\n\t\t\t\r\n\t\t\tArrayList<String> toWrite = mTaskBoard.getCompletedProducts(); //get the strings to write\r\n\t\t\tfor(int i = 0; i < toWrite.size(); i++) //For all the elements in toWrite\r\n\t\t\t{\r\n\t\t\t\tfw2.write(toWrite.get(i)+\"\\n\"); //Write it into the file\r\n\t\t\t\t//fw2.write(\"\\n\");\r\n\t\t\t}\r\n\t\t\t\r\n\t\t} catch (IOException ioe) {\r\n\t\t\tSystem.out.println(ioe.getMessage());\r\n\t\t\tif(complete != null) {\r\n\t\t\t\tcomplete.delete();\r\n\t\t\t}\r\n\t\t} finally {\r\n\t\t\tif(fw2 != null) {\r\n\t\t\t\ttry{\r\n\t\t\t\t\tfw2.close();\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t\tSystem.out.println(\"Failed to close the filewriter2!\");\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"public void writeToClientFile(String nick, MESSAGE message) {\n ConcurrentHashMap<String, Client> clientsList = ccv.getClients();\n Client client = clientsList.get(nick);\n OutputStream outputStream = null;\n try {\n// System.out.println(\"Server writer sendToClient \"+ client.getNick()+\" : \" +line);\n outputStream = client.getFileSenderSocket().getOutputStream();\n MessageManger.directWriteMessage(message, outputStream);\n } catch (SocketException ex) {\n synchronized (clientsList) {\n clientsList.remove(client.getNick());\n }\n //comunico a tutti di eliminare l'utente\n ServerWriter sw = new ServerWriter(ccv);\n MESSAGE toSend = MessageManger.createCommand(Command.REMOVEUSER, null);\n MessageManger.addParameter(toSend, \"nick\", client.getNick());\n sw.writeAll(toSend);\n log.error(ex);\n } catch (Exception ex) {\n log.warn(ex);\n log.debug(\"Resend message\");\n writeToClientFile(nick, message);\n }\n\n }",
"private void writeToFile(){\n Calendar c = Calendar.getInstance();\n String dateMedTaken = DateFormat.getDateInstance(DateFormat.FULL).format(c);\n FileOutputStream fos = null;\n\n try {\n fos = openFileOutput(FILE_NAME, MODE_APPEND);\n fos.write(dateMedTaken.getBytes());\n } catch (FileNotFoundException e) {\n e.printStackTrace();\n } catch (IOException e) {\n e.printStackTrace();\n } finally {\n if(fos != null){\n try {\n fos.close();\n } catch (IOException e) {\n e.printStackTrace();\n }\n }\n }\n\n }",
"private static void writeToFileEmployees() throws IOException {\n FileWriter write = new FileWriter(path2, append);\n PrintWriter print_line = new PrintWriter(write);\n for (int i = 0; i < RegisteredEmployees.listOfEmployees.size(); i++) {\n ArrayList<Integer> list = RegisteredEmployees.getEmployeeList();\n Integer ID = list.get(i);\n textLine = String.valueOf(ID);\n print_line.printf(\"%s\" + \"%n\", textLine);\n }\n print_line.close();\n }",
"public void saveStaffList(String fileName) {\n try {\n BufferedWriter out = new BufferedWriter(new FileWriter(fileName));\n out.write(maxStaff+\"\\r\\n\");\n \n out.write(numStaff+\"\\r\\n\");\n \n \n for (int i = 0; i < numStaff; i++) {\n if (staffList[i] instanceof Labourer) {\n out.write(staffList[i].toFile());\n } else if (staffList[i] instanceof Manager) {\n out.write(staffList[i].toFile());\n }\n }\n out.close();\n } catch (IOException iox) {\n System.out.println(\"Error saving to \" + fileName);\n }\n }",
"public static synchronized void save() {\n\n String team_fil = config.Server.serverdata_file_location + \"/teams.ser\";\n String team_backup = config.Server.serverdata_file_location + \"/teams\";\n\n Calendar dato = new GregorianCalendar();\n\n team_backup += dato.get(Calendar.YEAR) + \"-\" + dato.get(Calendar.DAY_OF_MONTH) + \"-\" + dato.get(Calendar.MONTH) + \"-\";\n team_backup += dato.get(Calendar.HOUR) + \"-\" + dato.get(Calendar.MINUTE) + \".ser\";\n\n admin.logging.globalserverMsg(\"Saving team data to file.\");\n\n try {\n FileOutputStream fil = new FileOutputStream(team_fil);\n FileOutputStream fil_backup = new FileOutputStream(team_backup);\n\n //Skriv til teams.txt\n ObjectOutputStream out = new ObjectOutputStream(fil);\n out.writeObject(team_list);\n out.flush();\n out.close();\n fil.close();\n\n //Skriv til backup fil.\n out = new ObjectOutputStream(fil_backup);\n out.writeObject(team_list);\n out.flush();\n out.close();\n fil.close();\n } catch (Exception e) {\n e.printStackTrace();\n admin.logging.globalserverMsg(\"Error saving team data to file.\");\n }\n }",
"public void gerarCupom(String cliente, String vendedor,List<Produto> produtos, float totalVenda ) throws IOException {\r\n \r\n File arquivo = new File(\"cupomFiscal.txt\");\r\n String produto =\" \"; \r\n if(arquivo.exists()){\r\n System.out.println(\"Arquivo localizado com sucessso\");\r\n }else{\r\n System.out.println(\"Arquivo não localizado, será criado outro\");\r\n arquivo.createNewFile();\r\n } \r\n \r\n for(Produto p: produtos){\r\n produto += \" \"+p.getQtd()+\" \"+ p.getNome()+\" \"+p.getMarca()+\" \"+ p.getPreco()+\"\\n \";\r\n }\r\n \r\n \r\n \r\n FileWriter fw = new FileWriter(arquivo, true);\r\n BufferedWriter bw = new BufferedWriter(fw);\r\n \r\n \r\n bw.write(\" \"+LOJA);\r\n bw.newLine();\r\n bw.write(\"---------------------------------------\");\r\n bw.newLine();\r\n bw.write(\"CLIENTE CPF\");\r\n bw.newLine();\r\n bw.write(cliente);\r\n bw.newLine();\r\n bw.write(\"---------------------------------------\");\r\n bw.newLine();\r\n bw.write(DateCustom.dataHora());\r\n bw.newLine();\r\n bw.write(\" CUPOM FISCAL \");\r\n bw.newLine();\r\n bw.write(\"QTD DESCRIÇÃO PREÇO\");\r\n bw.newLine();\r\n bw.write(produto);\r\n bw.newLine(); \r\n bw.write(\"---------------------------------------\");\r\n bw.newLine();\r\n bw.write(\"TOTAL R$ \" + totalVenda);\r\n bw.newLine();\r\n bw.write(\"---------------------------------------\");\r\n bw.newLine();\r\n bw.write(\"Vendedor \" + vendedor);\r\n bw.newLine();\r\n bw.newLine();\r\n bw.close();\r\n fw.close();\r\n }",
"public void writeToHotelRoomListFile()\r\n {\r\n\ttry(ObjectOutputStream toHotelRoomListFile = \r\n new ObjectOutputStream(new FileOutputStream(\"listfiles/hotelroomlist.dta\")))\r\n\t{\r\n toHotelRoomListFile.writeObject(hotelRoomList);\r\n hotelRoomList.saveStaticPrice(toHotelRoomListFile);\r\n\t}\r\n\tcatch(NotSerializableException nse)\r\n\t{\r\n JOptionPane.showMessageDialog(null, \"Hotelrom objektene er ikke \"\r\n + \"serialiserbare.\\nIngen registrering på fil!\"\r\n + nse.getMessage(), \"Feilmelding\", \r\n JOptionPane.ERROR_MESSAGE);\r\n\t}\r\n\tcatch(IOException ioe)\r\n\t{\r\n JOptionPane.showMessageDialog(null, \"Det oppsto en feil ved skriving \"\r\n + \"til fil.\\n\" + ioe.getMessage());\r\n\t}\r\n }",
"public static void writeCSV(Calendar cal) {\n\n try {\n\n BufferedWriter bw = null;\n\n String fileString = \"P5Calendar.csv\";\n String fileLine = \"\";\n\n FileWriter fw = new FileWriter(fileString, false);\n bw = new BufferedWriter(fw);\n\n ArrayList<Activity> activities = cal.getActivities();\n\n for (int j = 0; j < 1; j++) {\n bw.write(\"Year\" + \",\" + \"Month\" + \",\" + \"Activity\" + \",\" + \"Role\" + \"\\n\");\n }\n\n for (int i = 0; i < activities.size(); i++) {\n Activity activity = activities.get(i);\n bw.append(activity.Year + \",\" + activity.Month + \",\" + activity.Name + \",\" + activity.Roles);\n }\n\n bw.close();\n\n } catch (IOException e) {\n\n e.printStackTrace();\n\n }\n\n }",
"public void writeChannel() {\n try {\n java.io.FileWriter chWriter = new java.io.FileWriter(chFile);\n chWriter.write(chStored);\n chWriter.close();\n JTVProg.logPrint(this, 3, \"файл канала [\" + this.chName + \"] успешно сохранен\");\n } catch (IOException ex) {\n JTVProg.logPrint(this, 0, \"ошибка записи файла канала [\" + this.chName + \"]\");\n } finally {\n JTVProg.configer.markWrited(this.chFillOrder - 1);\n }\n }",
"private void saveFile(File file){\n\t\ttry{\r\n\t\t\tBufferedWriter writer = new BufferedWriter(new FileWriter(file));\r\n\t\t\t\r\n\t\t\tfor(QuizCard card:cardList){\r\n\t\t\t\twriter.write(card.getQuestion() + \"/\");\r\n\t\t\t\twriter.write(card.getAnswer() + \"\\n\");\r\n\t\t\t}\r\n\t\t\twriter.close();\r\n\t\t} catch (IOException ex){\r\n\t\t\tSystem.out.println(\"couldn't write the cardList out\");\r\n\t\t\tex.printStackTrace();}\r\n\t}",
"public void writeList() {\n try{\n PrintWriter out = new PrintWriter(new FileWriter(\"OutFile.txt\"));\n\n for (int i = 0; i < SIZE; i++) {\n // The get(int) method throws IndexOutOfBoundsException, which must be caught.\n out.println(\"Value at: \" + i + \" = \" + list.get(i));\n }\n out.close();\n } catch (IOException e) {\n e.printStackTrace();\n }\n\n }",
"private void writeToFile() {\n boolean flag = true;\n int expectedPacket = (lastPacket)? sequenceNo: Constants.WINDOW_SIZE;\n for (int i = 0; i < expectedPacket; i++) {\n if(!receivedPacketList.containsKey(i)) {\n flag = false;\n }\n }\n if (flag) {\n System.out.println(\"Time: \" + System.currentTimeMillis() + \"\\t\" + \"Write to file Possible\");\n try (BufferedOutputStream stream = new BufferedOutputStream(new FileOutputStream(fileSavePath, true))) {\n for (int i = 0; i < receivedPacketList.size(); i++) {\n //System.out.println(new String(receivedPacketList.get(i)));\n stream.write(receivedPacketList.get(i));\n }\n receivedPacketList.clear();\n stream.close();\n } catch (FileNotFoundException ex) {\n \n } catch (IOException ex) {\n \n }\n receivedPacketList.clear();\n expectedList.clear();\n }\n }",
"public void writeOutput() {\n // Create json object to be written\n Map<String, Object> jsonOutput = new LinkedHashMap<>();\n // Get array of json output objects for consumers\n List<Map<String, Object>> jsonConsumers = writeConsumers();\n // Add array for consumers to output object\n jsonOutput.put(Constants.CONSUMERS, jsonConsumers);\n // Get array of json output objects for distributors\n List<Map<String, Object>> jsonDistributors = writeDistributors();\n // Add array for distributors to output objects\n jsonOutput.put(Constants.DISTRIBUTORS, jsonDistributors);\n // Get array of json output objects for producers\n List<Map<String, Object>> jsonProducers = writeProducers();\n // Add array for producers to output objects\n jsonOutput.put(Constants.ENERGYPRODUCERS, jsonProducers);\n // Write to output file and close\n try {\n ObjectMapper mapper = new ObjectMapper();\n ObjectWriter writer = mapper.writer(new DefaultPrettyPrinter());\n writer.writeValue(Paths.get(outFile).toFile(), jsonOutput);\n } catch (Exception e) {\n e.printStackTrace();\n }\n }",
"private void saveAndExit() {\n if (yesNoQuestion(\"Would you like to save the current active courses to the saved list before saving?\")) {\n addActiveCourseListToCourseList();\n }\n try {\n JsonWriter writer = new JsonWriter(\"./data/ScheduleList.json\",\n \"./data/CourseList.json\");\n writer.open(true);\n writer.writeScheduleList(scheduleList);\n writer.close(true);\n\n writer.open(false);\n writer.writeCourseList(courseList);\n writer.close(false);\n } catch (IOException ioe) {\n System.out.println(\"File Not Found, failed to save\");\n } catch (Exception e) {\n System.out.println(\"Unexpected Error, failed to save\");\n }\n\n }",
"private void saveCustomDeck() {\n try (PrintWriter pw = new PrintWriter(new FileWriter(USER_DECK))) {\n for (int i = 0; i < customDeck.size(); i++) {\n pw.print(customDeck.get(i) + \"\\n\\n\");\n }\n } catch (IOException ex) {\n System.out.println(\"FAILED TO SAVE SCORES\");\n }\n }",
"public static void writeObject() {\r\n ChunkedCharBuffer buf = new ChunkedCharBuffer();\r\n for (Map.Entry<String, CronJob> entry : getInstance().events.entrySet()) {\r\n CronJob event = entry.getValue();\r\n buf.append(entry.getKey());\r\n buf.append(\"|\");\r\n buf.append(String.valueOf(event.getInterval()));\r\n buf.append(\"|\");\r\n buf.append(String.valueOf(event.getStartTime().getTime()));\r\n buf.append(\"|\");\r\n buf.append(event.getCommandString());\r\n buf.append(\"|\");\r\n buf.append(event.getUser());\r\n buf.append(\"|\");\r\n buf.append(event.getUserService());\r\n buf.append(\"\\n\");\r\n }\r\n if (buf.size() > 0) {\r\n try {\r\n OutputStreamWriter out = new OutputStreamWriter(new BufferedOutputStream(new FileOutputStream(FILE, false)));\r\n buf.writeTo(out);\r\n out.flush();\r\n out.close();\r\n } catch (Exception e) {\r\n LoggingService.getInstance().serverLog(\"Error writing statistics: \" + e);\r\n }\r\n }\r\n }",
"public void writeFile() \r\n\t{\r\n\t\tStringBuilder builder = new StringBuilder();\r\n\t\tfor(String str : scorers)\r\n\t\t\tbuilder.append(str).append(\",\");\r\n\t\tbuilder.deleteCharAt(builder.length() - 1);\r\n\t\t\r\n\t\ttry(DataOutputStream output = new DataOutputStream(new FileOutputStream(HIGHSCORERS_FILE)))\r\n\t\t{\r\n\t\t\toutput.writeChars(builder.toString());\r\n\t\t} \r\n\t\tcatch (FileNotFoundException e) \r\n\t\t{\r\n\t\t\te.printStackTrace();\r\n\t\t\tSystem.err.println(\"[ERROR]:[FileManager] File \" + HIGHSCORERS_FILE + \" was not found \" \r\n\t\t\t\t\t+ \"while writing.\");\r\n\t\t} \r\n\t\tcatch (IOException e) \r\n\t\t{\r\n\t\t\te.printStackTrace();\r\n\t\t\tSystem.err.println(\"[ERROR]:[FileManager] Error while reading the file \" + HIGHSCORERS_FILE);\r\n\t\t}\r\n\t}",
"public void writeData(List<EmployeePayrollData> employeePayrollList) {\n\t\tStringBuffer empBuffer=new StringBuffer();\n\t\temployeePayrollList.forEach(employee->{\n\t\t\tString emloyeeDataString=employee.toString().concat(\"\\n\");\n\t\t\tempBuffer.append(emloyeeDataString); \n\t\t});\n\t\ttry {\n\t\t\tFiles.write(Paths.get(PAYROLL_FILE_NAME),empBuffer.toString().getBytes());\n\t\t}catch(IOException e)\n\t\t{\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public static void save()\n {\n try {\n \n \n PrintWriter fich = null;\n \n fich = new PrintWriter(new BufferedWriter(new FileWriter(\"bd.pl\", true)));\n\t\t\t//true c'est elle qui permet d'écrire à la suite des donnée enregistrer et non de les remplacé \n \n for(String auto : GestionController.listApp)\n {\n \n fich.println(auto);\n }\n fich.println();\n for(String auto : GestionController.listDetFact)\n {\n \n fich.println(auto);\n }\n fich.println();\n for(String auto : GestionController.listFact)\n {\n \n fich.println(auto);\n }\n fich.println();\n for(String auto : GestionController.listType)\n {\n \n fich.println(auto);\n }\n fich.println();\n fich.close();\n } catch (Exception e1) {\n printStrace(e1);\n\t\t}\n }",
"public String savePermissionPersonCompany() {\r\n\t\tResourceBundle bundleSecurity = ControladorContexto\r\n\t\t\t\t.getBundle(\"messageSecurity\");\r\n\t\ttry {\r\n\t\t\tif (listPermissionPersonBusinessTemp != null) {\r\n\t\t\t\tthis.userTransaction.begin();\r\n\t\t\t\tString personName = person.getNames() + \" \"\r\n\t\t\t\t\t\t+ person.getSurnames();\r\n\t\t\t\tStringBuilder messageCompaniesFarms = new StringBuilder();\r\n\t\t\t\tString messageFarmCompany = \"person_permission_company_message_associate_company_farm\";\r\n\t\t\t\tfor (PermissionPersonBusiness permissionPersonBusinessAdd : listPermissionPersonBusinessTemp) {\r\n\t\t\t\t\tboolean predetermined = permissionPersonBusinessAdd\r\n\t\t\t\t\t\t\t.isPredetermined();\r\n\t\t\t\t\tPermissionPersonBusiness predeterminedPermision = permissionPersonBusinessDao\r\n\t\t\t\t\t\t\t.consultExistPredetermined(person.getDocument());\r\n\t\t\t\t\tif (predetermined && predeterminedPermision != null) {\r\n\t\t\t\t\t\tpredeterminedPermision.setPredetermined(false);\r\n\t\t\t\t\t\tpermissionPersonBusinessDao\r\n\t\t\t\t\t\t\t\t.editPermissionPersonCompany(predeterminedPermision);\r\n\t\t\t\t\t}\r\n\t\t\t\t\tnullValidate(permissionPersonBusinessAdd);\r\n\t\t\t\t\tpermissionPersonBusinessAdd.setDateCreation(new Date());\r\n\t\t\t\t\tpermissionPersonBusinessAdd.setUserName(identity\r\n\t\t\t\t\t\t\t.getUserName());\r\n\t\t\t\t\tpermissionPersonBusinessDao\r\n\t\t\t\t\t\t\t.savePermissionPersonCompany(permissionPersonBusinessAdd);\r\n\t\t\t\t\tif (messageCompaniesFarms.length() > 1) {\r\n\t\t\t\t\t\tmessageCompaniesFarms.append(\", \");\r\n\t\t\t\t\t}\r\n\t\t\t\t\tString nitCompany = permissionPersonBusinessAdd\r\n\t\t\t\t\t\t\t.getBusiness().getNit();\r\n\t\t\t\t\tString nameFarm = permissionPersonBusinessAdd.getFarm()\r\n\t\t\t\t\t\t\t.getName();\r\n\t\t\t\t\tString msg = MessageFormat.format(\r\n\t\t\t\t\t\t\tbundleSecurity.getString(messageFarmCompany),\r\n\t\t\t\t\t\t\tnitCompany, nameFarm);\r\n\t\t\t\t\tmessageCompaniesFarms.append(msg);\r\n\t\t\t\t}\r\n\t\t\t\tthis.userTransaction.commit();\r\n\t\t\t\tString format = MessageFormat\r\n\t\t\t\t\t\t.format(bundleSecurity\r\n\t\t\t\t\t\t\t\t.getString(\"person_permission_company_message_associate_company\"),\r\n\t\t\t\t\t\t\t\tpersonName, messageCompaniesFarms);\r\n\t\t\t\tControladorContexto.mensajeInformacion(null, format);\r\n\t\t\t}\r\n\t\t} catch (Exception e) {\r\n\t\t\ttry {\r\n\t\t\t\tthis.userTransaction.rollback();\r\n\t\t\t} catch (Exception e1) {\r\n\t\t\t\tControladorContexto.mensajeError(e1);\r\n\t\t\t}\r\n\t\t\tControladorContexto.mensajeError(e);\r\n\t\t}\r\n\t\treturn consultPermissionPersonCompany();\r\n\t}",
"private void writeToFile(){\r\n File file = new File(\"leaderboard.txt\");\r\n\r\n try {\r\n FileWriter fr = new FileWriter(file, true);\r\n BufferedWriter br = new BufferedWriter(fr);\r\n for(Player player : this.sortedPlayers){\r\n br.write(player.toString());\r\n br.write(\"\\n\");\r\n }\r\n br.close();\r\n fr.close();\r\n } catch (IOException e) {\r\n e.printStackTrace();\r\n }\r\n\r\n }",
"public void saveFile()\n\t{\n\t\tStringBuilder sb = new StringBuilder();\n\t\tString newLine = System.getProperty(\"line.separator\");\n\t\t\n\t\tfor(CSVItem cItem : itemList)\n\t\t{\n\t\t\tsb.append(cItem.buildCSVString()).append(newLine);\n\t\t\t\n\t\t}\n\t\tString fileString = sb.toString();\n\t\t\n\t\t File newTextFile = new File(filePath);\n\n FileWriter fw;\n\t\ttry {\n\t\t\tfw = new FileWriter(newTextFile);\n\t\t\t fw.write(fileString);\n\t\t fw.close();\n\t\t} catch (IOException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n \n\n\t}",
"public void writeInfoTofile() throws IOException\n\t{\n\t\tFileWriter fstream = new FileWriter(\"booking.txt\",true);\n BufferedWriter out = new BufferedWriter(fstream); //buffer class name out\n out.append(\"name : \"+this.customer_name);\n out.newLine();\n out.append(hotelInfo.getName());// Writing all customer info\n out.newLine();\n out.append(\"country : \"+hotelInfo.getCountry());\n out.newLine();\n out.append(\"Hotel rating : \"+hotelInfo.getStar());\n out.newLine(); \n out.append(\"check-in date : \"+this.checkin_date);\n out.newLine();\n out.append(\"check-out date: \"+this.checkout_date);\n out.newLine();\n out.append(\"Total price : \"+this.totalPrice);\n out.newLine();\n out.close();\n System.out.println(\"Writting successful.\");\n\t}",
"public void SerialWriteFile() {\r\n\r\n PrintWriter pwrite = null;\r\n File fileObject = new File(getName());\r\n QuizPlayer q = new QuizPlayer(getName(), getNickname(), getTotalScore());\r\n\r\n try {\r\n ObjectOutputStream outputStream =\r\n new ObjectOutputStream(new FileOutputStream(fileObject));\r\n\r\n outputStream.writeObject(q); //Writes the object to the serialized file.\r\n outputStream.close();\r\n\r\n\r\n } catch (IOException e) {\r\n System.out.println(\"Problem with file output.\");\r\n }\r\n\r\n }",
"public void saveOffers() {\n System.out.println(this.currentChild);\n // TODO [assignment_final] ulozeni aktualnich nabidek do souboru (vyberte si nazev souboru a format jaky uznate za vhodny - CSV nebo JSON)\n }",
"private static void writeToOrder() throws IOException {\n FileWriter write = new FileWriter(path5, append);\n PrintWriter print_line = new PrintWriter(write);\n ArrayList<Order> orders = Inventory.getOrderHistory();\n for (int i = 0; i < orders.size(); i++) {\n Order o = (Order) orders.get(i);\n\n String orderNum = String.valueOf(o.getOrderNumber());\n String UPC = String.valueOf(o.getUpc());\n String productName = o.getProductName();\n String distName = o.getDistributorName();\n String cost = String.valueOf(o.getCost());\n String quantity = String.valueOf(o.getQuantity());\n String isProcesed = String.valueOf(o.isProcessed());\n\n textLine =\n orderNum + \", \" + UPC + \", \" + quantity + \",\" + productName + \", \" + distName + \", \" + cost\n + \", \" + isProcesed;\n print_line.printf(\"%s\" + \"%n\", textLine);\n\n }\n print_line.close();\n\n }",
"@Override\n public void write() {\n for(MDCWriter writer : this.writers) {\n writer.write();\n }\n }",
"@Override\n\tpublic void write() throws IOException {\n\t\t// declare and instantiate a filewriter to write to the customer's file\n\t\tFileWriter wr = new FileWriter(this.customer);\n\t\tBufferedWriter br = new BufferedWriter(wr);\n\n\t\t// write the customers first and last name (seperate lines)\n\t\tbr.write(this.firstName + \"\\n\");\n\t\tbr.write(this.lastName + \"\\n\");\n\t\t// write the customers phone number (remove the parenthesis around the\n\t\t// area code and spaces)\n\t\t// only write a new line if the customer has transactions\n\t\t// (BufferedReader does not allow preceding \"\\n\")\n\t\tString phoneNum = this.phoneNum.substring(1, 4) + this.phoneNum.substring(6, 9) + this.phoneNum.substring(10);\n\n\t\tif (this.transactions.size() == 0) {\n\t\t\tbr.write(phoneNum);\n\t\t} else {\n\t\t\tbr.write(phoneNum + \"\\n\");\n\t\t}\n\n\t\t// write all of the transaction numbers\n\t\tfor (int i = 0; i < this.transactions.size(); i++) {\n\t\t\t// if this last transaction, do not write an enter\n\t\t\t// else, write an enter\n\t\t\tif (i == this.transactions.size() - 1) {\n\t\t\t\tbr.write(this.transactions.get(i));\n\t\t\t} else {\n\t\t\t\tbr.write(this.transactions.get(i) + \"\\n\");\n\t\t\t}\n\t\t}\n\n\t\t// close the filewriter (finished writing)\n\t\tbr.close();\n\t}",
"public void save(){\n try{\n Date date = new Date();\n \n PrintWriter writer = new PrintWriter(\"data.MBM\", \"UTF-8\");\n \n writer.println(\"version:\"+MBMDriver.version);\n writer.println(\"numworlds:\" + worlds.size());\n writer.println(\"lastclosed:\" + date.toString());\n writer.println(\"outDir:\"+outputDir.toPath());\n \n for(int i = 0; i < worlds.size(); i++){\n \n writer.println(\"MBMWORLD:\"+worlds.get(i).getWorldFile().getName()+\":\"+worlds.get(i).getName()+\":\"+worlds.get(i).getWorldFile().toPath()+\":\"+worlds.get(i).getLastBackupDate());\n }\n \n writer.close();\n }catch(FileNotFoundException e){\n System.out.println(\"ERROR: Failed to Find File\");\n }catch(UnsupportedEncodingException e){\n System.out.println(\"ERROR: Unsupported Encoding Exception\");\n }\n }",
"public static void saveReceipt()\r\n\t{\r\n\t\tPrintWriter listWriter = null;\r\n\t\tPrintWriter contentWriter = null;\r\n\t\tnewReceipt = getTimeStamp();\r\n\t\t\r\n\t\ttry\r\n\t\t{\r\n\t\t\tlistWriter = new PrintWriter(new FileOutputStream(RECEIPT_LIST_FILE, true));\r\n\t\t\tcontentWriter = new PrintWriter(RECEIPT_PATH + newReceipt);\r\n\t\t}\r\n\t\tcatch(FileNotFoundException e)\r\n\t\t{\r\n\t\t\tJOptionPane.showMessageDialog(null,\"File Not Found\");\r\n\t\t}\r\n\t\t\r\n\t\tlistWriter.println(newReceipt);\r\n\t\tfor(int count=0; count < listModel.getSize(); count++)\r\n\t\t\tcontentWriter.println(listModel.elementAt(count));\r\n\t\t\r\n\t\tlistWriter.close();\r\n\t\tcontentWriter.close();\r\n\t\tclearReceipt();\r\n\t}",
"public String SAVE(String filename){\n try{\n //File will be rewritten\n BufferedWriter writer = new BufferedWriter(new FileWriter(filename, false));\n Enumeration keys = this.clientData.keys();\n while(keys.hasMoreElements()){\n String keyToAppend = (String) keys.nextElement();\n writer.append(keyToAppend + \",\" + this.clientData.get(keyToAppend) + '\\n');\n }\n writer.close();\n } catch (IOException e) {\n e.printStackTrace();\n return \"ERROR CANNOT WRITE TO THE FILE\";\n }\n return \"OK\";\n }",
"private void saveEmployee()\n {\n Employee tempEmployee = new Employee();\n String line = \"\";\n try\n {\n PrintWriter out = new PrintWriter(fileName);\n for(int i = 0; i < employees.size(); i++)\n {\n tempEmployee = (Employee) employees.get(i);\n line = tempEmployee.getName() + \",\" + tempEmployee.getHours() + \",\" +\n tempEmployee.getRate();\n out.println(line);\n }\n out.close(); \n }\n catch(IOException ex)\n {\n ex.printStackTrace();\n }\n }",
"public void saveFile() {\r\n final String file = \"respuestaConjuntoDeDatosCon\" + this.numberOfBees + \"abejas.txt\";\r\n try {\r\n int count = 0;\r\n PrintWriter writer = new PrintWriter(file, \"UTF-8\");\r\n for (int i = 0; i < this.numberOfBees; i++) {\r\n if (beesArray[i].isInCollisionRisk()) {\r\n writer.println(beesArray[i].getLatitude() + \",\" + beesArray[i].getLongitude() + \",\" + beesArray[i].getHeight());\r\n count++;\r\n }\r\n }\r\n System.out.println(\"Number of bees in collision risk: \" + count);\r\n writer.close();\r\n } catch (IOException ioe) {\r\n System.out.println(\"Something went wrong writing the exit file\");\r\n }\r\n }",
"@Override\n\tpublic void flush() {\n\t\ttry {\n\t\t\tFile f = new File(path);\n\t\t\tFileWriter fw = new FileWriter(f);\n\t\t\tfw.write(\"\");\n\t\t\tfw.close();\n\t\t} catch (Exception e) {\n\t\t\t// TODO: handle exception\n\t\t}\n\t \n\t \n\t\n\t try {\n\t\t \n\t\t\n\t\t \n\t\t\tObjectOutputStream os;\n\t\t\tFile file = new File(path);\n\t\t\tFileOutputStream fos = new FileOutputStream(file, true);\n\t\t\tif (file.length() < 1) {\n\t\t\t\tos = new ObjectOutputStream(fos);\n\t\t\t} else {\n\t\t\t\tos = new MyObjectOutputStream(fos);\n\t\t\t}\n\t\t\tos.writeObject(constantPO);\n\t\t\tos.flush();\n\t\t\tos.close();\n\t\t} catch (FileNotFoundException e) {\n\t\t\te.printStackTrace();\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public void saveAllVehiclesToFile(ArrayList<DeliveryVehicle> vehicleList) throws java.io.IOException {\n\n // write object to file\n FileOutputStream fos = new FileOutputStream(_filePath); //object to hold a file, e.g. EmployeeData.txt\n PrintStream writer = new PrintStream(fos); //object to write data\n\n //For loop to read each employee and write them to the file\n for(DeliveryVehicle vehicle : vehicleList){\n writer.println(vehicle);\n }\n\n writer.close();//close the writer\n fos.close();//close the file\n\n }",
"private void writeClientFile(Content content) throws Exception {\n\t\tString path = open();\n\t\tTranslateContent translate = new TranslateContent(content, path);\n\n\t\t// Links may need to be deleted before update to content.\n\t\tPath linkPath = FileSystems.getDefault().getPath(path);\n\t\tlinkPath.toFile().delete();\n\n\t\ttranslate.writeClient();\n\t}",
"public void writeToFile() {\n try {\n // stworz plik\n File file = new File(\"../Alice.ids\");\n // stworz bufor zapisu do pliku\n FileWriter fileWriter = new FileWriter(file);\n for(int i = 0; i < identificationNumbers.length; i++) {\n for(int j = 0; j < identificationNumbers[i].length; j++)\n fileWriter.write(Integer.toString(identificationNumbers[i][j]));\n\t\t\t fileWriter.write(\"\\n\");\n }\n\t\t\tfileWriter.flush();\n\t\t\tfileWriter.close();\n } catch(Exception e) {\n e.printStackTrace();\n }\n }",
"void saveRecents(){\n File dotFile = new File( rcFile);\n FileWriter fw;\n BufferedWriter bw;\n PrintWriter pw;\n String str;\n\n // open dotFile\n try{\n // if there is not dotFile, create new one\n fw = new FileWriter( dotFile );\n bw = new BufferedWriter( fw );\n pw = new PrintWriter( bw );\n //write\n for(int i=0;i<MAX_RECENT;i++){\n str = miRecent[i].getText();\n pw.println(str);\n }\n pw.close();\n bw.close();\n fw.close();\n }catch(IOException e){\n }\n\n\n }",
"private void writeChatLog() {\n\t\tif (chatLog.size() < 100) {\n\t\t\treturn;\n\t\t}\n\n\t\ttry {\n\n\t\t\tBufferedWriter log = new BufferedWriter(new FileWriter(Data.CHAT_LOG, true));\n\n\t\t\ttry {\n\n\t\t\t\tfor (int i = 0; i < chatLog.size(); i++) {\n\t\t\t\t\tlog.write(chatLog.get(i));\n\t\t\t\t\tlog.newLine();\n\t\t\t\t}\n\n\t\t\t} finally {\n\t\t\t\tlog.close();\n\t\t\t\tchatLog.clear();\n\t\t\t}\n\n\t\t} catch (IOException ioe) {\n\t\t\tioe.printStackTrace();\n\t\t}\n\t}",
"private void writeToFile(){\n try(BufferedWriter br = new BufferedWriter(new FileWriter(filename))){\n for(Teme x:getAll())\n br.write(x.toString()+\"\\n\");\n br.close();\n }catch (IOException e){\n e.printStackTrace();\n }\n }",
"void SaveBook(String fileName)\r\n\t\t{\r\n\t\t\tFile f = new File(fileName);\r\n\t\t\t\r\n\t\t\tFileWriter writer;\r\n\t\t\t\r\n\t\t\ttry {\r\n\t\t\t\twriter = new FileWriter(f);\r\n\t\t\t\tfor(int i = 0; i < this.size(); i++)\r\n\t\t\t\t{\r\n\t\t\t\twriter.write(this.get(i).getContactName());\r\n\t\t\t\twriter.write(\",\");\r\n\t\t\t\twriter.write(Integer.toString(this.get(i).getContactNumber()));\r\n\t\t\t\twriter.write(\"\\n\");\r\n\t\t\t\t}\r\n\t\t\t\twriter.flush();\r\n\t\t\t\twriter.close();\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t\te.printStackTrace();\r\n\t\t\t}\r\n\t\t\t\r\n\t\t}",
"public static void savecars(){\n Cars xx = new Cars();\n System.out.println(\"save cars\");\n String outtext;\n try {\n File rentfile = new File(\"cars.csv\");\n FileWriter out = new FileWriter(rentfile);\n for (int i = 0; i < listcars.size();i++) {\n xx = listcars.get(i);\n String newline = System.getProperty(\"line.separator\");\n outtext = xx.getBrand()+ \";\"+ xx.getModel()+ \";\"+ xx.getReference()+ \";\"+ xx.getYear()+ newline;\n out.write(outtext);\n }\n out.close();\n System.out.println(\"cars data saved in cars.csv\");\n } catch (IOException i) {\n i.printStackTrace();\n }\n }",
"private void writeCollection() throws DvdCollectionDaoException {\n // NOTE FOR APPRENTICES: We are not handling the IOException - but\n // we are translating it to an application specific exception and \n // then simple throwing it (i.e. 'reporting' it) to the code that\n // called us. It is the responsibility of the calling code to \n // handle any errors that occur.\n PrintWriter out;\n\t \n try {\n out = new PrintWriter(new FileWriter(COLLECTION_FILE));\n } catch (IOException e) {\n throw new DvdCollectionDaoException(\n \"Could not save DVD Collection data.\", e);\n }\n\t \n // Write out the DVD objects to the collection file.\n List<Dvd> dvdList = this.getAllDvds();\n for (Dvd currentDvd : dvdList) {\n // write the DVD object to the file\n out.println(currentDvd.getTitle() + DELIMITER\n + currentDvd.getReleaseDate() + DELIMITER \n + currentDvd.getMpaaRating() + DELIMITER\n + currentDvd.getDirectorName() + DELIMITER \n + currentDvd.getStudio() + DELIMITER\n + currentDvd.getUserRating());\n // force PrintWriter to write line to the file\n out.flush();\n }\n // Clean up\n out.close();\n }",
"private void saveListToFile() {\n try {\n PrintStream out = new PrintStream(\n openFileOutput(LIST_FILENAME, MODE_PRIVATE)\n );\n\n for (int i = 0; i < listArr.size(); i++) {\n out.println(listArr.get(i));\n }\n\n out.close();\n\n } catch (IOException ioe) {\n Log.e(\"saveListToFile\", ioe.toString());\n }\n }",
"@Override\n\tpublic void saveActivityCommodity(List<ActivityCommodity> list) {\n\t\t\n\t}",
"public void writeList()\r\n\t{\r\n\t\ttry\r\n\t\t{\r\n\t\t\tPrintWriter writer = new PrintWriter(categoryName + \".txt\");\r\n\t\t\t\r\n\t\t\tfor(int i = 0; i < questions.size(); i++) // go through ArrayList\r\n\t\t\t{\r\n\t\t\t\twriter.println(questions.get(i).getQuestion() + \",\" + \r\n\t\t\t\t\t\t\t\t questions.get(i).getAnswer1() + \",\" +\r\n\t\t\t\t\t\t\t\t questions.get(i).getAnswer2() + \",\" +\r\n\t\t\t\t\t\t\t\t questions.get(i).getAnswer3() + \",\" +\r\n\t\t\t\t\t\t\t\t questions.get(i).getAnswer4() + \",\" +\r\n\t\t\t\t\t\t\t\t questions.get(i).getCorrectAnswer());\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\twriter.close();\r\n\t\t\t\r\n\t\t}\r\n\t\tcatch(FileNotFoundException fnf)\r\n\t\t{\r\n\t\t\tSystem.out.println(\"File was not found\");\r\n\t\t}\r\n\t}",
"public static void write2File(String fileName) throws IOException{\n BufferedWriter output = null;\n try {\n File file = new File(fileName);\n output = new BufferedWriter(new FileWriter(file));\n for(BufferIOIntercept ob : bufferIOList){\n \n output.write(ob.op + \",\" + ob.strategy + \",\" + ob.numberBte + \",\" + ob.blkSize + \",\" + ob.time + \"\\n\");\n }\n } catch ( IOException e ) {\n e.printStackTrace();\n } finally {\n if ( output != null ) output.close();\n }\n }",
"private void exportFile()\n\t{\n\t\ttry\n\t\t{\n\t\t\tdrinkListFileOutput = new BufferedWriter(new FileWriter(drinkListFile));\n\t\t\tdrinkListFileOutput.write(exportDrinkList);//insert string of drinks\n\t\t\tdrinkListFileOutput.close();\n\t\t\tJOptionPane.showMessageDialog(null, \"Successfully saved drinks\");\n\t\t}\n\t\tcatch(IOException e)\n\t\t{\n\t\t\te.toString();//change this\n\t\t\tJOptionPane.showMessageDialog(null, \"Drink save error: \" + e.toString());//change this);\n\t\t}\n\n\n\n\t}",
"private void outputfile() {\n\n ConnectDB dbconnect = new ConnectDB();\n\n try {\n PrintWriter writer = new PrintWriter(\"memberoutput.txt\");\n\n try {\n dbconnect.pst = dbconnect.con.prepareStatement(\"select * from members\");\n dbconnect.rs = dbconnect.pst.executeQuery();\n\n while (dbconnect.rs.next()) {\n writer.println(dbconnect.rs.getString(1) + \",\"\n + dbconnect.rs.getString(2) + \",\"\n + dbconnect.rs.getString(3) + \",\"\n + dbconnect.rs.getString(4) + \",\"\n + dbconnect.rs.getString(5) + \",\"\n + dbconnect.rs.getString(6) + \",\"\n + dbconnect.rs.getString(7) + \",\"\n + dbconnect.rs.getString(8) + \",\"\n + dbconnect.rs.getString(9));\n }\n\n writer.flush();\n } catch (SQLException e) {\n // TODO Auto-generated catch block\n }\n writer.close();\n\n } catch (FileNotFoundException e) {\n e.printStackTrace();\n }\n\n JOptionPane.showMessageDialog(null, \"File exported\");\n }",
"public void createNewFootballClub() {\n\n\n Scanner scan2 = new Scanner(System.in);\n\n System.out.print(\"Enter the club name : \");\n clubName = scan2.nextLine();\n System.out.print(\"Enter club location : \");\n clubLocation = scan2.nextLine();\n System.out.println(\"Enter Club Id : \");\n clubID = scan2.nextInt();\n\n //adding user data to the arraylist\n displayStatistics();\n footballClubArrayList.add(new FootballClub(clubName, clubLocation,clubID, date, numOfWins, numOfDraws, numOfDefeats, numOfGoalsScored, numOfGoalReceived, numOfPoints, numOfMatchesPlayed));\n\n //adding arraylist object to the file by fileoutput stream\n try {\n FileOutputStream fOutStr = new FileOutputStream(\"clubData.txt\");\n ObjectOutputStream objOutStr = new ObjectOutputStream(fOutStr);\n objOutStr.writeObject(footballClubArrayList);\n objOutStr.close();\n fOutStr.close();\n System.out.println(\"Club added Successfully\");\n\n\n } catch (FileNotFoundException e) {\n e.printStackTrace();\n } catch (IOException e) {\n e.printStackTrace();\n }\n }",
"private void saveInFile() {\n try {\n FileOutputStream fos = openFileOutput(FILENAME,\n Context.MODE_PRIVATE);//goes stream based on filename\n BufferedWriter out = new BufferedWriter(new OutputStreamWriter(fos)); //create buffer writer\n Gson gson = new Gson();\n gson.toJson(countbookList, out);//convert java object to json string & save in output\n out.flush();\n fos.close();\n } catch (FileNotFoundException e) {\n throw new RuntimeException();\n } catch (IOException e) {\n throw new RuntimeException();\n }\n }",
"private void saveInFile() {\n try {\n FileOutputStream fos = openFileOutput(FILENAME, Context.MODE_PRIVATE);\n\n BufferedWriter out = new BufferedWriter(new OutputStreamWriter(fos));\n\n Gson gson = new Gson();\n Log.d(\"PersonList\", personList.toString());\n gson.toJson(personList, out);\n out.flush();\n\n fos.close();\n\n } catch (FileNotFoundException e){\n throw new RuntimeException();\n } catch (IOException e){\n e.printStackTrace();\n }\n\n }",
"private void writeBatchToFile(ArrayList<SensorEntry> batch) {\n\n\t\tFile file = new File(currFolder + \"/\" + entriesRecorded + \".csv\");\n\n\t\ttry {\n\n\t\t\tFileOutputStream outputStream = new FileOutputStream(file);\n\n\t\t\tif (!file.exists()) {\n\t\t\t\tfile.createNewFile();\n\t\t\t\toutputStream.write(Constants.INS_DATA_HEADER.getBytes());\n\t\t\t}\n\n\t\t\tfor (SensorEntry e : batch)\n\t\t\t\toutputStream.write((e.toRawString() + \",\" + e.getTimeRecorded() + \"\\n\").getBytes());\n\n\t\t\toutputStream.close();\n\n\t\t\tsetsOfEntriesRecorded++;\n\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\n\t}",
"public void saveFile() throws FileNotFoundException {\r\n try {\r\n PrintWriter out = new PrintWriter(FILE_NAME);\r\n //This puts back the labels that the loadFile removed\r\n out.println(\"date,cust_email,cust_location,product_id,product_quantity\");\r\n int i = 0;\r\n\r\n while (i < orderInfo.size()) {\r\n String saved = orderInfo.get(i).toString();\r\n out.println(saved);\r\n i++;\r\n }\r\n out.close();\r\n } catch (FileNotFoundException e) {\r\n }\r\n\r\n }",
"void write(File file) throws IOException {\n Files.createParentDirs(file);\n FileWriter fileWriter = new FileWriter(file);\n try {\n for (Map.Entry<String, Status> record : records.entrySet()) {\n fileWriter.write(String.format(\"%s,%s\", record.getValue(), record.getKey()));\n fileWriter.write(\"\\n\");\n }\n } finally {\n fileWriter.close();\n }\n }",
"public void writeOutputToFile(ArrayList<Object> transformNums) throws IOException {\r\n FileWriter file = new FileWriter(writeFilename);\r\n\r\n for(int i=0; i<transformNums.size(); i++){\r\n file.write(transformNums.get(i)+\" \");\r\n }\r\n\r\n file.close();\r\n\r\n }",
"public void outputToFile(ModifierList original, ModifierList mutant) {\r\n\t\tMutantsInformationHolder.mainHolder().addMutation(MutationOperator.AMC, original, mutant);\r\n\t}",
"public static void writeClientfile(String filepath, Client clientObj) throws IOException {\r\n // add the new client object to clientMap\r\n addClient(clientObj);\r\n // write new client information to client csv\r\n CSVWriter writer = new CSVWriter(new FileWriter(filepath), CSVWriter.DEFAULT_SEPARATOR, \r\n CSVWriter.NO_QUOTE_CHARACTER);\r\n for (Entry<String, Client> entry : clientMap.entrySet()) {\r\n String [] record = entry.getValue().toString().split(\",\");\r\n writer.writeNext(record);\r\n }\r\n writer.close();\r\n\r\n }",
"@SuppressWarnings(\"unchecked\")\n public static void writeFile(String outputFile) {\n try (FileWriter file = new FileWriter(outputFile)) { // Creates file\n file.write(Constants.OPEN_SQUARE); // Begin array\n for(Map.Entry<Integer, String> entry : valid.entrySet()) { // Iterates names\n int id = entry.getKey();\n String name = entry.getValue();\n String cust = String.format(Constants.ENTRY, id, name);\n file.write(cust); // Writes formatted string to file\n }\n file.write(Constants.CLOSE_SQUARE); // Closes the array\n file.flush(); // Flushes buffer\n } catch (IOException e) { // Case of exception\n e.printStackTrace();\n }\n }",
"public void writeData(ArrayList<Task> orderList) {\n try {\n FileWriter fw = new FileWriter(filePath, false);\n for (Task task : orderList) {\n fw.write(task.fileFormattedString() + \"\\n\");\n }\n fw.close();\n\n } catch (IOException e) {\n System.out.println(e.getMessage());\n }\n }",
"static public void addEmployeesToFile(Set<Employee> company){\n\t\tfor(Employee employee : company) {\n\t\t\ttry{\n\t\t\t\tFileWriter writer = new FileWriter(employee.getDepartment() + \".txt\", true); // second argument for appending\n\t\t\t\tBufferedWriter bw = new BufferedWriter(writer);\n\t\t\t\tPrintWriter out = new PrintWriter(bw);\n\t\t\t\tout.println(employee.toFileString());\n\t\t\t\tout.close();\n\t\t\t\tbw.close();\n\t\t\t\twriter.close();\n\t\t\t}\n\t\t\tcatch (IOException ex){\n\t\t\t\tex.printStackTrace();\n\t\t\t}\n\t\t}\n\t}",
"public void recordOrder(){\n PrintWriter output = null;\n try{\n output = \n new PrintWriter(new FileOutputStream(\"record.txt\", true));\n }\n catch(Exception e){//throws exception\n System.out.println(\"File not found\");\n System.exit(0);\n }\n output.println(Coffee);//prints in file contents of Coffee\n output.close();//closes file\n }"
]
| [
"0.595896",
"0.5843249",
"0.57898986",
"0.56865126",
"0.5598278",
"0.5591814",
"0.5591112",
"0.55467737",
"0.5515195",
"0.5434569",
"0.5391005",
"0.53650016",
"0.5363946",
"0.5327779",
"0.53271395",
"0.5326352",
"0.53223073",
"0.5277286",
"0.52631044",
"0.5259959",
"0.5256818",
"0.5245634",
"0.5242351",
"0.52241814",
"0.52234626",
"0.5217026",
"0.5212961",
"0.5169542",
"0.516621",
"0.51636946",
"0.51598597",
"0.515895",
"0.5147586",
"0.513164",
"0.513044",
"0.5129284",
"0.5122345",
"0.51129216",
"0.51123816",
"0.51019573",
"0.5096394",
"0.50929147",
"0.5081747",
"0.5079405",
"0.5065458",
"0.50639683",
"0.5061557",
"0.50607336",
"0.50524366",
"0.5015627",
"0.5009477",
"0.49947053",
"0.49809596",
"0.49631187",
"0.49564952",
"0.49493918",
"0.49391174",
"0.49341074",
"0.49308756",
"0.49247998",
"0.49104112",
"0.49072924",
"0.49038827",
"0.4902934",
"0.4896175",
"0.48848474",
"0.4879098",
"0.4872321",
"0.48666072",
"0.48656556",
"0.48623362",
"0.48582762",
"0.48579907",
"0.48402897",
"0.48388076",
"0.48347124",
"0.48339584",
"0.48258707",
"0.4803866",
"0.48016822",
"0.47992802",
"0.4798984",
"0.47968644",
"0.47951755",
"0.4793162",
"0.47832108",
"0.47801378",
"0.47748828",
"0.4773172",
"0.47729513",
"0.47679946",
"0.47666416",
"0.4761932",
"0.47558865",
"0.47552663",
"0.4748955",
"0.47481987",
"0.4745283",
"0.47414568",
"0.4738621"
]
| 0.5637379 | 4 |
replaces the entry of index inside the logs file | public static void ReplacesEntry(int index){
int cont = 0;
String[] thingstowrite = ManageCommissionerList.ReturnsCommissionerListInString(index);
try{
Path path = Paths.get("logscommission.txt");
List<String> lines = Files.readAllLines(path, StandardCharsets.UTF_8);
for(int i = index*19;i<(index*19)+19;i++){
lines.set(i, thingstowrite[cont]);
cont++;
}
Files.write(path, lines, StandardCharsets.UTF_8);
}catch(Exception e){
e.printStackTrace();
System.out.printf("Not possible to replace entry!\n");
}
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private Reindex() {}",
"private Reindex() {}",
"private void updateIndexMap(String file) {\n\t\ttry (Scanner s = new Scanner(new File(file))) {\n\t\t\twhile (s.hasNext()) {\n\t\t\t\tString word = TextParserUtil.cleanWord(s.next());\n\t\t\t\tString partition = word.substring(0, 1);\n\t\t\t\tif (indexedDir.get(partition) == null) {\n\t\t\t\t\tinsertPartitionEntry(file, word, partition);\n\t\t\t\t} else if (indexedDir.get(partition).get(word) == null) {\n\t\t\t\t\tinsertWordEntry(file, word, partition);\n\t\t\t\t} else if (indexedDir.get(partition).get(word) != null) {\n\t\t\t\t\tupdateFileList(file, word, partition);\n\t\t\t\t}\n\t\t\t}\n\t\t} catch (FileNotFoundException e) {\n\t\t\te.printStackTrace();\n\t\t} \n\t}",
"public static void update(String indexFileName, String listOfDoc) throws IOException{\n\t\tHashMap<String, String> sCurrentHashMap = null;\n\t\tboolean hasFile = true;\n\t\t\n\t\tif(globalHash.containsKey(indexFileName)){\n\t\t\t//ถ้ามีใน global แล้ว เอาออกมาแล้วเอามารวมกับที่เพิ่งอ่านไฟล์ได้เลย\n\t\t\tsCurrentHashMap = globalHash.get(indexFileName);\n\t\t\n\t\t}else{ \n\t\t\t//if no hashmap in globalHash, then check if there's this fileName.txt in directory\n\t\t\t\n\t\t\tif(!new File(indexFileName+\".txt\").isFile()){\n\t\t\t\t\tSystem.out.println(\"ERROR: The inverted file is not found.\");\n\t\t\t\t\thasFile = false;\n\t\t\t}else{\n\t \t sCurrentHashMap = genHashMapFromInvertedIndexFile(indexFileName);\n\t\t\t \n\t\t\t}\n\t\t}\n\t\t\n\t\tif(hasFile){\n\t\t\tArrayList<Term> newTermList = extractDoc(listOfDoc);\n\t\t\t//if the new term list has value (not doc not found)\n\t\t\tif(newTermList.size()>0){\n\t\t\t\t\n\t\t\t\t\n\t\t\t\tsCurrentHashMap = addListToHashMap(sCurrentHashMap, newTermList);\n\t\t\t\t\n\t\t\t\t/*เพิ่มเงื่อนไขกรณี ลบคำออกจากไฟล์ \n\t\t\t\t * 1.ทำ list เป็น hashMap อีกอันไว้เซิชไวไว\n\t\t\t\t * loop amount of doc\n\t\t\t\t * 2.ไล่ iterative ของ hashMap ว่ามี value อันไหน contain ชื่อไฟล์บ้าง ถ้าcontain ให้เช็คกลับว่า key นั้น มีในแฮชอีกอันหรือเปล่า\n\t\t\t\t*/\n\t\t\t\t\n\t\t\t\t/* // Convert new word (from file) list to HashMap\n\t\t\t\tHashMap<String, String> newWordHashMap = new HashMap<String, String>();\n\t\t\t\tfor(Term i: newTermList){\n\t\t\t\t\tnewWordHashMap.put(i.getTerm(), i.getDocNumber()+\"\");\n\t\t\t\t}\n\t\t\t\t\n\t\t\t\t\n\t\t\t\tIterator it = sCurrentHashMap.entrySet().iterator();\n\t\t\t\twhile(it.hasNext()){\n\t\t\t\t\tHashMap.Entry<String, String> entry = (HashMap.Entry<String, String>) it.next();\n\t\t\t\t\t//if its value contains the doc number, then check if its key is in the newTermHash or note\n\t\t\t\t\t// if not --> this term was removed --> remove this key out from sCurrentHashMap\n\t\t\t\t\tif(entry.getValue().contains(s)) {\n\t\t\t\t\t\t\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\t*/\n\t\t\t\t\n\t\t\t\tglobalHash.put(indexFileName, sCurrentHashMap);\n\n\t\t\t\t\n\t\t\t}\n\t\t\t\n\t\t}\n\t\t\n\t\t\n\t\t\n\t\t\n\t}",
"private void updateToFile(PQNode node) throws Exception{\n List<PQNode> nodes = retrieveWholeFile(node.getPqIndex());\n int replaceIndex = node.getPqIndex()-bufStart;\n\n nodes.set(replaceIndex,node);\n int fileId = (node.getPqIndex()-1)/ENTRY_BLOCK_SIZE;\n File file = new File(DIRECTORY + getMapFileName(NAME_PATTERN, fileId));\n storeToFile(file,nodes, false);\n }",
"@Override\n\tpublic void update() {\n\t\tFile logFile = new File(AppStorage.getInstance().getLogFileLocation());\n\t\tlogFile.getParentFile().mkdirs();\n\n\t\ttry {\n\t\t\tFileHandler fileHandler = new FileHandler(AppStorage.getInstance().getLogFileLocation(), true);\n\t\t\tSimpleFormatter formatter = new SimpleFormatter();\n\t\t\tfileHandler.setFormatter(formatter);\n\n\t\t\twhile (logger.getHandlers().length > 0) {\n\t\t\t\tFileHandler prevFileHandler = (FileHandler)logger.getHandlers()[0];\n\t\t\t\tlogger.removeHandler(prevFileHandler);\n\t\t\t\tprevFileHandler.close();\n\t\t\t}\n\n\t\t\tlogger.addHandler(fileHandler);\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"long getLastLogIndex();",
"private void log(IndexObjectException e) {\n\t\t\r\n\t}",
"public abstract void updateIndex();",
"private void renameLogs() {\n File oldest = new File(getFileNameForIndex(mNumSegments - 1));\r\n oldest.delete();\r\n\r\n // Chain rename the rest\r\n for (int i = mNumSegments - 2; i >= 0; i--) {\r\n File chunk = new File(getFileNameForIndex(i));\r\n chunk.renameTo(new File(getFileNameForIndex(i + 1)));\r\n }\r\n }",
"protected synchronized void overrideEntityIndex(String entity, int index) { ent_2_i.put(entity,index); }",
"@Override\n\tpublic void replaceAt(int index, int e) {\n\t\t\n\t}",
"private void reLoadIndexesFromFileToIndexMap(File file) throws IOException {\n BufferedReader reader = new BufferedReader(new FileReader(file));\n for (String line = reader.readLine(); line != null; line = reader\n .readLine()) {\n String[] termIndex = line.split(\" \");\n String key = termIndex[0];\n LinkedList<TermPositions> value = new LinkedList<>();\n String postingList = termIndex[1];\n // split the posting lists 1:1,2,4;2:4\n String[] subPostings = postingList.split(\";\");\n for (String posting : subPostings) {\n String[] docPosting = posting.split(\":\");\n int docId = Integer.parseInt(docPosting[0]);\n String[] positions = docPosting[1].split(\",\");\n LinkedList<Integer> positionsList = new LinkedList<>();\n for (String position : positions) {\n positionsList.add(Integer.parseInt(position));\n }\n TermPositions termPositions = new TermPositions(docId, positionsList);\n value.add(termPositions);\n }\n indexMap.put(key, value);\n\n }\n\n }",
"@Test\n public void retrievesIndexFromLog() throws Exception {\n final String name = \"talk\";\n final Talks talks = new Talks.InDir();\n talks.create(\"\", name);\n talks.get(name).modify(\n new Directives().xpath(\"/talk\")\n .push().xpath(\"wire\").remove().pop()\n .add(\"wire\").add(\"href\").set(\"#2\").up().up()\n .add(\"archive\")\n .add(\"log\").attr(\"id\", \"1\").attr(\"title\", \"title1\")\n .attr(\"index\", \"1\").up()\n .add(\"log\").attr(\"id\", \"2\").attr(\"title\", \"title2\")\n .attr(\"index\", \"2\").up().up()\n .add(\"request\").attr(\"id\", \"a12345\")\n .add(\"author\").set(\"yegor256\").up()\n .add(\"args\").up()\n .add(\"type\").set(\"deploy\").up()\n );\n new IndexesRequests().execute(talks);\n MatcherAssert.assertThat(\n talks.get(name).read(),\n XhtmlMatchers.hasXPaths(\"/talk/request[@index='3']\")\n );\n }",
"public void onIndexUpdate();",
"long getFirstLogIndex();",
"public void update_local_index(String record_size_file, String record_file,\n\t\t\tString record_line) {\n \tint record_size = 0;\n\t\tif (file_helper.fileIsExists(record_size_file)) {\n\t\t\tString record_size_line = file_helper.read(record_size_file);\n\t\t\tif (record_size_line != null) {\n\t\t\t\trecord_size = Integer.parseInt(record_size_line);\n\t\t\t}\n\t\t}\n \trecord_size++;\n \tfile_helper.save(record_size_file, record_size + \"\");\n \t\n \t// record\n \tString new_record_line = record_size + \"\\t\" + record_line + \"\\n\";\n\t\tLog.i(TAG, record_file + \" NEW: \" + new_record_line);\n \tfile_helper.append(record_file, new_record_line);\n\t}",
"private void updateIndex() throws IOException {\n // maintain the document store (corpus) - if there is one\n if (currentMemoryIndex.containsPart(\"corpus\")) {\n // get all corpora + shove into document store\n ArrayList<DocumentReader> readers = new ArrayList<>();\n readers.add((DocumentReader) currentMemoryIndex.getIndexPart(\"corpus\"));\n for (String path : geometricParts.getAllShards().getBinPaths()) {\n String corpus = path + File.separator + \"corpus\";\n readers.add(new CorpusReader(corpus));\n }\n }\n // finally write new checkpointing data (checkpoints the disk indexes)\n Parameters checkpoint = createCheckpoint();\n this.checkpointer.saveCheckpoint(checkpoint);\n }",
"public void updateIndex() {\n int i = this.index;\n if (i == -1 || i > HashBiMap.this.size || !Objects.equal(HashBiMap.this.keys[this.index], this.key)) {\n this.index = HashBiMap.this.findEntryByKey(this.key);\n }\n }",
"boolean reset(final long nextLogIndex);",
"void indexReset();",
"public synchronized static void addIndex(File fileName, TreeMap<String, TreeSet<Integer>> index) {\n if (!fileIndices.containsKey(fileName)) {\n fileIndices.put(fileName, index);\n } else {\n System.out.println(\"There exist files with the same name in the input location.\");\n }\n }",
"public void replace(int idIndex, String inputFilePath) {\n\t\tString url = IP + String.valueOf(PORT) + \"/replace\";\n\t\thelper(url, idIndex, inputFilePath);\n\t}",
"public void updateImageForIndex(int index) {\n\t\t//Nothing to do\n\t}",
"Response<Void> logCustomStat(int index);",
"void updateFile() throws IOException;",
"void setLogFile(File log);",
"private void indexInTransaction(SVNLogEntry logEntry) throws SVNException {\n // Log values\n long revision = logEntry.getRevision();\n String author = logEntry.getAuthor();\n // Date to date time\n Date date = logEntry.getDate();\n DateTime dateTime = new DateTime(date.getTime(), DateTimeZone.UTC);\n // Message\n String message = logEntry.getMessage();\n // Branch for the revision\n String branch = getBranchForRevision(logEntry);\n // Logging\n logger.info(String.format(\"Indexing revision %d\", revision));\n // Inserting or updating the revision\n revisionDao.addRevision(revision, author, dateTime, message, branch);\n // Merge relationships (using a nested SVN client)\n Transaction svn = transactionService.start(true);\n try {\n List<Long> mergedRevisions = subversionService.getMergedRevisions(SVNUtils.toURL(subversionConfigurationExtension.getUrl(), branch), revision);\n revisionDao.addMergedRevisions(revision, mergedRevisions);\n } finally {\n svn.close();\n }\n // Subversion events\n indexSVNEvents(logEntry);\n // Indexes the issues\n indexIssues(logEntry);\n }",
"public EventLogEntry getEventLogEntry(int index);",
"private void createInvertedIndex() {\n\t\tArrayList<Index> invertedIndex=new ArrayList<>();\n\t\ttry{\n\t\t\tBufferedReader in = new BufferedReader(new FileReader(\"E:\\\\graduate\\\\cloud\\\\project\\\\data\\\\part-r-00001\"));\n\t\t\tString line = \"\";\n\t\t\twhile ((line = in.readLine()) != null) {\n\t\t\t\tString parts[] = line.split(\"\\t\");\n\t\t\t\tparts[1]=parts[1].replace(\"{\", \"\").replace(\"}\", \"\");\n\t\t\t\tString counts[]=parts[1].split(\",\");\n\t\t\t\tHashMap<String,Integer> fileList=new HashMap<String,Integer>();\n\t\t\t\tfor (String count : counts) {\n\t\t\t\t\tString file[]=count.split(\"=\");\n\t\t\t\t\tfileList.put(file[0].trim().replace(\".txt\", \"\"), Integer.parseInt(file[1].trim()));\n\t\t\t\t}\n\t\t\t\tIndex index=new Index();\n\t\t\t\tindex.setWord(parts[0]);\n\t\t\t\tindex.setFileList(fileList);\n\t\t\t\tinvertedIndex.add(index);\n\t\t\t}\n\t\t\tin.close();\n\t\t}catch(IOException e){\n\t\t\te.printStackTrace();\n\t\t}\n\t\tDBUtil.insertIndex(invertedIndex);\n\t}",
"abstract void onIndexDisrupted(String caseId);",
"public void controlIndex(String path)\n { \t \n \t JSONParser parser = new JSONParser();\n \t \n \t try\n \t {\n \t\t JSONArray array = (JSONArray)parser.parse(new FileReader(path));\n \t\t \n \t\t JSONObject jsonObject = new JSONObject();\n \t\t JSONObject metaObj;\n \t\t \n \t\t for(Object obj : array)\n \t\t {\n \t\t\t jsonObject = (JSONObject) obj;\n \t\t\t String p = jsonObject.get(\"p\").toString().replaceAll(\"\\\\\\\\\", \"/\");\n \t\t\t metaObj = (JSONObject) jsonObject.get(\"metadata\");\n \t\t\t \n \t\t\t String title = \"\";\n \t\t\t String description = \"\"; \n \t\t\t if(metaObj.get(\"title\")!=null)\n \t\t\t {\n \t\t\t\t title = metaObj.get(\"title\").toString();\n \t\t\t }\n \t\t\t if(metaObj.get(\"description\")!=null)\n \t\t\t {\n \t\t\t\t description = metaObj.get(\"description\").toString();\n \t\t\t }\n \t\t\t \n \t\t\t String id = p.substring(p.lastIndexOf(\"/\")+1,p.lastIndexOf(\".\"));\n \t\t\t \n \t\t\t performIndex(p,id,title,description);\n \t\t\t performMetaIndex(jsonObject.get(\"metadata\"),id);\n \t\t }\n \t\t fileWriter();\n \t\t }\n \t catch(Exception e)\n \t { \t\n \t\t e.printStackTrace();\n \t }\n }",
"@Override\r\n\tpublic void updateLog(Log log) throws RuntimeException {\n\t\tlogMapper.updateLog(log);\r\n\t}",
"public void onIndexReset();",
"public static void writeInvertedIndex(Map<Integer, Multimap> map, String filename) throws IOException{\n\t\tPrintWriter writer = new PrintWriter(new BufferedWriter(new FileWriter(\"C:/Users/Naveen/Desktop/TestRuns/LastRun/\"+filename, true)));\n\t\tfor (Entry<Integer, Multimap> entry : map.entrySet())\n\t {\t \t\t\n\t \t\twriter.println(entry.getKey()+\":\"+entry.getValue());\n\t }\n\t writer.close();\n\t}",
"int writerIndex();",
"public boolean setIndex(String name){\n\n //array to hold all database names from file\n ArrayList<String> dbNames = new ArrayList<String>();\n\n //create index if it doesn't exist\n File file = new File(\"databases/index.txt\");\n Scanner sc;\n FileWriter fw; \n\n try {\n sc = new Scanner(file); \n //read current database names to array\n String currName; \n if (sc.hasNextLine()){\n while(sc.hasNextLine()){\n currName = sc.nextLine();\n dbNames.add(currName);\n } \n }\n sc.close();\n\n //if database name already in index, exit\n if ( dbNames.contains(name) ){return true;}\n\n } catch(FileNotFoundException ex){}\n \n //add new database name to list of dbs\n dbNames.add(name);\n\n //create / overwrite index file\n try {\n fw = new FileWriter(\"databases/index.txt\");\n } catch (IOException ex2){\n System.out.println(\"ERROR: index not found and could not be created\");\n return false;\n }\n\n //write array of database names to file\n for (String dbName : dbNames){\n try {\n fw.write(dbName);\n fw.write(\"\\n\");\n } catch (IOException ex3) {\n System.out.println(\"ERROR: could not write to index\");\n }\n }\n\n try {\n fw.close();\n } catch (IOException ex4){\n System.out.println(\"ERROR: filewriter could not be closed\");\n return false;\n }\n\n return true;\n }",
"public static void update(Transcription t) throws IOException, SQLException\r\n {\r\n IndexWriter writer = null;\r\n Analyzer analyser;\r\n Directory directory;\r\n /**@TODO parameterize this location*/\r\n String dest = \"/usr/indexTranscriptions\";\r\n\r\n directory = FSDirectory.getDirectory(dest, true);\r\n analyser = new StandardAnalyzer();\r\n writer = new IndexWriter(directory, analyser, true);\r\n Term j=new Term(\"id\",\"\"+t.getLineID());\r\n writer.deleteDocuments(j);\r\n Document doc=new Document();\r\n Field field;\r\n field = new Field(\"text\", t.getText(), Field.Store.YES, Field.Index.ANALYZED);\r\n doc.add(field);\r\n field = new Field(\"comment\", t.getComment(), Field.Store.YES, Field.Index.ANALYZED);\r\n doc.add(field);\r\n field = new Field(\"creator\", \"\" + t.UID, Field.Store.YES, Field.Index.ANALYZED);\r\n doc.add(field);\r\n field = new Field(\"security\", \"\" + \"private\", Field.Store.YES, Field.Index.ANALYZED);\r\n doc.add(field);\r\n field = new Field(\"line\", \"\" + t.getLine(), Field.Store.YES, Field.Index.ANALYZED);\r\n doc.add(field);\r\n field = new Field(\"page\", \"\" + t.getFolio(), Field.Store.YES, Field.Index.ANALYZED);\r\n doc.add(field);\r\n field = new Field(\"id\", \"\" + t.getLineID(), Field.Store.YES, Field.Index.ANALYZED);\r\n doc.add(field);\r\n field = new Field(\"manuscript\", \"\" + new Manuscript(t.getFolio()).getID(), Field.Store.YES, Field.Index.ANALYZED);\r\n doc.add(field);\r\n field = new Field(\"projectID\", \"\" + t.getProjectID(), Field.Store.YES, Field.Index.ANALYZED);\r\n doc.add(field);\r\n writer.addDocument(doc);\r\n writer.commit();\r\n \twriter.close();\r\n\r\n }",
"public void reIndex(final Term recordIdTerm,\n\t\t\t\t\t\tfinal Document doc) {\t\n\t\ttry {\n\t\t\t_reopenToken = _trackingIndexWriter.updateDocument(recordIdTerm, \n\t\t\t\t\t\t\t\t\t\t\t\t\t \t\t doc);\n\t\t\tlog.debug(\"{} document re-indexed in lucene\",recordIdTerm.text());\n\t\t} catch(IOException ioEx) {\n\t\t\tlog.error(\"Error in lucene re-indexing operation: {}\",ioEx.getMessage(),\n\t\t\t\t\t\t\t\t\t\t\t \t\t ioEx);\n\t\t} finally {\n\t\t\ttry {\n\t\t\t\t_indexWriter.commit();\n\t\t\t} catch (IOException ioEx) {\n\t\t\t\tlog.error(\"Error while commiting changes to Lucene index: {}\",ioEx.getMessage(),\n\t\t\t\t\t\t\t\t\t\t\t\t \t\t \t\t\t\t\t ioEx);\n\t\t\t}\n\t\t}\n\t}",
"protected synchronized void updateIndex(DirectoryManagerIndex newIndex) {\n \n // Sanity check.\n if ((newIndex == null) && (index == null))\n throw new DirectoryManagerConfigurationException(\"Index not initialized but file \" + configuration.getIndexFilename() + \" still marked as outdated\");\n \n // Update existing index.\n index = newIndex;\n \n }",
"private synchronized void updateLogCount() {\n this.logCount++;\n }",
"public void WriteLineByField(Context oContext, String SearchStr, int FieldIndex, int WriteFieldIndex, String WriteFieldValue){\n\t\tArrayList <String> Lines = ReadLines(oContext);\n\t\tint LineCount = Lines.size();\n\t\tint iCtr ;\n\t\tString newLine = null; \n\t\tfor ( iCtr =0; iCtr < LineCount; iCtr++)\n\t\t{ \n\t\t\tString subValues[] = Lines.get(iCtr).split(\"~\");\n\t\t\t//Id check\n\t\t\tif(SearchStr.compareTo(subValues[FieldIndex]) == 0){\n\t\t\t\tfor(int jCtr = 0; jCtr < subValues.length; jCtr ++){\n\t\t\t\t\tsubValues[WriteFieldIndex] = subValues[WriteFieldIndex].replace(subValues[WriteFieldIndex],WriteFieldValue);\n\t\t\t\t}\n\t\t\t\tnewLine = subValues[0] + \"~\" + subValues[1] + \"~\" + subValues[2] + \"~\" + subValues[3] + \"~\" +subValues[4];\n\t\t\t\tLines.set(iCtr, newLine);\n\t\t\t}\t\t\n\t\t}\n\t\tSystem.out.println(Lines.toString());\n\t\tWriteLines(Lines, oContext);\n\t}",
"private void indexItem(IndexDocument indexDoc) {\n if(bDebug) System.out.println(\"\\n*** document to index - \" + indexDoc);\n Indexer indexer=null;\n try {\n indexer=new Indexer(PetstoreConstants.PETSTORE_INDEX_DIRECTORY, false);\n PetstoreUtil.getLogger().log(Level.FINE, \"Adding document to index: \" + indexDoc.toString());\n indexer.addDocument(indexDoc);\n } catch (Exception e) {\n PetstoreUtil.getLogger().log(Level.WARNING, \"index.exception\", e);\n e.printStackTrace();\n } finally {\n try {\n // must close file or will not be able to reindex\n if(indexer != null) {\n indexer.close();\n }\n } catch (Exception ee) {\n ee.printStackTrace();\n }\n }\n }",
"public static void fileEditor(String path, String search, String replace) {\t \t\n\t\t\ttry {\n\t\t\t\t File log= new File(path);\t \t\n\t\t\t FileReader fr = new FileReader(log);\n\t\t\t String s;\n\t\t\t String totalStr = \"\";\n\t\t\t try (BufferedReader br = new BufferedReader(fr)) {\n\t\t\t while ((s = br.readLine()) != null) { totalStr += s + \"\\n\"; }\t \n\t\t\t totalStr = totalStr.replaceAll(search, replace);\n\t\t\t FileWriter fw = new FileWriter(log);\n\t\t\t fw.write(totalStr);\n\t\t\t fw.close();\n\t\t\t }\n\t\t\t } catch(Exception e) { System.out.println(\"Problem reading file.\"); }\n\t\t\t}",
"private void addEntry(String word, String file, int position, HashMap<String, ArrayList<Integer>> subIndex) {\n\t\tif (subIndex.containsKey(word)) {\r\n\t\t\t// checks if the file name is a key in the nested\r\n\t\t\t// hash map of the word\r\n\t\t\tsubIndex.get(word).add(position);\r\n\t\t\r\n\t\t/*\r\n\t\t * if the word is not yet a key, create a new entry in the hash map.\r\n\t\t * Create new hash map to hold the file the word is found and an array\r\n\t\t * to find the position Then put that in the wordMap hash map as value\r\n\t\t * and the word as a key.\r\n\t\t */\r\n\t\t}else {\r\n\t\t\tsubIndex.put(word, new ArrayList<Integer>());\r\n\t\t\tsubIndex.get(word).add(position);\r\n\t\t\r\n\t\t}\r\n\t\r\n\t}",
"public synchronized void update(long entry, String type, String path)\n throws IOException {\n if (type == null)\n throw new IllegalArgumentException(\"Type cannot be null\");\n if (path == null)\n throw new IllegalArgumentException(\"Path cannot be null\");\n \n // Check if the new path fits the current index\n int typeLengthInBytes = type.getBytes().length;\n int pathLengthInBytes = path.getBytes().length;\n \n // Make sure there is still room left for an additional entry. One entry\n // consists of the uuid, the path and a closing '\\n'\n if (typeLengthInBytes >= bytesPerType || pathLengthInBytes >= bytesPerPath) {\n \n // Make sure the type field is long enough\n int newBytesPerType = bytesPerType;\n if (typeLengthInBytes >= bytesPerType) {\n logger.info(\"Type doesn't fit, triggering index resize\");\n while (newBytesPerType < typeLengthInBytes)\n newBytesPerType *= 2;\n }\n \n // Make sure the path field is long enough\n int newBytesPerPath = bytesPerPath;\n if (pathLengthInBytes >= bytesPerPath) {\n logger.info(\"Path doesn't fit, triggering index resize\");\n while (newBytesPerPath < pathLengthInBytes)\n newBytesPerPath *= 2;\n }\n \n bytesPerSlot = resize(bytesPerId, newBytesPerType, newBytesPerPath);\n }\n \n long startOfEntry = IDX_START_OF_CONTENT + (entry * bytesPerSlot);\n \n // Write the path to the index\n idx.seek(startOfEntry);\n idx.skipBytes(bytesPerId);\n idx.write(type.getBytes());\n idx.write(new byte[bytesPerType - type.getBytes().length]);\n idx.write(path.getBytes());\n idx.writeChar('\\n');\n idx.write(new byte[bytesPerPath - pathLengthInBytes - 2]);\n \n logger.debug(\"Updated uri at address '{}' to {}\", entry, path);\n }",
"public void truncate() {\n\t\ttry {\n\t\t\t_reopenToken = _trackingIndexWriter.deleteAll();\n\t\t\tlog.warn(\"lucene index truncated\");\n\t\t} catch(IOException ioEx) {\n\t\t\tlog.error(\"Error truncating lucene index: {}\",ioEx.getMessage(),\n\t\t\t\t\t\t\t\t\t\t\t \t\t \t ioEx);\t\t\t\n\t\t} finally {\n\t\t\ttry {\n\t\t\t\t_indexWriter.commit(); \n\t\t\t} catch (IOException ioEx) {\n\t\t\t\tlog.error(\"Error truncating lucene index: {}\",ioEx.getMessage(),\n\t\t\t\t\t\t\t\t\t\t\t\t \t\t\t ioEx);\n\t\t\t}\n\t\t}\n\t}",
"private void updateFile() {\n\t\tPrintWriter outfile;\n\t\ttry {\n\t\t\toutfile = new PrintWriter(new BufferedWriter(new FileWriter(\"stats.txt\")));\n\t\t\toutfile.println(\"15\"); // this is the number\n\t\t\tfor (Integer i : storeInfo) {\n\t\t\t\toutfile.println(i); // we overwrite the existing files\n\t\t\t}\n\t\t\tfor (String s : charBought) {\n\t\t\t\toutfile.println(s); // overwrite the character\n\t\t\t}\n\t\t\tfor (String s : miscBought) {\n\t\t\t\toutfile.println(s);\n\t\t\t}\n\t\t\toutfile.close();\n\t\t}\n\t\tcatch (IOException ex) {\n\t\t\tSystem.out.println(ex);\n\t\t}\n\t}",
"@Scheduled(fixedRate = 5000)\n public void refreshAllIndex() {\n\n HashMap<String, String> dictlist = new HashMap<>();\n\n //get the file list\n try {\n dictlist = FileUtil.subFolderList(fieryConfig.getIndexpath());\n } catch (Exception e) {\n e.printStackTrace();\n }\n\n //load all index if not contain on folder\n for (Map.Entry<String, String> e : dictlist.entrySet()) {\n String foldername = e.getKey();\n String folderpath = e.getValue();\n if (!readerList.containsKey(foldername)) {\n log.info(\"start load index foldername:\" + foldername + \" abspath:\" + folderpath);\n //open index\n boolean ret = this.openIndex(foldername, folderpath);\n\n //warning this may cause bug\n //loaded fail? clean it\n if (!ret) {\n FileUtil.deleteDir(folderpath);\n }\n }\n }\n\n\n /////////////////////\n // recycle expire index\n /////////////////////\n for (Map.Entry<String, DirectoryReader> e : readerList.entrySet()) {\n String dbname = e.getKey();\n\n try {\n Long dbtime = Long.parseLong(dbname);\n\n if (dbtime < DateTimeHepler.getBeforDay(fieryConfig.getKeepdataday())) {\n //closed all\n if (analyzerList.containsKey(dbname)) {\n analyzerList.get(dbname).close();\n analyzerList.remove(dbname);\n }\n if (directorList.containsKey(dbname)) {\n directorList.get(dbname).close();\n directorList.remove(dbname);\n }\n if (readerList.containsKey(dbname)) {\n readerList.get(dbname).close();\n readerList.remove(dbname);\n }\n\n //remove the folder\n FileUtil.deleteDir(fieryConfig.getIndexpath() + \"/\" + dbname);\n }\n } catch (Exception ex) {\n ex.printStackTrace();\n }\n }\n\n\n /////////////////////\n // refresh already loaded index\n /////////////////////\n for (Map.Entry<String, DirectoryReader> e : readerList.entrySet()) {\n\n String dbname = e.getKey();\n DirectoryReader diskReader = e.getValue();\n\n try {\n Date start = new Date();\n\n DirectoryReader tmp = DirectoryReader.openIfChanged(diskReader);\n if (tmp != null) {\n diskReader.close();\n diskReader = tmp;\n readerList.put(dbname, diskReader);\n Date end = new Date();\n log.info(\"Reload Index:\" + dbname + \" cost:\" + (end.getTime() - start.getTime()) + \" totalcount:\" + diskReader.numDocs());\n }\n\n } catch (Exception exx) {\n exx.printStackTrace();\n log.error(exx.getMessage());\n }\n }\n /////////////////////\n //refresh the all in one searcher\n /////////////////////\n\n this.reloadSearch();\n\n }",
"private void loadInvertedIndexFromFile(String indexPath) {\n try {\n invIndex = new HashMap<String, HashMap<String, IndexEntry>>();\n Scanner sc = new Scanner(new File(indexPath));\n int lineNum = 0;\n while (sc.hasNextLine()) {\n String entry = sc.nextLine().trim();\n if (!entry.isEmpty()) {\n String[] termValue = entry.trim().split(\" -> \");\n String[] docEntries = termValue[1].split(\"\\\\) \\\\(\");\n // clean up the opening and closing paranthesis post split\n if (docEntries[0].charAt(0) == '(')\n docEntries[0] = docEntries[0].substring(1);\n String lastDocEntry = docEntries[docEntries.length - 1];\n if (lastDocEntry.charAt(lastDocEntry.length() - 1) == ')')\n docEntries[docEntries.length - 1] =\n lastDocEntry.substring(0, lastDocEntry.length() - 1);\n HashMap<String, IndexEntry> invEntryVal = new HashMap<String, IndexEntry>();\n for (String docEntry : docEntries) {\n String[] components = docEntry.split(\", \");\n String docID = components[0];\n int tf = Integer.parseInt(components[1]);\n\n // if term positions information present\n List<Integer> termPos = new LinkedList<Integer>();\n if (components.length > 2) {\n String[] pos = components[2].replace(\"[\", \"\").replace(\" ]\", \"\").split(\" \");\n for (String eachPos : pos)\n termPos.add(Integer.parseInt(eachPos));\n }\n IndexEntry ie = new IndexEntry(docID, termPos, tf);\n invEntryVal.put(docID, ie);\n }\n invIndex.put(termValue[0], invEntryVal);\n System.out.println((++lineNum) + \" | \" + termValue[0]);\n }\n }\n sc.close();\n } catch (Exception e) {\n e.printStackTrace();\n }\n }",
"public void index(final Document doc) {\t\n\t\ttry {\n\t\t\t_reopenToken = _trackingIndexWriter.addDocument(doc);\n\t\t\tlog.debug(\"document indexed in lucene\");\n\t\t} catch(IOException ioEx) {\n\t\t\tlog.error(\"Error while in Lucene index operation: {}\",ioEx.getMessage(),\n\t\t\t\t\t\t\t\t\t\t\t \t\t ioEx);\n\t\t} finally {\n\t\t\ttry {\n\t\t\t\t_indexWriter.commit();\n\t\t\t} catch (IOException ioEx) {\n\t\t\t\tlog.error(\"Error while commiting changes to Lucene index: {}\",ioEx.getMessage(),\n\t\t\t\t\t\t\t\t\t\t\t\t \t\t \t\t\t\t\t ioEx);\n\t\t\t}\n\t\t}\n\t}",
"@Override\n @Secured(SecurityRoles.ADMINISTRATOR)\n public void reindex() {\n revisionDao.deleteAll();\n // OK, launches a new indexation\n indexFromLatest();\n }",
"private static void createIndex() {\n XML_Shell workFile = new XML_Shell();\n String messageFromServer = ClientService.getLastMessageFromServer();\n\n try {\n XML_Manager.stringToDom(messageFromServer, workFile);\n } catch (SAXException | ParserConfigurationException | IOException | TransformerException e) {\n e.printStackTrace();\n }\n\n }",
"public static String getLogEntry(int index){\n if(index < 0 || index >= log.size()){\n return \"\";\n }\n return log.get(index);\n }",
"public int replaceFixedLengthData(int index, int[] data) {\n for(int i = 0; i<data.length; i++) {\n theList.set(index+i,data[i]);\n }\n return index;\n }",
"protected void addEntryToIndex(String key, RecordHeader newRecord, int currentNumRecords) throws IOException {\n DbByteArrayOutputStream temp = new DbByteArrayOutputStream(MAX_KEY_LENGTH);\n (new DataOutputStream(temp)).writeUTF(key);\n if (temp.size() > MAX_KEY_LENGTH) {\n throw new IOException(\"Key is larger than permitted size of \" + MAX_KEY_LENGTH + \" bytes\");\n }\n file.seek(indexPositionToKeyFp(currentNumRecords));\n temp.writeTo(file);\n file.seek(indexPositionToRecordHeaderFp(currentNumRecords));\n newRecord.write(file);\n newRecord.setIndexPosition(currentNumRecords);\n writeNumRecordsHeader(currentNumRecords+1);\n\n getMemIndex().put(key, newRecord);\n }",
"@Test\n public void setFieldIndexFormat() throws Exception {\n Document doc = new Document();\n DocumentBuilder builder = new DocumentBuilder(doc);\n builder.write(\"A\");\n builder.insertBreak(BreakType.LINE_BREAK);\n builder.insertField(\"XE \\\"A\\\"\");\n builder.write(\"B\");\n\n builder.insertField(\" INDEX \\\\e \\\" · \\\" \\\\h \\\"A\\\" \\\\c \\\"2\\\" \\\\z \\\"1033\\\"\", null);\n\n doc.getFieldOptions().setFieldIndexFormat(FieldIndexFormat.FANCY);\n doc.updateFields();\n\n doc.save(getArtifactsDir() + \"Field.SetFieldIndexFormat.docx\");\n //ExEnd\n }",
"private void reIndex()\n {\n for(int i = 0; i < NodeList.size(); i++)\n NodeList.get(i).setID(i);\n ID = NodeList.size();\n }",
"private void indexUpdates(UpdateQueryResult updates) {\r\n Iterator<HashMap<String, String>> i = updates.getIterator();\r\n while (i.hasNext()) {\r\n HashMap<String, String> values = i.next();\r\n \r\n \t// during index default solr fields are indexed separately\r\n \tString articleId = values.get(\"KnowledgeArticleId\");\r\n \tString title = values.get(\"Title\");\r\n \tvalues.remove(\"Title\");\r\n \tString summary = values.get(\"Summary\");\r\n \tvalues.remove(\"Summary\");\r\n \t\r\n \ttry {\r\n \t\tif (UtilityLib.notEmpty(articleId) && UtilityLib.notEmpty(title)) {\r\n \t\t\t// index sObject\r\n \t\t\t// default fields every index must have\r\n \t\t\tStringBuilder sb = new StringBuilder();\r\n \t\t\tContent c = new Content();\r\n \t\t\tc.setKey(articleId);\r\n \t\t\tsb.setLength(0);\r\n \t\t\tsb.append(summary);\r\n \t\t\tc.setData(sb.toString().getBytes());\r\n \t\t\tc.addMetadata(\"Content-Type\", \"text/html\");\r\n \t\t\tc.addMetadata(\"title\", title);\r\n \t\t\t\r\n \t\t\tLOG.debug(\"Salesforce Crawler: Indexing articleId=\"+articleId+\" title=\"+title+\" summary=\"+summary);\r\n \t\t\t\r\n \t\t\t// index articleType specific fields\r\n \t\t\tfor (Entry<String, String> entry : values.entrySet()) {\r\n \t\t\t\tc.addMetadata(entry.getKey(), entry.getValue().toString());\r\n \t\t\t\tif (!entry.getKey().equals(\"Attachment__Body__s\")) {\r\n \t\t\t\t\tLOG.debug(\"Salesforce Crawler: Indexing field key=\"+entry.getKey()+\" value=\"+entry.getValue().toString());\r\n \t\t\t\t}\r\n \t\t\t}\r\n \t\t\tstate.getProcessor().process(c);\r\n \t\t}\r\n } catch (Exception e) {\r\n \tUtilityLib.errorException(LOG, e);\r\n \tstate.getStatus().incrementCounter(Counter.Failed);\r\n }\r\n }\r\n }",
"public static String seekIndex(File indexFile ,int authorid)\n\t{\n\t\tString index = \"\";\n\t\tString line = \"\";\n\t\tString id = \"\";\n\t\tBufferedReader reader = null;\n\t\ttry {\n\t\t\treader = new BufferedReader(new FileReader(indexFile.getAbsolutePath()));\n\t\t\twhile((line=reader.readLine())!=null)\n\t\t\t{\n\t\t\t\tid = line.split(\" \")[0];\n\t\t\t\tif(!id.equals(String.valueOf(authorid)))\n\t\t\t\t\tcontinue;\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tindex = line;\n\t\t\t\t\tbreak;\n\t\t\t\t}\n\t\t\t}\t\n\t\t\treader.close();\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\n\t\t\n\t\treturn index;\n\t}",
"@Override\n public void visit(Index node) {\n }",
"public void flush(String filename) throws IOException {\n // open the file\n // the false part means that the buffer won't be automatically flushed\n // we flush after every term\n PrintStream out = new PrintStream(new BufferedOutputStream(\n new FileOutputStream(filename)), false);\n\n // STORE THE INDEX\n\n // an iterator over all terms\n Iterator i = index.keySet().iterator();\n\n // temporary variables\n Iterator docs;\n HashMap docList;\n String doc;\n int[] t;\n\n // the first line is the number of terms\n out.println(index.size());\n String word;\n\n // loop through each term\n while (i.hasNext()) {\n word = (String) i.next();\n\n // print the term\n out.println(word);\n\n // get variables to loop through documents containing the term\n docList = (HashMap) index.get(word);\n docs = docList.keySet().iterator();\n\n // loop through documents containing the term\n while (docs.hasNext()) {\n // get the document and frequency\n doc = (String) docs.next();\n t = (int[]) docList.get(doc);\n\n // store the document and frequency\n out.println(doc);\n out.println(t[0]);\n }\n\n // put another newline on there and flush the buffer\n out.println();\n out.flush();\n }\n\n // close the file\n out.close();\n }",
"@Override\n\t\tpublic void add(int index, LogCate element) {\n\t\t\tsuper.add(index, element);\n\t\t\tLogCateManager.getInstance().onLogsChanged();\n\t\t}",
"public void printInvertedIndex(Directory index, boolean printToScreen, boolean printToFile){\n\t\t \n\t\ttry{\n\t\t\t //Creating our index\n\t\t\t IndexReader reader = DirectoryReader.open(index);\n\n\t\t\t HashMap<String, HashSet<String>> hmap = convertIndexToMap(reader);\n\t\t\t printIndexMap(hmap, printToScreen, printToFile);\n\n\t\t\t reader.close(); \n\t\t}\n\t\tcatch(Exception e){\n\t\t\tSystem.out.println(\"There was some exception thrown during printing: \" + e.getStackTrace());\n\t\t}\n\t}",
"public void editDetailLogFiles(){\r\n\t\tString filter1 = \"_advanced_detail_analyzed\";\r\n\t\tString filter2 = \"_standard_detail_analyzed\";\r\n\t\t\r\n\t\t//begin with creation of new file\r\n\t\tJFileChooser fc = new JFileChooser();\r\n\t\tfc.setSize(2560, 1300);\r\n\t\t//set directory and \".log\" filter\r\n\t\tfc.setMultiSelectionEnabled(true);\r\n\t\tfc.setCurrentDirectory(new File(System.getProperty(\"user.dir\")));\r\n\t\tfc.setFileSelectionMode(JFileChooser.FILES_ONLY);\r\n\t\t\r\n\t\tint status = fc.showDialog(this, Messages.getString(\"EditLogControlPanel.approveButton\"));\r\n\t\t\r\n\t\tif(status == JFileChooser.APPROVE_OPTION){\r\n\t\t\tFile[] tmpFiles = fc.getSelectedFiles();\r\n\t\t\t\r\n\t\t\tfor(File file:tmpFiles){\r\n\t\t\t\t//get log names\r\n\t\t\t\tArrayList<File> files = getFileList(file);\r\n\t\t\t\r\n\t\t\t\tfor(File f:files){\r\n\t\t\t\t\tif(f.getName().contains(filter1) || f.getName().contains(filter2)){\r\n\t\t\t\t FileWriter fstream;\r\n\t\t\t\t\t\ttry {\r\n\t\t\t\t\t\t\tif(!(new File(f.getParent() + \"/corrected/\")).exists()) (new File(f.getParent() + \"/corrected/\")).mkdir();\r\n\t\t\t\t\t\t\tfstream = new FileWriter(f.getParent() + \"/corrected/\" + f.getName(), false);\r\n\t\t\t\t\t\t\tBufferedWriter out = new BufferedWriter(fstream);\r\n\t\t\t\t\t\t\t\r\n\t\t\t\t\t\t\tint vehiclesTotal = 0;\r\n\t\t\t\t\t\t\tString[] data;\r\n\t\t\t\t\t\t\tfloat[] tmpData = new float[100];\r\n\t\t\t\t\t\t\tfloat[][] tmpData2 = new float[100][100];\r\n\t\t\t\t\t\t\tint counter = 0;\r\n\t\t\t\t\t\t\t//read file\r\n\t\t\t\t\t BufferedReader reader;\r\n\t\t\t\t\t \r\n\t\t\t\t\t //get maximal vehicles count and calculates values of line\r\n\t\t\t\t\t try{\r\n\t\t\t\t\t reader = new BufferedReader(new FileReader(f));\r\n\t\t\t\t\t String line = reader.readLine(); \r\n\t\t\t\t\t while(line != null){\t\r\n\t\t\t\t\t \tif(!line.substring(0, 1).equals(\"#\") && !line.equals(\"\")){\r\n\t\t\t\t\t \t\tdata = line.split(\" \");\r\n\t\t\t\t\t \t\t\r\n\t\t\t\t\t \t\tfor(int i = 1; i < data.length-1;i++){\r\n\t\t\t\t\t \t\t\ttmpData[counter] += Integer.parseInt(data[i]);\r\n\t\t\t\t\t \t\t\tvehiclesTotal += Integer.parseInt(data[i]);\r\n\t\t\t\t\t \t\t\ttmpData2[counter][i-1] = Integer.parseInt(data[i]);\r\n\t\t\t\t\t \t\t}\r\n\t\t\t\t\t \t\tcounter++;\r\n\t\t\t\t\t \t}\r\n\t\t\t\t\t \telse out.write(line + \"\\n\");\r\n\t\t\t\t\t \t\r\n\t\t\t\t\t \tline = reader.readLine();\r\n\t\t\t\t\t }\r\n\t\t\t\t\t \r\n\t\t\t\t\t\t\t} catch (Exception e) {\r\n\t\t\t\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t\t\t\t}\r\n\t\t\t\t\t \r\n\t\t\t\t\t float tmpSum = 0;\r\n\t\t\t\t\t\t\tfloat vehiclesTotal2 = 0;\r\n\t\t\t\t\t\t\tfor(int l = 0; l < counter;l++){\t\r\n\t\t\t\t\t\t\t\tout.write(\"\" + l);\r\n\t\t\t\t\t\t\t\tfor(int j = 0; j < counter-1; j++) out.write(\" \" + (int)tmpData2[l][j]);\r\n\t\t\t\t\t\t\t\t\r\n\t\t\t\t\t\t\t\t\r\n\t\t\t\t\t\t\t\tif(l == 0){\r\n\t\t\t\t\t\t\t\t\tout.write(\" \" + (float)(tmpData[l]/vehiclesTotal) + \"\\n\");\r\n\t\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\t\telse if(l == 1){\r\n\t\t\t\t\t\t\t\t\ttmpSum = 0;\r\n\t\t\t\t\t\t\t\t\tfor(int i = l; i < counter; i++) tmpSum += tmpData[i];\r\n\t\t\t\t\t\t\t\t\tout.write(\" \" + (float)(tmpSum/vehiclesTotal) + \"\\n\");\r\n\t\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\t\telse{\r\n\t\t\t\t\t\t\t\t\ttmpSum = 0;\r\n\t\t\t\t\t\t\t\t\tfor(int i = l; i < counter; i++) tmpSum += tmpData[i];\r\n\t\t\t\t\t\t\t\t\t\r\n\t\t\t\t\t\t\t\t\tvehiclesTotal2 = vehiclesTotal;\r\n\t\t\t\t\t\t\t\t\tfor(int n = 0; n < (l-1);n++){\r\n\t\t\t\t\t\t\t\t\t\tfor(int o = 0; o < l;o++){\r\n\t\t\t\t\t\t\t\t\t\t\tvehiclesTotal2 -= tmpData2[o][n];\r\n\t\t\t\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\t\t\tout.write(\" \" + (float)(tmpSum/vehiclesTotal2) + \"\\n\");\r\n\t\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\t out.close();\r\n\t\t\t\t\t\t} catch (IOException e1) {\r\n\t\t\t\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\t\t\t\te1.printStackTrace();\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\r\n\t\t\t\t \r\n\t\t\t\t\t}\t\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"void completeCurrentLog() throws IOException;",
"public void setIndex(int newIndex)\r\n {\r\n\t if(newIndex < 1)\r\n\t\t index = 1;\r\n\t else if(newIndex > getNumberOfLines())\r\n\t\t index = getNumberOfLines();\r\n\t else\r\n\t\t index = newIndex;\r\n }",
"void relocateLogFile(Path destinationPath) throws IOException;",
"private void flushCurrentIndexBlock() throws IOException {\n if (currentMemoryIndex.documentsInIndex() < 1) {\n return;\n }\n\n logger.info(\"Flushing current memory Index. id = \" + indexBlockCount);\n\n final MemoryIndex flushingMemoryIndex = currentMemoryIndex;\n final File shardFolder = getNextIndexShardFolder(1);\n\n try {\n // reset the current index\n // - this makes the flush operation thread safe while continuing to add new documents.\n resetCurrentMemoryIndex();\n } catch (Exception ex) {\n throw new IOException(ex);\n }\n\n try {\n // first flush the index to disk\n FlushToDisk.flushMemoryIndex(flushingMemoryIndex, shardFolder.getAbsolutePath(), false);\n\n // indicate that the flushing part of this thread is done\n synchronized (geometricParts) {\n // add flushed index to the set of bins -- needs to be a synconeous action\n geometricParts.add(0, shardFolder.getAbsolutePath());\n updateIndex();\n flushingMemoryIndex.close();\n }\n\n } catch (IOException e) {\n logger.severe(e.toString());\n }\n }",
"public static void addFile(Path inputFile, InvertedIndex index) throws IOException {\n\t\tStemmer stemmer = new SnowballStemmer(DEFAULT);\n\t\tint count = 0;\n\n\t\ttry(BufferedReader reader = Files.newBufferedReader(inputFile, StandardCharsets.UTF_8);){\n\t\t\tString line = reader.readLine();\n\t\t\tString result = inputFile.toString();\n\t\t\twhile(line != null){\n\t\t\t\tString[] parsed = TextParser.parse(line); //putting parsed words into new string array\n\t\t\t\tfor(String words : parsed) { //getting the words in the parsed line\n\t\t\t\t\tcount++;\n\t\t\t\t\tindex.add(stemmer.stem(words).toString(), result, count); //adds stemmed word into tree set\n\t\t\t\t}\n\t\t\t\tline = reader.readLine();\n\t\t\t}\n\t\t}\n\t}",
"public static void InvertedDocFrequency() throws FileNotFoundException {\n //int totalDoc = totaldocument;\n int i = 0;\n for(Entry<String, List<Integer>> entry: dictionary.entrySet()) {\n List<Integer> docFrequency = new ArrayList<>();\n //\tList<Double> idfValue = new ArrayList<>();\n docFrequency = entry.getValue(); //again taking the list of word terms from the same dictionary hashmap\n int df = docFrequency.get(totaldocument+1); // it will save the idf of every word term at the 57th index\n double ans = Math.log10(df);\n ans /= totaldocument;\n\n idfFinal.add(i,ans); //updatin\n i++;\n }\n saveidf();\n }",
"public void updateLog(String newName){\r\n\t\tString timeStamp = new SimpleDateFormat(\"yyyy/MM/dd HH:mm.ss\").format(new java.util.Date());\r\n\t\tlogger.log(Level.SEVERE,\"Previous name:{0}, New Name: {1}, Date: {2}\", new Object[] {name, newName,timeStamp});\r\n\t}",
"public void writeToLogFile(String entry) {\r\n\t\ttry{\r\n\t\t\tStringBuilder out = new StringBuilder(50);\r\n\t\t\tCalendar cal = Calendar.getInstance();\r\n\t\t SimpleDateFormat sdf = new SimpleDateFormat(DATE_FORMAT_NOW);\r\n\t\t out.append(sdf.format(cal.getTime()) + \";\" + entry);\r\n\t\t \r\n\t\t this.write(out);\r\n\t\t}catch (Exception e){\r\n\t\t System.err.println(\"Error: \" + e.getMessage());\r\n\t\t}\r\n\t}",
"public EventLogMessageEntry getEventLogMessage(int index);",
"protected void writeRecordHeaderToIndex(RecordHeader header) throws IOException {\n file.seek(indexPositionToRecordHeaderFp(header.indexPosition));\n header.write(file);\n }",
"List<ChangedFile> addUntrackedFilesToIndex(Map<Project, List<ChangedFile>> files);",
"private void setStat(int value, int index) {\n setStringStat(String.valueOf(value), index);\n }",
"void index(IDocument document, IIndexerOutput output) throws java.io.IOException;",
"public void cleanLogFile() throws IOException{\r\n\t\t//begin with creation of new file\r\n\t\tJFileChooser fc = new JFileChooser();\r\n\t\t//set directory and \".log\" filter\r\n\t\tfc.setMultiSelectionEnabled(true);\r\n\t\tfc.setCurrentDirectory(new File(System.getProperty(\"user.dir\")));\r\n\t\tfc.setFileSelectionMode(JFileChooser.FILES_ONLY);\r\n\t\tfc.setFileFilter(logFileFilter_);\r\n\t\t\r\n\t\tint status = fc.showDialog(this, Messages.getString(\"EditLogControlPanel.approveButton\"));\r\n\t\t\r\n\t\t//the coordinates with a port\r\n\t\tclass MixZoneCoordinate{\r\n\t\t\tpublic int xCoordinate = -1;\r\n\t\t\tpublic int yCoordinate = -1;\r\n\t\t\tpublic int port = -1;\r\n\t\t\t\r\n\t\t\tpublic MixZoneCoordinate(int x,int y, int p){\r\n\t\t\t\txCoordinate = x;\r\n\t\t\t\tyCoordinate = y;\r\n\t\t\t\tport = p;\r\n\t\t\t}\r\n\t\t}\r\n\t\t\r\n\t\t//choose one or mor logs\r\n\t\tif(status == JFileChooser.APPROVE_OPTION){\r\n\t\t\t File[] files = fc.getSelectedFiles();\r\n\t\t\t for(File file:files){\r\n\t\t\t\t\tArrayList<MixZoneCoordinate> mixZoneCoordinateList = new ArrayList<MixZoneCoordinate>();\r\n\t\t\t\t\t\r\n\t\t\t BufferedReader reader;\r\n\t\t\t FileWriter fstream = new FileWriter(file.getPath().substring(0, file.getPath().length() - 4) +\"_cleaned.log\");\r\n\t\t\t BufferedWriter out = new BufferedWriter(fstream);\r\n\t\t\t \r\n\t\t\t try{\r\n\t\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t\t String line = reader.readLine();\r\n\t\t\t \r\n\t\t\t boolean headerSeperator = true;\r\n\t\t\t \r\n\t\t\t ArrayList<String> savedLines = new ArrayList<String>();\r\n\t\t\t \r\n\t\t\t while(line != null){\r\n\t\t\t \t//read header completely\r\n\t\t\t \tif(line.length() >= 8 && line.substring(0, 8).equals(\"Mix-Zone\")){\r\n\t\t\t \t\tArrayList<String> savedLines2 = new ArrayList<String>();\r\n\t\t\t \t\tboolean saved = false;\r\n\t\t\t \t\tString[] lineSplitted = line.split(\":\");\r\n\t\t\t \t\t\r\n\t\t\t \t\tif(savedLines.size() < 1){\r\n\t\t\t \t\t\tsavedLines2.add(line);\r\n\t\t\t \t\t\tsaved = true;\r\n\t\t\t \t\t}\r\n\t\t\t \t\tfor(String savedLine:savedLines){\r\n\t\t\t \t\t\tif(!saved && Integer.parseInt(lineSplitted[2]) < Integer.parseInt(savedLine.split(\":\")[2])){\r\n\t\t\t \t\t\t\tsaved = true;\r\n\t\t\t \t\t\t\tsavedLines2.add(line);\r\n\t\t\t \t\t\t}\r\n\t\t\t \t\t\tsavedLines2.add(savedLine);\r\n\t\t\t \t\t}\r\n\t\t\t \t\tif(!saved)savedLines2.add(line);\r\n\t\t\t \t\tsavedLines = savedLines2;\r\n\t\t\t \t}\r\n\t\t\t \telse{\r\n\t\t\t \t\tif(headerSeperator){\r\n\t\t\t\t \t\tString xArray[];\r\n\t\t\t\t \t\tString yArray[];\r\n\t\t\t\t \t\tString writeLine =\"\"; \r\n\t\t\t\t \t\t\r\n\t\t\t\t \t\t//save all coordinates\r\n\t\t\t \t\t\tfor(int j = 0; j < savedLines.size(); j=j+2){\r\n\r\n\t\t\t \t\t\t\t\r\n\t\t\t\t\t \t\txArray = savedLines.get(j).split(\":\");\r\n\t\t\t\t\t \t\tyArray = savedLines.get(j+1).split(\":\");\r\n\r\n\t\t\t\t\t \t\twriteLine = \"Mix-Zone:\" + xArray[1] + \":\" + xArray[2] + \":\" + xArray[3] + \":\" + xArray[4];\r\n\t\t\t\t\t\t \t\r\n\t\t\t\t\t \t\tfor(int i = 5; i < xArray.length; i++) {\r\n\t\t\t\t\t \t\t\twriteLine += \":\" + (i-4) + \"=\" + xArray[i] + \"/\" + yArray[i];\r\n\t\t\t\t\t\t \t\t\r\n\t\t\t\t\t \t\t\tmixZoneCoordinateList.add(new MixZoneCoordinate(Integer.parseInt(xArray[i]), Integer.parseInt(yArray[i]), i-4));\r\n\t\t\t\t\t \t\t}\r\n\t\t\t\t\t \t\t\r\n\t\t\t\t\t \t\tout.write(writeLine + \"\\n\");\r\n\t\t\t \t\t\t}\r\n\t\t\t \t\t\t \t\t\r\n\t\t\t \t\t\tout.write(\"*******************\" + \"\\n\");\r\n\t\t\t \t\t\theaderSeperator=false;\r\n\t\t\t \t\t}\r\n\t\t\t \t\tint xCoord = -1;\r\n\t\t\t \t\tint yCoord = -1;\r\n\t\t\t \t\t\r\n\t\t\t \t\tString[] lineSplit = line.split(\":\");\r\n\t\t\t \t\tif(lineSplit.length == 23){\r\n\t\t\t \t\t\txCoord = Integer.parseInt(lineSplit[20]);\r\n\t\t\t \t\t\tyCoord = Integer.parseInt(lineSplit[22]);\t \t\t\t\r\n\t\t\t \t\t}\r\n\t\t\t \t\telse break;\r\n\t\t\t \t\t\r\n\t\t\t \t\t//check which coordinate is which port and write the result to file\r\n\t\t\t \t\tfor(MixZoneCoordinate c : mixZoneCoordinateList){\r\n\t\t\t\t\t\t\t\t\tlong dx = c.xCoordinate - xCoord;\r\n\t\t\t\t\t\t\t\t\tlong dy = c.yCoordinate - yCoord;\r\n\t\t\t\t\t\t\t\t\tlong distanceSquared = dx * dx + dy * dy;\r\n\t\t\t\t\t\t\t\t\tif(distanceSquared < 500000){\r\n\t\t\t\t\t\t\t\t\t\tout.write(lineSplit[0] + \":\" + lineSplit[1] + \":\" + lineSplit[2] + \":\" + lineSplit[3] + \":\" + lineSplit[4] + \":\" + lineSplit[5] + \":\" + lineSplit[6] + \":\" + lineSplit[7] + \":\" + lineSplit[8] + \":\" + lineSplit[9] + \":\" + lineSplit[10] + \":\" + lineSplit[11] + \":\" + lineSplit[12] + \":\" + lineSplit[13] + \":\" + lineSplit[14] + \":\" + lineSplit[15] + \":\" + lineSplit[16] + \":\" + lineSplit[17] + \":\" + lineSplit[18] + \":port:\" + c.port + \"\\n\");\r\n\t\t\t\t\t\t\t\t\t\tbreak;\r\n\t\t\t\t\t\t\t\t\t}\r\n\t\t\t \t\t}\t\r\n\t\t\t \t}\r\n\t\t\t \tline = reader.readLine();\r\n\t\t\t }\r\n\t\t\t \r\n\t\t\t out.close();\r\n\t\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t\t}\r\n\t\t\t }\r\n\t\t\t\t\r\n\t\t}\r\n\t\t\r\n\r\n\t}",
"public void finishedDirectIndexBuild()\n\t{\n\t\tif(logger.isInfoEnabled()){\n\t\t\tlogger.info(\"flushing utf block lexicon to disk after the direct index completed\");\n\t\t}\n\t\t//only write a temporary lexicon if there are any items in it\n\t\tif (TempLex.getNumberOfNodes() > 0)\n\t\t\twriteTemporaryLexicon();\n\n\t\t//merges the temporary lexicons\n\t\tif (tempLexFiles.size() > 0)\n\t\t{\n\t\t\ttry{\n\t\t\t\tmerge(tempLexFiles);\n\t\n\t\t\t\t//creates the offsets file\n\t\t\t\tfinal String lexiconFilename = \n\t\t\t\t\tindexPath + ApplicationSetup.FILE_SEPARATOR + \n\t\t\t\t\tindexPrefix + ApplicationSetup.LEXICONSUFFIX;\n\t\t\t\tLexiconInputStream lis = getLexInputStream(lexiconFilename);\n\t\t\t\tcreateLexiconIndex(\n\t\t\t\t\tlis,\n\t\t\t\t\tlis.numberOfEntries(),\n\t\t\t\t\t/* after inverted index is built, the lexicon will be transformed into a\n\t\t\t\t\t * normal lexicon, without block frequency */\n\t\t\t\t\tUTFLexicon.lexiconEntryLength\n\t\t\t\t\t); \n\t\t\t\tTermCount = lis.numberOfEntries();\n\t\t\t\tif (index != null)\n\t\t\t\t{\n\t\t\t\t\tindex.addIndexStructure(\"lexicon\", \"uk.ac.gla.terrier.structures.UTFBlockLexicon\");\n\t\t\t\t\tindex.addIndexStructureInputStream(\"lexicon\", \"uk.ac.gla.terrier.structures.UTFBlockLexiconInputStream\");\n\t\t\t\t\tindex.setIndexProperty(\"num.Terms\", \"\"+lis.numberOfEntries());\n\t\t\t\t\tindex.setIndexProperty(\"num.Pointers\", \"\"+lis.getNumberOfPointersRead());\n\t\t\t\t}\n\t\t\t} catch(IOException ioe){\n\t\t\t\tlogger.error(\"Indexing failed to write a lexicon index file to disk\", ioe);\n\t\t\t}\t\n\t\t}\n\t\telse\n\t\t\tlogger.warn(\"No temporary lexicons to merge, skipping\");\n\t\t\n\t}",
"public void writeToFile(StringBuilder text)throws IOException{\n\n Path filePath = Paths.get(\"index.txt\");\n if (!Files.exists(filePath)) {\n \t Files.createFile(filePath);\n \t}\n \tFiles.write(filePath, text.toString().getBytes(), StandardOpenOption.APPEND);\n }",
"public void indexFileOrDirectory(String fileName) {\r\n\r\n addFiles(new File(fileName));\r\n\r\n int originalNumDocs = writer.numRamDocs();\r\n for (File f : queue) {\r\n try {\r\n Document doc = new Document();\r\n\r\n // Creation of a simpledateformatter in order to print the last-modified-date of our files.\r\n SimpleDateFormat sdf = new SimpleDateFormat(\"MM/dd/yyyy HH:mm:ss\");\r\n String date = sdf.format(f.lastModified());\r\n\r\n if (f.getName().endsWith(\".html\")) {\r\n\r\n // Creation of a jsoup document to help us with our html parsing.\r\n org.jsoup.nodes.Document htmlFile = Jsoup.parse(f, null);\r\n String body = htmlFile.body().text();\r\n String title = htmlFile.title();\r\n String summary = getSummary(htmlFile);\r\n\r\n\r\n doc.add(new TextField(\"contents\", body + \" \" + title + \" \" + date, Field.Store.YES));\r\n doc.add(new TextField(\"title\", title, Field.Store.YES));\r\n doc.add(new StringField(\"path\", f.getPath(), Field.Store.YES));\r\n doc.add(new TextField(\"modified-date\", date, Field.Store.YES));\r\n doc.add(new StringField(\"summary\", summary, Field.Store.YES));\r\n\r\n }\r\n else {\r\n String content = FileUtils.readFileToString(f, StandardCharsets.UTF_8);\r\n\r\n doc.add(new TextField(\"contents\", content + \" \" + date, Field.Store.YES));\r\n doc.add(new StringField(\"path\", f.getPath(), Field.Store.YES));\r\n doc.add(new TextField(\"modified-date\", date, Field.Store.YES));\r\n }\r\n doc.add(new StringField(\"filename\", f.getName(), Field.Store.YES));\r\n\r\n writer.addDocument(doc);\r\n System.out.println(\"Added: \" + f);\r\n } catch (Exception e) {\r\n System.out.println(\"Could not add: \" + f);\r\n }\r\n }\r\n\r\n int newNumDocs = writer.numDocs();\r\n System.out.println(\"\");\r\n System.out.println(\"************************\");\r\n System.out.println((newNumDocs - originalNumDocs) + \" documents added.\");\r\n System.out.println(\"************************\");\r\n\r\n queue.clear();\r\n }",
"public void taskIndexReset(){\n String queryCommand = \"SELECT * FROM \" + TABLE_NAME;\n SQLiteDatabase db = this.getWritableDatabase();\n Cursor cursor = db.rawQuery(queryCommand, null);\n int i =0;\n if (cursor.moveToFirst()) {\n do {//id, label, time\n ContentValues values = new ContentValues();\n String oldid=cursor.getString(0);\n values.put(KEY_ID,String.valueOf(i));\n i++;\n values.put(KEY_LABEL, cursor.getString(1));\n String timestamp = cursor.getString(2);\n values.put(KEY_TIME, timestamp);\n db.update(TABLE_NAME, values, KEY_TIME+\" = ?\",\n new String[] { String.valueOf(timestamp) });\n } while (cursor.moveToNext());\n }\n }",
"protected void setIndex(Expression expr)\n {\n index = expr;\n }",
"public static void save(String indexFileName) throws FileNotFoundException, UnsupportedEncodingException{\n\t\tHashMap<String, String> sCurrentHashMap = globalHash.get(indexFileName);\n\t\t\n\t\tPrintWriter writer = new PrintWriter(indexFileName+\".txt\", \"UTF-8\");\n\n\t\tIterator it = sCurrentHashMap.entrySet().iterator();\n\t\twhile(it.hasNext()){\n\t\t\tHashMap.Entry<String, String> entry = (HashMap.Entry<String, String>) it.next();\n\t\t\t//if this term appear more than one doc\n\t\t\tif(entry.getValue().length()>1) {\n\t\t\t\tStringTokenizer stDocID = new StringTokenizer(entry.getValue(),\",\");\n\t\t\t\twriter.println(entry.getKey()+\",\"+stDocID.countTokens()+\":<\"+entry.getValue()+\">\");\n\t\t\t} else{\n\t\t\t\twriter.println(entry.getKey()+\",1:<\"+entry.getValue()+\">\");\n\t\t\t}\n\t\t}\n\t\twriter.close();\n\t}",
"public void update(int idIndex, String inpuFilePath) {\n\t\tString url = IP + String.valueOf(PORT) + \"/update\";\n\t\thelper(url, idIndex, inpuFilePath);\n\t}",
"private void setIndex(int index){\n\t\tthis.index = index;\n\t}",
"private void removeSeenInfo(int index) {\n ensureSeenInfoIsMutable();\n seenInfo_.remove(index);\n }",
"public void printIndexMetrics(Directory index, boolean printMetricsToScreen, boolean printMetricsToFile){\n\t\t \n\t\ttry{\n\t\t\t //Creating our index\n\t\t\t IndexReader reader = DirectoryReader.open(index);\n\t\t\t \n\t\t\t //Need this map for metrics\n\t\t\t HashMap<String, HashSet<String>> hmap = convertIndexToMap(reader);\n\t\t\t \n\t\t\t HashMap<String, String> metrics = calculateMetrics(hmap, reader); \n\n\t\t\t //add the bad file metric... should probably just make this map global\n\t\t\t metrics.put(INDEX_METRIC_UNPARSABLE_CT, String.valueOf(numberOfUnparsableFiles));\n\t\t\t printMetrics(metrics, printMetricsToScreen, printMetricsToFile);\n\t\n\t\t\t reader.close(); \n\t\t}\n\t\tcatch(Exception e){\n\t\t\tSystem.out.println(\"There was some exception thrown during printing: \" + e.getStackTrace());\n\t\t}\n\t}",
"public native String replaceItem(String newItem, Number index);",
"public void setIndex(int index) { this.index = index; }",
"private static void changeScheduleIndices(ArrayList<Integer> index_order) {\n for(int x = 0; x < 5; x++) {\n for(int y = 0; y < 9; y++) {\n if(schedule.getLesson(x, y) != null) {\n int newid = index_order.indexOf(schedule.getLesson(x, y).getSubjectIndex());\n schedule.getLesson(x, y).setSubjectIndex(newid);\n }\n }\n }\n }",
"private static void createIndexEntry(Document document, int menuId, String filename, String path) throws Exception {\r\n Indexer index = (Indexer) Context.getInstance().getBean(Indexer.class);\r\n index.deleteFile(String.valueOf(menuId), document.getLanguage());\r\n index.addDirectory(new File(path + filename), document);\r\n }",
"public void setForeignKeyIndex(String filepath, ArrayList<String> FKIndex){\n FileWriter fw;\n\n //create file\n try {\n fw = new FileWriter(filepath + \"/FKIndex.txt\");\n if (FKIndex.size() > 0){\n //add each row of array to a new line\n for (int i = 0; i < FKIndex.size(); i++){\n fw.write(FKIndex.get(i));\n fw.write(\"\\n\");\n }\n }\n fw.close();\n } catch (IOException ex){\n System.out.println(\"ERROR: failed to create foreign key index file\");\n }\n \n }",
"public void printIndex(Path outFile) throws IOException {\n\t\tSimpleJsonWriter.asDoubleNested(invertedIndex, outFile);\n\t}",
"private void setStringStat(String value, int index) {\n String[] scores = readFromFile().split(\"\\n\");\n String[] stats = scores[currPlayer].split(\",\");\n stats[index] = value;\n scores[currPlayer] = String.join(\",\", stats);\n writeToFile(String.join(\"\\n\", scores));\n }",
"public void findMatchingFiles()\n {\n\t\t\n\t\t//Get Server name from the log directory path\n\t\t\t\t\t\t\n\t\tString server = path.substring(0, path.length()-2);\n\t\tserver = server.substring(0,server.lastIndexOf(\"/\"));\n\t\tserver = server.substring(server.lastIndexOf(\"/\") + 1);\n\t\tSystem.out.println(\"Server Name is : \" + server);\n\t\t\t\t\t\t\n Map <String, String> logPatternMap = new HashMap<>(); // Map of log stash config and RegEx\n List<String> fileList = new ArrayList<>(); // List of All files in Log Dir\n List<String> logStashCommandList = new ArrayList<>(); // List of commands to be executed for log stashing files\n String placeholder = \"FILE_PATH\";\n logPatternMap = fetchPropertyFromFile();\n fileList = getAllLogFileNames();\n\n for (String file : fileList) {\n\n for (Map.Entry<String, String> entry : logPatternMap.entrySet()) {\n String fileName = entry.getKey();\n String pattern = entry.getValue();\n\n if (Pattern.matches(pattern,file))\n {\n System.out.println( \"Found a matching file : \" + pattern + \" : \" + file );\n File source = new File(\"/slog/templates/\" + fileName);\n File dest = new File(\"/slog/configs/\" + fileName);\n File logFile = new File(path + file);\n try {\n\t\t\t\t\t\t\n\t\t\t\t\t\t\n //copy files from template directory to configs directory\n\t\t\t\t\t\tFiles.copy(source.toPath(), dest.toPath()); \n System.out.println(\"Destination path is : \" + dest.getPath());\n\n //Replace contents of the config file to match log file paths\n\n BufferedReader reader = new BufferedReader(new FileReader(dest));\n String line = \"\", oldtext = \"\";\n while((line = reader.readLine()) != null)\n {\n oldtext += line + \"\\r\\n\";\n }\n reader.close();\n\n String replacedtext = oldtext.replaceAll(placeholder, logFile.getPath().toString());\n\n FileWriter writer = new FileWriter(dest);\n writer.write(replacedtext);\n writer.close();\n\n //Form LogStash command and Execute it\n\n String command = \"/slog/bin/logstash -f \" + dest.getPath() + \" < \" + path + file;\n String[] cmd = { \"/bin/sh\", \"-c\", command};\n Process process = Runtime.getRuntime().exec(cmd);\n try {\n BufferedReader out = new BufferedReader(new InputStreamReader(process.getErrorStream()));\n out.lines().forEach(System.out::println);\n process.waitFor();\n\n } catch (InterruptedException e) {\n e.printStackTrace();\n }\n\n //delete config file and log file after the work is done\n dest.delete();\n // logFile.delete();\n\n } catch (IOException e) {\n e.printStackTrace();\n }\n\n }\n }\n }\n\n }",
"void replace(int offset, int length, String text) throws BadLocationException;",
"@Test\r\n public void TestFindLog() {\r\n\r\n int index = r.nextInt(100);\r\n Assert.assertEquals(logs[index], logDocument.findLog(index));\r\n\r\n }",
"LogEntry getEntry(final long index);"
]
| [
"0.5875223",
"0.5875223",
"0.5831418",
"0.57824016",
"0.577178",
"0.5707217",
"0.57038295",
"0.5702541",
"0.5679685",
"0.5643812",
"0.5608264",
"0.558295",
"0.5571575",
"0.5491942",
"0.548454",
"0.5468631",
"0.54499286",
"0.5383341",
"0.53828984",
"0.53399813",
"0.5317977",
"0.53153175",
"0.5311799",
"0.52083063",
"0.52062",
"0.5197782",
"0.5185982",
"0.5173206",
"0.51602936",
"0.5136373",
"0.513257",
"0.5130595",
"0.51190364",
"0.5098938",
"0.5095904",
"0.5086699",
"0.5085319",
"0.5061491",
"0.50577307",
"0.5046832",
"0.5044015",
"0.5041835",
"0.5041687",
"0.50342816",
"0.5033027",
"0.5031323",
"0.50268275",
"0.50247175",
"0.50180835",
"0.50120705",
"0.5011075",
"0.5004882",
"0.49735674",
"0.49688166",
"0.49682546",
"0.49608248",
"0.49333963",
"0.49280763",
"0.49215",
"0.4911389",
"0.49108738",
"0.49067488",
"0.49031425",
"0.48957828",
"0.48910013",
"0.48856196",
"0.48795918",
"0.4875451",
"0.48744276",
"0.48695472",
"0.4867724",
"0.4866328",
"0.48608992",
"0.4859445",
"0.4856239",
"0.4854715",
"0.4848166",
"0.48417503",
"0.48411053",
"0.48390225",
"0.48387676",
"0.48378083",
"0.48350722",
"0.48292157",
"0.48273194",
"0.48265103",
"0.480637",
"0.48040697",
"0.47932997",
"0.4793044",
"0.47862846",
"0.47847074",
"0.4783976",
"0.47830057",
"0.47824895",
"0.47792038",
"0.47760925",
"0.47759524",
"0.47713137",
"0.4768526"
]
| 0.7176417 | 0 |
replaces the original wip image file | public static void ReplacesImage(int index){
try{
Commissions temp = ManageCommissionerList.comms.get(index);
BufferedImage img = temp.GetWipImage();
File fl = new File("wipimages/wip" + temp.GetCommissionTitle() + index + ".jpg");
ImageIO.write(img, "jpg", fl);
}catch (Exception e){
e.printStackTrace();
System.out.printf("Failure to write image file");
}
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"private void updateImageFile() throws FileNotFoundException {\n \t\tfinal PrintWriter out = new PrintWriter(asciiImageFile);\n \t\tout.print(asciiImage(false));\n \t\tout.close();\n \t}",
"private void enhanceImage(){\n }",
"@Test\n\tpublic void testUpdateImage() {\n\n\t\tip = new ImagePlus();\n\t\t//assertNull(ip.img);\n\t\tip.updateImage();\n\t\t//assertNull(ip.img);\n\n\t\tip = new ImagePlus(DataConstants.DATA_DIR + \"head8bit.tif\");\n\t\t//assertNull(ip.img);\n\t\tip.updateImage();\n\t\t//assertNotNull(ip.img);\n\t}",
"public void restore() {\n currentIm= originalIm.copy();\n }",
"public void testStripReadOnlyRemoveAlsoImages() {\n String fileName = \"read_only_strippedImagesRemoved.docx\";\n String fileInput = inputDirectory + \"read_only_with_image_inside.docx\";\n String expectedResult = expectedDirectory + fileName;\n ZipFile zipFileSource1;\n try {\n zipFileSource1 = new ZipFile(fileInput);\n Package packSource1 = Package.open(zipFileSource1, PackageAccess.ReadWrite);\n WordDocument docxSource1 = new WordDocument(packSource1);\n docxSource1.stripReadOnlyPartOfDocument();\n File destFile = new File(outputDirectory + fileName);\n assertTrue(docxSource1.save(destFile));\n OpenXmlAssert.assertEquals(new File(outputDirectory + fileName), new File(expectedResult));\n } catch (IOException e) {\n logger.error(e);\n fail(\"cannot open:\" + fileInput);\n } catch (OpenXML4JException e) {\n logger.error(e);\n fail(\"fail\" + e.getMessage());\n }\n }",
"void setImageFromFile(File imageFile);",
"private void reanderImage(ImageData data) {\n \n }",
"public void setImage2(String file){ \n try {\n player = ImageIO.read(new File(file));\n } catch (IOException ex) {\n Logger.getLogger(GridSquarePanel.class.getName()).log(Level.SEVERE, null, ex);\n }\n }",
"public static void main(String[]args){\n Scanner reader = new Scanner(System.in);\n System.out.print(\"Enter an image file name: \");\n String fileName = reader.nextLine();\n APImage theOriginal = new APImage(fileName);\n theOriginal.draw();\n\n // Create a copy of the image to blur\n APImage newImage = theOriginal.clone();\n\n // Visit all pixels except for those on the perimeter\n for (int y = 1; y < theOriginal.getHeight() - 1; y++)\n for (int x = 1; x < theOriginal.getWidth() - 1; x++){\n\n // Obtain info from the old pixel and its neighbors\n Pixel old = theOriginal.getPixel(x, y);\n Pixel left = theOriginal.getPixel(x - 1, y);\n Pixel right = theOriginal.getPixel(x + 1, y);\n Pixel top = theOriginal.getPixel(x, y - 1);\n Pixel bottom = theOriginal.getPixel(x, y + 1);\n int redAve = (old.getRed() + left.getRed() + right.getRed() + \n top.getRed() + bottom.getRed()) / 5;\n int greenAve = (old.getGreen() + left.getGreen() + right.getGreen() + \n top.getGreen() + bottom.getGreen()) / 5;\n int blueAve = (old.getBlue() + left.getBlue() + right.getBlue() + \n top.getBlue() + bottom.getBlue()) / 5;\n\n // Reset new pixel to that info\n Pixel newPixel = newImage.getPixel(x, y);\n newPixel.setRed(redAve);\n newPixel.setGreen(greenAve);\n newPixel.setBlue(blueAve);\n }\n System.out.print(\"Press return to continue:\");\n reader.nextLine();\n newImage.draw();\n }",
"public void fuzzify() {\n ImageArray newCopy = currentIm.copy();\n \n int rows= currentIm.getRows();\n int cols= currentIm.getCols();\n \n for(int rr = 1; rr < rows-1; rr++){\n \n for(int cc = 1; cc < cols-1; cc++){\n fuzPixel(rr,cc,newCopy);\n \n }\n \n }\n \n currentIm = newCopy.copy();\n \n \n }",
"public void changePicture()\n\t{\n\t\twhile(usedIndex2.contains(unknownWordFileIndex))\n\t\t\tunknownWordFileIndex = r.nextInt(unknownWordFile.size());\n\t\t\n\t\t// Send to all\n\t\tfor(ConnectionThread i : connectionPool)\n\t\t{\n\t\t\ti.sendMessage(\"changePicture\");\n\t\t\ti.sendMessage(unknownWordFile.get(unknownWordFileIndex));\n\t\t}\n\t\t\t\n\t}",
"private void updateImage(File file) throws IOException {\n\t\t\tfileLabel.setText(\"\");\n\n\t\t\ttry {\n\t\t\t\tMyImageD tmpImage = null;\n\t\t\t\tString fileName = file.getName();\n\n\t\t\t\t// Update preview for opening ggb files\n\t\t\t\tif (fileChooser\n\t\t\t\t\t\t.getMode() == GeoGebraFileChooser.MODE_GEOGEBRA) {\n\n\t\t\t\t\tif (fileName.endsWith(\".ggb\")) {\n\t\t\t\t\t\ttmpImage = new MyImageD(MyXMLioD.getPreviewImage(file)); // load\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// preview\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// from\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t// zip\n\n\t\t\t\t\t\tStringBuilder fileInfo = new StringBuilder();\n\n\t\t\t\t\t\tif (fileName.length() > 20) {\n\t\t\t\t\t\t\tfileInfo.append(fileName.substring(0, 20));\n\t\t\t\t\t\t\tfileInfo.append(\"..\");\n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\tfileInfo.append(fileName);\n\t\t\t\t\t\t}\n\n\t\t\t\t\t\tfileInfo.append(\" : \");\n\t\t\t\t\t\tfileInfo.append(file.length() / 1024);\n\t\t\t\t\t\tfileInfo.append(\" kB\");\n\t\t\t\t\t\tfileLabel.setText(fileInfo.toString());\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t\t// Update preview for saving a ggb file\n\t\t\t\telse if (fileChooser\n\t\t\t\t\t\t.getMode() == GeoGebraFileChooser.MODE_GEOGEBRA_SAVE) {\n\t\t\t\t\ttmpImage = (MyImageD)\n\t\t\t\t\t\t\tapp.getExportImage(MyXMLio.THUMBNAIL_PIXELS_X,\n\t\t\t\t\t\t\t\t\tMyXMLio.THUMBNAIL_PIXELS_Y);\n\t\t\t\t\t// TODO: show file size info?\n\t\t\t\t\tfileLabel.setText(null);\n\t\t\t\t}\n\n\t\t\t\t// Update preview for images\n\t\t\t\telse {\n\t\t\t\t\t// fails for a few JPEGs so turn off preview for large files\n\t\t\t\t\tif (file.length() < 1024 * maxImageSize) {\n\n\t\t\t\t\t\ttmpImage = MyImageD.fromFile(file, fileName);\n\t\t\t\t\t\tStringBuilder imgInfo = new StringBuilder();\n\n\t\t\t\t\t\tif (fileName.length() > 20) {\n\t\t\t\t\t\t\timgInfo.append(fileName.substring(0, 20));\n\t\t\t\t\t\t\timgInfo.append(\"..\");\n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\timgInfo.append(fileName);\n\t\t\t\t\t\t}\n\n\t\t\t\t\t\tif (tmpImage != null) {\n\t\t\t\t\t\t\timgInfo.append(\" : \");\n\t\t\t\t\t\t\timgInfo.append(tmpImage.getWidth());\n\t\t\t\t\t\t\timgInfo.append(\" x \");\n\t\t\t\t\t\t\timgInfo.append(tmpImage.getHeight());\n\t\t\t\t\t\t}\n\t\t\t\t\t\tfileLabel.setText(imgInfo.toString());\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t\t// resize tmp image if necessary\n\t\t\t\tif (tmpImage != null) {\n\n\t\t\t\t\tint oldWidth = tmpImage.getWidth();\n\t\t\t\t\tint oldHeight = tmpImage.getHeight();\n\n\t\t\t\t\tint newWidth;\n\t\t\t\t\tint newHeight;\n\n\t\t\t\t\tif (oldWidth > ImagePanel.SIZE\n\t\t\t\t\t\t\t|| oldHeight > ImagePanel.SIZE) {\n\t\t\t\t\t\tif (oldWidth > oldHeight) {\n\t\t\t\t\t\t\tnewWidth = ImagePanel.SIZE;\n\t\t\t\t\t\t\tnewHeight = (ImagePanel.SIZE * oldHeight)\n\t\t\t\t\t\t\t\t\t/ oldWidth;\n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\tnewWidth = (ImagePanel.SIZE * oldWidth) / oldHeight;\n\t\t\t\t\t\t\tnewHeight = ImagePanel.SIZE;\n\t\t\t\t\t\t}\n\t\t\t\t\t\t// Create a new image for the scaled preview image\n\t\t\t\t\t\tsetImg(new MyImageD(new BufferedImage(newWidth,\n\t\t\t\t\t\t\t\tnewHeight, BufferedImage.TYPE_INT_RGB)));\n\n\t\t\t\t\t\tGGraphics2DD graphics2D = (GGraphics2DD) getImg()\n\t\t\t\t\t\t\t\t.createGraphics();\n\t\t\t\t\t\tif (tmpImage.isSVG()) {\n\t\t\t\t\t\t\tgraphics2D.setColor(GColor.WHITE);\n\t\t\t\t\t\t\tgraphics2D.fillRect(0, 0, newWidth, newHeight);\n\t\t\t\t\t\t}\n\t\t\t\t\t\tgraphics2D.drawImageScaled(tmpImage, newWidth, newHeight);\n\t\t\t\t\t\tgraphics2D.dispose();\n\t\t\t\t\t} else {\n\t\t\t\t\t\tsetImg(tmpImage);\n\t\t\t\t\t}\n\t\t\t\t} else {\n\t\t\t\t\tsetImg(null);\n\t\t\t\t}\n\n\t\t\t\trepaint();\n\t\t\t} catch (IllegalArgumentException iae) {\n\t\t\t\t// This is thrown if you select .ico files\n\t\t\t\tsetImg(null);\n\t\t\t} catch (Throwable t) {\n\t\t\t\tt.printStackTrace();\n\t\t\t\tLog.debug(t.getClass() + \"\");\n\t\t\t\tsetImg(null);\n\t\t\t}\n\t\t}",
"public void write(File path) throws IOException{\n\t\tif(this.picture != null){ // in cazul in care poza are continut null se arunca exceptie\n\t\t\t//File output = new File(path);\n\t\t\tImageIO.write(zoomed,\"bmp\",path);\n\t\t\tSystem.out.println(path);\n\t\t\tSystem.out.println(\"\\nS-a scris in fisier cu succes\");\n\t\t}\n\t}",
"private void changePixelValues(ImageProcessor ip) {\n\t\t\tint[] pixels = (int[])ip.getPixels();\r\n\t\t\t\r\n\t\t\tfor (int y=0; y<height; y++) {\r\n\t\t\t\tfor (int x=0; x<width; x++) {\r\n\t\t\t\t\tint pos = y*width + x;\r\n\t\t\t\t\tint argb = origPixels[pos]; // Lesen der Originalwerte \r\n\t\t\t\t\t\r\n\t\t\t\t\tint r = (argb >> 16) & 0xff;\r\n\t\t\t\t\tint g = (argb >> 8) & 0xff;\r\n\t\t\t\t\tint b = argb & 0xff;\r\n\t\t\t\t\t\r\n\t\t\t\t\t\r\n\t\t\t\t\t// anstelle dieser drei Zeilen später hier die Farbtransformation durchführen,\r\n\t\t\t\t\t// die Y Cb Cr -Werte verändern und dann wieder zurücktransformieren\r\n\t\t\t\t\t\r\n\t\t\t\t\tYUV c = new YUV(r, g, b);\r\n\t\t\t\t\t\r\n\t\t\t\t\tc.changeBrightness(brightness).changeContrast(contrast).changeSaturation(saturation).changeHue(hue);\r\n\t\t\t\t\t\r\n\t\t\t\t\tint[] rgbNew = c.toRGB();\r\n\r\n\t\t\t\t\t// Hier muessen die neuen RGB-Werte wieder auf den Bereich von 0 bis 255 begrenzt werden\r\n\t\t\t\t\t\r\n\t\t\t\t\tpixels[pos] = (0xFF<<24) | (rgbNew[0]<<16) | (rgbNew[1]<<8) | rgbNew[2];\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}",
"public final void replaceImage(final ImageProcessor newImage) {\r\n this.image = newImage;\r\n }",
"private void change_im_tool4(int boo){\r\n if(boo == 0){ //IMAGEN SI EL USUARIO ESTA INHABILITADO\r\n im_tool4.setImage(new Image(getClass().getResourceAsStream(\"/Images/img07.png\")));\r\n }else{ //IMAGEN PARA HABILITAR AL USUARIO\r\n im_tool4.setImage(new Image(getClass().getResourceAsStream(\"/Images/img06.png\")));\r\n }\r\n }",
"public void rewrite() throws FitsException, IOException;",
"private void save(FileItem file) throws Exception {\n FileHandler fileHandler = new FileHandler(oriImgFile());\n fileHandler.saveFile(file);\n }",
"public void testStripReadOnlyKeepTextImageAndTable() {\n String fileName = \"write_enable_text_table_image.docx\";\n String fileInput = inputDirectory + \"write_enable_text_table_image.docx\";\n String expectedResult = expectedDirectory + fileName;\n ZipFile zipFileSource1;\n try {\n zipFileSource1 = new ZipFile(fileInput);\n Package packSource1 = Package.open(zipFileSource1, PackageAccess.ReadWrite);\n WordDocument docxSource1 = new WordDocument(packSource1);\n docxSource1.stripReadOnlyPartOfDocument();\n File destFile = new File(outputDirectory + fileName);\n assertTrue(docxSource1.save(destFile));\n OpenXmlAssert.assertEquals(new File(outputDirectory + fileName), new File(expectedResult));\n } catch (IOException e) {\n logger.error(e);\n fail(\"cannot open:\" + fileInput);\n } catch (OpenXML4JException e) {\n logger.error(e);\n fail(\"failed\" + e.getMessage());\n }\n }",
"public void imagesaver(String name){\n\tthis.new_image_name = name;\n\t try{\n\t\tImageIO.write(new_buff_image, \"png\", new File(new_image_name));\n\t }\n\t catch(IOException e){\n\t\tSystem.out.println(\"The desired output file is invalid. Please try running the program again.\");\n\t\tSystem.exit(0);\n\t }\n }",
"public native boolean modulateImage(String modulate) throws MagickException;",
"String removeImageStyle();",
"public static void overwritePal() throws Exception {\n\n\t\tString fileName = PropertiesFile.getInstance().getProperty(\"input_qualifier\")+ Constants.PALETTE_FILE_EXTENSION;\n\t\tFile templateFile = new File(getFullyQualifiedFileName(\"cell\") +\"/\" + fileName );\n\n\t\tFile newPal = new File(getRISEInputFolder()+\"/\" + fileName );\n\n\t\tFileInputStream input = new FileInputStream(templateFile);\n\t\twriter(input, newPal);\n\t}",
"void updateFile() throws IOException;",
"private void updateBoard() throws FileNotFoundException {\r\n\t\tSystem.out.println(\"[DEBUG LOG/Game.java] Creating board image\");\r\n\t\tBufferedImage combined = new BufferedImage(GlobalVars.images.get(\"Board1\").getWidth(), GlobalVars.images.get(\"Board1\").getHeight(), BufferedImage.TYPE_INT_ARGB);\r\n\t\t\r\n\t\tGraphics g = combined.getGraphics();\r\n\t\t// Draws board template first\r\n\t\tg.drawImage(GlobalVars.images.get(\"Board1\"), 0, 0, null);\r\n\t\t\r\n\t\t// Loops through contents and adds secrets, artifacts, idols\r\n\t\tfor (int i = 0; i < mapContents.length; i++) {\r\n\t\t\tif (mapContents[i] != null && mapContents[i] != \"heart\") {\r\n\t\t\t\tint offsetX = 4;\r\n\t\t\t\tint offsetY = -1;\r\n\t\t\t\tif (mapContents[i].startsWith(\"Minor\")) {\r\n\t\t\t\t\toffsetX = 7;\r\n\t\t\t\t\toffsetY = 3;\r\n\t\t\t\t}\r\n\t\t\t\t// Specific spots to this map\r\n\t\t\t\tif (i == 18) {\r\n\t\t\t\t\tg.drawImage(GlobalVars.images.get(mapContents[i]), 206, 286, null);\r\n\t\t\t\t} else if (i == 19) {\r\n\t\t\t\t\tg.drawImage(GlobalVars.images.get(mapContents[i]), 299, 287, null);\r\n\t\t\t\t} else if (i == 25) {\r\n\t\t\t\t\tg.drawImage(GlobalVars.images.get(mapContents[i]), 297, 352, null);\r\n\t\t\t\t} else if (i == 28) {\r\n\t\t\t\t\tint num = Integer.parseInt(mapContents[i].substring(10));\r\n\t\t\t\t\tif (num > 0) {\r\n\t\t\t\t\t\tg.drawImage(GlobalVars.images.get(\"MonkeyIdol\"), 28, 369, null);\r\n\t\t\t\t\t\tif (num > 1) {\r\n\t\t\t\t\t\t\tg.drawImage(GlobalVars.images.get(\"MonkeyIdol\"), 28, 395, null);\r\n\t\t\t\t\t\t\tif (num > 2) {\r\n\t\t\t\t\t\t\t\tg.drawImage(GlobalVars.images.get(\"MonkeyIdol\"), 28, 422, null);\r\n\t\t\t\t\t\t\t}\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t}\r\n\t\t\t\t} else {\r\n\t\t\t\t\tg.drawImage(GlobalVars.images.get(mapContents[i]), GlobalVars.playerCoordsPerRoom[i][0]+offsetX, GlobalVars.playerCoordsPerRoom[i][1]+offsetY, null);\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}\r\n\t\t\r\n\t\t// Draws dragons\r\n\t\tif (attackLevel == 0) g.drawImage(GlobalVars.images.get(\"Dragon\"), 395, 548, null);\r\n\t\telse if (attackLevel == 1) g.drawImage(GlobalVars.images.get(\"Dragon\"), 456, 542, null);\r\n\t\telse if (attackLevel == 2) g.drawImage(GlobalVars.images.get(\"Dragon\"), 513, 510, null);\r\n\t\telse if (attackLevel == 3) g.drawImage(GlobalVars.images.get(\"Dragon\"), 549, 462, null);\r\n\t\telse if (attackLevel == 4) g.drawImage(GlobalVars.images.get(\"Dragon\"), 561, 412, null);\r\n\t\telse if (attackLevel == 5) g.drawImage(GlobalVars.images.get(\"Dragon\"), 551, 349, null);\r\n\t\telse {\r\n\t\t\tg.drawImage(GlobalVars.images.get(\"Dragon\"), 552, 287, null);\r\n\t\t}\r\n\t\t\r\n\t\t// Draws characters\r\n\t\tg.drawImage(GlobalVars.images.get(\"RedChar\"), p1.getPiece().getX(), p1.getPiece().getY(), null);\r\n\t\tif (playerCount >= 2) {\r\n\t\t\tg.drawImage(GlobalVars.images.get(\"BlueChar\"), p2.getPiece().getX(), p2.getPiece().getY(), null);\r\n\t\t\tif (playerCount >= 3) {\r\n\t\t\t\tg.drawImage(GlobalVars.images.get(\"YellowChar\"), p3.getPiece().getX(), p3.getPiece().getY(), null);\r\n\t\t\t\tif (playerCount >= 4) {\r\n\t\t\t\t\tg.drawImage(GlobalVars.images.get(\"GreenChar\"), p4.getPiece().getX(), p4.getPiece().getY(), null);\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}\r\n\t\t\r\n\t\t// Writes the combined image into a file\r\n\t\ttry {\r\n\t\t\tImageIO.write(combined, \"PNG\", new File(\"newboard.png\"));\r\n\t\t} catch (IOException e) {\r\n\t\t\t// TODO Auto-generated catch block\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t\t\r\n\t\t// Builds an embed and sends it to the filesChannel\r\n\t\tEmbedBuilder embed = new EmbedBuilder();\r\n\t\tembed.setTitle(gameChannel.getName());\r\n\t\tembed.setColor(Color.GRAY);\r\n\t\tInputStream test = new FileInputStream(\"newboard.png\");\r\n\t\tembed.setImage(\"attachment://newboard.png\");\r\n\t\tMessageBuilder m = new MessageBuilder();\r\n\t\tm.setEmbed(embed.build());\r\n\t\tGlobalVars.filesChannel.sendFile(test, \"newboard.png\", m.build()).queue();\r\n\t}",
"public ImageManip(String file) {\n\t\tthis.image = new Picture(file, false);\n\t\tthis.canvas = new Picture(this.image.getWidth(), this.image.getHeight(), false);\n\t\tthis.random = new Random();\n\t\tthis.rotateOffset = 0;\n\t}",
"private void setImage() {\n BitmapFactory.Options options = new BitmapFactory.Options();\n Bitmap originalBm = BitmapFactory.decodeFile(tempFile.getAbsolutePath(), options);\n // Log.d(TAG, \"setImage : \" + tempFile.getAbsolutePath());\n\n myImage.setImageBitmap(originalBm);\n\n /**\n * tempFile 사용 후 null 처리를 해줘야 합니다.\n * (resultCode != RESULT_OK) 일 때 tempFile 을 삭제하기 때문에\n * 기존에 데이터가 남아 있게 되면 원치 않은 삭제가 이뤄집니다.\n */\n System.out.println(\"setImage : \" + tempFile.getAbsolutePath());\n fileSource = tempFile.getAbsolutePath();\n myImageSource = fileSource;\n check++;\n tempFile = null;\n\n }",
"public void updateImageForIndex(int index) {\n\t\t//Nothing to do\n\t}",
"private void editImageButtonActionPerformed(java.awt.event.ActionEvent evt) {//GEN-FIRST:event_editImageButtonActionPerformed\n JFileChooser fileChooser = new JFileChooser();\n fileChooser.setFileFilter(new FileNameExtensionFilter(\"Image\", \"jpg\"));\n fileChooser.showOpenDialog(this);\n if (fileChooser.getSelectedFile() != null) {\n selectedFilePath = fileChooser.getSelectedFile().getAbsolutePath();\n oldImageTitle = imageTitle;\n imageTitle = phoneField.getText() + fileChooser.getSelectedFile().getName();\n ImageIcon contactImage = new ImageIcon(new ImageIcon(fileChooser.getSelectedFile().getAbsolutePath()).getImage().getScaledInstance(contactImageLabel.getWidth(), contactImageLabel.getHeight(), Image.SCALE_DEFAULT));\n contactImageLabel.setIcon(contactImage);\n } else {\n\n }\n\n\n }",
"private void updateContPicture(String path) {\n \t\t// don't update if its already correct!\n \t\tif (imgPath == path) {\n \t\t\treturn;\n \t\t}\n \t\t\n \t\ttry {\n \t\t\tImage img = ImageIO.read(new File(path));\n \t\t\tif(img==null)\n \t\t\t\tthrow new IOException();\n \t\t\t// scale the image!\n \t\t\tif (img.getWidth(null) > 200 ||\n \t\t\t\t\timg.getHeight(null) > 200) {\n \t\t\t\timg = img.getScaledInstance(200, 200, Image.SCALE_SMOOTH);\n \t\t\t}\n \t\t\t\n \t\t\t// NO IO errors occured if getting here:\n \t\t\tImageIcon imgD = new ImageIcon(img);\n \t\t\timgDisplay.setIcon(imgD);\n \t\t\timgPath = path;\n \t\t} catch (IOException e) {\n \t\t\tSystem.out.println(\"Exception loading image for contestant \" +\n \t\t\t\t\t\"picture [\" + path + \"]\");\n \t\t\timgDisplay.setIcon(null);\n \t\t\timgDisplay.setText(\"Could not load: \" + path);\n \t\t}\n \t\t\n \t}",
"String updateMyAvatar(String pictureFilePath);",
"public static Texture getWat(){\n //set a linear filter to clean image\n h2o.setFilter(Texture.TextureFilter.Linear, Texture.TextureFilter.Linear);\n //return image\n return h2o;\n }",
"public void createNewImageFile(){\n fillNewImage();\n\n try {\n ImageIO.write(newImage, imageFileType, new File(k + \"_Colored_\" + fileName.substring(0,fileName.length() - 4) + \".\" + imageFileType));\n } catch (IOException e){\n e.printStackTrace();\n }\n \n }",
"@Override\n\tpublic void unReplace(String fileUploadPath) {\n\t\tbianLiTemplateFile(fileUploadPath);\n\t}",
"public void runDarken() {\n BufferedImage transformedImage = new BufferedImage(this.image.getWidth(), this.image.getHeight(), this.image.getType());\n\n try {\n for(int i = 0; i < this.image.getWidth(); i++) {\n for(int j = 0; j < this.image.getHeight(); j++) {\n transformedImage.setRGB(i, j, image.getRGB(i,j));\n }\n }\n float scaleFactor = 0.5f;\n RescaleOp op = new RescaleOp(scaleFactor, 0, null);\n transformedImage = op.filter(transformedImage, null);\n\n File outputImageFileLocation = new File(this.exportLocation);\n ImageIO.write(transformedImage, Files.getFileExtension(this.imageLocation), outputImageFileLocation);\n System.out.println(\"Success\");\n } catch (IOException e) {\n e.printStackTrace();\n }\n }",
"public void updatePicture(int frameNum) {\n\n if (frameNum < billboardFileList.size()) {\n String[] filename = billboardFileList.get(frameNum);\n File inputfile = new File(\"/Users/sha33/NetBeansProjects/vbs2gui/saved/\" + filename[1]);\n if (inputfile.exists()) {\n BufferedImage uncropped = null;\n BufferedImage scaled = null;\n\n try {\n uncropped = ImageIO.read(inputfile);\n } catch (IOException e) {\n }\n AffineTransform at = new AffineTransform();\n at.scale(1.5, 1.5);\n AffineTransformOp scaleOp =\n new AffineTransformOp(at, AffineTransformOp.TYPE_BICUBIC);\n scaled = scaleOp.filter(uncropped, scaled);\n picture.setIcon(new ImageIcon(scaled));\n// txt.setText(\"Showing now: \" + billboardFileList.get(frameNum));\n\n } else {\n picture.setText(\"image #\" + billboardFileList.get(frameNum) + \" does not exist!\");\n }\n }\n }",
"private static Bitmap fixImageRotation (Bitmap bitmap, String rawImageFilePath) throws IOException\r\n {\r\n /* Evaluate if we need to rotate the bitmap and replace the old bitmap. */\r\n float angle = getRawImageRotation(rawImageFilePath);\r\n if ( bitmap != null\r\n && angle != 0)\r\n {\r\n Matrix matrix = new Matrix();\r\n matrix.postRotate(angle);\r\n\r\n Bitmap oldBitmap = bitmap;\r\n\r\n bitmap = Bitmap.createBitmap(bitmap, 0, 0, bitmap.getWidth(),\r\n bitmap.getHeight(), matrix, true);\r\n\r\n oldBitmap.recycle();\r\n }\r\n return bitmap;\r\n }",
"public void runLighten() {\n BufferedImage transformedImage = new BufferedImage(this.image.getWidth(), this.image.getHeight(), this.image.getType());\n\n try {\n for(int i = 0; i < this.image.getWidth(); i++) {\n for(int j = 0; j < this.image.getHeight(); j++) {\n transformedImage.setRGB(i, j, image.getRGB(i,j));\n }\n }\n float scaleFactor = 5.3f;\n RescaleOp op = new RescaleOp(scaleFactor, 0, null);\n transformedImage = op.filter(transformedImage, null);\n\n File outputImageFileLocation = new File(this.exportLocation);\n ImageIO.write(transformedImage, Files.getFileExtension(this.imageLocation), outputImageFileLocation);\n System.out.println(\"Success\");\n } catch (IOException e) {\n e.printStackTrace();\n }\n }",
"public void clearImage() {\n IntStream.range(0, bytes.length).forEach(i -> bytes[i] = CLEAR_BYTE);\n }",
"public static Bitmap convertToMutable(Bitmap imgIn) {\n try {\n //this is the file going to use temporally to save the bytes.\n // This file will not be a imageView, it will store the raw imageView data.\n File file = new File(Environment.getExternalStorageDirectory() + File.separator + \"temp.tmp\");\n\n //Open an RandomAccessFile\n //Make sure you have added uses-permission android:name=\"android.permission.WRITE_EXTERNAL_STORAGE\"\n //into AndroidManifest.xml file\n RandomAccessFile randomAccessFile = new RandomAccessFile(file, \"rw\");\n\n // get the width and height of the source bitmap.\n int width = imgIn.getWidth();\n int height = imgIn.getHeight();\n Bitmap.Config type = imgIn.getConfig();\n\n //Copy the byte to the file\n //Assume source bitmap loaded using options.inPreferredConfig = Config.ARGB_8888;\n FileChannel channel = randomAccessFile.getChannel();\n MappedByteBuffer map = channel.map(FileChannel.MapMode.READ_WRITE, 0, imgIn.getRowBytes()*height);\n imgIn.copyPixelsToBuffer(map);\n //recycle the source bitmap, this will be no longer used.\n imgIn.recycle();\n System.gc();// try to force the bytes from the imgIn to be released\n\n //Create a new bitmap to load the bitmap again. Probably the memory will be available.\n imgIn = Bitmap.createBitmap(width, height, type);\n map.position(0);\n //load it back from temporary\n imgIn.copyPixelsFromBuffer(map);\n //close the temporary file and channel , then delete that also\n channel.close();\n randomAccessFile.close();\n\n // delete the temp file\n file.delete();\n\n } catch (FileNotFoundException e) {\n e.printStackTrace();\n } catch (IOException e) {\n e.printStackTrace();\n }\n\n return imgIn;\n }",
"public void changeHeaderFile(){\n if ( changedAttr.isEmpty() ) return;\n else {\n Set<Object> tmpAttr = changedAttr.keySet();\n Object[] attributes = tmpAttr.toArray(new Object[tmpAttr.size()]);\n for (int i = 0; i < attributes.length; i++){\n if ( headerFile.containsKey(attributes[i]) ) {\n headerFile.put(attributes[i], changedAttr.get(attributes[i]));\n // DeidData.imageHandler.findImageByDisplayName(curimage.getImageDisplayName())\n // .getHeader().put(attributes[i], changedAttr.get(attributes[i]));\n curimage.getHeader().put(attributes[i], changedAttr.get(attributes[i]));\n //System.out.println(curimage.getHeader().get(attributes[i]));\n }\n }\n curimage.changeHeader();\n \n }\n }",
"@Override\n\tpublic void desenhar() {\n\t\tSystem.out.println(\"desenhar imagem png\");\n\t\t\n\t}",
"public void reload() {\n mHandle = new Texture(mBitmap, mMinMode, mMagMode, mWrapS, mWrapT).getHandle();\n }",
"@FXML public void saveToFile()throws java.io.IOException {\n Highgui.imwrite( this.originalImagePath, this.image );\n System.out.println(\"Saving\");\n }",
"private void setUpSharp() {\n Image sharp = new Image(this.getClass().getResourceAsStream(\"Sharp.png\"));\n _accidentalImage.setImage(sharp);\n _accidentalImage.setFitHeight(26);\n _accidentalImage.setFitWidth(26);\n _accidentalImage.setX(_noteHead.getCenterX() + Constants.SHARP_X_OFFSET);\n _accidentalImage.setY(_noteHead.getCenterY() + Constants.ACCIDENTAL_Y_OFFSET);\n }",
"private void createUpdateImage(Item item) throws Exception {\r\n //cria a imagem\r\n new Image().saveImage(item.getImagem(), item.getNome());\r\n \t}",
"public static void modifySkin(File file) {\n String filePathName = file.toString();\n String filePathNameLowerCase = filePathName.toLowerCase();\n if (filePathNameLowerCase.endsWith(\"png\") || filePathNameLowerCase.endsWith(\"gif\")) {\n // Actions to be taken when a png or gif file is found\n // check if image must be flipped or not\n for (String fileName : vImagesToFlip) {\n if (filePathNameLowerCase.indexOf(fileName) != -1) {\n try {\n FlipImage.proceed(file.toString());\n } catch (Exception e) {\n log4j.error(\"RTLSkin.modifySkin error in file \" + filePathName + \": \" + e);\n }\n }\n }\n }\n if (filePathNameLowerCase.endsWith(\"css\")) {\n // Actions with css files\n if (filePathName.indexOf(\"Openbravo_ERP_\") != -1 || filePathName.indexOf(\"loginStyles\") != -1) {\n try {\n addLine(file, \"html {direction:rtl;}\");\n } catch (Exception e) {\n log4j.error(\"RTLSkin.modifySkin error in file \" + filePathName + \": \" + e);\n }\n }\n try {\n processCSS(file);\n } catch (Exception e) {\n log4j.error(\"RTLSkin.modifySkin error in file \" + filePathName + \": \" + e);\n }\n }\n }",
"public void writeImage(File file, String id) {\n try {\n FileInputStream in = new FileInputStream(file);\n PreparedStatement pstmt = conn.prepareStatement(\n \"UPDATE vehicles vehicles SET photo=? WHERE veh_reg_no = ?\");\n pstmt.setBinaryStream(1, (InputStream)in, (int)file.length());\n pstmt.setString(2, id);\n System.out.println(pstmt); // for debugging\n int returnCode = pstmt.executeUpdate();\n System.out.println(returnCode + \" record updated\");\n } catch (Exception ex) {\n ex.printStackTrace();\n }\n }",
"public void read(File file, Drawing drawing, boolean replace) throws IOException;",
"public void eraseImage() {\n\t\timage = null;\n\t}",
"private void rebuildImageIfNeeded() {\n Rectangle origRect = this.getBounds(); //g.getClipBounds();\n// System.out.println(\"origRect \" + origRect.x + \" \" + origRect.y + \" \" + origRect.width + \" \" + origRect.height);\n\n backBuffer = createImage(origRect.width, origRect.height);\n// System.out.println(\"Image w \" + backBuffer.getWidth(null) + \", h\" + backBuffer.getHeight(null));\n Graphics backGC = backBuffer.getGraphics();\n backGC.setColor(Color.BLACK);\n backGC.fillRect(0, 0, origRect.width, origRect.height);\n// updateCSysEntList(combinedRotatingMatrix);\n paintWorld(backGC);\n }",
"public final void restore() {\r\n\t\tbi_image.restore();\r\n\t}",
"public Texture changeImg(String ImageFile2) {\r\n Texture imgTexture = new Texture ();\r\n try {\r\n imgTexture.loadFromFile (Paths.get (ImageFile2));\r\n } catch (IOException ex) {\r\n ex.printStackTrace ();\r\n }\r\n imgTexture.setSmooth (true);\r\n return imgTexture;\r\n }",
"public void replace() {\n\t\tArrayList<Point> points = nullPoint();\n\t\twhile(0 < points.size()) {\n\t\t\tPoint p = points.get(0); //only get the first one \n\t\t\tif(p.x==0) { //if p is in first column\n\t\t\t\tset(p,_colorFileNames.get(_rand.nextInt(_colorFileNames.size()))); //set a new string\n\t\t\t}\n\t\t\telse { \n\t\t\t\texchange(p, new Point(p.x-1,p.y)); //exchange with the string above\n\t\t\t}\n\t\t\tpoints = nullPoint(); //renew the arraylist, will exclude the fist point\n\t\t} //end loop when there are is no null point\n\t}",
"public static void WriteFile(){\n String[] linha;\n FileWriter writer;\n try{\n writer = new FileWriter(logscommissions, true);\n PrintWriter printer = new PrintWriter(writer);\n linha = ManageCommissionerList.ReturnsCommissionerListInString(ManageCommissionerList.comms.size()-1);\n for(int i=0;i<19;i++){\n printer.append(linha[i]+ \"\\n\");\n }\n printer.close();\n }catch(Exception e){\n e.printStackTrace();\n System.out.println(\"Unable to read file\\n\");\n }\n try{\n Commissions temp = ManageCommissionerList.comms.get(ManageCommissionerList.comms.size()-1);\n BufferedImage img = temp.GetWipImage();\n File fl = new File(\"wipimages/wip\" + temp.GetCommissionTitle() + temp.GetUniqueID() + \".jpg\");\n ImageIO.write(img, \"jpg\", fl);\n }catch (Exception e){\n e.printStackTrace();\n System.out.printf(\"Failure to write image file\");\n }\n \n }",
"public native MagickImage flipImage() throws MagickException;",
"private Bitmap flipImage(byte[] input, FileOutputStream fos){\n\n\t\t\t\tMatrix rotate_matrix = new Matrix();\n\t\t\t\trotate_matrix.preScale(-1.0f, 1.0f);\n\t\t\t\tBitmapFactory bmf = new BitmapFactory();\n\t\t\t\tBitmap raw_bitmap = bmf.decodeByteArray(input, 0, input.length);\n\t\t\t\tBitmap result = Bitmap.createBitmap(raw_bitmap, 0, 0, raw_bitmap.getWidth(), raw_bitmap.getHeight(), rotate_matrix, true);\n\t\t\t\treturn result;\n\t\t\t\t/*\n\t\t\t\tresult.compress(Bitmap.CompressFormat.JPEG, 90, fos);\n\t\t\t\ttry {\n\t\t\t\t\tfos.close();\n\t\t\t\t} catch (IOException e) {\n\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\te.printStackTrace();\n\t\t\t\t}\n\t\t\t\t*/\n\t\t\t}",
"public native MagickImage enhanceImage() throws MagickException;",
"public void setOriginalFilePath(String newValue);",
"public ImageIcon changeImageSize(String fileName) throws IOException{ //change the image size to be fitted for the room\n//\t\tImageIcon myIcon = new ImageIcon(fileName);\n//\t\tBufferedImage img = ImageIO.read(getClass().getResource(fileName));\n//\t\tImage img = myIcon.getImage();\n\n\t\t//Using getResource() allows it to run in runnable .jar form\n\t\tURL url = SAR.class.getClassLoader().getResource(fileName);\n\t\tImageIcon icon = new ImageIcon(url);\n\t\tImage img = icon.getImage();\n\t\tImage newImg = img.getScaledInstance(CELL_SIZE/3, CELL_SIZE/3, java.awt.Image.SCALE_SMOOTH);\n\t\tImageIcon newIcon = new ImageIcon(newImg);\n\t\treturn newIcon;\n\t}",
"@HTTP(\n method = \"PUT\",\n path = \"/apis/config.openshift.io/v1/images/{name}\",\n hasBody = true\n )\n @Headers({ \n \"Content-Type: application/json\",\n \"Accept: */*\"\n })\n KubernetesCall<Image> replaceImage(\n @Path(\"name\") String name, \n @Body Image body);",
"private void updateFingerprintImage(FingerprintImage fi) {\n\n try {\n byte[] fpBmp = null;\n Bitmap bitmap;\n if (fi == null || (fpBmp = fi.convert2Bmp()) == null || (bitmap = BitmapFactory.decodeByteArray(fpBmp, 0, fpBmp.length)) == null) {\n //loger.addRecordToLog(\"updateFingerprintImage sin huella \");\n bitmap = BitmapFactory.decodeResource(getResources(), R.drawable.sinhuella);\n }\n mHandler.sendMessage(mHandler.obtainMessage(MSG_UPDATE_IMAGE, bitmap));\n\n } catch (Exception e) {\n\n //loger.addRecordToLog(\"Exception updateFingerprintImage : \" + e.getMessage());\n\n //mFingerprintImage.setImageResource( R.drawable.errornuevahuella );\n\n //e.printStackTrace();\n\n }\n\n }",
"private void change_im_check(boolean boo){\r\n if(boo){ //IMAGEN SI EL MEASURE ES CORRECTO\r\n im_check.setImage(new Image(getClass().getResourceAsStream(\"/Images/img06.png\")));\r\n }else{ //IMAGEN PARA LA BUSQUEDA DE UN MEASURE\r\n im_check.setImage(new Image(getClass().getResourceAsStream(\"/Images/img34.png\")));\r\n }\r\n }",
"@Override\n\tpublic boolean baseToImg() {\n\t\tList<Image> imgList = imageRepository.findAll();\n\t\tfor (Image img : imgList) {\n\t\t\tString base = img.getSource();\n\t\t\tFiles file = new Files(img.getSaegimId(), \"jpg\");\n\t\t\tfile = fileRepository.save(file);\n\t\t\tLong fileId = file.getId();\n\t\t\t\n\t\t\tBase64ToImgDecoder.decoder(base, dir + fileId + '.' + \"jpg\");\n\t\t}\n\t\treturn true;\n\t}",
"public void writeToImage() {\n imageWriter.writeToImage();\n }",
"public void changePhoto() {\r\n\t\tisPictFetche = false;\r\n\t\tlaPhoto = new Photo();\r\n\t\tlaPhotoCandidate = new Photo();\r\n\t}",
"@Override\n public void updateImages()\n {\n image = ThemeManager.getInstance().getObstacleImage();\n blackedOutImage = ThemeManager.getInstance().getDisabledImage(\"obstacle\");\n }",
"public static void modifytext (String name) throws IOException {\n // Copy the contents of the input file and put it into the new file\n File inputF = new File(\"src/main/java/ex45/\"+ name +\".txt\");\n Path dest = inputF.toPath();\n Path src = Paths.get(\"src/main/java/ex45/exercise45_input.txt\");\n Files.copy(src, dest);\n\n // This process will replace the word 'utilize' with the word 'use'\n String utilize = new String(Files.readAllBytes(dest));\n Charset charset = StandardCharsets.UTF_8;\n utilize = utilize.replaceAll(\"utilize\", \"use\");\n Files.write(dest, utilize.getBytes(charset));\n\n System.out.print(\"Your file has been created.\");\n }",
"public void writeToImage() {\r\n\t\t_imageWriter.writeToImage();\r\n\t}",
"void releaseOldLayers() throws IOException;",
"protected static ImageFile revertToOldName(String name, ImageFile img)throws IOException\n {\n String tagString = \"\";\n if(name.contains(\"@\"))\n {\n tagString = \" \" + name.substring(name.indexOf('@'), name.indexOf(\".\"));\n }\n else\n {\n tagString = \" \" + name.substring(0, name.indexOf(\".\"));\n }\n StringTokenizer st = new StringTokenizer(tagString,\" @\");\n ArrayList<Tag> tags = new ArrayList<Tag>();\n ArrayList<Tag> actualTags = new ArrayList<Tag>();\n\n while (st.hasMoreElements())\n {\n tags.add(new Tag(st.nextToken()));\n }\n\n for (Tag tag : tags)\n {\n for (Tag currTag : Log.allTags)\n {\n if (tag.getName().equals(currTag.getName()))\n {\n actualTags.add(currTag);\n }\n }\n }\n\n return rename(img, actualTags);\n }",
"private void setPic() {\n int targetW = 210;\n int targetH = 320;\n\n // Get the dimensions of the bitmap\n BitmapFactory.Options bmOptions = new BitmapFactory.Options();\n bmOptions.inJustDecodeBounds = true;\n BitmapFactory.decodeFile(previewPhotoPath, bmOptions);\n int photoW = bmOptions.outWidth;\n int photoH = bmOptions.outHeight;\n\n // Determine how much to scale down the image\n int scaleFactor = Math.min(photoW/targetW, photoH/targetH);\n\n // Decode the image file into a Bitmap sized to fill the View\n bmOptions.inJustDecodeBounds = false;\n bmOptions.inSampleSize = scaleFactor;\n bmOptions.inPurgeable = true;\n\n Bitmap bitmap = BitmapFactory.decodeFile(previewPhotoPath, bmOptions);\n bitmap = RotateBitmap(bitmap,270);\n preview.setImageBitmap(bitmap);\n }",
"private void resetINIFile(){\n\tFileOutputStream outstream = null;\n System.out.println(\"do reset\");\n InputStream instream = brokenJavaNaming(\"UI.ini\");\n if (instream == null){\n System.out.println(\"instream null looking for UI.ini\");\n System.exit(1);\n }\n \n \ttry{\n \t File outfile = iniFile;\n \n \t outstream = new FileOutputStream(outfile);\n \n \t byte[] buffer = new byte[1024];\n \n \t int length;\n \t /*copying the contents from input stream to\n \t * output stream using read and write methods\n \t */\n \t while ((length = instream.read(buffer)) > 0){\n \t \toutstream.write(buffer, 0, length);\n \t }\n\n \t //Closing the input/output file streams\n \t instream.close();\n \t outstream.close();\n \t \n System.out.println(\"File copied successfully!!\");\n \n \t}catch(IOException ioe){\n \t\tioe.printStackTrace();\n \t }\n }",
"public static void main(String[] args)\n {\n \n //opens selfie picture \n /**/ \n //relative path\n //og pics\n Picture apic = new Picture(\"images/selfie.jpg\");\n Picture obama = new Picture(\"images/obama.jpg\");\n apic.explore();\n obama.explore();\n\n //change with selfie picture\n Picture me = new Picture(\"images/selfie.jpg\"); \n Picture me1 = new Picture(\"images/selfie.jpg\");\n Picture me2 = new Picture(\"images/selfie.jpg\");\n \n //initializes array pix\n Pixel[] pix;\n \n /**\n * method 1 change\n * divides colors into 4 equal groups\n */\n //initializes vars for rgb values\n int red;\n int blue;\n int green;\n pix = me.getPixels(); \n \n for (Pixel spot: pix) {\n //gets rgb values of colors\n red = spot.getRed();\n blue = spot.getBlue();\n green = spot.getGreen();\n \n //if pixel under a certain value then the color is changed\n if (red < 63 && blue < 63 && green < 63) {\n spot.setColor(new Color(2, 32, 62));\n }\n else if (red < 127 && blue < 127 && green < 127) {\n spot.setColor(new Color(198, 37, 8));\n }\n else if (red < 191 && blue < 191 && green < 191) {\n spot.setColor(new Color(102, 157, 160));\n }\n else {\n spot.setColor(new Color(250, 238, 192));\n }\n }\n me.explore();\n me.write(\"images/selfie1.jpg\");\n\n /**\n * method 2 change\n * changes color based on intensity using max and min grayscale values\n */\n pix = me1.getPixels(); \n int s = 0; //smallest pix value\n int b = 255; //largest pix value\n int ave;\n int quads; //size of four equal range of colors\n \n for (Pixel spot: pix) {\n red = spot.getRed();\n blue = spot.getBlue();\n green = spot.getGreen();\n \n ave = (red + blue + green)/3;\n if (ave > b) { //gets maximum grayscale\n b = ave;\n }\n if (ave < s) { //gets min grayscale\n s = ave;\n }\n quads = (b-s)/4; //divides range of pix values into 4\n \n //sees if pixel value is less than the factor of quad\n if (red < quads && blue < quads && green < quads) {\n spot.setColor(new Color(2, 32, 62));\n }\n else if (red < quads*2 && blue < quads*2 && green < quads*2 ) {\n spot.setColor(new Color(198, 37, 8));\n }\n else if (red < quads*3 && blue < quads*3 && green < quads*3) {\n spot.setColor(new Color(102, 157, 160));\n }\n else {\n spot.setColor(new Color(250, 238, 192));\n }\n }\n me1.explore();\n me1.write(\"images/selfie2.jpg\");\n \n /**\n * custom color palette\n */\n pix = me2.getPixels();\n \n for (Pixel spot: pix) {\n red = spot.getRed();\n blue = spot.getBlue();\n green = spot.getGreen();\n \n //sets color to new value if under a certain value\n if (red < 63 && blue < 63 && green < 63) {\n spot.setColor(new Color(77, 105, 170));\n }\n else if (red < 127 && blue < 127 && green < 127) {\n spot.setColor(new Color(71, 183, 116));\n }\n else if (red < 191 && blue < 191 && green < 191) {\n spot.setColor(new Color(254, 129, 99));\n }\n else {\n spot.setColor(new Color(254, 202, 99));\n }\n }\n me2.explore();\n me2.write(\"images/selfie3.jpg\");\n \n }",
"public String replaceOneCharacter() {\n int colNumber = idx%col;\n int rowNumber = idx/col;\n hidden[rowNumber][colNumber] = original[rowNumber][colNumber];\n idx++;\n return(getImage());\n }",
"public void unsetWeatherImage()\n {\n synchronized (monitor())\n {\n check_orphaned();\n get_store().remove_element(WEATHERIMAGE$2, 0);\n }\n }",
"public void changeImage() {\r\n this.image = ColourDoor.image2;\r\n }",
"public void changeXMLFile() throws IOException {\n File orig = new File(RunnerClass.homedir + \"launch4j.xml\");\n File custom = new File(RunnerClass.homedir + \"launch4j2.xml\");\n BufferedReader br = new BufferedReader(new FileReader(orig));\n PrintWriter pw = new PrintWriter(new FileWriter(custom));\n int line = 0;\n String s;\n //Reads all lines, and replaces 5th line with new destination file\n while ((s = br.readLine()) != null) {\n line++;\n if (line == 5)\n pw.println(\" <outfile>\" + exeF.getCanonicalPath() + \"</outfile>\");\n else if(line == 18)\n pw.println(\" <minVersion>\"+ getFullVersion(RunnerClass.mf.generalOptionalPanel.javaVersion.getText().trim()) +\"</minVersion>\");\n else\n pw.println(s);\n }\n br.close();\n pw.close();\n //Deletes original file, renames temp to original\n RunnerClass.logger.info(\"del: \" + orig.delete());\n RunnerClass.logger.info(\"ren: \" + custom.renameTo(orig));\n }",
"@Override\n\tpublic void updateAvatar(CommonsMultipartFile fileUpload, String username) throws IOException {\n\t\tString savePath = imageConfiguration.getAvatarPackage(username);\n\t\tif (imageRepository.findImageNameByUsername(username) != null) {\n\t\t\tfileUpload.transferTo(new File(savePath));\n\t\t} else {\n\t\t\tUser user = findOne(username);\n\t\t\tImage image = new Image();\n\t\t\timage.setUser(user);\n\t\t\timage.setImageName(user.getUsername());\n\t\t\timage.setImageLocation(savePath);\n\t\t\timageService.create(image);\n\t\t\tfileUpload.transferTo(new File(savePath));\n\t\t}\n\t}",
"public void editImage(Mask m, boolean bNw) {\t\r\n\t\tfor (int i = 0; i < m.mask.length; i++) {\r\n\t\t\tfor (int j = 0; j < m.mask[0].length; j++) {\r\n\t\t\t\tif (m.mask[i][j] == false && bNw == false) {\r\n\t\t\t\t\t\tupdatePixel(m,i,j);\r\n\t\t\t\t\t}\r\n\t\t\t\telse {\r\n\t\t\t\t\tif (bNw) {\r\n\t\t\t\t\t\tbnwPixel(m,i,j);\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"@Override\n\tpublic void pintar() {\n\t\n\t\tapp.image(water, this.px, this.py);\n\t\t\n\t}",
"public void ChangeImage(Image SymImage){\n\n this.imgBackground = SymImage;\n /**\n imwidth = (double) this.imgBackground.getWidth(null);\n oldwidth = 461;\n oldheight = 361;\n */\n }",
"public static void testMirrorTemple()\n {\n Picture temple = new Picture(\"temple.jpg\");\n temple.explore();\n temple.mirrorTemple();\n temple.explore();\n }",
"public void run() {\n sight.setImageBitmap(bmp);\n // old = null;\n }",
"@HTTP(\n method = \"PUT\",\n path = \"/apis/config.openshift.io/v1/images/{name}\",\n hasBody = true\n )\n @Headers({ \n \"Content-Type: application/json\",\n \"Accept: */*\"\n })\n KubernetesCall<Image> replaceImage(\n @Path(\"name\") String name, \n @Body Image body, \n @QueryMap ReplaceImage queryParameters);",
"public ReplaceImage pretty(String pretty) {\n put(\"pretty\", pretty);\n return this;\n }",
"private void updateToFile(PQNode node) throws Exception{\n List<PQNode> nodes = retrieveWholeFile(node.getPqIndex());\n int replaceIndex = node.getPqIndex()-bufStart;\n\n nodes.set(replaceIndex,node);\n int fileId = (node.getPqIndex()-1)/ENTRY_BLOCK_SIZE;\n File file = new File(DIRECTORY + getMapFileName(NAME_PATTERN, fileId));\n storeToFile(file,nodes, false);\n }",
"private void setPixels() {\n\t\t\tfinal byte[] dest = new byte[(int) (getMetadata().get(0).getAxisLength(\n\t\t\t\tAxes.X) * getMetadata().get(0).getAxisLength(Axes.Y))];\n\t\t\tlong lastImage = -1;\n\n\t\t\t// fill in starting image contents based on last image's dispose\n\t\t\t// code\n\t\t\tif (getMetadata().getLastDispose() > 0) {\n\t\t\t\tif (getMetadata().getLastDispose() == 3) { // use image before last\n\t\t\t\t\tfinal long n = getMetadata().get(0).getPlaneCount() - 2;\n\t\t\t\t\tif (n > 0) lastImage = n - 1;\n\t\t\t\t}\n\n\t\t\t\tif (lastImage != -1) {\n\t\t\t\t\tfinal byte[] prev = getMetadata().getImages().get((int) lastImage);\n\t\t\t\t\tSystem.arraycopy(prev, 0, dest, 0, (int) (getMetadata().get(0)\n\t\t\t\t\t\t.getAxisLength(Axes.X) * getMetadata().get(0).getAxisLength(\n\t\t\t\t\t\t\tAxes.Y)));\n\t\t\t\t}\n\t\t\t}\n\n\t\t\t// copy each source line to the appropriate place in the destination\n\n\t\t\tint pass = 1;\n\t\t\tint inc = 8;\n\t\t\tint iline = 0;\n\t\t\tfor (int i = 0; i < getMetadata().getIh(); i++) {\n\t\t\t\tint line = i;\n\t\t\t\tif (getMetadata().isInterlace()) {\n\t\t\t\t\tif (iline >= getMetadata().getIh()) {\n\t\t\t\t\t\tpass++;\n\t\t\t\t\t\tswitch (pass) {\n\t\t\t\t\t\t\tcase 2:\n\t\t\t\t\t\t\t\tiline = 4;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\tcase 3:\n\t\t\t\t\t\t\t\tiline = 2;\n\t\t\t\t\t\t\t\tinc = 4;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\tcase 4:\n\t\t\t\t\t\t\t\tiline = 1;\n\t\t\t\t\t\t\t\tinc = 2;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t\tline = iline;\n\t\t\t\t\tiline += inc;\n\t\t\t\t}\n\t\t\t\tline += getMetadata().getIy();\n\t\t\t\tif (line < getMetadata().get(0).getAxisLength(Axes.Y)) {\n\t\t\t\t\tfinal int k = line * (int) getMetadata().get(0).getAxisLength(Axes.X);\n\t\t\t\t\tint dx = k + getMetadata().getIx(); // start of line in dest\n\t\t\t\t\tint dlim = dx + getMetadata().getIw(); // end of dest line\n\t\t\t\t\tif ((k + getMetadata().get(0).getAxisLength(Axes.X)) < dlim) dlim =\n\t\t\t\t\t\tk + (int) getMetadata().get(0).getAxisLength(Axes.X);\n\t\t\t\t\tint sx = i * getMetadata().getIw(); // start of line in\n\t\t\t\t\t// source\n\t\t\t\t\twhile (dx < dlim) {\n\t\t\t\t\t\t// map color and insert in destination\n\t\t\t\t\t\tfinal int index = getMetadata().getPixels()[sx++] & 0xff;\n\t\t\t\t\t\tdest[dx++] = (byte) index;\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t\tgetMetadata().getColorTables().add(getMetadata().getAct());\n\t\t\tgetMetadata().getImages().add(dest);\n\t\t}",
"public boolean updateWorkerPic(String path, String oldPath, byte[] pic) {\n\n\t\t\tboolean f = false;\n\n\t\t\ttry {\n\n\t\t\t\tFile oldFile = new File(oldPath);\n\t\t\t\tboolean f1 = oldFile.delete();\n\n\t\t\t\tif (f1 == true) {\n\n\t\t\t\t\tFileOutputStream fos = new FileOutputStream(path);\n\t\t\t\t\tSystem.out.println(path);\n\t\t\t\t\tfos.write(pic);\n\t\t\t\t\tfos.close();\n\t\t\t\t\tfos.flush();\n\n\t\t\t\t\tf = true;\n\n\t\t\t\t}\n\n\t\t\t} catch (Exception e) {\n\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t\treturn f;\n\t\t}",
"public static void clickrun2() {\n JFileChooser file = new JFileChooser();\n file.setCurrentDirectory(new File(System.getProperty(\"user.home\")));\n FileNameExtensionFilter filter = new FileNameExtensionFilter(\"*.images\", \"jpg\", \"png\");\n file.addChoosableFileFilter(filter);\n int result = file.showSaveDialog(null);\n if (result == JFileChooser.APPROVE_OPTION) {\n File selectedFile = file.getSelectedFile();\n String path = selectedFile.getAbsolutePath();\n lblAnhsanphamsua.setIcon(ResizeImage2(path, null));\n ImagePast2 = path;\n System.out.println(ImagePast2);\n } else {\n\n }\n }",
"private void getNewImage() {\n try {\n URL imageUrl = new URL(path);\n URLConnection uc = imageUrl.openConnection();\n\n InputStream is = uc.getInputStream();\n BufferedInputStream bis = new BufferedInputStream(is);\n\n ByteArrayOutputStream buffer = new ByteArrayOutputStream();\n int current;\n while ((current = bis.read()) != -1) {\n buffer.write((byte) current);\n }\n final byte[] data = buffer.toByteArray();\n // enqueue UI update as a priority\n Handler handler = new Handler(Looper.getMainLooper());\n handler.post(new Runnable() {\n public void run() {\n view.setImageBitmap(BitmapFactory.decodeByteArray(\n data, 0, data.length));\n }\n });\n // update database while that is queueing\n ContentValues values = new ContentValues();\n values.put(MovieEntry.COLUMN_POSTER, data);\n context.getContentResolver().update(MovieEntry.buildMovieUriWithId(movieId),\n values, null, null);\n } catch (Exception E) {\n Log.i(TAG, E.toString());\n E.printStackTrace();\n }\n }",
"void newframe() {\n\t\ti = oldind;\r\n\t\toldind = newind;\r\n\t\tnewind = i;\r\n\r\n\t\ti = 0;\r\n\t\tmapind = oldind;\r\n\t\tfor (int y = 0; y < height; y++) {\r\n\t\t\tfor (int x = 0; x < width; x++) {\r\n\t\t\t\tshort data = (short) ((ripplemap[mapind - width] + ripplemap[mapind + width] + ripplemap[mapind - 1] + ripplemap[mapind + 1]) >> 1);\r\n\t\t\t\tdata -= ripplemap[newind + i];\r\n\t\t\t\tdata -= data >> 5;\r\n\t\t\t\tripplemap[newind + i] = data;\r\n\r\n\t\t\t\t// where data=0 then still, where data>0 then wave\r\n\t\t\t\tdata = (short) (1024 - data);\r\n\r\n\t\t\t\t// offsets\r\n\t\t\t\ta = ((x - hwidth) * data / 1024) + hwidth;\r\n\t\t\t\tb = ((y - hheight) * data / 1024) + hheight;\r\n\r\n\t\t\t\t// bounds check\r\n\t\t\t\tif (a >= width)\r\n\t\t\t\t\ta = width - 1;\r\n\t\t\t\tif (a < 0)\r\n\t\t\t\t\ta = 0;\r\n\t\t\t\tif (b >= height)\r\n\t\t\t\t\tb = height - 1;\r\n\t\t\t\tif (b < 0)\r\n\t\t\t\t\tb = 0;\r\n\r\n\t\t\t\tripple[i] = texture[a + (b * width)];\r\n\t\t\t\tmapind++;\r\n\t\t\t\ti++;\r\n\t\t\t}\r\n\t\t}\r\n\t}",
"public void actualizarImagen() {\n\t\tentidadGrafica.actualizarImagen(this.valor);\n\t}",
"public void writeOutputSettings(File file) throws IOException\n{\n if (file != null && m.getOutputImageManager().getMosaic() != null)\n {\n boolean[][] vFlip = m.getOutputImageManager().getMosaic().getFlipV();\n boolean[][] hFlip = m.getOutputImageManager().getMosaic().getFlipH();\n String[] lines = new String[8];\n lines[0] = \"output\";\n lines[1] = new Integer((int)cp5.getController(\"sizeOfTiles\").getValue()).toString(); //size of cells\n lines[2] = new Integer((int)cp5.getController(\"evenRowShift\").getValue()).toString(); //even row shift\n lines[3] = new Integer((int)cp5.getController(\"oddRowShift\").getValue()).toString(); //odd row shift\n lines[4] = new Integer(vFlip[0].length-1).toString(); //number of x cells\n lines[5] = new Integer(vFlip.length).toString(); //number of y cells\n int i = 6;\n \n boolean[][] array = vFlip;\n while(i < lines.length)\n {\n lines[i] = \"\";\n for (int j = 0; j < array[0].length; j++)\n {\n for (int k = 0; k < array.length; k++)\n {\n if (array[k][j])\n {\n lines[i] += \"t\";\n } else\n {\n lines[i] += \"f\";\n }\n lines[i] += \"-\";\n }\n lines[i] = lines[i].substring(0,lines[i].length()-1);\n lines[i] += \";\";\n }\n array = hFlip;\n i++;\n }\n \n // list the files in the data folder\n String[] filenames = file.list();\n int fileNumber = 1;\n \n for(String f: filenames)\n {\n if(f.endsWith(\".config\") && f.startsWith(\"OutputConfiguration\"))\n {\n f = f.substring(f.length()-8,f.length()-7);\n if(isParsable(f))\n {\n fileNumber = max(Integer.parseInt(f),fileNumber);\n fileNumber++;\n }\n \n }\n }\n \n saveStrings(file+\"/\"+\"OutputConfiguration\"+fileNumber+\".config\", lines);\n }\n}",
"public void replaceFile(String inputFilename) {\n try {\n FileReader fr = new FileReader(inputFilename);\n BufferedReader br = new BufferedReader(fr);\n String line;\n\n while ((line = br.readLine()) != null) {\n if (line.isEmpty()) {\n System.out.println();\n } else {\n line = replaceLine(line);\n System.out.println(line);\n }\n }\n } catch (IOException e) {\n System.out.println(\"ERROR: \" + e.getMessage());\n }\n }",
"@Test\r\n public void testComplex(){\r\n List<Tone> palette = StandardPalettes.PWG_STANDARD;\r\n\r\n BufferedImage image = ImageFileUtils.loadImageResource(\"/sampleImages/complex/rooves.jpg\");\r\n\r\n PaletteReplacer replacer = new PaletteReplacer();\r\n\r\n BufferedImage result = replacer.replace(image, palette);\r\n\r\n BufferedImage target = ImageFileUtils.loadImageResource(\"/resultImages/paletteReplacer/pwgRooves.png\");\r\n\r\n assertPixelsMatch(target, result);\r\n }",
"public void replaceWithCovers()\r\n/* 197: */ {\r\n/* 198:156 */ short[] covs = Arrays.copyOf(this.Covers, 29);\r\n/* 199:157 */ CoverLib.replaceWithCovers(this.k, this.l, this.m, this.n, this.CoverSides, covs);\r\n/* 200: */ }",
"public static Bitmap resize(Bitmap in, int newH, int newW) {\n\n Bitmap out = Bitmap.createBitmap(newH, newW, Bitmap.Config.ARGB_4444);\n int inW = in.getWidth();\n int inH = in.getHeight();\n int H;\n int W;\n\n Bitmap resized = null;\n\n /*\n 1) RIDIMENSIONIAMO L'IMMAGINE ALLA DIMENSIONE MASSIMA VOLUTA MANTENENDO L'ASPECT RATIO\n */\n if (inH < inW) {\n float ratio = (float) inW / newW;\n H = (int) (inH / ratio);\n resized = Bitmap.createScaledBitmap(in, newW, H, true);\n\n //se filter=false , l'immagine non viene filtrata--> maggiori performance, peggiore qualità\n }\n if (inH > inW) {\n float ratio = (float) inH / newH;\n W = (int) (inW / ratio);\n resized = Bitmap.createScaledBitmap(in, W, newH, true);\n\n //se filter=false , l'immagine non viene filtrata--> maggiori performance, peggiore qualità\n }\n if (inH == inW) {\n resized = Bitmap.createScaledBitmap(in, newW, newH, true);\n\n }\n\n /*\n 2) Creiamo il contenitore finale della nostra immagine e riempiamo manualmente i pixel\n */\n out = Bitmap.createBitmap(newW, newH, resized.getConfig());\n Canvas canvas = new Canvas(out);\n canvas.drawBitmap(resized, new Matrix(), null);\n\n return out;\n }",
"public native MagickImage despeckleImage() throws MagickException;",
"public void loadimage(File file) {\n\t\tthis.transformedImageIcon = new ImageIcon(file.getAbsolutePath()); //Here we are fetching the Image from the File into an ImageIcon \n\t\tImage image = transformedImageIcon.getImage(); //Here we are getting the Actual Concrete Image from the ImageIcon which fetched the Image from the File \n\t\tupdateImage(image); //Here it will Set the Image to the JLabel after calling the Scaling Method \n\t}"
]
| [
"0.63937587",
"0.5687046",
"0.56526566",
"0.54738593",
"0.547063",
"0.5413172",
"0.5389582",
"0.53681856",
"0.53652376",
"0.5364564",
"0.5345936",
"0.53440565",
"0.5330016",
"0.52858543",
"0.52806616",
"0.52511644",
"0.5235328",
"0.5234176",
"0.5224846",
"0.5215565",
"0.52041095",
"0.5203068",
"0.5201874",
"0.51925796",
"0.51900274",
"0.5181834",
"0.51511705",
"0.51247454",
"0.5114569",
"0.510427",
"0.5102291",
"0.5093297",
"0.50741255",
"0.50690275",
"0.5066438",
"0.505204",
"0.50502694",
"0.503215",
"0.50239414",
"0.5023277",
"0.50124234",
"0.4994524",
"0.49938124",
"0.4993649",
"0.49809024",
"0.49799886",
"0.4973691",
"0.4971317",
"0.49580902",
"0.49563763",
"0.4954431",
"0.4951816",
"0.4951813",
"0.49485335",
"0.49481094",
"0.4942691",
"0.49395692",
"0.49347046",
"0.49304008",
"0.4929798",
"0.49242768",
"0.49198437",
"0.49157903",
"0.49102256",
"0.4903769",
"0.4903052",
"0.4893586",
"0.48926356",
"0.48822",
"0.48790982",
"0.4873509",
"0.48713788",
"0.48620042",
"0.48487",
"0.48466796",
"0.4846053",
"0.48423877",
"0.48375",
"0.48157367",
"0.48122513",
"0.48097038",
"0.4805474",
"0.48035136",
"0.48015738",
"0.48014358",
"0.47965008",
"0.47927514",
"0.47837722",
"0.4783434",
"0.4778772",
"0.47786793",
"0.47745794",
"0.4766659",
"0.47649175",
"0.47615275",
"0.47555536",
"0.47518343",
"0.47517502",
"0.47499293",
"0.47447854"
]
| 0.644516 | 0 |
one method that runs for all buttons when they're clicked to use less code | public void imageClicked(int imageView){
//get text from all buttons
String name=etName.getText().toString().trim();
String phoneNum=etPhoneNumber.getText().toString().trim();
String website=etWebsite.getText().toString().trim();
String address=etLocation.getText().toString().trim();
//check if strings are empty, otherwise close this activity and send intent
if(name.isEmpty()||phoneNum.isEmpty()||website.isEmpty()||address.isEmpty()){
Toast.makeText(this, "Enter all fields", Toast.LENGTH_SHORT).show();
}else{
Intent intent= new Intent();
intent.putExtra("name", name);
intent.putExtra("phone number",phoneNum);
intent.putExtra("website",website);
intent.putExtra("address", address);
intent.putExtra("image",imageView);
setResult(RESULT_OK,intent);
Activity2.this.finish();
}
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"protected void onClick() {\n for(Runnable action : onClick) action.run();\n }",
"@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\tif(e.getSource().equals(ClientWindow.retButtons()[0])){\n\t\t\tperformButton(0);\n\t\t}\n\t\tif(e.getSource().equals(ClientWindow.retButtons()[1])){\n\t\t\tperformButton(1);\n\t\t}\n\t\tif(e.getSource().equals(ClientWindow.retButtons()[2])){\n\t\t\tperformButton(2);\n\t\t}\n\t\tif(e.getSource().equals(ClientWindow.retButtons()[3])){\n\t\t\tperformButton(3);\n\t\t}\n\t\tif(e.getSource().equals(ClientWindow.retButtons()[4])){\n\t\t\tperformButton(4);\n\t\t}\n\t\tif(e.getSource().equals(ClientWindow.retButtons()[5])){\n\t\t\tperformButton(5);\n\t\t}\n\t\tif(e.getSource().equals(ClientWindow.retButtons()[6])){\n\t\t\tperformButton(6);\n\t\t}\n\t\tif(e.getSource().equals(ClientWindow.retButtons()[7])){\n\t\t\tperformButton(7);\n\t\t}\n\t\tif(e.getSource().equals(ClientWindow.retButtons()[8])){\n\t\t\tperformButton(8);\n\t\t}\n\t}",
"@Override\n\tprotected void setOnClickForButtons() {\n\t\tthis.buttons[0].setOnClickListener(new OnClickListener() {\n\t\t\t@Override\n\t\t\tpublic void onClick(View v) {\n\t\t\t\tIntent i = new Intent(getActivity(), MainScreenActivity.class);\n\t\t\t\tstartActivity(i);\n\t\t\t\tMainFunctions.selectedOption = 1;\n\t\t\t\tdestroyServices();\n\t\t\t\tfinish();\n\t\t\t}\n\t\t});\n\n\t\t/* message box - onclick event */\n\t\tthis.buttons[1].setOnClickListener(new OnClickListener() {\n\t\t\t@Override\n\t\t\tpublic void onClick(View v) {\n\t\t\t\tdestroyServices();\n\t\t\t\tMainFunctions.selectedOption = 2;\n\t\t\t\tfinish();\n\t\t\t}\n\t\t});\n\t\t\n\t\t/* one tick sound */\n\t\tfor (int i = 0; i < this.totalButtons; i++){\n\t\t\tfinal String desc = buttons[i].getTag().toString();\n\t\t\tbuttons[i].setOnFocusChangeListener(new View.OnFocusChangeListener() {\n\t\t\t\tpublic void onFocusChange(View v, boolean hasFocus) {\n\t\t\t\t\tif (hasFocus) {\n\t\t\t\t\t\tLog.i(TAG, \"Button \" + desc + \" was selected\");\n\t\t\t\t\t\tlogFunctions.logTextFile(\"Button \" + desc + \" was selected\");\n\t\t\t\t\t\tspeakButton(desc, 1.0f, 1.0f);\t\t\t\t\t\t\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t});\n\t\t}\n\t}",
"private void init_buttons(){\r\n /**\r\n * BOTON NUEVO\r\n */\r\n im_tool1.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n if(mouseEvent.getClickCount() > 0){\r\n botonInicio();\r\n botonNuevo();\r\n }\r\n }\r\n });\r\n /**\r\n * BOTON EDITAR\r\n */\r\n im_tool2.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n if(mouseEvent.getClickCount() > 0){\r\n botonEditar();\r\n }\r\n }\r\n });\r\n /**\r\n * BOTON GUARDAR\r\n */\r\n im_tool3.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n if(mouseEvent.getClickCount() > 0){\r\n botonGuardar();\r\n }\r\n }\r\n }); \r\n /**\r\n * BOTON ELIMINAR\r\n */\r\n im_tool4.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n if(mouseEvent.getClickCount() > 0){\r\n botonEliminar();\r\n }\r\n }\r\n });\r\n /**\r\n * BOTON IMPRIMIR\r\n */\r\n im_tool5.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n if(mouseEvent.getClickCount() > 0){ \r\n botonImprimir();\r\n }\r\n }\r\n });\r\n /**\r\n * BOTON REGRESAR\r\n */\r\n im_tool6.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n if(mouseEvent.getClickCount() > 0){\r\n botonInicio();\r\n }\r\n }\r\n });\r\n /**\r\n * BOTON POR ASIGNAR\r\n */\r\n im_tool7.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n if(mouseEvent.getClickCount() > 0){\r\n //\r\n }\r\n }\r\n });\r\n /**\r\n * BOTON NOTAS DE CREDITO\r\n */\r\n im_tool8.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n if(mouseEvent.getClickCount() > 0){\r\n //\r\n }\r\n }\r\n });\r\n /**\r\n * BOTON DEVOLUCION\r\n */\r\n im_tool9.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n if(mouseEvent.getClickCount() > 0){\r\n //\r\n }\r\n }\r\n });\r\n /**\r\n * BOTON BUSCAR\r\n */\r\n im_tool12.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n switch (mouseEvent.getClickCount()){\r\n case 1:\r\n botonInicio();\r\n botonBuscar();\r\n break;\r\n case 2:\r\n Datos.setIdButton(2003041);\r\n Gui.getInstance().showBusqueda(\"Busqueda\"); \r\n break;\r\n }\r\n }\r\n });\r\n /**\r\n * SELECCION EN LA TABLA\r\n */\r\n tb_guias.setOnMouseClicked((MouseEvent mouseEvent) -> {\r\n if(mouseEvent.getButton().equals(MouseButton.PRIMARY)){\r\n if(mouseEvent.getClickCount() > 0){\r\n if ((tb_guias.getItems() != null) && (!tb_guias.getItems().isEmpty()))\r\n selectedRowGuide();\r\n }\r\n }\r\n }); \r\n /**\r\n * metodo para mostrar buscar el nro de guia\r\n * param: ENTER O TAB\r\n */\r\n tf_nroguia.setOnKeyReleased((KeyEvent ke) -> {\r\n if (ke.getCode().equals(KeyCode.ENTER)){\r\n //Valida que el evento se haya generado en el campo de busqueda\r\n if(((Node)ke.getSource()).getId().equals(\"tf_nroguia\")){\r\n //Solicita los datos y envia la Respuesta a imprimirse en la Pantalla\r\n Datos.setLog_cguias(new log_CGuias()); \r\n boolean boo = Ln.getInstance().check_log_CGuias_rela_caja(tf_nroguia.getText()); \r\n numGuias = 0;\r\n if(boo){\r\n Datos.setRep_log_cguias(Ln.getInstance().find_log_CGuias(tf_nroguia.getText(), \"\", \"ncaja\", Integer.parseInt(rows)));\r\n loadTable(Datos.getRep_log_cguias()); \r\n }\r\n else{\r\n change_im_val(0, im_checkg); \r\n Gui.getInstance().showMessage(\"El Nro. de \" + ScreenName + \" NO existe!\", \"A\");\r\n tf_nroguia.requestFocus();\r\n }\r\n }\r\n }\r\n });\r\n /**\r\n * metodo para mostrar buscar el nro de guia\r\n * param: ENTER O TAB\r\n */\r\n tf_nrorguia.setOnKeyReleased((KeyEvent ke) -> {\r\n if (ke.getCode().equals(KeyCode.ENTER)){\r\n //Valida que el evento se haya generado en el campo de busqueda\r\n if(((Node)ke.getSource()).getId().equals(\"tf_nrorguia\")){\r\n //Solicita los datos y envia la Respuesta a imprimirse en la Pantalla\r\n boolean booa = true; \r\n if(booa){\r\n boolean booc = Ln.getInstance().check_log_CGuias_caja(tf_nrorguia.getText()); \r\n if(booc){\r\n change_im_val(0, im_checkg); \r\n Gui.getInstance().showMessage(\"El Nro. de Guia ya esta relacionado!\", \"A\");\r\n tf_nrorguia.requestFocus();\r\n }\r\n else{\r\n for (int i = 0; i < log_guide_guia.size(); i++) {\r\n if(tf_nrorguia.getText().equals(tb_guias.getItems().get(i).getGuias())){\r\n booa = false;\r\n Gui.getInstance().showMessage(\"El Nro. de Guia ya esta relacionado!\", \"A\");\r\n tf_nrorguia.requestFocus();\r\n break;\r\n }\r\n } \r\n if(booa){\r\n log_Guide_rel_inv guide_carga = new log_Guide_rel_inv();\r\n\r\n List<Fxp_Archguid_gfc> data = \r\n Ln.getList_log_Archguid_gfc(Ln.getInstance().find_Archguid_gfc(tf_nrorguia.getText()));\r\n\r\n if (data.get(0).getStat_guia().equals(\"X\")\r\n || data.get(0).getStat_guia().equals(\"C\")){\r\n guide_carga.setNumorden(String.valueOf((log_guide_guia.size() + 1)));\r\n guide_carga.setGuias(tf_nrorguia.getText());\r\n guide_carga.setNumfact(data.get(0).getNumfact());\r\n guide_carga.setNumclie(data.get(0).getNumclie());\r\n\r\n if (data.get(0).getStat_guia().equals(\"A\")){\r\n if (tipoOperacion == 1)\r\n guide_carga.setStat_guia(null);\r\n else\r\n guide_carga.setStat_guia(data.get(0).getStat_guia());\r\n }\r\n else{\r\n guide_carga.setStat_guia(null);\r\n }\r\n \r\n \r\n log_guide_guia.add(guide_carga);\r\n\r\n loadTableGuide_guias();\r\n change_im_val(200, im_checkg); \r\n\r\n numFactCarga = numFactCarga + data.get(0).getNumfact();\r\n numClieCarga = numClieCarga + data.get(0).getNumclie();\r\n\r\n tf_nrorguia.setText(\"\");\r\n }else{\r\n if (data.get(0).getStat_guia().equals(\"\")){\r\n Gui.getInstance().showMessage(\"El Nro. de Guia NO tiene relación de Guia de Carga!\", \"A\");\r\n }\r\n else{\r\n Gui.getInstance().showMessage(\"El Nro. de Guia ya esta relacionado!\", \"A\");\r\n }\r\n tf_nrorguia.requestFocus();\r\n }\r\n \r\n }\r\n }\r\n }\r\n else{\r\n change_im_val(0, im_checkg); \r\n Gui.getInstance().showMessage(\"El Nro. de Guia NO existe!\", \"A\");\r\n tf_nrorguia.requestFocus();\r\n }\r\n }\r\n }\r\n });\r\n }",
"public void buttonClicked();",
"@Override\n\tprotected void on_button_pressed(String button_name) {\n\n\t}",
"private void allBtnActionPerformed(ActionEvent evt) {\n }",
"@Override\n public void onClick(View v) {\n switch(v.getId()) {\n case R.id.button1:\n display.setText(button1.getText());\n button1.setBackgroundColor(Color.BLUE);\n reset(1);\n tuningF = getNoteFrequency(1, tuning);\n tuningIndex = 1;\n break;\n case R.id.button2:\n display.setText(button2.getText());\n button2.setBackgroundColor(Color.BLUE);\n reset(2);\n tuningF = getNoteFrequency(2, tuning);\n tuningIndex = 2;\n break;\n case R.id.button3:\n display.setText(button3.getText());\n button3.setBackgroundColor(Color.BLUE);\n reset(3);\n tuningF = getNoteFrequency(3, tuning);\n tuningIndex = 3;\n break;\n case R.id.button4:\n display.setText(button4.getText());\n button4.setBackgroundColor(Color.BLUE);\n reset(4);\n tuningF = getNoteFrequency(4, tuning);\n tuningIndex = 4;\n break;\n case R.id.button5:\n display.setText(button5.getText());\n button5.setBackgroundColor(Color.BLUE);\n reset(5);\n tuningF = getNoteFrequency(5, tuning);\n tuningIndex = 5;\n break;\n case R.id.button6:\n display.setText(button6.getText());\n button6.setBackgroundColor(Color.BLUE);\n reset(6);\n tuningF = getNoteFrequency(6, tuning);\n tuningIndex = 6;\n break;\n }\n }",
"public void listenButtons() {\n\n playGameButton.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n mActivities = MyActivities.PLAY_GAME;\n startActivity();\n }\n });\n\n freePlayButton.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n mActivities = MyActivities.FREE_PLAY;\n startActivity();\n }\n });\n\n informationIcon.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n mActivities = MyActivities.POP_UP;\n startActivity();\n }\n });\n }",
"@Override\n public void onClick(View view) {\n Toast.makeText(MainActivity.this,\"ButtonHandler onClick: \"+view,Toast.LENGTH_SHORT).show();\n\n //Determine the Button was clicked\n for (int row = 0; row < TicTacToe.SIDE; row++)\n for (int col = 0; col < TicTacToe.SIDE; col++)\n {\n if (view == buttons [row][col]){\n update(row,col);\n }\n }\n }",
"private void button1MouseClicked(MouseEvent e) {\n\t}",
"public void buttonClicked() {\n mSanitizorGame.buttonClicked();\n }",
"private void doButtons()\n {\n if (scopes.size()>1) addButtons();\n else hideButtons();\n }",
"private void button1MouseClicked(MouseEvent e) {\n }",
"@Override\n public void actionPerformed(ActionEvent e) {\n if(e.getSource().equals(btnQuayLai)){\n btnquaylaiclick();}\n }",
"void buttonPressed(ButtonType type);",
"private void boundButtons() {\r\n \tsingleplayer = (Button) findViewById(R.id.single);\r\n \tsingleplayer.setTypeface(tf);\r\n \tsingleplayer.setOnClickListener(new OnClickListener() {\r\n \t\t\r\n \t\t/** Start a drawing surface for one player*/\r\n\t\t\t@Override\r\n\t\t\tpublic void onClick(View v) {\r\n\t\t\t\tIntent intent = new Intent(Main.this, DrawingActivitySingle.class);\r\n\t\t\t\tstartActivity(intent);\r\n\t\t}});\r\n \t\r\n \tmultiplayer = (Button) findViewById(R.id.multi);\r\n \tmultiplayer.setTypeface(tf);\r\n \tmultiplayer.setOnClickListener(new OnClickListener() {\r\n \t\t\r\n \t\t/** Connect to other users to start a drawing surface*/\r\n\t\t\t@Override\r\n\t\t\tpublic void onClick(View v) {\r\n\t\t\t\tif (multiplayer.isEnabled()) {\r\n\t\t\t\t\tmultiplayer.setEnabled(false);\r\n\t\t\t\t\t\r\n\t\t\t\t\tinitMultiPlayer();\r\n\t\t\t\t}\r\n\t\t}});\r\n \t\r\n \toptions = (Button) findViewById(R.id.options);\r\n \toptions.setTypeface(tf);\r\n \toptions.setOnClickListener(new OnClickListener() {\r\n \t\t\r\n \t\t/** Start the options menu */\r\n\t\t\t@Override\r\n\t\t\tpublic void onClick(View v) {\r\n\t\t\t\tIntent intent = new Intent(Main.this, Options.class);\r\n\t\t\t\tstartActivity(intent);\r\n\t\t}});\r\n }",
"@Override\n public void onClick(View v) {\n buttonPressed = 0;\n switch (v.getId()) {\n case R.id.button01:\n buttonPressed = 1;\n break;\n\n case R.id.button02:\n buttonPressed = 2;\n break;\n }\n launchTask();\n }",
"private void setupButtons() {\n for (int i = 0; i < players.size(); i++) {\n final int j = i + 1;\n players.get(i).setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n buttonPushed(j);\n }\n });\n }\n }",
"@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\tRunAll();\n\t}",
"public void eventos() {\n btnAbrir.addActionListener(new ActionListener() {\n @Override\n public void actionPerformed(ActionEvent evt) {\n btnAbrirActionPerformed(evt);\n }\n });\n }",
"public void onClick(View clickedButton) {\n switch (clickedButton.getId()) {\n case R.id.calculateButton:\n calculate();\n break;\n case R.id.saveButton:\n save();\n break;\n case R.id.previousResultsButton:\n show();\n break;\n }\n }",
"public void buttonShowAll(ActionEvent actionEvent) {\n }",
"@Override\n public void onClick(View view) {\n Button trykket = null;\n for (int i = 0; i < 30 ; i++) {\n if (view==buttons.get(i)){\n trykket=buttons.get(i);\n }\n }\n assert trykket != null;\n gæt(trykket);\n\n //vi afslutter spiller hvis det er slut eller vundet.\n if(logik.erSpilletSlut()){\n if(logik.erSpilletTabt()){\n // die.start();\n slutspilllet(false);\n }\n if(logik.erSpilletVundet()) slutspilllet(true);\n }\n\n }",
"public FinalActionButtons()\n {\n eliminateButton = new JButton( \"Eliminate a Candidate\" );\n eliminateButton.setPreferredSize( new Dimension( 300, 100 ) );\n eliminateButton.addActionListener( this );\n add( eliminateButton );\n eliminateButton.setFont( new Font( \"Helvetica\", Font.PLAIN, 20 ) );\n\n doneButton = new JButton( \"Get Statistics\" );\n doneButton.setPreferredSize( new Dimension( 300, 100 ) );\n doneButton.addActionListener( this );\n add( doneButton );\n doneButton.setFont( new Font( \"Helvetica\", Font.PLAIN, 20 ) );\n }",
"public void buttonAction(ButtonClass button){\n //Sets the chosenButton to most recently chosen button\n chosenButton = button;\n chosenGame = chosenButton.getSmallGame();\n allClickedButtons.add(chosenButton);\n nextGamePosition = chosenButton.getButtonPosition();\n checkAndUpdateIfSmallGameWin(chosenGame);\n updateBigGameBoardForNextMove();\n }",
"void bsButtonHandling(){\n\n Boolean checkFlag = false;\n for(int i = 0; i < 4; ++i){\n if(operatorButtonClicked[i]){\n checkFlag = true;\n break;\n }\n }\n\n // -----------------------------------------------------\n // if an operator button was clicked then ignore BS\n if(checkFlag == false){\n numberOnDisplay = Integer.parseInt(display.getText().toString());\n numberOnDisplay = numberOnDisplay/10;\n display.setText(Integer.toString(numberOnDisplay));\n numberOnDisplay = 0;\n }\n }",
"void mainButtonPressed();",
"private void button1MousePressed(MouseEvent e) {\n }",
"public void updateAllButtons(){\n updateStartButton();\n updateResetButton();\n }",
"private void setButtons()\n\t{\n\t\tstartSim = new JButton(\"Start Sim\");\n\t\tstartSim.addActionListener(this);\n\t\tpauseSim = new JButton(\"Pause Sim\");\n\t\tpauseSim.addActionListener(this);\n\t\taddEat = new JButton(\"Add Eatery\");\n\t\taddEat.addActionListener(this);\n\t\tsubEat = new JButton(\"Subtract Eatery\");\n\t\tsubEat.addActionListener(this);\n\t\taddCash = new JButton(\"Add Cashier\");\n\t\taddCash.addActionListener(this);\n\t\tsubCash = new JButton(\"Subtract Cashier\");\n\t\tsubCash.addActionListener(this);\n\t}",
"private void checkButton(ActionEvent e) {\n List<PuzzleButton> selectedButtons = buttons.stream()\n .filter(PuzzleButton::isSelectedButton)\n .collect(Collectors.toList());\n PuzzleButton currentButton = (PuzzleButton) e.getSource();// getting current button\n currentButton.setSelectedButton(true);\n int currentButtonIndex = buttons.indexOf(currentButton);\n //if no button are selected, do not update collection of PuzzleButton\n if (selectedButtons.size() == 1) {\n int lastClickedButtonIndex = 0;\n\n for (PuzzleButton button : buttons) {\n if (button.isSelectedButton() && !button.equals(currentButton)) {\n lastClickedButtonIndex = buttons.indexOf(button);\n }\n }\n Collections.swap(buttons, lastClickedButtonIndex, currentButtonIndex);\n updateButtons();\n }\n }",
"protected void mouseClicked(int par1, int par2, int par3)\n {\n if (this.buttonId >= 0)\n {\n \t// no setting minimap keybinds to mouse button. Can do so if wanted if I change ZanMinimap to not send every input to Keyboard for processing. Check if it's mouse first\n // this.options.setKeyBinding(this.buttonId, -100 + par3);\n // ((GuiButton)this.controlList.get(this.buttonId)).displayString = this.options.getOptionDisplayString(this.buttonId);\n this.buttonId = -1;\n // KeyBinding.resetKeyBindingArrayAndHash();\n }\n else\n {\n super.mouseClicked(par1, par2, par3);\n }\n }",
"protected void buttonUI (final Context context, final Map<Button,Integer> audios){\n final int offColor = R.color.cardview_dark_background;\n final int onColor = R.color.colorAccent;\n\n String retval = \"\";\n //Modify color of buttons in a column on click\n for (final Button btn : audios.keySet()) {\n// retval = \"\";\n btn.setOnClickListener(new View.OnClickListener() {\n\n @Override\n public void onClick(View v) {\n //Play audio and turn on color\n btn.setBackgroundColor(ContextCompat.getColor(context, onColor));\n MediaPlayer mp = MediaPlayer.create(btn.getContext(), audios.get(btn));\n mp.start();\n //Change color of other buttons to off\n for (Button other : audios.keySet()) {\n if (other != btn) {\n other.setBackgroundColor(ContextCompat.getColor(context, offColor));\n }\n }\n\n }\n });\n }\n }",
"protected void actionPerformed(GuiButton par1GuiButton)\n {\n if (par1GuiButton.id == 0)\n {\n this.mc.displayGuiScreen(new GuiOptions(this, this.mc.gameSettings));\n }\n\n if (par1GuiButton.id == 5)\n {\n this.mc.displayGuiScreen(new GuiLanguage(this, this.mc.gameSettings));\n }\n\n if (par1GuiButton.id == 1)\n {\n this.mc.displayGuiScreen(new GuiSelectWorld(this));\n }\n\n if (par1GuiButton.id == 2)\n {\n this.mc.displayGuiScreen(new GuiMultiplayer(this));\n }\n\n if (par1GuiButton.id == 3)\n {\n this.mc.displayGuiScreen(new GuiTexturePacks(this));\n }\n\n if (par1GuiButton.id == 4)\n {\n this.mc.shutdown();\n }\n }",
"public abstract void buttonPressed();",
"public void sButton() {\n\n\n\n }",
"@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\n\t\tJButton orange = (JButton) e.getSource();\n\n\t\tif (orange == buttonOne) {\n\n\t\t\tshowDucks();\n\n\t\t} else if (orange == buttonTwo) {\n\n\t\t\tshowFrog();\n\n\t\t} else if (orange == buttonThree) {\n\n\t\t\tshowFluffyUnicorns();\n\n\t\t}\n\n\t}",
"public void actionPerformed (ActionEvent e) {\n \t\t\tfor(int i=0; i<10; i++) {//add the buttons to the frame\n \t \tfor (int j=0; j<10; j++) {\n \t \t\ttile[i][j].addActionListener(new tileClicked());\n \t \t}\n \t }\n \t\t\tSystem.out.println(\"Move Mode Selected\");\n \t\t}",
"private void refreshButtons() {\n flowPane.getChildren().clear();\n\n for(String testName : Files.listTests()) {\n TestJson info;\n try {\n info = TestParser.read(testName);\n } catch(FileNotFoundException e) {\n continue; /* Skip */\n }\n\n JFXButton button = new JFXButton(testName);\n button.pseudoClassStateChanged(PseudoClass.getPseudoClass(\"select-button\"), true);\n\n button.setOnAction(e -> buttonPressed(info));\n\n if(!filter(info, button))\n continue;\n\n // If this model asked to be put in a specific place, put it there\n if(!info.custom && info.order >= 0)\n flowPane.getChildren().add(Math.min(info.order, flowPane.getChildren().size()), button);\n else\n flowPane.getChildren().add(button);\n }\n }",
"private static void buttonSetup() {\n \n // For all buttons except clear and equals=, update display\n for(JButton i:buttonOrder) {\n if(i.equals(clear) || i.equals(equals))\n continue;\n i.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent evt) {\n if(displayString.toString().equals(\"ERROR\")) {\n displayString.replace(0, displayString.length(), i.getText());\n numField.setText(displayString.toString());\n } else {\n displayString.append(i.getText());\n numField.setText(displayString.toString());\n }\n }\n });\n }\n \n // Clears display\n clear.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent evt) {\n displayString.delete(0, displayString.length());\n numField.setText(displayString.toString());\n }\n });\n \n // Clears display, shows result\n equals.addActionListener(new ActionListener() {\n public void actionPerformed(ActionEvent evt) {\n equationParse(displayString);\n }\n });\n }",
"public void answer1Clicked(View view) {\n\n answer1Clicked = true;\n\n answer2Clicked = false;\n answer3Clicked = false;\n answer4Clicked = false;\n\n changeButtonColor();\n }",
"private void setupButtons() {\n final ButtonGroup btngrp = new ButtonGroup();\n\n for (final AbstractAction actn : myToolActions) {\n final JToggleButton btn = new JToggleButton(actn);\n btn.addActionListener(actn);\n btngrp.add(btn);\n add(btn);\n }\n\n btngrp.clearSelection();\n btngrp.getElements().nextElement().setSelected(true);\n\n }",
"public void actionPerformed (ActionEvent e) {\n\t \t\t\tfor(int i=0; i<10; i++) {//add the buttons to the frame\n\t \t \tfor (int j=0; j<10; j++) {\n\t \t \t\ttile[i][j].addActionListener(new tileClicked());\n\t \t \t}\n\t \t }\n\t \t\t\tSystem.out.println(\"Move Mode Selected\");\n\t \t\t}",
"@Override\n public void onClick(View v) {\n Outerloop:\n for(int row = 0; row < TicTacToe.SIDE; row++) {\n for(int col = 0; col < TicTacToe.SIDE; col++){\n if (buttonGridView.isButtonThere(v, row, col)) {\n Update(row, col);\n break Outerloop;\n }\n }\n }\n\n }",
"public void buttonClickHandler (ActionEvent evt) {\n\t\tButton clickedButton = (Button) evt.getTarget();\n\t\tString buttonLabel = clickedButton.getText();\n\t\t\n\t\tswitch(buttonLabel) {\n\t\t\tcase(\"Instructions\"): openInstructionsWindow(); break;\n\t\t\tcase(\"About\"): openAboutWindow(); break;\n\t\t\tcase(\"Quit\"): GameScreenController.quitWindow(); break;\n\t\t}\t\n\t}",
"@Override\r\n public void onClick(View v) {\n switch (v.getId()) {\r\n case R.id.btn_u_one:\r\n startTest(ONE);\r\n break;\r\n case R.id.btn_u_two:\r\n startTest(TWO);\r\n break;\r\n }\r\n }",
"public void onClicked();",
"public void onButtonAPressed();",
"private void setClickListeners() {\n buttonSomethingWentWrong.setOnClickListener(this);\n buttonSuggestion.setOnClickListener(this);\n buttonHighlightRequest.setOnClickListener(this);\n closeButton.setOnClickListener(this);\n }",
"void enablButtonListener();",
"public void onClick(Widget sender) {\n if(sender.equals(this.deleteButton)) {\n\t\t\tthis.removeObject();\n\t\t} else if(sender.equals(this.backButton)) {\n\t\t\tthis.backObject();\n\t\t} else if(sender.equals(this.frontButton)) {\n\t\t\tthis.frontObject();\n\t\t} else if(sender.equals(this.saveButton)) {\n\t\t\tthis.saver.saveDocument(this.canvas);\n }else if(sender.equals(this.selectButton)) {\n this.action.setAction(Action.SELECT);\n\t\t} else if(sender.equals(this.pencilButton)) {\n this.unSelect();\n this.action.setAction(Action.PENCIL);\n\t\t} else if(sender.equals(this.lineButton)) {\n this.unSelect();\n this.action.setAction(Action.LINE);\n\t\t} else if(sender.equals(this.rectButton)) {\n this.unSelect();\n this.action.setAction(Action.RECTANGLE);\n\t\t} else if(sender.equals(this.circleButton)) {\n this.unSelect();\n this.action.setAction(Action.CIRCLE);\n\t\t} else if(sender.equals(this.ellipseButton)) {\n this.unSelect();\n this.action.setAction(Action.ELLIPSE);\n\t\t} else if(sender.equals(this.polylineButton)) {\n this.unSelect();\n this.action.setAction(Action.POLYLINE);\n } else if(sender.equals(this.textButton)) {\n this.unSelect();\n this.action.setAction(Action.TEXTBOX);\n } else if(sender.equals(this.strokeButton)) {\n this.showPopUpStroke();\n\t\t} else if(sender.equals(this.fill)) {\n this.showPopupColorFill(true);\n } else if(sender.equals(this.stroke)) {\n this.showPopupColorFill(false);\n }\n\t\t\n\t}",
"@Override\r\n\tpublic void actionPerformed(ActionEvent e) {\n\t\tif (e.getSource().getClass().equals(talkbot.Buttons.class)) {\r\n\t\t\t// int bn;\r\n\t\t\t/*if (on)\r\n\t\t\t\tbn=1;\r\n\t\t\telse\r\n\t\t\t\tbn=2; */\r\n\t\t\tButtons temp = (Buttons) e.getSource(); \r\n\t\t\t//bn = temp.getbtnNumber();\r\n\t\t\t\r\n\t\t\tString tempath = this.con.getPathToAudioFile(currentset+1, temp.getbtnNumber());\r\n\t\t\tplaySound(tempath);\r\n\t\t\tlogger.info(\"Set \" + currentset + \" - Button \" + temp.getbtnNumber());\r\n\t\t} else if (categories.contains((JButton) e.getSource())) {\r\n\t\t\tif (currentset != categories.indexOf((JButton) e.getSource())) {\r\n\t\t\tfor (int i = 0; i < tbuttons.get(currentset).size(); i++) {\r\n\t\t\t\tsp.remove(tbuttons.get(currentset).get(i));\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\tcurrentset= categories.indexOf((JButton) e.getSource());\r\n\t\t\t//System.out.println(currentset); \r\n\t\t\tif (!tbuttons.get(currentset).isEmpty()) {\r\n\t\t\tfor (int i = 0; i < tbuttons.get(currentset).size(); i++) {\r\n\t\t\t\tsp.add(tbuttons.get(currentset).get(i));\r\n\t\t\t\ttbuttons.get(currentset).get(i).addActionListener(this);\r\n\t\t\t\ttbuttons.get(currentset).get(i).setVisible(true);\r\n\t\t\t}}\r\n\t\t\tthis.revalidate(); this.repaint(); }\r\n\t\t\tlogger.info(\"Set - \" + currentset);\r\n\t\t} \r\n\t}",
"private void initButtons() {\n\t\taddGoalkeeper = new JButton(\"+\");\n\t\taddGoalkeeper.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(0, e);\n\t\t\t}\n\t\t});\n\t\t\n\t\taddDefence1 = new JButton(\"+\");\n\t\taddDefence1.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(1, e);\n\t\t\t}\n\t\t});\n\t\t\n\t\taddDefence2 = new JButton(\"+\");\n\t\taddDefence2.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(2, e);\n\t\t\t}\n\t\t});\n\t\t\t\t\n\t\taddDefence3 = new JButton(\"+\");\n\t\taddDefence3.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(3, e);\n\t\t\t}\n\t\t});\n\t\t\n\t\taddDefence4 = new JButton(\"+\");\n\t\taddDefence4.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(4, e);\n\t\t\t}\n\t\t});\n\t\t\n\t\taddMiddle1 = new JButton(\"+\");\n\t\taddMiddle1.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(5, e);\n\t\t\t}\n\t\t});\n\t\t\n\t\taddMiddle2 = new JButton(\"+\");\n\t\taddMiddle2.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(6, e);\n\t\t\t}\n\t\t});\n\t\t\n\t\taddMiddle3 = new JButton(\"+\");\n\t\taddMiddle3.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(7, e);\n\t\t\t}\n\t\t});\n\t\t\n\t\taddMiddle4 = new JButton(\"+\");\n\t\taddMiddle4.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(8, e);\n\t\t\t}\n\t\t});\n\t\t\n\t\taddForward1 = new JButton(\"+\");\n\t\taddForward1.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(9, e);\n\t\t\t}\n\t\t});\n\t\t\n\t\taddForward2 = new JButton(\"+\");\n\t\taddForward2.addActionListener(new ActionListener() {\n\t\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\tchangePlayer(10, e);\n\t\t\t}\n\t\t});\n\t}",
"private void pressedButton(int button) {\n if (button < CalculatorButtons.CALCULATE_BUTTONS && button > CalculatorButtons.NONE) {\n equation.sortButton(button, CalculatorButtons.BUTTON_PRESSED);\n }\n else if (button == CalculatorButtons.FRACTION_CHANGE_BUTTON) {\n buttonActions.sortButton(button, CalculatorButtons.BUTTON_PRESSED);\n }\n else if (button == 36) {\n buttonActions.sortButton(button, CalculatorButtons.BUTTON_PRESSED);\n equation.formatAnswer();\n }\n else if (button < CalculatorButtons.FRACTION_BUTTONS && button > CalculatorButtons.FRACTION_CHANGE_BUTTON) {\n fractionActions.sortButton(button, CalculatorButtons.BUTTON_PRESSED);\n }\n\n }",
"private void setButtonListener() {\n for(CellButton[] buttonsRow : mainFrame.getButtons()) {\n for(CellButton button :buttonsRow) {\n button.addButtonListener(this);\n }\n }\n }",
"@Override\n public void actionPerformed(ActionEvent e) {\n Object o = e.getSource();\n if (o == add) {\n btn_Add.doClick();\n }\n if (o == details) {\n btn_Details.doClick();\n }\n if (o == edit) {\n btn_Edit.doClick();\n }\n if (o == delete) {\n btn_Delete.doClick();\n }\n }",
"public void actionPerformed(ActionEvent e) {\r\n canvas.refresh();\r\n addNodeButton.setEnabled(true);\r\n rmvNodeButton.setEnabled(true);\r\n addEdgeButton.setEnabled(true);\r\n rmvEdgeButton.setEnabled(true);\r\n chgTextButton.setEnabled(true);\r\n chgDistButton.setEnabled(true);\r\n BFSButton.setEnabled(true);\r\n DFSButton.setEnabled(true);\r\n spButton.setEnabled(true);\r\n TPSButton.setEnabled(true);\r\n instr.setText(\"Try functions by clicking buttons.\");\r\n }",
"String handleButtonPress(Button button);",
"@Override\n public void onClick(View btn) {\n debug(\"onClick\");\n\n int caras = btn.getId();\n\n switch (caras) {\n case R.id.buttond2:\n case R.id.buttond3:\n case R.id.buttond4:\n case R.id.buttond6:\n case R.id.buttond8:\n case R.id.buttond10:\n case R.id.buttond12:\n case R.id.buttond20:\n case R.id.buttond24:\n case R.id.buttond100:\n int carasDado = getNumeroCaras(btn);\n debug(\"onClick\", \"\", carasDado);\n getDiceRollerPresenter().dicePressed(carasDado);\n break;\n\n case R.id.buttonListaTiradas:\n debug(\"onClick\");\n getDiceRollerPresenter().botonListaPressed();\n break;\n }\n }",
"public void submit_intsatpos(View button) {\n }",
"@FXML public void handleToggleButtons() {\n\t\t\n\t\t// binarySplitButton\n\t\tif (binarySplitButton.isSelected()) {\n\t\t\tbinarySplitButton.setText(\"True\");\n\t\t} else {\n\t\t\tbinarySplitButton.setText(\"False\");\n\t\t}\n\t\t\n\t\t// collapseTreeButton\n\t\tif (collapseTreeButton.isSelected()) {\n\t\t\tcollapseTreeButton.setText(\"True\");\n\t\t} else {\n\t\t\tcollapseTreeButton.setText(\"False\");\n\t\t}\n\t\t\n\t\t// debugButton\n\t\tif (debugButton.isSelected()) {\n\t\t\tdebugButton.setText(\"True\");\n\t\t} else {\n\t\t\tdebugButton.setText(\"False\");\n\t\t}\n\t\t\n\t\t// doNotCheckCapabilitiesButton\n\t\tif (doNotCheckCapabilitiesButton.isSelected()) {\n\t\t\tdoNotCheckCapabilitiesButton.setText(\"True\");\n\t\t} else {\n\t\t\tdoNotCheckCapabilitiesButton.setText(\"False\");\n\t\t}\n\t\t\n\t\t// doNotMakeSplitPAVButton\n\t\tif (doNotMakeSplitPAVButton.isSelected()) {\n\t\t\tdoNotMakeSplitPAVButton.setText(\"True\");\n\t\t} else {\n\t\t\tdoNotMakeSplitPAVButton.setText(\"False\");\n\t\t}\n\t\t\n\t\t// reduceErrorPruningButton\n\t\tif (reduceErrorPruningButton.isSelected()) {\n\t\t\treduceErrorPruningButton.setText(\"True\");\n\t\t} else {\n\t\t\treduceErrorPruningButton.setText(\"False\");\n\t\t}\n\t\t\n\t\t// saveInstanceDataButton\n\t\tif (saveInstanceDataButton.isSelected()) {\n\t\t\tsaveInstanceDataButton.setText(\"True\");\n\t\t} else {\n\t\t\tsaveInstanceDataButton.setText(\"False\");\n\t\t}\n\t\t\n\t\t// subTreeRaisingButton\n\t\tif (subTreeRaisingButton.isSelected()) {\n\t\t\tsubTreeRaisingButton.setText(\"True\");\n\t\t} else {\n\t\t\tsubTreeRaisingButton.setText(\"False\");\n\t\t}\n\t\t\n\t\t// unprunedButton\n\t\tif (unprunedButton.isSelected()) {\n\t\t\tunprunedButton.setText(\"True\");\n\t\t} else {\n\t\t\tunprunedButton.setText(\"False\");\n\t\t}\n\t\t\n\t\t// useLaplaceButton\n\t\tif (useLaplaceButton.isSelected()) {\n\t\t\tuseLaplaceButton.setText(\"True\");\n\t\t} else {\n\t\t\tuseLaplaceButton.setText(\"False\");\n\t\t}\n\t\t\n\t\t// useMDLcorrectionButton\n\t\tif (useMDLcorrectionButton.isSelected()) {\n\t\t\tuseMDLcorrectionButton.setText(\"True\");\n\t\t} else {\n\t\t\tuseMDLcorrectionButton.setText(\"False\");\n\t\t}\n\t\t\n\t}",
"@Override\n\tpublic void actionPerformed(ActionEvent anything) \n\t{\n\t\t\n\t\tif (anything.getSource() == getButton1())\n\t\t{\t\n\t\t\tqueryAllMenu();\n\t\t}\n\t\t\n\t\tif(anything.getSource() == getButton2())\n\t\t{\n\t\t\tquerySumMenu();\n\t\t}\n\t\tif(anything.getSource() == getButton3())\n\t\t{\n\t\t\tselectMenu();\n\t\t}\n\t\tif(anything.getSource() == getButton4())\n\t\t{\n\t\t\tqueryAllMenu();\n\t\t}\n\t\tif(anything.getSource() == getButton5())\n\t\t{\n\t\t\tqueryMaxMenu();\n\t\t}\n\t\tif(anything.getSource()==getButton6())\n\t\t{\n\t\t\tqueryMinMenu();\n\t\t}\n\t\t\n\t\t\n\t\t\n\t}",
"@Override\n\tpublic void onClick(View arg0) {\n \t\t\n \t\t\n \t\t\n \t\tswitch(arg0.getId())\n \t\t{\n \t\tcase R.id.button1 : result();\n \t\t\t\t\t\t\tbreak;\n \t\tcase R.id.button2 : clr1();\n \t\t\t\t\t\t\tbreak;\n \t\t}\t\t\n\t\t\n\t}",
"private void mymethods() {\n\t\tNew.addActionListener(new ActionListener()\r\n\t\t{\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic void actionPerformed(ActionEvent arg0) {\r\n\t\t\t\t// TODO Auto-generated method stub\r\n\t\t\t\tta1.setText(\" \");\r\n\t\t\t}\r\n\t\t\t\r\n\t\t});\r\n\t\t\r\n\t\t\r\n\t}",
"@Override\n public void actionPerformed(final ActionEvent e) {\n for (Map.Entry<FrameContainer<?>, JToggleButton> entry : buttons.entrySet()) {\n if (entry.getValue().equals(e.getSource())) {\n final TextFrame frame = (TextFrame) controller.getSwingWindow(\n entry.getKey());\n if (frame != null && frame.equals(activeWindow)) {\n entry.getValue().setSelected(true);\n }\n entry.getKey().activateFrame();\n }\n }\n }",
"@Override\n\tprotected void OnClick() {\n\t\t\n\t}",
"public void click(int mouseButton){\n\n if(mouseButton ==1){\n for (int i = 0; i <buttons.length ; i++) {\n //if click was registered on a button\n if(buttons[i].contains(Game.mousePoint)){\n int j = i +1;\n\n if(i == 0 && !(noOfCredits - Translator.pitifullPrice < 0)){\n noOfCredits -= Translator.pitifullPrice;\n army.addToArmyQueue(TrooperType.PITIFUL);\n\n }\n if(i == 1 && !(noOfCredits -\n Translator.armoredTrooperPrice < 0)){\n noOfCredits -= Translator.armoredTrooperPrice;\n army.addToArmyQueue(TrooperType.ARMORED);\n }\n if(i == 2 && !(noOfCredits -\n Translator.teleporterPrice < 0)){\n noOfCredits -= Translator.teleporterPrice;\n army.addToArmyQueue(TrooperType.TELEPORTER);\n }\n if(i==3){\n for (Trooper t:army.getArmy()) {\n if(t.getClass().equals(TeleportTrooper.class)){\n TeleportTrooper tp = (TeleportTrooper)t;\n if(tp.hasTeleport()) {\n Game.air[t.getPosition().getX()]\n [t.getPosition().getY()] =\n Translator.indexTeleportZone;\n tp.placePortal(tp.getDirection());\n Game.air[t.getPosition().getX()]\n [t.getPosition().getY()] =\n Translator.indexTeleporterZoneOut;\n }\n }\n }\n }\n if(i==4){\n if(army != null && army.getPreferred() == null\n || army.getPreferred() == Direction.RIGHT) {\n buttons[i].setIsSelected(true);\n buttons[i+1].setIsSelected(false);\n army.setPreferred(Direction.LEFT);\n }\n else if(army.getPreferred().equals(Direction.LEFT)){\n buttons[i].setIsSelected(false);\n army.setPreferred(null);\n }\n }\n if(i==5){\n if(army != null && army.getPreferred() == null\n || army.getPreferred() == Direction.LEFT) {\n army.setPreferred(Direction.RIGHT);\n buttons[i].setIsSelected(true);\n buttons[i-1].setIsSelected(false);\n }\n else if(army.getPreferred().equals(Direction.RIGHT)){\n army.setPreferred(null);\n buttons[i].setIsSelected(false);\n }\n }\n }\n }\n }\n }",
"private void setupButtons() {\n\t\tsetupCreateCourse();\n\t\tsetupRemoveCourse();\n\t\tsetupCreateOffering();\n\t\tsetupRemoveOffering();\n\t\tsetupAddPreReq();\n\t\tsetupRemovePreReq();\n\t\tsetupBack();\n\t}",
"public void clickedButton(View view) {\n\n switch (view.getId()) {\n case R.id.contactBook:\n intent = new Intent(this, ContactBookActivity.class);\n startActivity(intent);\n break;\n case R.id.message:\n intent = new Intent(this, SMS_Activity.class);\n startActivity(intent);\n break;\n case R.id.fav_contacts:\n intent = new Intent(this, ContactGridActivity.class);\n startActivity(intent);\n break;\n case R.id.lastCall:\n intent = new Intent(this, LatestCallsActivity.class);\n startActivity(intent);\n break;\n case R.id.microphone:\n SpeechRecognitionHelper.run(this);\n break;\n }\n }",
"@Override\n public void onClick(View view) {\n if(buttonHandler != null)\n {\n //we send out to our button handler\n buttonHandler.handleEvolve(wid);\n }\n Toast.makeText(getContext(), \"Evolve please!\", Toast.LENGTH_SHORT).show();\n\n }",
"protected void actionPerformed(GuiButton par1GuiButton)\n {\n for (int var2 = 0; var2 < this.options.keyBindings.length; ++var2)\n {\n ((GuiButton)this.controlList.get(var2)).displayString = this.options.getOptionDisplayString(var2);\n }\n\n if (par1GuiButton.id == 200)\n {\n this.mc.displayGuiScreen(this.parentScreen);\n }\n else\n {\n this.buttonId = par1GuiButton.id;\n par1GuiButton.displayString = \"> \" + this.options.getOptionDisplayString(par1GuiButton.id) + \" <\"; // what is this even for.. it gets overwritten in drawScreen\n }\n }",
"@Override\n public void run() {\n nextButtonAction(); // invoking next button //\n }",
"public abstract void executeRunButton();",
"private void addClick() {\n\t\tfindViewById(R.id.top_return).setOnClickListener(this);\n\t\tfm1_jhtx.setOnClickListener(this);\n\t\tfm1_sx.setOnClickListener(this);\n\t}",
"public void click_on(){\n float x = mouseX;\n float y = mouseY;\n //if(dela>0)dela--;\n if(overRect(x, y, 570, 50, btn_ext.width, btn_ext.height)){sfx(4);\n clicked(btn_ext.get(), 570, 50, btn_ext.width, btn_ext.height, INVERT);\n qq = -1;\n }else if(overRect(x, y, 190, 50, btn_tip.width, btn_tip.height)&&!level_pick){sfx(4);\n sm = k;\n sp = 5;\n qq = 6;\n qqTmp = 2;\n }else if(level_pick){\n if(overRect(x, y, 190, 50, btn_back.width, btn_back.height)){sfx(4);\n clicked(btn_back.get(), 190, 50, btn_back.width, btn_back.height, INVERT);\n level_pick = false;\n }else{\n for(int i=0;i<7;i++){\n float xx = 252.5f;\n float yy = 130;\n if(i>3){\n xx = -45;\n yy = 215;\n }\n if(User.getInt((char)('A'+k)+str(i+1))!=-1){\n if(overRect(x, y, xx+85*i, yy, level_on.width, level_on.height)){sfx(4);\n sl = i;\n _1.setLevel();\n _1.initGame();\n pp = 1;qq = -1;\n }\n }\n }\n }\n }else{\n if(overRect(x, y, 540, height/2, btn_next.width, btn_next.height)){sfx(4);\n clicked(btn_next.get(), 540, height/2, btn_next.width, btn_next.height, INVERT);\n k=(k+1)%3;\n }\n else if(overRect(x, y, 220, height/2, btn_prev.width, btn_prev.height)){sfx(4);\n clicked(btn_prev.get(), 220, height/2, btn_prev.width, btn_prev.height, INVERT);\n k--;\n if(k<0)k=2;\n }else if(overRect(x, y, width/2, height/2, latar[k].width, latar[k].height)){sfx(4);\n level_pick = true;\n sm = k;\n }\n }\n }",
"private void fixButtons() {\n\t\tfixModButtonListener();\n\t\tfixBuscarButtonListener();\n\t\tfixDeleteButtonListener();\n\t\tfixClearFieldsButtonListener();\n\t}",
"@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\tJButton buttonPressed = (JButton) e.getSource();\n\t\tif (buttonPressed == buttonOne) {\n\t\t\tSystem.out.println(\"button 1 pressed\");\n\t\t} else if (buttonPressed == buttonTwo) {\n\t\t\tSystem.out.println(\"button 2 pressed\");\n\t\t}\n\t}",
"@Override\n public void mouseClicked(MouseEvent e) {\n System.out.println(\"MouseClicked\");\n //kwadrat.clicked();\n trojkat.clicked();\n //kolo.clicked();\n //square.clicked();\n }",
"public void mousePressed(MouseEvent e) {\n mDown=true;\n int i=0;\n // Iterate through each button bounding box\n for(Rectangle r : buttonBounds) {\n // Check if the click point intersects with the rectangle's area\n if(r.contains(e.getPoint())) {\n // If it does, call the buttonCallback with the appropriate button display text\n buttonCallback(buttonNames.get(i));\n }\n i++;\n }\n }",
"@Override\n public void actionPerformed(ActionEvent e) {\n\n Object clicked = e.getSource();\n\n if (clicked == next_turn){\n NextTurn();\n }\n if (clicked == next_game){\n NextGame();\n }\n if (clicked == go_back){\n GoBack();\n }\n if (clicked == prev_game){\n PrevGame();\n }\n if (clicked == prev_turn){\n PrevTurn();\n }\n }",
"@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\tif(e.getSource()==btn_pause) {\n\t\t\n\t\t\tgamePause();\n\t\t}\n\t\tif(e.getSource()==btn_continue) {\n\t\t\tgameContinue();\n\t\t}\n\t\tif(e.getSource()==btn_restart) {\n\t\t\tgameResTart();\n\t\t}\n\t\tif(e.getSource()==btn_rank) {\n\t\t\tgameRank();\n\t\t}\n\t\tif(e.getSource()==btn_admin) {\n\t\t\tgameAdmin();\n\t\t}\n\t\t\n\t}",
"@Override\n public void onClick(View view) {\n switch(view.getId()) {\n case R.id.btn1:\n // Must break after each case, or all cases would be run.\n myToast(\"btn1\"); break;\n case R.id.btn2:\n myToast(\"btn2\"); break;\n case R.id.btn3:\n myToast(\"btn3\"); break;\n }\n }",
"public void buttonFunctions(){\n runSim.addActionListener((ActionEvent q) -> {\n simulation = new Secretary();\n setNewValues();\n simulation.runSim();\n showDetails.setEnabled(true);\n showResults(); \n });\n showDetails.addActionListener((ActionEvent e) -> {\n resultDisplay.setText(simulation.getResults());\n resultFrame.setVisible(true); \n });\n changeSimProp.addActionListener((ActionEvent ch) ->{\n changeFrame.setVisible(true);\n });\n okay.addActionListener((ActionEvent ok) ->{ \n changeFrame.setVisible(false);\n });\n programDescription.addActionListener((ActionEvent d)->{\n descriptionDisplay.setText(programD());\n dFrame.setVisible(true);\n });\n }",
"public void setOnClickListeners(){\n\n biegeAlien.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n\n normalizeImages();\n Constants.CHOSEN_CHARACTER = 0;\n biegeAlien.setImageResource(R.drawable.alienbeige_jump);\n biegeAlien.setBackgroundColor(getResources().getColor(R.color.colorMarker));\n }\n });\n\n blueAlien.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n\n normalizeImages();\n Constants.CHOSEN_CHARACTER = 1;\n blueAlien.setImageResource(R.drawable.alienblue_jump);\n blueAlien.setBackgroundColor(getResources().getColor(R.color.colorMarker));\n }\n });\n\n greenAlien.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n\n normalizeImages();\n Constants.CHOSEN_CHARACTER = 2;\n greenAlien.setImageResource(R.drawable.aliengreen_jump);\n greenAlien.setBackgroundColor(getResources().getColor(R.color.colorMarker));\n }\n });\n\n pinkAlien.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n\n normalizeImages();\n Constants.CHOSEN_CHARACTER = 3;\n pinkAlien.setImageResource(R.drawable.alienpink_jump);\n pinkAlien.setBackgroundColor(getResources().getColor(R.color.colorMarker));\n }\n });\n\n yellowAlien.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n\n normalizeImages();\n Constants.CHOSEN_CHARACTER = 4;\n yellowAlien.setImageResource(R.drawable.alienyellow_jump);\n yellowAlien.setBackgroundColor(getResources().getColor(R.color.colorMarker));\n }\n });\n }",
"public void settingBtnClick() {\n\t}",
"@Override\n\t\tpublic void onClick(Widget sender) {\n\t\t\t\n\t\t}",
"public abstract boolean onButtonClick(Player player, int button);",
"@Override\n public void onClick(View v) {\n count++;\n\n // So we will make\n switch (v.getId() /*to get clicked view id**/) {\n case R.id.button1:\n code += \"1\";\n\n System.out.println(\"I am a button1\");\n System.out.println(code);\n // do something when the button1 is clicked\n\n break;\n case R.id.button2:\n System.out.println(\"I am a button2\");\n code += \"2\";\n // do something when the button2 is clicked\n System.out.println(code);\n break;\n case R.id.button3:\n System.out.println(\"I am a button3\");\n // do something when the button3 is clicked\n code += \"3\";\n System.out.println(code);\n break;\n case R.id.button4:\n System.out.println(\"I am a button4\");\n // do something when the button3 is clicked\n code += \"4\";\n System.out.println(code);\n break;\n\n case R.id.button5:\n System.out.println(\"I am a button5\");\n // do something when the button3 is clicked\n code += \"5\";\n System.out.println(code);\n break;\n case R.id.button6:\n System.out.println(\"I am a button6\");\n // do something when the button3 is clicked\n code += \"6\";\n System.out.println(code);\n break;\n case R.id.button7:\n System.out.println(\"I am a button7\");\n // do something when the button3 is clicked\n code += \"7\";\n System.out.println(code);\n break;\n case R.id.button8:\n System.out.println(\"I am a button8\");\n // do something when the button3 is clicked\n code += \"8\";\n System.out.println(code);\n break;\n case R.id.button9:\n System.out.println(\"I am a button9\");\n // do something when the button3 is clicked\n code += \"9\";\n System.out.println(code);\n\n break;\n case R.id.button0:\n System.out.println(\"I am a button0\");\n // do something when the button3 is clicked\n code += \"0\";\n System.out.println(code);\n\n break;\n default:\n break;\n }\n\n\n }",
"@Override\n protected void actionPerformed(GuiButton button)\n {\n super.actionPerformed(button);\n }",
"public void actionPerformed (ActionEvent e) {\n \t\t\tfor(int i=0; i<10; i++) {//add the buttons to the frame\n \t \tfor (int j=0; j<10; j++) {\n \t \t\ttile[i][j].addActionListener(new attackGamePiece());\n \t \t}\n \t }\n \t\t\tSystem.out.println(\"Attack Mode Selected\");\n \t\t}",
"@Override\n public void onClick(View whichbtn) {\n\n switch (whichbtn.getId()) {\n case R.id.bt_ssspp:\n intent.setClass(ShowBranchAndBound.this, BranchAndBoundSSSPPActivity.class);\n startActivity(intent);\n break;\n case R.id.bt_loading_prob:\n intent.setClass(ShowBranchAndBound.this, BranchAndBoundLoadingProbActivity.class);\n startActivity(intent);\n break;\n case R.id.bt_0and1k_pro:\n intent.setClass(ShowBranchAndBound.this, BranchAndBound0And1KProbActivity.class);\n startActivity(intent);\n break;\n }\n }",
"@Override\n public void onClick() {\n System.out.println(\"Button has been JUST clicked\");\n }",
"private void pressed(int count, int button, JButton a) {\n if (winner) {\n return;\n }\n //when counter is even, X is placed in an empty spot\n if (count % 2 == 0) {\n tBoard[button] = 1; //all squares are set to two in the beginning, if a square has a 1 it is an X\n turn.setText(\"It is o's turn\"); //changes the turn to alert the person playing in the position of O that it is their turn\n a.setText(\"X\"); //sets button to show an X \n } else {\n tBoard[button] = 0; //all squares are set to two in the beginning, if a square has a 0 it is an 0\n turn.setText(\"It is x's turn\"); //changes the turn to alert the person playing in the position of X that it is their turn\n a.setText(\"O\"); //sets button to show an O\n }\n //disables the button that is pressed\n a.setEnabled(false);\n\n }",
"private void setUpClickListerns ()\n\t{\n\t\tLinearLayout temp_layout ;\n\t\tButton temp_button ;\n\t\tfor (int i = 0 ; i<numPad.getChildCount() ; i++)\n\t\t{\n\t\t\ttemp_layout = (LinearLayout) numPad.getChildAt(i);\n\t\t\tfor (int j = 0;j< temp_layout.getChildCount() ; j++)\n\t\t\t{\n\t\t\t\ttemp_button = (Button) temp_layout.getChildAt(j);\n\t\t\t\ttemp_button.setOnClickListener(this);\n\t\t\t}\n\t\t}\n\t\t\n\t\tchangePass.setOnClickListener(this);\n\t\tclear.setOnClickListener(this);\n\t\tpassField.setFocusable(false);\n\t}",
"@Override\r\n\tpublic void onClick(View v) {\n\t\tswitch (v.getId()) {\r\n\t\tcase R.id.btn_Fourgroup6_xuan_big:\r\n\t\t\tclearxuan();\r\n\r\n\t\t\tbtn_Fourgroup6_xuan_big.setTextColor(0xff000000);\r\n\t\t\tbtn_Fourgroup6_xuan_big.setBackgroundResource(R.drawable.change);\r\n\t\t\tvibrator.vibrate(new long[] { 0, 100 }, -1);\r\n\t\t\tgetnumber_Fourgroup6_xuan_big();\r\n\t\t\t// RelativeLayout_addbasket.setBackgroundResource(R.drawable.yellow_button);\r\n\t\t\t// imagebtn_addbasket.setVisibility(View.VISIBLE);\r\n\t\t\t// LinearLayout_nochoose.setVisibility(View.GONE);\r\n\t\t\tmMainActivity.getresultint(getresultint());\r\n\t\t\tmMainActivity.showresult(getresult());\r\n\t\t\tmMainActivity.getmoney();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_little:\r\n\t\t\tclearxuan();\r\n\t\t\tbtn_Fourgroup6_xuan_little.setTextColor(0xff000000);\r\n\t\t\tbtn_Fourgroup6_xuan_little.setBackgroundResource(R.drawable.change);\r\n\t\t\tvibrator.vibrate(new long[] { 0, 100 }, -1);\r\n\t\t\tgetnumber_Fourgroup6_xuan_little();\r\n\t\t\tmMainActivity.getresultint(getresultint());\r\n\t\t\tmMainActivity.showresult(getresult());\r\n\t\t\tmMainActivity.getmoney();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_all:\r\n\t\t\tclearxuan();\r\n\t\t\tbtn_Fourgroup6_xuan_all.setTextColor(0xff000000);\r\n\t\t\tbtn_Fourgroup6_xuan_all.setBackgroundResource(R.drawable.change);\r\n\t\t\tvibrator.vibrate(new long[] { 0, 100 }, -1);\r\n\t\t\tgetnumber_Fourgroup6_xuan_all();\r\n\t\t\tmMainActivity.getresultint(getresultint());\r\n\t\t\tmMainActivity.showresult(getresult());\r\n\t\t\tmMainActivity.getmoney();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_odd:\r\n\t\t\tclearxuan();\r\n\t\t\tbtn_Fourgroup6_xuan_odd.setTextColor(0xff000000);\r\n\t\t\tbtn_Fourgroup6_xuan_odd.setBackgroundResource(R.drawable.change);\r\n\t\t\tvibrator.vibrate(new long[] { 0, 100 }, -1);\r\n\t\t\tgetnumber_Fourgroup6_xuan_odd();\r\n\t\t\tmMainActivity.getresultint(getresultint());\r\n\t\t\tmMainActivity.showresult(getresult());\r\n\t\t\tmMainActivity.getmoney();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_even:\r\n\t\t\tclearxuan();\r\n\t\t\tbtn_Fourgroup6_xuan_even.setTextColor(0xff000000);\r\n\t\t\tbtn_Fourgroup6_xuan_even.setBackgroundResource(R.drawable.change);\r\n\t\t\tvibrator.vibrate(new long[] { 0, 100 }, -1);\r\n\t\t\tgetnumber_Fourgroup6_xuan_even();\r\n\t\t\tmMainActivity.getresultint(getresultint());\r\n\t\t\tmMainActivity.showresult(getresult());\r\n\t\t\tmMainActivity.getmoney();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_clear:\r\n\t\t\tclearxuan();\r\n\t\t\tbtn_Fourgroup6_xuan_clear.setTextColor(0xff000000);\r\n\t\t\tbtn_Fourgroup6_xuan_clear.setBackgroundResource(R.drawable.change);\r\n\t\t\tvibrator.vibrate(new long[] { 0, 100 }, -1);\r\n\t\t\tgetnumber_Fourgroup6_xuan_clear();\r\n\t\t\tmMainActivity.getresultint(getresultint());\r\n\t\t\tmMainActivity.showresult(getresult());\r\n\t\t\tmMainActivity.getmoney();\r\n\t\t\tbreak;\r\n\r\n\t\tcase R.id.btn_Fourgroup6_xuan_0:\r\n\t\t\tselectxuan0();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_1:\r\n\t\t\tselectxuan1();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_2:\r\n\t\t\tselectxuan2();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_3:\r\n\t\t\tselectxuan3();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_4:\r\n\t\t\tselectxuan4();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_5:\r\n\t\t\tselectxuan5();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_6:\r\n\t\t\tselectxuan6();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_7:\r\n\t\t\tselectxuan7();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_8:\r\n\t\t\tselectxuan8();\r\n\t\t\tbreak;\r\n\t\tcase R.id.btn_Fourgroup6_xuan_9:\r\n\t\t\tselectxuan9();\r\n\t\t\tbreak;\r\n\r\n\t\tdefault:\r\n\t\t\tbreak;\r\n\t\t}\r\n\t}",
"@Override\n\t\t\tpublic void onClick(View v) {\n\t\t\t\tclickMulti();\n\t\t\t}",
"public static void scheduleButtonListener(ActionEvent evt){\r\n MyButton button = (MyButton) evt.getSource();\r\n button.switchChosen();\r\n if(button.isChosen()){\r\n checkCollisions(button);\r\n }\r\n setButtonsColor();\r\n }",
"@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\tButton button = (Button)e.getSource();\n\t\t\n\t\t/* Filter / Periksa komponen sesuai button event-nya masing2 */\n\t\tif(b == button)\n\t\t\tSystem.out.println(\"Button b\");\n\t\t\n\t\tif(c == button)\n\t\t\tSystem.out.println(\"Button c\");\n\n\t}",
"public void actionPerformed (ActionEvent e) {\n\t \t\t\tfor(int i=0; i<10; i++) {//add the buttons to the frame\n\t \t \tfor (int j=0; j<10; j++) {\n\t \t \t\ttile[i][j].addActionListener(new attackGamePiece());\n\t \t \t}\n\t \t }\n\t \t\t\tSystem.out.println(\"Attack Mode Selected\");\n\t \t\t}",
"@Override\n\t\t\tpublic void mouseClicked(MouseEvent e) {\n\t\t\t\tif(e.getButton()==MouseEvent.BUTTON1)\n\t\t\t\t{\n\t\t\t\t\tif(Conf.isbegin==1)\n\t\t\t\t\t{\n\t\t\t\t\t\tConf.isbegin=0;\n\t\t\t\t\t}\n\t\t\t\t\telse\n\t\t\t\t\t{\n\t\t\t\t\t\tConf.isbegin=1;\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tif(e.getButton()==MouseEvent.BUTTON3)\n\t\t\t\t{\n\t\t\t\t\tif(Conf.isreplay==1)\t\n\t\t\t\t\t{\n\t\t\t\t\t\tConf.isreplay=0;\n\t\t\t\t\t}\n\t\t\t\t\telse\n\t\t\t\t\t{\n\t\t\t\t\t\tConf.isreplay=1;\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\t \n\t\t\t\t\n\t\t\t}"
]
| [
"0.75972474",
"0.73150265",
"0.7153793",
"0.7116389",
"0.71072376",
"0.7065604",
"0.70354354",
"0.69617283",
"0.6958122",
"0.6910598",
"0.6856371",
"0.68290883",
"0.67874485",
"0.67793906",
"0.6713116",
"0.67100376",
"0.6695038",
"0.6687705",
"0.6661109",
"0.6655501",
"0.6651031",
"0.6625873",
"0.6623587",
"0.65901417",
"0.6576119",
"0.6573144",
"0.65520775",
"0.6551403",
"0.65424544",
"0.65423506",
"0.65419513",
"0.65245974",
"0.65157855",
"0.65100837",
"0.649997",
"0.649951",
"0.6494621",
"0.6494227",
"0.6490723",
"0.6489521",
"0.64680815",
"0.6464826",
"0.6454471",
"0.6451156",
"0.6445204",
"0.64427537",
"0.6439749",
"0.6436233",
"0.643574",
"0.6430967",
"0.64277697",
"0.64228284",
"0.64179486",
"0.6415316",
"0.64108086",
"0.6410341",
"0.6405528",
"0.6402013",
"0.63984245",
"0.6390385",
"0.63773966",
"0.6377131",
"0.6371143",
"0.6367792",
"0.6365871",
"0.6361146",
"0.6360575",
"0.6351842",
"0.63516647",
"0.6351194",
"0.63452315",
"0.63352275",
"0.633338",
"0.6330374",
"0.6329335",
"0.6327861",
"0.6324858",
"0.63222456",
"0.63170356",
"0.63167286",
"0.63120574",
"0.6308738",
"0.6295938",
"0.6294126",
"0.62906176",
"0.62903404",
"0.6290121",
"0.62900823",
"0.62869644",
"0.62707746",
"0.6263436",
"0.6263364",
"0.626107",
"0.62571526",
"0.6249329",
"0.62438834",
"0.62375444",
"0.62303877",
"0.62267745",
"0.62242573",
"0.6223352"
]
| 0.0 | -1 |
set connection socket on construction | public serverResponse(Socket connetionSocket) throws FileNotFoundException {
this.connectionSocket = connetionSocket;
} | {
"objective": {
"self": [],
"paired": [],
"triplet": [
[
"query",
"document",
"negatives"
]
]
}
} | [
"public void setSocket(SocketWrapper socket);",
"protected final void setSocket(Socket socket) {\n this.socket = socket;\n }",
"public void setSocket(ServerSocket socket) {\n\t\tthis.socket = socket;\n\t}",
"public GridPeer setSocket(Socket socket) throws Exception\n {\n connected = true;\n connectionSocket = socket;\n address = connectionSocket.getInetAddress();\n localPeerID = ++localPeerIDCount;\n reader = new BufferedReader(new InputStreamReader(connectionSocket.getInputStream()));\n writer = new PrintWriter(connectionSocket.getOutputStream(),true);\n initListener();\n return this;\n }",
"public void initialize() throws SocketException{\n defPortUsed = true;\n initializeReal(defPortNumber, defPacketSize);\n }",
"public ServerConnection()\n {\n //Initializing of the variables used in the constructor\n this.hostAddress = \"http://localhost\";\n this.port = 8882;\n }",
"public ClientHandler(Socket s){\r\n mySocket = s;\r\n }",
"private void initSocket(String host, String port) throws IOException {\n\t\t// check the validity of the host name\n\t\tif (host == null || host.isEmpty()) throw new IllegalArgumentException(\"host == null || host.isEmpty()\");\n\t\t// check the validity of the port number\n\t\tint p = 0;\n\t\ttry {\n\t\t\tp = Integer.parseInt(port);\n\t\t} catch (NumberFormatException e) {\n\t\t\tthrow new IllegalArgumentException(\"Illegal port argument\");\n\t\t}\n\t\tif (p <= 0) {\n\t\t\tthrow new IllegalArgumentException(\"Illegal port argument\");\n\t\t}\n\t\t// establish the network connection\n\t\ttry {\n\t\t\tthis.socket = new Socket(host, p);\n\t\t} catch (IOException e) {\n\t\t\tgetErrorManager().error(\"Failed to establish the network connection\", e,\n\t\t\t\tErrorManager.OPEN_FAILURE);\n\t\t\tthrow e;\n\t\t}\n\t\tsuper.internalSetOutputStream(new BufferedOutputStream(this.socket.getOutputStream()));\n\t}",
"private void establishConnection() throws UnknownHostException, \n \t\t\t\t\t\t\t\t\t\t IOException {\n \t socket = new Socket(serverIP, serverPort);\n }",
"public ServerThread(Socket socket) {\r\n\t\tsoc = socket;\r\n\t}",
"private void initServerSock(int port) throws IOException {\n\tserver = new ServerSocket(port);\n\tserver.setReuseAddress(true);\n }",
"private void initConnection(Socket cli) {\t\n\tConnection conn = new Connection(this, cli);\n conn.setConnlist(connlist);\n\tThread t = new Thread(conn);\n\tt.start();\n\t\n\tconnlist.add(conn);\n\t\t\n\tsetConnectedStatus(true);\n }",
"private TcpClient()\n {\n socket = null;\n writer = null;\n connected = false;\n \n connect(\"localhost\", 7778);\n }",
"AuthServerConnectionHandler(Socket socket){\n\t\tthis.socket=socket;\n\n\t}",
"public Servidor(Socket s) {\r\n\t\tconexao = s;\r\n\t}",
"private void initBinding() throws IOException {\n serverSocketChannel.bind(new InetSocketAddress(0));\n serverSocketChannel.configureBlocking(false);\n serverSocketChannel.register(selector, SelectionKey.OP_ACCEPT);\n\n sc.configureBlocking(false);\n var key = sc.register(selector, SelectionKey.OP_CONNECT);\n uniqueContext = new ClientContext(key, this);\n key.attach(uniqueContext);\n sc.connect(serverAddress);\n }",
"public InitialValuesConnectionCenter() \n\t{\n\t\ttry {\n\t\t\tserverSocket = new ServerSocket(PORT);\n\t\t} catch (IOException e) {\n\t\t\tSystem.err.println(\"IOException ServerConnectionCenter.\");\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public SocketParams() {\n init();\n }",
"public MapiSocket() {\n\t\tcon = null;\n\t}",
"public void connect() {\n\t\ttry {\n\t\t\tsocket = new Socket(host, port);\n\t\t} catch (IOException e) {\n\t\t\tSystem.err.println(\"Error connecting: \" + e.getMessage());\n\t\t}\n\t}",
"public SocketChannelTarantoolConnection() {\n\t\tthis(\"localhost\", 33013);\n\t}",
"public void initiateConnection() {\n\t\tif (Settings.getRemoteHostname() != null) {\n\t\t\ttry {\n\t\t\t\toutgoingConnection(new Socket(Settings.getRemoteHostname(), Settings.getRemotePort()));\n\t\t\t} catch (IOException e) {\n\t\t\t\tlog.error(\"failed to make connection to \" + Settings.getRemoteHostname() + \":\"\n\t\t\t\t\t\t+ Settings.getRemotePort() + \" :\" + e);\n\t\t\t\tSystem.exit(-1);\n\t\t\t}\n\t\t}\n\t}",
"public void setConnection(String sConnection) throws IOException;",
"private void init() throws IOException {\n m_sock = new Socket(InetAddress.getByAddress(m_address), VIDEO_TO_PC_PORT);\n m_sock.setSoTimeout(READ_TIMEOUT_MS);\n m_sockistream = m_sock.getInputStream();\n m_daistream = new DataInputStream(m_sockistream);\n m_initialized = true;\n }",
"private void initServerSocket()\n\t{\n\t\tboundPort = new InetSocketAddress(port);\n\t\ttry\n\t\t{\n\t\t\tserverSocket = new ServerSocket(port);\n\n\t\t\tif (serverSocket.isBound())\n\t\t\t{\n\t\t\t\tSystem.out.println(\"Server bound to data port \" + serverSocket.getLocalPort() + \" and is ready...\");\n\t\t\t}\n\t\t}\n\t\tcatch (Exception e)\n\t\t{\n\t\t\tSystem.out.println(\"Unable to initiate socket.\");\n\t\t}\n\n\t}",
"public void setConnection(Connection conn);",
"public ClientThread(Socket socket){\n this.socket = socket;\n }",
"public void connect() {\n try {\n socket = connectToBackEnd();\n } catch (IOException ioe) {\n ioe.printStackTrace();\n }\n }",
"public void setSocket(String socket) {\n this.socket = socket == null ? null : socket.trim();\n }",
"public void setConn(Connection conn) {this.conn = conn;}",
"@Override\r\n\tpublic void start(Socket socket){}",
"public Connection(Socket client_socket) {\r\n client = client_socket;\r\n try {\r\n in = new DataInputStream(client.getInputStream());\r\n out = new PrintStream(client.getOutputStream());\r\n }\r\n catch (IOException e) {\r\n try { client.close(); } catch (IOException e2) { ; }\r\n System.err.println(\"Exception while getting socket streams: \" + e);\r\n return;\r\n }\r\n this.start();\r\n }",
"private void start_Connexion()throws UnknownHostException, IOException{\n \tsocket = new Socket(IP,num_Socket);\n \tout = new ObjectOutputStream(socket.getOutputStream());\n \tin = new ObjectInputStream(socket.getInputStream());\n \t\n }",
"public void init(){\n taskClient.connect(\"127.0.0.1\", 9123);\n }",
"public ConnectionHandler(Socket controlSocket, Socket dataSocket) {\n\t\tnetwork = new NetworkHandler(controlSocket, dataSocket);\n\t}",
"protected abstract ConnectionBase createNewConnection(Socket socket);",
"public TestCaseSocket() {\n\t}",
"public ConnectionManager() {\r\n\t\tthis(DEFAULT_PORT, true, true);\r\n\t}",
"ClientHandler(Socket socket) {\n this.client = socket;\n }",
"public void init() throws IOException {\r\n try {\r\n serverSocket = new ServerSocket(PORT);\r\n this.running = true;\r\n } catch (IOException e) {\r\n System.out.println(e);\r\n }\r\n }",
"public ServidorSocket() throws IOException {\n\t\tservidor = new ServerSocket(PUERTO);\n\t\tcliente = new Socket();\n\t}",
"protected void startConnect() {\n if (tcp) {\n connection = new TCPConnection(this);\n } else {\n connection = new UDPConnection(this, udpSize);\n }\n connection.connect(remoteAddr, localAddr);\n }",
"public SocketWrapper(final Socket socket) throws IOException {\n this.host = socket.getInetAddress().getHostName();\n this.port = socket.getPort();\n this.socket = socket;\n initStreams();\n opened = true;\n }",
"public MockSocket () {\n state = UNBOUND;\n }",
"public ControlCenter(){\n serverConnect = new Sockets();\n serverConnect.startClient(\"127.0.0.1\", 5000);\n port = 5000;\n }",
"public void connect() throws IOException {\n socket = new java.net.Socket(IP_SERVER, PORT);\n Logger.getLogger(\"SocketClient\").log(Level.INFO, \"Socket establecido\");\n }",
"private void connect() {\n\t\ttry {\n\t\t\tsocket = new Socket(Server.ADDRESS, Server.PORT_NUMBER);\n\t\t\tthis.oos = new ObjectOutputStream(socket.getOutputStream());\n\t\t\tthis.ois = new ObjectInputStream(socket.getInputStream());\n\t\t\tServerListener serverlistener = new ServerListener();\n\t\t\tserverlistener.start();\n\t\t\tRequest request = new Request(RequestCode.START_DOCUMENT_STREAM);\n\t\t\trequest.setUsername(user.getUsername());\n\t\t\toos.writeObject(request);\n\t\t} catch (IOException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public void setSocketChannel(SocketChannel socketChannel);",
"public ClientHandle(Socket cs) {\r\n \t\r\n this.threadSocket = cs;\r\n\r\n }",
"public void socketConnect(String ip, int port) throws UnknownHostException, \n IOException{\n System.out.println(\"[Connecting to socket...]\"); \n SSocket.socket= new Socket(ip, port); \n \n System.out.println(\"CORRIENDO EN EL PUERTO:\"+SSocket.socket.getLocalAddress()+\":\"+SSocket.socket.getPort());\n }",
"public TCPCanSocket() throws IOException\n \t{\n \t\t// this(new ServerSocket(DEFAULT_PORT).accept());\n \t\tthis(new ServerSocket(DEFAULT_PORT, 100).accept());\n \t\tSystem.out.println( \"constructor: open server socket\" );\n \t}",
"public synchronized boolean set_connection_socket(String add, int port) {\n //handle socket in UI thread\n StrictMode.ThreadPolicy policy = new StrictMode.ThreadPolicy.Builder().permitAll().build();\n StrictMode.setThreadPolicy(policy);\n\n socketaddress = add;\n socketport = port;\n try {\n socket = new Socket(add,port);\n } catch (IOException e) {\n e.printStackTrace();\n return false;\n }\n return true;\n }",
"public SocketConnection(String description, Socket socket) throws IOException {\n\t\tif (DEBUG) System.err.println(\"##### \" + getClass().getName() + \" - instantiated \" + description + \" \" + socket);\n\n\t\t_description = description\n\t\t\t+ \",localHost=\" + socket.getLocalAddress().getHostName()\n\t\t\t+ \",localPort=\" + socket.getLocalPort()\n\t\t\t+ \",peerHost=\" + socket.getInetAddress().getHostName()\n\t\t\t+ \",peerPort=\" + socket.getPort();\n\n\t\t_socket = socket;\n\t\t_inputStream = new BufferedInputStream(socket.getInputStream());\n\t\t_outputStream = new BufferedOutputStream(socket.getOutputStream());\n\n\t\t_listeners = new Vector();\n\t\t_firstRead = true;\n\t}",
"private ServerSocket setUpServer(){\n ServerSocket serverSocket = null;\n try{\n serverSocket = new ServerSocket(SERVER_PORT);\n\n }\n catch (IOException ioe){\n throw new RuntimeException(ioe.getMessage());\n }\n return serverSocket;\n }",
"public NetworkSource(Socket socket) {\n try {\n comUtils = new ComUtils(socket);\n\n // TODO @alex disable timeout\n comUtils.setTimeout(0);\n\n } catch (Exception ex) {\n System.err.println(\"NETWORK SORUCE: Could not Open Socket\");\n ex.printStackTrace();\n }\n }",
"public ServerConnecter() {\r\n\r\n\t}",
"public ClientWorker(Socket connectionSocket){\r\n\t\tthis.connectionSocketConected = connectionSocket;\r\n\t}",
"private void setUpConnection(final String IP_ADDR, final int portNumber) {\n\n Runnable runnable = new Runnable() {\n @Override\n public void run() {\n try {\n\n // Not thread safe (Destroy could be calling close at the same time)\n socket.connect((new InetSocketAddress(\n InetAddress.getByName(IP_ADDR), portNumber)));\n Log.d(TAG, \"Connection Successfull\");\n\n } catch (UnknownHostException e) {\n Log.e(TAG, \"Connection Failed\");\n e.printStackTrace();\n } catch (IOException e) {\n Log.e(TAG, \"Connection Failed\");\n e.printStackTrace();\n }\n }\n };\n\n connectionThread = new Thread(runnable);\n connectionThread.start();\n\t}",
"public ClientTSap() {\n socketFactory = SocketFactory.getDefault();\n }",
"public RRCPConnectionHandler(Socket s) {\n this.s = s;\n try {\n dis = new DataInputStream(new BufferedInputStream(s.getInputStream()));\n dos = new DataOutputStream(new BufferedOutputStream(this.s.getOutputStream()));\n } catch (IOException ex) {\n System.err.println(\"Error making data streams on ConnectionHandler: \\\"\" + ex.getMessage() + \"\\\"\");\n }\n }",
"public Handler(Socket socket) {\n this.socket = socket;\n }",
"public Handler(Socket socket) {\n this.socket = socket;\n }",
"public void openServer() {\n try {\n this.serverSocket = new ServerSocket(this.portNumber);\n } catch (IOException ex) {\n System.out.println(ex);\n }\n }",
"public NewConnectionWorkerThread(LocalService srv, Socket sock) {\n mSocket = sock;\n mIsPassive = true;\n mService = srv;\n }",
"public Client(Socket socket) {\n\t\t\tthis.socket = socket;\n\t\t}",
"public TCPSocketManager(String name, OutputStream os, Socket sock, InetAddress addr, String host, int port, int delay, boolean immediateFail, Layout<? extends Serializable> layout) {\n/* 77 */ super(name, os, addr, host, port, layout);\n/* 78 */ this.reconnectionDelay = delay;\n/* 79 */ this.socket = sock;\n/* 80 */ this.immediateFail = immediateFail;\n/* 81 */ this.retry = (delay > 0);\n/* 82 */ if (sock == null) {\n/* 83 */ this.connector = new Reconnector(this);\n/* 84 */ this.connector.setDaemon(true);\n/* 85 */ this.connector.setPriority(1);\n/* 86 */ this.connector.start();\n/* */ } \n/* */ }",
"public RequestThread(Socket soc){\r\n this.soc = soc; \r\n }",
"public SocketServer() {\n \n super();\n start();\n\n }",
"protected void spawnConnectionThread(Socket socket) {\n\ttry {\n\t CAMPServerConnectionThread sct = new CAMPServerConnectionThread(socket);\n\t sct.start();\n\t} catch (IOException iox) {\n\t System.err.println(\"Error creating sct: \"+iox);\n\t}\n }",
"public HandleAClient(Socket s) {\n\t\t\tmySocket = s;\n\t\t}",
"public void InitSocket(String server, int port) throws IOException {\n socket = new Socket(server, port);\n outputStream = socket.getOutputStream();\n\n Thread receivingThread = new Thread() {\n @Override\n public void run() {\n try {\n \n BufferedReader reader = new BufferedReader(\n new InputStreamReader(socket.getInputStream()));\n String line;\n while ((line = reader.readLine()) != null)\n notifyObservers(line);\n } catch (IOException ex) {\n notifyObservers(ex);\n }\n }\n };\n receivingThread.start();\n }",
"public void initializeBuffers(){\r\n\t\ttry {\r\n\t\t\tif(_socket == null) {\r\n\t\t\t\t_connectedSocket = false;\r\n\t\t\t\tthrow(new IOException(\"Cannot initialize connections before socket has been initialized.\"));\r\n\t\t\t}\r\n\t\t\t// Obter printer e reader para o socket\r\n\t\t\t_out = new PrintWriter(_socket.getOutputStream(), true);\r\n\t\t\t_in = new BufferedReader(new InputStreamReader(_socket.getInputStream()));\r\n\t\t\t_outputStream = _socket.getOutputStream();\r\n\t\t\t_connected = true;\r\n\t\t} catch (IOException e) {\r\n\t\t\tSystem.err.println(\"Nao se conseguiram inicializar os buffers para ler da conexao: \" + e.toString());\r\n\t\t\t_connected = false;\r\n\t\t\t//System.exit(1);\r\n\t\t}\r\n\t\r\n\r\n\t}",
"public DefaultTCPServer(int port) throws Exception {\r\n\t\tserverSocket = new ServerSocket(port);\t}",
"public abstract void createConnection(Socket socket, String userName);",
"@Override\n public void start() throws IOException\n {\n try\n {\n InetSocketAddress address = new InetSocketAddress(config.getHost(), config.getPort());\n sock = new Socket();\n sock.setSoTimeout(config.getReadTimeout());\n sock.connect(address, config.getReadTimeout());\n out = new ObjectOutputStream(new BufferedOutputStream(sock.getOutputStream()));\n out.flush();\n in = new ObjectInputStream(new BufferedInputStream(sock.getInputStream()));\n }\n catch (ConnectException ce)\n {\n log.info(\"Unable to connect to TCP socket on interface \" + config.getHost() + \" and port \" + config.getPort());\n throw ce;\n }\n }",
"public PeerConnect(Socket socket)throws IOException{\n\t\tthis.clientSocket = socket;\n\t}",
"public SocketIO(Socket nsocket)\n\t{\n\t\tsocket = nsocket;\n\t\ttry\n\t\t{\n\t\t\tinput = new DataInputStream(socket.getInputStream());\n\t\t\tout = new DataOutputStream(socket.getOutputStream());\n\t\t}\n\t\tcatch(UnknownHostException u)\n\t\t{\n\t\t\treturn;\n\t\t}\n\t\tcatch(IOException i)\n\t\t{\n\t\t\treturn;\n\t\t}\n\t}",
"@Override\r\n \tpublic void initialize() {\n \t\tThreadRenamingRunnable.setThreadNameDeterminer(ThreadNameDeterminer.CURRENT);\r\n \r\n \t\tInetSocketAddress address;\r\n \r\n \t\tif (m_host == null) {\r\n \t\t\taddress = new InetSocketAddress(m_port);\r\n \t\t} else {\r\n \t\t\taddress = new InetSocketAddress(m_host, m_port);\r\n \t\t}\r\n \r\n \t\tm_queue = new LinkedBlockingQueue<ChannelBuffer>(m_queueSize);\r\n \r\n \t\tExecutorService bossExecutor = Threads.forPool().getCachedThreadPool(\"Cat-TcpSocketReceiver-Boss-\" + address);\r\n \t\tExecutorService workerExecutor = Threads.forPool().getCachedThreadPool(\"Cat-TcpSocketReceiver-Worker\");\r\n \t\tChannelFactory factory = new NioServerSocketChannelFactory(bossExecutor, workerExecutor);\r\n \t\tServerBootstrap bootstrap = new ServerBootstrap(factory);\r\n \r\n \t\tbootstrap.setPipelineFactory(new ChannelPipelineFactory() {\r\n \t\t\tpublic ChannelPipeline getPipeline() {\r\n \t\t\t\treturn Channels.pipeline(new MyDecoder(), new MyHandler());\r\n \t\t\t}\r\n \t\t});\r\n \r\n \t\tbootstrap.setOption(\"child.tcpNoDelay\", true);\r\n \t\tbootstrap.setOption(\"child.keepAlive\", true);\r\n \t\tbootstrap.bind(address);\r\n \r\n \t\tm_logger.info(\"CAT server started at \" + address);\r\n \t\tm_factory = factory;\r\n \t}",
"public Client(Data data, Socket socket){\n try {\n connector = new Connector(socket, data);\n connector.start();\n } catch (Exception e) {\n e.printStackTrace();\n }\n }",
"public HandleAClient(Socket socket) {\n this.socket = socket;\n }",
"public TCPServer() throws SocketException\n\t{\n\t\tsuper();\n\t\tsetCheck(null);\n\t}",
"public static void initCommunicationServerThread(ProjectType project){\r\n try{\r\n serverSocket = new ServerSocket(Attributes.PROFILING_PORT, 2, InetAddress.getLocalHost());\r\n System.out.println(\"Server - ServerSocket created on port: \" + serverSocket.getLocalPort());\r\n }catch (UnknownHostException uhe){\r\n uhe.printStackTrace();\r\n //TODO - log this stuff properly\r\n }catch (IOException ioe){\r\n ioe.printStackTrace();\r\n //TODO - log this stuff properly\r\n }\r\n new CommunicationServerThread(project);\r\n }",
"public void establishSocketConnection() {\n\t\ttry {\n\t\t\tsocket = new Socket(serverIP, serverPort);\n\t\t\tlogger.info(\"Connection with JSON-RPC server opened at local endpoint \" + socket.getLocalAddress().getHostAddress() + \":\" + socket.getLocalPort());\n\t\t\t// create a writer to send JSON-RPC requests to the JSON-RPC server\n\t\t\twriter = new OutputStreamWriter(socket.getOutputStream(), \"utf-8\");\n\t\t\t// create a JsonReader object to receive JSON-RPC response\n\t\t\tjsonReader = new JsonReader(new InputStreamReader(socket.getInputStream(), \"utf-8\"));\n\t\t} catch (UnknownHostException e) {\n\t\t\n\t\t\te.printStackTrace();\n\t\t} catch (IOException e) {\n\t\t\t\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public Server() throws IOException\n {\n socket = new ServerSocket(port);\n }",
"SocketNode(NodeInterface node, Socket socketIn) {\n this.connectionIn = true;\n try {\n this.socketInput = new ObjectInputStream(socketIn.getInputStream());\n this.socketOutput = new ObjectOutputStream(socketIn.getOutputStream());\n } catch (IOException e) {\n this.close();\n }\n this.connected = true;\n Executors.newCachedThreadPool().execute(() ->\n node.getSocketManager().createConnection(this, socketIn.getInetAddress().getHostAddress()));\n }",
"public void InitSocket(String server, int port) throws IOException {\r\n socket = new Socket(server, port);\r\n outputStream = socket.getOutputStream();\r\n\r\n Thread receivingThread = new Thread() {\r\n @Override\r\n public void run() {\r\n try {\r\n BufferedReader reader = new BufferedReader(\r\n new InputStreamReader(socket.getInputStream()));\r\n String line;\r\n while ((line = reader.readLine()) != null) {\r\n notifyObservers(line);\r\n }\r\n } catch (IOException ex) {\r\n notifyObservers(ex);\r\n }\r\n }\r\n };\r\n receivingThread.start();\r\n }",
"private static Socket getSocket() \n{\n return socket; \n }",
"public ClientConnectionHandler(Socket socket, int number) {\r\n clientSocket = socket;\r\n clientNumber = number;\r\n isOpen = true;\r\n\r\n try {\r\n in = new DataInputStream(socket.getInputStream());\r\n out = new DataOutputStream(socket.getOutputStream());\r\n } catch (Exception e) {\r\n e.printStackTrace();\r\n }\r\n }",
"public WSocket() throws SocketException, UnknownHostException {\r\n\t\tthis.socket = new DatagramSocket();\r\n\t\tthis.port = socket.getLocalPort();\r\n\t\tthis.addr = InetAddress.getByName(\"localhost\");\r\n\t}",
"public ControlWorker(Socket socket) {\n \n }",
"public SocketConnection(String id, Socket socket) {\n this.identifier = id;\n this.clientSocket = socket;\n\n try {\n this.inputStream = new ObjectInputStream(\n this.clientSocket.getInputStream());\n this.outputStream = new ObjectOutputStream(\n this.clientSocket.getOutputStream());\n } catch (IOException ex) {\n ex.printStackTrace();\n }\n }",
"public MonitoringSocket(String host, int port) throws IOException {\r\n\r\n\t\tsuper(host, port);\r\n\t\tincrementNumberOfOpenSockets();\r\n\t\tprintMonitoringSocketStatus();\r\n\t}",
"public TCPServerWorker(GENServer server, Socket socket) throws IOException {\n this.server = server;\n this.socket = socket;\n this.player = null;\n state = new WorkerConnectState(this, socket);\n System.out.println(\"New ServerWorker\");\n }",
"@Override\r\n\tpublic void initial() {\n\t\ttry {\r\n\t\t\tserverSocket = new ServerSocket(port);\r\n\t\t} catch (IOException e) {\r\n\t\t\t// TODO Auto-generated catch block\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t\t// System.out.println(\"LocalProxy run on \" + port);\r\n\t}",
"public void init() {\n\t\ttry {\n\t\t\tthis.is = new ObjectInputStream(clientSocket.getInputStream());\n\t\t\tthis.os = new ObjectOutputStream(clientSocket.getOutputStream());\n\t\t\twhile (this.readCommand()) {}\n\t\t} \n\t\tcatch (IOException e) \n\t\t{\n\t\t\tSystem.out.println(\"XX. There was a problem with the Input/Output Communication:\");\n\t\t\te.printStackTrace();\n\t\t}\n\t}",
"public OOXXServer(){\n\t\ttry\n\t\t{\n\t\t\tserver = new ServerSocket(port);\n\t\t\t\n\t\t}\n\t\tcatch(java.io.IOException e)\n\t\t{\n\t\t}\n\t}",
"private void open() throws ConnectException, IOException {\n if (!opened) {\n if ((host == null) || \"\".equals(host.trim())) throw new ConnectException(\"You must specify the host name\");\n else if (port <= 0) throw new ConnectException(\"You must specify the port number\");\n socket = new Socket();\n InetSocketAddress addr = new InetSocketAddress(host, port);\n socket.setReceiveBufferSize(Utils.SOCKET_BUFFER_SIZE);\n socket.setSendBufferSize(Utils.SOCKET_BUFFER_SIZE);\n socket.setTcpNoDelay(Utils.SOCKET_TCP_NODELAY);\n socket.setKeepAlive(Utils.SOCKET_KEEPALIVE);\n socket.connect(addr);\n initStreams();\n opened = true;\n if (log.isDebugEnabled()) log.debug(\"getReceiveBufferSize() = \" + socket.getReceiveBufferSize());\n }\n }",
"public TCPRequest(ServerSocket ss) {\n try {\n this.clientSock = ss.accept();\n } catch (IOException e) {\n e.printStackTrace();\n }\n }",
"public void setConn(Connection conn) {\r\n this.conn = conn;\r\n }",
"private void init() {\n\n\t\tgroup = new NioEventLoopGroup();\n\t\ttry {\n\t\t\thandler = new MoocHandler();\n\t\t\tBootstrap b = new Bootstrap();\n\t\t\t\n\t\t\t\n\t\t\t//ManagementInitializer ci=new ManagementInitializer(false);\n\t\t\t\n\t\t\tMoocInitializer mi=new MoocInitializer(handler, false);\n\t\t\t\n\t\t\t\n\t\t\t//ManagemenetIntializer ci = new ManagemenetIntializer(handler, false);\n\t\t\t//b.group(group).channel(NioSocketChannel.class).handler(handler);\n\t\t\tb.group(group).channel(NioSocketChannel.class).handler(mi);\n\t\t\tb.option(ChannelOption.CONNECT_TIMEOUT_MILLIS, 10000);\n\t\t\tb.option(ChannelOption.TCP_NODELAY, true);\n\t\t\tb.option(ChannelOption.SO_KEEPALIVE, true);\n\n\t\t\t// Make the connection attempt.\n\t\t\tchannel = b.connect(host, port).syncUninterruptibly();\n\n\t\t\t// want to monitor the connection to the server s.t. if we loose the\n\t\t\t// connection, we can try to re-establish it.\n\t\t\tChannelClosedListener ccl = new ChannelClosedListener(this);\n\t\t\tchannel.channel().closeFuture().addListener(ccl);\n\t\t\tSystem.out.println(\" channle is \"+channel);\n\t\t} catch (Exception ex) {\n\t\t\tlogger.error(\"failed to initialize the client connection\", ex);\n\n\t\t}\n\n\t\t// start outbound message processor\n\t//\tworker = new OutboundWorker(this);\n\t//\tworker.start();\n\t}",
"public void initialize(BluetoothSocket socket) throws IOException {\n\t\tthis.socket = socket;\n\t\trfile = this.socket.getInputStream();\n\t\twfile = this.socket.getOutputStream();\n\t\t\n\t\tmessageSender.start();\n\t\tmessageReceiver.start();\n\t}"
]
| [
"0.76259726",
"0.7056697",
"0.70262396",
"0.6964509",
"0.68047476",
"0.6801477",
"0.67943376",
"0.67671347",
"0.67487663",
"0.6744657",
"0.6740747",
"0.67309713",
"0.6700717",
"0.67006594",
"0.6684615",
"0.6670477",
"0.6644881",
"0.66117376",
"0.65560275",
"0.6550612",
"0.6548063",
"0.65460324",
"0.6519154",
"0.6513198",
"0.6501533",
"0.6490644",
"0.6489766",
"0.6482914",
"0.6482834",
"0.64781153",
"0.64509887",
"0.6447946",
"0.6430818",
"0.6417663",
"0.64172274",
"0.641451",
"0.64130676",
"0.640405",
"0.6380915",
"0.6379293",
"0.63666373",
"0.6355929",
"0.6344575",
"0.6324399",
"0.6318668",
"0.6317295",
"0.6302912",
"0.63",
"0.6288833",
"0.6280326",
"0.6269754",
"0.6263968",
"0.6255959",
"0.62543344",
"0.6246884",
"0.62460744",
"0.6235685",
"0.6228826",
"0.6222653",
"0.62154675",
"0.6213702",
"0.6213702",
"0.619615",
"0.61956775",
"0.61922985",
"0.6189001",
"0.61873794",
"0.6174786",
"0.6169127",
"0.6163259",
"0.61566865",
"0.61538094",
"0.61502534",
"0.6144222",
"0.61396426",
"0.61372215",
"0.6131858",
"0.6131175",
"0.6125324",
"0.61250055",
"0.6114539",
"0.6112453",
"0.6107792",
"0.6106897",
"0.6087831",
"0.6086716",
"0.60856414",
"0.6083655",
"0.6080229",
"0.6079735",
"0.6079482",
"0.60766983",
"0.6072675",
"0.60682195",
"0.60679317",
"0.606772",
"0.6060419",
"0.60578245",
"0.60555345",
"0.6050569",
"0.6048631"
]
| 0.0 | -1 |
Subsets and Splits
No community queries yet
The top public SQL queries from the community will appear here once available.