content
stringlengths
40
137k
"public void collectNearestNeighbors(final E queryPoint, final NearestNeighborCollector<E> collector) {\n if (this.points == null) {\n final VPNode<E> firstNodeSearched = this.getChildNodeForPoint(collector.getQueryPoint());\n firstNodeSearched.collectNearestNeighbors(collector);\n final double distanceFromVantagePointToQueryPoint = this.distanceFunction.getDistance(this.vantagePoint, collector.getQueryPoint());\n final double distanceFromQueryPointToFarthestPoint = this.distanceFunction.getDistance(collector.getQueryPoint(), collector.getFarthestPoint());\n if (firstNodeSearched == this.closer) {\n final double distanceFromQueryPointToThreshold = this.threshold - distanceFromVantagePointToQueryPoint;\n if (distanceFromQueryPointToFarthestPoint > distanceFromQueryPointToThreshold) {\n this.farther.collectNearestNeighbors(queryPoint, collector);\n }\n } else {\n double distanceFromQueryPointToThreshold = distanceFromVantagePointToQueryPoint - this.threshold;\n if (distanceFromQueryPointToThreshold <= distanceFromQueryPointToFarthestPoint) {\n this.closer.collectNearestNeighbors(queryPoint, collector);\n }\n }\n } else {\n for (final E point : this.points) {\n collector.offerPoint(point);\n }\n }\n}\n"
"private String healthDataKeyToAnonimizedKeyString(HealthDataKey key) {\n if (key == null) {\n throw new BridgeServiceException(\"String_Node_Str\");\n } else if (key.getStudyId() == 0) {\n throw new BridgeServiceException(\"String_Node_Str\");\n } else if (key.getTrackerId() == 0) {\n throw new BridgeServiceException(\"String_Node_Str\");\n } else if (key.getSessionToken() == null) {\n throw new BridgeServiceException(\"String_Node_Str\");\n }\n UserSessionData data = getSynapseClient(key.getSessionToken()).getUserSessionData();\n String ownerId = data.getProfile().getOwnerId();\n if (StringUtils.isBlank(ownerId)) {\n throw new BridgeServiceException(\"String_Node_Str\");\n }\n String encryptedValue = encryptor.encrypt(ownerId);\n return String.format(\"String_Node_Str\", key.getStudyId(), key.getTrackerId(), encryptedValue);\n}\n"
"public boolean apply(VersionInfo input) {\n return input.getTimestamp().equals(maxTimestamp) || input.getOperation() != Operation.DELETE;\n}\n"
"private List<OverviewIndUIElement> wapperInput(EList<TableIndicator> indicatorTableList, IRepositoryNode parentNode) {\n List<OverviewIndUIElement> cataUIEleList = new ArrayList<OverviewIndUIElement>();\n List<IRepositoryNode> children = parentNode.getChildren();\n for (IRepositoryNode folderNode : children) {\n if (folderNode instanceof DBTableFolderRepNode) {\n List<IRepositoryNode> tableNodes = folderNode.getChildren();\n for (TableIndicator indicator : indicatorTableList) {\n for (IRepositoryNode tableNode : tableNodes) {\n MetadataTable table = ((MetadataTableRepositoryObject) tableNode.getObject()).getTable();\n String name = table.getName();\n String tableName = indicator.getTableName();\n equals = name.equals(tableName);\n if (equals) {\n OverviewIndUIElement tableUIEle = new OverviewIndUIElement();\n tableUIEle.setNode(tableNode);\n tableUIEle.setOverviewIndicator(indicator);\n cataUIEleList.add(tableUIEle);\n break;\n }\n }\n }\n }\n }\n return cataUIEleList;\n}\n"
"public static Object evalExpr(IBaseExpression expr, ScriptContext cx, String source, int lineNo) throws DataException {\n try {\n if (logger.isLoggable(Level.FINER))\n logger.entering(ScriptEvalUtil.class.getName(), \"String_Node_Str\", \"String_Node_Str\" + LogUtil.toString(expr) + \"String_Node_Str\" + source + \"String_Node_Str\" + lineNo);\n Object result;\n if (expr == null) {\n result = null;\n } else if (expr instanceof IConditionalExpression) {\n Object handle = expr.getHandle();\n if (handle instanceof NEvaluator) {\n result = Boolean.valueOf(((NEvaluator) handle).evaluate(cx, ((IDataScriptEngine) cx.getScriptEngine(IDataScriptEngine.ENGINE_NAME)).getJSScope(cx)));\n } else {\n ConditionalExpression conditionalExpr = (ConditionalExpression) expr;\n Object expression = evalExpr(conditionalExpr.getExpression(), cx, source, lineNo);\n if (conditionalExpr.getOperand1() instanceof IExpressionCollection) {\n IExpressionCollection combinedExpr = (IExpressionCollection) ((IConditionalExpression) expr).getOperand1();\n Object[] exprs = combinedExpr.getExpressions().toArray();\n Object[] opValues = new Object[exprs.length];\n for (int i = 0; i < opValues.length; i++) {\n opValues[i] = evalExpr((IBaseExpression) exprs[i], cx, source, lineNo);\n }\n result = evalConditionalExpr(expression, conditionalExpr.getOperator(), MiscUtil.flatternMultipleValues(opValues));\n } else {\n Object Op1 = evalExpr(MiscUtil.constructValidScriptExpression((IScriptExpression) conditionalExpr.getOperand1()), cx, source, lineNo);\n Object Op2 = evalExpr(MiscUtil.constructValidScriptExpression((IScriptExpression) conditionalExpr.getOperand2()), cx, source, lineNo);\n result = evalConditionalExpr(expression, conditionalExpr.getOperator(), new Object[] { Op1, Op2 });\n }\n }\n } else if (expr instanceof ICollectionConditionalExpression) {\n Collection<IScriptExpression> testExpr = ((ICollectionConditionalExpression) expr).getExpr();\n Collection<Collection<IScriptExpression>> operand = ((ICollectionConditionalExpression) expr).getOperand();\n List<Object> testObj = new ArrayList<Object>();\n boolean in = false;\n for (IScriptExpression se : testExpr) {\n testObj.add(evalExpr(se, cx, source, lineNo));\n }\n for (Collection<IScriptExpression> op : operand) {\n List<Object> targetObj = new ArrayList<Object>();\n for (IScriptExpression se : op) {\n if (se == null) {\n targetObj.add(null);\n } else {\n if (se.getHandle() == null) {\n se.setHandle(evalExpr(se, cx, source, lineNo));\n }\n targetObj.add(se.getHandle());\n }\n targetObj.add(se.getHandle());\n }\n if (compare(testObj, targetObj) == 0) {\n in = Boolean.TRUE;\n break;\n }\n }\n result = (((ICollectionConditionalExpression) expr).getOperator() == ICollectionConditionalExpression.OP_IN) ? in : (!in);\n } else {\n IScriptExpression jsExpr = (IScriptExpression) expr;\n if (jsExpr.isConstant() && jsExpr.getConstantValue() != null) {\n result = jsExpr.getConstantValue();\n } else {\n if (jsExpr.getText() != null && jsExpr.getHandle() != null) {\n if (jsExpr.getHandle() instanceof ICompiledScript) {\n result = cx.evaluate((ICompiledScript) jsExpr.getHandle());\n } else {\n result = ((CompiledExpression) jsExpr.getHandle()).evaluate(cx, ((IDataScriptEngine) cx.getScriptEngine(IDataScriptEngine.ENGINE_NAME)).getJSScope(cx));\n }\n } else {\n result = evaluateJSAsExpr(cx, ((IDataScriptEngine) cx.getScriptEngine(IDataScriptEngine.ENGINE_NAME)).getJSScope(cx), jsExpr.getText(), source, lineNo);\n }\n if (jsExpr.isConstant()) {\n jsExpr.setConstantValue(result);\n }\n }\n }\n if (logger.isLoggable(Level.FINER))\n logger.exiting(ScriptEvalUtil.class.getName(), \"String_Node_Str\", result);\n return result;\n } catch (BirtException e) {\n throw DataException.wrap(e);\n }\n}\n"
"public void setFontSize(double screenWidth, double screenHeight) {\n int initialsize = 16;\n if (screenWidth >= 2160.0 && screenHeight >= 1440) {\n fontSize = (int) (initialsize * 1.37);\n } else if (screenWidth >= 1920.0 && screenHeight >= 1080.0) {\n fontSize = (int) (initialsize * 1.29);\n } else if (screenWidth >= 1366.0 && screenHeight >= 768.0) {\n fontSize = (int) (initialsize * 1.07);\n } else if (screenWidth >= 1280.0 && screenHeight >= 800.0) {\n fontSize = initialsize;\n }\n}\n"
"void fillPropertyScopes() {\n List<Symbol> types = new ArrayList<>();\n List<Symbol> googModuleExportTypes = new ArrayList<>();\n for (Symbol sym : getAllSymbols()) {\n if (needsPropertyScope(sym)) {\n if (sym.getName().startsWith(\"String_Node_Str\")) {\n googModuleExportTypes.add(sym);\n } else {\n types.add(sym);\n }\n }\n }\n Collections.sort(types, getNaturalSymbolOrdering().reverse());\n Collections.sort(googModuleExportTypes, getNaturalSymbolOrdering().reverse());\n Iterable<Symbol> allTypes = Iterables.concat(googModuleExportTypes, types);\n Map<JSType, Symbol> symbolThatDeclaresType = new IdentityHashMap<>();\n for (Symbol s : allTypes) {\n symbolThatDeclaresType.put(s.getType(), s);\n }\n for (Symbol s : allTypes) {\n if (s.getType() == null || symbolThatDeclaresType.get(s.getType()).equals(s)) {\n createPropertyScopeFor(s);\n }\n }\n for (Symbol s : allTypes) {\n if (s.getType() != null) {\n s.propertyScope = symbolThatDeclaresType.get(s.getType()).getPropertyScope();\n }\n }\n pruneOrphanedNames();\n}\n"
"public static boolean isPluginLoaded(String name) {\n boolean loaded;\n try {\n Class pluginCore = Class.forName(pluginCore_Class);\n Method isPluginAlive = pluginCore.getMethod(\"String_Node_Str\", new Class[] { String.class });\n String l = isPluginAlive.invoke(null, name).toString();\n if (l.toLowerCase().equals(\"String_Node_Str\")) {\n if (API.verbose) {\n System.out.println(name + \"String_Node_Str\");\n }\n loaded = true;\n } else {\n if (API.verbose) {\n System.out.println(name + \"String_Node_Str\");\n }\n loaded = false;\n }\n } catch (Exception ex) {\n ex.printStackTrace();\n return false;\n }\n return loaded;\n}\n"
"public ITmfStateValue popAttribute(long t, int attributeQuark) throws AttributeNotFoundException, TimeRangeException, StateValueTypeException {\n ITmfStateValue previousSV = queryOngoingState(attributeQuark);\n if (previousSV.isNull()) {\n return null;\n }\n if (previousSV.getType() != Type.INTEGER) {\n throw new StateValueTypeException();\n }\n int stackDepth = previousSV.unboxInt();\n if (stackDepth <= 0) {\n String message = \"String_Node_Str\" + \"String_Node_Str\";\n throw new StateValueTypeException(message);\n }\n int subAttributeQuark = getQuarkRelative(attributeQuark, stackDepth.toString());\n ITmfStateValue poppedValue = queryOngoingState(subAttributeQuark);\n ITmfStateValue nextSV;\n if (--stackDepth == 0) {\n nextSV = TmfStateValue.nullValue();\n } else {\n nextSV = TmfStateValue.newValueInt(stackDepth);\n }\n modifyAttribute(t, nextSV, attributeQuark);\n removeAttribute(t, subAttributeQuark);\n return poppedValue;\n}\n"
"public static String addQuotesWithSpaceField(String fieldName, String dbType) {\n if (fieldName == null) {\n fieldName = \"String_Node_Str\";\n }\n if (fieldName.startsWith(\"String_Node_Str\") && fieldName.endsWith(\"String_Node_Str\")) {\n return fieldName;\n }\n boolean b = true;\n for (int i = 0; i < fieldName.length(); i++) {\n char c = fieldName.charAt(i);\n b = b && c >= '0' && c <= '9';\n }\n EDatabaseTypeName name = EDatabaseTypeName.getTypeFromDbType(dbType);\n if (name.equals(EDatabaseTypeName.MYSQL) && fieldName.contains(JAVA_END_STRING)) {\n String newFieldName = TalendQuoteUtils.addQuotes(fieldName);\n return newFieldName;\n }\n boolean isCheck = !CorePlugin.getDefault().getPreferenceStore().getBoolean(ITalendCorePrefConstants.SQL_ADD_QUOTE);\n if (!b) {\n if (isCheck && isPSQLSimilar(name) && check) {\n return fieldName;\n }\n }\n String newFieldName = fieldName;\n String quote = getQuoteByDBType(name);\n if (!newFieldName.contains(quote)) {\n newFieldName = addQuotes(newFieldName, quote);\n }\n return newFieldName;\n}\n"
"private void sendWolfPrice(Player p) {\n if (hasPermission(p, PERM_ADOPT))\n if (this.adoptPrice == 0) {\n p.sendMessage(\"String_Node_Str\");\n } else if (this.adoptType == -1) {\n p.sendMessage(\"String_Node_Str\" + adoptPrice + \"String_Node_Str\");\n } else {\n Material m = Material.getMaterial(adoptType);\n if (m != null) {\n p.sendMessage(\"String_Node_Str\" + adoptPrice + \"String_Node_Str\" + m.toString() + \"String_Node_Str\");\n } else {\n p.sendMessage(\"String_Node_Str\" + adoptPrice + \"String_Node_Str\");\n }\n }\n}\n"
"private void performAdd() {\n try {\n TreePath path = this.tree.getSelectionPath();\n DefaultMutableTreeNode node = (DefaultMutableTreeNode) path.getLastPathComponent();\n if (!(node.getUserObject() instanceof String)) {\n node = (DefaultMutableTreeNode) node.getParent();\n }\n DefaultMutableTreeNode parent = (DefaultMutableTreeNode) node.getParent();\n Object obj = parent.getUserObject();\n String fieldName = node.getUserObject().toString();\n Field field = obj.getClass().getDeclaredField(fieldName);\n field.setAccessible(true);\n Object fieldObject = field.get(obj);\n if (fieldObject instanceof Collection) {\n ParameterizedType gtype = (ParameterizedType) field.getGenericType();\n java.lang.reflect.Type[] types = gtype.getActualTypeArguments();\n Object item = ((Class) types[0]).newInstance();\n ((Collection) fieldObject).add(item);\n generateTree();\n }\n } catch (SecurityException e) {\n throw new WorkBenchError(e);\n } catch (NoSuchFieldException e) {\n throw new WorkBenchError(e);\n } catch (IllegalAccessException e) {\n throw new WorkBenchError(e);\n } catch (InstantiationException e) {\n throw new WorkBenchError(e);\n }\n}\n"
"public void run() {\n if (activeComponent != -1) {\n synchronized (context.get(Context.KEY_TAB_LIST)) {\n frames.get(activeComponent).deactivate();\n activeComponent++;\n if (activeComponent >= frames.size()) {\n activeComponent = 0;\n }\n Component.Instance component = frames.get(activeComponent);\n component.activate();\n component.update1stStep();\n component.setPosition(leftMostColumn, row, column, size);\n component.update2ndStep();\n }\n }\n}\n"
"public void expunged(int msn) {\n synchronized (_expungedMsns) {\n _expungedMsns.add(Integer.valueOf(msn));\n }\n}\n"
"private void addProfileData(List<String> valueList, DateFormatter dateFormatter, StringBuilder builder, PointFeatureIterator profileIterator, int stNum) {\n try {\n while (profileIterator.hasNext()) {\n PointFeature pointFeature = profileIterator.next();\n valueList.clear();\n valueList.add(\"String_Node_Str\" + dateFormatter.toDateTimeStringISO(pointFeature.getObservationTimeAsDate()));\n String profileID = getProfileIDFromProfile(pointFeature);\n if (profileID != null) {\n valueList.clear();\n valueList.add(\"String_Node_Str\" + dateFormatter.toDateTimeStringISO(pointFeature.getObservationTimeAsDate()));\n valueList.add(\"String_Node_Str\" + stNum);\n addProfileDataToBuilder(valueList, pointFeature, builder);\n }\n }\n } catch (Exception ex) {\n builder.delete(0, builder.length());\n builder.append(\"String_Node_Str\").append(ex.getLocalizedMessage()).append(\"String_Node_Str\");\n }\n}\n"
"public InvokeInstruction getTheInvokeInstruction() {\n InvokeInstruction theInvInstr = null;\n for (InstructionHandle ih : this.instructions) {\n if (!(ih.getInstruction() instanceof InvokeInstruction))\n continue;\n InvokeInstruction inv = (InvokeInstruction) ih.getInstruction();\n if (this.getAppInfo().getProcessorModel().isSpecialInvoke(methodCode.getMethodInfo(), inv)) {\n continue;\n }\n if (theInvInstr != null) {\n throw new ControlFlowGraph.ControlFlowError(\"String_Node_Str\");\n }\n theInvInstr = ih;\n }\n return theInvInstr;\n}\n"
"public void stop() {\n this.setStopping();\n LOGGER.trace(\"String_Node_Str\");\n final LoggerContextFactory factory = LogManager.getFactory();\n if (factory instanceof Log4jContextFactory) {\n ContextSelector selector = ((Log4jContextFactory) factory).getSelector();\n if (selector instanceof AsyncLoggerContextSelector) {\n }\n }\n int asyncLoggerConfigCount = 0;\n for (final LoggerConfig logger : loggers.values()) {\n if (logger instanceof AsyncLoggerConfig) {\n logger.stop();\n asyncLoggerConfigCount++;\n }\n }\n if (root instanceof AsyncLoggerConfig) {\n root.stop();\n asyncLoggerConfigCount++;\n }\n LOGGER.trace(\"String_Node_Str\", asyncLoggerConfigCount);\n final Appender[] array = appenders.values().toArray(new Appender[appenders.size()]);\n int asyncAppenderCount = 0;\n for (int i = array.length - 1; i >= 0; --i) {\n if (array[i] instanceof AsyncAppender) {\n array[i].stop();\n asyncAppenderCount++;\n }\n }\n LOGGER.trace(\"String_Node_Str\", asyncAppenderCount);\n int appenderCount = 0;\n for (int i = array.length - 1; i >= 0; --i) {\n if (array[i].isStarted()) {\n array[i].stop();\n appenderCount++;\n }\n }\n LOGGER.trace(\"String_Node_Str\", appenderCount);\n int loggerCount = 0;\n for (final LoggerConfig logger : loggers.values()) {\n logger.clearAppenders();\n logger.stop();\n loggerCount++;\n }\n LOGGER.trace(\"String_Node_Str\", loggerCount);\n if (!alreadyStopped.contains(root)) {\n root.stop();\n }\n super.stop();\n if (advertiser != null && advertisement != null) {\n advertiser.unadvertise(advertisement);\n }\n}\n"
"public boolean equals(Object obj) {\n if (this == obj) {\n return true;\n if (obj == null)\n return false;\n if (getClass() != obj.getClass())\n return false;\n HolePunchingMetaData other = (HolePunchingMetaData) obj;\n if (maxConnectionSetupTime != other.maxConnectionSetupTime)\n return false;\n if (name == null) {\n if (other.name != null)\n return false;\n } else if (!name.equals(other.name))\n return false;\n if (timeoutInSeconds != other.timeoutInSeconds)\n return false;\n if (version == null) {\n if (other.version != null)\n return false;\n } else if (!version.equals(other.version))\n return false;\n return true;\n}\n"
"public Report saveReport(Report report, String description) {\n String reportRequestUuid = report.getRequest().getUuid();\n CachedReportData cachedData = persistCachedReportDataToDisk(reportRequestUuid);\n if (cachedData != null && !cachedData.isPersisted()) {\n throw new ReportingException(\"String_Node_Str\");\n }\n}\n"
"public void run() {\n try {\n final boolean fullSync = !Hosts.isCoordinator() && host.isLocalHost() && BootstrapArgs.isCloudController() && !Databases.isSynchronized();\n final boolean passiveSync = !fullSync && host.hasSynced();\n if (!fullSync && !passiveSync) {\n throw Exceptions.toUndeclared(\"String_Node_Str\" + host);\n } else {\n DriverDatabaseClusterMBean cluster = LookupPersistenceContextDatabaseCluster.INSTANCE.apply(contextName);\n final String dbUrl = \"String_Node_Str\" + ServiceUris.remote(Database.class, host.getBindAddress(), contextName);\n final String realJdbcDriver = Databases.getDriverName();\n String syncStrategy = \"String_Node_Str\";\n Lock dbLock = cluster.getLockManager().writeLock(\"String_Node_Str\");\n if (dbLock.tryLock(120, TimeUnit.SECONDS)) {\n try {\n boolean activated = cluster.getActiveDatabases().contains(hostName);\n boolean deactivated = cluster.getInactiveDatabases().contains(hostName);\n syncStrategy = (fullSync ? \"String_Node_Str\" : \"String_Node_Str\");\n if (fullSync) {\n LOG.info(\"String_Node_Str\" + host);\n } else {\n LOG.info(\"String_Node_Str\" + host);\n }\n if (activated) {\n LOG.info(\"String_Node_Str\" + host);\n cluster.deactivate(hostName);\n ActivateHostFunction.prepareConnections(host, contextName);\n } else if (deactivated) {\n ActivateHostFunction.prepareConnections(host, contextName);\n } else {\n LOG.info(\"String_Node_Str\" + host);\n cluster.add(hostName, realJdbcDriver, dbUrl);\n ActivateHostFunction.prepareConnections(host, contextName);\n }\n } finally {\n dbLock.unlock();\n }\n try {\n cluster.activate(hostName, syncStrategy);\n if (fullSync) {\n LOG.info(\"String_Node_Str\" + host + \"String_Node_Str\" + cluster.getActiveDatabases());\n } else {\n LOG.info(\"String_Node_Str\" + host + \"String_Node_Str\" + cluster.getActiveDatabases());\n }\n return;\n } catch (Exception ex) {\n throw Exceptions.toUndeclared(ex);\n }\n }\n }\n } catch (final NoSuchElementException ex1) {\n LOG.info(ex1);\n Logs.extreme().debug(ex1, ex1);\n return;\n } catch (final IllegalStateException ex1) {\n LOG.info(ex1);\n Logs.extreme().debug(ex1, ex1);\n return;\n } catch (final Exception ex1) {\n Logs.extreme().error(ex1, ex1);\n throw Exceptions.toUndeclared(\"String_Node_Str\" + host + \"String_Node_Str\" + ex1.getMessage(), ex1);\n }\n}\n"
"public void testEvaluate() throws Exception {\n DataSetDefinitionService service = mock(DataSetDefinitionService.class);\n Location aLocation = new Location();\n SqlDataSetDefinition baseDsd = new SqlDataSetDefinition();\n baseDsd.addParameter(new Parameter(\"String_Node_Str\", \"String_Node_Str\", Date.class));\n baseDsd.addParameter(new Parameter(\"String_Node_Str\", \"String_Node_Str\", Date.class));\n baseDsd.addParameter(new Parameter(\"String_Node_Str\", \"String_Node_Str\", Location.class));\n RepeatPerTimePeriodDataSetDefinition dsd = new RepeatPerTimePeriodDataSetDefinition();\n dsd.addParameter(new Parameter(\"String_Node_Str\", \"String_Node_Str\", Date.class));\n dsd.addParameter(new Parameter(\"String_Node_Str\", \"String_Node_Str\", Date.class));\n dsd.addParameter(new Parameter(\"String_Node_Str\", \"String_Node_Str\", Location.class));\n dsd.setBaseDefinition(baseDsd);\n dsd.setRepeatPerTimePeriod(TimePeriod.WEEKLY);\n RepeatPerTimePeriodDataSetEvaluator evaluator = new RepeatPerTimePeriodDataSetEvaluator();\n evaluator.setDataSetDefinitionService(service);\n EvaluationContext context = new EvaluationContext();\n context.addParameterValue(\"String_Node_Str\", DateUtil.parseYmd(\"String_Node_Str\"));\n context.addParameterValue(\"String_Node_Str\", DateUtils.addMilliseconds(DateUtil.parseYmd(\"String_Node_Str\"), -1));\n context.addParameterValue(\"String_Node_Str\", aLocation);\n evaluator.evaluate(dsd, context);\n final MultiParameterDataSetDefinition expectedDelegate = new MultiParameterDataSetDefinition();\n expectedDelegate.setBaseDefinition(baseDsd);\n expectedDelegate.addParameter(new Parameter(\"String_Node_Str\", \"String_Node_Str\", Date.class));\n expectedDelegate.addParameter(new Parameter(\"String_Node_Str\", \"String_Node_Str\", Date.class));\n expectedDelegate.addParameter(new Parameter(\"String_Node_Str\", \"String_Node_Str\", Location.class));\n Map<String, Object> iteration = new HashMap<String, Object>();\n iteration.put(\"String_Node_Str\", DateUtil.parseYmd(\"String_Node_Str\"));\n iteration.put(\"String_Node_Str\", DateUtils.addMilliseconds(DateUtil.parseYmd(\"String_Node_Str\"), -1));\n expectedDelegate.addIteration(iteration);\n iteration = new HashMap<String, Object>();\n iteration.put(\"String_Node_Str\", DateUtil.parseYmd(\"String_Node_Str\"));\n iteration.put(\"String_Node_Str\", DateUtils.addMilliseconds(DateUtil.parseYmd(\"String_Node_Str\"), -1));\n expectedDelegate.addIteration(iteration);\n iteration = new HashMap<String, Object>();\n iteration.put(\"String_Node_Str\", DateUtil.parseYmd(\"String_Node_Str\"));\n iteration.put(\"String_Node_Str\", DateUtils.addMilliseconds(DateUtil.parseYmd(\"String_Node_Str\"), -1));\n expectedDelegate.addIteration(iteration);\n iteration = new HashMap<String, Object>();\n iteration.put(\"String_Node_Str\", DateUtil.parseYmd(\"String_Node_Str\"));\n iteration.put(\"String_Node_Str\", DateUtils.addMilliseconds(DateUtil.parseYmd(\"String_Node_Str\"), -1));\n expectedDelegate.addIteration(iteration);\n iteration = new HashMap<String, Object>();\n iteration.put(\"String_Node_Str\", DateUtil.parseYmd(\"String_Node_Str\"));\n iteration.put(\"String_Node_Str\", DateUtils.addMilliseconds(DateUtil.parseYmd(\"String_Node_Str\"), -1));\n expectedDelegate.addIteration(iteration);\n verify(service).evaluate(argThat(new ArgumentMatcher<DataSetDefinition>() {\n public boolean matches(Object argument) {\n MultiParameterDataSetDefinition actualDelegate = (MultiParameterDataSetDefinition) argument;\n return actualDelegate.getParameters().equals(expectedDelegate.getParameters()) && actualDelegate.getIterations().equals(expectedDelegate.getIterations());\n }\n }), eq(context));\n}\n"
"public GetTypesResponse getTypes(GetTypes parameters) throws RuntimeException, InvalidArgumentException, ObjectNotFoundException, ConstraintViolationException, OperationNotSupportedException, UpdateConflictException, PermissionDeniedException {\n checkRepositoryId(parameters.getRepositoryId());\n Collection<CMISTypeId> typeIds;\n if (parameters.getTypeId() == null) {\n typeIds = cmisDictionaryService.getAllObjectTypeIds();\n } else {\n typeIds = cmisDictionaryService.getChildTypeIds(cmisDictionaryService.getCMISMapping().getCmisTypeId(parameters.getTypeId().getValue()), true);\n }\n GetTypesResponse response = new GetTypesResponse();\n if (parameters.getMaxItems() != null) {\n response.setHasMoreItems(parameters.getMaxItems().getValue().intValue() < typeIds.size());\n }\n Cursor cursor = createCursor(typeIds.size(), parameters.getSkipCount() != null ? parameters.getSkipCount().getValue() : null, parameters.getMaxItems() != null ? parameters.getMaxItems().getValue() : null);\n Iterator<CMISTypeId> iterTypeIds = typeIds.iterator();\n for (int i = 0; i < cursor.getStartRow(); i++) {\n iterTypeIds.next();\n }\n boolean returnPropertyDefinitions = parameters.getReturnPropertyDefinitions() == null ? false : parameters.getReturnPropertyDefinitions().getValue();\n List<JAXBElement<? extends CmisTypeDefinitionType>> types = response.getType();\n for (int i = cursor.getStartRow(); i <= cursor.getEndRow(); i++) {\n JAXBElement<? extends CmisTypeDefinitionType> element = getCmisTypeDefinition(iterTypeIds.next().getTypeId(), returnPropertyDefinitions);\n if (element != null) {\n types.add(element);\n }\n }\n return response;\n}\n"
"public List<String> getAllPlayers() {\n return Arrays.asList(getPlayer().getName());\n}\n"
"private final void sendServiceArgsLocked(ServiceRecord r, boolean execInFg, boolean oomAdjusted) throws TransactionTooLargeException {\n final int N = r.pendingStarts.size();\n if (N == 0) {\n return;\n }\n while (r.pendingStarts.size() > 0) {\n Exception caughtException = null;\n ServiceRecord.StartItem si = null;\n try {\n si = r.pendingStarts.remove(0);\n if (DEBUG_SERVICE)\n Slog.v(TAG_SERVICE, \"String_Node_Str\" + r + \"String_Node_Str\" + r.intent + \"String_Node_Str\" + si.intent);\n if (si.intent == null && N > 1) {\n continue;\n }\n si.deliveredTime = SystemClock.uptimeMillis();\n r.deliveredStarts.add(si);\n si.deliveryCount++;\n if (si.neededGrants != null) {\n mAm.grantUriPermissionUncheckedFromIntentLocked(si.neededGrants, si.getUriPermissionsLocked());\n }\n bumpServiceExecutingLocked(r, execInFg, \"String_Node_Str\");\n if (!oomAdjusted) {\n oomAdjusted = true;\n mAm.updateOomAdjLocked(r.app);\n }\n int flags = 0;\n if (si.deliveryCount > 1) {\n flags |= Service.START_FLAG_RETRY;\n }\n if (si.doneExecutingCount > 0) {\n flags |= Service.START_FLAG_REDELIVERY;\n }\n r.app.thread.scheduleServiceArgs(r, si.taskRemoved, si.id, flags, si.intent);\n } catch (TransactionTooLargeException e) {\n if (DEBUG_SERVICE)\n Slog.v(TAG_SERVICE, \"String_Node_Str\" + si.intent);\n caughtException = e;\n } catch (RemoteException e) {\n if (DEBUG_SERVICE)\n Slog.v(TAG_SERVICE, \"String_Node_Str\" + r);\n caughtException = e;\n } catch (Exception e) {\n Slog.w(TAG, \"String_Node_Str\", e);\n caughtException = e;\n }\n if (caughtException != null) {\n final boolean inDestroying = mDestroyingServices.contains(r);\n serviceDoneExecutingLocked(r, inDestroying, inDestroying);\n if (caughtException instanceof TransactionTooLargeException) {\n throw (TransactionTooLargeException) caughtException;\n }\n break;\n }\n }\n}\n"
"protected void createLogPropertyFiles(File directory) {\n ArgumentNotValid.checkNotNull(directory, \"String_Node_Str\");\n for (Application app : applications) {\n try {\n File logProp = new File(directory, Constants.LOG_PROP_APPLICATION_PREFIX + app.getIdentification() + Constants.LOG_PROP_APPLICATION_SUFFIX);\n FileWriter logfw = new FileWriter(logProp);\n String prop = FileUtils.readFile(inheritedLogPropFile);\n prop = prop.replace(Constants.LOG_PROPERTY_APPLICATION_ID_TAG, app.getIdentification());\n try {\n logfw.write(prop);\n } finally {\n if (logfw != null) {\n logfw.close();\n }\n }\n } catch (IOException e) {\n log.warn(\"String_Node_Str\" + e);\n }\n }\n}\n"
"public void testGetLocalizedMessages() throws InterruptedException, ExecutionException, TimeoutException {\n try {\n handler.getLocalizedMessages().get(1, MINUTES);\n } catch (RequestException ex) {\n if (isNotServerside(ex))\n throw ex;\n }\n}\n"
"public void testForeignKeyModel() {\n Delete.tables(TestModel1.class, ForeignInteractionModel.class);\n ForeignInteractionModel foreignInteractionModel = new ForeignInteractionModel();\n TestModel1 testModel1 = new TestModel1();\n testModel1.name = \"String_Node_Str\";\n foreignInteractionModel.setTestModel1(testModel1);\n foreignInteractionModel.name = \"String_Node_Str\";\n foreignInteractionModel.save(false);\n assertTrue(foreignInteractionModel.exists());\n assertTrue(foreignInteractionModel.testModel1.exists());\n Delete.tables(TestModel1.class, ForeignInteractionModel.class);\n}\n"
"protected void openStreams() throws IncomingFileTransferException {\n final String urlString = getRemoteFileURL().toString();\n try {\n httpClient.getHttpConnectionManager().getParams().setSoTimeout(DEFAULT_CONNECTION_TIMEOUT);\n httpClient.getHttpConnectionManager().getParams().setConnectionTimeout(DEFAULT_CONNECTION_TIMEOUT);\n setupAuthentication(urlString);\n setupHostAndPort(urlString);\n getMethod = new GzipGetMethod(urlString);\n getMethod.setFollowRedirects(true);\n setRequestHeaderValues();\n final int code = httpClient.executeMethod(getMethod);\n if (code == HttpURLConnection.HTTP_PARTIAL || code == HttpURLConnection.HTTP_OK) {\n getResponseHeaderValues();\n setInputStream(getMethod.getResponseBodyAsUnzippedStream());\n fireReceiveStartEvent();\n } else if (code == HttpURLConnection.HTTP_NOT_FOUND) {\n getMethod.releaseConnection();\n throw new FileNotFoundException(urlString);\n } else if (code == HttpURLConnection.HTTP_UNAUTHORIZED || code == HttpURLConnection.HTTP_FORBIDDEN) {\n getMethod.getResponseBody();\n getMethod.releaseConnection();\n throw new IncomingFileTransferException(Messages.HttpClientRetrieveFileTransfer_Unauthorized);\n } else if (code == HttpURLConnection.HTTP_PROXY_AUTH) {\n getMethod.releaseConnection();\n throw new LoginException(Messages.HttpClientRetrieveFileTransfer_Proxy_Auth_Required);\n } else {\n getMethod.releaseConnection();\n throw new IOException(NLS.bind(Messages.HttpClientRetrieveFileTransfer_ERROR_GENERAL_RESPONSE_CODE, new Integer(code)));\n }\n } catch (final Exception e) {\n throw new IncomingFileTransferException(NLS.bind(Messages.HttpClientRetrieveFileTransfer_EXCEPTION_COULD_NOT_CONNECT, urlString), e);\n }\n}\n"
"public final JSONArray getRMIndicators(JSONObject jsonObject) {\n JSONArray indicators = null;\n try {\n JSONObject rmNode = getRMNode(jsonObject);\n if (rmNode != null) {\n indicators = (JSONArray) rmNode.get(\"String_Node_Str\");\n }\n } catch (Exception err) {\n throw new AlfrescoRuntimeException(\"String_Node_Str\" + err);\n }\n return indicators;\n}\n"
"public LogicalWorkflow getLogicalWorkflow() {\n List<LogicalStep> logiclaSteps = new ArrayList<>();\n Project project = new Project(Operations.PROJECT, new TableName(catalog, table), clusterName, columns);\n LogicalStep lastStep = project;\n for (Filter filter : filters) {\n lastStep.setNextStep(filter);\n lastStep = filter;\n }\n if (limit != null) {\n lastStep.setNextStep(limit);\n lastStep = limit;\n }\n if (window != null) {\n lastStep.setNextStep(window);\n lastStep = window;\n }\n if (select == null) {\n Map<ColumnName, String> selectColumn = new LinkedHashMap<>();\n Map<String, ColumnType> typeMap = new LinkedHashMap();\n Map<ColumnName, ColumnType> typeMapColumnName = new LinkedHashMap<>();\n for (ColumnName columnName : project.getColumnList()) {\n ColumnName columnNameTemp = new ColumnName(catalog, table, columnName.getName());\n selectColumn.put(columnNameTemp, columnName.getName());\n typeMap.put(columnName.getQualifiedName(), ColumnType.VARCHAR);\n typeMapColumnName.put(columnNameTemp, ColumnType.VARCHAR);\n }\n select = new Select(Operations.PROJECT, selectColumn, typeMap, typeMapColumnName);\n }\n lastStep.setNextStep(select);\n logiclaSteps.add(project);\n return new LogicalWorkflow(logiclaSteps);\n}\n"
"public final Var_declContext var_decl() throws RecognitionException {\n Var_declContext _localctx = new Var_declContext(_ctx, getState());\n enterRule(_localctx, 98, RULE_var_decl);\n try {\n setState(456);\n switch(getInterpreter().adaptivePredict(_input, 39, _ctx)) {\n case 1:\n _localctx = new DeclByClassContext(_localctx);\n enterOuterAlt(_localctx, 1);\n {\n setState(436);\n class_def();\n setState(438);\n switch(getInterpreter().adaptivePredict(_input, 37, _ctx)) {\n case 1:\n {\n setState(437);\n init_declarator_list();\n }\n break;\n }\n }\n break;\n case 2:\n _localctx = new DeclByTypeContext(_localctx);\n enterOuterAlt(_localctx, 2);\n {\n setState(440);\n type_name();\n setState(441);\n init_declarator_list();\n }\n break;\n }\n } catch (RecognitionException re) {\n _localctx.exception = re;\n _errHandler.reportError(this, re);\n _errHandler.recover(this, re);\n } finally {\n exitRule();\n }\n return _localctx;\n}\n"
"public CharSequence getFlyweightStr(int col) {\n return colA(col).getStr(colB(col).getLong(recordIndex * 8));\n}\n"
"private static List<ITimeEvent> getEventList(ResourcesEntry entry, long startTime, long endTime, long resolution, boolean includeNull, IProgressMonitor monitor) {\n IStateSystemQuerier ssq = entry.getTrace().getStateSystem();\n startTime = Math.max(startTime, ssq.getStartTime());\n endTime = Math.min(endTime, ssq.getCurrentEndTime() + 1);\n if (endTime <= startTime) {\n return null;\n }\n List<ITimeEvent> eventList = null;\n int quark = entry.getQuark();\n try {\n if (entry.getType().equals(Type.CPU)) {\n int statusQuark = ssq.getQuarkRelative(quark, Attributes.STATUS);\n List<ITmfStateInterval> statusIntervals = ssq.queryHistoryRange(statusQuark, startTime, endTime - 1, resolution, monitor);\n eventList = new ArrayList<ITimeEvent>(statusIntervals.size());\n long lastEndTime = -1;\n for (ITmfStateInterval statusInterval : statusIntervals) {\n if (monitor.isCanceled()) {\n return null;\n }\n int status = statusInterval.getStateValue().unboxInt();\n long time = statusInterval.getStartTime();\n long duration = statusInterval.getEndTime() - time + 1;\n if (!statusInterval.getStateValue().isNull()) {\n if (lastEndTime != time && lastEndTime != -1) {\n eventList.add(new TimeEvent(entry, lastEndTime, time - lastEndTime));\n }\n eventList.add(new ResourcesEvent(entry, time, duration, status));\n lastEndTime = time + duration;\n } else {\n if (includeNull) {\n eventList.add(new ResourcesEvent(entry, time, duration));\n }\n }\n }\n } else if (entry.getType().equals(Type.IRQ)) {\n List<ITmfStateInterval> irqIntervals = ssq.queryHistoryRange(quark, startTime, endTime - 1, resolution);\n eventList = new ArrayList<ITimeEvent>(irqIntervals.size());\n long lastEndTime = -1;\n boolean lastIsNull = true;\n for (ITmfStateInterval irqInterval : irqIntervals) {\n if (monitor.isCanceled()) {\n return null;\n }\n long time = irqInterval.getStartTime();\n long duration = irqInterval.getEndTime() - time + 1;\n if (!irqInterval.getStateValue().isNull()) {\n int cpu = irqInterval.getStateValue().unboxInt();\n eventList.add(new ResourcesEvent(entry, time, duration, cpu));\n lastIsNull = false;\n } else {\n if (lastEndTime != time && lastEndTime != -1 && lastIsNull) {\n eventList.add(new ResourcesEvent(entry, lastEndTime, time - lastEndTime, -1));\n }\n if (includeNull) {\n eventList.add(new ResourcesEvent(entry, time, duration));\n }\n lastIsNull = true;\n }\n lastEndTime = time + duration;\n }\n } else if (entry.getType().equals(Type.SOFT_IRQ)) {\n List<ITmfStateInterval> softIrqIntervals = ssq.queryHistoryRange(quark, startTime, endTime - 1, resolution);\n eventList = new ArrayList<ITimeEvent>(softIrqIntervals.size());\n long lastEndTime = -1;\n boolean lastIsNull = true;\n for (ITmfStateInterval softIrqInterval : softIrqIntervals) {\n if (monitor.isCanceled()) {\n return null;\n }\n long time = softIrqInterval.getStartTime();\n long duration = softIrqInterval.getEndTime() - time + 1;\n if (!softIrqInterval.getStateValue().isNull()) {\n int cpu = softIrqInterval.getStateValue().unboxInt();\n eventList.add(new ResourcesEvent(entry, time, duration, cpu));\n } else {\n if (lastEndTime != time && lastEndTime != -1 && lastIsNull) {\n eventList.add(new ResourcesEvent(entry, lastEndTime, time - lastEndTime, -1));\n }\n if (includeNull) {\n eventList.add(new ResourcesEvent(entry, time, duration));\n }\n lastIsNull = true;\n }\n lastEndTime = time + duration;\n }\n }\n } catch (AttributeNotFoundException e) {\n e.printStackTrace();\n } catch (TimeRangeException e) {\n e.printStackTrace();\n } catch (StateValueTypeException e) {\n e.printStackTrace();\n }\n return eventList;\n}\n"
"public void run() {\n titleText.setText(\"String_Node_Str\");\n contentText.setText(\"String_Node_Str\");\n try {\n assertEquals(\"String_Node_Str\", mFragment.getTitle());\n assertEquals(\"String_Node_Str\", mFragment.getContent());\n } catch (EditorFragmentNotAddedException e) {\n throw new RuntimeException();\n }\n htmlButton.performClick();\n uiThreadLatch2.countDown();\n}\n"
"protected void executeImpl(final Action action, final NodeRef actionedUponNodeRef) {\n if (nodeService.exists(actionedUponNodeRef) && freezeService.isFrozen(actionedUponNodeRef) == false && recordService.isFiled(actionedUponNodeRef) == false) {\n NodeRef recordFolder = (NodeRef) action.getParameterValue(PARAM_DESTINATION_RECORD_FOLDER);\n if (recordFolder == null) {\n recordFolder = createOrResolveRecordFolder(action, actionedUponNodeRef);\n }\n if (recordFolder == null) {\n throw new AlfrescoRuntimeException(\"String_Node_Str\");\n }\n if (recordFolderService.isRecordFolder(recordFolder)) {\n final NodeRef finalRecordFolder = recordFolder;\n AuthenticationUtil.runAsSystem(new RunAsWork<Void>() {\n\n public Void doWork() throws Exception {\n try {\n fileFolderService.move(actionedUponNodeRef, finalRecordFolder, null);\n } catch (FileNotFoundException fileNotFound) {\n throw new AlfrescoRuntimeException(\"String_Node_Str\", fileNotFound);\n }\n return null;\n }\n });\n } else {\n throw new AlfrescoRuntimeException(\"String_Node_Str\");\n }\n }\n }\n}\n"
"public boolean canBeBlocked(Permanent attacker, Permanent blocker, Ability source, Game game) {\n for (Permanent permanent : game.getBattlefield().getAllActivePermanents(filter, blocker.getControllerId(), game)) {\n if (permanent.isTapped() && !game.getState().getContinuousEffects().asThough(this.getId(), AsThoughEffectType.BLOCK_TAPPED, source, blocker.getControllerId(), game)) {\n return false;\n }\n for (Map.Entry<RestrictionEffect, HashSet<Ability>> entry : game.getContinuousEffects().getApplicableRestrictionEffects(permanent, game).entrySet()) {\n for (Ability ability : entry.getValue()) {\n if (!entry.getKey().canBlock(attacker, permanent, ability, game)) {\n return false;\n }\n }\n }\n for (Map.Entry<RestrictionEffect, HashSet<Ability>> restrictionEntry : game.getContinuousEffects().getApplicableRestrictionEffects(attacker, game).entrySet()) {\n for (Ability ability : restrictionEntry.getValue()) {\n if (!(restrictionEntry.getKey() instanceof CantBeBlockedUnlessAllEffect) && !restrictionEntry.getKey().canBeBlocked(attacker, permanent, ability, game)) {\n return false;\n }\n }\n }\n if (attacker.hasProtectionFrom(permanent, game)) {\n return false;\n }\n }\n return true;\n}\n"
"private boolean _isOpaque(CompositeEntity entity) {\n if (entity instanceof CompositeActor && ((CompositeActor) entity).isOpaque()) {\n return true;\n } else {\n NamedObj container = entity.getContainer();\n boolean isOpaque = false;\n while (container != null) {\n if (_match.containsValue(container)) {\n container = (NamedObj) _match.getKey(container);\n } else if (_temporaryMatch.containsValue(container)) {\n container = (NamedObj) _temporaryMatch.getKey(container);\n }\n if (!attributeList.isEmpty()) {\n HierarchyFlatteningAttribute attribute = (HierarchyFlatteningAttribute) attributeList.get(0);\n try {\n BooleanToken token = (BooleanToken) attribute.flatteningAttribute.getToken();\n isOpaque = !token.booleanValue();\n break;\n } catch (IllegalActionException e) {\n return false;\n }\n }\n container = container.getContainer();\n }\n return isOpaque;\n }\n}\n"
"public boolean equals(Object obj) {\n if (this.inetAddress != null) {\n return this.inetAddress.equals(ici.inetAddress);\n } else {\n return this.fileName.equals(obj);\n }\n}\n"
"private void callVisibleForUser(Call call, String type, String number, String callerId) {\n Intent intent = new Intent(this, CallActivity.class);\n intent.setFlags(Intent.FLAG_ACTIVITY_NEW_TASK);\n Uri sipAddressUri = SipUri.sipAddressUri(this, PhoneNumberUtils.format(number));\n intent.setDataAndType(sipAddressUri, type);\n intent.putExtra(CallActivity.CONTACT_NAME, callerId);\n intent.putExtra(CallActivity.PHONE_NUMBER, number);\n startActivity(intent);\n}\n"
"public void disablePlugin(Plugin plugin) {\n if (!plugin.isEnabled()) {\n boolean locked = manager.lock(key);\n try {\n plugin.getPluginLoader().disablePlugin(plugin);\n } catch (Exception e) {\n safelyLog(Level.SEVERE, new StringBuilder().append(\"String_Node_Str\").append(plugin.getDescription().getFullName()).append(\"String_Node_Str\").append(e.getMessage()).toString(), e);\n }\n if (!locked)\n manager.unlock(key);\n }\n}\n"
"public void processEvent(final AbstractEvent event) {\n if (event instanceof ByteBufferedChannelCloseEvent) {\n this.closeAcknowledgmentReceived = true;\n } else if (event instanceof ReceiverNotFoundEvent) {\n this.lastSequenceNumberWithReceiverNotFound = ((ReceiverNotFoundEvent) event).getSequenceNumber();\n } else if (event instanceof AbstractTaskEvent) {\n this.byteBufferedOutputChannel.processEvent(event);\n }\n getNext().processEvent(event);\n}\n"
"private void findAdvUserProperties(LdapContext ldapContext, boolean isOutputNeeded) throws Throwable {\n int noOfUsers;\n NamingEnumeration<SearchResult> userSearchResultEnum = null;\n SearchControls userSearchControls = new SearchControls();\n userSearchControls.setSearchScope(config.getUserSearchScope());\n if (userNameAttribute != null && !userNameAttribute.isEmpty()) {\n Set<String> userSearchAttributes = new HashSet<>();\n userSearchAttributes.add(userNameAttribute);\n userSearchAttributes.add(userGroupMemberName);\n userSearchAttributes.add(\"String_Node_Str\");\n userSearchControls.setReturningAttributes(userSearchAttributes.toArray(new String[userSearchAttributes.size()]));\n } else {\n userSearchControls.setReturningAttributes(new java.lang.String[] { \"String_Node_Str\", \"String_Node_Str\" });\n }\n String extendedUserSearchFilter = \"String_Node_Str\" + userObjClassName + \"String_Node_Str\";\n try {\n HashMap<String, Integer> ouOccurences = new HashMap<>();\n if (userSearchBase == null || userSearchBase.isEmpty()) {\n userSearchResultEnum = ldapContext.search(searchBase, extendedUserSearchFilter, userSearchControls);\n } else {\n userSearchResultEnum = ldapContext.search(userSearchBase, extendedUserSearchFilter, userSearchControls);\n }\n noOfUsers = 0;\n while (userSearchResultEnum.hasMore()) {\n if (noOfUsers >= 20) {\n break;\n }\n final SearchResult userEntry = userSearchResultEnum.next();\n if (userEntry == null) {\n logFile.println(\"String_Node_Str\");\n continue;\n }\n Attributes attributes = userEntry.getAttributes();\n if (attributes == null) {\n logFile.println(\"String_Node_Str\" + userEntry.getNameInNamespace());\n continue;\n }\n String dnValue;\n Attribute dnAttr = attributes.get(\"String_Node_Str\");\n if (dnAttr != null) {\n dnValue = dnAttr.get().toString();\n String ouStr = \"String_Node_Str\";\n int indexOfOU = dnValue.indexOf(ouStr);\n if (indexOfOU > 0) {\n dnValue = dnValue.substring(indexOfOU);\n } else {\n dnValue = dnValue.substring(dnValue.indexOf(\"String_Node_Str\") + 1);\n }\n } else {\n dnValue = userEntry.getNameInNamespace();\n dnValue = dnValue.substring(dnValue.indexOf(\"String_Node_Str\") + 1);\n }\n Integer ouOccrs = ouOccurences.get(dnValue);\n if (ouOccrs == null) {\n ouOccrs = Integer.valueOf(0);\n }\n int val = ouOccrs.intValue();\n ouOccrs = Integer.valueOf(++val);\n ouOccurences.put(dnValue, ouOccrs);\n noOfUsers++;\n }\n if (!ouOccurences.isEmpty()) {\n Set<String> keys = ouOccurences.keySet();\n int maxOUOccr = 0;\n for (String key : keys) {\n int ouOccurVal = ouOccurences.get(key).intValue();\n logFile.println(\"String_Node_Str\" + key + \"String_Node_Str\" + ouOccurVal);\n if (ouOccurVal > maxOUOccr) {\n maxOUOccr = ouOccurVal;\n userSearchBase = key;\n }\n }\n }\n userSearchFilter = userNameAttribute + \"String_Node_Str\";\n if (isOutputNeeded) {\n installProps.println(\"String_Node_Str\" + userSearchBase);\n installProps.println(\"String_Node_Str\" + userSearchFilter);\n ambariProps.println(\"String_Node_Str\" + userSearchBase);\n ambariProps.println(\"String_Node_Str\" + userSearchFilter);\n }\n } catch (NamingException ne) {\n String msg = \"String_Node_Str\" + \"String_Node_Str\" + \"String_Node_Str\";\n if ((config.getUserNameAttribute() != null && !config.getUserNameAttribute().isEmpty()) || (config.getUserObjectClass() != null && !config.getUserObjectClass().isEmpty()) || (config.getGroupNameAttribute() != null && !config.getGroupNameAttribute().isEmpty())) {\n throw new Exception(\"String_Node_Str\" + \"String_Node_Str\" + \"String_Node_Str\");\n } else {\n throw new Exception(msg + ne);\n }\n } finally {\n if (userSearchResultEnum != null) {\n userSearchResultEnum.close();\n }\n }\n}\n"
"public Image getNodeIcon(Object model) {\n if (model instanceof DesignElementHandle && ((DesignElementHandle) model).getSemanticErrors().size() > 0) {\n return ReportPlatformUIImages.getImage(ISharedImages.IMG_OBJS_ERROR_TSK);\n }\n if (model instanceof DesignElementHandle && DEUtil.isLinkedElement((DesignElementHandle) model))\n return CrosstabUIHelper.getImage(CrosstabUIHelper.CROSSTAB_LINK_IMAGE);\n return CrosstabUIHelper.getImage(CrosstabUIHelper.CROSSTAB_IMAGE);\n}\n"
"public static void main(String[] args) throws InterruptedException {\n RedisLockTest redisLockTest = new RedisLockTest();\n redisLockTest.init();\n initThread();\n for (int i = 0; i < 50; i++) {\n executorServicePool.execute(new Worker(i));\n }\n executorServicePool.shutdown();\n while (!executorServicePool.awaitTermination(1, TimeUnit.SECONDS)) {\n logger.info(\"String_Node_Str\");\n }\n logger.info(\"String_Node_Str\");\n}\n"
"public void setScale(Vector2 scale) {\n scale(scale.x / scaleX, scale.y / scaleY);\n}\n"
"private void setNavHeadView(SongEntity songEntity) {\n if (songEntity == null || isDestroyed()) {\n return;\n }\n mNavTitle.setText(songEntity.title);\n mNavSinger.setText(songEntity.artistName);\n ImageLoader.getInstance().display(MainActivity.this, new ImageConfig.Builder().url(songEntity.albumCover).isRound(false).placeholder(R.drawable.ic_default).into(mImgNavHeadBg).build());\n mImgNavHeadBg.setColorFilter(ContextCompat.getColor(MainActivity.this, R.color.colorDarkerTransparent), PorterDuff.Mode.SRC_OVER);\n}\n"
"private boolean upgradeSixSeven(SQLiteDatabase db, int oldVersion, int newVersion) {\n db.beginTransaction();\n try {\n SqlStorage<ACase> caseStorage = new SqlStorage<ACase>(ACase.STORAGE_KEY, ACasePreV6Model.class, new ConcreteDbHelper(c, db));\n updateModels(caseStorage);\n db.setTransactionSuccessful();\n return true;\n } finally {\n db.endTransaction();\n }\n}\n"
"public XaConnection getXaConnection() {\n return new NeoStoreXaConnection(neoStore, xaContainer.getResourceManager(), branchId);\n}\n"
"public int convertRowIndexToModel(int index) {\n if (viewToModel != null && index >= 0 && index < viewToModel.length) {\n if (isSorted()) {\n return viewToModel[index];\n } else {\n return index;\n }\n } else {\n return index;\n }\n}\n"
"private void updateStatus(int state) {\n switch(state) {\n case State.PULL_NORMAL:\n pullDownReset();\n break;\n case State.PULL_DOWN:\n if (mHeaderWrapper != null) {\n mHeaderWrapper.pullDown();\n }\n break;\n case State.PULL_DOWN_RELEASABLE:\n if (mHeaderView != null) {\n mHeaderView.pullDownReleasable();\n }\n break;\n case State.PULL_DOWN_RELEASE:\n if (mHeaderView != null) {\n mHeaderView.pullDownRelease();\n }\n if (mRefreshListener != null) {\n mRefreshListener.onRefresh();\n }\n showNoMore(false);\n setEnable(false);\n break;\n case State.PULL_DOWN_RESET:\n pullDownReset();\n break;\n case State.PULL_UP_RESET:\n pullUpReset();\n break;\n case State.PULL_UP:\n if (mFooterView != null) {\n mFooterView.pullUp();\n }\n break;\n case State.PULL_UP_RELEASABLE:\n if (mFooterView != null) {\n mFooterView.pullUpReleasable();\n }\n break;\n case State.PULL_UP_RELEASE:\n if (mFooterView != null) {\n mFooterView.pullUpRelease();\n }\n if (mRefreshListener != null) {\n mRefreshListener.onLoadMore();\n }\n setEnable(false);\n break;\n case State.PULL_UP_FINISH:\n if (mFooterView != null) {\n mFooterView.pullUpFinish();\n }\n break;\n case State.BOTTOM:\n if (mBottomView != null) {\n mBottomView.showBottom();\n }\n break;\n }\n currentState = state;\n}\n"
"public void drawArmor() {\n GL11.glDisable(GL11.GL_DEPTH_TEST);\n res = new ScaledResolution(Minecraft.getMinecraft(), Minecraft.getMinecraft().displayWidth, Minecraft.getMinecraft().displayHeight);\n int x = (res.getScaledWidth() / 2) - 11;\n int y = res.getScaledHeight() - 49;\n Item boots = null;\n Item body = null;\n Item legs = null;\n Item helmet = null;\n ItemStack stackBoots = Minecraft.getMinecraft().thePlayer.inventory.armorItemInSlot(0);\n ItemStack stackLegs = Minecraft.getMinecraft().thePlayer.inventory.armorItemInSlot(1);\n ItemStack stackBody = Minecraft.getMinecraft().thePlayer.inventory.armorItemInSlot(2);\n ItemStack stackHelmet = Minecraft.getMinecraft().thePlayer.inventory.armorItemInSlot(3);\n float speedMultiplier = 1;\n if (stackBoots != null)\n boots = stackBoots.getItem();\n else\n boots = null;\n if (stackBody != null)\n body = stackBody.getItem();\n else\n body = null;\n if (stackLegs != null)\n legs = stackLegs.getItem();\n else\n legs = null;\n if (stackHelmet != null)\n helmet = stackHelmet.getItem();\n else\n helmet = null;\n int size = 0;\n if (boots == TwilightItemsArmor.haliteBoots && legs == TwilightItemsArmor.haliteLeggings && body == TwilightItemsArmor.haliteChestplate && helmet == TwilightItemsArmor.haliteHelmet)\n size = 1;\n switch(size) {\n case 1:\n Minecraft.getMinecraft().getTextureManager().bindTexture(r);\n Util.drawTexturedModalRect(x, y, 0, 0, 9, 9);\n break;\n case 2:\n Minecraft.getMinecraft().getTextureManager().bindTexture(r);\n Util.drawTexturedModalRect(x, y, 9, 0, 18, 9);\n break;\n }\n}\n"
"protected void PicardPreprocess(Context context, PreprocessingTools tools, SAMRecordIterator input, String output) throws InterruptedException, QualityException, IOException, URISyntaxException {\n outHeader = header.clone();\n outHeader.setSortOrder(SAMFileHeader.SortOrder.coordinate);\n String tmpOut1 = tmpFileBase + \"String_Node_Str\";\n String tmpOut2 = tmpFileBase + \"String_Node_Str\";\n String tmpOut3 = tmpFileBase + \"String_Node_Str\";\n String fCounts = tmpFileBase + \"String_Node_Str\";\n String tmpMetrics = tmpFileBase + \"String_Node_Str\";\n SAMFileWriterFactory factory = new SAMFileWriterFactory();\n if (!inputIsBam)\n outHeader.addReadGroup(bamrg);\n SAMFileWriter writer = factory.makeBAMWriter(outHeader, true, new File(tmpOut1));\n long startTime = System.currentTimeMillis();\n int count = 0;\n SAMRecord sam;\n while (input.hasNext()) {\n sam = input.next();\n writer.addAlignment(sam);\n count++;\n }\n int reads = input.getCount();\n writer.close();\n context.getCounter(HalvadeCounters.IN_PREP_READS).increment(reads);\n long estimatedTime = System.currentTimeMillis() - startTime;\n context.getCounter(HalvadeCounters.TIME_HADOOP_SAMTOBAM).increment(estimatedTime);\n Logger.DEBUG(\"String_Node_Str\" + count + \"String_Node_Str\" + estimatedTime / 1000);\n Logger.DEBUG(\"String_Node_Str\");\n context.setStatus(\"String_Node_Str\");\n tools.runCleanSam(tmpOut1, tmpOut2);\n Logger.DEBUG(\"String_Node_Str\");\n context.setStatus(\"String_Node_Str\");\n tools.runMarkDuplicates(tmpOut2, tmpOut3, tmpMetrics);\n if (gff != null) {\n Logger.DEBUG(\"String_Node_Str\");\n context.setStatus(\"String_Node_Str\");\n tools.runFeatureCounts(gff, tmpOut3, fCounts);\n HalvadeFileUtils.uploadFileToHDFS(context, FileSystem.get(new URI(outputdir), context.getConfiguration()), fCounts, outputdir + context.getTaskAttemptID().toString() + \"String_Node_Str\");\n HalvadeFileUtils.uploadFileToHDFS(context, null, ref, tmp);\n }\n if (!inputIsBam) {\n Logger.DEBUG(\"String_Node_Str\");\n context.setStatus(\"String_Node_Str\");\n tools.runAddOrReplaceReadGroups(tmpOut3, output, RGID, RGLB, RGPL, RGPU, RGSM);\n }\n Logger.DEBUG(\"String_Node_Str\");\n context.setStatus(\"String_Node_Str\");\n tools.runBuildBamIndex(output);\n estimatedTime = System.currentTimeMillis() - startTime;\n Logger.DEBUG(\"String_Node_Str\" + estimatedTime / 1000);\n HalvadeFileUtils.removeLocalFile(keep, tmpMetrics, context, HalvadeCounters.FOUT_GATK_TMP);\n HalvadeFileUtils.removeLocalFile(keep, tmpOut1, context, HalvadeCounters.FOUT_GATK_TMP);\n HalvadeFileUtils.removeLocalFile(keep, tmpOut2, context, HalvadeCounters.FOUT_GATK_TMP);\n HalvadeFileUtils.removeLocalFile(keep, tmpOut3, context, HalvadeCounters.FOUT_GATK_TMP);\n HalvadeFileUtils.removeLocalFile(keep, fCounts);\n}\n"
"public Calendar timestamp(ReferenceTick reference) {\n final double TICK_TIME_STEP = (48 / 32768.0) * 1000;\n Calendar copy = (Calendar) reference.timestamp().clone();\n copy.add(Calendar.MILLISECOND, (int) ((tick() - reference.tickCount()) * TICK_TIME_STEP));\n return copy;\n}\n"
"public ByteWriter toByteWriter(ByteWriter writer) {\n writer.putSha256Hash(txid);\n writer.putCompactInt(index);\n return writer;\n}\n"
"private byte[] readFully(final InputStream stream) {\n try {\n int totalLength = 0;\n byte[] buffer = getOrCreateBuffer();\n int read;\n while ((read = stream.read(buffer, totalLength, totalLength - buffer.length)) != -1) {\n totalLength += read;\n if (totalLength >= buffer.length - 1) {\n byte[] newBuffer = new byte[buffer.length + BUFFER_SIZE];\n System.arraycopy(buffer, 0, newBuffer, 0, buffer.length);\n buffer = newBuffer;\n }\n }\n final byte[] result = new byte[totalLength];\n System.arraycopy(buffer, 0, result, 0, totalLength);\n return result;\n } catch (Throwable t) {\n LogWrapper.log(Level.WARNING, t, \"String_Node_Str\");\n return new byte[0];\n }\n}\n"
"private void getFacebookFriendsList() {\n Request.newMyFriendsRequest(Session.getActiveSession(), new Request.GraphUserListCallback() {\n\n public void onCompleted(List<com.facebook.model.GraphUser> users, Response response) {\n for (com.facebook.model.GraphUser user : users) {\n friendsFacebookList.add(new InviteFriend(user.getId(), user.getName(), user.getLink(), InviteFriend.VIA_FACEBOOK_TYPE, null, false));\n }\n fiendsReceived();\n }\n });\n}\n"
"private void runAsync(Runnable test) {\n Thread t = new Thread(test);\n t.start();\n try {\n t.join(50);\n } catch (InterruptedException e) {\n }\n if (t.isAlive()) {\n t.stop();\n throw new RuntimeException(\"String_Node_Str\" + label);\n }\n}\n"
"public String decode(Event e, String s) {\n if (e.equals(Event.MESSAGE) && !protocolReceived.getAndSet(true)) {\n try {\n String[] proto = new String(b, \"String_Node_Str\").trim().split(\"String_Node_Str\");\n List<String> l = new ArrayList<String>();\n l.add(proto[0]);\n queryString.put(\"String_Node_Str\", l);\n l = new ArrayList<String>();\n l.add(proto[1]);\n queryString.put(\"String_Node_Str\", l);\n s = null;\n } catch (Exception ex) {\n logger.warn(\"String_Node_Str\", s);\n logger.warn(\"String_Node_Str\", e);\n }\n }\n return s;\n}\n"
"public boolean onPreferenceClick(Preference preference) {\n Favorite fav = new Favorite();\n fav.setUserName(AccountHelper.getSelectedAccount(getActivity()));\n fav.setModelKey(\"String_Node_Str\");\n fav.setModelEnum(ModelHelper.MODELS.TEAM.getEnum());\n Database.getInstance(DevSettingsActivity.this).getFavoritesTable().add(fav);\n return true;\n}\n"
"public static String className(String s, boolean flag, boolean isClass, boolean logOn) {\n preProcessJavaReservedNames(s);\n preProcessSDOReservedNames(s);\n String[] as = getWordList(s);\n StringBuffer stringbuffer = new StringBuffer();\n StringBuffer stringbuffer1 = new StringBuffer();\n if (as.length == 0) {\n return stringbuffer.toString();\n }\n for (int i = 0; i < as.length; i++) {\n char[] ac = as[i].toCharArray();\n if (Character.isLowerCase(ac[0])) {\n ac[0] = Character.toUpperCase(ac[0]);\n }\n for (int j = 0; j < ac.length; j++) {\n if ((ac[j] >= ' ') && (ac[j] < '\\177')) {\n if ((ac[j] != '_') || !asWordSeparator) {\n stringbuffer.append(ac[j]);\n }\n continue;\n }\n if (flag) {\n stringbuffer.append(escapeUnicode(stringbuffer1, ac[j]));\n } else {\n stringbuffer.append(ac[j]);\n }\n }\n }\n String normalizedName = stringbuffer.toString();\n if (!s.equals(normalizedName) && logOn) {\n int logLevel;\n if (!s.equalsIgnoreCase(normalizedName)) {\n logLevel = AbstractSessionLog.INFO;\n } else {\n logLevel = AbstractSessionLog.FINER;\n }\n if (isClass) {\n AbstractSessionLog.getLog().log(logLevel, \"String_Node_Str\", new Object[] { \"String_Node_Str\", s, normalizedName });\n } else {\n AbstractSessionLog.getLog().log(logLevel, \"String_Node_Str\", new Object[] { \"String_Node_Str\", s, normalizedName });\n }\n }\n return normalizedName;\n}\n"
"private InstanceInitializationFactory createIIF() {\n return new MockupProviderFactory(mockup == null ? new Hashtable() : mockup.getInstances());\n}\n"
"private int[] _getTokenConsumptionRate(IOPort port) throws IllegalActionException {\n int[] rate = new int[port.getWidth()];\n Arrays.fill(rate, 1);\n Variable parameter = SDFUtilities.getRateVariable(port, \"String_Node_Str\");\n if (parameter != null) {\n Token token = parameter.getToken();\n if (token instanceof ArrayToken) {\n Token[] tokens = ((ArrayToken) token).arrayValue();\n if (tokens.length < port.getWidth())\n throw new IllegalActionException(this, \"String_Node_Str\" + \"String_Node_Str\" + \"String_Node_Str\");\n for (int i = 0; i < port.getWidth(); i++) rate[i] = ((IntToken) tokens[i]).intValue();\n } else {\n Arrays.fill(rate, ((IntToken) token).intValue());\n }\n }\n return rate;\n}\n"
"private synchronized LinkedBlockingQueue<IAtomContainer> multiSolution() {\n LinkedBlockingQueue<IAtomContainer> mcss = new LinkedBlockingQueue<>();\n logger.debug(\"String_Node_Str\" + taskNumber + \"String_Node_Str\" + mcssList.size() + \"String_Node_Str\");\n long startTime = Calendar.getInstance().getTimeInMillis();\n IAtomContainer querySeed = mcssList.get(0);\n long calcTime = startTime;\n ConcurrentLinkedQueue<IAtomContainer> seeds = new ConcurrentLinkedQueue<>();\n try {\n Set<Fragment> localSeeds = new TreeSet<>();\n int minSeedSize = querySeed.getAtomCount();\n for (int index = 1; index < mcssList.size(); index++) {\n IAtomContainer target = mcssList.get(index);\n Collection<Fragment> fragmentsFromMCS;\n BaseMapping comparison;\n comparison = new Isomorphism(querySeed, target, Algorithm.DEFAULT, matchBonds, matchRings, matchAtomType);\n comparison.setChemFilters(true, true, true);\n fragmentsFromMCS = getMCSS(comparison);\n logger.debug(\"String_Node_Str\" + taskNumber + \"String_Node_Str\" + fragmentsFromMCS.size() + \"String_Node_Str\" + comparison.getFirstAtomMapping().getCount());\n logger.debug(\"String_Node_Str\" + taskNumber + \"String_Node_Str\" + querySeed.getAtomCount() + \"String_Node_Str\" + querySeed.getBondCount() + \"String_Node_Str\");\n logger.debug(\"String_Node_Str\" + taskNumber + \"String_Node_Str\" + target.getAtomCount() + \"String_Node_Str\" + target.getBondCount() + \"String_Node_Str\");\n long endCalcTime = Calendar.getInstance().getTimeInMillis();\n logger.debug(\"String_Node_Str\" + taskNumber + \"String_Node_Str\" + index + \"String_Node_Str\" + (endCalcTime - calcTime) + \"String_Node_Str\");\n calcTime = endCalcTime;\n if (fragmentsFromMCS.isEmpty()) {\n localSeeds.clear();\n break;\n }\n Iterator<Fragment> iterator = fragmentsFromMCS.iterator();\n while (iterator.hasNext()) {\n Fragment fragment = iterator.next();\n if (minSeedSize > fragment.getContainer().getAtomCount()) {\n localSeeds.clear();\n minSeedSize = fragment.getContainer().getAtomCount();\n }\n if (minSeedSize == fragment.getContainer().getAtomCount()) {\n localSeeds.add(fragment);\n }\n }\n }\n if (!localSeeds.isEmpty()) {\n for (Fragment f : localSeeds) {\n seeds.add(f.getContainer());\n }\n localSeeds.clear();\n }\n logger.debug(\"String_Node_Str\" + seeds.size());\n minSeedSize = Integer.MAX_VALUE;\n while (!seeds.isEmpty()) {\n IAtomContainer fragmentMCS = seeds.poll();\n localSeeds = new TreeSet<>();\n logger.debug(\"String_Node_Str\" + getMCSSSmiles(fragmentMCS));\n Collection<Fragment> fragmentsFromMCS;\n for (IAtomContainer target : mcssList) {\n Isomorphism comparison = new Isomorphism(fragmentMCS, target, Algorithm.DEFAULT, matchBonds, matchRings, matchAtomType);\n comparison.setChemFilters(true, true, true);\n fragmentsFromMCS = getMCSS(comparison);\n if (fragmentsFromMCS == null || fragmentsFromMCS.isEmpty()) {\n localSeeds.clear();\n break;\n }\n Iterator<Fragment> iterator = fragmentsFromMCS.iterator();\n while (iterator.hasNext()) {\n Fragment fragment = iterator.next();\n if (minSeedSize > fragment.getContainer().getAtomCount()) {\n localSeeds.clear();\n minSeedSize = fragment.getContainer().getAtomCount();\n }\n if (minSeedSize == fragment.getContainer().getAtomCount()) {\n localSeeds.add(fragment);\n }\n }\n fragmentMCS = localSeeds.iterator().next().getContainer();\n }\n if (!localSeeds.isEmpty()) {\n for (Fragment f : localSeeds) {\n mcss.add(f.getContainer());\n }\n localSeeds.clear();\n }\n }\n } catch (CDKException e) {\n logger.error(\"String_Node_Str\", e);\n }\n long endTime = Calendar.getInstance().getTimeInMillis();\n logger.debug(\"String_Node_Str\" + taskNumber + \"String_Node_Str\" + (endTime - startTime) + \"String_Node_Str\");\n logger.debug(\"String_Node_Str\" + querySeed.getAtomCount() + \"String_Node_Str\" + querySeed.getBondCount() + \"String_Node_Str\");\n return mcss;\n}\n"
"public Function getDefaultFunction(MetadataColumnExt bean, String talendType) {\n Function currentFun = new Function();\n List<Function> functions = getFunctionByName(talendType);\n String[] arrayTalendFunctions2 = new String[functions.size()];\n List<String> list = new ArrayList<String>();\n if (functions.isEmpty()) {\n currentFun.setDescription(\"String_Node_Str\");\n currentFun.setPreview(\"String_Node_Str\");\n currentFun.setParameters(new ArrayList<Parameter>());\n bean.setArrayFunctions(arrayTalendFunctions2);\n } else {\n for (int i = 0; i < functions.size(); i++) {\n String name = functions.get(i).getName();\n String className = functions.get(i).getClassName();\n if (className == null) {\n arrayTalendFunctions2[i] = name;\n } else {\n arrayTalendFunctions2[i] = className + \"String_Node_Str\" + name;\n }\n }\n Arrays.sort(arrayTalendFunctions2, new Comparator<String>() {\n public int compare(String n1, String n2) {\n return n1.compareTo(n2);\n }\n });\n currentFun = (Function) functions.get(0).clone();\n bean.setArrayFunctions(arrayTalendFunctions2);\n }\n for (Function fun : functions) {\n if (fun.getName().equals(DEFAULT_SELECTED_METHOD)) {\n currentFun = (Function) fun.clone();\n break;\n }\n }\n return currentFun;\n}\n"
"public void setTarget(String version) {\n options.target = SpecVersion.parse(version);\n if (options.target == null)\n throw new BuildException(version + \"String_Node_Str\");\n}\n"
"private static void setFileExcelValue(FileExcelConnection connection, INode node, String repositoryValue) {\n if (\"String_Node_Str\".equals(repositoryValue)) {\n String value = getParameterValue(connection, node, \"String_Node_Str\");\n if (value != null) {\n connection.setFilePath(value);\n }\n }\n if (\"String_Node_Str\".equals(param.getRepositoryValue())) {\n String value = getParameterValue(connection, node, param);\n if (value != null) {\n connection.setSelectAllSheets(Boolean.valueOf(value).booleanValue());\n }\n }\n if (\"String_Node_Str\".equals(repositoryValue)) {\n String value = getParameterValue(connection, node, \"String_Node_Str\");\n if (value != null) {\n connection.setAdvancedSpearator(Boolean.valueOf(value).booleanValue());\n }\n }\n if (\"String_Node_Str\".equals(repositoryValue)) {\n String value = getParameterValue(connection, node, \"String_Node_Str\");\n if (value != null) {\n connection.setHeaderValue(value);\n }\n }\n if (\"String_Node_Str\".equals(repositoryValue)) {\n String value = getParameterValue(connection, node, \"String_Node_Str\");\n if (value != null) {\n connection.setFooterValue(value);\n }\n }\n if (\"String_Node_Str\".equals(repositoryValue)) {\n String value = getParameterValue(connection, node, \"String_Node_Str\");\n if (value != null) {\n connection.setLimitValue(value);\n }\n }\n if (\"String_Node_Str\".equals(repositoryValue)) {\n String value = getParameterValue(connection, node, \"String_Node_Str\");\n if (value != null) {\n connection.setFirstColumn(value);\n }\n }\n if (\"String_Node_Str\".equals(repositoryValue)) {\n String value = getParameterValue(connection, node, \"String_Node_Str\");\n if (value != null) {\n connection.setLastColumn(value);\n }\n }\n if (\"String_Node_Str\".equals(repositoryValue)) {\n String value = getParameterValue(connection, node, \"String_Node_Str\");\n if (value != null) {\n connection.setThousandSeparator(value);\n }\n }\n if (\"String_Node_Str\".equals(repositoryValue)) {\n String value = getParameterValue(connection, node, \"String_Node_Str\");\n if (value != null) {\n connection.setDecimalSeparator(value);\n }\n }\n if (\"String_Node_Str\".equals(repositoryValue)) {\n String value = getParameterValue(connection, node, \"String_Node_Str\");\n if (value != null) {\n connection.setEncoding(value);\n }\n }\n}\n"
"public String toString() {\n return \"String_Node_Str\" + delegate;\n}\n"
"private void processSm(ProcessingData processingData) {\n CommandApdu commandApdu = processingData.getCommandApdu();\n byte cla = commandApdu.getCla();\n if ((cla & 0x03) != 0x03) {\n if (pseudoSmIsActive) {\n if (!(commandApdu instanceof IsoSecureMessagingCommandApdu) || !((IsoSecureMessagingCommandApdu) commandApdu).wasSecureMessaging()) {\n log(this, \"String_Node_Str\");\n pseudoSmIsActive = false;\n processingData.addUpdatePropagation(this, \"String_Node_Str\", new ProtocolUpdate(true));\n }\n }\n }\n if (!pseudoSmIsActive) {\n return;\n }\n SmMarkerApdu smMarkerApdu = new SmMarkerApdu(commandApdu);\n processingData.updateCommandApdu(this, \"String_Node_Str\", smMarkerApdu);\n byte[] apduBytes = commandApdu.toByteArray();\n apduBytes[0] &= (byte) 0xFC;\n processingData.updateCommandApdu(this, \"String_Node_Str\", CommandApduFactory.createCommandApdu(apduBytes, smMarkerApdu));\n}\n"
"public void addSeriesDefinitions(EList elSD, GroupingLookupHelper lhmLookup) throws ChartException {\n for (int k = 0; k < elSD.size(); k++) {\n SeriesDefinition sdOrthogonal = (SeriesDefinition) elSD.get(k);\n Series series = sdOrthogonal.getDesignTimeSeries();\n List qlist = ChartEngine.instance().getDataSetProcessor(series.getClass()).getDataDefinitionsForGrouping(series);\n String strOrtAgg = lhmLookup.getOrthogonalAggregationExpression(sdOrthogonal);\n if (strOrtAgg != null) {\n addAggregation(strOrtAgg, slist);\n } else {\n baseQueryList.addAll(qlist);\n }\n }\n}\n"
"public IValue checkArguments(MarkerList markers, ICodePosition position, IContext context, IValue instance, IArguments arguments, ITypeContext typeContext) {\n int len = arguments.size();\n if (this.modifiers.hasIntModifier(Modifiers.PREFIX) && !this.isStatic()) {\n IValue argument = arguments.getFirstValue();\n arguments.setFirstValue(receiver);\n receiver = argument;\n }\n if (instance != null) {\n int mod = this.modifiers.toFlags() & Modifiers.INFIX;\n if (mod == Modifiers.INFIX && instance.valueTag() != IValue.CLASS_ACCESS) {\n IParameter par = this.parameters[0];\n IValue instance1 = IType.convertValue(instance, par.getType(), typeContext, markers, context);\n if (instance1 == null) {\n Util.createTypeError(markers, instance, par.getType(), typeContext, \"String_Node_Str\", par.getName());\n } else {\n instance = instance1;\n }\n if (this.isVarargs()) {\n arguments.checkVarargsValue(this.parameterCount - 2, this.parameters[this.parameterCount - 1], typeContext, markers, context);\n for (int i = 0; i < this.parameterCount - 2; i++) {\n arguments.checkValue(i, this.parameters[i + 1], typeContext, markers, context);\n }\n this.checkTypeVarsInferred(markers, position, typeContext);\n return instance;\n }\n for (int i = 0; i < this.parameterCount - 1; i++) {\n arguments.checkValue(i, this.parameters[i + 1], typeContext, markers, context);\n }\n this.checkTypeVarsInferred(markers, position, typeContext);\n return instance;\n }\n if ((mod & Modifiers.STATIC) != 0) {\n if (instance.valueTag() != IValue.CLASS_ACCESS) {\n markers.add(Markers.semantic(position, \"String_Node_Str\", this.name));\n } else if (instance.getType().getTheClass() != this.theClass) {\n markers.add(Markers.semantic(position, \"String_Node_Str\", this.name, this.theClass.getFullName()));\n }\n instance = null;\n } else if (instance.valueTag() == IValue.CLASS_ACCESS) {\n if (!instance.getType().getTheClass().isObject()) {\n markers.add(Markers.semantic(position, \"String_Node_Str\", this.name));\n }\n } else {\n IValue instance1 = IType.convertValue(instance, this.receiverType, typeContext, markers, context);\n if (instance1 == null) {\n Util.createTypeError(markers, instance, this.receiverType, typeContext, \"String_Node_Str\", this.name);\n } else {\n instance = instance1;\n }\n }\n } else if (!this.modifiers.hasIntModifier(Modifiers.STATIC)) {\n if (context.isStatic()) {\n markers.add(Markers.semantic(position, \"String_Node_Str\", this.name));\n } else {\n markers.add(Markers.semantic(position, \"String_Node_Str\", this.name.unqualified));\n instance = new ThisExpr(position, this.theClass.getType(), context, markers);\n }\n }\n if (this.isVarargs()) {\n len = this.parameterCount - 1;\n arguments.checkVarargsValue(len, this.parameters[len], typeContext, markers, null);\n for (int i = 0; i < len; i++) {\n arguments.checkValue(i, this.parameters[i], typeContext, markers, context);\n }\n this.checkTypeVarsInferred(markers, position, typeContext);\n return instance;\n }\n for (int i = 0; i < this.parameterCount; i++) {\n arguments.checkValue(i, this.parameters[i], typeContext, markers, context);\n }\n this.checkTypeVarsInferred(markers, position, typeContext);\n return instance;\n}\n"
"private void initializeValues() {\n for (String bundleKey : feedbackResultBundles.keySet()) {\n FeedbackSessionResultsBundle bundle = feedbackResultBundles.get(bundleKey);\n Map<FeedbackQuestionAttributes, List<FeedbackResponseAttributes>> responseEntriesMap = bundle.getQuestionResponseMap();\n for (FeedbackQuestionAttributes attributeKey : responseEntriesMap.keySet()) {\n List<FeedbackResponseAttributes> responseEntries = responseEntriesMap.get(attributeKey);\n FeedbackQuestionAttributes question = bundle.questions.get(attributeKey.getId());\n FeedbackQuestionDetails questionDetails = question.getQuestionDetails();\n for (FeedbackResponseAttributes responseEntry : responseEntries) {\n String giverEmail = responseEntry.giverEmail;\n String giverName = bundle.emailNameTable.get(giverEmail);\n String giverTeamName = bundle.emailTeamNameTable.get(giverEmail);\n String recipientEmail = responseEntry.recipientEmail;\n String recipientName = bundle.emailNameTable.get(recipientEmail);\n String recipientTeamName = bundle.emailTeamNameTable.get(recipientEmail);\n String appendedGiverName = bundle.appendTeamNameToName(giverName, giverTeamName);\n String appendedRecipientName = bundle.appendTeamNameToName(recipientName, recipientTeamName);\n giverNames.put(giverEmail, appendedGiverName);\n recipientNames.put(recipientEmail, appendedRecipientName);\n String responseEntryAnswerHtml = responseEntry.getResponseDetails().getAnswerHtml(questionDetails);\n responseEntryAnswerHtmls.put(questionDetails, responseEntryAnswerHtml);\n if (currentInstructor == null || !currentInstructor.isAllowedForPrivilege(responseEntry.giverSection, responseEntry.feedbackSessionName, Const.ParamsNames.INSTRUCTOR_PERMISSION_SUBMIT_SESSION_IN_SECTIONS) || !currentInstructor.isAllowedForPrivilege(responseEntry.recipientSection, responseEntry.feedbackSessionName, Const.ParamsNames.INSTRUCTOR_PERMISSION_SUBMIT_SESSION_IN_SECTIONS)) {\n instructorAllowedToSubmit = false;\n } else {\n instructorAllowedToSubmit = true;\n }\n }\n }\n }\n}\n"
"public LinkedHashSet<VariableDeclaration> getRecursivelyDefinedFields(MethodDeclaration method, Set<MethodDeclaration> processedMethods) {\n LinkedHashSet<VariableDeclaration> definedFields = new LinkedHashSet<VariableDeclaration>();\n definedFields.addAll(definedFieldMap.get(method));\n processedMethods.add(method);\n LinkedHashSet<MethodDeclaration> invokedMethods = methodInvocationMap.get(method);\n if (invokedMethods != null) {\n for (MethodDeclaration invokedMethod : invokedMethods) {\n if (!processedMethods.contains(invokedMethod)) {\n if (invokedMethod.getBody() != null) {\n if ((invokedMethod.getModifiers() & Modifier.NATIVE) != 0) {\n } else {\n definedFields.addAll(getRecursivelyDefinedFields(invokedMethod, processedMethods));\n }\n } else {\n LinkedHashSet<MethodDeclaration> overridingMethods = overridingMethodMap.get(invokedMethod);\n processedMethods.add(invokedMethod);\n if (overridingMethods != null) {\n for (MethodDeclaration overridingMethod : overridingMethods) {\n if ((overridingMethod.getModifiers() & Modifier.NATIVE) != 0) {\n } else {\n definedFields.addAll(getRecursivelyDefinedFields(overridingMethod, processedMethods));\n }\n }\n }\n }\n }\n }\n }\n return definedFields;\n}\n"
"public LinkObjectType getEdge() {\n return this.edge;\n}\n"
"public boolean isInventoryDisabled() {\n if (Main.game.getCurrentDialogueNode().getDialogueNodeType() == DialogueNodeType.INVENTORY || Main.game.isInCombat() || Main.game.isInSex()) {\n return false;\n } else if (Main.game.getCurrentDialogueNode().getDialgoueNodeType() == DialogueNodeType.OPTIONS || Main.game.getCurrentDialogueNode().getDialgoueNodeType() == DialogueNodeType.PHONE) {\n return Main.game.getSavedDialogueNode().isInventoryDisabled();\n } else {\n return Main.game.getCurrentDialogueNode().isInventoryDisabled();\n }\n}\n"
"private int _countUnfulfilledInputs(Actor a, LinkedList actorList, Map waitingTokens) throws IllegalActionException {\n if (_debugging)\n _debug(\"String_Node_Str\" + ((Entity) a).getFullName());\n Iterator ainputPorts = a.inputPortList().iterator();\n int inputCount = 0;\n while (ainputPorts.hasNext()) {\n IOPort ainputPort = (IOPort) ainputPorts.next();\n if (_debugging)\n _debug(\"String_Node_Str\" + ainputPort.getFullName());\n Iterator cports = ainputPort.deepConnectedOutPortList().iterator();\n boolean isOnlyExternalPort = true;\n while (cports.hasNext()) {\n IOPort cport = (IOPort) cports.next();\n if (actorList.contains(cport.getContainer()))\n isOnlyExternalPort = false;\n }\n int threshold = getTokenConsumptionRate(ainputPort);\n if (_debugging)\n _debug(\"String_Node_Str\" + threshold);\n int[] tokens = (int[]) waitingTokens.get(ainputPort);\n boolean isFulfilled = true;\n int channel;\n for (channel = 0; channel < ainputPort.getWidth(); channel++) {\n if (_debugging) {\n _debug(\"String_Node_Str\" + channel);\n _debug(\"String_Node_Str\" + tokens[channel]);\n }\n if (tokens[channel] < threshold)\n isAlreadyFulfilled = false;\n }\n if (!isOnlyExternalPort && !isAlreadyFulfilled)\n inputCount++;\n }\n return inputCount;\n}\n"
"protected boolean create(final AndroidSDK sdk) throws IOException {\n final String[] params = { sdk.getAndroidToolPath(), \"String_Node_Str\", \"String_Node_Str\", \"String_Node_Str\", name, \"String_Node_Str\", target, \"String_Node_Str\", DEFAULT_SDCARD_SIZE, \"String_Node_Str\", DEFAULT_SKIN, \"String_Node_Str\", \"String_Node_Str\" };\n avdList = null;\n final ProcessHelper p = new ProcessHelper(params);\n try {\n final ProcessResult createAvdResult = p.execute(\"String_Node_Str\");\n if (createAvdResult.succeeded()) {\n return true;\n }\n if (createAvdResult.toString().contains(\"String_Node_Str\")) {\n Base.showWarningTiered(\"String_Node_Str\", AVD_TARGET_PRIMARY, AVD_TARGET_SECONDARY, null);\n } else {\n Base.showWarningTiered(\"String_Node_Str\", AVD_CREATE_PRIMARY, AVD_CREATE_SECONDARY, null);\n System.out.println(createAvdResult);\n }\n } catch (final InterruptedException ie) {\n }\n return false;\n}\n"
"public Response get1() {\n return verify();\n}\n"
"public void testCreateMixedMapFromV8Object() {\n V8Object object = v8.executeObjectScript(\"String_Node_Str\");\n Map<String, ? super Object> map = V8ObjectUtils.toMap(object);\n assertEquals(4, map.size());\n assertTrue((boolean) map.get(\"String_Node_Str\"));\n assertEquals(1, (int) map.get(\"String_Node_Str\"));\n assertEquals(3.14159, (double) map.get(\"String_Node_Str\"), 0.0000001);\n assertEquals(\"String_Node_Str\", map.get(\"String_Node_Str\"));\n object.release();\n}\n"
"protected void drawGuiContainerBackgroundLayer(float v, int x, int y) {\n getShapeRenderer().handleMouseWheel();\n offsetLabel.setText(\"String_Node_Str\" + BlockPosTools.toString(tileEntity.getDataOffset()));\n dimensionLabel.setText(\"String_Node_Str\" + BlockPosTools.toString(tileEntity.getDataDim()));\n drawWindow();\n long currentRF = GenericEnergyStorageTileEntity.getCurrentRF();\n energyBar.setValue(currentRF);\n tileEntity.requestRfFromServer(RFTools.MODID);\n boolean instack = inventorySlots.getSlot(ScannerTileEntity.SLOT_IN).getHasStack();\n if (currentRF < ScannerConfiguration.SCANNER_PERTICK) {\n instack = false;\n }\n if (tileEntity.getScanProgress() >= 0) {\n instack = false;\n progressLabel.setText(tileEntity.getScanProgress() + \"String_Node_Str\");\n } else {\n progressLabel.setText(\"String_Node_Str\");\n }\n scanButton.setEnabled(instack);\n ItemStack stack = tileEntity.getRenderStack();\n if (!stack.isEmpty()) {\n int cnt = countFilters();\n if (cnt != filterCnt) {\n filterCnt = cnt;\n move(0, 0, 0);\n }\n getShapeRenderer().setShapeID(getShapeID());\n getShapeRenderer().renderShape(this, stack, guiLeft, guiTop, showAxis.isPressed(), showOuter.isPressed(), showScan.isPressed(), false);\n }\n}\n"
"public void entryRemoved(EntryEvent event) {\n final ProxyKey proxyKey = (ProxyKey) event.getKey();\n logger.log(Level.FINEST, \"String_Node_Str\" + proxyKey);\n node.clusterService.enqueueAndReturn(new Processable() {\n\n public void process() {\n destroyProxy(proxyKey);\n }\n });\n }\n}\n"
"private void goOneStep(DirectionData directionData, DirectionData otherSide, Map<Integer, List<Path>> hits, boolean stopAsEarlyAsPossible, DirectionData startSide) {\n if (!directionData.hasNext()) {\n return;\n }\n LevelData levelData = directionData.next();\n LevelData otherSideHit = otherSide.visitedNodes.get(levelData.node);\n if (otherSideHit != null) {\n int depth = directionData.currentDepth + otherSideHit.depth;\n if (directionData.sharedFrozenDepth.value == null) {\n directionData.sharedFrozenDepth.value = depth;\n }\n if (depth <= directionData.sharedFrozenDepth.depth) {\n directionData.haveFoundSomething = true;\n if (depth < directionData.sharedFrozenDepth.depth) {\n directionData.sharedFrozenDepth.depth = depth;\n otherSide.stop = true;\n if (stopAsEarlyAsPossible) {\n directionData.sharedStop.value = true;\n }\n }\n List<Path> paths = hits.get(depth);\n if (paths == null) {\n paths = new ArrayList<Path>();\n hits.put(depth, paths);\n }\n Path.Builder startPath = directionData == startSide ? levelData.path : otherSideHit.path;\n Path.Builder endPath = directionData == startSide ? otherSideHit.path : levelData.path;\n paths.add(startPath.build(endPath));\n }\n if (depth == 1) {\n directionData.sharedStop.value = true;\n }\n }\n}\n"
"public void close() throws BirtException {\n if (state == CLOSED)\n return;\n if (this.getRdSaveHelper().needsSaveToDoc()) {\n if (this.isEmpty()) {\n lastRowIndex = odiResult.getCurrentResultIndex() - 1;\n this.prepareCurrentRow();\n } else {\n while (this.next()) ;\n }\n this.getRdSaveHelper().doSaveFinish();\n }\n if (needCache()) {\n while (this.next()) {\n }\n closeCacheOutputStream();\n }\n if (odiResult != null)\n odiResult.close();\n odiResult = null;\n resultService = null;\n state = CLOSED;\n logger.logp(Level.FINE, ResultIterator.class.getName(), \"String_Node_Str\", \"String_Node_Str\");\n}\n"
"public char next() {\n if (!hasNext()) {\n throw new NoSuchElementException();\n }\n fetched = false;\n return next;\n}\n"
"public void start() {\n final Future<Connection> f = client.getClientExecutionService().submit(new InitialConnectionCall());\n try {\n int connectionAttemptPeriodMs = client.getClientConfig().getConnectionAttemptPeriod();\n int connectionAttempts = client.getClientConfig().getConnectionAttemptLimit();\n long timeoutMs = connectionAttempts * connectionAttemptPeriodMs + 1000;\n final Connection connection = f.get(timeoutMs, TimeUnit.MILLISECONDS);\n clusterThread.setInitialConn(connection);\n } catch (Throwable e) {\n if (e instanceof ExecutionException && e.getCause() != null) {\n e = e.getCause();\n fixRemoteStackTrace(e, Thread.currentThread().getStackTrace());\n }\n if (e instanceof RuntimeException) {\n throw (RuntimeException) e;\n }\n throw new HazelcastException(e);\n }\n clusterThread.start();\n while (membersRef.get() == null) {\n try {\n Thread.sleep(100);\n } catch (InterruptedException e) {\n throw new HazelcastException(e);\n }\n }\n active = true;\n}\n"
"private static byte[] encodeSingleByteChars(String s) {\n final int length = s.length();\n final byte[] result = new byte[length];\n encode(s, 0, length, result);\n return result;\n}\n"
"public void createIndex(ClusterName targetCluster, IndexMetadata indexMetadata) throws ConnectorException {\n session = sessions.get(targetCluster.getName());\n CreateIndexStatement indexStatement = new CreateIndexStatement(indexMetadata, true, session);\n try {\n CassandraExecutor.execute(indexStatement.toString(), session);\n } catch (ConnectorException e) {\n String tableName = Utils.toCaseSensitive(indexMetadata.getName().getTableName().getName());\n String catalog = Utils.toCaseSensitive(indexMetadata.getName().getTableName().getCatalogName().getName());\n String remove = \"String_Node_Str\" + catalog + \"String_Node_Str\" + tableName + \"String_Node_Str\" + indexMetadata.getName().getName();\n CassandraExecutor.execute(remove, session);\n throw e;\n }\n}\n"
"public Alert appendLink(HTMLAnchorElement anchorElement) {\n if (nonNull(anchorElement)) {\n anchorElement.classList.add(\"String_Node_Str\");\n element.appendChild(anchorElement);\n }\n return this;\n}\n"
"public static void registerRecipes() {\n ToolUpgrade.addUpgradeRecipes();\n FusionRecipeRegistry.registerRecipe(new SimpleFusionRecipe(new ItemStack(Items.STONE_AXE), new ItemStack(Items.WOODEN_AXE), 1000, 0, new ItemStack(Items.DIAMOND), new ItemStack(Blocks.OBSIDIAN), new ItemStack(DEFeatures.draconiumDust), new ItemStack(DEFeatures.draconicCore)));\n FusionRecipeRegistry.registerRecipe(new SimpleFusionRecipe(new ItemStack(Items.IRON_AXE), new ItemStack(Items.STONE_AXE), 1000, 0, new ItemStack(Items.DIAMOND), new ItemStack(Blocks.OBSIDIAN), new ItemStack(DEFeatures.draconiumDust), new ItemStack(DEFeatures.draconicCore)));\n FusionRecipeRegistry.registerRecipe(new SimpleFusionRecipe(new ItemStack(Items.GOLDEN_AXE), new ItemStack(Items.IRON_AXE), 1000, 0, new ItemStack(Items.DIAMOND), new ItemStack(Blocks.OBSIDIAN), new ItemStack(DEFeatures.draconiumDust), new ItemStack(DEFeatures.draconicCore)));\n FusionRecipeRegistry.registerRecipe(new SimpleFusionRecipe(new ItemStack(Items.DIAMOND_AXE), new ItemStack(Items.GOLDEN_AXE), 1000, 0, new ItemStack(Items.DIAMOND), new ItemStack(Blocks.OBSIDIAN), new ItemStack(DEFeatures.draconiumDust), new ItemStack(DEFeatures.draconicCore)));\n FusionRecipeRegistry.registerRecipe(new SimpleFusionRecipe(new ItemStack(DEFeatures.wyvernAxe), new ItemStack(Items.DIAMOND_AXE), 1000, 0, new ItemStack(Items.DIAMOND), new ItemStack(Blocks.OBSIDIAN), new ItemStack(DEFeatures.draconiumDust), new ItemStack(DEFeatures.draconicCore)));\n FusionRecipeRegistry.registerRecipe(new SimpleFusionRecipe(new ItemStack(Blocks.BEACON, 12), new ItemStack(Blocks.OBSIDIAN), 1000, 3, \"String_Node_Str\", \"String_Node_Str\", \"String_Node_Str\", \"String_Node_Str\", \"String_Node_Str\", new ItemStack(Items.GOLDEN_SWORD), Items.APPLE, Blocks.DIAMOND_ORE));\n FusionRecipeRegistry.registerRecipe(new SimpleFusionRecipe(new ItemStack(Items.STONE_AXE), new ItemStack(Items.WOODEN_AXE), 1000, 0, new ItemStack[] { new ItemStack(DEFeatures.draconicCore) }));\n FusionRecipeRegistry.registerRecipe(new SimpleFusionRecipe(new ItemStack(DEFeatures.wyvernAxe), new ItemStack(Items.DIAMOND_AXE), 10000, 0, new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore), new ItemStack(DEFeatures.draconicCore)));\n}\n"
"public int hashCode() {\n return (connection != null ? connection.hashCode() : super.hashCode());\n}\n"
"public static boolean shouldOverwriteExampleFoodGroup(File exampleFoodGroup) throws IOException {\n FileInputStream exampleFoodGroupStream;\n try {\n exampleFoodGroupStream = new FileInputStream(exampleFoodGroup);\n } catch (FileNotFoundException e) {\n return true;\n }\n BufferedReader exampleFoodGroupReader = null;\n try {\n exampleFoodGroupReader = new BufferedReader(new InputStreamReader(exampleFoodGroupStream, \"String_Node_Str\"));\n String firstLine = exampleFoodGroupReader.readLine();\n return firstLine == null || !firstLine.equals(\"String_Node_Str\" + ModInfo.VERSION);\n } catch (IOException e) {\n throw e;\n } finally {\n MiscHelper.tryCloseStream(exampleFoodGroupReader);\n }\n}\n"
"public UserTO executeAction(HttpServletResponse response, UserTO userTO, String actionName) throws WorkflowException, NotFoundException {\n return userDataBinder.getUserTO(doExecuteAction(actionName, userTO, null), userWorkflow);\n}\n"
"public void handleStatement(Statement st) {\n String subject = st.getSubject().stringValue();\n String object = st.getObject().stringValue();\n addDocumentToIndex(subject, predicate, object);\n}\n"
"public Object applyToKeyInMap(ListConfigKey<T> key, Map target) {\n if (clearFirst) {\n StructuredModification<StructuredConfigKey> clearing = StructuredModifications.clearing();\n clearing.applyToKeyInMap(key, target);\n }\n for (T o : this) target.put(key.subKey(), o);\n return null;\n}\n"
"private void waitForFinish() {\n try {\n Thread.sleep(TIME_OF_SLOW_PROVIDERS + 200);\n } catch (final InterruptedException e) {\n Throws.throwUnhandledException(e);\n }\n}\n"
"public void run(NatTable natTable, MouseEvent event) {\n int rowIndex = natTable.getRowIndexByPosition(natTable.getRowPositionByY(event.y));\n if (rowIndex > 0) {\n swapRows(rowIndex, rowIndex - 1);\n update();\n selectRow(rowIndex - 1);\n }\n}\n"
"public void onServiceConnected(ComponentName className, IBinder service) {\n UrlDeviceDiscoveryService.LocalBinder localBinder = (UrlDeviceDiscoveryService.LocalBinder) service;\n localBinder.getServiceInstance().restartScan();\n mContext.unbindService(this);\n}\n"
"public long readPixel(int x, int y, int band) {\n TIFFImageReadParam t = new TIFFImageReadParam();\n Rectangle rect = new Rectangle(x, y, 1, 1);\n rect = rect.intersection(bounds);\n t.setSourceRegion(rect);\n TIFF tiff = getImage(band);\n try {\n int img = tiff.read(0, t).getRaster().getSample(0, 0, 1);\n int real = tiff.read(0, t).getRaster().getSample(0, 0, 0);\n return (int) Math.sqrt(real * real + img * img);\n } catch (IOException ex) {\n logger.error(ex.getMessage(), ex);\n } catch (ArrayIndexOutOfBoundsException ex) {\n logger.warn(\"String_Node_Str\" + ex.getMessage());\n } catch (IllegalArgumentException iae) {\n logger.warn(iae.getMessage());\n } finally {\n }\n return -1;\n}\n"
"public void onStartScreen() {\n bind(nifty, nifty.getCurrentScreen());\n switch(nifty.getCurrentScreen().getScreenId()) {\n case \"String_Node_Str\":\n mapSelector.reset();\n initSkirmishPlayers();\n break;\n case \"String_Node_Str\":\n inputManager.addRawInputListener(listener);\n break;\n case \"String_Node_Str\":\n Label levelTitle = screen.findNiftyControl(\"String_Node_Str\", Label.class);\n levelTitle.setText(getLevelTitle());\n Label mainObjective = screen.findNiftyControl(\"String_Node_Str\", Label.class);\n mainObjective.setText(getLevelResourceBundle().getString(\"String_Node_Str\"));\n Element mainObjectiveImage = screen.findElementById(\"String_Node_Str\");\n NiftyImage img = nifty.createImage(\"String_Node_Str\" + selectedLevel.getFullName() + \"String_Node_Str\", false);\n mainObjectiveImage.getRenderer(ImageRenderer.class).setImage(img);\n mainObjectiveImage.setWidth(img.getWidth());\n mainObjectiveImage.setHeight(img.getHeight());\n String subText1 = getLevelResourceBundle().getString(\"String_Node_Str\");\n String subText2 = getLevelResourceBundle().getString(\"String_Node_Str\");\n String subText3 = getLevelResourceBundle().getString(\"String_Node_Str\");\n Element subObjectivePanel = screen.findElementById(\"String_Node_Str\");\n subObjectivePanel.hide();\n if (!(subText1.isEmpty() && subText2.isEmpty() && subText3.isEmpty())) {\n subObjectivePanel.show();\n setupSubObjectiveLabel(\"String_Node_Str\", subText1);\n setupSubObjectiveLabel(\"String_Node_Str\", subText2);\n Label subObjective = setupSubObjectiveLabel(\"String_Node_Str\", subText3);\n subObjective.getElement().getParent().layoutElements();\n Element subObjectiveImage = screen.findElementById(\"String_Node_Str\");\n subObjectiveImage.hide();\n if (selectedLevel.getType().equals(Level.LevelType.Level)) {\n subObjectiveImage.show();\n img = nifty.createImage(\"String_Node_Str\" + selectedLevel.getFullName() + \"String_Node_Str\", false);\n subObjectiveImage.getRenderer(ImageRenderer.class).setImage(img);\n subObjectiveImage.setWidth(img.getWidth());\n subObjectiveImage.setHeight(img.getHeight());\n levelBriefing = new AudioNode(assetManager, ConversionUtils.getCanonicalAssetKey(\"String_Node_Str\" + String.format(\"String_Node_Str\", selectedLevel.getLevel()) + \"String_Node_Str\"), DataType.Stream);\n levelBriefing.setLooping(false);\n levelBriefing.setDirectional(false);\n levelBriefing.setPositional(false);\n levelBriefing.play();\n }\n }\n break;\n case \"String_Node_Str\":\n generateHiscoreList();\n break;\n case \"String_Node_Str\":\n setGraphicsSettingsToGUI();\n break;\n case \"String_Node_Str\":\n setControlSettingsToGUI();\n break;\n case \"String_Node_Str\":\n generateMovieList();\n break;\n case \"String_Node_Str\":\n mapSelector.setSkirmish(true);\n populateSelectedMap(mapSelector.getMap());\n populateSkirmishPlayerTable();\n break;\n case \"String_Node_Str\":\n mapSelector.reset();\n break;\n case \"String_Node_Str\":\n mapSelector.setSkirmish(false);\n populateSelectedMap(mapSelector.getMap());\n if (client != null) {\n ListBox<TableRow> players = screen.findNiftyControl(\"String_Node_Str\", ListBox.class);\n if (players != null) {\n players.addItem(new TableRow(players.itemCount(), client.getPlayer()));\n }\n client.setChat(MainMenuState.this.screen.findNiftyControl(\"String_Node_Str\", Chat.class));\n Label title = screen.findNiftyControl(\"String_Node_Str\", Label.class);\n if (title != null) {\n title.setText(client.getClient().getGameName());\n }\n if (client.getRole() == NetworkClient.Role.SLAVE) {\n Element element = screen.findElementById(\"String_Node_Str\");\n if (element != null) {\n element.hide();\n }\n element = screen.findElementById(\"String_Node_Str\");\n if (element != null) {\n element.hide();\n }\n }\n }\n break;\n case \"String_Node_Str\":\n mapSelector.reset();\n break;\n case \"String_Node_Str\":\n {\n populateMapSelection();\n }\n }\n}\n"
"private void advanceStop(VMInstanceVO vm, boolean cleanUpEvenIfUnableToStop) throws AgentUnavailableException, OperationTimedoutException, ConcurrentOperationException {\n State state = vm.getState();\n if (state == State.Stopped) {\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(\"String_Node_Str\" + vm);\n }\n return;\n }\n if (state == State.Destroyed || state == State.Expunging || state == State.Error) {\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(\"String_Node_Str\" + vm + \"String_Node_Str\" + state);\n }\n return;\n }\n ItWorkVO work = _workDao.findByOutstandingWork(vm.getId(), vm.getState());\n if (work != null) {\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(\"String_Node_Str\" + vm + \"String_Node_Str\" + vm.getState() + \"String_Node_Str\" + work.getId());\n }\n }\n Long hostId = vm.getHostId();\n if (hostId == null) {\n if (!cleanUpEvenIfUnableToStop) {\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(\"String_Node_Str\" + vm + \"String_Node_Str\" + vm.getState());\n }\n throw new CloudRuntimeException(\"String_Node_Str\" + vm);\n }\n try {\n stateTransitTo(vm, Event.AgentReportStopped, null, null);\n } catch (NoTransitionException e) {\n s_logger.warn(e.getMessage());\n }\n if (work != null) {\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(\"String_Node_Str\" + work.getId());\n }\n work.setStep(Step.Done);\n _workDao.update(work.getId(), work);\n }\n return;\n }\n VirtualMachineGuru vmGuru = getVmGuru(vm);\n VirtualMachineProfile profile = new VirtualMachineProfileImpl(vm);\n try {\n if (!stateTransitTo(vm, Event.StopRequested, vm.getHostId())) {\n throw new ConcurrentOperationException(\"String_Node_Str\");\n }\n } catch (NoTransitionException e1) {\n if (!cleanUpEvenIfUnableToStop) {\n throw new CloudRuntimeException(\"String_Node_Str\" + vm + \"String_Node_Str\" + vm.getState());\n }\n boolean doCleanup = false;\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(\"String_Node_Str\");\n }\n if ((state == State.Starting) || (state == State.Migrating) || (state == State.Stopping)) {\n if (work != null) {\n doCleanup = true;\n } else {\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(\"String_Node_Str\" + vm + \"String_Node_Str\");\n }\n throw new CloudRuntimeException(\"String_Node_Str\" + vm + \"String_Node_Str\" + vm.getState());\n }\n } else if (state == State.Stopping) {\n doCleanup = true;\n }\n if (doCleanup) {\n if (cleanup(vmGuru, new VirtualMachineProfileImpl(vm), work, Event.StopRequested, cleanUpEvenIfUnableToStop)) {\n try {\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(\"String_Node_Str\" + work.getId());\n }\n if (!changeState(vm, Event.AgentReportStopped, null, work, Step.Done)) {\n throw new CloudRuntimeException(\"String_Node_Str\" + vm);\n }\n } catch (NoTransitionException e) {\n s_logger.warn(\"String_Node_Str\" + vm);\n throw new CloudRuntimeException(\"String_Node_Str\" + vm, e);\n }\n } else {\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(\"String_Node_Str\" + vm);\n }\n throw new CloudRuntimeException(\"String_Node_Str\" + vm + \"String_Node_Str\" + vm.getState());\n }\n }\n }\n if (vm.getState() != State.Stopping) {\n throw new CloudRuntimeException(\"String_Node_Str\" + vm + \"String_Node_Str\" + vm.getState());\n }\n vmGuru.prepareStop(profile);\n StopCommand stop = new StopCommand(vm, getExecuteInSequence(vm.getHypervisorType()), false);\n boolean stopped = false;\n StopAnswer answer = null;\n try {\n answer = (StopAnswer) _agentMgr.send(vm.getHostId(), stop);\n if (answer != null) {\n if (vm.getType() == VirtualMachine.Type.User) {\n String platform = answer.getPlatform();\n if (platform != null) {\n UserVmVO userVm = _userVmDao.findById(vm.getId());\n _userVmDao.loadDetails(userVm);\n userVm.setDetail(\"String_Node_Str\", platform);\n _userVmDao.saveDetails(userVm);\n }\n }\n stopped = answer.getResult();\n if (!stopped) {\n throw new CloudRuntimeException(\"String_Node_Str\" + answer.getDetails());\n }\n vmGuru.finalizeStop(profile, answer);\n GPUDeviceTO gpuDevice = stop.getGpuDevice();\n if (gpuDevice != null) {\n _resourceMgr.updateGPUDetails(vm.getHostId(), gpuDevice.getGroupDetails());\n }\n } else {\n throw new CloudRuntimeException(\"String_Node_Str\" + vm.instanceName);\n }\n } catch (AgentUnavailableException e) {\n s_logger.warn(\"String_Node_Str\" + e.toString());\n } catch (OperationTimedoutException e) {\n s_logger.warn(\"String_Node_Str\" + e.toString());\n } finally {\n if (!stopped) {\n if (!cleanUpEvenIfUnableToStop) {\n s_logger.warn(\"String_Node_Str\" + vm);\n try {\n stateTransitTo(vm, Event.OperationFailed, vm.getHostId());\n } catch (NoTransitionException e) {\n s_logger.warn(\"String_Node_Str\" + vm);\n }\n throw new CloudRuntimeException(\"String_Node_Str\" + vm);\n } else {\n s_logger.warn(\"String_Node_Str\" + vm + \"String_Node_Str\");\n vmGuru.finalizeStop(profile, answer);\n }\n }\n }\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(vm + \"String_Node_Str\");\n }\n try {\n _networkMgr.release(profile, cleanUpEvenIfUnableToStop);\n s_logger.debug(\"String_Node_Str\" + vm);\n } catch (Exception e) {\n s_logger.warn(\"String_Node_Str\", e);\n }\n try {\n if (vm.getHypervisorType() != HypervisorType.BareMetal) {\n volumeMgr.release(profile);\n s_logger.debug(\"String_Node_Str\" + vm);\n }\n } catch (Exception e) {\n s_logger.warn(\"String_Node_Str\", e);\n }\n try {\n if (work != null) {\n if (s_logger.isDebugEnabled()) {\n s_logger.debug(\"String_Node_Str\" + work.getId());\n }\n work.setStep(Step.Done);\n _workDao.update(work.getId(), work);\n }\n if (!stateTransitTo(vm, Event.OperationSucceeded, null)) {\n throw new CloudRuntimeException(\"String_Node_Str\" + vm);\n }\n } catch (NoTransitionException e) {\n s_logger.warn(e.getMessage());\n throw new CloudRuntimeException(\"String_Node_Str\" + vm);\n }\n}\n"
"public void testHashJoinJournalRecordSource() throws Exception {\n bw.append(new Band().setName(\"String_Node_Str\").setType(\"String_Node_Str\").setUrl(\"String_Node_Str\"));\n bw.append(new Band().setName(\"String_Node_Str\").setType(\"String_Node_Str\").setUrl(\"String_Node_Str\"));\n bw.append(new Band().setName(\"String_Node_Str\").setType(\"String_Node_Str\").setUrl(\"String_Node_Str\"));\n bw.append(new Band().setName(\"String_Node_Str\").setType(\"String_Node_Str\").setUrl(\"String_Node_Str\"));\n bw.commit();\n aw.append(new Album().setName(\"String_Node_Str\").setBand(\"String_Node_Str\").setGenre(\"String_Node_Str\"));\n aw.append(new Album().setName(\"String_Node_Str\").setBand(\"String_Node_Str\").setGenre(\"String_Node_Str\"));\n aw.append(new Album().setName(\"String_Node_Str\").setBand(\"String_Node_Str\").setGenre(\"String_Node_Str\"));\n aw.commit();\n StringSink sink = new StringSink();\n RecordSourcePrinter p = new RecordSourcePrinter(sink);\n RecordSource joinResult = new SelectedColumnsRecordSource(new HashJoinRecordSource(new JournalSource(new JournalPartitionSource(bw.getMetadata(), false), new AllRowSource()), new IntList() {\n {\n add(bw.getMetadata().getColumnIndex(\"String_Node_Str\"));\n }\n }, new JournalSource(new JournalPartitionSource(aw.getMetadata(), false), new AllRowSource()), new IntList() {\n {\n add(aw.getMetadata().getColumnIndex(\"String_Node_Str\"));\n }\n }, false, 4 * 1024 * 1024, 4 * 1024 * 1024, 1024 * 1024), new ObjList<CharSequence>() {\n {\n add(\"String_Node_Str\");\n }\n });\n p.print(joinResult, factory);\n Assert.assertEquals(\"String_Node_Str\" + \"String_Node_Str\" + \"String_Node_Str\" + \"String_Node_Str\" + \"String_Node_Str\", sink.toString());\n}\n"